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/07 21:53:00 UTC

[01/17] incubator-geode git commit: GEODE-308: Separate hydra from dunit and junit tests in gemfire-core

Repository: incubator-geode
Updated Branches:
  refs/heads/feature/GEODE-837 1c41d7cbd -> 470cd73ea


GEODE-308: Separate hydra from dunit and junit tests in gemfire-core

Removed hydra classes.

Merge branch 'feature/GEODE-308' of https://github.com/kjduling/incubator-geode into pull


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/fb719d0a
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/fb719d0a
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/fb719d0a

Branch: refs/heads/feature/GEODE-837
Commit: fb719d0a1a5d2a33045c210807b4b4b5c1d80afe
Parents: 61ad7e4
Author: Kevin J. Duling <kd...@pivotal.io>
Authored: Tue May 31 15:39:16 2016 -0700
Committer: Jinmei Liao <ji...@pivotal.io>
Committed: Fri Jun 3 14:10:06 2016 -0700

----------------------------------------------------------------------
 .../PartitionedRegionTestUtilsDUnitTest.java    |  10 +-
 .../gemfire/test/dunit/standalone/ChildVM.java  |  28 +-
 geode-core/src/test/java/hydra/GsRandom.java    | 311 -----------
 .../test/java/hydra/HydraRuntimeException.java  |  33 --
 geode-core/src/test/java/hydra/Log.java         | 219 --------
 .../src/test/java/hydra/LogVersionHelper.java   |  45 --
 .../src/test/java/hydra/log/AnyLogWriter.java   | 555 -------------------
 .../java/hydra/log/CircularOutputStream.java    | 131 -----
 .../parReg/query/unittest/NewPortfolio.java     |  37 +-
 .../src/test/java/perffmwk/Formatter.java       |  14 +-
 .../PartitionedRegionCqQueryDUnitTest.java      |  39 +-
 11 files changed, 51 insertions(+), 1371 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
index c0c7529..d1083ad 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
@@ -17,15 +17,13 @@
 
 package com.gemstone.gemfire.internal.cache;
 
-import hydra.GsRandom;
-
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.io.Serializable;
-import java.util.HashSet;
 import java.util.Iterator;
 import java.util.List;
+import java.util.Random;
 import java.util.Set;
 
 import com.gemstone.gemfire.DataSerializable;
@@ -88,7 +86,7 @@ public class PartitionedRegionTestUtilsDUnitTest extends
     vm0.invoke(new CacheSerializableRunnable("GetSomeKeys") {
       public void run2() throws CacheException {
         PartitionedRegion pr = (PartitionedRegion) getCache().getRegion(r);
-        GsRandom rand = new GsRandom(123);
+        Random rand = new Random(123);
         // Assert that its empty
         for(int i=0; i<5; i++) {
           LogWriterUtils.getLogWriter().info("Invocation " + i + " of getSomeKeys");
@@ -125,7 +123,7 @@ public class PartitionedRegionTestUtilsDUnitTest extends
               val = (Integer) pr.get(key);
               assertNotNull(val);
               assertTrue(val.intValue() >= 0);
-              assertTrue(val.intValue() < MAXKEYS); 
+              assertTrue(val.intValue() < MAXKEYS);
             }
           } catch (ClassNotFoundException cnfe) {
             Assert.fail("GetSomeKeys failed with ClassNotFoundException", cnfe);
@@ -530,7 +528,7 @@ public class PartitionedRegionTestUtilsDUnitTest extends
           assertNotNull(p);
           assertEquals(3, p.getTotalNumberOfBuckets());
           // Create one bucket
-          p.put(new Integer(0), "zero"); 
+          p.put(new Integer(0), "zero");
           assertEquals(1, p.getRegionAdvisor().getCreatedBucketsCount());
         }
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/ChildVM.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/ChildVM.java b/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/ChildVM.java
index 5301ffe..b1fe786 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/ChildVM.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/ChildVM.java
@@ -18,14 +18,12 @@ package com.gemstone.gemfire.test.dunit.standalone;
 
 import java.rmi.Naming;
 
-import hydra.HydraRuntimeException;
-import hydra.Log;
-import org.apache.logging.log4j.Logger;
-
 import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.logging.LogService;
 import com.gemstone.gemfire.test.dunit.standalone.DUnitLauncher.MasterRemote;
 
+import org.apache.logging.log4j.Logger;
+
 /**
  *
  */
@@ -39,24 +37,19 @@ public class ChildVM {
   public static void stopVM() {
     stopMainLoop = true;
   }
-  
-  static {
-    createHydraLogWriter();
-  }
-  
+
   private final static Logger logger = LogService.getLogger();
-  private static RemoteDUnitVM dunitVM;
-  
+
   public static void main(String[] args) throws Throwable {
     try {
-      int namingPort = Integer.getInteger(DUnitLauncher.RMI_PORT_PARAM).intValue();
-      int vmNum = Integer.getInteger(DUnitLauncher.VM_NUM_PARAM).intValue();
+      int namingPort = Integer.getInteger(DUnitLauncher.RMI_PORT_PARAM);
+      int vmNum = Integer.getInteger(DUnitLauncher.VM_NUM_PARAM);
       int pid = OSProcess.getId();
       logger.info("VM" + vmNum + " is launching" + (pid > 0? " with PID " + pid : ""));
       MasterRemote holder = (MasterRemote) Naming.lookup("//localhost:" + namingPort + "/" + DUnitLauncher.MASTER_PARAM);
       DUnitLauncher.init(holder);
       DUnitLauncher.locatorPort = holder.getLocatorPort();
-      dunitVM = new RemoteDUnitVM();
+      final RemoteDUnitVM dunitVM = new RemoteDUnitVM();
       Naming.rebind("//localhost:" + namingPort + "/vm" + vmNum, dunitVM);
       holder.signalVMReady();
       //This loop is here so this VM will die even if the master is mean killed.
@@ -69,11 +62,4 @@ public class ChildVM {
       System.exit(1);
     }
   }
-
-  private static void createHydraLogWriter() {
-    try {
-      Log.createLogWriter("dunit-childvm", "fine");
-    } catch (HydraRuntimeException ignore) {
-    }
-  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/hydra/GsRandom.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/hydra/GsRandom.java b/geode-core/src/test/java/hydra/GsRandom.java
deleted file mode 100644
index bed02da..0000000
--- a/geode-core/src/test/java/hydra/GsRandom.java
+++ /dev/null
@@ -1,311 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package hydra;
-
-import java.io.*;
-import java.util.*;
-
-/**
-  * This is a simple extension of java.util.Random that allows for the
-  * generation of random numbers within ranges. It also allows for the
-  * generation of random strings (within ranges as well).
-  * @see     java.lang.Math#random()
-  * @see     java.util.Random
-  * @since   JDK1.0
-  */
-
-public class GsRandom extends java.util.Random implements Serializable {
-  
-  /**
-    *
-    * ourString is a privately held instance of a String with 
-    * with some junk characters 
-    *
-    */
-  
-  static protected String ourString = "854ku45Q985a.lsdk;,.ifpq4z58Ao45u.sdflkjsdgkjqwJKL:EIUR[p4pnm,.zxc239*h1@0*Fn/~5.+3&gwNa(.3K-c/2bd(kb1.(=wvz!/56NIwk-4/(#mDhn%kd#9jas9_n!KC0-c>3*(fbn3Fl)Fhaw.2?nz~l;1q3=Fbak1>ah1Bci23fripB319v*bnFl2Ba-cH$lfb?A)_2bgFo2_+Vv$al+b124kasbFV[2G}b@9ASFbCk2.KIhb4K";
-
-  /** 
-    * Creates a new random number generator. Its seed is initialized to 
-    * a value based on the current time. 
-    *
-    * @see     java.lang.System#currentTimeMillis()
-    * @see     java.util.Random#Random()
-    */
-  
-  public GsRandom() {
-    super();
-  }
-  
-  /** 
-    * Creates a new random number generator using a single 
-    * <code>long</code> seed. 
-    *
-    * @param   seed   the initial seed.
-    * @see     java.util.Random#Random(long)
-    */
-
-  public GsRandom(long seed) {
-    super(seed);
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>boolean</code>
-    * value from this random number generator's sequence
-    *
-    * @return the next pseudorandom, uniformly distributed <code>boolean</code>
-    *         value from this random number generator's sequence.
-    */
-
-  public boolean nextBoolean() {
-
-    return (this.next(1) == 0);
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>char</code>
-    * value from this random number generator's sequence
-    * There is a hack here to prevent '}' so as to eliminate the possiblity 
-    * of generating a sequence which would falsely get marked as a suspect
-    * string while we are matching the pattern <code>{[0-9]+}</code>.
-    * @return the next pseudorandom, uniformly distributed <code>char</code>
-    *         value from this random number generator's sequence.
-    */
-
-  public char nextChar() {
-
-    char c = (char) this.next(16);
-    if( c == '}' ) c = nextChar(); //prevent right bracket, try again
-    return c;
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>byte</code>
-    * value from this random number generator's sequence
-    *
-    * @return the next pseudorandom, uniformly distributed <code>byte</code>
-    *         value from this random number generator's sequence.
-    */
-
-  public byte nextByte() {
-
-    return (byte) this.next(8);
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>double</code>
-    * value from this random number generator's sequence within a range
-    * from 0 to max.
-    *
-    * @param   max the maximum range (inclusive) for the pseudorandom.
-    * @return  the next pseudorandom, uniformly distributed <code>double</code>
-    *          value from this random number generator's sequence.
-    */
-  public double nextDouble(double max) {
-
-    return nextDouble(0.0, max);
-
-  } 
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>double</code>
-    * value from this random number generator's sequence within a range
-    * from min to max.
-    *
-    * @param   min the minimum range (inclusive) for the pseudorandom.
-    * @param   max the maximum range (inclusive) for the pseudorandom.
-    * @return  the next pseudorandom, uniformly distributed <code>double</code>
-    *          value from this random number generator's sequence.
-    */
-
-  public double nextDouble(double min, double max) {
-
-    return nextDouble() * (max - min) + min;
-
-    // return nextDouble(max-min) + min;
-  }
-
-  public short nextShort() {
-    return (short) this.nextChar();
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>long</code>
-    * value from this random number generator's sequence within a range
-    * from 0 to max.
-    *
-    * @param   max the maximum range (inclusive) for the pseudorandom.
-    * @return  the next pseudorandom, uniformly distributed <code>long</code>
-    *          value from this random number generator's sequence.
-    */
-
-  public long nextLong(long max) {
-
-    if (max == Long.MAX_VALUE) {
-      max--;
-    }
-
-    return Math.abs(this.nextLong()) % (max+1);
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>long</code>
-    * value from this random number generator's sequence within a range
-    * from min to max.
-    *
-    * @param   min the minimum range (inclusive) for the pseudorandom.
-    * @param   max the maximum range (inclusive) for the pseudorandom.
-    * @return  the next pseudorandom, uniformly distributed <code>long</code>
-    *          value from this random number generator's sequence.
-    */
-
-  public long nextLong(long min, long max) {
-
-
-    return nextLong(max-min) + min;
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>int</code>
-    * value from this random number generator's sequence within a range
-    * from 0 to max (inclusive -- which is different from {@link
-    * Random#nextInt}).
-    *
-    * @param   max the maximum range (inclusive) for the pseudorandom.
-    * @return  the next pseudorandom, uniformly distributed <code>int</code>
-    *          value from this random number generator's sequence.
-    */
-
-  public int nextInt(int max) {
-
-    if (max == Integer.MAX_VALUE) {
-      max--;
-    }
-    
-    int theNext = this.nextInt();
-    // Math.abs behaves badly when given min int, so avoid
-    if (theNext == Integer.MIN_VALUE) {
-        theNext = Integer.MIN_VALUE + 1;
-    }
-    return Math.abs(theNext) % (max+1);
-  }
-
-  /**
-    * Returns the next pseudorandom, uniformly distributed <code>int</code>
-    * value from this random number generator's sequence within a range
-    * from min to max.
-    * If max < min, returns 0 .
-    *
-    * @param   min the minimum range (inclusive) for the pseudorandom.
-    * @param   max the maximum range (inclusive) for the pseudorandom.
-    * @return  the next pseudorandom, uniformly distributed <code>int</code>
-    *          value from this random number generator's sequence.
-    */
-
-  public int nextInt(int min, int max) {
-    if (max < min)
-      return 0;  // handle max == 0 and avoid  divide-by-zero exceptions
-
-    return nextInt(max-min) + min;
-  }
-
-  /**
-    * Returns a large, pregenerated string.
-    *
-    * @return a large, pregenerated string.
-    */
-
-  private String string() {
-    return ourString;
-  }
-
-  /**
-    *
-    * Returns a random Date.
-    * 
-    * @return  A random Date.
-    */
- 
-  public Date nextDate() {
-    return new Date(nextLong());
-  }
- 
-  /** 
-  *
-  * Returns a randomly-selected element of Vector vec. 
-  *
-  */
-  public Object randomElement(Vector vec) {
-    Object result;
-    synchronized (vec) {                           // fix 26810
-      int index =  nextInt(0, vec.size() - 1);
-      result = vec.elementAt(index);
-    }
-    return result;
-  }
-
-  /**
-    * Returns a random subset of a pregenerated string. Both the
-    * length and offset of the string are pseudorandom values.
-    *
-    * @return a random subset of a pregenerated string.
-    */
-
-  public String randomString() {
-
-    return this.randomString(this.string().length());
-  }
-
-  /**
-    * Returns a bounded random subset of a pregenerated large
-    * string. The length can be no longer than max. max must be no
-    * longer than the length of the pregenerated string.
-    *
-    * @param max the maximum length of the random string to generate.
-    * @return a bounded random string with a length between 0 and
-    * max length inclusive.
-    */
-
-  public String randomString(int max) {
-
-    int length = this.nextInt(0, max);
-    byte[] bytes = new byte[length];
-    this.nextBytes(bytes);
-    return new String(bytes);
-  }
-
-  /**
-    * 
-    * Like randomString(), but returns only readable characters.
-    *
-    */
-  public String randomReadableString(int max) {
-
-    int stringlen = this.string().length();
-    if ( max > stringlen )
-      throw new HydraRuntimeException
-      (
-        "GsRandom.randomReadableString is limited to " + stringlen +
-        " characters, cannot create string of length " + max
-      );
-
-    int length = this.nextInt(0, max);
-    int offset = this.nextInt(0, stringlen - length);
-    return this.string().substring(offset, offset+length);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/hydra/HydraRuntimeException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/hydra/HydraRuntimeException.java b/geode-core/src/test/java/hydra/HydraRuntimeException.java
deleted file mode 100644
index 668c191..0000000
--- a/geode-core/src/test/java/hydra/HydraRuntimeException.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package hydra;
-
-import com.gemstone.gemfire.*;
-
-public class HydraRuntimeException extends GemFireException {
-
-    public HydraRuntimeException(String s) {
-        super(s);
-    }
-    public HydraRuntimeException(String s,Exception e) {
-        super(s,e);
-    }
-    public HydraRuntimeException(String s,Throwable t) {
-        super(s,t);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/hydra/Log.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/hydra/Log.java b/geode-core/src/test/java/hydra/Log.java
deleted file mode 100644
index 2c306be..0000000
--- a/geode-core/src/test/java/hydra/Log.java
+++ /dev/null
@@ -1,219 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package hydra;
-
-import com.gemstone.gemfire.LogWriter;
-
-import hydra.log.AnyLogWriter;
-
-import java.util.Hashtable;
-
-/**
-*
-* Manages a singleton instance of {@link com.gemstone.gemfire.LogWriter}
-* to do all the logging for a VM.  The instance is created using
-* <code>createLogWriter</code> and accessed using <code>getLogWriter</code>.
-*
-*/
-public class Log { 
-
-  // the singleton instance
-  private static AnyLogWriter logWriter;
-
-  // the name of the singleton instance
-  private static String logName;
-
-  // cache for log writers
-  private static Hashtable cache;
-
-  /**
-  * Creates a singleton log writer that logs to stdout.
-  * @param name the name of the singleton log writer.
-  * @param levelName only messages at this level or higher will be logged.
-  * @return the singleton log writer.
-  * @throws HydraRuntimeException if log writer has already been created.
-  * @throws IllegalArgumentException if level is illegal.
-  */
-  public synchronized static LogWriter createLogWriter( String name, String levelName ) {
-    if ( logWriter == null ) {
-      logWriter = new AnyLogWriter( levelName );
-    } else {
-      throw new HydraRuntimeException( "Log writer has already been created" );
-    }
-    logName = name;
-    return logWriter;
-  }
-  /**
-  * Creates a singleton log writer that logs to a file.
-  * @param name the name of the singleton log writer.
-  * @param filePrefix the prefix for the name of the log file.
-  * @param levelName only messages at this level or higher will be logged.
-  * @param append whether to append to an existing log file.
-  * @return the singleton log writer.
-  * @throws HydraRuntimeException if log writer has already been created.
-  * @throws IllegalArgumentException if level is illegal.
-  */
-  public synchronized static LogWriter createLogWriter( String name, String filePrefix, String levelName, boolean append ) {
-    if ( logWriter == null ) {
-      logWriter = new AnyLogWriter( filePrefix, levelName, append );
-    } else {
-      throw new HydraRuntimeException( "Log writer has already been created" );
-    }
-    logName = name;
-    return logWriter;
-  }
-  /**
-  * Creates a singleton log writer that logs to a file in a specified directory.
-  * @param name the name of the singleton log writer.
-  * @param filePrefix the prefix for the name of the log file.
-  * @param levelName only messages at this level or higher will be logged.
-  * @param dir the directory in which to create the log file.
-  * @param append whether to append to an existing log file.
-  * @return the singleton log writer.
-  * @throws HydraRuntimeException if log writer has already been created.
-  * @throws IllegalArgumentException if level is illegal.
-  */
-  public synchronized static LogWriter createLogWriter( String name, String filePrefix, String levelName, String dir, boolean append ) {
-    if ( logWriter == null ) {
-      logWriter = new AnyLogWriter( filePrefix, levelName, dir, append );
-    } else {
-      throw new HydraRuntimeException( "Log writer has already been created" );
-    }
-    logName = name;
-    return logWriter;
-  }
-  /**
-  * Creates a singleton log writer that logs to a file.
-  * @param name the name of the singleton log writer.
-  * @param filePrefix the prefix for files created by this log writer.
-  *
-  * @return the singleton log writer.
-  * @throws HydraRuntimeException if file can't be created or if log writer has
-  *         already been created.
-  * @throws IllegalArgumentException if level is illegal.
-  */
-  public synchronized static LogWriter createLogWriter( String name,
-                                                        String filePrefix,
-                                                        boolean fileLogging,
-                                                        String fileLogLevelName,
-                                                        int fileMaxKBPerVM ) {
-    if ( logWriter == null ) {
-      logWriter = new AnyLogWriter( filePrefix, fileLogging, fileLogLevelName,
-                                    fileMaxKBPerVM );
-    } else {
-      throw new HydraRuntimeException( "Log writer has already been created" );
-    }
-    logName = name;
-    return logWriter;
-  }
-  /**
-  * Closes the singleton log writer.  After this method executes, there is no
-  * singleton log writer.
-  * @throws HydraRuntimeException if the singleton log writer does not exist.
-  */
-  public static void closeLogWriter() {
-    if ( logWriter == null ) {
-      throw new HydraRuntimeException( "Log writer does not exist" );
-    } else {
-      logName = null;
-      logWriter = null;
-    }
-  }
-  /**
-  * Caches the singleton log writer so another log writer can be created.
-  * After this method executes, there is no singleton log writer.
-  * @throws HydraRuntimeException if the singleton log writer does not exist or
-  *                               has already been cached.
-  */
-  public static void cacheLogWriter() {
-    if ( logWriter == null ) {
-      throw new HydraRuntimeException( "Log writer has not been created" );
-    } else {
-      if ( cache == null )
-        cache = new Hashtable();
-      if ( cache.get( logName ) != null )
-        throw new HydraRuntimeException( "Log writer " + logName + " has already been cached" );
-      cache.put( logName, logWriter );
-      logName = null;
-      logWriter = null;
-    }
-  }
-  /**
-  * Uncaches the log writer with the specified name, blowing away the existing one
-  * (unless it was previously cached).  After this method executes, the named log
-  * writer is the singleton log writer.
-  * @param name the name of the log writer to uncache.
-  * @return the uncached (now active) log writer.
-  * @throws HydraRuntimeException if the named log writer does not exist or there
-  *                               is already a singleton log writer.
-  */
-  public static LogWriter uncacheLogWriter( String name ) {
-    if ( cache == null )
-      throw new HydraRuntimeException( "Log writer " + name + " has not been cached" );
-    if ( logWriter != null )
-      throw new HydraRuntimeException( "Log writer " + name + " is still active" );
-    AnyLogWriter lw = (AnyLogWriter) cache.get( name );
-    if ( lw == null )
-      throw new HydraRuntimeException( "Log writer " + name + " has not been cached" );
-    logName = name;
-    logWriter = lw;
-    return logWriter;
-  }
-  /**
-  * Fetches the singleton log writer.
-  * @throws HydraRuntimeException if log writer has not been created.
-  */
-  public static LogWriter getLogWriter() {
-    if ( logWriter == null )
-      throw new HydraRuntimeException( "Attempt to getLogWriter() before createLogWriter()" );
-    return logWriter;
-  }
-  /**
-  *
-  * Fetches the current log level of the singleton log writer.
-  *
-  */
-  public static String getLogWriterLevel() {
-    return LogVersionHelper.levelToString(logWriter.getLevel());
-  }
-  /**
-  *
-  * Resets the log level of the singleton log writer.
-  *
-  */
-  public static void setLogWriterLevel( String levelName ) {
-    logWriter.setLevel(LogVersionHelper.levelNameToCode(levelName));
-  }
-  /**
-  * Small Log test program
-  */
-  public static void main(String[] args) {
-     Thread.currentThread().setName( "chester" );
-
-     Log.createLogWriter( "test", "finer" );
-
-     Log.getLogWriter().fine( "fine" );
-     Log.getLogWriter().finer( "finer" );
-     Log.getLogWriter().finest( "finest" );
-
-     Log.setLogWriterLevel( "all" );
-     Log.getLogWriter().fine( "fine" );
-     Log.getLogWriter().finer( "finer" );
-     Log.getLogWriter().finest( "finest" );
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/hydra/LogVersionHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/hydra/LogVersionHelper.java b/geode-core/src/test/java/hydra/LogVersionHelper.java
deleted file mode 100644
index 9278ab2..0000000
--- a/geode-core/src/test/java/hydra/LogVersionHelper.java
+++ /dev/null
@@ -1,45 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package hydra;
-
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.LogWriterImpl;
-import com.gemstone.gemfire.LogWriter;
-
-/**
- * Provides version-dependent support for logging changes.
- */
-public class LogVersionHelper {
-
-  protected static String levelToString(int level) {
-    return LogWriterImpl.levelToString(level);
-  }
-
-  protected static int levelNameToCode(String level) {
-    return LogWriterImpl.levelNameToCode(level);
-  }
-
-  protected static ThreadGroup getLoggingThreadGroup(String group, LogWriter logger) {
-    return LoggingThreadGroup.createThreadGroup(group, (InternalLogWriter)logger);
-  }
-
-  protected static String getMergeLogFilesClassName() {
-    return "com.gemstone.gemfire.internal.logging.MergeLogFiles";
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/hydra/log/AnyLogWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/hydra/log/AnyLogWriter.java b/geode-core/src/test/java/hydra/log/AnyLogWriter.java
deleted file mode 100644
index 369f35b..0000000
--- a/geode-core/src/test/java/hydra/log/AnyLogWriter.java
+++ /dev/null
@@ -1,555 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package hydra.log;
-
-import hydra.HydraRuntimeException;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LocalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogWriterImpl;
-import com.gemstone.gemfire.i18n.StringId;
-
-import java.io.*;
-
-/**
- *
- *  A {@link com.gemstone.gemfire.LogWriter} that writes to a file logger,
- *  depending on whether it is turned on via LogPrms#file_logging.
- *  <p>
- *  The log level query methods answer true if a file logger is active and
- *  answer true.  See LogPrms#file_logLevel.
- */
-
-public class AnyLogWriter implements InternalLogWriter {
-
-  private boolean FILE_LOGGING;
-//  private String filePrefix;
-  private InternalLogWriter file;
-
-  /**
-   *  Create a log writer to stdout.
-   *  @param levelName the log level.
-   */
-  public AnyLogWriter( String levelName ) {
-    this.FILE_LOGGING = true;
-    int level = LogWriterImpl.levelNameToCode( levelName );
-    this.file = new LocalLogWriter( level, System.out );
-  }
-
-  /**
-   *  Create a log writer to a file of unlimited size.
-   *  @param filePrefix the prefix for the filename of the log.
-   *  @param levelName the log level.
-   */
-  public AnyLogWriter( String filePrefix, String levelName, boolean append ) {
-    this.FILE_LOGGING = true;
-    FileOutputStream fos;
-    String fn = filePrefix + ".log";
-    try {
-      fos = new FileOutputStream( fn, append );
-    } catch( IOException e ) {
-      throw new HydraRuntimeException( "Unable to open " + fn, e );
-    }
-    PrintStream ps = new PrintStream( fos, true ); // autoflush
-    System.setOut( ps ); System.setErr( ps );
-    int level = LogWriterImpl.levelNameToCode( levelName );
-    this.file = new LocalLogWriter( level, ps );
-  }
-
-  /**
-   *  Create a log writer to a file of unlimited size in the specified directory.
-   *  @param filePrefix the prefix for the filename of the log.
-   *  @param levelName the log level.
-   *  @param dir the directory in which to create the file.
-   */
-  public AnyLogWriter( String filePrefix, String levelName, String dir, boolean append ) {
-    this.FILE_LOGGING = true;
-    FileOutputStream fos;
-    String fn = dir + File.separator + filePrefix + ".log";
-    try {
-      fos = new FileOutputStream( fn, append );
-    } catch( IOException e ) {
-      throw new HydraRuntimeException( "Unable to open " + fn, e );
-    }
-    PrintStream ps = new PrintStream( fos, true ); // autoflush
-    System.setOut( ps ); System.setErr( ps );
-    int level = LogWriterImpl.levelNameToCode( levelName );
-    this.file = new LocalLogWriter( level, ps );
-  }
-
-  /**
-   *  Create a log writer to a file.  May be circular.
-   *  @param filePrefix the prefix for names of files created by this logwriter.
-   *  @param fileLogging turn on logging to the file.
-   *  @param fileLogLevelName name of the file log level.
-   *  @param fileMaxKBPerVM the maximum size of the file log per VM, in kilobytes .
-   */
-  public AnyLogWriter( String filePrefix, boolean fileLogging,
-                       String fileLogLevelName, int fileMaxKBPerVM ) {
-
-//    this.filePrefix = filePrefix;
-    if ( fileLogging ) {
-      this.FILE_LOGGING = fileLogging;
-      if ( fileMaxKBPerVM < 0 )
-        throw new IllegalArgumentException( "Illegal (negative) file log length: " + fileMaxKBPerVM );
-      int maxBytes = fileMaxKBPerVM * 1024;
-      CircularOutputStream cos;
-      String fn = filePrefix + ".log";
-      try {
-        cos = new CircularOutputStream( fn, maxBytes );
-      } catch( IOException e ) {
-        throw new HydraRuntimeException( "Unable to create " + fn, e );
-      }
-      // create a local log writer using the circular file
-      int level = LogWriterImpl.levelNameToCode( fileLogLevelName );
-      this.file = new LocalLogWriter( level, new PrintStream( cos ) );
-    }
-  }
-
-  /**
-   *  Gets the writer's level.  Returns the level obtained from active logger.
-   */
-  public int getLevel() {
-    if ( FILE_LOGGING )
-      return ((LocalLogWriter)file).getLogWriterLevel();
-    else
-      return LogWriterImpl.NONE_LEVEL;
-  }
-  /**
-   *  Sets the writer's level.  Applies to any active logger.
-   *  @throws IllegalArgumentException if level is not in legal range
-   */
-  public void setLevel(int newLevel) {
-    if ( FILE_LOGGING )
-      ((LocalLogWriter)file).setLevel( newLevel );
-  }
-
-  public void setLogWriterLevel(int newLevel) {
-    setLevel(newLevel);
-  }
-  
-////////////////////////////////////////////////////////////////////////////////
-////                           LOGWRITER INTERFACE                         /////
-////////////////////////////////////////////////////////////////////////////////
-
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#severeEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean severeEnabled() {
-    if ( FILE_LOGGING )
-      return file.severeEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#severe(String,Throwable)}.
-   */
-  public void severe(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.severe(msg,ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#severe(String)}.
-   */
-  public void severe(String msg) {
-    if ( FILE_LOGGING ) file.severe(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#severe(Throwable)}.
-   */
-  public void severe(Throwable ex) {
-    if ( FILE_LOGGING ) file.severe(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#errorEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean errorEnabled() {
-    if ( FILE_LOGGING )
-      return file.errorEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#error(String,Throwable)}.
-   */
-  public void error(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.error(msg, ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#error(String)}.
-   */
-  public void error(String msg) {
-    if ( FILE_LOGGING ) file.error(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#error(Throwable)}.
-   */
-  public void error(Throwable ex) {
-    if ( FILE_LOGGING ) file.error(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#warningEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean warningEnabled() {
-    if ( FILE_LOGGING )
-      return file.warningEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#warning(String,Throwable)}.
-   */
-  public void warning(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.warning(msg,ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#warning(String)}.
-   */
-  public void warning(String msg) {
-    if ( FILE_LOGGING ) file.warning(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#warning(Throwable)}.
-   */
-  public void warning(Throwable ex) {
-    if ( FILE_LOGGING ) file.warning(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#infoEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean infoEnabled() {
-    if ( FILE_LOGGING )
-      return file.infoEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#info(String,Throwable)}.
-   */
-  public void info(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.info(msg,ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#info(String)}.
-   */
-  public void info(String msg) {
-    if ( FILE_LOGGING ) file.info(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#info(Throwable)}.
-   */
-  public void info(Throwable ex) {
-    if ( FILE_LOGGING ) file.info(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#configEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean configEnabled() {
-    if ( FILE_LOGGING )
-      return file.configEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#config(String,Throwable)}.
-   */
-  public void config(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.config(msg,ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#config(String)}.
-   */
-  public void config(String msg) {
-    if ( FILE_LOGGING ) file.config(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#config(Throwable)}.
-   */
-  public void config(Throwable ex) {
-    if ( FILE_LOGGING ) file.config(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#fineEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean fineEnabled() {
-    if ( FILE_LOGGING )
-      return file.fineEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#fine(String,Throwable)}.
-   */
-  public void fine(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.fine(msg,ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#fine(String)}.
-   */
-  public void fine(String msg) {
-    if ( FILE_LOGGING ) file.fine(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#fine(Throwable)}.
-   */
-  public void fine(Throwable ex) {
-    if ( FILE_LOGGING ) file.fine(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finerEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean finerEnabled() {
-    if ( FILE_LOGGING )
-      return file.finerEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finer(String,Throwable)}.
-   */
-  public void finer(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.finer(msg,ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finer(String)}.
-   */
-  public void finer(String msg) {
-    if ( FILE_LOGGING ) file.finer(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finer(Throwable)}.
-   */
-  public void finer(Throwable ex) {
-    if ( FILE_LOGGING ) file.finer(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finestEnabled}.
-   *  Answers true if the file logger answers true.
-   */
-  public boolean finestEnabled() {
-    if ( FILE_LOGGING )
-      return file.finestEnabled();
-    else
-      return false;
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finest(String,Throwable)}.
-   */
-  public void finest(String msg, Throwable ex) {
-    if ( FILE_LOGGING ) file.finest(msg,ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finest(String)}.
-   */
-  public void finest(String msg) {
-    if ( FILE_LOGGING ) file.finest(msg);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#finest(Throwable)}.
-   */
-  public void finest(Throwable ex) {
-    if ( FILE_LOGGING ) file.finest(ex);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#entering(String,String)}.
-   */
-  public void entering(String sourceClass, String sourceMethod) {
-    if ( FILE_LOGGING ) file.entering(sourceClass,sourceMethod);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#exiting(String,String)}.
-   */
-  public void exiting(String sourceClass, String sourceMethod) {
-    if ( FILE_LOGGING ) file.exiting(sourceClass,sourceMethod);
-  }
-  /**
-   *  Implements {@link com.gemstone.gemfire.LogWriter#throwing(String,String,Throwable)}.
-   */
-  public void throwing(String sourceClass, String sourceMethod, Throwable thrown) {
-    if ( FILE_LOGGING ) file.throwing(sourceClass,sourceMethod,thrown);
-  }
-  public java.util.logging.Handler getHandler() {
-    return null;
-  }
-
-  public void config(StringId msgId, Object param, Throwable ex) {
-    config(msgId.toLocalizedString(param), ex);  
-  }
-
-  public void config(StringId msgId, Object param) {
-    config(msgId.toLocalizedString(param));
-  }
-
-  public void config(StringId msgId, Object[] params, Throwable ex) {
-    config(msgId.toLocalizedString(params), ex);
-  }
-
-  public void config(StringId msgId, Object[] params) {
-    config(msgId.toLocalizedString(params));
-  }
-
-  public void config(StringId msgId, Throwable ex) {
-    config(msgId.toLocalizedString(), ex);
-  }
-
-  public void config(StringId msgId) {
-    config(msgId.toLocalizedString());
-  }
-
-  public void error(StringId msgId, Object param, Throwable ex) {
-    error(msgId.toLocalizedString(param), ex);
-  }
-
-  public void error(StringId msgId, Object param) {
-    error(msgId.toLocalizedString(param));
-  }
-
-  public void error(StringId msgId, Object[] params, Throwable ex) {
-    error(msgId.toLocalizedString(params), ex);
-  }
-
-  public void error(StringId msgId, Object[] params) {
-    error(msgId.toLocalizedString(params));
-  }
-
-  public void error(StringId msgId, Throwable ex) {
-    error(msgId.toLocalizedString(), ex);
-  }
-
-  public void error(StringId msgId) {
-    error(msgId.toLocalizedString());
-  }
-
-  public void info(StringId msgId, Object param, Throwable ex) {
-    info(msgId.toLocalizedString(param), ex);    
-  }
-
-  public void info(StringId msgId, Object param) {
-    info(msgId.toLocalizedString(param));
-  }
-
-  public void info(StringId msgId, Object[] params, Throwable ex) {
-    info(msgId.toLocalizedString(params), ex); 
-  }
-
-  public void info(StringId msgId, Object[] params) {
-    info(msgId.toLocalizedString(params));    
-  }
-
-  public void info(StringId msgId, Throwable ex) {
-    info(msgId.toLocalizedString(), ex);  
-  }
-  
-  public void info(StringId msgId) {
-    info(msgId.toLocalizedString()); 
-  }
-
-  public void severe(StringId msgId, Object param, Throwable ex) {
-    severe(msgId.toLocalizedString(param), ex);
-  }
-
-  public void severe(StringId msgId, Object param) {
-    severe(msgId.toLocalizedString(param));
-  }
-
-  public void severe(StringId msgId, Object[] params, Throwable ex) {
-    severe(msgId.toLocalizedString(params), ex); 
-  }
-
-  public void severe(StringId msgId, Object[] params) {
-    severe(msgId.toLocalizedString(params));
-  }
-
-  public void severe(StringId msgId, Throwable ex) {
-    severe(msgId.toLocalizedString(), ex);    
-  }
-  
-  public void severe(StringId msgId) {
-    severe(msgId.toLocalizedString());
-  }
-
-  public void warning(StringId msgId, Object param, Throwable ex) {
-    warning(msgId.toLocalizedString(param), ex);
-  }
-
-  public void warning(StringId msgId, Object param) {
-    warning(msgId.toLocalizedString(param));
-  }
-
-  public void warning(StringId msgId, Object[] params, Throwable ex) {
-    warning(msgId.toLocalizedString(params), ex);
-  }
-
-  public void warning(StringId msgId, Object[] params) {
-    warning(msgId.toLocalizedString(params));
-  }
-
-  public void warning(StringId msgId, Throwable ex) {
-    warning(msgId.toLocalizedString(), ex);
-  }
-    
-  public void warning(StringId msgId) {
-    warning(msgId.toLocalizedString()); 
-  }
-  /* (non-Javadoc)
-   * @see com.gemstone.gemfire.LogWriterI18n#convertToLogWriter()
-   */ 
-  public LogWriter convertToLogWriter() {
-    return this;
-  }
-
-  /* (non-Javadoc)
-   * @see com.gemstone.gemfire.LogWriter#convertToLogWriterI18n()
-   */
-  public LogWriterI18n convertToLogWriterI18n() {
-    return this;
-  }
-
-  @Override
-  public int getLogWriterLevel() {
-    return file.getLogWriterLevel();
-  }
-  
-  @Override
-  public boolean isSecure() {
-    return false;
-  }
-  
-  @Override
-  public String getConnectionName() {
-    return null;
-  }
-
-  @Override
-  public void put(int msgLevel, String msg, Throwable exception) {
-    file.put(msgLevel, msg, exception);
-  }
-
-  @Override
-  public void put(int msgLevel, StringId msgId, Object[] params,Throwable exception) {
-    file.put(msgLevel, msgId, params, exception);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/hydra/log/CircularOutputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/hydra/log/CircularOutputStream.java b/geode-core/src/test/java/hydra/log/CircularOutputStream.java
deleted file mode 100644
index 266f57d..0000000
--- a/geode-core/src/test/java/hydra/log/CircularOutputStream.java
+++ /dev/null
@@ -1,131 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package hydra.log;
-
-import java.io.*;
-
-/**
- *  Implements a circular output stream with an upper limit on the number of bytes
- *  it contains.
- */
-public class CircularOutputStream extends OutputStream {
-  
-  private static byte marker = '%';
-
-  String name;
-  int maxBytes;
-  boolean rolling = false;
-  RandomAccessFile raf;
-
-  /**
-   *  Constructs a new circular output stream.
-   *  @param name the name of the output stream.
-   *  @param maxBytes the maximum number of bytes in the output stream.
-   *  @throws IOException if the stream cannot be created or written.
-   */
-  public CircularOutputStream( String name, int maxBytes )
-  throws IOException {
-    this.name = name;
-    this.maxBytes = maxBytes;
-    this.rolling = ( maxBytes > 0 );
-    try {
-      this.raf = new RandomAccessFile( name, "rw" );
-    } catch( FileNotFoundException e ) {
-      e.printStackTrace();
-      throw new IOException( "Unable to create stream named " + name );
-    }
-    if ( this.rolling ) {
-      // write the initial marker
-      this.raf.write( marker );
-    }
-  }
-  /**
-   *  Implements {@link java.io.OutputStream#close}.
-   */
-  /*
-  public void close() {
-    this.raf.close();
-  }
-  */
-  /**
-   *  Implements {@link java.io.OutputStream#flush}.
-   */
-  /*
-  public void flush() {
-  }
-  */
-  /**
-   *  Implements {@link java.io.OutputStream#write(byte[])}.
-   */
-  @Override
-  public void write( byte[] b ) throws IOException {
-    write( b, 0, b.length );
-  }
-  /**
-   *  Implements {@link java.io.OutputStream#write(byte[],int,int)}.
-   */
-  @Override
-  public void write( byte[] b, int off, int len ) throws IOException {
-    if ( this.rolling ) {
-      // back over marker character
-      long fptr = this.raf.getFilePointer() - 1;
-      this.raf.seek( fptr );
-      // write bytes
-      int space = (int)( this.maxBytes - fptr );
-      if ( len <= space ) {
-        this.raf.write( b, off, len );
-      } else {
-        this.raf.write( b, off, space );
-        this.raf.seek(0);
-        this.raf.write( b, off + space, len - space );
-      }
-      // wrap around if landed at the end
-      if ( this.raf.getFilePointer() == this.maxBytes )
-        this.raf.seek(0);
-      // write marker character
-      this.raf.write( marker );
-    } else {
-      this.raf.write( b, off, len );
-    }
-  }
-  /**
-   *  Implements {@link java.io.OutputStream#write(int)}.
-   */
-  @Override
-  public void write( int b ) throws IOException {
-    // back over marker character
-    long fptr = this.raf.getFilePointer() - 1;
-    this.raf.seek( fptr );
-    // write byte
-    this.raf.writeByte( b );
-    // wrap around if landed at the end
-    if ( this.raf.getFilePointer() == this.maxBytes )
-      this.raf.seek(0);
-    // write marker character
-    this.raf.write( marker );
-  }
-
-  public static void main( String[] args ) throws IOException {
-    CircularOutputStream t = new CircularOutputStream( "frip", 10 );
-    PrintStream ps = new PrintStream( t, true ); // autoflush
-    System.setOut( ps ); System.setErr( ps );
-
-    System.out.println( "WHERE WILL THIS GO?" );
-    String s = "AND WHAT ABOUT THIS?\n";
-    t.write( s.getBytes() );
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/parReg/query/unittest/NewPortfolio.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/parReg/query/unittest/NewPortfolio.java b/geode-core/src/test/java/parReg/query/unittest/NewPortfolio.java
index 9bdb861..65620f9 100755
--- a/geode-core/src/test/java/parReg/query/unittest/NewPortfolio.java
+++ b/geode-core/src/test/java/parReg/query/unittest/NewPortfolio.java
@@ -16,7 +16,6 @@
  */
 package parReg.query.unittest;
 
-import hydra.Log;
 
 import java.io.Serializable;
 import java.util.*;
@@ -96,7 +95,7 @@ public class NewPortfolio implements Serializable {
   }
     
   public void init( int i ) {
-    this.name = new Integer(i).toString();
+    this.name = Integer.toString(i);
     this.id = i;
     this.status = i % 2 == 0 ? "active" : "inactive";
     this.type = "type" + (i % NUM_OF_TYPES);
@@ -119,7 +118,7 @@ public class NewPortfolio implements Serializable {
       secId += i * 7;                    
       if (secId > NUM_OF_SECURITIES)
         secId -= NUM_OF_SECURITIES;
-      props.setProperty("secId", new Integer(secId).toString());
+      props.setProperty("secId", Integer.toString(secId));
       
       Position pos = new Position();
       pos.init(props);
@@ -145,8 +144,8 @@ public class NewPortfolio implements Serializable {
    */
   protected Properties getProps() {
    Properties props = new Properties();
-   Double qty = new Double(rng.nextInt(MAX_QTY) * 100.00);
-   Double mktValue = new Double(rng.nextDouble() * MAX_PRICE); 
+   Double qty = rng.nextInt(MAX_QTY) * 100.00;
+   Double mktValue = rng.nextDouble() * MAX_PRICE;
 
    props.setProperty("qty", qty.toString());
    props.setProperty("mktValue", mktValue.toString());
@@ -162,36 +161,27 @@ public class NewPortfolio implements Serializable {
     if (anObj == null) {
        return false;
     }
-//    Log.getLogWriter().info("comparing\n"+this+"\n and "+anObj);
 
     if (anObj.getClass().getName().equals(this.getClass().getName())) { // cannot do class identity check for pdx tets
-//      Log.getLogWriter().info("checkpoint 1,.this class is checked " + this.getClass().getName() );
        NewPortfolio np = (NewPortfolio)anObj;
        if (!np.name.equals(this.name) || (np.id != this.id) || !np.type.equals(this.type) || !np.status.equals(this.status)) {
-//         Log.getLogWriter().info("checkpoint 1,obj " +np.name + " " + np.id + " " + np.type );
          return false;
        }
-//       Log.getLogWriter().info("checkpoint 2, NP name, id checked" );
-       
+
        if (np.positions == null) {
           if (this.positions != null) {
             return false;
           }
        } else {
-//         Log.getLogWriter().info("checkpoint 3, checking position size" );
          if (np.positions.size() != this.positions.size()) {
-           Log.getLogWriter().info("checkpoint 3, position size failed" );
            return false;
          }
          else {                 //loops thru the map of positions
            Iterator itr = np.positions.values().iterator();
            Position pos;
            while (itr.hasNext()) {
-//             Log.getLogWriter().info("checkpoint 4, to check iteration" );
              pos = (Position)itr.next();
-//             Log.getLogWriter().info("checkpoint 4, to check pos" );
              if (!this.positions.containsValue(pos)){
-//               Log.getLogWriter().info("checkpoint 5, check pos failed" );                                            
                return false;
              }            
            }
@@ -199,7 +189,6 @@ public class NewPortfolio implements Serializable {
        }
     } else {
       //not same class
-//      Log.getLogWriter().info("checkpoint 6, not the same class");
        return false;
     }
     return true;
@@ -231,25 +220,9 @@ public class NewPortfolio implements Serializable {
     fieldMap.put("type", type);
     fieldMap.put("positions", positions);
     fieldMap.put("undefinedTestField", undefinedTestField);
-//    Log.getLogWriter().info("created map in tests/parReg.query.NewPortfolio: " + fieldMap);
     return fieldMap;
   }
 
-  /** Restore the fields of this instance using the values of the Map, created
-   *  by createPdxHelperMap()
-   */
-  public void restoreFromPdxHelperMap(Map aMap) {
-//    Log.getLogWriter().info("restoring from map into " + this.getClass().getName() + ": " + aMap);
-    this.myVersion = (String)aMap.get("myVersion");
-    this.id = (Integer)aMap.get("id");
-    this.name = (String)aMap.get("name");
-    this.status = (String)aMap.get("status");
-    this.type = (String)aMap.get("type");
-    this.positions = (Map)aMap.get("positions");
-    this.undefinedTestField = (String)aMap.get("undefinedTestField");
-//    Log.getLogWriter().info("returning instance from map in tests/parReg.query.NewPortfolio: " + this);
-  }
-
   @Override
   public String toString() {
     StringBuffer sb = new StringBuffer();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-core/src/test/java/perffmwk/Formatter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/perffmwk/Formatter.java b/geode-core/src/test/java/perffmwk/Formatter.java
index 410c850..1f6a49c 100644
--- a/geode-core/src/test/java/perffmwk/Formatter.java
+++ b/geode-core/src/test/java/perffmwk/Formatter.java
@@ -17,11 +17,11 @@
 
 package perffmwk;
 
-import hydra.HydraRuntimeException;
-
-import java.io.*;
-import java.text.*;
-import java.util.*;
+import java.io.PrintWriter;
+import java.text.DecimalFormat;
+import java.util.Collection;
+import java.util.Iterator;
+import java.util.Vector;
 
 /**
  *  Contains common code used to format reports.
@@ -111,7 +111,7 @@ public class Formatter {
    */
   public static String padLeft( String s, int length ) {
     if ( s.length() > length ) {
-      throw new HydraRuntimeException( s + " cannot be padded to length " + length + ", it is too long" );
+      throw new RuntimeException( s + " cannot be padded to length " + length + ", it is too long" );
     }
     String t = "";
     for ( int i = 0; i < length - s.length(); i++ ) {
@@ -124,7 +124,7 @@ public class Formatter {
    */
   public static String padRight( String s, int length ) {
     if ( s.length() > length ) {
-      throw new HydraRuntimeException( s + " cannot be padded to length " + length + ", it is too long" );
+      throw new RuntimeException( s + " cannot be padded to length " + length + ", it is too long" );
     }
     String t = new String( s );
     for ( int i = 0; i < length - s.length(); i++ ) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/fb719d0a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
index acede33..de93c75 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
@@ -16,24 +16,43 @@
  */
 package com.gemstone.gemfire.cache.query.cq.dunit;
 
-import com.gemstone.gemfire.cache.*;
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+
+import java.io.IOException;
+import java.util.HashSet;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.PartitionAttributes;
+import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.client.ClientCache;
 import com.gemstone.gemfire.cache.client.ClientCacheFactory;
 import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.query.*;
+import com.gemstone.gemfire.cache.query.CqAttributes;
+import com.gemstone.gemfire.cache.query.CqAttributesFactory;
+import com.gemstone.gemfire.cache.query.CqListener;
+import com.gemstone.gemfire.cache.query.CqQuery;
+import com.gemstone.gemfire.cache.query.QueryService;
+import com.gemstone.gemfire.cache.query.SelectResults;
+import com.gemstone.gemfire.cache.query.Struct;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.cache30.ClientServerTestCase;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.test.dunit.*;
-import hydra.Log;
-
-import java.io.IOException;
-import java.util.HashSet;
-
-import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
+import com.gemstone.gemfire.test.dunit.Assert;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.LogWriterUtils;
+import com.gemstone.gemfire.test.dunit.NetworkUtils;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.Wait;
 
 /**
  * Test class for Partitioned Region and CQs
@@ -1418,8 +1437,6 @@ public class PartitionedRegionCqQueryDUnitTest extends CacheTestCase {
         if (localRegion != null) {
 
           // REGION NULL
-          Log.getLogWriter().info("Local region is NOT null in client 1");
-          
           Wait.pause(5*1000);
           CqQuery[] cqs = getCache().getQueryService().getCqs();
           if (cqs != null && cqs.length > 0) {


[07/17] incubator-geode git commit: GEODE-1491: Make sure when checking if a transaction is completed from isHostedTxRecentlyCompleted() method, the rolled back transaction is considered as well.

Posted by kl...@apache.org.
GEODE-1491: Make sure when checking if a transaction is completed from isHostedTxRecentlyCompleted() method, the rolled back transaction is considered as well.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/0815e1b6
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/0815e1b6
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/0815e1b6

Branch: refs/heads/feature/GEODE-837
Commit: 0815e1b6e9f11881b03780ac730856ee5db36c9c
Parents: 001a4e1
Author: eshu <es...@pivotal.io>
Authored: Mon Jun 6 12:38:25 2016 -0700
Committer: eshu <es...@pivotal.io>
Committed: Mon Jun 6 12:38:25 2016 -0700

----------------------------------------------------------------------
 .../gemfire/internal/cache/TXManagerImpl.java   | 20 +++---
 .../cache/partitioned/PartitionMessage.java     |  2 +-
 .../tier/sockets/command/RollbackCommand.java   |  5 ++
 .../internal/cache/TXManagerImplTest.java       | 70 ++++++++++++++++++--
 4 files changed, 83 insertions(+), 14 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0815e1b6/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXManagerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXManagerImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXManagerImpl.java
index df0176d..2608878 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXManagerImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXManagerImpl.java
@@ -1021,16 +1021,18 @@ public class TXManagerImpl implements CacheTransactionManager,
   }
   
   public boolean isHostedTxRecentlyCompleted(TXId txId) {
-    // if someone is asking to see if we have the txId, they will come
-    // back and ask for the commit message, this could take a long time
-    // specially when called from TXFailoverCommand, so we move
-    // the txId to the front of the queue
-    TXCommitMessage msg = failoverMap.remove(txId);
-    if (msg != null) {
-      failoverMap.put(txId, msg);
-      return true;
+    synchronized(failoverMap) {
+      if (failoverMap.containsKey(txId)) {
+        // if someone is asking to see if we have the txId, they will come
+        // back and ask for the commit message, this could take a long time
+        // specially when called from TXFailoverCommand, so we move
+        // the txId back to the linked map by removing and putting it back.
+        TXCommitMessage msg = failoverMap.remove(txId);
+        failoverMap.put(txId, msg);
+        return true;
+      }
+      return false;
     }
-    return false;
   }
   
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0815e1b6/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
index 9c54587..c2ab27e 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
@@ -186,7 +186,7 @@ public abstract class PartitionMessage extends DistributionMessage implements
    * (non-Javadoc)
    * @see com.gemstone.gemfire.internal.cache.TransactionMessage#getTXOriginatorClient()
    */
-  public final InternalDistributedMember getTXOriginatorClient() {
+  public InternalDistributedMember getTXOriginatorClient() {
     return txMemberId;
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0815e1b6/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/RollbackCommand.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/RollbackCommand.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/RollbackCommand.java
index ed7c706..f0316bd 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/RollbackCommand.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/RollbackCommand.java
@@ -63,6 +63,11 @@ public class RollbackCommand extends BaseCommand {
         txId = txState.getTxId();
         txMgr.rollback();
         sendRollbackReply(msg, servConn);
+      } else {
+        //could not find TxState in the host server.
+        //Protect against a failover command received so late,
+        //and it is removed from the failoverMap due to capacity.
+        sendRollbackReply(msg, servConn);
       }
     } catch (Exception e) {
       writeException(msg, e, false, servConn);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0815e1b6/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/TXManagerImplTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/TXManagerImplTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/TXManagerImplTest.java
index a4b8127..ce24947 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/TXManagerImplTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/TXManagerImplTest.java
@@ -28,6 +28,7 @@ import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
 import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.distributed.internal.DistributionManager;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.cache.partitioned.DestroyMessage;
 import com.gemstone.gemfire.test.fake.Fakes;
@@ -44,24 +45,29 @@ public class TXManagerImplTest {
   TXId completedTxid;
   TXId notCompletedTxid;
   InternalDistributedMember member;
-  CountDownLatch latch = new CountDownLatch(1);
+  CountDownLatch latch;
   TXStateProxy tx1, tx2;
+  DistributionManager dm;
+  TXRemoteRollbackMessage rollbackMsg;
 
   @Before
   public void setUp() {
     Cache cache = Fakes.cache();
-    txMgr = new TXManagerImpl(null, cache);
+    dm = mock(DistributionManager.class);
+    txMgr = new TXManagerImpl(mock(CachePerfStats.class), cache);
     txid = new TXId(null, 0);
     msg = mock(DestroyMessage.class);    
     txCommitMsg = mock(TXCommitMessage.class);
     member = mock(InternalDistributedMember.class);
     completedTxid = new TXId(member, 1);
     notCompletedTxid = new TXId(member, 2);
+    latch = new CountDownLatch(1);
+    rollbackMsg = new TXRemoteRollbackMessage();
     
     when(this.msg.canStartRemoteTransaction()).thenReturn(true);
     when(this.msg.canParticipateInTransaction()).thenReturn(true);
   }
-  
+
   @Test
   public void getOrSetHostedTXStateAbleToSetTXStateAndGetLock(){    
     TXStateProxy tx = txMgr.getOrSetHostedTXState(txid, msg);
@@ -232,5 +238,61 @@ public class TXManagerImplTest {
     txMgr.saveTXCommitMessageForClientFailover(completedTxid, txCommitMsg); 
     assertTrue(txMgr.hasTxAlreadyFinished(tx, completedTxid));
   }
-  
+
+  @Test
+  public void txRolledbackShouldCompleteTx() throws InterruptedException {
+    when(msg.getTXOriginatorClient()).thenReturn(mock(InternalDistributedMember.class));
+
+    Thread t1 = new Thread(new Runnable() {
+      public void run() {
+        try {
+          tx1 = txMgr.masqueradeAs(msg);
+        } catch (InterruptedException e) {
+          e.printStackTrace();
+          throw new RuntimeException(e);
+        }
+        try {
+          msg.process(dm);
+        } finally {
+          txMgr.unmasquerade(tx1);
+        }
+
+        TXStateProxy existingTx = masqueradeToRollback();
+        latch.countDown();
+        Awaitility.await().pollInterval(10, TimeUnit.MILLISECONDS).pollDelay(10, TimeUnit.MILLISECONDS)
+        .atMost(30, TimeUnit.SECONDS).until(() -> tx1.getLock().hasQueuedThreads());
+
+        rollbackTransaction(existingTx);
+      }
+    });
+    t1.start();
+
+    assertTrue(latch.await(60, TimeUnit.SECONDS));
+
+    TXStateProxy tx = txMgr.masqueradeAs(rollbackMsg);
+    assertEquals(tx, tx1);
+    t1.join();
+    rollbackTransaction(tx);
+  }
+
+  private TXStateProxy masqueradeToRollback() {
+    TXStateProxy existingTx;
+    try {
+      existingTx = txMgr.masqueradeAs(rollbackMsg);
+    } catch (InterruptedException e) {
+      e.printStackTrace();
+      throw new RuntimeException(e);
+    }
+    return existingTx;
+  }
+
+  private void rollbackTransaction(TXStateProxy existingTx) {
+    try {
+      if (!txMgr.isHostedTxRecentlyCompleted(txid)) {
+        txMgr.rollback();
+      }
+    } finally {
+      txMgr.unmasquerade(existingTx);
+    }
+  }
 }


[04/17] incubator-geode git commit: GEODE-1471: GatewayEventFilter callbacks are now invoked on AsyncEventQueues

Posted by kl...@apache.org.
GEODE-1471: GatewayEventFilter callbacks are now invoked on AsyncEventQueues


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/001a4e16
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/001a4e16
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/001a4e16

Branch: refs/heads/feature/GEODE-837
Commit: 001a4e167d287e66a944edf45ac9591b09104954
Parents: c742c4e
Author: Barry Oglesby <bo...@pivotal.io>
Authored: Thu Jun 2 18:25:05 2016 -0700
Committer: Barry Oglesby <bo...@pivotal.io>
Committed: Mon Jun 6 09:56:48 2016 -0700

----------------------------------------------------------------------
 .../cache/xmlcache/AsyncEventQueueCreation.java |  3 +-
 .../cache/wan/MyAsyncEventListener.java         |  7 +-
 .../cache/wan/MyGatewayEventFilter.java         | 69 ++++++++++++++++++++
 .../AsyncEventQueueValidationsJUnitTest.java    | 56 ++++++++++++++++
 ...ntQueueConfiguredFromXmlUsesFilter.cache.xml | 40 ++++++++++++
 ...ntQueueConfiguredFromXmlUsesFilter.cache.xml | 40 ++++++++++++
 6 files changed, 213 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/001a4e16/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/AsyncEventQueueCreation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/AsyncEventQueueCreation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/AsyncEventQueueCreation.java
index 4c2943e..e55ec3f 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/AsyncEventQueueCreation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/AsyncEventQueueCreation.java
@@ -61,7 +61,8 @@ public class AsyncEventQueueCreation implements AsyncEventQueue {
     this.dispatcherThreads = senderAttrs.dispatcherThreads;
     this.orderPolicy = senderAttrs.policy;
     this.asyncEventListener = eventListener;
-    this.isBucketSorted = senderAttrs.isBucketSorted; 
+    this.isBucketSorted = senderAttrs.isBucketSorted;
+    this.gatewayEventFilters = senderAttrs.eventFilters;
     this.gatewayEventSubstitutionFilter = senderAttrs.eventSubstitutionFilter;
     this.ignoreEvictionAndExpiration = senderAttrs.ignoreEvictionAndExpiration;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/001a4e16/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyAsyncEventListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyAsyncEventListener.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyAsyncEventListener.java
index f2401a5..9e8357d 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyAsyncEventListener.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyAsyncEventListener.java
@@ -18,13 +18,15 @@ package com.gemstone.gemfire.internal.cache.wan;
 
 import java.util.List;
 import java.util.Map;
+import java.util.Properties;
 import java.util.concurrent.ConcurrentHashMap;
 
+import com.gemstone.gemfire.cache.Declarable;
 import com.gemstone.gemfire.cache.asyncqueue.AsyncEvent;
 import com.gemstone.gemfire.cache.asyncqueue.AsyncEventListener;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 
-public class MyAsyncEventListener implements AsyncEventListener {
+public class MyAsyncEventListener implements AsyncEventListener, Declarable {
 
   private final Map eventsMap;
 
@@ -50,4 +52,7 @@ public class MyAsyncEventListener implements AsyncEventListener {
 
   public void close() {
   }
+
+  @Override
+  public void init(Properties props) {}
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/001a4e16/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyGatewayEventFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyGatewayEventFilter.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyGatewayEventFilter.java
new file mode 100644
index 0000000..39766e9
--- /dev/null
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/MyGatewayEventFilter.java
@@ -0,0 +1,69 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.internal.cache.wan;
+
+import com.gemstone.gemfire.cache.Declarable;
+import com.gemstone.gemfire.cache.wan.GatewayEventFilter;
+import com.gemstone.gemfire.cache.wan.GatewayQueueEvent;
+
+import java.util.Properties;
+import java.util.concurrent.atomic.AtomicInteger;
+
+// Note: This class is used by AsyncEventQueueValidationsJUnitTest testAsyncEventQueueConfiguredFromXmlUsesFilter
+public class MyGatewayEventFilter implements GatewayEventFilter, Declarable {
+
+  private AtomicInteger beforeEnqueueInvocations = new AtomicInteger();
+
+  private AtomicInteger beforeTransmitInvocations = new AtomicInteger();
+
+  private AtomicInteger afterAcknowledgementInvocations = new AtomicInteger();
+
+  @Override
+  public boolean beforeEnqueue(GatewayQueueEvent event) {
+    beforeEnqueueInvocations.incrementAndGet();
+    return true;
+  }
+
+  @Override
+  public boolean beforeTransmit(GatewayQueueEvent event) {
+    beforeTransmitInvocations.incrementAndGet();
+    return true;
+  }
+
+  @Override
+  public void afterAcknowledgement(GatewayQueueEvent event) {
+    afterAcknowledgementInvocations.incrementAndGet();
+  }
+
+  public int getBeforeEnqueueInvocations() {
+    return this.beforeEnqueueInvocations.get();
+  }
+
+  public int getBeforeTransmitInvocations() {
+    return this.beforeTransmitInvocations.get();
+  }
+
+  public int getAfterAcknowledgementInvocations() {
+    return this.afterAcknowledgementInvocations.get();
+  }
+
+  @Override
+  public void init(Properties props) {}
+
+  @Override
+  public void close() {}
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/001a4e16/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
index 2a7e57f..3055c8e 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
@@ -21,14 +21,29 @@ package com.gemstone.gemfire.internal.cache.wan.asyncqueue;
 
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
 import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueueFactory;
+import com.gemstone.gemfire.cache.wan.GatewayEventFilter;
 import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.internal.cache.wan.AsyncEventQueueConfigurationException;
+import com.gemstone.gemfire.internal.cache.wan.MyGatewayEventFilter;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import com.gemstone.gemfire.util.test.TestUtil;
+import com.jayway.awaitility.Awaitility;
+import junitparams.JUnitParamsRunner;
+import junitparams.Parameters;
+import org.junit.After;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
+import org.junit.runner.RunWith;
 
+import java.util.List;
+import java.util.concurrent.TimeUnit;
+
+import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.CACHE_XML_FILE;
 import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
+import static junitparams.JUnitParamsRunner.$;
 import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.fail;
 
@@ -36,10 +51,18 @@ import static org.junit.Assert.fail;
  *
  */
 @Category(IntegrationTest.class)
+@RunWith(JUnitParamsRunner.class)
 public class AsyncEventQueueValidationsJUnitTest {
 
   private Cache cache;
 
+  @After
+  public void closeCache() {
+    if(this.cache != null) {
+      this.cache.close();
+    }
+  }
+
   @Test
   public void testConcurrentParallelAsyncEventQueueAttributesWrongDispatcherThreads() {
     cache = new CacheFactory().set(MCAST_PORT, "0").create();
@@ -72,4 +95,37 @@ public class AsyncEventQueueValidationsJUnitTest {
     }
   }
 
+  @Test
+  @Parameters(method = "getCacheXmlFileBaseNames")
+  public void testAsyncEventQueueConfiguredFromXmlUsesFilter(String cacheXmlFileBaseName) {
+    // Create cache with xml
+    String cacheXmlFileName = TestUtil.getResourcePath(getClass(), getClass().getSimpleName() + "." + cacheXmlFileBaseName + ".cache.xml");
+    cache = new CacheFactory().set(MCAST_PORT, "0").set(CACHE_XML_FILE, cacheXmlFileName).create();
+
+    // Get region and do puts
+    Region region = cache.getRegion(cacheXmlFileBaseName);
+    int numPuts = 10;
+    for (int i=0; i<numPuts; i++) {
+      region.put(i,i);
+    }
+
+    // Get AsyncEventQueue and GatewayEventFilter
+    AsyncEventQueue aeq = cache.getAsyncEventQueue(cacheXmlFileBaseName);
+    List<GatewayEventFilter> filters = aeq.getGatewayEventFilters();
+    assertTrue(filters.size() == 1);
+    MyGatewayEventFilter filter = (MyGatewayEventFilter) filters.get(0);
+
+    // Validate filter callbacks were invoked
+    Awaitility.waitAtMost(60, TimeUnit.SECONDS).until(() -> filter.getBeforeEnqueueInvocations() == numPuts);
+    Awaitility.waitAtMost(60, TimeUnit.SECONDS).until(() -> filter.getBeforeTransmitInvocations() == numPuts);
+    Awaitility.waitAtMost(60, TimeUnit.SECONDS).until(() -> filter.getAfterAcknowledgementInvocations() == numPuts);
+  }
+
+  private final Object[] getCacheXmlFileBaseNames() {
+    return $(
+        new Object[] { "testSerialAsyncEventQueueConfiguredFromXmlUsesFilter" },
+        new Object[] { "testParallelAsyncEventQueueConfiguredFromXmlUsesFilter" }
+    );
+  }
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/001a4e16/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testParallelAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml
----------------------------------------------------------------------
diff --git a/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testParallelAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml b/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testParallelAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml
new file mode 100755
index 0000000..9d8ed7f
--- /dev/null
+++ b/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testParallelAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml
@@ -0,0 +1,40 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<!DOCTYPE cache PUBLIC
+  "-//GemStone Systems, Inc.//GemFire Declarative Caching 8.0//EN"
+  "http://www.gemstone.com/dtd/cache8_0.dtd">
+  
+<cache>
+
+  <async-event-queue id="testParallelAsyncEventQueueConfiguredFromXmlUsesFilter" parallel="true">
+    <gateway-event-filter>
+      <class-name>com.gemstone.gemfire.internal.cache.wan.MyGatewayEventFilter</class-name>
+    </gateway-event-filter>
+    <async-event-listener>
+      <class-name>com.gemstone.gemfire.internal.cache.wan.MyAsyncEventListener</class-name>
+    </async-event-listener>
+  </async-event-queue>
+
+  <region name="testParallelAsyncEventQueueConfiguredFromXmlUsesFilter" refid="PARTITION">
+    <region-attributes async-event-queue-ids="testParallelAsyncEventQueueConfiguredFromXmlUsesFilter"/>
+  </region>
+
+</cache>
+

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/001a4e16/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testSerialAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml
----------------------------------------------------------------------
diff --git a/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testSerialAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml b/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testSerialAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml
new file mode 100755
index 0000000..1361036
--- /dev/null
+++ b/geode-core/src/test/resources/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.testSerialAsyncEventQueueConfiguredFromXmlUsesFilter.cache.xml
@@ -0,0 +1,40 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<!DOCTYPE cache PUBLIC
+  "-//GemStone Systems, Inc.//GemFire Declarative Caching 8.0//EN"
+  "http://www.gemstone.com/dtd/cache8_0.dtd">
+  
+<cache>
+
+  <async-event-queue id="testSerialAsyncEventQueueConfiguredFromXmlUsesFilter" parallel="false">
+    <gateway-event-filter>
+      <class-name>com.gemstone.gemfire.internal.cache.wan.MyGatewayEventFilter</class-name>
+    </gateway-event-filter>
+    <async-event-listener>
+      <class-name>com.gemstone.gemfire.internal.cache.wan.MyAsyncEventListener</class-name>
+    </async-event-listener>
+  </async-event-queue>
+
+  <region name="testSerialAsyncEventQueueConfiguredFromXmlUsesFilter" refid="PARTITION">
+    <region-attributes async-event-queue-ids="testSerialAsyncEventQueueConfiguredFromXmlUsesFilter"/>
+  </region>
+
+</cache>
+


[05/17] incubator-geode git commit: GEODE-11: Added support for lucene index profile exchange

Posted by kl...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java b/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
index 33cb3d3..98233b0 100644
--- a/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
+++ b/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
@@ -84,11 +84,10 @@ public class LuceneIndexCreation implements LuceneIndex, Extension<Region<?, ?>>
   @Override
   public void beforeCreate(Extensible<Region<?, ?>> source, Cache cache) {
     LuceneServiceImpl service = (LuceneServiceImpl) LuceneServiceProvider.get(cache);
-    if (this.fieldAnalyzers == null) {
-      service.createIndex(getName(), getRegionPath(), getFieldNames());
-    } else {
-      service.createIndex(getName(), getRegionPath(), this.fieldAnalyzers);
-    }
+    Analyzer analyzer = this.fieldAnalyzers == null
+        ? new StandardAnalyzer()
+        : new PerFieldAnalyzerWrapper(new StandardAnalyzer(), this.fieldAnalyzers);
+    service.createIndex(getName(), getRegionPath(), analyzer, this.fieldAnalyzers, getFieldNames());
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneDUnitTest.java b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneDUnitTest.java
new file mode 100644
index 0000000..565ec4f
--- /dev/null
+++ b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneDUnitTest.java
@@ -0,0 +1,38 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package com.gemstone.gemfire.cache.lucene;
+
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
+
+public abstract class LuceneDUnitTest extends JUnit4CacheTestCase {
+  protected VM dataStore1;
+  protected VM dataStore2;
+
+  @Override
+  public void postSetUp() throws Exception {
+    Host host = Host.getHost(0);
+    dataStore1 = host.getVM(0);
+    dataStore2 = host.getVM(1);
+  }
+
+  protected abstract void initDataStore(SerializableRunnableIF createIndex) throws Exception;
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.java b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.java
new file mode 100644
index 0000000..f51c848
--- /dev/null
+++ b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.java
@@ -0,0 +1,281 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package com.gemstone.gemfire.cache.lucene;
+
+import com.gemstone.gemfire.cache.RegionShortcut;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+import com.gemstone.gemfire.util.test.TestUtil;
+import junitparams.JUnitParamsRunner;
+import junitparams.Parameters;
+import org.apache.lucene.analysis.Analyzer;
+import org.apache.lucene.analysis.core.KeywordAnalyzer;
+import org.apache.lucene.analysis.standard.StandardAnalyzer;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+import org.junit.runner.RunWith;
+
+import java.io.FileInputStream;
+import java.io.FileNotFoundException;
+import java.util.HashMap;
+import java.util.Map;
+
+import static com.gemstone.gemfire.cache.lucene.test.LuceneTestUtilities.*;
+import static junitparams.JUnitParamsRunner.$;
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.fail;
+
+@Category(DistributedTest.class)
+@RunWith(JUnitParamsRunner.class)
+public class LuceneIndexCreationDUnitTest extends LuceneDUnitTest {
+
+  @Override
+  protected void initDataStore(SerializableRunnableIF createIndex) throws Exception {
+    createIndex.run();
+    getCache().createRegionFactory(RegionShortcut.PARTITION).create(REGION_NAME);
+  }
+
+  @Test
+  public void verifyDifferentFieldsFails() {
+    SerializableRunnableIF createIndex1 = getFieldsIndexWithOneField();
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = getFieldsIndexWithTwoFields();
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_FIELDS));
+  }
+
+  @Test
+  public void verifyDifferentFieldAnalyzerSizesFails1() {
+    SerializableRunnableIF createIndex1 = getAnalyzersIndexWithTwoFields();
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = getAnalyzersIndexWithOneField();
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD2));
+  }
+
+  @Test
+  public void verifyDifferentFieldAnalyzerSizesFails2() {
+    SerializableRunnableIF createIndex1 = getAnalyzersIndexWithOneField();
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = getAnalyzersIndexWithTwoFields();
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZER_SIZES_1));
+  }
+
+  @Test
+  public void verifyDifferentFieldAnalyzersFails1() {
+    SerializableRunnableIF createIndex1 = getAnalyzersIndexWithOneField(StandardAnalyzer.class);
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = getAnalyzersIndexWithOneField(KeywordAnalyzer.class);
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZERS));
+  }
+
+  @Test
+  public void verifyDifferentFieldAnalyzersFails2() {
+    SerializableRunnableIF createIndex1 = getAnalyzersIndexWithNullField2();
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = getAnalyzersIndexWithNullField1();
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD1));
+  }
+
+  @Test
+  public void verifyDifferentFieldAnalyzersFails3() {
+    SerializableRunnableIF createIndex1 = getAnalyzersIndexWithNullField1();
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = getAnalyzersIndexWithNullField2();
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_EXISTING_MEMBER));
+  }
+
+  @Test
+  public void verifyDifferentIndexNamesFails() {
+    SerializableRunnableIF createIndex1 = () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      luceneService.createIndex(INDEX_NAME+"1", REGION_NAME, "field1");
+    };
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      luceneService.createIndex(INDEX_NAME+"2", REGION_NAME, "field1");
+    };
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_NAMES));
+  }
+
+  @Test
+  public void verifyDifferentIndexesFails1() {
+    SerializableRunnableIF createIndex1 = getFieldsIndexWithOneField();
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = () -> {/*Do nothing*/};
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_INDEXES_1));
+  }
+
+  @Test
+  public void verifyDifferentIndexesFails2() {
+    SerializableRunnableIF createIndex1 = getFieldsIndexWithOneField();
+    dataStore1.invoke(() -> initDataStore(createIndex1));
+
+    SerializableRunnableIF createIndex2 = () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, "field1");
+      luceneService.createIndex(INDEX_NAME+"2", REGION_NAME, "field2");
+    };
+    dataStore2.invoke(() -> initDataStore(createIndex2, CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_INDEXES_2));
+  }
+
+  @Test
+  @Parameters(method = "getIndexes")
+  public void verifySameIndexesSucceeds(SerializableRunnableIF createIndex) {
+    dataStore1.invoke(() -> initDataStore(createIndex));
+    dataStore2.invoke(() -> initDataStore(createIndex));
+  }
+
+  private final Object[] getIndexes() {
+    return $(
+        new Object[] { getFieldsIndexWithOneField() },
+        new Object[] { getFieldsIndexWithTwoFields() },
+        new Object[] { get2FieldsIndexes() },
+        new Object[] { getAnalyzersIndexWithOneField() },
+        new Object[] { getAnalyzersIndexWithTwoFields() },
+        new Object[] { getAnalyzersIndexWithNullField1() }
+    );
+  }
+
+  @Test
+  @Parameters(method = "getXmlAndExceptionMessages")
+  public void verifyXml(String cacheXmlFileBaseName, String exceptionMessage) {
+    dataStore1.invoke(() -> initCache(getXmlFileForTest(cacheXmlFileBaseName + ".1")));
+    dataStore2.invoke(() -> initCache(getXmlFileForTest(cacheXmlFileBaseName + ".2"), exceptionMessage));
+  }
+
+  private final Object[] getXmlAndExceptionMessages() {
+    return $(
+        new Object[] { "verifyDifferentFieldsFails", CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_FIELDS },
+        new Object[] { "verifyDifferentFieldAnalyzerSizesFails1", CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD2 },
+        new Object[] { "verifyDifferentFieldAnalyzerSizesFails2", CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZER_SIZES_1 },
+        new Object[] { "verifyDifferentFieldAnalyzersFails1", CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZERS },
+        // Currently setting a null analyzer is not a valid xml configuration: <lucene:field name="field2" analyzer="null"/>
+        //new Object[] { "verifyDifferentFieldAnalyzersFails2", CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD1 },
+        //new Object[] { "verifyDifferentFieldAnalyzersFails3", CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_EXISTING_MEMBER },
+        new Object[] { "verifyDifferentIndexNamesFails", CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_NAMES },
+        new Object[] { "verifyDifferentIndexesFails1", CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_INDEXES_1 },
+        new Object[] { "verifyDifferentIndexesFails2", CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_INDEXES_2 }
+    );
+  }
+
+  private String getXmlFileForTest(String testName) {
+    return TestUtil.getResourcePath(getClass(), getClass().getSimpleName() + "." + testName + ".cache.xml");
+  }
+
+  private void initDataStore(SerializableRunnableIF createIndex, String message) throws Exception {
+    createIndex.run();
+    try {
+      getCache().createRegionFactory(RegionShortcut.PARTITION).create(REGION_NAME);
+      fail("Should not have been able to create index");
+    } catch (IllegalStateException e) {
+      assertEquals(message, e.getMessage());
+    }
+  }
+
+  private void initCache(String cacheXmlFileName) throws FileNotFoundException {
+    getCache().loadCacheXml(new FileInputStream(cacheXmlFileName));
+  }
+
+  private void initCache(String cacheXmlFileName, String message) throws FileNotFoundException {
+    try {
+      getCache().loadCacheXml(new FileInputStream(cacheXmlFileName));
+      fail("Should not have been able to create cache");
+    } catch (IllegalStateException e) {
+      assertEquals(message, e.getMessage());
+    }
+  }
+
+  private SerializableRunnableIF getFieldsIndexWithOneField() {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, "field1");
+    };
+  }
+
+  private SerializableRunnableIF getFieldsIndexWithTwoFields() {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, "field1", "field2");
+    };
+  }
+
+  private SerializableRunnableIF get2FieldsIndexes() {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      luceneService.createIndex(INDEX_NAME+"_1", REGION_NAME, "field1");
+      luceneService.createIndex(INDEX_NAME+"_2", REGION_NAME, "field2");
+    };
+  }
+
+  private SerializableRunnableIF getAnalyzersIndexWithNullField1() {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      Map<String, Analyzer> analyzers = new HashMap<>();
+      analyzers.put("field1", null);
+      analyzers.put("field2", new KeywordAnalyzer());
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, analyzers);
+    };
+  }
+
+  private SerializableRunnableIF getAnalyzersIndexWithNullField2() {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      Map<String, Analyzer> analyzers = new HashMap<>();
+      analyzers.put("field1", new KeywordAnalyzer());
+      analyzers.put("field2", null);
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, analyzers);
+    };
+  }
+
+  private SerializableRunnableIF getAnalyzersIndexWithOneField(Class<? extends Analyzer> analyzerClass) {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      Map<String, Analyzer> analyzers = new HashMap<>();
+      analyzers.put("field1", analyzerClass.newInstance());
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, analyzers);
+    };
+  }
+
+  private SerializableRunnableIF getAnalyzersIndexWithOneField() {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      Map<String, Analyzer> analyzers = new HashMap<>();
+      analyzers.put("field1", new KeywordAnalyzer());
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, analyzers);
+    };
+  }
+
+  private SerializableRunnableIF getAnalyzersIndexWithTwoFields() {
+    return () -> {
+      LuceneService luceneService = LuceneServiceProvider.get(getCache());
+      Map<String, Analyzer> analyzers = new HashMap<>();
+      analyzers.put("field1", new KeywordAnalyzer());
+      analyzers.put("field2", new KeywordAnalyzer());
+      luceneService.createIndex(INDEX_NAME, REGION_NAME, analyzers);
+    };
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneQueriesBase.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneQueriesBase.java b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneQueriesBase.java
index 821be17..92d8e8b 100644
--- a/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneQueriesBase.java
+++ b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/LuceneQueriesBase.java
@@ -28,16 +28,10 @@ import java.util.Map;
 
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
-import com.gemstone.gemfire.cache.lucene.internal.LuceneEventListener;
 import com.gemstone.gemfire.cache.lucene.internal.LuceneIndexImpl;
-import com.gemstone.gemfire.cache.lucene.internal.LuceneServiceImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
-import com.gemstone.gemfire.internal.logging.LogService;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
 
 import org.junit.Test;
 
@@ -47,23 +41,17 @@ import org.junit.Test;
   * of different regions types and topologies.
   *
   */
-public abstract class LuceneQueriesBase extends JUnit4CacheTestCase {
+public abstract class LuceneQueriesBase extends LuceneDUnitTest {
 
   private static final long serialVersionUID = 1L;
-  protected VM dataStore1;
-  protected VM dataStore2;
   protected VM accessor;
 
   @Override
   public final void postSetUp() throws Exception {
-    Host host = Host.getHost(0);
-    dataStore1 = host.getVM(0);
-    dataStore2 = host.getVM(1);
-    accessor = host.getVM(3);
+    super.postSetUp();
+    accessor = Host.getHost(0).getVM(3);
   }
 
-  protected abstract void initDataStore(SerializableRunnableIF createIndex) throws Exception;
-
   protected abstract void initAccessor(SerializableRunnableIF createIndex) throws Exception;
 
   @Test

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfileJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfileJUnitTest.java b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfileJUnitTest.java
new file mode 100644
index 0000000..ecb48af
--- /dev/null
+++ b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfileJUnitTest.java
@@ -0,0 +1,144 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package com.gemstone.gemfire.cache.lucene.internal;
+
+import com.gemstone.gemfire.CopyHelper;
+import com.gemstone.gemfire.test.junit.categories.UnitTest;
+import junitparams.JUnitParamsRunner;
+import junitparams.Parameters;
+import org.apache.lucene.analysis.Analyzer;
+import org.apache.lucene.analysis.core.KeywordAnalyzer;
+import org.apache.lucene.analysis.miscellaneous.PerFieldAnalyzerWrapper;
+import org.apache.lucene.analysis.standard.StandardAnalyzer;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+import org.junit.runner.RunWith;
+
+import java.util.HashMap;
+import java.util.Map;
+
+import static com.gemstone.gemfire.cache.lucene.test.LuceneTestUtilities.*;
+import static junitparams.JUnitParamsRunner.$;
+import static org.junit.Assert.assertArrayEquals;
+import static org.junit.Assert.assertEquals;
+
+@Category(UnitTest.class)
+@RunWith(JUnitParamsRunner.class)
+public class LuceneIndexCreationProfileJUnitTest {
+
+  @Test
+  @Parameters(method = "getSerializationProfiles")
+  public void testSerialization(LuceneIndexCreationProfile profile) {
+    LuceneServiceImpl.registerDataSerializables();
+    LuceneIndexCreationProfile copy = CopyHelper.deepCopy(profile);
+    assertEquals(profile.getIndexName(), copy.getIndexName());
+    assertEquals(profile.getAnalyzerClass(), copy.getAnalyzerClass());
+    assertArrayEquals(profile.getFieldNames(), copy.getFieldNames());
+    assertEquals(profile.getFieldAnalyzers(), copy.getFieldAnalyzers());
+  }
+
+  private final Object[] getSerializationProfiles() {
+    return $(
+        new Object[] { getOneFieldLuceneIndexCreationProfile() },
+        new Object[] { getTwoFieldLuceneIndexCreationProfile() },
+        new Object[] { getTwoAnalyzersLuceneIndexCreationProfile() },
+        new Object[] { getNullField1AnalyzerLuceneIndexCreationProfile() }
+    );
+  }
+
+  @Test
+  @Parameters(method = "getCheckCompatibilityProfiles")
+  public void testCheckCompatibility(LuceneIndexCreationProfile myProfile, LuceneIndexCreationProfile otherProfile, String expectedResult) {
+    assertEquals(expectedResult, otherProfile.checkCompatibility("/"+REGION_NAME, myProfile));
+  }
+
+  private final Object[] getCheckCompatibilityProfiles() {
+    return $(
+        new Object[] {
+            getOneFieldLuceneIndexCreationProfile(),
+            getTwoFieldLuceneIndexCreationProfile(),
+            CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_FIELDS
+        },
+        new Object[] {
+            getTwoAnalyzersLuceneIndexCreationProfile(),
+            getOneAnalyzerLuceneIndexCreationProfile(new KeywordAnalyzer()),
+            CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD2
+        },
+        new Object[] {
+            getOneAnalyzerLuceneIndexCreationProfile(new KeywordAnalyzer()),
+            getTwoAnalyzersLuceneIndexCreationProfile(),
+            CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZER_SIZES_2
+        },
+        new Object[] {
+            getOneAnalyzerLuceneIndexCreationProfile(new StandardAnalyzer()),
+            getOneAnalyzerLuceneIndexCreationProfile(new KeywordAnalyzer()),
+            CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZERS
+        },
+        new Object[] {
+            getNullField2AnalyzerLuceneIndexCreationProfile(),
+            getNullField1AnalyzerLuceneIndexCreationProfile(),
+            CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD1
+        },
+        new Object[] {
+            getNullField1AnalyzerLuceneIndexCreationProfile(),
+            getNullField2AnalyzerLuceneIndexCreationProfile(),
+            CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_EXISTING_MEMBER
+        }
+    );
+  }
+
+  private LuceneIndexCreationProfile getOneFieldLuceneIndexCreationProfile() {
+    return new LuceneIndexCreationProfile(INDEX_NAME, new String[] { "field1" }, new StandardAnalyzer(), null);
+  }
+
+  private LuceneIndexCreationProfile getTwoFieldLuceneIndexCreationProfile() {
+    return new LuceneIndexCreationProfile(INDEX_NAME, new String[] { "field1", "field2" }, new StandardAnalyzer(), null);
+  }
+
+  private LuceneIndexCreationProfile getOneAnalyzerLuceneIndexCreationProfile(Analyzer analyzer) {
+    Map<String, Analyzer> fieldAnalyzers = new HashMap<>();
+    fieldAnalyzers.put("field1", analyzer);
+    return new LuceneIndexCreationProfile(INDEX_NAME, new String[] { "field1", "field2" }, getPerFieldAnalyzerWrapper(fieldAnalyzers), fieldAnalyzers);
+  }
+
+  private LuceneIndexCreationProfile getTwoAnalyzersLuceneIndexCreationProfile() {
+    Map<String, Analyzer> fieldAnalyzers = new HashMap<>();
+    fieldAnalyzers.put("field1", new KeywordAnalyzer());
+    fieldAnalyzers.put("field2", new KeywordAnalyzer());
+    return new LuceneIndexCreationProfile(INDEX_NAME, new String[] { "field1", "field2" }, getPerFieldAnalyzerWrapper(fieldAnalyzers), fieldAnalyzers);
+  }
+
+  private LuceneIndexCreationProfile getNullField1AnalyzerLuceneIndexCreationProfile() {
+    Map<String, Analyzer> fieldAnalyzers = new HashMap<>();
+    fieldAnalyzers.put("field1", null);
+    fieldAnalyzers.put("field2", new KeywordAnalyzer());
+    return new LuceneIndexCreationProfile(INDEX_NAME, new String[] { "field1", "field2" }, getPerFieldAnalyzerWrapper(fieldAnalyzers), fieldAnalyzers);
+  }
+
+  private LuceneIndexCreationProfile getNullField2AnalyzerLuceneIndexCreationProfile() {
+    Map<String, Analyzer> fieldAnalyzers = new HashMap<>();
+    fieldAnalyzers.put("field1", new KeywordAnalyzer());
+    fieldAnalyzers.put("field2", null);
+    return new LuceneIndexCreationProfile(INDEX_NAME, new String[] { "field1", "field2" }, getPerFieldAnalyzerWrapper(fieldAnalyzers), fieldAnalyzers);
+  }
+
+  private Analyzer getPerFieldAnalyzerWrapper(Map<String, Analyzer> fieldAnalyzers) {
+    return new PerFieldAnalyzerWrapper(new StandardAnalyzer(), fieldAnalyzers);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/test/LuceneTestUtilities.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/test/LuceneTestUtilities.java b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/test/LuceneTestUtilities.java
index 860dacf..0cf8953 100644
--- a/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/test/LuceneTestUtilities.java
+++ b/geode-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/test/LuceneTestUtilities.java
@@ -43,6 +43,17 @@ public class LuceneTestUtilities {
   public static final String INDEX_NAME = "index";
   public static final String REGION_NAME = "region";
 
+  public static final String CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_FIELDS = "Cannot create Lucene index index on region /region with fields [field1, field2] because another member defines the same index with fields [field1].";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD2 = "Cannot create Lucene index index on region /region with no analyzer on field field2 because another member defines the same index with analyzer org.apache.lucene.analysis.core.KeywordAnalyzer on that field.";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZER_SIZES_1 = "Cannot create Lucene index index on region /region with field analyzers {field2=class org.apache.lucene.analysis.core.KeywordAnalyzer, field1=class org.apache.lucene.analysis.core.KeywordAnalyzer} because another member defines the same index with field analyzers {field1=class org.apache.lucene.analysis.core.KeywordAnalyzer}.";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZER_SIZES_2 = "Cannot create Lucene index index on region /region with field analyzers {field1=class org.apache.lucene.analysis.core.KeywordAnalyzer, field2=class org.apache.lucene.analysis.core.KeywordAnalyzer} because another member defines the same index with field analyzers {field1=class org.apache.lucene.analysis.core.KeywordAnalyzer}.";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_ANALYZERS = "Cannot create Lucene index index on region /region with analyzer org.apache.lucene.analysis.core.KeywordAnalyzer on field field1 because another member defines the same index with analyzer org.apache.lucene.analysis.standard.StandardAnalyzer on that field.";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_FIELD1 = "Cannot create Lucene index index on region /region with no analyzer on field field1 because another member defines the same index with analyzer org.apache.lucene.analysis.core.KeywordAnalyzer on that field.";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_NO_ANALYZER_EXISTING_MEMBER = "Cannot create Lucene index index on region /region with analyzer org.apache.lucene.analysis.core.KeywordAnalyzer on field field1 because another member defines the same index with no analyzer on that field.";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_NAMES = "Cannot create Region /region with [index2#_region] async event ids because another cache has the same region defined with [index1#_region] async event ids";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_INDEXES_1 = "Cannot create Region /region with [] async event ids because another cache has the same region defined with [index#_region] async event ids";
+  public static final String CANNOT_CREATE_LUCENE_INDEX_DIFFERENT_INDEXES_2 = "Cannot create Region /region with [index#_region, index2#_region] async event ids because another cache has the same region defined with [index#_region] async event ids";
+
   public static void verifyInternalRegions(LuceneService luceneService, Cache cache, Consumer<LocalRegion> verify) {
     // Get index
     LuceneIndexForPartitionedRegion index = (LuceneIndexForPartitionedRegion) luceneService.getIndex(INDEX_NAME, REGION_NAME);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.1.cache.xml
new file mode 100755
index 0000000..40fc80e
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.1.cache.xml
@@ -0,0 +1,37 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+      <lucene:field name="field2" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.2.cache.xml
new file mode 100755
index 0000000..ec278b1
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails1.2.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.1.cache.xml
new file mode 100755
index 0000000..ec278b1
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.1.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.2.cache.xml
new file mode 100755
index 0000000..40fc80e
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzerSizesFails2.2.cache.xml
@@ -0,0 +1,37 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+      <lucene:field name="field2" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.1.cache.xml
new file mode 100755
index 0000000..12ef799
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.1.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.standard.StandardAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.2.cache.xml
new file mode 100755
index 0000000..ec278b1
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails1.2.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.1.cache.xml
new file mode 100755
index 0000000..5550ad6
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.1.cache.xml
@@ -0,0 +1,37 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+      <lucene:field name="field2" analyzer="null"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.2.cache.xml
new file mode 100755
index 0000000..ceed0ec
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails2.2.cache.xml
@@ -0,0 +1,37 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="null"/>
+      <lucene:field name="field2" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.1.cache.xml
new file mode 100755
index 0000000..ceed0ec
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.1.cache.xml
@@ -0,0 +1,37 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="null"/>
+      <lucene:field name="field2" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.2.cache.xml
new file mode 100755
index 0000000..5550ad6
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldAnalyzersFails3.2.cache.xml
@@ -0,0 +1,37 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1" analyzer="org.apache.lucene.analysis.core.KeywordAnalyzer"/>
+      <lucene:field name="field2" analyzer="null"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.1.cache.xml
new file mode 100755
index 0000000..b0870ee
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.1.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.2.cache.xml
new file mode 100755
index 0000000..77936e2
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentFieldsFails.2.cache.xml
@@ -0,0 +1,37 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1"/>
+      <lucene:field name="field2"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.1.cache.xml
new file mode 100755
index 0000000..38afdbd
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.1.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index1">
+      <lucene:field name="field1"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.2.cache.xml
new file mode 100755
index 0000000..83e532d
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexNamesFails.2.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index2">
+      <lucene:field name="field1"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.1.cache.xml
new file mode 100755
index 0000000..b0870ee
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.1.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.2.cache.xml
new file mode 100755
index 0000000..3666c4f
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails1.2.cache.xml
@@ -0,0 +1,32 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT"/>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.1.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.1.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.1.cache.xml
new file mode 100755
index 0000000..b0870ee
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.1.cache.xml
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1"/>
+    </lucene:index>
+  </region>
+ 
+</cache>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.2.cache.xml
----------------------------------------------------------------------
diff --git a/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.2.cache.xml b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.2.cache.xml
new file mode 100755
index 0000000..7aca855
--- /dev/null
+++ b/geode-lucene/src/test/resources/com/gemstone/gemfire/cache/lucene/LuceneIndexCreationDUnitTest.verifyDifferentIndexesFails2.2.cache.xml
@@ -0,0 +1,39 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<cache
+    xmlns="http://geode.apache.org/schema/cache"
+    xmlns:lucene="http://geode.apache.org/schema/lucene"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://geode.apache.org/schema/cache
+        http://geode.apache.org/schema/cache/cache-1.0.xsd
+        http://geode.apache.org/schema/lucene
+        http://geode.apache.org/schema/lucene/lucene-1.0.xsd"
+    version="1.0">
+
+  <region name="region" refid="PARTITION_REDUNDANT">
+    <lucene:index name="index">
+      <lucene:field name="field1"/>
+    </lucene:index>
+    <lucene:index name="index2">
+      <lucene:field name="field2"/>
+    </lucene:index>
+  </region>
+ 
+</cache>


[12/17] incubator-geode git commit: GEODE-1464: remove sqlf code

Posted by kl...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
index c4a8e27..fff9bab 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
@@ -87,7 +87,7 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
   protected static final int REQUIRES_NOTIFICATION_MASK = 0x8000;
   private static final int HAS_CACHE_SERVER_MASK = 0x10000;
   private static final int REQUIRES_OLD_VALUE_MASK = 0x20000;
-  private static final int MEMBER_UNINITIALIZED_MASK = 0x40000;
+  // unused 0x40000;
   private static final int PERSISTENCE_INITIALIZED_MASK = 0x80000;
   //Important below mentioned bit masks are not available 
   /**
@@ -229,8 +229,7 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
         CacheProfile prof = (CacheProfile)profile;
 
         // if region in cache is not yet initialized, exclude
-        if (!prof.regionInitialized          // fix for bug 41102
-            || prof.memberUnInitialized) {
+        if (!prof.regionInitialized) { // fix for bug 41102
           return false;
         }
 
@@ -269,10 +268,6 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
           if (!cp.regionInitialized) {
             return false;
           }
-          // if member is not yet initialized, exclude
-          if (cp.memberUnInitialized) {
-            return false;
-          }
           if (!cp.cachedOrAllEventsWithListener()) {
             return false;
           }
@@ -327,8 +322,7 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
       public boolean include(Profile profile) {
         assert profile instanceof CacheProfile;
         CacheProfile cp = (CacheProfile)profile;
-        if (cp.dataPolicy.withReplication() && cp.regionInitialized
-            && !cp.memberUnInitialized) {
+        if (cp.dataPolicy.withReplication() && cp.regionInitialized) {
           return true;
         }
         return false;
@@ -350,10 +344,6 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
         if (!cp.regionInitialized) {
           return false;
         }
-        // if member is not yet initialized, exclude
-        if (cp.memberUnInitialized) {
-          return false;
-        }
         DataPolicy dp = cp.dataPolicy;
         return dp.withStorage();
       }
@@ -544,14 +534,6 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
      */
     public boolean regionInitialized;
 
-    /**
-     * True when member is still not ready to receive cache operations. Note
-     * that {@link #regionInitialized} may be still true so other members can
-     * proceed with GII etc. Currently used by SQLFabric to indicate that DDL
-     * replay is in progress and so cache operations/functions should not be
-     * routed to that node.
-     */
-    public boolean memberUnInitialized = false;
     
     /**
      * True when a members persistent store is initialized. Note that
@@ -615,7 +597,6 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
       if (this.isGatewayEnabled) s |= IS_GATEWAY_ENABLED_MASK;
       if (this.isPersistent) s |= PERSISTENT_MASK;
       if (this.regionInitialized) s|= REGION_INITIALIZED_MASK;
-      if (this.memberUnInitialized) s |= MEMBER_UNINITIALIZED_MASK;
       if (this.persistentID != null) s|= PERSISTENT_ID_MASK;
       if (this.hasCacheServer) s|= HAS_CACHE_SERVER_MASK;
       if (this.requiresOldValueInEvents) s|= REQUIRES_OLD_VALUE_MASK;
@@ -693,7 +674,6 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
       this.isGatewayEnabled = (s & IS_GATEWAY_ENABLED_MASK) != 0;
       this.isPersistent = (s & PERSISTENT_MASK) != 0;
       this.regionInitialized = ( (s & REGION_INITIALIZED_MASK) != 0 );
-      this.memberUnInitialized = (s & MEMBER_UNINITIALIZED_MASK) != 0;
       this.hasCacheServer = ( (s & HAS_CACHE_SERVER_MASK) != 0 );
       this.requiresOldValueInEvents = ((s & REQUIRES_OLD_VALUE_MASK) != 0);
       this.persistenceInitialized = (s & PERSISTENCE_INITIALIZED_MASK) != 0;
@@ -890,8 +870,6 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
       sb.append("; scope=" + this.scope);
       sb.append("; regionInitialized=").append(
           String.valueOf(this.regionInitialized));
-      sb.append("; memberUnInitialized=").append(
-          String.valueOf(this.memberUnInitialized));
       sb.append("; inRecovery=" + this.inRecovery);
       sb.append("; subcription=" + this.subscriptionAttributes);
       sb.append("; isPartitioned=" + this.isPartitioned);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServerLauncher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServerLauncher.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServerLauncher.java
index bb595d1..e982e32 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServerLauncher.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServerLauncher.java
@@ -362,7 +362,7 @@ public class CacheServerLauncher  {
     }
 
     // -J-Djava.awt.headless=true has been added for Mac platform where it
-    // causes an icon to appear for sqlf launched procs
+    // causes an icon to appear for launched procs
     // TODO: check which library/GemFire code causes awt to be touched
     vmArgs.add("-Djava.awt.headless=true");
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CachedDeserializableFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CachedDeserializableFactory.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CachedDeserializableFactory.java
index 83b0a58..ae60056 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CachedDeserializableFactory.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CachedDeserializableFactory.java
@@ -39,13 +39,6 @@ public class CachedDeserializableFactory {
   public static boolean STORE_ALL_VALUE_FORMS = Boolean.getBoolean(DistributionConfig.GEMFIRE_PREFIX + "STORE_ALL_VALUE_FORMS");
 
   /**
-   * Currently GFE always wants a CachedDeserializable wrapper.
-   */
-  public static final boolean preferObject() {
-    return false;
-  }
-  
-  /**
    * Creates and returns an instance of CachedDeserializable that contains the
    * specified byte array.
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
index b53ed31..012a77f 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
@@ -47,61 +47,7 @@ public class ColocationHelper {
 
   /** Logging mechanism for debugging */
   private static final Logger logger = LogService.getLogger();
-   /**
-    * An utility method to retrieve colocated region name of a given partitioned
-    * region without waiting on initialize
-    *
-    * @param partitionedRegion
-    * @return colocated PartitionedRegion
-    * @since GemFire cheetah
-    */
-  public static PartitionedRegion getColocatedRegionName(
-      final PartitionedRegion partitionedRegion) {
-    Assert.assertTrue(partitionedRegion != null); // precondition1
-    String colocatedWith = partitionedRegion.getPartitionAttributes().getColocatedWith();
-    if (colocatedWith == null) {
-      // the region is not colocated with any region
-      return null;
-    }
-    PartitionedRegion colocatedPR = partitionedRegion.getColocatedWithRegion();
-    if (colocatedPR != null && !colocatedPR.isLocallyDestroyed
-        && !colocatedPR.isDestroyed()) {
-      return colocatedPR;
-    }
-    Region prRoot = PartitionedRegionHelper.getPRRoot(partitionedRegion
-        .getCache());
-    PartitionRegionConfig prConf = (PartitionRegionConfig)prRoot
-        .get(getRegionIdentifier(colocatedWith));
-    int prID = -1; 
-    try {
-      if (prConf == null) {
-        colocatedPR = getColocatedPR(partitionedRegion, colocatedWith);
-      }
-      else {
-        prID = prConf.getPRId();
-        colocatedPR = PartitionedRegion.getPRFromId(prID);
-        if (colocatedPR == null && prID > 0) {
-          // colocatedPR might have not called registerPartitionedRegion() yet, but since prID is valid,
-          // we are able to get colocatedPR and do colocatedPR.waitOnBucketMetadataInitialization()
-          colocatedPR = getColocatedPR(partitionedRegion, colocatedWith);
-        }
-      }
-    }
-    catch (PRLocallyDestroyedException e) {
-      if (logger.isDebugEnabled()) {
-        logger.debug("PRLocallyDestroyedException : Region with prId=" + prID
-            + " is locally destroyed on this node", e);
-      } 
-    } 
-    return colocatedPR;
-  }
-    private static PartitionedRegion getColocatedPR(
-      final PartitionedRegion partitionedRegion, final String colocatedWith) {
-    PartitionedRegion colocatedPR = (PartitionedRegion) partitionedRegion
-        .getCache().getPartitionedRegion(colocatedWith, false);
-    assert colocatedPR != null;
-    return colocatedPR;
-  }
+
   /** Whether to ignore missing parallel queues on restart
    * if they are not attached to the region. See bug 50120. Mutable
    * for tests.
@@ -517,17 +463,6 @@ public class ColocationHelper {
     
     return prRegion;
   }
-  
-  // Gemfirexd will skip initialization for PR, so just get region name without waitOnInitialize
-  public static PartitionedRegion getLeaderRegionName(PartitionedRegion prRegion) {
-    PartitionedRegion parentRegion;
-    
-    while((parentRegion = getColocatedRegionName(prRegion)) != null) {
-      prRegion = parentRegion;
-    } 
-      
-    return prRegion;
-  }
 
   private static String getRegionIdentifier(String regionName) {
     if (regionName.startsWith("/")) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyOperation.java
index e267190..5bfb3cc 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyOperation.java
@@ -129,9 +129,6 @@ public class DestroyOperation extends DistributedCacheOperation
     @Retained
     protected final InternalCacheEvent createEvent(DistributedRegion rgn)
         throws EntryNotFoundException {
-      if (rgn.keyRequiresRegionContext()) {
-        ((KeyWithRegionContext)this.key).setRegionContext(rgn);
-      }
       EntryEventImpl ev = createEntryEvent(rgn);
       boolean evReturned = false;
       try {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
index e015460..5da0d9a 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
@@ -85,13 +85,6 @@ public interface DiskEntry extends RegionEntry {
    * @param context
    */
   public void handleValueOverflow(RegionEntryContext context);
-  
-  /**
-   * In some cases we need to do something just after we unset the value
-   * from a DiskEntry that has been moved (i.e. overflowed) to disk.
-   * @param context
-   */
-  public void afterValueOverflow(RegionEntryContext context);
 
   /**
    * Returns true if the DiskEntry value is equal to {@link Token#DESTROYED}, {@link Token#REMOVED_PHASE1}, or {@link Token#REMOVED_PHASE2}.
@@ -247,27 +240,6 @@ public interface DiskEntry extends RegionEntry {
         }
       }
     }
-      
-    /**
-     * Returns false if the entry is INVALID (or LOCAL_INVALID). Determines this
-     * without faulting in the value from disk.
-     * 
-     * @since GemFire 3.2.1
-     */
-    /* TODO prpersist - Do we need this method? It was added by the sqlf merge
-    static boolean isValid(DiskEntry entry, DiskRegion dr) {
-      synchronized (entry) {
-        if (entry.isRecovered()) {
-          // We have a recovered entry whose value is still on disk.
-          // So take a peek at it without faulting it in.
-          //long id = entry.getDiskId().getKeyId();
-          //entry.getDiskId().setKeyId(-id);
-          byte bits = dr.getBits(entry.getDiskId());
-          //TODO Asif:Check if resetting is needed
-          return !EntryBits.isInvalid(bits) && !EntryBits.isLocalInvalid(bits);
-        }
-      }
-    }*/
 
     static boolean isOverflowedToDisk(DiskEntry de, DiskRegion dr, DistributedRegion.DiskPosition dp,RegionEntryContext context) {
       Object v = null;
@@ -372,10 +344,6 @@ public interface DiskEntry extends RegionEntry {
           dr.releaseReadLock();
         }
       }
-      final boolean isEagerDeserialize = entry.isEagerDeserialize();
-      if (isEagerDeserialize) {
-        entry.clearEagerDeserialize();
-      }
       if (Token.isRemovedFromDisk(v)) {
         // fix for bug 31757
         return false;
@@ -386,30 +354,15 @@ public interface DiskEntry extends RegionEntry {
             entry.setSerialized(false);
             entry.value = cd.getDeserializedForReading();
             
-            //For SQLFire we prefer eager deserialized
-//            if(v instanceof ByteSource) {
-//              entry.setEagerDeserialize();
-//            }
           } else {
             // don't serialize here if it is not already serialized
             
             Object tmp = cd.getValue();
-          //For SQLFire we prefer eager deserialized
-//            if(v instanceof ByteSource) {
-//              entry.setEagerDeserialize();
-//            }
             if (tmp instanceof byte[]) {
               byte[] bb = (byte[])tmp;
               entry.value = bb;
               entry.setSerialized(true);
             }
-            else if (isEagerDeserialize && tmp instanceof byte[][]) {
-              // optimize for byte[][] since it will need to be eagerly deserialized
-              // for SQLFabric
-              entry.value = tmp;
-              entry.setEagerDeserialize();
-              entry.setSerialized(true);
-            }
             else {
               try {
                 HeapDataOutputStream hdos = new HeapDataOutputStream(Version.CURRENT);
@@ -437,12 +390,6 @@ public interface DiskEntry extends RegionEntry {
         entry.value = v;
         entry.setSerialized(false);
       }
-      else if (isEagerDeserialize && v instanceof byte[][]) {
-        // optimize for byte[][] since it will need to be eagerly deserialized
-        // for SQLFabric
-        entry.value = v;
-        entry.setEagerDeserialize();
-      }
       else if (v == Token.INVALID) {
         entry.setInvalid();
       }
@@ -460,11 +407,7 @@ public interface DiskEntry extends RegionEntry {
             return false;
           }
         }
-      if (CachedDeserializableFactory.preferObject()) {
-        entry.value = preparedValue;
-        entry.setEagerDeserialize();
-      }
-      else {
+      {
         try {
           HeapDataOutputStream hdos = new HeapDataOutputStream(Version.CURRENT);
           BlobHelper.serializeTo(preparedValue, hdos);
@@ -833,9 +776,7 @@ public interface DiskEntry extends RegionEntry {
         // to the file using the off-heap memory with no extra copying.
         // So we give preference to getRawNewValue over getCachedSerializedNewValue
         Object rawValue = null;
-        if (!event.hasDelta()) {
-          // We don't do this for the delta case because getRawNewValue returns delta
-          // and we want to write the entire new value to disk.
+        {
           rawValue = event.getRawNewValue();
           if (wrapOffHeapReference(rawValue)) {
             return new OffHeapValueWrapper((StoredObject) rawValue);
@@ -969,13 +910,8 @@ public interface DiskEntry extends RegionEntry {
           // Second, do the stats done for the current recovered value
           if (re.getRecoveredKeyId() < 0) {
             if (!entry.isValueNull()) {
-              try {
-                entry.handleValueOverflow(region);
-                entry.setValueWithContext(region, null); // fixes bug 41119
-              }finally {
-                entry.afterValueOverflow(region);
-              }
-              
+              entry.handleValueOverflow(region);
+              entry.setValueWithContext(region, null); // fixes bug 41119
             }
             dr.incNumOverflowOnDisk(1L);
             dr.incNumOverflowBytesOnDisk(did.getValueLength());
@@ -989,11 +925,7 @@ public interface DiskEntry extends RegionEntry {
         }
         else {
           //The new value in the entry needs to be set after the disk writing 
-          // has succeeded. If not , for GemFireXD , it is possible that other thread
-          // may pick this transient value from region entry ( which for 
-          //offheap will eventually be released ) as index key, 
-          //given that this operation is bound to fail in case of
-          //disk access exception.
+          // has succeeded.
           
           //entry.setValueWithContext(region, newValue); // OFFHEAP newValue already prepared
           
@@ -1008,10 +940,7 @@ public interface DiskEntry extends RegionEntry {
           if (dr.isBackup()) {
             dr.testIsRecoveredAndClear(did); // fixes bug 41409
             if (dr.isSync()) {
-              //In case of compression the value is being set first 
-              // because atleast for now , GemFireXD does not support compression
-              // if and when it does support, this needs to be taken care of else
-              // we risk Bug 48965
+              //In case of compression the value is being set first
               if (AbstractRegionEntry.isCompressible(dr, newValue)) {
                 entry.setValueWithContext(region, newValue); // OFFHEAP newValue already prepared
                 
@@ -1134,12 +1063,8 @@ public interface DiskEntry extends RegionEntry {
               false));
         } else {
           if (!oldValueWasNull) {
-            try {
-              entry.handleValueOverflow(context);
-              entry.setValueWithContext(context,null); // fixes bug 41119
-            }finally {
-              entry.afterValueOverflow(context);
-            }
+            entry.handleValueOverflow(context);
+            entry.setValueWithContext(context,null); // fixes bug 41119
           }
         }
         if (entry instanceof LRUEntry) {
@@ -1218,11 +1143,6 @@ public interface DiskEntry extends RegionEntry {
       boolean lruFaultedIn = false;
       boolean done = false;
       try {
-      //Asif: If the entry is instance of LRU then DidkRegion cannot be null.
-      //Since SqlFabric is accessing this method direcly & it passes the owning region,
-      //if the region happens to be persistent PR type, the owning region passed is PR,
-      // but it will have DiskRegion as null. SqlFabric takes care of passing owning region
-      // as BucketRegion in case of Overflow type entry. This is fix for Bug # 41804
       if ( entry instanceof LRUEntry && !dr.isSync() ) {
         synchronized (entry) {
           DiskId did = entry.getDiskId();
@@ -1391,10 +1311,8 @@ public interface DiskEntry extends RegionEntry {
      * Sets the value in the entry.
      * This is only called by the faultIn code once it has determined that
      * the value is no longer in memory.
-     * return the result will only be off-heap if the value is a sqlf ByteSource. Otherwise result will be on-heap.
      * Caller must have "entry" synced.
      */
-    @Retained
     private static Object readValueFromDisk(DiskEntry entry, DiskRecoveryStore region) {
 
       DiskRegionView dr = region.getDiskRegionView();
@@ -1407,16 +1325,8 @@ public interface DiskEntry extends RegionEntry {
       synchronized (did) {
         Object value = getValueFromDisk(dr, did, null);
         if (value == null) return null;
-        @Unretained Object preparedValue = setValueOnFaultIn(value, did, entry, dr, region);
-        // For Sqlfire we want to return the offheap representation.
-        // So we need to retain it for the caller to release.
-        /*if (preparedValue instanceof ByteSource) {
-          // This is the only case in which we return a retained off-heap ref.
-          ((ByteSource)preparedValue).retain();
-          return preparedValue;
-        } else */{
-          return value;
-        }
+        setValueOnFaultIn(value, did, entry, dr, region);
+        return value;
       }
       } finally {
         dr.releaseReadLock();
@@ -1464,16 +1374,7 @@ public interface DiskEntry extends RegionEntry {
 
     static Object readRawValue(byte[] valueBytes, Version version,
         ByteArrayDataInput in) {
-      /*
-      final StaticSystemCallbacks sysCb;
-      if (version != null && (sysCb = GemFireCacheImpl.FactoryStatics
-          .systemCallbacks) != null) {
-        // may need to change serialized shape for SQLFire
-        return sysCb.fromVersion(valueBytes, false, version, in);
-      }
-      else */ {
-        return valueBytes;
-      }
+      return valueBytes;
     }
 
     public static void incrementBucketStats(Object owner,
@@ -1521,12 +1422,6 @@ public interface DiskEntry extends RegionEntry {
         did = entry.getDiskId();
       }
       
-      // Notify the SQLFire IndexManager if present
-     /* final IndexUpdater indexUpdater = region.getIndexUpdater();
-      if(indexUpdater != null && dr.isSync()) {
-        indexUpdater.onOverflowToDisk(entry);
-      }*/
-      
       int change = 0;
       boolean scheduledAsyncHere = false;
       dr.acquireReadLock();
@@ -1561,13 +1456,8 @@ public interface DiskEntry extends RegionEntry {
           // do the stats when it is actually written to disk
         } else {
           region.updateSizeOnEvict(entry.getKey(), oldSize);
-          //did.setValueSerializedSize(byteSizeOnDisk);
-          try {
-            entry.handleValueOverflow(region);
-            entry.setValueWithContext(region,null);
-          }finally {
-            entry.afterValueOverflow(region);
-          }
+          entry.handleValueOverflow(region);
+          entry.setValueWithContext(region,null);
           movedValueToDisk = true;
           change = ((LRUClockNode)entry).updateEntrySize(ccHelper);
         }
@@ -1648,12 +1538,8 @@ public interface DiskEntry extends RegionEntry {
                 dr.incNumOverflowBytesOnDisk(did.getValueLength());
                 incrementBucketStats(region, 0/*InVM*/, 0/*OnDisk*/,
                                      did.getValueLength());
-                try {
-                  entry.handleValueOverflow(region);
-                  entry.setValueWithContext(region,null);
-                }finally {
-                  entry.afterValueOverflow(region);
-                }
+                entry.handleValueOverflow(region);
+                entry.setValueWithContext(region,null);
               }
               
               //See if we the entry we wrote to disk has the same tag
@@ -1769,12 +1655,8 @@ public interface DiskEntry extends RegionEntry {
                 dr.incNumOverflowBytesOnDisk(did.getValueLength());
                 incrementBucketStats(region, 0/*InVM*/, 0/*OnDisk*/,
                                      did.getValueLength());
-                try {
-                 entry.handleValueOverflow(region);
-                 entry.setValueWithContext(region,null);
-                }finally {
-                  entry.afterValueOverflow(region);
-                }
+                entry.handleValueOverflow(region);
+                entry.setValueWithContext(region,null);
               }
             } catch (RegionClearedException ignore) {
               // no need to do the op since it was clobbered by a region clear

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
index 018a065..c6533a5 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
@@ -2435,8 +2435,6 @@ public class DiskInitFile implements DiskInitFileInterpreter {
 
   /**
    * Additional flags for a disk region that are persisted in its meta-data.
-   * Currently only few for GemFireXD added here but all other boolean flags also
-   * be better moved here.
    * 
    * @since GemFire 7.0
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
index a2092fd..3f511f0 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
@@ -791,8 +791,6 @@ public class DiskRegion extends AbstractDiskRegion {
           DiskId id = de.getDiskId();
           if (id != null) {
             synchronized (id) {
-              // SQLFabric: give a chance to copy key from value bytes when key
-              // is just a pointer to value row
               re.setValueToNull(); // TODO why call _setValue twice in a row?
               re.removePhase2();
               id.unmarkForWriting();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
index 9bb148b..3e005cb 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
@@ -83,18 +83,6 @@ public final class DiskWriteAttributesImpl implements DiskWriteAttributes
   public static final String SYNCHRONOUS_PROPERTY = "synchronous";
 
   /**
-   * The property used to specify the base directory for Sql Fabric persistence
-   * of Gateway Queues, Tables, Data Dictionary etc.
-   */
-  public static final String SYS_PERSISTENT_DIR = "sys-disk-dir";
-
-  /**
-   * The system property for {@link #SYS_PERSISTENT_DIR}.
-   */
-  public static final String SYS_PERSISTENT_DIR_PROP = "sqlfabric."
-      + SYS_PERSISTENT_DIR;
-
-  /**
    * Default disk directory size in megabytes
    * 
    * @since GemFire 5.1
@@ -477,83 +465,4 @@ public final class DiskWriteAttributesImpl implements DiskWriteAttributes
   {
     return DEFAULT_SYNC_DWA;
   }
-
-
-  // Asif: Sql Fabric related helper methods.
-  // These static functions need to be moved to a better place.
-  // preferably in sql Fabric source tree but since GatewayImpl is also
-  // utilizing it, we have no option but to keep it here.
-  public static String generateOverFlowDirName(String dirName) {
-    dirName = generatePersistentDirName(dirName);
-    final GemFireCacheImpl cache = GemFireCacheImpl.getInstance();
-    if (cache == null) {
-      throw new CacheClosedException(
-          "DiskWriteAttributesImpl::generateOverFlowDirName: no cache found.");
-    }
-    /* [sumedh] no need of below since sys-disk-dir is VM specific anyways
-    char fileSeparator = System.getProperty("file.separator").charAt(0);
-    DistributedMember member = cache.getDistributedSystem()
-        .getDistributedMember();
-    String host = member.getHost();
-    int pid = member.getProcessId();
-    final StringBuilder temp = new StringBuilder(dirName);
-    temp.append(fileSeparator);
-    temp.append(host);
-    temp.append('-');
-    temp.append(pid);
-    return temp.toString();
-    */
-    return dirName;
-  }
-
-  public static String generatePersistentDirName(String dirPath) {
-    String baseDir = System.getProperty(SYS_PERSISTENT_DIR_PROP);
-    if (baseDir == null) {
-    //Kishor : TODO : Removing old wan related code
-      //baseDir = GatewayQueueAttributes.DEFAULT_OVERFLOW_DIRECTORY;
-      baseDir = ".";
-    }
-    if (dirPath != null) {
-      File dirProvided = new File(dirPath);
-      // Is the directory path absolute?
-      // For Windows this will check for drive letter. However, we want
-      // to allow for no drive letter so prepend the drive.
-      boolean isAbsolute = dirProvided.isAbsolute();
-      if (!isAbsolute) {
-        String driveName;
-        // get the current drive for Windows and prepend
-        if ((dirPath.charAt(0) == '/' || dirPath.charAt(0) == '\\')
-            && (driveName = getCurrentDriveName()) != null) {
-          isAbsolute = true;
-          dirPath = driveName + dirPath;
-        }
-      }
-      if (!isAbsolute) {
-        // relative path so resolve it relative to parent dir
-        dirPath = new File(baseDir, dirPath).getAbsolutePath();
-      }
-    }
-    else {
-      dirPath = baseDir;
-    }
-    return dirPath;
-  }
-
-  /**
-   * Get the drive name of current working directory for windows else return
-   * null for non-Windows platform (somewhat of a hack -- see if something
-   * cleaner can be done for this).
-   */
-  public static String getCurrentDriveName() {
-    if (System.getProperty("os.name").startsWith("Windows")) {
-      try {
-        // get the current drive
-        return new File(".").getCanonicalPath().substring(0, 2);
-      } catch (IOException ex) {
-        throw new IllegalArgumentException(
-            "Failed in setting the overflow directory", ex);
-      }
-    }
-    return null;
-  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
index cafdb80..ed59108 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
@@ -447,7 +447,7 @@ public class DistTXState extends TXState {
         postPutAll(dtop.getPutAllOperation(), versions, dtop.region);
       } else {
         result = putEntryOnRemote(dtop, false/* ifNew */,
-          dtop.hasDelta()/* ifOld */, null/* expectedOldValue */,
+          false/* ifOld */, null/* expectedOldValue */,
           false/* requireOldValue */, 0L/* lastModified */, true/*
                                                                  * overwriteDestroyed
                                                                  * *not*
@@ -572,7 +572,7 @@ public class DistTXState extends TXState {
           @Released EntryEventImpl ev = PutAllPRMessage.getEventFromEntry(theRegion,
               myId, myId, i, putallOp.putAllData, false, putallOp
                   .getBaseEvent().getContext(), false, !putallOp.getBaseEvent()
-                  .isGenerateCallbacks(), false);
+                  .isGenerateCallbacks());
           try {
 //            ev.setPutAllOperation(putallOp);
             

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXStateOnCoordinator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXStateOnCoordinator.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXStateOnCoordinator.java
index 33bec1c..436c637 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXStateOnCoordinator.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXStateOnCoordinator.java
@@ -359,7 +359,7 @@ public final class DistTXStateOnCoordinator extends DistTXState implements
         postPutAll(dtop.getPutAllOperation(), versions, dtop.region);
       } else {
         result = putEntry(dtop, false/* ifNew */,
-          dtop.hasDelta()/* ifOld */, null/* expectedOldValue */,
+          false/* ifOld */, null/* expectedOldValue */,
           false/* requireOldValue */, 0L/* lastModified */, true/*
                                                                  * overwriteDestroyed
                                                                  * *not*

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
index 6b1073b..83d4c5a 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
@@ -101,13 +101,6 @@ public abstract class DistributedCacheOperation {
   public static final byte DESERIALIZATION_POLICY_NONE = (byte)0;
 
   /**
-   * Deserialization policy: deserialize eagerly (for Deltas)
-   * 
-   * @since GemFire 5.7
-   */
-  public static final byte DESERIALIZATION_POLICY_EAGER = (byte)1;
-
-  /**
    * Deserialization policy: deserialize lazily (for all other objects)
    * 
    * @since GemFire 5.7
@@ -115,14 +108,11 @@ public abstract class DistributedCacheOperation {
   public static final byte DESERIALIZATION_POLICY_LAZY = (byte)2;
   
   /**
-   * @param deserializationPolicy must be one of the following: DESERIALIZATION_POLICY_NONE, DESERIALIZATION_POLICY_EAGER, DESERIALIZATION_POLICY_LAZY.
+   * @param deserializationPolicy must be one of the following: DESERIALIZATION_POLICY_NONE, DESERIALIZATION_POLICY_LAZY.
    */
   public static void writeValue(final byte deserializationPolicy, final Object vObj, final byte[] vBytes, final DataOutput out) throws IOException {
     if (vObj != null) {
-      if (deserializationPolicy == DESERIALIZATION_POLICY_EAGER) {
-        // for DESERIALIZATION_POLICY_EAGER avoid extra byte array serialization
-        DataSerializer.writeObject(vObj, out);
-      } else if (deserializationPolicy == DESERIALIZATION_POLICY_NONE) {
+      if (deserializationPolicy == DESERIALIZATION_POLICY_NONE) {
         // We only have NONE with a vObj when vObj is off-heap and not serialized.
         StoredObject so = (StoredObject) vObj;
         assert !so.isSerialized();
@@ -131,14 +121,7 @@ public abstract class DistributedCacheOperation {
         DataSerializer.writeObjectAsByteArray(vObj, out);
       }
     } else {
-      if (deserializationPolicy == DESERIALIZATION_POLICY_EAGER) {
-        // object is already in serialized form in the byte array.
-        // So just write the bytes to the stream.
-        // fromData will call readObject which will deserialize to object form.
-        out.write(vBytes);
-      } else {
-        DataSerializer.writeByteArray(vBytes, out);
-      }
+      DataSerializer.writeByteArray(vBytes, out);
     }    
   }
   // static values for oldValueIsObject
@@ -151,7 +134,6 @@ public abstract class DistributedCacheOperation {
    */
   public static byte valueIsToDeserializationPolicy(boolean oldValueIsSerialized) {
     if (!oldValueIsSerialized) return DESERIALIZATION_POLICY_NONE;
-    if (CachedDeserializableFactory.preferObject()) return DESERIALIZATION_POLICY_EAGER;
     return DESERIALIZATION_POLICY_LAZY;
   }
 
@@ -180,8 +162,6 @@ public abstract class DistributedCacheOperation {
     switch (policy) {
     case DESERIALIZATION_POLICY_NONE:
       return "NONE";
-    case DESERIALIZATION_POLICY_EAGER:
-      return "EAGER";
     case DESERIALIZATION_POLICY_LAZY:
       return "LAZY";
     default:
@@ -863,8 +843,6 @@ public abstract class DistributedCacheOperation {
 
     private final static int INHIBIT_NOTIFICATIONS_MASK = 0x400;
 
-    protected final static short IS_PUT_DML = 0x100;
-
     public boolean needsRouting;
 
     protected String regionPath;
@@ -1364,9 +1342,6 @@ public abstract class DistributedCacheOperation {
       }
       if ((extBits & INHIBIT_NOTIFICATIONS_MASK) != 0) {
         this.inhibitAllNotifications = true;
-	  if (this instanceof PutAllMessage) {
-        ((PutAllMessage) this).setPutDML((extBits & IS_PUT_DML) != 0);
-      }
       }
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
index 5d71ef2..e73ca35 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
@@ -51,7 +51,6 @@ import com.gemstone.gemfire.internal.DataSerializableFixedID;
 import com.gemstone.gemfire.internal.InternalDataSerializer;
 import com.gemstone.gemfire.internal.Version;
 import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.delta.Delta;
 import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
 import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
@@ -416,8 +415,7 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
      * {@link PutAllPRMessage#toData(DataOutput)} <br>
      * {@link RemotePutAllMessage#toData(DataOutput)} <br>
      */
-    public final void toData(final DataOutput out, 
-        final boolean requiresRegionContext) throws IOException {
+    public final void toData(final DataOutput out) throws IOException {
       Object key = this.key;
       final Object v = this.value;
       DataSerializer.writeObject(key, out);
@@ -856,7 +854,6 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
     PutAllMessage msg = new PutAllMessage();
     msg.eventId = event.getEventId();
     msg.context = event.getContext();
-    msg.setPutDML(event.isPutDML());
     return msg;
   }
 
@@ -870,7 +867,7 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
   public PutAllPRMessage createPRMessagesNotifyOnly(int bucketId) {
     final EntryEventImpl event = getBaseEvent();
     PutAllPRMessage prMsg = new PutAllPRMessage(bucketId, putAllDataSize, true,
-        event.isPossibleDuplicate(), !event.isGenerateCallbacks(), event.getCallbackArgument(), false /*isPutDML*/);
+        event.isPossibleDuplicate(), !event.isGenerateCallbacks(), event.getCallbackArgument());
     if (event.getContext() != null) {
       prMsg.setBridgeContext(event.getContext());
     }
@@ -899,7 +896,7 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
       PutAllPRMessage prMsg = (PutAllPRMessage)prMsgMap.get(bucketId);
       if (prMsg == null) {
         prMsg = new PutAllPRMessage(bucketId.intValue(), putAllDataSize, false,
-            event.isPossibleDuplicate(), !event.isGenerateCallbacks(), event.getCallbackArgument(), event.isPutDML());
+            event.isPossibleDuplicate(), !event.isGenerateCallbacks(), event.getCallbackArgument());
         prMsg.setTransactionDistributed(event.getRegion().getCache().getTxManager().isDistributed());
 
         // set dpao's context(original sender) into each PutAllMsg
@@ -1076,8 +1073,6 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
 
     protected EventID eventId = null;
     
-    private transient boolean isPutDML = false;
-
     protected static final short HAS_BRIDGE_CONTEXT = UNRESERVED_FLAGS_START;
     protected static final short SKIP_CALLBACKS =
       (short)(HAS_BRIDGE_CONTEXT << 1);
@@ -1132,13 +1127,10 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
      * @param rgn
      *          the region the entry is put in
      */
-    public void doEntryPut(PutAllEntryData entry, DistributedRegion rgn,
-        boolean requiresRegionContext, boolean isPutDML) {
+    public void doEntryPut(PutAllEntryData entry, DistributedRegion rgn) {
       @Released EntryEventImpl ev = PutAllMessage.createEntryEvent(entry, getSender(), 
-          this.context, rgn,
-          requiresRegionContext, this.possibleDuplicate,
+          this.context, rgn, this.possibleDuplicate,
           this.needsRouting, this.callbackArg, true, skipCallbacks);
-      ev.setPutDML(isPutDML);
       // we don't need to set old value here, because the msg is from remote. local old value will get from next step
       try {
         super.basicOperateOnRegion(ev, rgn);
@@ -1158,7 +1150,6 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
      * @param sender
      * @param context
      * @param rgn
-     * @param requiresRegionContext
      * @param possibleDuplicate
      * @param needsRouting
      * @param callbackArg
@@ -1167,13 +1158,10 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
     @Retained
     public static EntryEventImpl createEntryEvent(PutAllEntryData entry,
         InternalDistributedMember sender, ClientProxyMembershipID context,
-        DistributedRegion rgn, boolean requiresRegionContext, 
+        DistributedRegion rgn,
         boolean possibleDuplicate, boolean needsRouting, Object callbackArg,
         boolean originRemote, boolean skipCallbacks) {
       final Object key = entry.getKey();
-      if (requiresRegionContext) {
-        ((KeyWithRegionContext)key).setRegionContext(rgn);
-      }
       EventID evId = entry.getEventID();
       @Retained EntryEventImpl ev = EntryEventImpl.create(rgn, entry.getOp(),
           key, null/* value */, callbackArg,
@@ -1225,14 +1213,13 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
       
       rgn.syncBulkOp(new Runnable() {
         public void run() {
-          final boolean requiresRegionContext = rgn.keyRequiresRegionContext();
           final boolean isDebugEnabled = logger.isDebugEnabled();
           for (int i = 0; i < putAllDataSize; ++i) {
             if (isDebugEnabled) {
               logger.debug("putAll processing {} with {} sender={}", putAllData[i], putAllData[i].versionTag, sender);
             }
             putAllData[i].setSender(sender);
-            doEntryPut(putAllData[i], rgn, requiresRegionContext,  isPutDML);
+            doEntryPut(putAllData[i], rgn);
           }
         }
       }, ev.getEventId());
@@ -1283,10 +1270,6 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
         EntryVersionsList versionTags = new EntryVersionsList(putAllDataSize);
 
         boolean hasTags = false;
-        // get the "keyRequiresRegionContext" flag from first element assuming
-        // all key objects to be uniform
-        final boolean requiresRegionContext =
-          (this.putAllData[0].key instanceof KeyWithRegionContext);
         for (int i = 0; i < this.putAllDataSize; i++) {
           if (!hasTags && putAllData[i].versionTag != null) {
             hasTags = true;
@@ -1294,7 +1277,7 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
           VersionTag<?> tag = putAllData[i].versionTag;
           versionTags.add(tag);
           putAllData[i].versionTag = null;
-          this.putAllData[i].toData(out, requiresRegionContext);
+          this.putAllData[i].toData(out);
           this.putAllData[i].versionTag = tag;
         }
 
@@ -1342,11 +1325,7 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
         Object valueObj = null;
         Object v = entry.getValue();
         byte deserializationPolicy;
-        if (v instanceof Delta) {
-          deserializationPolicy = DESERIALIZATION_POLICY_EAGER;
-          valueObj = v;
-        }
-        else if (v instanceof CachedDeserializable) {
+        if (v instanceof CachedDeserializable) {
           deserializationPolicy = DESERIALIZATION_POLICY_LAZY;
           valueBytes = ((CachedDeserializable)v).getSerializedValue();
         }
@@ -1360,18 +1339,5 @@ public class DistributedPutAllOperation extends AbstractUpdateOperation
       }
       return Arrays.asList(ops);
     }
-    
-    public void setPutDML(boolean val) {
-      this.isPutDML = val;
-    }
-    
-    @Override
-    protected short computeCompressedExtBits(short bits) {
-      bits = super.computeCompressedExtBits(bits);
-      if (isPutDML) {
-        bits |= IS_PUT_DML;
-      }
-      return bits;
-    }
   }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
index eed5268..b42a617 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
@@ -28,7 +28,6 @@ import com.gemstone.gemfire.cache.execute.FunctionException;
 import com.gemstone.gemfire.cache.execute.ResultCollector;
 import com.gemstone.gemfire.cache.execute.ResultSender;
 import com.gemstone.gemfire.cache.persistence.PersistentReplicatesOfflineException;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.cache.wan.GatewaySender;
 import com.gemstone.gemfire.distributed.DistributedLockService;
 import com.gemstone.gemfire.distributed.DistributedMember;
@@ -1136,21 +1135,8 @@ public class DistributedRegion extends LocalRegion implements
       getLockService(); // create lock service eagerly now
     }
 
-    final IndexUpdater indexUpdater = getIndexUpdater();
-    boolean sqlfGIILockTaken = false;
-    // this try block is to release the SQLF GII lock in finally
-    // which should be done after bucket status will be set
-    // properly in LocalRegion#initialize()
-    try {
      try {
       try {
-        // take the GII lock to avoid missing entries while updating the
-        // index list for SQLFabric (#41330 and others)
-        if (indexUpdater != null) {
-          indexUpdater.lockForGII();
-          sqlfGIILockTaken = true;
-        }
-        
         PersistentMemberID persistentId = null;
         boolean recoverFromDisk = isRecoveryNeeded();
         DiskRegion dskRgn = getDiskRegion();
@@ -1194,11 +1180,6 @@ public class DistributedRegion extends LocalRegion implements
         this.eventTracker.setInitialized();
       }
      }
-    } finally {
-      if (sqlfGIILockTaken) {
-        indexUpdater.unlockForGII();
-      }
-    }
   }
 
   @Override
@@ -2273,13 +2254,6 @@ public class DistributedRegion extends LocalRegion implements
     }
     profile.serialNumber = getSerialNumber();
     profile.regionInitialized = this.isInitialized();
-    if (!this.isUsedForPartitionedRegionBucket()) {
-      profile.memberUnInitialized = getCache().isUnInitializedMember(
-          profile.getDistributedMember());
-    }
-    else {
-      profile.memberUnInitialized = false;
-    }
     profile.persistentID = getPersistentID();
     if(getPersistenceAdvisor() != null) {
       profile.persistenceInitialized = getPersistenceAdvisor().isOnline();
@@ -2485,11 +2459,7 @@ public class DistributedRegion extends LocalRegion implements
     }
     
     if (preferCD) {
-      if (event.hasDelta()) {
-        result = event.getNewValue();
-      } else {
         result = event.getRawNewValueAsHeapObject();
-      }    
     } else {
       result = event.getNewValue();     
     }
@@ -3909,12 +3879,10 @@ public class DistributedRegion extends LocalRegion implements
   /**
    * Used to bootstrap txState.
    * @param key
-   * @return  distributedRegions,
-   * member with parimary bucket for partitionedRegions
+   * @return member with primary bucket for partitionedRegions
    */
   @Override
   public DistributedMember getOwnerForKey(KeyInfo key) {
-    //Asif: fix for  sqlfabric bug 42266
     assert !this.isInternalRegion() || this.isMetaRegionWithTransactions();
     if (!this.getAttributes().getDataPolicy().withStorage()
         || (this.concurrencyChecksEnabled && this.getAttributes()
@@ -4032,8 +4000,7 @@ public class DistributedRegion extends LocalRegion implements
       if (this.randIndex < 0) {
         this.randIndex = PartitionedRegion.rand.nextInt(numProfiles);
       }
-      if (cp.dataPolicy.withReplication() && cp.regionInitialized
-          && !cp.memberUnInitialized) {
+      if (cp.dataPolicy.withReplication() && cp.regionInitialized) {
         if (onlyPersistent && !cp.dataPolicy.withPersistence()) {
           return true;
         }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage.java
index e51bedd..af54945 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage.java
@@ -231,8 +231,6 @@ public class DistributedRegionFunctionStreamingMessage extends DistributionMessa
           }
         }
         // Send the reply if the operateOnPartitionedRegion returned true
-        // Fix for hang in dunits on sqlfabric after merge.
-        //ReplyMessage.send(getSender(), this.processorId, rex, dm);
         sendReply(getSender(), this.processorId, dm, rex, null, 0, true, false);
       }
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
index eabefdf..0390b29 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
@@ -380,8 +380,7 @@ public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TO
      * {@link PutAllPRMessage#toData(DataOutput)} <br>
      * {@link RemotePutAllMessage#toData(DataOutput)} <br>
      */
-    public final void toData(final DataOutput out, 
-        final boolean requiresRegionContext) throws IOException {
+    public final void toData(final DataOutput out) throws IOException {
       Object key = this.key;
       DataSerializer.writeObject(key, out);
 
@@ -886,11 +885,9 @@ public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TO
      * @param rgn
      *          the region the entry is removed from
      */
-    public void doEntryRemove(RemoveAllEntryData entry, DistributedRegion rgn,
-        boolean requiresRegionContext) {
+    public void doEntryRemove(RemoveAllEntryData entry, DistributedRegion rgn) {
       @Released EntryEventImpl ev = RemoveAllMessage.createEntryEvent(entry, getSender(), 
-          this.context, rgn,
-          requiresRegionContext, this.possibleDuplicate,
+          this.context, rgn, this.possibleDuplicate,
           this.needsRouting, this.callbackArg, true, skipCallbacks);
 //      rgn.getLogWriterI18n().info(LocalizedStrings.DEBUG, "RemoveAllMessage.doEntryRemove sender=" + getSender() +
 //          " event="+ev);
@@ -922,7 +919,6 @@ public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TO
      * @param sender
      * @param context
      * @param rgn
-     * @param requiresRegionContext
      * @param possibleDuplicate
      * @param needsRouting
      * @param callbackArg
@@ -931,13 +927,10 @@ public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TO
     @Retained
     public static EntryEventImpl createEntryEvent(RemoveAllEntryData entry,
         InternalDistributedMember sender, ClientProxyMembershipID context,
-        DistributedRegion rgn, boolean requiresRegionContext, 
+        DistributedRegion rgn,
         boolean possibleDuplicate, boolean needsRouting, Object callbackArg,
         boolean originRemote, boolean skipCallbacks) {
       final Object key = entry.getKey();
-      if (requiresRegionContext) {
-        ((KeyWithRegionContext)key).setRegionContext(rgn);
-      }
       EventID evId = entry.getEventID();
       @Retained EntryEventImpl ev = EntryEventImpl.create(rgn, entry.getOp(),
           key, null/* value */, callbackArg,
@@ -985,13 +978,12 @@ public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TO
       
       rgn.syncBulkOp(new Runnable() {
         public void run() {
-          final boolean requiresRegionContext = rgn.keyRequiresRegionContext();
           for (int i = 0; i < removeAllDataSize; ++i) {
             if (logger.isTraceEnabled()) {
               logger.trace("removeAll processing {} with {}", removeAllData[i], removeAllData[i].versionTag);
             }
             removeAllData[i].setSender(sender);
-            doEntryRemove(removeAllData[i], rgn, requiresRegionContext);
+            doEntryRemove(removeAllData[i], rgn);
           }
         }
       }, ev.getEventId());
@@ -1043,10 +1035,6 @@ public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TO
         EntryVersionsList versionTags = new EntryVersionsList(removeAllDataSize);
 
         boolean hasTags = false;
-        // get the "keyRequiresRegionContext" flag from first element assuming
-        // all key objects to be uniform
-        final boolean requiresRegionContext =
-          (this.removeAllData[0].key instanceof KeyWithRegionContext);
         for (int i = 0; i < this.removeAllDataSize; i++) {
           if (!hasTags && removeAllData[i].versionTag != null) {
             hasTags = true;
@@ -1054,7 +1042,7 @@ public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TO
           VersionTag<?> tag = removeAllData[i].versionTag;
           versionTags.add(tag);
           removeAllData[i].versionTag = null;
-          this.removeAllData[i].toData(out, requiresRegionContext);
+          this.removeAllData[i].toData(out);
           this.removeAllData[i].versionTag = tag;
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryBits.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryBits.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryBits.java
index f95af60..a67a335 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryBits.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryBits.java
@@ -30,16 +30,6 @@ public abstract class EntryBits {
   private static final byte TOMBSTONE = 0x40;
   private static final byte WITH_VERSIONS = (byte)0x80; // oplog entry contains versions 
 
-  /**
-   * Currently for SQLFabric to deserialize byte[][] eagerly in
-   * InitialImageOperation. Can be made a general flag later for all kinds of
-   * objects in CachedDeserializable whose serialization is not expensive but
-   * that are pretty heavy so creating an intermediate byte[] is expensive.
-   * 
-   * This is a transient bit that clashes with on-disk persisted bits.
-   */
-  private static final byte EAGER_DESERIALIZE = 0x20;
-
   public static boolean isSerialized(byte b) {
     return (b & SERIALIZED) != 0;
   }
@@ -79,10 +69,6 @@ public abstract class EntryBits {
     return (b & (INVALID|LOCAL_INVALID|TOMBSTONE)) == 0;
   }
 
-  public static boolean isEagerDeserialize(byte b) {
-    return (b & EntryBits.EAGER_DESERIALIZE) != 0;
-  }
-
   public static byte setSerialized(byte b, boolean isSerialized) {
     return isSerialized ? (byte)(b | SERIALIZED) : (byte)(b & ~SERIALIZED);
   }
@@ -116,12 +102,4 @@ public abstract class EntryBits {
   public static byte getPersistentBits(byte b) {
     return (byte)(b & (SERIALIZED|INVALID|LOCAL_INVALID|TOMBSTONE|WITH_VERSIONS));
   }
-
-  public static byte setEagerDeserialize(byte b) {
-    return (byte)(b | EntryBits.EAGER_DESERIALIZE);
-  }
-
-  public static byte clearEagerDeserialize(byte b) {
-    return (byte)(b & ~EntryBits.EAGER_DESERIALIZE);
-  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
index 65b2c04..c4849be 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
@@ -21,7 +21,6 @@ import com.gemstone.gemfire.*;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.cache.query.IndexMaintenanceException;
 import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
 import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
 import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
@@ -33,7 +32,6 @@ import com.gemstone.gemfire.distributed.internal.DistributionMessage;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.*;
 import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.delta.Delta;
 import com.gemstone.gemfire.internal.cache.lru.Sizeable;
 import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
 import com.gemstone.gemfire.internal.cache.partitioned.PutMessage;
@@ -92,7 +90,6 @@ public class EntryEventImpl
   private byte[] cachedSerializedNewValue = null;
   @Retained(ENTRY_EVENT_OLD_VALUE)
   private Object oldValue = null;
-  protected Delta delta = null;
  
   protected short eventFlags = 0x0000;
 
@@ -141,13 +138,6 @@ public class EntryEventImpl
   protected ClientProxyMembershipID context = null;
   
   /**
-   * A custom context object that can be used for any other contextual
-   * information. Currently used by SQL Fabric to pass around evaluated rows
-   * from raw byte arrays and routing object.
-   */
-  private transient Object contextObj = null;
-
-  /**
    * this holds the bytes representing the change in value effected by this
    * event.  It is used when the value implements the Delta interface.
    */
@@ -165,8 +155,6 @@ public class EntryEventImpl
   /** version tag for concurrency checks */
   protected VersionTag versionTag;
 
-  private transient boolean isPutDML = false;
-
   /** boolean to indicate that the RegionEntry for this event has been evicted*/
   private transient boolean isEvicted = false;
   
@@ -191,7 +179,7 @@ public class EntryEventImpl
     this.txId = (TXId)DataSerializer.readObject(in);
 
     if (in.readBoolean()) {     // isDelta
-      this.delta = (Delta)DataSerializer.readObject(in);
+      assert false : "isDelta should never be true";
     }
     else {
       // OFFHEAP Currently values are never deserialized to off heap memory. If that changes then this code needs to change.
@@ -247,10 +235,7 @@ public class EntryEventImpl
     this.op = op;
     this.keyInfo = this.region.getKeyInfo(key, newVal, callbackArgument);
 
-    if (newVal instanceof Delta) {
-      this.delta = (Delta)newVal;
-    }
-    else if (!Token.isInvalid(newVal)) {
+    if (!Token.isInvalid(newVal)) {
       basicSetNewValue(newVal);
     }
 
@@ -299,7 +284,6 @@ public class EntryEventImpl
     this.newValueBytes = other.newValueBytes;
     this.cachedSerializedNewValue = other.cachedSerializedNewValue;
     this.re = other.re;
-    this.delta = other.delta;
     if (setOldValue) {
       retainAndSetOldValue(other.basicGetOldValue());
       this.oldValueBytes = other.oldValueBytes;
@@ -781,25 +765,19 @@ public class EntryEventImpl
 
   /**
    * Like getRawNewValue except that if the result is an off-heap reference then copy it to the heap.
-   * ALERT: If there is a Delta, returns that, not the (applied) new value.
    * Note: to prevent the heap copy use getRawNewValue instead
    */
   public final Object getRawNewValueAsHeapObject() {
-    if (this.delta != null) {
-      return this.delta;
-    }
     return OffHeapHelper.getHeapForm(OffHeapHelper.copyIfNeeded(basicGetNewValue()));
   }
   
   /**
-   * If new value is a Delta return it.
-   * Else if new value is off-heap return the StoredObject form (unretained OFF_HEAP_REFERENCE). 
+   * If new value is off-heap return the StoredObject form (unretained OFF_HEAP_REFERENCE). 
    * Its refcount is not inced by this call and the returned object can only be safely used for the lifetime of the EntryEventImpl instance that returned the value.
    * Else return the raw form.
    */
   @Unretained(ENTRY_EVENT_NEW_VALUE)
   public final Object getRawNewValue() {
-    if (this.delta != null) return this.delta;
     return basicGetNewValue();
   }
 
@@ -808,39 +786,6 @@ public class EntryEventImpl
     return basicGetNewValue();
   }
   
-  /**
-   * Returns the delta that represents the new value; null if no delta.
-   * @return the delta that represents the new value; null if no delta.
-   */
-  public final Delta getDeltaNewValue() {
-    return this.delta;
-  }
-
-  /**
-   *  Applies the delta 
-   */
-  private Object applyDeltaWithCopyOnRead(boolean doCopyOnRead) {
-    //try {
-      if (applyDelta(true)) {
-        Object applied = basicGetNewValue();
-        // if applyDelta returns true then newValue should not be off-heap
-        assert !(applied instanceof StoredObject);
-        if (applied == this.oldValue && doCopyOnRead) {
-          applied = CopyHelper.copy(applied);
-        }
-        return applied;
-      }
-    //} catch (EntryNotFoundException ex) {
-      // only (broken) product code has the opportunity to call this before
-      // this.oldValue is set. If oldValue is not set yet, then
-      // we most likely haven't synchronized on the region entry yet.
-      // (If we have, then make sure oldValue is set before
-      // calling this method).
-      //throw new AssertionError("too early to call getNewValue");
-    //}
-    return null;
-  }
-
   @Released(ENTRY_EVENT_NEW_VALUE)
   protected void basicSetNewValue(@Retained(ENTRY_EVENT_NEW_VALUE) Object v) {
     if (v == this.newValue) return;
@@ -1003,23 +948,6 @@ public class EntryEventImpl
   public final Object getNewValue() {
     
     boolean doCopyOnRead = getRegion().isCopyOnRead();
-    try {
-      if (applyDelta(true)) {
-        @Unretained(ENTRY_EVENT_NEW_VALUE)
-        Object applied = basicGetNewValue();
-        if (applied == this.oldValue && doCopyOnRead) {
-          applied = CopyHelper.copy(applied);
-        }
-        return applied;
-      }
-    } catch (EntryNotFoundException ex) {
-      // only (broken) product code has the opportunity to call this before
-      // this.oldValue is set. If oldValue is not set yet, then
-      // we most likely haven't synchronized on the region entry yet.
-      // (If we have, then make sure oldValue is set before
-      // calling this method).
-      throw new AssertionError("too early to call getNewValue");
-    }
     Object nv = basicGetNewValue();
     if (nv != null) {
       if (nv == Token.NOT_AVAILABLE) {
@@ -1055,44 +983,9 @@ public class EntryEventImpl
     return StringUtils.forceToString(basicGetOldValue());
   }
   
-  protected boolean applyDelta(boolean throwOnNullOldValue)
-      throws EntryNotFoundException {
-    if (this.newValue != null || this.delta == null) {
-      return false;
-    }
-    if (this.oldValue == null) {
-      if (throwOnNullOldValue) {
-        // !!!:ezoerner:20080611 It would be nice if the client got this
-        // exception
-        throw new EntryNotFoundException(
-            "Cannot apply a delta without an existing value");
-      }
-      return false;
-    }
-    // swizzle BucketRegion in event for Delta.
-    // !!!:ezoerner:20090602 this is way ugly; this whole class severely
-    // needs refactoring
-    LocalRegion originalRegion = this.region;
-    try {
-      if (originalRegion instanceof BucketRegion) {
-        this.region = ((BucketRegion)this.region).getPartitionedRegion();
-      }
-      basicSetNewValue(this.delta.apply(this));
-    } finally {
-      this.region = originalRegion;
-    }
-    return true;
-  }
-
   /** Set a deserialized value */
   public final void setNewValue(@Retained(ENTRY_EVENT_NEW_VALUE) Object obj) {
-    if (obj instanceof Delta) {
-      this.delta = (Delta)obj;
-      basicSetNewValue(null);
-    }
-    else {
-      basicSetNewValue(obj);
-    }
+    basicSetNewValue(obj);
   }
 
   public TransactionId getTransactionId()
@@ -1384,34 +1277,11 @@ public class EntryEventImpl
   }
 
   /**
-   * If applyDelta is true then first attempt to apply a delta (if we have one) and return the value.
-   * Else if new value is a Delta return it.
-   * Else if new value is off-heap return the StoredObject form (unretained OFF_HEAP_REFERENCE). 
-   * Its refcount is not inced by this call and the returned object can only be safely used for the lifetime of the EntryEventImpl instance that returned the value.
-   * Else return the raw form.
-   */
-  @Unretained(ENTRY_EVENT_NEW_VALUE)
-  public final Object getRawNewValue(boolean applyDelta) {
-    if (applyDelta) {
-      boolean doCopyOnRead = getRegion().isCopyOnRead();
-      Object newValueWithDelta = applyDeltaWithCopyOnRead(doCopyOnRead);
-      if (newValueWithDelta != null) {
-        return newValueWithDelta;
-      }
-      // if applyDelta is true and we have already applied the delta then
-      // just return the applied value instead of the delta object.
-      @Unretained(ENTRY_EVENT_NEW_VALUE)
-      Object newValue = basicGetNewValue();
-      if (newValue != null) return newValue;
-    }
-    return getRawNewValue();
-  }
-  /**
    * Just like getRawNewValue(true) except if the raw new value is off-heap deserialize it.
    */
   @Unretained(ENTRY_EVENT_NEW_VALUE)
   public final Object getNewValueAsOffHeapDeserializedOrRaw() {
-    Object result = getRawNewValue(true);
+    Object result = getRawNewValue();
     if (result instanceof StoredObject) {
       result = ((StoredObject) result).getDeserializedForReading();
     }
@@ -1448,7 +1318,6 @@ public class EntryEventImpl
   }
   
   public final Object getDeserializedValue() {
-    if (this.delta == null) {
       final Object val = basicGetNewValue();
       if (val instanceof CachedDeserializable) {
         return ((CachedDeserializable)val).getDeserializedForReading();
@@ -1456,16 +1325,11 @@ public class EntryEventImpl
       else {
         return val;
       }
-    }
-    else {
-      return this.delta;
-    }
   }
 
   public final byte[] getSerializedValue() {
     if (this.newValueBytes == null) {
       final Object val;
-      if (this.delta == null) {
         val = basicGetNewValue();
         if (val instanceof byte[]) {
           return (byte[])val;
@@ -1473,10 +1337,6 @@ public class EntryEventImpl
         else if (val instanceof CachedDeserializable) {
           return ((CachedDeserializable)val).getSerializedValue();
         }
-      }
-      else {
-        val = this.delta;
-      }
       try {
         return CacheServerHelper.serialize(val);
       } catch (IOException ioe) {
@@ -1508,11 +1368,6 @@ public class EntryEventImpl
     if (isSynced) {
       this.setSerializationDeferred(false);
     }
-    else if (obj == null && this.delta != null) {
-      // defer serialization until setNewValueInRegion
-      this.setSerializationDeferred(true);
-      return;
-    }
     basicSetNewValue(getCachedDeserializable(obj, this));
   }
 
@@ -1527,12 +1382,11 @@ public class EntryEventImpl
                             || obj == Token.NOT_AVAILABLE
                             || Token.isInvalidOrRemoved(obj)
                             // don't serialize delta object already serialized
-                            || obj instanceof com.gemstone.gemfire.Delta
-                            || obj instanceof Delta) { // internal delta
+                            || obj instanceof com.gemstone.gemfire.Delta) { // internal delta
       return obj;
     }
     final CachedDeserializable cd;
-    // avoid unneeded serialization of byte[][] used by SQLFabric that
+    // avoid unneeded serialization of byte[][] that
     // will end up being deserialized in any case (serialization is cheap
     //   for byte[][] anyways)
     if (obj instanceof byte[][]) {
@@ -1567,18 +1421,7 @@ public class EntryEventImpl
   public final void setSerializedNewValue(byte[] serializedValue) {
     Object newVal = null;
     if (serializedValue != null) {
-      if (CachedDeserializableFactory.preferObject()) {
-        newVal = deserialize(serializedValue);
-      } else {
-        newVal = CachedDeserializableFactory.create(serializedValue);
-      }
-      if (newVal instanceof Delta) {
-        this.delta = (Delta)newVal;
-        newVal = null;
-        // We need the newValueBytes field and the newValue field to be in sync.
-        // In the case of non-null delta set both fields to null.
-        serializedValue = null;
-      }
+      newVal = CachedDeserializableFactory.create(serializedValue);
     }
     this.newValueBytes = serializedValue;
     basicSetNewValue(newVal);
@@ -1588,10 +1431,7 @@ public class EntryEventImpl
   public void setSerializedOldValue(byte[] serializedOldValue){
     this.oldValueBytes = serializedOldValue;
     final Object ov;
-    if (CachedDeserializableFactory.preferObject()) {
-      ov = deserialize(serializedOldValue);
-    }
-    else if (serializedOldValue != null) {
+    if (serializedOldValue != null) {
       ov = CachedDeserializableFactory.create(serializedOldValue);
     }
     else {
@@ -1705,12 +1545,6 @@ public class EntryEventImpl
     
     // put in newValue
 
-    if (applyDelta(this.op.isCreate())) {
-      if (this.isSerializationDeferred()) {
-        makeSerializedNewValue(true);
-      }
-    }
-
     // If event contains new value, then it may mean that the delta bytes should
     // not be applied. This is possible if the event originated locally.
     if (this.deltaBytes != null && this.newValue == null) {
@@ -1749,7 +1583,7 @@ public class EntryEventImpl
       basicSetNewValue(v);
     }
 
-    Object preparedV = reentry.prepareValueForCache(this.region, v, this, this.hasDelta());
+    Object preparedV = reentry.prepareValueForCache(this.region, v, this, false);
     if (preparedV != v) {
       v = preparedV;
       if (v instanceof StoredObject) {
@@ -1790,29 +1624,9 @@ public class EntryEventImpl
         }
       }
     }
-    final IndexUpdater indexUpdater = this.region.getIndexUpdater();
-    if (indexUpdater != null) {
-      final LocalRegion indexRegion;
-      if (owner != null) {
-        indexRegion = owner;
-      }
-      else {
-        indexRegion = this.region;
-      }
-      try {
-        indexUpdater.onEvent(indexRegion, this, reentry);
-        calledSetValue = true;
-        reentry.setValueWithTombstoneCheck(v, this); // already called prepareValueForCache
-        success = true;
-      } finally {
-        indexUpdater.postEvent(indexRegion, this, reentry, success);
-      }
-    }
-    else {
-      calledSetValue = true;
-      reentry.setValueWithTombstoneCheck(v, this); // already called prepareValueForCache
-      success = true;
-    }
+    calledSetValue = true;
+    reentry.setValueWithTombstoneCheck(v, this); // already called prepareValueForCache
+    success = true;
     } finally {
       if (!success && reentry instanceof OffHeapRegionEntry && v instanceof StoredObject) {
         OffHeapRegionEntryHelper.releaseEntry((OffHeapRegionEntry)reentry, (StoredObject)v);
@@ -1950,8 +1764,6 @@ public class EntryEventImpl
         // there must be a nearSidePendingValue
         processDeltaBytes(tx.getNearSidePendingValue());
         v = basicGetNewValue();
-      } else if (this.delta != null) {
-        v = this.delta;
       } else {
         v = isLocalInvalid() ? Token.LOCAL_INVALID : Token.INVALID;
       }
@@ -2053,12 +1865,6 @@ public class EntryEventImpl
   /** Return true if new value available */
   public boolean hasNewValue() {
     Object tmp = this.newValue;
-    if (tmp == null && hasDelta()) {
-      // ???:ezoerner:20080611 what if applying the delta would produce
-      // null or (strangely) NOT_AVAILABLE.. do we need to apply it here to
-      // find out?
-      return true;
-    }
     return  tmp != null && tmp != Token.NOT_AVAILABLE;
   }
 
@@ -2069,16 +1875,6 @@ public class EntryEventImpl
     return this.oldValue instanceof Token;
   }
 
-  /**
-   * This should only be used in case of internal delta and <B>not for Delta of
-   * Delta Propagation feature</B>.
-   * 
-   * @return boolean
-   */
-  public boolean hasDelta() {
-    return (this.delta != null);
-  }
-
   public boolean isOldValueAvailable() {
     if (isOriginRemote() && this.region.isProxy()) {
       return false;
@@ -2297,12 +2093,8 @@ public class EntryEventImpl
     DataSerializer.writeObject(this.txId, out);
 
     {
-      boolean isDelta = this.delta != null;
-      out.writeBoolean(isDelta);
-      if (isDelta) {
-        DataSerializer.writeObject(this.delta, out);
-      }
-      else {
+      out.writeBoolean(false);
+      {
         Object nv = basicGetNewValue();
         boolean newValueSerialized = nv instanceof CachedDeserializable;
         if (newValueSerialized) {
@@ -2422,7 +2214,6 @@ public class EntryEventImpl
   public int getNewValSizeForPR()
   {
     int newSize = 0;
-    applyDelta(false);
     Object v = basicGetNewValue();
     if (v != null) {
       try {
@@ -2664,14 +2455,6 @@ public class EntryEventImpl
     return this;
   }
 
-  public final void setContextObject(Object ctx) {
-    this.contextObj = ctx;
-  }
-
-  public final Object getContextObject() {
-    return this.contextObj;
-  }
-
   /**
    * @return the keyInfo
    */
@@ -2994,12 +2777,4 @@ public class EntryEventImpl
   public boolean isOldValueOffHeap() {
     return isOffHeapReference(this.oldValue);
   }
-
-  public final boolean isPutDML() {
-    return this.isPutDML;
-  }
-
-  public final void setPutDML(boolean val) {
-    this.isPutDML = val;
-  }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
index 16215ac..4b757fb 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
@@ -38,7 +38,7 @@ public class EntryOperationImpl implements EntryOperation {
 
   private final Object key;
 
-  private Object callbackArgument = Token.NOT_AVAILABLE;
+  private final Object callbackArgument;
 
   public EntryOperationImpl(Region region, Operation operation, Object key,
       Object value, Object callbackArgument) {
@@ -102,17 +102,4 @@ public class EntryOperationImpl implements EntryOperation {
   public Object getRawNewValue() {
     return this.value;
   }
-
-  /**
-   * Method for internal use. (Used by SQLFabric)
-   */
-  public void setCallbackArgument(Object newCallbackArgument) {
-    if (this.callbackArgument instanceof WrappedCallbackArgument) {
-      ((WrappedCallbackArgument)this.callbackArgument)
-          .setOriginalCallbackArgument(newCallbackArgument);
-    }
-    else {
-      this.callbackArgument = newCallbackArgument;
-    }
-  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
index 5355a2b..186ebbc 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
@@ -17,7 +17,69 @@
 
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.*;
+import java.io.BufferedReader;
+import java.io.ByteArrayInputStream;
+import java.io.ByteArrayOutputStream;
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.InputStreamReader;
+import java.io.OutputStream;
+import java.io.OutputStreamWriter;
+import java.io.PrintStream;
+import java.io.Reader;
+import java.io.StringBufferInputStream;
+import java.io.StringWriter;
+import java.io.Writer;
+import java.net.InetSocketAddress;
+import java.net.URL;
+import java.net.UnknownHostException;
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.Collections;
+import java.util.Date;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.LinkedHashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.Map.Entry;
+import java.util.Properties;
+import java.util.ServiceLoader;
+import java.util.Set;
+import java.util.TreeMap;
+import java.util.concurrent.ArrayBlockingQueue;
+import java.util.concurrent.CancellationException;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.ConcurrentMap;
+import java.util.concurrent.CopyOnWriteArrayList;
+import java.util.concurrent.CopyOnWriteArraySet;
+import java.util.concurrent.ExecutionException;
+import java.util.concurrent.Executor;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+import java.util.concurrent.Future;
+import java.util.concurrent.LinkedBlockingQueue;
+import java.util.concurrent.RejectedExecutionException;
+import java.util.concurrent.ThreadFactory;
+import java.util.concurrent.ThreadPoolExecutor;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicBoolean;
+import java.util.concurrent.atomic.AtomicInteger;
+import java.util.concurrent.atomic.AtomicReference;
+
+import javax.naming.Context;
+
+import org.apache.logging.log4j.Logger;
+
+import com.gemstone.gemfire.CancelCriterion;
+import com.gemstone.gemfire.CancelException;
+import com.gemstone.gemfire.ForcedDisconnectException;
+import com.gemstone.gemfire.GemFireCacheException;
+import com.gemstone.gemfire.InternalGemFireError;
+import com.gemstone.gemfire.LogWriter;
+import com.gemstone.gemfire.SystemFailure;
 import com.gemstone.gemfire.admin.internal.SystemMemberCacheEventProcessor;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.cache.TimeoutException;
@@ -107,19 +169,6 @@ import com.gemstone.gemfire.pdx.internal.TypeRegistry;
 import com.gemstone.gemfire.redis.GemFireRedisServer;
 import com.sun.jna.Native;
 import com.sun.jna.Platform;
-import org.apache.logging.log4j.Logger;
-
-import javax.naming.Context;
-import java.io.*;
-import java.net.InetSocketAddress;
-import java.net.URL;
-import java.net.UnknownHostException;
-import java.util.*;
-import java.util.Map.Entry;
-import java.util.concurrent.*;
-import java.util.concurrent.atomic.AtomicBoolean;
-import java.util.concurrent.atomic.AtomicInteger;
-import java.util.concurrent.atomic.AtomicReference;
 
 // @todo somebody Come up with more reasonable values for {@link #DEFAULT_LOCK_TIMEOUT}, etc.
 /**
@@ -414,18 +463,6 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
 
   private volatile boolean isShutDownAll = false;
 
-  /**
-   * Set of members that are not yet ready. Currently used by SQLFabric during initial DDL replay to indicate that the
-   * member should not be chosen for primary buckets.
-   */
-  private final HashSet<InternalDistributedMember> unInitializedMembers = new HashSet<InternalDistributedMember>();
-
-  /**
-   * Set of {@link BucketAdvisor}s for this node that are pending for volunteer for primary due to uninitialized node
-   * (SQLFabric DDL replay in progress).
-   */
-  private final LinkedHashSet<BucketAdvisor> deferredVolunteerForPrimary = new LinkedHashSet<BucketAdvisor>();
-
   private final ResourceAdvisor resourceAdvisor;
   private final JmxManagerAdvisor jmxAdvisor;
 
@@ -4911,76 +4948,6 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
     return this.regionsInDestroy.get(path);
   }
 
-  /**
-   * Mark a node as initialized or not initialized. Used by SQLFabric to avoid creation of buckets or routing of
-   * operations/functions on a node that is still in the DDL replay phase.
-   */
-  public boolean updateNodeStatus(InternalDistributedMember member, boolean initialized) {
-    HashSet<BucketAdvisor> advisors = null;
-    synchronized (this.unInitializedMembers) {
-      if (initialized) {
-        if (this.unInitializedMembers.remove(member)) {
-          if (member.equals(getMyId())) {
-            // don't invoke volunteerForPrimary() inside the lock since
-            // BucketAdvisor will also require the lock after locking itself
-            advisors = new HashSet<BucketAdvisor>(this.deferredVolunteerForPrimary);
-            this.deferredVolunteerForPrimary.clear();
-          }
-        } else {
-          return false;
-        }
-      } else {
-        return this.unInitializedMembers.add(member);
-      }
-    }
-    if (advisors != null) {
-      for (BucketAdvisor advisor : advisors) {
-        if (logger.isDebugEnabled()) {
-          logger.debug("Invoking volunteer for primary for deferred bucket " + "post SQLFabric DDL replay for BucketAdvisor: {}",  advisor);
-        }
-        advisor.volunteerForPrimary();
-      }
-    }
-    return true;
-  }
-
-  /**
-   * Return true if this node is still not initialized else false.
-   */
-  public boolean isUnInitializedMember(InternalDistributedMember member) {
-    synchronized (this.unInitializedMembers) {
-      return this.unInitializedMembers.contains(member);
-    }
-  }
-
-  /**
-   * Return false for volunteer primary if this node is not currently initialized. Also adds the {@link BucketAdvisor}
-   * to a list that will be replayed once this node is initialized.
-   */
-  public boolean doVolunteerForPrimary(BucketAdvisor advisor) {
-    synchronized (this.unInitializedMembers) {
-      if (!this.unInitializedMembers.contains(getMyId())) {
-        return true;
-      }
-      if (logger.isDebugEnabled()) {
-        logger.debug("Deferring volunteer for primary due to uninitialized " + "node (SQLFabric DDL replay) for BucketAdvisor: {}", advisor);
-      }
-      this.deferredVolunteerForPrimary.add(advisor);
-      return false;
-    }
-  }
-
-  /**
-   * Remove all the uninitialized members from the given collection.
-   */
-  public final void removeUnInitializedMembers(Collection<InternalDistributedMember> members) {
-    synchronized (this.unInitializedMembers) {
-      for (final InternalDistributedMember m : this.unInitializedMembers) {
-        members.remove(m);
-      }
-    }
-  }
-
   public TombstoneService getTombstoneService() {
     return this.tombstoneService;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
index ec5fc4e..ff7dea1 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
@@ -249,7 +249,7 @@ public abstract class GridAdvisor extends DistributionAdvisor {
     private String host;
 
     /**
-     * SQLFabric uses a negative port value when creating a fake profile meant
+     * a negative port value is used when creating a fake profile meant
      * to only gather information about all available locators.
      */
     private int port;
@@ -308,7 +308,7 @@ public abstract class GridAdvisor extends DistributionAdvisor {
         if(advisee != null && advisee.getProfile().equals(this)) {
           continue;
         }
-        // negative value for port used by SQLFabric to indicate fake profile
+        // negative value for port indicates fake profile
         // meant to only gather remote profiles during profile exchange
         if (this.port > 0) {
           handleDistributionAdvisee(advisee, removeProfile, exchangeProfiles,
@@ -337,7 +337,7 @@ public abstract class GridAdvisor extends DistributionAdvisor {
             if(bsi.getProfile().equals(this)) {
               continue;
             }
-            // negative value for port used by SQLFabric to indicate fake
+            // negative value for port indicates fake
             // profile meant to only gather remote profiles during profile
             // exchange
             if (this.port > 0) {



[09/17] incubator-geode git commit: GEODE-1464: remove sqlf code

Posted by kl...@apache.org.
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


[14/17] incubator-geode git commit: GEODE-1464: fix AnalyzeSerializablesJUnitTest

Posted by kl...@apache.org.
GEODE-1464: fix AnalyzeSerializablesJUnitTest


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/103a6bcd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/103a6bcd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/103a6bcd

Branch: refs/heads/feature/GEODE-837
Commit: 103a6bcdf9932dfe0ed5c34c71d942db0e2e02e1
Parents: 880f864
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Tue Jun 7 10:01:28 2016 -0700
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Tue Jun 7 10:01:28 2016 -0700

----------------------------------------------------------------------
 .../sanctionedDataSerializables.txt             | 40 ++++++++++----------
 1 file changed, 20 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/103a6bcd/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 37eee1b..fdad3a8 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
@@ -947,8 +947,8 @@ fromData,14,2a2bb7001a2a2bb8001bb50004b1
 toData,14,2a2bb700182ab400042bb80019b1
 
 com/gemstone/gemfire/internal/cache/DistributedCacheOperation$CacheOperationMessage,2
-fromData,318,2bb9009301003d2bb9009301003e2a1cb500942a1c2bb600952a2bb80096b500212a2bb900970100b80098b500072a1c1100807e99000704a7000403b500022a1c10087e99000704a7000403b500561c1102007e99000b2a2bb8009ab500862a1c1104007e99000704a7000403b500052a1c10407e99000704a7000403b5001b2ab4001b9900382bb900970100360415049a000b2a03b5001ca7001b150404a0000b2a04b5001ca7000dbb009b59129cb7009dbf2a2bb8009eb5001d1c1101007e99000704a700040336042a1c1108007e99000704a7000403b5009f15049900162abb00a059b700a1b5000c2ab4000c2bb800a21c1110007e99001c1c1120007e99000704a700040336052a15052bb800a3b500081d1104007e9900232a04b5000d2ac100a49900172ac000a41d1101007e99000704a7000403b600a5b1
-toData,202,033d033e2a1cb600a63d2a1db600a73e2b1cb900a802002b1db900a802002ab4000b9e000d2b2ab4000bb900a902002ab400212bb800aa2b2ab40007b400abb900ac02002ab40086c6000b2ab400862bb800ad2ab4001b9900542b2ab4001c99000704a7000403b900ac02002ab4001cb800ae36042ab4001c9a001f2ab4001dc1001e990015013a052ab4001dc0001ec0001e3a06a7000c2ab4001d3a05013a061504190519062bb800af2ab4000cc6000b2ab4000c2bb800b02ab40008c6000b2ab400082bb800b0b1
+fromData,291,2bb9009501003d2bb9009501003e2a1cb500962a1c2bb600972a2bb80098b500232a2bb900990100b8009ab500092a1c1100807e99000704a7000403b500042a1c10087e99000704a7000403b500581c1102007e99000b2a2bb8009bb500882a1c1104007e99000704a7000403b500072a1c10407e99000704a7000403b5001d2ab4001d9900382bb900990100360415049a000b2a03b5001ea7001b150404a0000b2a04b5001ea7000dbb009c59129db7009ebf2a2bb8009fb5001f1c1101007e99000704a700040336042a1c1108007e99000704a7000403b500a015049900162abb00a159b700a2b5000e2ab4000e2bb800a31c1110007e99001c1c1120007e99000704a700040336052a15052bb800a4b5000a1d1104007e9900082a04b5000fb1
+toData,202,033d033e2a1cb600a53d2a1db600a63e2b1cb900a702002b1db900a702002ab4000d9e000d2b2ab4000db900a802002ab400232bb800a92b2ab40009b400aab900ab02002ab40088c6000b2ab400882bb800ac2ab4001d9900542b2ab4001e99000704a7000403b900ab02002ab4001eb800ad36042ab4001e9a001f2ab4001fc10020990015013a052ab4001fc00020c000203a06a7000c2ab4001f3a05013a061504190519062bb800ae2ab4000ec6000b2ab4000e2bb800af2ab4000ac6000b2ab4000a2bb800afb1
 
 com/gemstone/gemfire/internal/cache/DistributedClearOperation$ClearRegionMessage,2
 fromData,53,2a2bb700212ab800222bb90023010032b500022a2bb80024c00025b500062a2bb80024c00026b500172a2bb80024c00027b50011b1
@@ -966,8 +966,8 @@ com/gemstone/gemfire/internal/cache/DistributedPutAllOperation$PutAllEntryData,1
 toData,229,2ab4000a4d2ab4000c4e2c2bb8003d2dc1003e9a00072dc700182b03b9003f02002dc0003ec0003e2bb80040a700312dc1004199001e2dc000413a042b04b9003f02001904b9004201002bb80040a7000f2b04b9003f02002d2bb800432b2ab40012b40044b9003f02002ab4000636042ab40026c6000a150407809136042ab40017c6001d15041008809136042ab40017c1004599000b150410208091360415041080809136042b1504b9003f02002ab40026c6000b2ab400262bb8003d2ab40017c6000b2ab400172bb800462ab6002899000b2ab400142bb800462ab400082bb80047b1
 
 com/gemstone/gemfire/internal/cache/DistributedPutAllOperation$PutAllMessage,2
-fromData,197,2a2bb7003c2a2bb8003dc0003eb500052a2bb8003f88b500152a2ab40015bd0040b500062ab400159e00722bb800414dbb004259b700434e03360415042ab40015a200202ab400061504bb0040592b2ab4000515042c2db7004453840401a7ffdd2bb9004501003604150499002f2bb800463a0503360615062ab40015a2001d2ab4000615063219051506b60047c00048b5002e840601a7ffe02ab400491140007e99000e2a2bb8003dc0004bb5000b2a2ab400491180007e99000704a7000403b5001ab1
-toData,181,2a2bb7004c2ab400052bb8004d2ab40015852bb8004e2ab400159e008bbb004f592ab40015b700504d033e2ab400060332b40051c10024360403360515052ab40015a200531d9a00122ab40006150532b4002ec60005043e2ab40006150532b4002e3a062c1906b60052572ab4000615053201b5002e2ab400061505322b1504b600532ab400061505321906b5002e840501a7ffaa2b1db9005402001d9900082c2bb800552ab4000bc6000b2ab4000b2bb8004db1
+fromData,197,2a2bb7003a2a2bb8003bc0003cb500062a2bb8003d88b500162a2ab40016bd003eb500072ab400169e00722bb8003f4dbb004059b700414e03360415042ab40016a200202ab400071504bb003e592b2ab4000615042c2db7004253840401a7ffdd2bb9004301003604150499002f2bb800443a0503360615062ab40016a2001d2ab4000715063219051506b60045c00046b5002c840601a7ffe02ab400471140007e99000e2a2bb8003bc00048b5000c2a2ab400471180007e99000704a7000403b5001bb1
+toData,165,2a2bb700492ab400062bb8004a2ab40016852bb8004b2ab400169e007bbb004c592ab40016b7004d4d033e03360415042ab40016a200511d9a00122ab40007150432b4002cc60005043e2ab40007150432b4002c3a052c1905b6004e572ab4000715043201b5002c2ab400071504322bb6004f2ab400071504321905b5002c840401a7ffac2b1db9005002001d9900082c2bb800512ab4000cc6000b2ab4000c2bb8004ab1
 
 com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage,2
 fromData,171,2a2bb700612bb9006201003d1c047e9900142a2bb900640100b500082ab40008b800651c077e99000d2a2bb900640100b500051c057e99000e2a2bb80066c00067b500062bb800664e2dc100689900252a03b5000d2a2dc00068b80069b500072ab40007c7001b2a2dc00068b5004ca700102a2dc0006ab500072a04b5000d2a2bb80066c0006bb500092a2bb8006cb5000b2a2bb8006db5000a2a1c10407e99000704a7000403b5000cb1
@@ -978,8 +978,8 @@ com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation$RemoveAllEntry
 toData,136,2ab4000a4d2c2bb8003f2b2ab40010b40040b9004102002ab400063e2ab40022c600081d0780913e2ab40015c600191d100880913e2ab40015c100429900091d102080913e1d108080913e2b1db9004102002ab40022c6000b2ab400222bb8003f2ab40015c6000b2ab400152bb800432ab6002499000b2ab400122bb800432ab400082bb80044b1
 
 com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation$RemoveAllMessage,2
-fromData,197,2a2bb700382a2bb80039c0003ab500032a2bb8003b88b500132a2ab40013bd003cb500042ab400139e00722bb8003d4dbb003e59b7003f4e03360415042ab40013a200202ab400041504bb003c592b2ab4000315042c2db7004053840401a7ffdd2bb9004101003604150499002f2bb800423a0503360615062ab40013a2001d2ab4000415063219051506b60043c00044b5002b840601a7ffe02ab400451140007e99000e2a2bb80039c00047b500092a2ab400451180007e99000704a7000403b50018b1
-toData,181,2a2bb700482ab400032bb800492ab40013852bb8004a2ab400139e008bbb004b592ab40013b7004c4d033e2ab400040332b4004dc10026360403360515052ab40013a200531d9a00122ab40004150532b4002bc60005043e2ab40004150532b4002b3a062c1906b6004e572ab4000415053201b5002b2ab400041505322b1504b6004f2ab400041505321906b5002b840501a7ffaa2b1db9005002001d9900082c2bb800512ab40009c6000b2ab400092bb80049b1
+fromData,197,2a2bb700382a2bb80039c0003ab500052a2bb8003b88b500152a2ab40015bd003cb500062ab400159e00722bb8003d4dbb003e59b7003f4e03360415042ab40015a200202ab400061504bb003c592b2ab4000515042c2db7004053840401a7ffdd2bb9004101003604150499002f2bb800423a0503360615062ab40015a2001d2ab4000615063219051506b60043c00044b5002b840601a7ffe02ab400451140007e99000e2a2bb80039c00046b5000b2a2ab400451180007e99000704a7000403b5001ab1
+toData,165,2a2bb700472ab400052bb800482ab40015852bb800492ab400159e007bbb004a592ab40015b7004b4d033e03360415042ab40015a200511d9a00122ab40006150432b4002bc60005043e2ab40006150432b4002b3a052c1905b6004c572ab4000615043201b5002b2ab400061504322bb6004d2ab400061504321905b5002b840401a7ffac2b1db9004e02001d9900082c2bb8004f2ab4000bc6000b2ab4000b2bb80048b1
 
 com/gemstone/gemfire/internal/cache/DistributedTombstoneOperation$TombstoneMessage,2
 fromData,125,2a2bb700162ab800172bb90018010032b500192bb9001a01003d2abb001b591cb7001cb500112bb9001d01003e03360415041ca2003e1d990019bb001e59b7001f3a0619062bb8002019063a05a700092bb800213a052ab4001119052bb900220100b80023b90024030057840401a7ffc22a2bb80025c00026b50003b1
@@ -990,8 +990,8 @@ fromData,17,2a2bb80005b500022a2bb80005b50003b1
 toData,17,2ab400022bb800042ab400032bb80004b1
 
 com/gemstone/gemfire/internal/cache/EntryEventImpl,2
-fromData,214,2a2bb80016c00017b500182bb800164d2bb800164e2abb0019592c2d01b7001ab5001b2a2bb9001c0100b8001db5001e2a2bb9001f0100b500092ab4001b2bb80016b600202a2bb80016c00021b5000a2bb9002201009900112a2bb80016c00023b50008a700322bb9002201009900212a2bb80024b500252a2ab40025b500062a2ab40025b80026b50005a7000b2a2bb80016b500052bb9002201009900192a2bb80024b500272a2ab40027b80026b50007a7000b2a2bb80016b500072a2bb80028b500292a2bb8002ab5000b2a2bb8002bb50014b1
-toData,312,2ab400182bb8015a2ab600882bb8015a2ab4001bb601872bb8015a2b2ab4001eb40188b9018902002b2ab4000911c03f7eb9018a02002ab600462bb8015a2ab4000a2bb8015a2ab40008c6000704a70004033d2b1cb9018b02001c99000e2ab400082bb8015aa700682ab6003c4e2dc1007e3604150499000e2dc0007eb900b4010036042b1504b9018b0200150499003b2ab40025c6000e2ab400252bb8018ca7002e2ab40006c6000e2ab400062bb8018ca7001c2dc0007e3a051905b900c201002bb8018da700082d2bb8015a2ab7003e4d2cc1007e3e1d99000d2cc0007eb900b401003e2b1db9018b02001d9900292ab40027c6000e2ab400272bb8018ca7001c2cc0007e3a041904b900c201002bb8018da700082c2bb8015a2ab40029c0018e2bb8018f2ab600542bb8015a2ab400142bb80190b1
+fromData,216,2a2bb80013c00014b500152bb800134d2bb800134e2abb0016592c2d01b70017b500182a2bb900190100b8001ab5001b2a2bb9001c0100b500082ab400182bb80013b6001d2a2bb80013c0001eb500092bb9001f0100990013b200209a003cbb0021591222b70023bf2bb9001f01009900212a2bb80024b500252a2ab40025b500062a2ab40025b80026b50005a7000b2a2bb80013b500052bb9001f01009900192a2bb80024b500272a2ab40027b80026b50007a7000b2a2bb80013b500072a2bb80028b500292a2bb8002ab5000a2a2bb8002bb50011b1
+toData,279,2ab400152bb801452ab600882bb801452ab40018b601722bb801452b2ab4001bb40173b9017402002b2ab4000811c03f7eb9017502002ab600462bb801452ab400092bb801452b03b9017602002ab6003c4d2cc1007e3e1d99000d2cc0007eb900a801003e2b1db9017602001d99003b2ab40025c6000e2ab400252bb80177a7002e2ab40006c6000e2ab400062bb80177a7001c2cc0007e3a041904b900b601002bb80178a700082c2bb801452ab7003e4d2cc1007e3e1d99000d2cc0007eb900a801003e2b1db9017602001d9900292ab40027c6000e2ab400272bb80177a7001c2cc0007e3a041904b900b601002bb80178a700082c2bb801452ab40029c001792bb8017a2ab600542bb801452ab400112bb8017bb1
 
 com/gemstone/gemfire/internal/cache/EntrySnapshot,2
 fromData,50,2a03b500052bb9004101003d1c9900112abb000759b70042b50004a7000e2abb000359b70043b500042ab400042bb60044b1
@@ -1235,16 +1235,16 @@ fromData,43,2a2bb7005c2a2bb9005d0100b5005e2a2ab4005e2bb6005f2a2bb80060b5000a2a2b
 toData,103,2a2bb700622ab600633d2b1cb9006402002ab4000c99000d2b2ab4000cb9006502002ab4006699000d2b2ab40066b9006702002ab60015029f000d2b2ab60015b9006502002ab60016c6000b2ab600162bb800682ab4000a2bb800692b2ab40006b9006a0200b1
 
 com/gemstone/gemfire/internal/cache/RemotePutAllMessage,2
-fromData,243,2a2bb700512a2bb80052c00053b500372a2bb80052b500392a2ab4005410087e99000704a7000403b500042ab4005410407e99000e2a2bb80052c00056b5004f2a2ab400541100807e99000704a7000403b500032a2ab400541101007e99000704a7000403b500022a2bb8005788b500062a2ab40006bd0058b500052ab400069e00722bb800594dbb005a59b7005b4e03360415042ab40006a200202ab400051504bb0058592b2ab4003715042c2db7005c53840401a7ffdd2bb9005d01003604150499002f2bb8005e3a0503360615062ab40006a2001d2ab4000515063219051506b6005fc0001eb5001f840601a7ffe0b1
-toData,189,2a2bb700602ab400372bb800612ab400392bb800612ab4004fc6000b2ab4004f2bb800612ab40006852bb800622ab400069e008bbb0063592ab40006b700644d033e2ab400050332b40065c10066360403360515052ab40006a200531d9a00122ab40005150532b4001fc60005043e2ab40005150532b4001f3a062c1906b60067572ab4000515053201b5001f2ab400051505322b1504b600682ab400051505321906b5001f840501a7ffaa2b1db9006902001d9900082c2bb8006ab1
+fromData,223,2a2bb700502a2bb80051c00052b500382a2bb80051b5003a2a2ab4005310087e99000704a7000403b500052ab4005310407e99000e2a2bb80051c00054b5004e2a2ab400531100807e99000704a7000403b500042a2bb8005588b500072a2ab40007bd0056b500062ab400079e00722bb800574dbb005859b700594e03360415042ab40007a200202ab400061504bb0056592b2ab4003815042c2db7005a53840401a7ffdd2bb9005b01003604150499002f2bb8005c3a0503360615062ab40007a2001d2ab4000615063219051506b6005dc0001fb50020840601a7ffe0b1
+toData,173,2a2bb7005e2ab400382bb8005f2ab4003a2bb8005f2ab4004ec6000b2ab4004e2bb8005f2ab40007852bb800602ab400079e007bbb0061592ab40007b700624d033e03360415042ab40007a200511d9a00122ab40006150432b40020c60005043e2ab40006150432b400203a052c1905b60063572ab4000615043201b500202ab400061504322bb600642ab400061504321905b50020840401a7ffac2b1db9006502001d9900082c2bb80066b1
 
 com/gemstone/gemfire/internal/cache/RemotePutAllMessage$PutAllReplyMessage,2
 fromData,17,2a2bb7001a2a2bb8001bc0001cb50001b1
 toData,14,2a2bb7001d2ab400012bb8001eb1
 
 com/gemstone/gemfire/internal/cache/RemotePutMessage,2
-fromData,242,2a2bb700742a2bb80075b600762bb9007701003d2a1cb200787e91b500052a2bb80075b500202a2bb900790100b500212a2bb9007a0100b8007bb500231cb2007c7e99000e2a2bb80075c0007db500251cb2007e7e99000e2a2bb80075c0003fb5007f2abb008059b70081b500272ab400272bb800822ab400831120007e99000b2a2bb80075b5000f2ab4000899001e2a2bb9007a010004a0000704a7000403b500062a2bb80084b700852ab4000504a0000e2a2bb80075b70086a7000b2a2bb80084b700872ab400831104007e9900102a04b5000a2a2bb80084b500881cb200897e99000e2a2bb80075c0008ab5002cb1
-toData,252,2a03b500092a2bb7008c2ab6008d2bb8008e2ab400053d2ab40025c600091cb2007c803d2ab4007fc600091cb2007e803d2ab4002cc600091cb20089803d2b1cb9008f02002ab600902bb8008e2b2ab40021b9009103002b2ab40023b40092b9008f02002ab40025c6000b2ab400252bb8008e2ab4007fc6000b2ab4007f2bb8008e2ab400272bb800932ab4000fc6000b2ab4000f2bb8008e2ab4000899002a2b2ab4000699000704a7000403b9008f02002ab40006b800943e1d2ab700952ab600962bb800972ab400052ab400712ab600982bb800972ab4000cb60099c6000e2ab4000cb600992bb8009a2ab4002cc6000b2ab4002c2bb8008eb1
+fromData,223,2a2bb700732a2bb80074b600752bb9007601003d2a1cb200777e91b500072a2bb80074b500202a2bb900780100b500212a2bb900790100b8007ab500231cb2007b7e99000e2a2bb80074c0007cb500251cb2007d7e99000e2a2bb80074c0003fb5007e2abb007f59b70080b500272ab400272bb800812ab400821120007e99000b2a2bb80074b500112ab4000a99001e2a2bb90079010004a0000704a7000403b500082a2bb80083b700842a2bb80083b700852ab400821104007e9900102a04b5000c2a2bb80083b500861cb200877e99000e2a2bb80074c00088b5002cb1
+toData,252,2a03b5000b2a2bb7008a2ab6008b2bb8008c2ab400073d2ab40025c600091cb2007b803d2ab4007ec600091cb2007d803d2ab4002cc600091cb20087803d2b1cb9008d02002ab6008e2bb8008c2b2ab40021b9008f03002b2ab40023b40090b9008d02002ab40025c6000b2ab400252bb8008c2ab4007ec6000b2ab4007e2bb8008c2ab400272bb800912ab40011c6000b2ab400112bb8008c2ab4000a99002a2b2ab4000899000704a7000403b9008d02002ab40008b800923e1d2ab700932ab600942bb800952ab400072ab400702ab600962bb800952ab4000eb60097c6000e2ab4000eb600972bb800982ab4002cc6000b2ab4002c2bb8008cb1
 
 com/gemstone/gemfire/internal/cache/RemotePutMessage$PutReplyMessage,2
 fromData,81,2a2bb700262bb9002701001100ff7e913d2a1c047e99000704a7000403b500032a2bb900270100b80028b500022a2bb80029b500061c057e9900181c077e99000704a70004033e2a1d2bb8002ab50007b1
@@ -1259,8 +1259,8 @@ fromData,6,2a2bb70014b1
 toData,6,2a2bb70015b1
 
 com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage,2
-fromData,203,2a2bb7004d2a2bb8004ec0004fb500352a2bb8004eb500372a2ab4005010087e99000704a7000403b500022ab4005010407e99000e2a2bb8004ec00052b5004b2a2bb8005388b500042a2ab40004bd0054b500032ab400049e00722bb800554dbb005659b700574e03360415042ab40004a200202ab400031504bb0054592b2ab4003515042c2db7005853840401a7ffdd2bb9005901003604150499002f2bb8005a3a0503360615062ab40004a2001d2ab4000315063219051506b6005bc0001cb5001d840601a7ffe0b1
-toData,189,2a2bb7005c2ab400352bb8005d2ab400372bb8005d2ab4004bc6000b2ab4004b2bb8005d2ab40004852bb8005e2ab400049e008bbb005f592ab40004b700604d033e2ab400030332b40061c10062360403360515052ab40004a200531d9a00122ab40003150532b4001dc60005043e2ab40003150532b4001d3a062c1906b60063572ab4000315053201b5001d2ab400031505322b1504b600642ab400031505321906b5001d840501a7ffaa2b1db9006502001d9900082c2bb80066b1
+fromData,203,2a2bb7004e2a2bb8004fc00050b500362a2bb8004fb500382a2ab4005110087e99000704a7000403b500032ab4005110407e99000e2a2bb8004fc00052b5004c2a2bb8005388b500052a2ab40005bd0054b500042ab400059e00722bb800554dbb005659b700574e03360415042ab40005a200202ab400041504bb0054592b2ab4003615042c2db7005853840401a7ffdd2bb9005901003604150499002f2bb8005a3a0503360615062ab40005a2001d2ab4000415063219051506b6005bc0001db5001e840601a7ffe0b1
+toData,173,2a2bb7005c2ab400362bb8005d2ab400382bb8005d2ab4004cc6000b2ab4004c2bb8005d2ab40005852bb8005e2ab400059e007bbb005f592ab40005b700604d033e03360415042ab40005a200511d9a00122ab40004150432b4001ec60005043e2ab40004150432b4001e3a052c1905b60061572ab4000415043201b5001e2ab400041504322bb600622ab400041504321905b5001e840401a7ffac2b1db9006302001d9900082c2bb80064b1
 
 com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage$RemoveAllReplyMessage,2
 fromData,17,2a2bb7001a2a2bb8001bc0001cb50001b1
@@ -1729,16 +1729,16 @@ fromData,16,2a2bb700092a2bb9000a0100b50007b1
 toData,16,2a2bb7000b2b2ab40007b9000c0200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage,2
-fromData,183,2a2bb7003d2a2bb8003e88b80007b500082ab4003f1110007e99000e2a2bb80041c00042b5003b2a2bb80041b5000e2a2bb8004388b500032a2ab40003bd0009b5000a2ab400039e006f2bb800444dbb004559b700464e03360415042ab40003a2001d2ab4000a1504bb0009592b0115042c2db7004753840401a7ffe02bb9004801003604150499002f2bb800493a0503360615062ab40003a2001d2ab4000a15063219051506b6004ac0004bb5004c840601a7ffe0b1
-toData,210,2a2bb7004d2ab40008c7000d14004e2bb80050a7000f2ab40008b60051852bb800502ab4003bc6000b2ab4003b2bb800522ab4000e2bb800522ab40003852bb800532ab400039e008bbb0054592ab40003b700554d033e2ab4000a0332b60020c10056360403360515052ab40003a200531d9a00122ab4000a150532b4004cc60005043e2ab4000a150532b4004c3a062c1906b60057572ab4000a15053201b5004c2ab4000a1505322b1504b600582ab4000a1505321906b5004c840501a7ffaa2b1db9005902001d9900082c2bb8005ab1
+fromData,183,2a2bb7003e2a2bb8003f88b80009b5000a2ab400401110007e99000e2a2bb80041c00042b5003c2a2bb80041b500102a2bb8004388b500052a2ab40005bd000bb5000c2ab400059e006f2bb800444dbb004559b700464e03360415042ab40005a2001d2ab4000c1504bb000b592b0115042c2db7004753840401a7ffe02bb9004801003604150499002f2bb800493a0503360615062ab40005a2001d2ab4000c15063219051506b6004ac0004bb5004c840601a7ffe0b1
+toData,194,2a2bb7004d2ab4000ac7000d14004e2bb80050a7000f2ab4000ab60051852bb800502ab4003cc6000b2ab4003c2bb800522ab400102bb800522ab40005852bb800532ab400059e007bbb0054592ab40005b700554d033e03360415042ab40005a200511d9a00122ab4000c150432b4004cc60005043e2ab4000c150432b4004c3a052c1905b60056572ab4000c15043201b5004c2ab4000c1504322bb600572ab4000c1504321905b5004c840401a7ffac2b1db9005802001d9900082c2bb80059b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage$PutAllReplyMessage,2
 fromData,27,2a2bb7001b2a2bb9001c0100b500032a2bb8001dc0001eb50002b1
 toData,24,2a2bb7001f2b2ab40003b9002002002ab400022bb80021b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutMessage,2
-fromData,260,2a2bb7005c2bb9005d01003d2a2bb8005eb6005f2a2bb8005eb500152a2bb900600100b500162a2bb900610100b80062b500171cb200637e99000b2a2bb80064b500181cb200657e99000e2a2bb8005ec00066b5001a2abb006759b70068b5001b2ab4001b2bb800692ab4006a1120007e99000b2a2bb8005eb500202ab4006b9900162abb006c59b7006db500262ab400262bb800692a1cb2006e7e91b500052ab4000799000e2a2bb8006fb5000ba7002e2ab4000504a0000e2a2bb8005eb70070a7000b2a2bb8006fb700711cb200727e99000b2a2bb8006fb5000b2ab4006a1140007e99000e2a2bb8005ec00073b500232ab4006a1180007e9900082a04b50074b1
-toData,358,014d2ab4001fb60075b9007601003e2ab4000ab60077c600161d9900122ab4000999000b2a04b50007a700082a03b50007a7000d4ebb0079592db7007abf2a2bb7007b2ab400053e2ab40018c600091db20063803e2ab400059900282ab4000fc7000a2ab6007cc6001a2ab4007d9900132ab4000ab60077c600091db20072803e2ab4001ac600091db20065803e2b1db9007e02002ab6007f2bb800802ab600812bb800802b2ab40016b9008203002b2ab40017b40083b9007e02002ab40018c6000b2ab400182bb800802ab4001ac6000b2ab4001a2bb800802ab4001b2bb800842ab40020c6000b2ab400202bb800802ab4006b99000b2ab400262bb800842ab4000799002f2ab40085b800864da7000f3a04bb0088591289b7008abf2ab4000ab600772bb8008b2cb6008cb6008da700262ab400052ab4000f2ab6007c2bb8008e1db200727e99000e2ab4000ab600772bb8008b2ab40023c6000b2ab400232bb80080b1
+fromData,225,2a2bb7005b2bb9005c01003d2a2bb8005db6005e2a2bb8005db500172a2bb9005f0100b500182a2bb900600100b80061b500191cb200627e99000b2a2bb80063b5001a1cb200647e99000e2a2bb8005dc00065b5001c2abb006659b70067b5001d2ab4001d2bb800682ab400691120007e99000b2a2bb8005db500222ab4006a9900162abb006b59b7006cb500282ab400282bb800682a1cb2006d7e91b500072ab4000999000e2a2bb8006eb5000da7001b2a2bb8006eb7006f1cb200707e99000b2a2bb8006eb5000d2ab400691140007e99000e2a2bb8005dc00071b50025b1
+toData,358,014d2ab40021b60072b9007301003e2ab4000cb60074c600161d9900122ab4000b99000b2a04b50009a700082a03b50009a7000d4ebb0076592db70077bf2a2bb700782ab400073e2ab4001ac600091db20062803e2ab400079900282ab40011c7000a2ab60079c6001a2ab4007a9900132ab4000cb60074c600091db20070803e2ab4001cc600091db20064803e2b1db9007b02002ab6007c2bb8007d2ab6007e2bb8007d2b2ab40018b9007f03002b2ab40019b40080b9007b02002ab4001ac6000b2ab4001a2bb8007d2ab4001cc6000b2ab4001c2bb8007d2ab4001d2bb800812ab40022c6000b2ab400222bb8007d2ab4006a99000b2ab400282bb800812ab4000999002f2ab40082b800834da7000f3a04bb0085591286b70087bf2ab4000cb600742bb800882cb60089b6008aa700262ab400072ab400112ab600792bb8008b1db200707e99000e2ab4000cb600742bb800882ab40025c6000b2ab400252bb8007db1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutMessage$PutReplyMessage,2
 fromData,48,2a2bb700252a2bb900260100b500032a2bb900270100b80028b500022a2bb80029b500062a2bb80029c0002ab50007b1
@@ -1773,8 +1773,8 @@ fromData,16,2a2bb7001e2a2bb9001f0100b50003b1
 toData,16,2a2bb7001b2b2ab40003b9001c0200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage,2
-fromData,190,2a2bb7003c2a2bb8003d88b80007b500082ab4003e1110007e99000e2a2bb80040c00041b5003a2bb800424d2a2bb80040b5000e2a2bb8004388b500032a2ab40003bd0009b5000a2ab400039e00712bb800444ebb004559b700463a0403360515052ab40003a2001e2ab4000a1505bb0009592b0115052d1904b7004753840501a7ffdf2bb9004801003605150599002f2bb800493a0603360715072ab40003a2001d2ab4000a15073219061507b6004ac0004bb5004c840701a7ffe0b1
-toData,210,2a2bb7004d2ab40008c7000d14004e2bb80050a7000f2ab40008b60051852bb800502ab4003ac6000b2ab4003a2bb800522ab4000e2bb800522ab40003852bb800532ab400039e008bbb0054592ab40003b700554d033e2ab4000a0332b6001fc10056360403360515052ab40003a200531d9a00122ab4000a150532b4004cc60005043e2ab4000a150532b4004c3a062c1906b60057572ab4000a15053201b5004c2ab4000a1505322b1504b600582ab4000a1505321906b5004c840501a7ffaa2b1db9005902001d9900082c2bb8005ab1
+fromData,190,2a2bb7003e2a2bb8003f88b80009b5000a2ab400401110007e99000e2a2bb80041c00042b5003c2bb800434d2a2bb80041b500102a2bb8004488b500052a2ab40005bd000bb5000c2ab400059e00712bb800454ebb004659b700473a0403360515052ab40005a2001e2ab4000c1505bb000b592b0115052d1904b7004853840501a7ffdf2bb9004901003605150599002f2bb8004a3a0603360715072ab40005a2001d2ab4000c15073219061507b6004bc0004cb5004d840701a7ffe0b1
+toData,194,2a2bb7004e2ab4000ac7000d14004f2bb80051a7000f2ab4000ab60052852bb800512ab4003cc6000b2ab4003c2bb800532ab400102bb800532ab40005852bb800542ab400059e007bbb0055592ab40005b700564d033e03360415042ab40005a200511d9a00122ab4000c150432b4004dc60005043e2ab4000c150432b4004d3a052c1905b60057572ab4000c15043201b5004d2ab4000c1504322bb600582ab4000c1504321905b5004d840401a7ffac2b1db9005902001d9900082c2bb8005ab1
 
 com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage$RemoveAllReplyMessage,2
 fromData,27,2a2bb7001b2a2bb9001c0100b500032a2bb8001dc0001eb50002b1


[16/17] incubator-geode git commit: Fixup

Posted by kl...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/470cd73e/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 37ff587..351e6e0 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
@@ -167,6 +167,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     SerializableRunnable createRegion = new CacheSerializableRunnable(
     "createRegion") {
 
+      @Override
       public void run2() throws CacheException {
         Cache cache = getCache();
         RegionAttributes regionAttribs = getRegionAttributes();
@@ -197,6 +198,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     //String exceptionStr = "";
     VM vm0 = Host.getHost(0).getVM(0);
     vm0.invoke(new CacheSerializableRunnable("doConcurrentMapOperations") {
+      @Override
       public void run2() throws CacheException {
         Cache cache = getCache();
         final Region pr = cache.getRegion(rName);
@@ -314,6 +316,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
      */
     vm0.invoke(new CacheSerializableRunnable("destroyRegionOp") {
                
+       @Override
        public void run2() {
          Cache cache = getCache();
          Region pr = cache.getRegion(rName);
@@ -337,6 +340,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -355,6 +359,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable put =
       new CacheSerializableRunnable("Put key/value") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -367,6 +372,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(put);
 
     vm0.invoke(new CacheSerializableRunnable("Update") {
+        @Override
         public void run2() throws CacheException {
           Region region = getRootRegion().getSubregion(name);
           region.put(key, newValue);
@@ -375,6 +381,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Validate update") {
+        @Override
         public void run2() throws CacheException {
           Region region = getRootRegion().getSubregion(name);
           Region.Entry entry = region.getEntry(key);
@@ -411,6 +418,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create region entry") {
+          @Override
           public void run2() throws CacheException {
             Region region = createRegion(name);
             region.create(key, null);
@@ -421,11 +429,13 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm1.invoke(new CacheSerializableRunnable("Set listener") {
+        @Override
         public void run2() throws CacheException {
           Region region = getRootRegion().getSubregion(name);
           region.setUserAttribute(new LinkedBlockingQueue());
           region.getAttributesMutator().addCacheListener(new
             CacheListenerAdapter() {
+              @Override
               public void afterUpdate(EntryEvent e) {
                 Region region2 = e.getRegion();
                 LinkedBlockingQueue queue =
@@ -446,6 +456,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
     AsyncInvocation ai1 =
       vm1.invokeAsync(new CacheSerializableRunnable("Verify") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -467,6 +478,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     AsyncInvocation ai0 =
       vm0.invokeAsync(new CacheSerializableRunnable("Populate") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -505,6 +517,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm1 = host.getVM(1);
 
     vm0.invoke(new CacheSerializableRunnable("Populate region") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           region.put(key, value);
@@ -512,6 +525,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     SerializableRunnable get = new CacheSerializableRunnable("Distributed get") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           assertEquals(value, region.get(key));
@@ -535,6 +549,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -553,6 +568,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     final Object value = "VALUE";
 
     vm0.invoke(new CacheSerializableRunnable("Put key/value") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -563,6 +579,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     Thread.sleep(250);
 
     vm1.invoke(new CacheSerializableRunnable("Verify no update") {
+        @Override
         public void run2() throws CacheException {
           Region region = getRootRegion().getSubregion(name);
           Region.Entry entry = region.getEntry(key);
@@ -595,6 +612,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -604,6 +622,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Create and populate") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -611,6 +630,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new CacheSerializableRunnable("Define entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -619,6 +639,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm0.invoke(new CacheSerializableRunnable("Update entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -626,6 +647,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     Invoke.invokeRepeatingIfNecessary(vm1, new CacheSerializableRunnable("Get entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -647,6 +669,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
 //DebuggerSupport.waitForJavaDebugger(getLogWriter(), " about to create region");
             Region region = createRegion(name);
@@ -671,6 +694,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable put =
       new CacheSerializableRunnable("Put key/value") {
+          @Override
           public void run2() throws CacheException {
 //DebuggerSupport.waitForJavaDebugger(getLogWriter(), " about to put");
             Region region =
@@ -688,6 +712,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable verifyPut =
       new CacheSerializableRunnable("Verify Put") {
+          @Override
           public void run2() throws CacheException {
             Region root = getRootRegion();
             assertTrue(!root.isDestroyed());
@@ -703,6 +728,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invoke(verifyPut);
 
     vm0.invoke(new CacheSerializableRunnable("Destroy Entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -713,6 +739,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     CacheSerializableRunnable verifyDestroy =
       new CacheSerializableRunnable("Verify entry destruction") {
+          @Override
           public void run2() throws CacheException {
             Region root = getRootRegion();
             assertTrue(!root.isDestroyed());
@@ -738,6 +765,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -749,6 +777,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm0 = host.getVM(0);
 
     vm0.invoke(new CacheSerializableRunnable("Destroy Region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -758,11 +787,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     Invoke.invokeInEveryVM(new CacheSerializableRunnable("Verify region destruction") {
+      @Override
       public void run2() throws CacheException {
         WaitCriterion ev = new WaitCriterion() {
+          @Override
           public boolean done() {
             return getRootRegion().getSubregion(name) == null;
           }
+          @Override
           public String description() {
             return "Waiting for region " + name + " to be destroyed";
           }
@@ -792,6 +824,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -811,6 +844,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable put =
       new CacheSerializableRunnable("Put key/value") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -824,6 +858,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     Thread.sleep(250);
 
     vm0.invoke(new CacheSerializableRunnable("Local Destroy Entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -835,6 +870,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable verify =
       new CacheSerializableRunnable("Verify entry existence") {
+          @Override
           public void run2() throws CacheException {
             Region region = getRootRegion().getSubregion(name);
             assertNotNull(region.getEntry(key));
@@ -855,6 +891,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -870,6 +907,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     Thread.sleep(250);
 
     vm0.invoke(new CacheSerializableRunnable("Local Destroy Region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -881,6 +919,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable verify =
       new CacheSerializableRunnable("Verify region existence") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -902,6 +941,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -923,6 +963,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable put =
       new CacheSerializableRunnable("Put key/value") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -936,6 +977,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invoke(put);
 
     vm0.invoke(new CacheSerializableRunnable("Invalidate Entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -946,6 +988,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     CacheSerializableRunnable verify =
       new CacheSerializableRunnable("Verify entry invalidation") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -980,6 +1023,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -994,6 +1038,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable put =
         new CacheSerializableRunnable("put entry") {
+            @Override
             public void run2() throws CacheException {
               Region region =
                   getRootRegion().getSubregion(name);
@@ -1009,6 +1054,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
       SerializableRunnable invalidate =
       new CacheSerializableRunnable("Invalidate Entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1024,6 +1070,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable verify =
       new CacheSerializableRunnable("Verify entry invalidation") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -1053,6 +1100,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             Region region;
             region = createRegion(name);
@@ -1071,6 +1119,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable put =
       new CacheSerializableRunnable("Put key/value") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -1093,6 +1142,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm0 = host.getVM(0);
 
     vm0.invoke(new CacheSerializableRunnable("Invalidate Region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1102,6 +1152,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     CacheSerializableRunnable verify =
       new CacheSerializableRunnable("Verify region invalidation") {
+          @Override
           public void run2() throws CacheException {
             Region region =
               getRootRegion().getSubregion(name);
@@ -1149,6 +1200,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable populate =
       new CacheSerializableRunnable("Create Region and Put") {
+          @Override
           public void run2() throws CacheException {
             Region region = createRegion(name);
             region.put(key, oldValue);
@@ -1163,10 +1215,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(populate);
 
     vm1.invoke(new CacheSerializableRunnable("Set listener") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           listener = new TestCacheListener() {
+              @Override
               public void afterUpdate2(EntryEvent event) {
                 assertEquals(Operation.UPDATE, event.getOperation());
                 assertEquals(region, event.getRegion());
@@ -1210,6 +1264,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // If needed then do a flushIfNecessary(region) after adding the cache listener
 
     vm0.invoke(new CacheSerializableRunnable("Update") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1218,6 +1273,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify Update") {
+        @Override
         public void run2() throws CacheException {
           listener.waitForInvocation(3000, 10);
 
@@ -1225,6 +1281,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           final Region region =
             getRootRegion().getSubregion(name);
           listener = new TestCacheListener() {
+              @Override
               public void afterInvalidate2(EntryEvent event) {
                 assertEquals(Operation.INVALIDATE, event.getOperation());
                 assertEquals(region, event.getRegion());
@@ -1253,6 +1310,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Invalidate") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1261,6 +1319,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify Invalidate") {
+        @Override
         public void run2() throws CacheException {
           listener.waitForInvocation(3000, 10);
 
@@ -1268,6 +1327,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           final Region region =
             getRootRegion().getSubregion(name);
           listener = new TestCacheListener() {
+              @Override
               public void afterDestroy2(EntryEvent event) {
                 assertTrue(event.getOperation().isDestroy());
                 assertEquals(region, event.getRegion());
@@ -1291,6 +1351,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Destroy") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1299,6 +1360,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify Destroy") {
+        @Override
         public void run2() throws CacheException {
           listener.waitForInvocation(3000, 10);
 
@@ -1306,6 +1368,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           final Region region =
             getRootRegion().getSubregion(name);
           listener = new TestCacheListener() {
+              @Override
               public void afterRegionInvalidate2(RegionEvent event) {
                 assertEquals(Operation.REGION_INVALIDATE, event.getOperation());
                 assertEquals(region, event.getRegion());
@@ -1320,6 +1383,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Invalidate Region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1328,6 +1392,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify Invalidate Region") {
+        @Override
         public void run2() throws CacheException {
           listener.waitForInvocation(3000, 10);
 
@@ -1335,6 +1400,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           final Region region =
             getRootRegion().getSubregion(name);
           listener = new TestCacheListener() {
+              @Override
               public void afterRegionDestroy2(RegionEvent event) {
                 assertEquals(Operation.REGION_DESTROY, event.getOperation());
                 assertEquals(region, event.getRegion());
@@ -1349,6 +1415,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Destroy Region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1357,6 +1424,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify Destroy Region") {
+        @Override
         public void run2() throws CacheException {
           listener.waitForInvocation(3000, 10);
         }
@@ -1376,6 +1444,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -1386,6 +1455,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     final VM vm1 = host.getVM(1);
 
     vm0.invoke(new CacheSerializableRunnable("Create Root") {
+      @Override
       public void run2() throws CacheException {
         createRootRegion();
       }
@@ -1394,10 +1464,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm1.invoke(new CacheSerializableRunnable("Set listener") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           listener = new TestCacheListener() {
+              @Override
               public void afterRegionInvalidate2(RegionEvent event) {
                 assertEquals(Operation.REGION_INVALIDATE, event.getOperation());
                 assertEquals(region, event.getRegion());
@@ -1412,12 +1484,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Invalidate Root Region") {
+        @Override
         public void run2() throws CacheException {
           getRootRegion().invalidateRegion(getSystem().getDistributedMember());
         }
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify Invalidate Region") {
+        @Override
         public void run2() throws CacheException {
           listener.waitForInvocation(3000, 10);
 
@@ -1425,6 +1499,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           final Region region =
             getRootRegion().getSubregion(name);
           listener = new TestCacheListener() {
+              @Override
               public void afterRegionDestroy2(RegionEvent event) {
                 assertEquals(Operation.REGION_DESTROY, event.getOperation());
                 assertEquals(region, event.getRegion());
@@ -1439,12 +1514,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Destroy Root Region") {
+        @Override
         public void run2() throws CacheException {
           getRootRegion().destroyRegion(getSystem().getDistributedMember());
         }
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify Destroy Region") {
+        @Override
         public void run2() throws CacheException {
           listener.waitForInvocation(3000, 10);
         }
@@ -1476,6 +1553,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -1491,10 +1569,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     vm1.invoke(new CacheSerializableRunnable("Set CacheLoader") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           loader = new TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
                 assertEquals(region, helper.getRegion());
@@ -1509,6 +1589,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Remote load") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1517,6 +1598,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new SerializableRunnable("Verify loader") {
+        @Override
         public void run() {
           assertTrue(loader.wasInvoked());
         }
@@ -1540,6 +1622,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
             // Can't test non-Serializable callback argument here
@@ -1558,10 +1641,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm1.invoke(new CacheSerializableRunnable("Set CacheLoader") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           loader = new TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
                 assertEquals(region, helper.getRegion());
@@ -1577,6 +1662,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Remote load") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1598,6 +1684,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new SerializableRunnable("Verify loader") {
+        @Override
         public void run() {
           assertTrue(loader.wasInvoked());
         }
@@ -1620,6 +1707,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -1634,10 +1722,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm1.invoke(new CacheSerializableRunnable("Set CacheLoader") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           loader = new TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
                 assertEquals(region, helper.getRegion());
@@ -1654,6 +1744,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Remote load") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1668,6 +1759,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new SerializableRunnable("Verify loader") {
+        @Override
         public void run() {
           assertTrue(loader.wasInvoked());
         }
@@ -1693,6 +1785,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // use vm on other gemfire system
     VM vm1 = host.getVM(1);
     vm1.invoke(new CacheSerializableRunnable("set remote value") {
+      @Override
       public void run2() throws CacheException {
 //        final TestCacheLoader remoteloader = new TestCacheLoader() {
 //            public Object load2(LoaderHelper helper)
@@ -1714,6 +1807,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     final TestCacheLoader loader1 = new TestCacheLoader() {
+        @Override
         public Object load2(LoaderHelper helper)
           throws CacheLoaderException {
 
@@ -1749,6 +1843,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // make sure value is still there in vm1
     vm1.invoke(new CacheSerializableRunnable("verify remote value") {
+      @Override
       public void run2() throws CacheException {
         Region rgn = getRootRegion().getSubregion(name);
         assertEquals(value, rgn.getEntry(key).getValue());
@@ -1787,8 +1882,10 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // use vm on other gemfire system
     VM vm1 = host.getVM(1);
     vm1.invoke(new CacheSerializableRunnable("set up remote loader") {
+      @Override
       public void run2() throws CacheException {
         final TestCacheLoader remoteloader = new TestCacheLoader() {
+            @Override
             public Object load2(LoaderHelper helper)
               throws CacheLoaderException {
 
@@ -1806,6 +1903,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     final TestCacheLoader loader1 = new TestCacheLoader() {
+        @Override
         public Object load2(LoaderHelper helper)
           throws CacheLoaderException {
 
@@ -1861,6 +1959,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -1873,6 +1972,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Remote load") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1896,9 +1996,11 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             Region region = createRegion(name);
             loader = new TestCacheLoader() {
+                @Override
                 public Object load2(LoaderHelper helper)
                   throws CacheLoaderException {
 
@@ -1918,6 +2020,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm1.invoke(new CacheSerializableRunnable("Create invalid entry") {
+      @Override
       public void run2() throws CacheException {
         Region region =
           getRootRegion().getSubregion(name);
@@ -1926,6 +2029,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Remote get") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -1936,6 +2040,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new SerializableRunnable("Verify loader") {
+        @Override
         public void run() {
           assertFalse(loader.wasInvoked());
         }
@@ -1963,6 +2068,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             Region region = createRegion(name);
 
@@ -1993,10 +2099,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     ////////  Create
 
     vm1.invoke(new CacheSerializableRunnable("Set Writer") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           writer = new TestCacheWriter() {
+              @Override
               public void beforeCreate2(EntryEvent event)
                 throws CacheWriterException {
 
@@ -2026,6 +2134,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Create with Exception") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2046,12 +2155,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
       });
 
     vm0.invoke(new CacheSerializableRunnable("Create with Argument") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2069,6 +2180,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
@@ -2077,10 +2189,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     ////////  Update
 
     vm1.invoke(new CacheSerializableRunnable("Set Writer") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           writer = new TestCacheWriter() {
+              @Override
               public void beforeUpdate2(EntryEvent event)
                 throws CacheWriterException {
 
@@ -2112,6 +2226,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Update with Exception") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2136,12 +2251,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
       });
 
     vm0.invoke(new CacheSerializableRunnable("Update with Argument") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2155,6 +2272,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
@@ -2163,10 +2281,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     ////////  Destroy
 
     vm1.invoke(new CacheSerializableRunnable("Set Writer") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           writer = new TestCacheWriter() {
+              @Override
               public void beforeDestroy2(EntryEvent event)
                 throws CacheWriterException {
 
@@ -2197,6 +2317,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Destroy with Exception") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2216,12 +2337,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
       });
 
     vm0.invoke(new CacheSerializableRunnable("Destroy with Argument") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2235,6 +2358,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
        }
       });
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
@@ -2243,10 +2367,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     ////////  Region Destroy
 
     vm1.invoke(new CacheSerializableRunnable("Set Writer") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
           writer = new TestCacheWriter() {
+              @Override
               public void beforeRegionDestroy2(RegionEvent event)
                 throws CacheWriterException {
 
@@ -2270,6 +2396,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Destroy with Exception") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2291,12 +2418,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
       });
 
     vm0.invoke(new CacheSerializableRunnable("Destroy with Argument") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2311,9 +2440,11 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
             GemFireCacheImpl gfc = (GemFireCacheImpl) getCache();
             final MemoryAllocatorImpl ma = (MemoryAllocatorImpl) gfc.getOffHeapStore();
             WaitCriterion waitForStatChange = new WaitCriterion() {
+              @Override
               public boolean done() {
                 return ma.getStats().getObjects() == 0;
               }
+              @Override
               public String description() {
                 return "never saw off-heap object count go to zero. Last value was " + ma.getStats().getObjects();
               }
@@ -2323,6 +2454,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new SerializableRunnable("Verify callback") {
+        @Override
         public void run() {
           assertTrue(writer.wasInvoked());
         }
@@ -2347,18 +2479,23 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm1 = host.getVM(1);
 
     vm0.invoke(new CacheSerializableRunnable("Create \"Local\" Region") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           writer = new TestCacheWriter() {
+              @Override
               public void beforeUpdate2(EntryEvent event)
                 throws CacheWriterException { }
 
+              @Override
               public void beforeCreate2(EntryEvent event)
                 throws CacheWriterException { }
 
+              @Override
               public void beforeDestroy2(EntryEvent event)
                 throws CacheWriterException { }
 
+              @Override
               public void beforeRegionDestroy2(RegionEvent event)
                 throws CacheWriterException { }
           };
@@ -2367,6 +2504,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
    SerializableRunnable create = new CacheSerializableRunnable("Create \"Local\" Region") {
+      @Override
       public void run2() throws CacheException {
         Region region = createRegion(name);
         writer = new TestCacheWriter() { };
@@ -2378,12 +2516,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable verify = new
       SerializableRunnable("Verify no callback") {
+        @Override
         public void run() {
           assertFalse(writer.wasInvoked());
         }
       };
 
     vm0.invoke(new CacheSerializableRunnable("Create entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2394,6 +2534,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(verify);
 
     vm0.invoke(new CacheSerializableRunnable("Update entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2404,6 +2545,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(verify);
 
     vm0.invoke(new CacheSerializableRunnable("Destroy entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2414,6 +2556,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(verify);
 
     vm0.invoke(new CacheSerializableRunnable("Destroy region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2441,6 +2584,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create =
       new CacheSerializableRunnable("Create Region") {
+          @Override
           public void run2() throws CacheException {
             createRegion(name);
           }
@@ -2455,10 +2599,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     CacheSerializableRunnable setLoader = new CacheSerializableRunnable("Set CacheLoader") {
+      @Override
       public void run2() throws CacheException {
         final Region region =
           getRootRegion().getSubregion(name);
         loader = new TestCacheLoader() {
+            @Override
             public Object load2(LoaderHelper helper)
               throws CacheLoaderException {
 
@@ -2477,10 +2623,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // if  this is a partitioned region, we need the loader in both vms
     vm1.invoke(new CacheSerializableRunnable("Conditionally create second loader") {
+      @Override
       public void run2() throws CacheException {
         final Region region = getRootRegion().getSubregion(name);
         if (region.getAttributes().getPartitionAttributes() != null) {
           loader = new TestCacheLoader() {
+            @Override
             public Object load2(LoaderHelper helper)
               throws CacheLoaderException {
 
@@ -2496,9 +2644,11 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     vm1.invoke(new CacheSerializableRunnable("Set CacheWriter") {
+        @Override
         public void run2() throws CacheException {
           final Region region = getRootRegion().getSubregion(name);
           writer = new TestCacheWriter() {
+              @Override
               public void beforeCreate2(EntryEvent event)
                 throws CacheWriterException {
 
@@ -2512,6 +2662,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Create entry") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2523,6 +2674,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Validate callback") {
+        @Override
         public void run2() throws CacheException {
 //          if (getRootRegion().getSubregion(name).getAttributes()
 //              .getPartitionAttributes() == null) { // bug 36500 - remove check when fixed
@@ -2552,6 +2704,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm1 = host.getVM(1);
 
     SerializableRunnable create = new CacheSerializableRunnable("Get value") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           assertEquals(value, region.get(key));
@@ -2560,10 +2713,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     vm0.invoke(new CacheSerializableRunnable("Create Region") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           region.getAttributesMutator().setCacheLoader(new
             TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
 
@@ -2596,9 +2751,11 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm1 = host.getVM(1);
 
     SerializableRunnable create = new CacheSerializableRunnable("Create \"remote\" region") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           loader = new TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
                 if (helper.getRegion().getAttributes().getPartitionAttributes() == null) {
@@ -2616,10 +2773,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     vm0.invoke(new CacheSerializableRunnable("Create \"local\" region") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           region.getAttributesMutator().setCacheLoader(new
             TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
                 return value;
@@ -2632,6 +2791,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     vm0.invoke(new CacheSerializableRunnable("Get") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2639,6 +2799,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm1.invoke(new SerializableRunnable("Verify loader not invoked") {
+        @Override
         public void run() {
           assertFalse(loader.wasInvoked());
         }
@@ -2654,6 +2815,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     final String rgnName = getUniqueName();
 
     SerializableRunnable create = new SerializableRunnable("testDistributedPut: Create Region") {
+      @Override
       public void run() {
         try {
           createRegion(rgnName);
@@ -2666,6 +2828,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     };
 
     SerializableRunnable newKey = new SerializableRunnable("testDistributedPut: Create Key") {
+      @Override
       public void run() {
         try {
           if (!getRegionAttributes().getDataPolicy().withReplication() &&
@@ -2708,6 +2871,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       getSystem().getLogWriter().info("testDistributedPut: Put Value");
 
       Invoke.invokeInEveryVMRepeatingIfNecessary(new CacheSerializableRunnable("testDistributedPut: Verify Received Value") {
+        @Override
         public void run2() {
           Region rgn1 = getRootRegion().getSubregion(rgnName);
           assertNotNull("Could not find entry for 'key'", rgn1.getEntry("key"));
@@ -2862,6 +3026,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create = new
       CacheSerializableRunnable("Create Mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           RegionAttributes ra = getRegionAttributes();
           AttributesFactory factory =
@@ -2879,6 +3044,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Put data") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2890,6 +3056,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     Invoke.invokeRepeatingIfNecessary(vm2, new CacheSerializableRunnable("Wait for update") {
+      @Override
       public void run2() throws CacheException {
         Region region = getRootRegion().getSubregion(name);
         assertNotNull(region.getEntry(key1));
@@ -2901,6 +3068,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Destroy the local entries so we know that they are not found by
     // a netSearch
     vm0.invoke(new CacheSerializableRunnable("Remove local entries") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2910,6 +3078,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     Invoke.invokeRepeatingIfNecessary(vm2, new CacheSerializableRunnable("Verify keys") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2954,6 +3123,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create = new
       CacheSerializableRunnable("Create Mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           RegionAttributes ra = getRegionAttributes();
           AttributesFactory factory =
@@ -2971,6 +3141,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm0.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Put data") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2985,6 +3156,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Destroy the local entries so we know that they are not found by
     // a netSearch
     vm0.invoke(new CacheSerializableRunnable("Remove local entries") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -2993,6 +3165,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm2.invoke(new CacheSerializableRunnable("Verify keys/values") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3040,6 +3213,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create = new
       CacheSerializableRunnable("Create Mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           RegionAttributes ra = getRegionAttributes();
           AttributesFactory factory =
@@ -3057,6 +3231,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm0.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Put data") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3071,6 +3246,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Destroy the local entries so we know that they are not found by
     // a netSearch
     vm0.invoke(new CacheSerializableRunnable("Remove local entries") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3079,6 +3255,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm2.invoke(new CacheSerializableRunnable("Verify keys/values") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3116,6 +3293,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm2 = host.getVM(2); // use a VM on a different gemfire system
 
     SerializableRunnable create = new CacheSerializableRunnable("Populate non-mirrored region") {
+      @Override
       public void run2() throws CacheException {
         RegionAttributes ra = getRegionAttributes();
         AttributesFactory fac =
@@ -3141,6 +3319,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       List expectedValues = new ArrayList(Arrays.asList(new Object[] {
         value1, value2, value3}));
 
+      @Override
       public synchronized void afterCreate2(EntryEvent event) {
         //getLogWriter().info("Invoking afterCreate2 with key=" + event.getKey());
         int index = expectedKeys.indexOf(event.getKey());
@@ -3153,6 +3332,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     }
 
     vm0.invoke(new CacheSerializableRunnable("Create Mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           RegionAttributes ra = getRegionAttributes();
           AttributesFactory factory =
@@ -3172,6 +3352,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Destroy the local entries so we know that they are not found by
     // a netSearch
     vm2.invoke(new CacheSerializableRunnable("Remove local entries") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3183,6 +3364,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Verify keys/values and listener") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3232,12 +3414,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm2 = host.getVM(2); // use VM on different gemfire system
 
     vm0.invoke(new CacheSerializableRunnable("Create Non-mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           createRegion(name, getRegionAttributes());
         }
       });
 
     SerializableRunnable create = new CacheSerializableRunnable("Populate mirrored region") {
+      @Override
       public void run2() throws CacheException {
         RegionAttributes ra = getRegionAttributes();
         AttributesFactory factory =
@@ -3260,6 +3444,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // Make sure that data wasn't pushed
     vm0.invoke(new CacheSerializableRunnable("Verify keys/values") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
@@ -3309,6 +3494,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm2 = host.getVM(2); // use VMs on different gemfire systems
 
     vm0.invoke(new CacheSerializableRunnable("Create region with loader") {
+        @Override
         public void run2() throws CacheException {
           RegionAttributes ra = getRegionAttributes();
           AttributesFactory factory =
@@ -3319,6 +3505,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           }
           factory.setDataPolicy(DataPolicy.REPLICATE);
           factory.setCacheLoader(new TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
                 return value;
@@ -3329,6 +3516,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     SerializableRunnable create = new CacheSerializableRunnable("Create region with bad loader") {
+      @Override
       public void run2() throws CacheException {
         RegionAttributes ra = getRegionAttributes();
         AttributesFactory factory =
@@ -3339,6 +3527,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
         factory.setDataPolicy(DataPolicy.REPLICATE);
         loader = new TestCacheLoader() {
+          @Override
           public Object load2(LoaderHelper helper)
           throws CacheLoaderException {
 
@@ -3355,6 +3544,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Get") {
+      @Override
       public void run2() throws CacheException {
        Region region =
          getRootRegion().getSubregion(name);
@@ -3363,6 +3553,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     vm2.invoke(new CacheSerializableRunnable("Verify no load") {
+      @Override
       public void run2() throws CacheException {
        assertFalse(loader.wasInvoked());
       }
@@ -3386,6 +3577,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm2 = host.getVM(2); // use VMs on different gemfire systems
 
     SerializableRunnable create = new CacheSerializableRunnable("Create region with loader") {
+      @Override
       public void run2() throws CacheException {
           RegionAttributes ra = getRegionAttributes();
           AttributesFactory factory =
@@ -3396,6 +3588,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           }
           factory.setDataPolicy(DataPolicy.REPLICATE);
           factory.setCacheLoader(new TestCacheLoader() {
+              @Override
               public Object load2(LoaderHelper helper)
                 throws CacheLoaderException {
                 return value;
@@ -3407,6 +3600,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     vm0.invoke(new CacheSerializableRunnable("Create region with bad loader") {
+        @Override
         public void run2() throws CacheException {
           RegionAttributes ra = getRegionAttributes();
           AttributesFactory factory =
@@ -3423,6 +3617,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Get") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3444,12 +3639,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm0 = host.getVM(0);
 
     vm0.invoke(new CacheSerializableRunnable("Create region") {
+        @Override
         public void run2() throws CacheException {
           createRegion(name);
         }
       });
 
     vm0.invoke(new CacheSerializableRunnable("Populate region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3458,12 +3655,14 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         }
       });
     vm0.invoke(new CacheSerializableRunnable("Close cache") {
+        @Override
         public void run2() throws CacheException {
           closeCache();
         }
       });
 
     vm0.invoke(new CacheSerializableRunnable("Re-create cache") {
+        @Override
         public void run2() throws CacheException {
           Region region = createRegion(name);
           // if this is a backup region, then it will find the data
@@ -3493,6 +3692,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm1 = host.getVM(2);  // Other VM is from a different gemfire system
 
     SerializableRunnable create = new CacheSerializableRunnable("Create with TTL") {
+      @Override
       public void run2() throws CacheException {
         AttributesFactory factory = new AttributesFactory(getRegionAttributes());
         factory.setStatisticsEnabled(true);
@@ -3515,6 +3715,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // vm0 - Create region, short timeout
     vm0.invoke(new CacheSerializableRunnable("Create with TTL") {
+      @Override
       public void run2() throws CacheException {
         RegionAttributes ra = getRegionAttributes();
         AttributesFactory factory =
@@ -3548,6 +3749,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Even though netSearch finds vm1's entry is not expired, it is considered
     // expired with respect to vm0's attributes
     vm0.invoke(new CacheSerializableRunnable("get(key), expect null") {
+      @Override
       public void run2() throws CacheException {
         Region region = getRootRegion().getSubregion(name);
         Object got = region.get(key);
@@ -3557,6 +3759,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // We see the object is actually still there
     vm1.invoke(new CacheSerializableRunnable("get(key), expect value") {
+      @Override
       public void run2() throws CacheException {
         Region region = getRootRegion().getSubregion(name);
         Object got = region.get(key);
@@ -3582,6 +3785,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     final VM vm1 = host.getVM(2);
 
     SerializableRunnable create = new CacheSerializableRunnable("Create with IdleTimeout") {
+      @Override
       public void run2() throws CacheException {
         AttributesFactory factory = new AttributesFactory(getRegionAttributes());
         factory.setStatisticsEnabled(true);
@@ -3604,6 +3808,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // vm0 - Create region, short timeout
     vm0.invoke(new CacheSerializableRunnable("Create with IdleTimeout") {
+      @Override
       public void run2() throws CacheException {
         RegionAttributes ra = getRegionAttributes();
         AttributesFactory factory =
@@ -3637,6 +3842,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Even though netSearch finds vm1's entry is not expired, it is considered
     // expired with respect to vm0's attributes
     vm0.invoke(new CacheSerializableRunnable("get(key), expect null") {
+      @Override
       public void run2() throws CacheException {
         Region region = getRootRegion().getSubregion(name);
         Object got = region.get(key);
@@ -3646,6 +3852,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // We see the object is actually still there
     vm1.invoke(new CacheSerializableRunnable("get(key), expect value") {
+      @Override
       public void run2() throws CacheException {
         Region region = getRootRegion().getSubregion(name);
         Object got = region.get(key);
@@ -3677,9 +3884,11 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     class DestroyListener extends TestCacheListener {
       boolean eventIsExpiration = false;
 
+      @Override
       public void afterDestroyBeforeAddEvent(EntryEvent event) {
         eventIsExpiration = event.isExpiration();
       }
+      @Override
       public void afterDestroy2(EntryEvent event) {
         if (event.isOriginRemote()) {
           assertTrue(!event.getDistributedMember().equals(getSystem().getDistributedMember()));
@@ -3691,10 +3900,12 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         eventIsExpiration = event.getOperation().isExpiration();
       }
 
+      @Override
       public void afterCreate2(EntryEvent event) {
         // ignore
       }
 
+      @Override
       public void afterUpdate2(EntryEvent event) {
         // ignore
       }
@@ -3702,6 +3913,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     SerializableRunnable createRegion = new CacheSerializableRunnable("Create with Listener") {
+      @Override
       public void run2() throws CacheException {
         AttributesFactory fac = new AttributesFactory(getRegionAttributes());
         fac.addCacheListener(destroyListener = new DestroyListener());
@@ -3712,6 +3924,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(createRegion);
 
     vm0.invoke(new CacheSerializableRunnable("Create with TTL") {
+        @Override
         public void run2() throws CacheException {
           AttributesFactory factory = new AttributesFactory(getRegionAttributes());
           factory.setStatisticsEnabled(true);
@@ -3741,6 +3954,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     //pause(10);
 
     vm1.invoke(new SerializableCallable() {
+      @Override
       public Object call() throws Exception {
         Region region = getRootRegion().getSubregion(name);
         DestroyListener dl = (DestroyListener)region.getAttributes().getCacheListeners()[0];
@@ -3756,12 +3970,15 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       }
     });
     vm0.invoke(new CacheSerializableRunnable("Check create received from vm1") {
+      @Override
       public void run2() throws CacheException {
         final Region region = getRootRegion().getSubregion(name);
         WaitCriterion waitForCreate = new WaitCriterion() {
+          @Override
           public boolean done() {
             return region.getEntry(key) != null;
           }
+          @Override
           public String description() {
             return "never saw create of " + key;
           }
@@ -3772,6 +3989,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     } finally {
       vm0.invoke(new CacheSerializableRunnable("resume expiration") {
+        @Override
         public void run2() throws CacheException {
           ExpiryTask.permitExpiration();
         }
@@ -3780,12 +3998,15 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // now wait for it to expire
     vm0.invoke(new CacheSerializableRunnable("Check local destroy") {
+        @Override
         public void run2() throws CacheException {
           final Region region = getRootRegion().getSubregion(name);
           WaitCriterion waitForExpire = new WaitCriterion() {
+            @Override
             public boolean done() {
               return region.getEntry(key) == null;
             }
+            @Override
             public String description() {
               return "never saw expire of " + key + " entry=" + region.getEntry(key);
             }
@@ -3795,12 +4016,15 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify destroyed and event") {
+        @Override
         public void run2() throws CacheException {
           final Region region = getRootRegion().getSubregion(name);
           WaitCriterion waitForExpire = new WaitCriterion() {
+            @Override
             public boolean done() {
               return region.getEntry(key) == null;
             }
+            @Override
             public String description() {
               return "never saw expire of " + key + " entry=" + region.getEntry(key);
             }
@@ -3842,6 +4066,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm1 = host.getVM(1);
 
     SerializableRunnable create = new CacheSerializableRunnable("Populate") {
+      @Override
       public void run2() throws CacheException {
       System.setProperty(LocalRegion.EXPIRY_MS_PROPERTY, "true");
       try {
@@ -3856,6 +4081,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm1.invoke(create);
 
     vm0.invoke(new CacheSerializableRunnable("Create with TTL") {
+        @Override
         public void run2() throws CacheException {
           AttributesFactory factory = new AttributesFactory(getRegionAttributes());
           factory.setStatisticsEnabled(true);
@@ -3892,6 +4118,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     if (mirrored) return;
 
     vm1.invoke(new SerializableCallable() {
+      @Override
       public Object call() throws Exception {
         Region region = getRootRegion().getSubregion(name);
         region.put(key, value);
@@ -3900,6 +4127,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     vm0.invoke(new CacheSerializableRunnable("Check local destroy") {
+        @Override
         public void run2() throws CacheException {
           final Region region =
             getRootRegion().getSubregion(name);
@@ -3930,6 +4158,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
             // scheduling delays and machine load (see GEODE-410).
             // The previous code would fail after 100ms; now we wait 3000ms.
             WaitCriterion waitForUpdate = new WaitCriterion() {
+              @Override
               public boolean done() {
                 Region.Entry re = region.getEntry(key);
                 if (re != null) {
@@ -3943,6 +4172,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
                 }
                 return re == null;
               }
+              @Override
               public String description() {
                 String expiryInfo = "";
                 try {
@@ -3963,6 +4193,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm1.invoke(new CacheSerializableRunnable("Verify local") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -3999,6 +4230,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     VM vm1 = host.getVM(1);
 
     vm0.invoke(new CacheSerializableRunnable("Create with Idle") {
+      @Override
       public void run2() throws CacheException {
         AttributesFactory factory = new AttributesFactory(getRegionAttributes());
         factory.setStatisticsEnabled(true);
@@ -4022,6 +4254,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     vm1.invoke(new CacheSerializableRunnable("Create Region " + name) {
+      @Override
       public void run2() throws CacheException {
         AttributesFactory factory = new AttributesFactory(getRegionAttributes());
         factory.setStatisticsEnabled(true);
@@ -4038,6 +4271,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     vm1.invoke(new CacheSerializableRunnable("Update entry") {
+      @Override
       public void run2() throws CacheException {
         final Region r = getRootRegion().getSubregion(name);
         assertNotNull(r);
@@ -4046,15 +4280,18 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     });
 
     vm0.invoke(new CacheSerializableRunnable("Verify reset") {
+      @Override
       public void run2() throws CacheException {
         final LocalRegion region =
             (LocalRegion) getRootRegion().getSubregion(name);
 
         // wait for update to reach us from vm1 (needed if no-ack)
         WaitCriterion waitForUpdate = new WaitCriterion() {
+          @Override
           public boolean done() {
             return value.equals(region.get(key));
           }
+          @Override
           public String description() {
             return "never saw update of " + key;
           }
@@ -4100,6 +4337,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create = new
       CacheSerializableRunnable("Create Mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           beginCacheXml();
           { // root region must be DACK because its used to sync up async subregions
@@ -4129,6 +4367,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     vm0.invoke(new
       CacheSerializableRunnable("Create Nonmirrored Region") {
+        @Override
         public void run2() throws CacheException {
           { // root region must be DACK because its used to sync up async subregions
             AttributesFactory factory = new AttributesFactory();
@@ -4147,6 +4386,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Put initial data") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4159,6 +4399,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // start asynchronous process that does updates to the data
     AsyncInvocation async = vm0.invokeAsync(new CacheSerializableRunnable("Do Nonblocking Operations") {
+      @Override
       public void run2() throws CacheException {
         Region region = getRootRegion().getSubregion(name);
 
@@ -4167,6 +4408,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           ((com.gemstone.gemfire.internal.cache.DistributedRegion)region).getCacheDistributionAdvisor();
         final int expectedProfiles = 1;
         WaitCriterion ev = new WaitCriterion() {
+          @Override
           public boolean done() {
             DataPolicy currentPolicy = getRegionAttributes().getDataPolicy();
             if (currentPolicy == DataPolicy.PRELOADED) {
@@ -4175,6 +4417,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
               return adv.adviseReplicates().size() >= expectedProfiles;              
             }
           }
+          @Override
           public String description() {
             return "replicate count never reached " + expectedProfiles;
           }
@@ -4245,6 +4488,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // slow down image processing to make it more likely to get async updates
     if (!getRegionAttributes().getScope().isGlobal()) {
       vm2.invoke(new SerializableRunnable("Set slow image processing") {
+          @Override
           public void run() {
             // if this is a no_ack test, then we need to slow down more because of the
             // pauses in the nonblocking operations
@@ -4261,6 +4505,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       // wait for nonblocking operations to complete
       ThreadUtils.join(async, 30 * 1000);
       vm2.invoke(new SerializableRunnable("Set fast image processing") {
+          @Override
           public void run() {
             com.gemstone.gemfire.internal.cache.InitialImageOperation.slowImageProcessing = 0;
           }
@@ -4287,6 +4532,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Locally destroy the region in vm0 so we know that they are not found by
     // a netSearch
     vm0.invoke(new CacheSerializableRunnable("Locally destroy region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4299,6 +4545,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invokeRepeatingIfNecessary(new CacheSerializableRunnable("Verify entryCount") {
         boolean entriesDumped = false;
 
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4333,6 +4580,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     vm2.invoke(new CacheSerializableRunnable("Verify keys/values & Nonblocking") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4429,6 +4677,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create = new
       CacheSerializableRunnable("Create Mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           beginCacheXml();
           { // root region must be DACK because its used to sync up async subregions
@@ -4456,6 +4705,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     vm0.invoke(new
       CacheSerializableRunnable("Create Nonmirrored Region") {
+        @Override
         public void run2() throws CacheException {
           { // root region must be DACK because its used to sync up async subregions
             AttributesFactory factory = new AttributesFactory();
@@ -4474,6 +4724,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Put initial data") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4486,6 +4737,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // start asynchronous process that does updates to the data
     AsyncInvocation async = vm0.invokeAsync(new CacheSerializableRunnable("Do Nonblocking Operations") {
+      @Override
       public void run2() throws CacheException {
         Region region = getRootRegion().getSubregion(name);
 
@@ -4494,6 +4746,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           ((com.gemstone.gemfire.internal.cache.DistributedRegion)region).getCacheDistributionAdvisor();
         final int expectedProfiles = 1;
         WaitCriterion ev = new WaitCriterion() {
+          @Override
           public boolean done() {
             DataPolicy currentPolicy = getRegionAttributes().getDataPolicy(); 
             if (currentPolicy == DataPolicy.PRELOADED) {
@@ -4502,6 +4755,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
               return adv.adviseReplicates().size() >= expectedProfiles;              
             }
           }
+          @Override
           public String description() {
             return "replicate count never reached " + expectedProfiles;
           }
@@ -4570,6 +4824,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // slow down image processing to make it more likely to get async updates
     if (!getRegionAttributes().getScope().isGlobal()) {
       vm2.invoke(new SerializableRunnable("Set slow image processing") {
+          @Override
           public void run() {
             // if this is a no_ack test, then we need to slow down more because of the
             // pauses in the nonblocking operations
@@ -4587,6 +4842,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       ThreadUtils.join(async, 30 * 1000);
 
       vm2.invoke(new SerializableRunnable("Set fast image processing") {
+          @Override
           public void run() {
             com.gemstone.gemfire.internal.cache.InitialImageOperation.slowImageProcessing = 0;
           }
@@ -4613,6 +4869,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Locally destroy the region in vm0 so we know that they are not found by
     // a netSearch
     vm0.invoke(new CacheSerializableRunnable("Locally destroy region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4624,6 +4881,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invokeRepeatingIfNecessary(new CacheSerializableRunnable("Verify entryCount") {
         boolean entriesDumped = false;
 
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4652,6 +4910,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
 
     vm2.invoke(new CacheSerializableRunnable("Verify keys/values & Nonblocking") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4740,6 +4999,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     SerializableRunnable create = new
       CacheSerializableRunnable("Create Mirrored Region") {
+        @Override
         public void run2() throws CacheException {
           beginCacheXml();
           { // root region must be DACK because its used to sync up async subregions
@@ -4764,6 +5024,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     vm0.invoke(new
       CacheSerializableRunnable("Create Nonmirrored Region") {
+        @Override
         public void run2() throws CacheException {
           { // root region must be DACK because its used to sync up async subregions
             AttributesFactory factory = new AttributesFactory();
@@ -4783,6 +5044,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Put initial data") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4799,6 +5061,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // start asynchronous process that does updates to the data
     AsyncInvocation async = vm0.invokeAsync(new CacheSerializableRunnable("Do Nonblocking Operations") {
+      @Override
       public void run2() throws CacheException {
         Region region =
           getRootRegion().getSubregion(name);
@@ -4808,9 +5071,11 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
           ((com.gemstone.gemfire.internal.cache.DistributedRegion)region).getCacheDistributionAdvisor();
         final int expectedProfiles = 1;
         WaitCriterion ev = new WaitCriterion() {
+          @Override
           public boolean done() {
             return adv.adviseReplicates().size() >= expectedProfiles;
           }
+          @Override
           public String description() {
             return "profile count never reached " + expectedProfiles;
           }
@@ -4879,6 +5144,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // slow down image processing to make it more likely to get async updates
     if (!getRegionAttributes().getScope().isGlobal()) {
       vm2.invoke(new SerializableRunnable("Set slow image processing") {
+          @Override
           public void run() {
             // make sure the cache is set up before turning on slow
             // image processing
@@ -4900,6 +5166,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
         ThreadUtils.join(async, 30 * 1000);
       } finally {
         vm2.invoke(new SerializableRunnable("Set fast image processing") {
+          @Override
           public void run() {
             com.gemstone.gemfire.internal.cache.InitialImageOperation.slowImageProcessing = 0;
           }
@@ -4926,6 +5193,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     // Locally destroy the region in vm0 so we know that they are not found by
     // a netSearch
     vm0.invoke(new CacheSerializableRunnable("Locally destroy region") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4938,6 +5206,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     vm2.invokeRepeatingIfNecessary(new CacheSerializableRunnable("Verify entryCount") {
         private boolean entriesDumped = false;
 
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -4965,6 +5234,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
     }, 3000);
 
     vm2.invoke(new CacheSerializableRunnable("Verify keys/values & Nonblocking") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -5060,6 +5330,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     vm0.invoke(new
       CacheSerializableRunnable("Create Nonmirrored Region") {
+        @Override
         public void run2() throws CacheException {
           { // root region must be DACK because its used to sync up async subregions
             AttributesFactory factory = new AttributesFactory();
@@ -5078,6 +5349,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
       });
 
     vm0.invoke(new CacheSerializableRunnable("Put initial data") {
+        @Override
         public void run2() throws CacheException {
           Region region =
             getRootRegion().getSubregion(name);
@@ -5094,6 +5366,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 
     // start asynchronous process that does updates to the data
     AsyncInvocation async = vm0.invokeAsync(new CacheSerializableRunnable("Do Nonblocking Operations") {
+      @Override
       public void run2() throws CacheException {
         Wait.pause(200); // give the gii guy a chance to start
         Region region =
@@ -5105,9 +5378,11 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
 //        int numProfiles;
         final int expectedProfiles = 1;
         WaitCriterion ev = new WaitCriterion() {
+          @Override
           public boolean done() {
             return expectedProfiles == adv.adviseReplicates().size();
           }
+          @Override
           public String description() {
             return "profile count never became exactly " + expectedProfiles;
           }
@@ -5185,6 +5460,7 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase

<TRUNCATED>


[10/17] incubator-geode git commit: GEODE-1464: remove sqlf code

Posted by kl...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage.java
index 2d5989b..da60a98 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage.java
@@ -267,10 +267,6 @@ public final class RemoteRemoveAllMessage extends RemoteOperationMessageWithDire
       EntryVersionsList versionTags = new EntryVersionsList(removeAllDataCount);
 
       boolean hasTags = false;
-      // get the "keyRequiresRegionContext" flag from first element assuming
-      // all key objects to be uniform
-      final boolean requiresRegionContext =
-        (this.removeAllData[0].key instanceof KeyWithRegionContext);
       for (int i = 0; i < this.removeAllDataCount; i++) {
         if (!hasTags && removeAllData[i].versionTag != null) {
           hasTags = true;
@@ -278,7 +274,7 @@ public final class RemoteRemoveAllMessage extends RemoteOperationMessageWithDire
         VersionTag<?> tag = removeAllData[i].versionTag;
         versionTags.add(tag);
         removeAllData[i].versionTag = null;
-        this.removeAllData[i].toData(out, requiresRegionContext);
+        this.removeAllData[i].toData(out);
         this.removeAllData[i].versionTag = tag;
       }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor.java
index bd19104..4f49ccf 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor.java
@@ -1898,9 +1898,6 @@ public class SearchLoadAndWriteProcessor implements MembershipListener {
           setClearCountReference(region);		
 	  try {
 	    boolean initialized = region.isInitialized();
-	    if(region.keyRequiresRegionContext()) {
-	      ((KeyWithRegionContext)this.key).setRegionContext(region);
-	    }
             RegionEntry entry = region.basicGetEntry(this.key);
             if (entry != null) {
               synchronized (entry) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntry.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntry.java
index 2cc6681..317f4e6 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntry.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntry.java
@@ -56,17 +56,6 @@ public class TXEntry implements Region.Entry
     this.keyInfo = key;
     this.myTX = tx;
     this.rememberReads = rememberReads;
-    
-    //Assert that these contructors are invoked only 
-    // via factory path. I am not able to make them private
-    // because SqlfabricTxEntry needs extending TxEntry
-    /*if(logger.isDebugEnabled()) {
-      StackTraceElement[] traces =Thread.currentThread().getStackTrace();
-      //The third element should be the factory one
-      StackTraceElement trace = traces[2];
-      Assert.assertTrue(TxEntryFactory.class.isAssignableFrom(trace.getClass()));
-      Assert.assertTrue(trace.getMethodName().equals("createEntry"));
-    }*/
   }
 
   public boolean isLocal() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntryState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntryState.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntryState.java
index f392f04..c6caefa 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntryState.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXEntryState.java
@@ -24,7 +24,6 @@ import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedM
 import com.gemstone.gemfire.internal.Assert;
 import com.gemstone.gemfire.internal.DataSerializableFixedID;
 import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.delta.Delta;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.internal.lang.StringUtils;
@@ -82,10 +81,6 @@ public class TXEntryState implements Releasable
    */
   private int nearSideEventOffset = -1;
 
-  //Asif: In case of Sqlfabric, the pending value may be a SerializableDelta object 
-  //which may be containing base value ( in case of Tx create) along with bunch 
-  //of incremental deltas, so for correct behaviour this field should be accessed only 
-  //by its getter. Do not use it directly  
   private Object pendingValue;
   
   /**
@@ -290,24 +285,12 @@ public class TXEntryState implements Releasable
   }
 
   public Object getOriginalValue() {
-    Object value = this.originalValue;
-    
-    if(value instanceof Delta) {
-      value = ((Delta) value).getResultantValue();
-    }
-    
-    return value;
+    return this.originalValue;
   }
 
   public Object getPendingValue()
   {
-    Object value = this.pendingValue;
-    
-    if(value instanceof Delta) {
-      value = ((Delta) value).getResultantValue();
-    }
-    
-    return value;
+    return this.pendingValue;
   }
   
   public Object getCallbackArgument()
@@ -335,12 +318,7 @@ public class TXEntryState implements Releasable
 
   void setPendingValue(Object pv)
   {
-    if(pv instanceof Delta) {
-      Object toMerge = this.pendingValue;      
-      this.pendingValue = ((Delta)pv).merge(toMerge, this.op == OP_CREATE);
-    }else {
-      this.pendingValue = pv;
-    }
+    this.pendingValue = pv;
   }
   
   void setCallbackArgument(Object callbackArgument)
@@ -2001,9 +1979,6 @@ public class TXEntryState implements Releasable
         valueBytes = (byte[])v;
       }
       else {
-        // this value shouldn't be a Delta
-        Assert.assertTrue(!(v instanceof Delta));
-    
         deserializationPolicy = DistributedCacheOperation.DESERIALIZATION_POLICY_LAZY;
         valueBytes = EntryEventImpl.serialize(v);
       }
@@ -2076,7 +2051,6 @@ public class TXEntryState implements Releasable
   }
   
 
-  // Asif:Add for sql fabric as it has to plug in its own TXEntry object
   private final static TXEntryStateFactory factory = new TXEntryStateFactory() {
 
     public TXEntryState createEntry()

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionLockRequestImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionLockRequestImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionLockRequestImpl.java
index 6d997c7..6327ed7 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionLockRequestImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionLockRequestImpl.java
@@ -104,24 +104,17 @@ public class TXRegionLockRequestImpl
     final GemFireCacheImpl cache = getCache(false);
     try {
       final int size = InternalDataSerializer.readArrayLength(in);
-      boolean read = false;
       if (cache != null && size > 0) {
         this.r = (LocalRegion)cache.getRegion(this.regionPath);
-        if( this.r != null ) {
-          this.entryKeys = readEntryKeySet(this.r.keyRequiresRegionContext(), size, in);
-          read = true;
-        }
-      }
-      if ( !read && size > 0 ) {
-        this.entryKeys = readEntryKeySet(false, size, in);
       }
+      this.entryKeys = readEntryKeySet(size, in);
     } catch (CacheClosedException cce) {
       // don't throw in deserialization
       this.entryKeys = null;
     }
   }
   
-  private final Set<Object> readEntryKeySet(final boolean keyRequiresRegionContext,
+  private final Set<Object> readEntryKeySet(
       final int size, final DataInput in) throws IOException,
       ClassNotFoundException {
 
@@ -133,9 +126,6 @@ public class TXRegionLockRequestImpl
     Object key;
     for (int i = 0; i < size; i++) {
       key = DataSerializer.readObject(in);
-      if (keyRequiresRegionContext) {
-        ((KeyWithRegionContext)key).setRegionContext(this.r);
-      }
       set.add(key);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionState.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionState.java
index 19cbe33..479beb2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionState.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXRegionState.java
@@ -524,12 +524,7 @@ public class TXRegionState {
     return changes;
   }
   
-  public Map<Object,TXEntryState> getEntriesInTxForSqlFabric() {
-    return Collections.unmodifiableMap(this.entryMods);
-  }
-
   public TXState getTXState() {
-    // TODO Auto-generated method stub
     return txState;
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXState.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXState.java
index 0ce049d..c42f63c 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXState.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXState.java
@@ -1325,13 +1325,10 @@ public class TXState implements TXStateInterface {
    * @param rememberRead true if the value read from committed state
    *   needs to be remembered in tx state for repeatable read.
    * @param createIfAbsent should a transactional entry be created if not present. 
-   *        Used by sql fabric system
    * @return a txEntryState or null if the entry doesn't exist in the transaction and/or committed state. 
    */
   public TXEntryState txReadEntry(KeyInfo keyInfo, LocalRegion localRegion,
       boolean rememberRead, boolean createIfAbsent) {
-    // EntryNotFoundException can be expected in case of sqlfabric and should
-    // not be caught.
     localRegion.cache.getCancelCriterion().checkCancelInProgress(null);
     return txReadEntry(keyInfo, localRegion, rememberRead, null, createIfAbsent);
   }
@@ -1764,7 +1761,7 @@ public class TXState implements TXStateInterface {
 //	        final boolean requiresRegionContext = theRegion.keyRequiresRegionContext();
 	        InternalDistributedMember myId = theRegion.getDistributionManager().getDistributionManagerId();
 	        for (int i = 0; i < putallOp.putAllDataSize; ++i) {
-	          @Released EntryEventImpl ev = PutAllPRMessage.getEventFromEntry(theRegion, myId,myId, i, putallOp.putAllData, false, putallOp.getBaseEvent().getContext(), false, !putallOp.getBaseEvent().isGenerateCallbacks(), false);
+	          @Released EntryEventImpl ev = PutAllPRMessage.getEventFromEntry(theRegion, myId,myId, i, putallOp.putAllData, false, putallOp.getBaseEvent().getContext(), false, !putallOp.getBaseEvent().isGenerateCallbacks());
 	          try {
 	          ev.setPutAllOperation(putallOp);
 	          if (theRegion.basicPut(ev, false, false, null, false)) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXStateInterface.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXStateInterface.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXStateInterface.java
index ffcae4b..865ebd5 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXStateInterface.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/TXStateInterface.java
@@ -146,7 +146,6 @@ public interface TXStateInterface extends Synchronization, InternalDataView {
    * @param rememberRead true if the value read from committed state
    *   needs to be remembered in tx state for repeatable read.
    * @param  createTxEntryIfAbsent should a transactional entry be created if not present. 
-   *        Used by sqlfabric system
    * @return a txEntryState or null if the entry doesn't exist in the transaction and/or committed state. 
    */
   public TXEntryState txReadEntry(KeyInfo entryKey, LocalRegion localRegion, boolean rememberRead

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateAttributesProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateAttributesProcessor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateAttributesProcessor.java
index ceb98f0..9754ab9 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateAttributesProcessor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateAttributesProcessor.java
@@ -369,14 +369,7 @@ public class UpdateAttributesProcessor {
       // set the processor ID to be able to send reply to sender in case of any
       // unexpected exception during deserialization etc.
       ReplyProcessor21.setMessageRPId(this.processorId);
-      try {
-        this.profile = DataSerializer.readObject(in);
-      } catch (DSFIDFactory.SqlfSerializationException ex) {
-        // Ignore SQLFabric serialization errors and reply with nothing.
-        // This can happen even during normal startup of all SQLFabric VMs
-        // when DS connect is complete but SQLFabric boot is still in progress.
-        this.profile = null;
-      }
+      this.profile = DataSerializer.readObject(in);
       this.exchangeProfiles = in.readBoolean();
       this.removeProfile = in.readBoolean();
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateEntryVersionOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateEntryVersionOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateEntryVersionOperation.java
index fce4dee..23fb300 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateEntryVersionOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateEntryVersionOperation.java
@@ -94,11 +94,6 @@ public class UpdateEntryVersionOperation extends DistributedCacheOperation {
     @Retained
     protected InternalCacheEvent createEvent(DistributedRegion rgn)
         throws EntryNotFoundException {
-      
-      if (rgn.keyRequiresRegionContext()) {
-        ((KeyWithRegionContext)this.key).setRegionContext(rgn);
-      }
-      
       @Retained EntryEventImpl ev = EntryEventImpl.create(rgn, getOperation(), this.key,
          null /* newValue */, this.callbackArg /*callbackArg*/, true /* originRemote*/ , getSender(), false /*generateCallbacks*/);
       ev.setEventId(this.eventId);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateOperation.java
index 730d6d7..e60cda3 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/UpdateOperation.java
@@ -100,11 +100,7 @@ public class UpdateOperation extends AbstractUpdateOperation
     m.event = ev;
     m.eventId = ev.getEventId();
     m.key = ev.getKey();
-    if (CachedDeserializableFactory.preferObject() || ev.hasDelta()) {
-      m.deserializationPolicy = DESERIALIZATION_POLICY_EAGER;
-    } else {
-      m.deserializationPolicy = DESERIALIZATION_POLICY_LAZY;
-    }
+    m.deserializationPolicy = DESERIALIZATION_POLICY_LAZY;
     ev.exportNewValue(m);
   }
 
@@ -297,8 +293,7 @@ public class UpdateOperation extends AbstractUpdateOperation
      */
     static void setNewValueInEvent(byte[] newValue, Object newValueObj,
         EntryEventImpl event, byte deserializationPolicy) {
-      if (newValue == null
-          && deserializationPolicy != DESERIALIZATION_POLICY_EAGER) {
+      if (newValue == null) {
         // in an UpdateMessage this results from a create(key, null) call,
         // set local invalid flag in event if this is a normal region. Otherwise
         // it should be a distributed invalid.
@@ -317,9 +312,6 @@ public class UpdateOperation extends AbstractUpdateOperation
         case DESERIALIZATION_POLICY_NONE:
           event.setNewValue(newValue);
           break;
-        case DESERIALIZATION_POLICY_EAGER:
-          event.setNewValue(newValueObj);
-          break;
         default:
           throw new InternalGemFireError(LocalizedStrings
               .UpdateOperation_UNKNOWN_DESERIALIZATION_POLICY_0
@@ -332,10 +324,6 @@ public class UpdateOperation extends AbstractUpdateOperation
     {
       Object argNewValue = null;
       final boolean originRemote = true, generateCallbacks = true;
-
-      if (rgn.keyRequiresRegionContext()) {
-        ((KeyWithRegionContext)this.key).setRegionContext(rgn);
-      }
       @Retained EntryEventImpl result = EntryEventImpl.create(rgn, getOperation(), this.key,
           argNewValue, // oldValue,
           this.callbackArg, originRemote, getSender(), generateCallbacks);
@@ -413,13 +401,7 @@ public class UpdateOperation extends AbstractUpdateOperation
         this.deltaBytes = DataSerializer.readByteArray(in);
       }
       else {
-        if (this.deserializationPolicy
-            == DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER) {
-          this.newValueObj = DataSerializer.readObject(in);
-        }
-        else {
-          this.newValue = DataSerializer.readByteArray(in);
-        }
+        this.newValue = DataSerializer.readByteArray(in);
         if ((extraFlags & HAS_DELTA_WITH_FULL_VALUE) != 0) {
           this.deltaBytes = DataSerializer.readByteArray(in);
         }
@@ -500,13 +482,7 @@ public class UpdateOperation extends AbstractUpdateOperation
       byte[] valueBytes = null;
       Object valueObj = null;
       if (this.newValueObj != null) {
-        if (this.deserializationPolicy ==
-          DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER) {
-          valueObj = this.newValueObj;
-        }
-        else {
-          valueBytes = EntryEventImpl.serialize(this.newValueObj);
-        }
+        valueBytes = EntryEventImpl.serialize(this.newValueObj);
       }
       else {
         valueBytes = this.newValue;
@@ -576,10 +552,6 @@ public class UpdateOperation extends AbstractUpdateOperation
       // boolean localLoad = false, netLoad = false, netSearch = false,
       // distributed = true;
       final boolean originRemote = true, generateCallbacks = true;
-
-      if (rgn.keyRequiresRegionContext()) {
-        ((KeyWithRegionContext)this.key).setRegionContext(rgn);
-      }
       @Retained EntryEventImpl ev = EntryEventImpl.create(rgn, getOperation(), this.key,
           argNewValue, this.callbackArg, originRemote, getSender(),
           generateCallbacks);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ValidatingDiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ValidatingDiskRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ValidatingDiskRegion.java
index 32abd68..edf3316 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ValidatingDiskRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ValidatingDiskRegion.java
@@ -173,9 +173,6 @@ public class ValidatingDiskRegion extends DiskRegion implements DiskRecoveryStor
     public void handleValueOverflow(RegionEntryContext context) {throw new IllegalStateException("should never be called");}
     
     @Override
-    public void afterValueOverflow(RegionEntryContext context) {throw new IllegalStateException();}
-    
-    @Override
     public Object prepareValueForCache(RegionEntryContext r, Object val, boolean isEntryUpdate) {
       throw new IllegalStateException("Should never be called");
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/WrappedCallbackArgument.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/WrappedCallbackArgument.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/WrappedCallbackArgument.java
index 7d5b255..93fc533 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/WrappedCallbackArgument.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/WrappedCallbackArgument.java
@@ -40,12 +40,6 @@ public abstract class WrappedCallbackArgument {
    */
   private Object _originalCallbackArg;
   
-  /** If the GatewayEvent is in a Sql Fabric started Hub, in which case
-   * the original callback argument is not serialized
-   * 
-   */
-   private boolean serializeCallbackArg = true; 
-
   /**
    * No arg constructor for DataSerializable.
    */
@@ -57,20 +51,6 @@ public abstract class WrappedCallbackArgument {
    *
    * @param originalCallbackArg The original callback argument set by the
    * caller or null if there was not callback arg
-   * @param serializeCBArg  boolean indicating if the event is created by a 
-   * sql fabric system
-   */
-  public WrappedCallbackArgument(Object originalCallbackArg, boolean serializeCBArg) {
-    this._originalCallbackArg = originalCallbackArg;
-    this.serializeCallbackArg = serializeCBArg;
-  }
- 
-  
-  /**
-   * Constructor.
-   *
-   * @param originalCallbackArg The original callback argument set by the
-   * caller or null if there was not callback arg
    */
   public WrappedCallbackArgument(Object originalCallbackArg) {
     this._originalCallbackArg = originalCallbackArg;    
@@ -86,11 +66,7 @@ public abstract class WrappedCallbackArgument {
   }
 
   public void toData(DataOutput out) throws IOException {
-    if(this.serializeCallbackArg) {
-      DataSerializer.writeObject(this._originalCallbackArg, out);
-    }else {
-      DataSerializer.writeObject(null, out);      
-    }
+    DataSerializer.writeObject(this._originalCallbackArg, out);
   }
 
   public void fromData(DataInput in) throws IOException, ClassNotFoundException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/delta/Delta.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/delta/Delta.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/delta/Delta.java
deleted file mode 100644
index 27d02c4..0000000
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/delta/Delta.java
+++ /dev/null
@@ -1,56 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package com.gemstone.gemfire.internal.cache.delta;
-
-import com.gemstone.gemfire.cache.EntryEvent;
-
-/**
- * Represents changes to apply to a region entry instead of a new value.
- * A Delta is passed as the new value in a put operation on a Region
- * and knows how to apply itself to an old value.
- *
- * Internal Note: When an update message carries a Delta as a payload,
- * it makes sure it gets deserialized before being put into the region.
- *
- * @since GemFire 5.5
- * @see com.gemstone.gemfire.internal.cache.UpdateOperation
- */
-public interface Delta {
-
-  /**
-   * Apply delta to the old value from the provided EntryEvent.
-   * If the delta cannot be applied for any reason then an (unchecked)
-   * exception should be thrown. If the put is being applied in a
-   * distributed-ack scope, then the exception will be propagated back
-   * to the originating put call, but will not necessarily cause puts
-   * in other servers to fail.
-   *
-   * @param putEvent the EntryEvent for the put operation, from which
-   * the old value can be obtained (as well as other information such
-   * as the key and region being operated on)
-   *
-   * @return the new value to be put into the region
-   */
-  Object apply(EntryEvent<?, ?> putEvent);
-
-  Object merge(Object toMerge, boolean isCreate);
-
-  Object merge(Object toMerge);
-
-  Object getResultantValue();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/AbstractExecution.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/AbstractExecution.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/AbstractExecution.java
index 7b7c34d..fefc1c1 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/AbstractExecution.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/AbstractExecution.java
@@ -159,7 +159,6 @@ public abstract class AbstractExecution implements InternalExecution {
   }
   
   protected AbstractExecution() {
-    this.hasRoutingObjects = false;
   }
 
   protected AbstractExecution(AbstractExecution ae) {
@@ -173,7 +172,6 @@ public abstract class AbstractExecution implements InternalExecution {
       this.memberMappedArg = ae.memberMappedArg;
     }
     this.isMemberMappedArgument = ae.isMemberMappedArgument;
-    this.hasRoutingObjects = ae.hasRoutingObjects;
     this.isClientServerMode = ae.isClientServerMode;
     if (ae.proxyCache != null) {
       this.proxyCache = ae.proxyCache;
@@ -211,26 +209,10 @@ public abstract class AbstractExecution implements InternalExecution {
     return this.rc;
   }
 
-  public AbstractExecution withRoutingObjects(Set<Object> routingObjects) {
-    if (routingObjects == null) {
-      throw new FunctionException(
-          LocalizedStrings.FunctionService_ROUTING_OBJECTS_SET_IS_NULL
-              .toLocalizedString());
-    }
-    this.filter.clear();
-    this.filter.addAll(routingObjects);
-    this.hasRoutingObjects = true;
-    return this;
-  }
-
   public Set getFilter() {
     return this.filter;
   }
 
-  public boolean hasRoutingObjects() {
-    return this.hasRoutingObjects;
-  }
-
   public AbstractExecution setIsReExecute() {
     this.isReExecute = true;
     if (this.executionNodesListener != null) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionStreamingResultCollector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionStreamingResultCollector.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionStreamingResultCollector.java
index 3874ad9..7ed908e 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionStreamingResultCollector.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionStreamingResultCollector.java
@@ -96,8 +96,7 @@ public class FunctionStreamingResultCollector extends ReplyProcessor21 implement
     this.execution = execution;
     this.fites = Collections.synchronizedList(new ArrayList<FunctionInvocationTargetException>());
     // add a reference to self inside the ResultCollector, if required, to avoid
-    // this ReplyProcessor21 from being GCed; currently is of use for SQLFabric
-    // result collectors to properly implement streaming
+    // this ReplyProcessor21 from being GCed
     if (rc instanceof LocalResultCollector<?, ?>) {
       ((LocalResultCollector<?, ?>)rc).setProcessor(this);
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
index 5ffd72d..81944ef 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.cache.execute.FunctionService;
 import com.gemstone.gemfire.cache.execute.ResultCollector;
 
 /**
- * Internal interface for SQLFabric. It has internal methods specific for SQLFabric
+ * Internal interface that adds some internal methods to the Execution interface.
  * 
  * @since GemFire 5.8LA
  * 
@@ -36,31 +36,6 @@ public interface InternalExecution extends Execution {
       MemberMappedArgument argument); 
 
   /**
-   * Specifies a data filter of routing objects for selecting the GemFire
-   * members to execute the function that are not GemFire keys rather routing
-   * objects as determined by resolver. Currently used by SQL fabric for passing
-   * routing objects obtained from the custom resolvers.
-   * <p>
-   * If the set is empty the function is executed on all members that have the
-   * {@linkplain FunctionService#onRegion(com.gemstone.gemfire.cache.Region)
-   * region defined}.
-   * </p>
-   * 
-   * @param routingObjects
-   *          Set defining the routing objects to be used for executing the
-   *          function.
-   * 
-   * @return an Execution with the routing objects
-   * 
-   * @throws IllegalArgumentException
-   *           if the set of routing objects passed is null.
-   * @throws UnsupportedOperationException
-   *           if not called after
-   *           {@link FunctionService#onRegion(com.gemstone.gemfire.cache.Region)}
-   */
-  public InternalExecution withRoutingObjects(Set<Object> routingObjects);
-  
-  /**
    * Specifies a  filter of bucketIDs for selecting the GemFire
    * members to execute the function on.
    * <p>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
index 54e03c7..f0ed757 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
@@ -31,7 +31,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 
 /**
  * 
- * Provides internal methods for sqlFabric product
+ * Provides internal methods for tests
  * 
  * 
  * @since GemFire 6.1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalRegionFunctionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalRegionFunctionContext.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalRegionFunctionContext.java
index 2234925..90ad79c 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalRegionFunctionContext.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalRegionFunctionContext.java
@@ -30,11 +30,6 @@ import com.gemstone.gemfire.internal.cache.LocalDataSet;
 /**
  * Internal interface used to provide for some essential functionality for
  * {@link RegionFunctionContext} invoked by {@link PartitionRegionHelper}.
- * SQLFabric provides its own implementation when using function messages
- * instead of {@link Function}s so {@link PartitionRegionHelper} should not
- * depend on casting to {@link RegionFunctionContextImpl} directly rather should
- * use this interface.
- * 
  */
 public interface InternalRegionFunctionContext extends RegionFunctionContext {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutor.java
index ac628a0..3912245 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutor.java
@@ -239,13 +239,6 @@ public class MemberFunctionExecutor extends AbstractExecution {
             .toLocalizedString("bucket as filter"));
   }
 
-  @Override
-  public AbstractExecution withRoutingObjects(Set<Object> routingObjects) {
-    throw new FunctionException(
-        LocalizedStrings.ExecuteFunction_CANNOT_SPECIFY_0_FOR_DATA_INDEPENDENT_FUNCTIONS
-            .toLocalizedString("routing objects"));
-  }
-
   public InternalExecution withMemberMappedArgument(
       MemberMappedArgument argument) {
     if(argument == null){

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutor.java
index 1929169..a9f933a 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutor.java
@@ -182,13 +182,6 @@ public class MultiRegionFunctionExecutor extends AbstractExecution {
   }
 
   @Override
-  public AbstractExecution withRoutingObjects(Set<Object> routingObjects) {
-    throw new FunctionException(
-        LocalizedStrings.ExecuteFunction_CANNOT_SPECIFY_0_FOR_ONREGIONS_FUNCTION
-            .toLocalizedString("routing objects"));
-  }
-
-  @Override
   protected ResultCollector executeFunction(Function function) {
     if (function.hasResult()) {
       ResultCollector rc = this.rc;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/RegionFunctionContextImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/RegionFunctionContextImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/RegionFunctionContextImpl.java
index 15d39c9..302b24e 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/RegionFunctionContextImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/RegionFunctionContextImpl.java
@@ -26,9 +26,7 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.execute.Execution;
 import com.gemstone.gemfire.cache.execute.FunctionService;
 import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.LocalDataSet;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
 
 /**
  * Context available to data dependent functions. When function is executed
@@ -67,17 +65,6 @@ public class RegionFunctionContextImpl extends FunctionContextImpl implements
     this.localBucketSet = localBucketSet;
     this.isPossibleDuplicate = isPossibleDuplicate;
     setFunctionContexts();
-    // set the region context for keys if required
-    if (routingObjects != null) {
-      final LocalRegion r = (LocalRegion)this.dataSet;
-      if (r.keyRequiresRegionContext()) {
-        for (Object key : routingObjects) {
-          if (key instanceof KeyWithRegionContext) {
-            ((KeyWithRegionContext)key).setRegionContext(r);
-          }
-        }
-      }
-    }
   }
 
   private void setFunctionContexts() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
index 9c06bf6..d821b32 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
@@ -266,13 +266,6 @@ public class ServerFunctionExecutor extends AbstractExecution {
             .toLocalizedString("buckets as filter"));
   }
 
-  @Override
-  public AbstractExecution withRoutingObjects(Set<Object> routingObjects) {
-    throw new FunctionException(
-        LocalizedStrings.ExecuteFunction_CANNOT_SPECIFY_0_FOR_DATA_INDEPENDENT_FUNCTIONS
-            .toLocalizedString("routing objects"));
-  }
-
   public Execution withArgs(Object args) {
     if (args == null) {
       throw new FunctionException(

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/ContainsKeyValueMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/ContainsKeyValueMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/ContainsKeyValueMessage.java
index f3f534a..ffdfde0 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/ContainsKeyValueMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/ContainsKeyValueMessage.java
@@ -38,7 +38,6 @@ import com.gemstone.gemfire.distributed.internal.ReplySender;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.Assert;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.PrimaryBucketException;
@@ -125,9 +124,6 @@ public final class ContainsKeyValueMessage extends PartitionMessageWithDirectRep
     final boolean replyVal;
     if (ds != null) {
       try {
-        if (r.keyRequiresRegionContext()) {
-          ((KeyWithRegionContext)this.key).setRegionContext(r);
-        }
         if (this.valueCheck) {
           replyVal = ds.containsValueForKeyLocally(this.bucketId, this.key);
         } else {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/DestroyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/DestroyMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/DestroyMessage.java
index 2700c61..3bd32cc 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/DestroyMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/DestroyMessage.java
@@ -48,7 +48,6 @@ import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.FilterRoutingInfo;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
@@ -253,9 +252,6 @@ public class DestroyMessage extends PartitionMessageWithDirectReply {
     }
     @Released EntryEventImpl event = null;
     try {
-    if (r.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext)this.key).setRegionContext(r);
-    }
     if (this.bridgeContext != null) {
       event = EntryEventImpl.create(r, getOperation(), this.key, null/*newValue*/,
           getCallbackArg(), false/*originRemote*/, eventSender, 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchBulkEntriesMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchBulkEntriesMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchBulkEntriesMessage.java
index 8a6563b..efd0bea 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchBulkEntriesMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchBulkEntriesMessage.java
@@ -52,7 +52,6 @@ import com.gemstone.gemfire.internal.cache.BucketRegion;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.VersionTagHolder;
@@ -523,8 +522,6 @@ public final class FetchBulkEntriesMessage extends PartitionMessage
         try {
           ByteArrayInputStream byteStream = new ByteArrayInputStream(msg.chunk);
           DataInputStream in = new DataInputStream(byteStream);
-          final boolean requiresRegionContext = this.pr
-              .keyRequiresRegionContext();
           Object key;
           int currentId;
 
@@ -538,9 +535,6 @@ public final class FetchBulkEntriesMessage extends PartitionMessage
               deserializingKey = true;
               key = DataSerializer.readObject(in);
               if (key != null) {
-                if (requiresRegionContext) {
-                  ((KeyWithRegionContext) key).setRegionContext(this.pr);
-                }
                 deserializingKey = false;
                 Object value = DataSerializer.readObject(in);
                 VersionTag versionTag = DataSerializer.readObject(in);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessage.java
index d7a3a5f..a18837a 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessage.java
@@ -51,7 +51,6 @@ import com.gemstone.gemfire.internal.cache.BucketRegion;
 import com.gemstone.gemfire.internal.cache.CachedDeserializable;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
@@ -542,17 +541,12 @@ public final class FetchEntriesMessage extends PartitionMessage
         try {
           ByteArrayInputStream byteStream = new ByteArrayInputStream(msg.chunk);
           DataInputStream in = new DataInputStream(byteStream);
-          final boolean requiresRegionContext = this.pr
-              .keyRequiresRegionContext();
           Object key;
           
           while (in.available() > 0) {
             deserializingKey = true;
             key = DataSerializer.readObject(in);
             if (key != null) {
-              if (requiresRegionContext) {
-                ((KeyWithRegionContext)key).setRegionContext(this.pr);
-              }
               deserializingKey = false;
               Object value = DataSerializer.readObject(in);
               VersionTag versionTag = DataSerializer.readObject(in);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntryMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntryMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntryMessage.java
index fafb546..82f9efb 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntryMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntryMessage.java
@@ -46,7 +46,6 @@ import com.gemstone.gemfire.internal.cache.DataLocationException;
 import com.gemstone.gemfire.internal.cache.EntrySnapshot;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.KeyInfo;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.PrimaryBucketException;
@@ -146,9 +145,6 @@ public final class FetchEntryMessage extends PartitionMessage
     EntrySnapshot val;
     if (ds != null) {
       try {
-        if (r.keyRequiresRegionContext()) {
-          ((KeyWithRegionContext)this.key).setRegionContext(r);
-        }
         KeyInfo keyInfo = r.getKeyInfo(key);
         val = (EntrySnapshot)r.getDataView().getEntryOnRemote(keyInfo, r, true);
         r.getPrStats().endPartitionMessagesProcessing(startTime); 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchKeysMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchKeysMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchKeysMessage.java
index 3faf1da..6714271 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchKeysMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/FetchKeysMessage.java
@@ -44,7 +44,6 @@ import com.gemstone.gemfire.internal.HeapDataOutputStream;
 import com.gemstone.gemfire.internal.Version;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.tier.InterestType;
@@ -495,14 +494,9 @@ public final class FetchKeysMessage extends PartitionMessage
         try {
           ByteArrayInputStream byteStream = new ByteArrayInputStream(msg.chunk);
           DataInputStream in = new DataInputStream(byteStream);
-          final boolean requiresRegionContext = this.pr
-              .keyRequiresRegionContext();
           while (in.available() > 0) {
             Object key = DataSerializer.readObject(in);
             if (key != null) {
-              if (requiresRegionContext) {
-                ((KeyWithRegionContext)key).setRegionContext(this.pr);
-              }
               synchronized(returnValue) {
                 returnValue.add(key);
               }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/GetMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/GetMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/GetMessage.java
index e903def..a0d4f63 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/GetMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/GetMessage.java
@@ -29,6 +29,18 @@ import com.gemstone.gemfire.internal.InternalDataSerializer;
 import com.gemstone.gemfire.internal.Version;
 import com.gemstone.gemfire.internal.cache.*;
 import com.gemstone.gemfire.internal.cache.BucketRegion.RawValue;
+import com.gemstone.gemfire.internal.cache.CachedDeserializableFactory;
+import com.gemstone.gemfire.internal.cache.DataLocationException;
+import com.gemstone.gemfire.internal.cache.EntryEventImpl;
+import com.gemstone.gemfire.internal.cache.ForceReattemptException;
+import com.gemstone.gemfire.internal.cache.KeyInfo;
+import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
+import com.gemstone.gemfire.internal.cache.PrimaryBucketException;
+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.VersionTagHolder;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
@@ -159,9 +171,6 @@ public final class GetMessage extends PartitionMessageWithDirectReply
     if (ds != null) {
       VersionTagHolder event = new VersionTagHolder();
       try {
-        if (r.keyRequiresRegionContext()) {
-          ((KeyWithRegionContext)this.key).setRegionContext(r);
-        }
         KeyInfo keyInfo = r.getKeyInfo(key, cbArg);
         boolean lockEntry = forceUseOfPRExecutor || isDirectAck();
         
@@ -325,7 +334,6 @@ public final class GetMessage extends PartitionMessageWithDirectReply
     // static values for valueType
     static final byte VALUE_IS_SERIALIZED_OBJECT = 0;
     static final byte VALUE_IS_BYTES = 1;
-    /** came from partial SQLF merge and reconciling with it but not used yet */
     //static final byte VALUE_IS_OBJECT = 2;
     static final byte VALUE_IS_INVALID = 3;
     static final byte VALUE_IS_TOMBSTONE = 4;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/InvalidateMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/InvalidateMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/InvalidateMessage.java
index 6f86acd..bbb9753 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/InvalidateMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/InvalidateMessage.java
@@ -45,7 +45,6 @@ import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
 import com.gemstone.gemfire.internal.cache.FilterRoutingInfo;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
@@ -177,9 +176,6 @@ public final class InvalidateMessage extends DestroyMessage {
        eventSender = getSender();
     }
     final Object key = getKey();
-    if (r.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext)key).setRegionContext(r);
-    }
     @Released final EntryEventImpl event = EntryEventImpl.create(
         r,
         getOperation(),

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PREntriesIterator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PREntriesIterator.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PREntriesIterator.java
index ec2a8db..94a3670 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PREntriesIterator.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PREntriesIterator.java
@@ -22,11 +22,9 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 
 
 /**
- * This interface is implemented by the iterators
- * GemFireContainer.PRLocalEntriesIterator,
- * PartitionedRegion.PRLocalBucketSetEntriesIterator and
- * PartitionedRegion.KeysSetIterator used by SqlFabric to obtain information of
- * the bucket ID from which the current local entry is being fetched from.
+ * This interface provides the
+ * bucket ID from which the current local entry is being fetched from
+ * and the PartitionedRegion being iterated.
  * 
  */
 public interface PREntriesIterator<T> extends Iterator<T>{

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PRUpdateEntryVersionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PRUpdateEntryVersionMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PRUpdateEntryVersionMessage.java
index e1766dc..726246b 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PRUpdateEntryVersionMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PRUpdateEntryVersionMessage.java
@@ -42,7 +42,6 @@ import com.gemstone.gemfire.internal.cache.DataLocationException;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
@@ -126,10 +125,6 @@ public class PRUpdateEntryVersionMessage extends
   protected boolean operateOnPartitionedRegion(DistributionManager dm,
       PartitionedRegion pr, long startTime) throws CacheException,
       QueryException, DataLocationException, InterruptedException, IOException {
-    if (pr.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext) key).setRegionContext(pr);
-    }
-
     // release not needed because disallowOffHeapValues called
     final EntryEventImpl event = EntryEventImpl.create(pr, getOperation(),
         getKey(), null, /* newValue */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
index c2ab27e..1b83ee3 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage.java
@@ -468,10 +468,6 @@ public abstract class PartitionMessage extends DistributionMessage implements
     this.processorId = processor == null? 0 : processor.getProcessorId();
     this.notificationOnly = true;
         
-    //Set sqlfAsyncListenerRecepients = r.getRegionAdvisor().adviseSqlfAsyncEventListenerHub();
-    //sqlfAsyncListenerRecepients.retainAll(adjunctRecipients);
-    //Now remove those adjunct recepients which are present in SqlfAsyncListenerRecepients
-    //adjunctRecipients.removeAll(sqlfAsyncListenerRecepients);
     this.setFilterInfo(filterRoutingInfo);
     Set failures1= null;
     if(!adjunctRecipients.isEmpty()) {
@@ -482,20 +478,6 @@ public abstract class PartitionMessage extends DistributionMessage implements
       setRecipients(adjunctRecipients);
       failures1 = r.getDistributionManager().putOutgoing(this);
     }
-    /*
-    //Now distribute message with old value to Sqlf Hub nodes
-    if(!sqlfAsyncListenerRecepients.isEmpty()) {
-      //System.out.println("Asif1: sqlf hub  recepients ="+sqlfHubRecepients);
-      resetRecipients();
-      setRecipients(sqlfAsyncListenerRecepients);
-      event.applyDelta(true);
-      Set failures2 = r.getDistributionManager().putOutgoing(this);
-      if(failures1 == null) {
-        failures1 = failures2;
-      }else if(failures2 != null) {
-        failures1.addAll(failures2);
-      }
-    }*/
     
     return failures1;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage.java
index 7bbe5ce..f7c63f9 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage.java
@@ -59,7 +59,6 @@ import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
@@ -101,8 +100,6 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
 
   protected static final short HAS_BRIDGE_CONTEXT = UNRESERVED_FLAGS_START;
   protected static final short SKIP_CALLBACKS = (HAS_BRIDGE_CONTEXT << 1);
-  //using the left most bit for IS_PUT_DML, the last available bit
-  protected static final short IS_PUT_DML = (short) (SKIP_CALLBACKS << 1);
 
   private transient InternalDistributedSystem internalDs;
 
@@ -117,7 +114,6 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
   
   transient VersionedObjectList versions = null;
 
-  private boolean isPutDML;
   /**
    * Empty constructor to satisfy {@link DataSerializer}requirements
    */
@@ -125,7 +121,7 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
   }
 
   public PutAllPRMessage(int bucketId, int size, boolean notificationOnly,
-      boolean posDup, boolean skipCallbacks, Object callbackArg, boolean isPutDML) {
+      boolean posDup, boolean skipCallbacks, Object callbackArg) {
     this.bucketId = Integer.valueOf(bucketId);
     putAllPRData = new PutAllEntryData[size];
     this.notificationOnly = notificationOnly;
@@ -133,7 +129,6 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
     this.skipCallbacks = skipCallbacks;
     this.callbackArg = callbackArg;
     initTxMemberId();
-    this.isPutDML = isPutDML;
   }
 
   public void addEntry(PutAllEntryData entry) {
@@ -270,10 +265,6 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
       EntryVersionsList versionTags = new EntryVersionsList(putAllPRDataSize);
 
       boolean hasTags = false;
-      // get the "keyRequiresRegionContext" flag from first element assuming
-      // all key objects to be uniform
-      final boolean requiresRegionContext =
-        (this.putAllPRData[0].getKey() instanceof KeyWithRegionContext);
       for (int i = 0; i < this.putAllPRDataSize; i++) {
         // If sender's version is >= 7.0.1 then we can send versions list.
         if (!hasTags && putAllPRData[i].versionTag != null) {
@@ -283,7 +274,7 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
         VersionTag<?> tag = putAllPRData[i].versionTag;
         versionTags.add(tag);
         putAllPRData[i].versionTag = null;
-        putAllPRData[i].toData(out, requiresRegionContext);
+        putAllPRData[i].toData(out);
         putAllPRData[i].versionTag = tag;
         // PutAllEntryData's toData did not serialize eventID to save
         // performance for DR, but in PR,
@@ -302,7 +293,6 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
     s = super.computeCompressedShort(s);
     if (this.bridgeContext != null) s |= HAS_BRIDGE_CONTEXT;
     if (this.skipCallbacks) s |= SKIP_CALLBACKS;
-    if (this.isPutDML) s |= IS_PUT_DML;
     return s;
   }
 
@@ -311,7 +301,6 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
       ClassNotFoundException {
     super.setBooleans(s, in);
     this.skipCallbacks = ((s & SKIP_CALLBACKS) != 0);
-    this.isPutDML = ((s & IS_PUT_DML) != 0);
   }
 
   @Override
@@ -436,12 +425,8 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
     // Fix the updateMsg misorder issue
     // Lock the keys when doing postPutAll
     Object keys[] = new Object[putAllPRDataSize];
-    final boolean keyRequiresRegionContext = r.keyRequiresRegionContext();
     for (int i = 0; i < putAllPRDataSize; ++i) {
       keys[i] = putAllPRData[i].getKey();
-      if (keyRequiresRegionContext) {
-        ((KeyWithRegionContext)keys[i]).setRegionContext(r);
-      }
     }
 
     if (!notificationOnly) {
@@ -482,7 +467,7 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
            * in this request, because these request will be blocked by foundKey
            */
           for (int i=0; i<putAllPRDataSize; i++) {
-            @Released EntryEventImpl ev = getEventFromEntry(r, myId, eventSender, i,putAllPRData,notificationOnly,bridgeContext,posDup,skipCallbacks, this.isPutDML);
+            @Released EntryEventImpl ev = getEventFromEntry(r, myId, eventSender, i,putAllPRData,notificationOnly,bridgeContext,posDup,skipCallbacks);
             try {
             key = ev.getKey();
 
@@ -558,7 +543,7 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
       }
     } else {
       for (int i=0; i<putAllPRDataSize; i++) {
-        EntryEventImpl ev = getEventFromEntry(r, myId, eventSender, i,putAllPRData,notificationOnly,bridgeContext,posDup,skipCallbacks, this.isPutDML);
+        EntryEventImpl ev = getEventFromEntry(r, myId, eventSender, i,putAllPRData,notificationOnly,bridgeContext,posDup,skipCallbacks);
         try {
         ev.setOriginRemote(true);
         if (this.callbackArg != null) {
@@ -594,7 +579,7 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
       InternalDistributedMember myId, InternalDistributedMember eventSender,
       int idx, DistributedPutAllOperation.PutAllEntryData[] data,
       boolean notificationOnly, ClientProxyMembershipID bridgeContext,
-      boolean posDup, boolean skipCallbacks, boolean isPutDML) {
+      boolean posDup, boolean skipCallbacks) {
     PutAllEntryData prd = data[idx];
     //EntryEventImpl ev = EntryEventImpl.create(r, 
        // prd.getOp(),
@@ -633,7 +618,6 @@ public final class PutAllPRMessage extends PartitionMessageWithDirectReply
     } else {
       ev.setTailKey(prd.getTailKey());
     }
-    ev.setPutDML(isPutDML);
     evReturned = true;
     return ev;
     } finally {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutMessage.java
index db137c6..e63d288 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/PutMessage.java
@@ -56,7 +56,6 @@ import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.FilterRoutingInfo;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.PrimaryBucketException;
@@ -119,8 +118,7 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
   
   /**
    * Indicates if and when the new value should be deserialized on the
-   * the receiver. Distinguishes between Deltas which need to be eagerly
-   * deserialized (DESERIALIZATION_POLICY_EAGER), a non-byte[] value that was
+   * the receiver. Distinguishes between a non-byte[] value that was
    * serialized (DESERIALIZATION_POLICY_LAZY) and a
    * byte[] array value that didn't need to be serialized
    * (DESERIALIZATION_POLICY_NONE). While this seems like an extra data, it
@@ -182,15 +180,11 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
 
   private VersionTag versionTag;
 
-  private transient boolean isPutDML;
-  
   // additional bitmask flags used for serialization/deserialization
 
   protected static final short CACHE_WRITE = UNRESERVED_FLAGS_START;
   protected static final short HAS_EXPECTED_OLD_VAL = (CACHE_WRITE << 1);
   protected static final short HAS_VERSION_TAG = (HAS_EXPECTED_OLD_VAL << 1);
-  //using the left most bit for IS_PUT_DML, the last available bit
-  protected static final short IS_PUT_DML = (short) (HAS_VERSION_TAG << 1);
 
   // extraFlags
   protected static final int HAS_BRIDGE_CONTEXT =
@@ -349,11 +343,7 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
     this.expectedOldValue = expectedOldValue;
     this.key = event.getKey();
     if (event.hasNewValue()) {
-      if (CachedDeserializableFactory.preferObject() || event.hasDelta()) {
-        this.deserializationPolicy = DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER;
-      } else {
-        this.deserializationPolicy = DistributedCacheOperation.DESERIALIZATION_POLICY_LAZY;
-      }
+      this.deserializationPolicy = DistributedCacheOperation.DESERIALIZATION_POLICY_LAZY;
       event.exportNewValue(this);
     }
     else {
@@ -627,14 +617,7 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
       this.deltaBytes = DataSerializer.readByteArray(in);
     }
     else {
-      // for eager deserialization avoid extra byte array serialization
-      if (this.deserializationPolicy ==
-          DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER) {
-        setValObj(DataSerializer.readObject(in));
-      }
-      else {
-        setValBytes(DataSerializer.readByteArray(in));
-      }
+      setValBytes(DataSerializer.readByteArray(in));
       if ((extraFlags & HAS_DELTA_WITH_FULL_VALUE) != 0) {
         this.deltaBytes = DataSerializer.readByteArray(in);
       }
@@ -642,10 +625,6 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
     if ((flags & HAS_VERSION_TAG) != 0) {
       this.versionTag =  DataSerializer.readObject(in);
     }
-    if ((flags & IS_PUT_DML) != 0) {
-      this.isPutDML = true;
-    }
-    
   }
   
   @Override
@@ -752,7 +731,6 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
       }
     }
     if (this.versionTag != null) s |= HAS_VERSION_TAG;
-    if (this.event.isPutDML()) s |= IS_PUT_DML;
     return s;
   }
 
@@ -788,9 +766,6 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
     if (eventSender == null) {
        eventSender = getSender();
     }
-    if (r.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext)this.key).setRegionContext(r);
-    }
     @Released final EntryEventImpl ev = EntryEventImpl.create(
         r,
         getOperation(),
@@ -814,7 +789,6 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
     ev.setCausedByMessage(this);
     ev.setInvokePRCallbacks(!notificationOnly);
     ev.setPossibleDuplicate(this.posDup);
-    ev.setPutDML(this.isPutDML);
     /*if (this.hasOldValue) {
       if (this.oldValueIsSerialized) {
         ev.setSerializedOldValue(getOldValueBytes());
@@ -839,10 +813,6 @@ public final class PutMessage extends PartitionMessageWithDirectReply implements
         case DistributedCacheOperation.DESERIALIZATION_POLICY_NONE:
           ev.setNewValue(getValBytes());
           break;
-        case DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER:
-          // new value is a Delta
-          ev.setNewValue(this.valObj); // sets the delta field
-          break;
         default:
           throw new AssertionError("unknown deserialization policy: "
               + deserializationPolicy);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RegionAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RegionAdvisor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RegionAdvisor.java
index 176a41a..a5b4d71 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RegionAdvisor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RegionAdvisor.java
@@ -1157,23 +1157,6 @@ public class RegionAdvisor extends CacheDistributionAdvisor
     return result;
   }
 
-  // For SQLFabric ALTER TABLE, need to reset the parentAdvisors if colocated
-  // region changes
-  public void resetBucketAdvisorParents() {
-    if (this.buckets != null) {
-      for (ProxyBucketRegion pbr : this.buckets) {
-        if (pbr.getCreatedBucketRegion() != null) {
-          throw new InternalGemFireException(
-              LocalizedStrings.RegionAdvisor_CANNOT_RESET_EXISTING_BUCKET
-                  .toLocalizedString(new Object[] {
-                      pbr.getPartitionedRegion().getFullPath(),
-                      pbr.getBucketId() }));
-        }
-        pbr.getBucketAdvisor().resetParentAdvisor(pbr.getBucketId());
-      }
-    }
-  }
-
   /**
    * Returns the bucket identified by bucketId after waiting for initialization
    * to finish processing queued profiles. Call synchronizes and waits on 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoteFetchKeysMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoteFetchKeysMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoteFetchKeysMessage.java
index ac95e03..bea08fc 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoteFetchKeysMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoteFetchKeysMessage.java
@@ -49,7 +49,6 @@ import com.gemstone.gemfire.internal.Assert;
 import com.gemstone.gemfire.internal.HeapDataOutputStream;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.RemoteOperationException;
@@ -421,14 +420,9 @@ public class RemoteFetchKeysMessage extends RemoteOperationMessage {
         
         ByteArrayInputStream byteStream = new ByteArrayInputStream(msg.chunk);
         DataInputStream in = new DataInputStream(byteStream);
-        final boolean requiresRegionContext = this.region
-            .keyRequiresRegionContext();
         while (in.available() > 0) {
           Object key = DataSerializer.readObject(in);
           if (key != null) {
-            if (requiresRegionContext) {
-              ((KeyWithRegionContext)key).setRegionContext(this.region);
-            }
             synchronized(returnValue) {
               returnValue.add(key);
             }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage.java
index 125cdb0..5c9e799 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage.java
@@ -59,7 +59,6 @@ import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
@@ -260,10 +259,6 @@ public final class RemoveAllPRMessage extends PartitionMessageWithDirectReply
       EntryVersionsList versionTags = new EntryVersionsList(removeAllPRDataSize);
 
       boolean hasTags = false;
-      // get the "keyRequiresRegionContext" flag from first element assuming
-      // all key objects to be uniform
-      final boolean requiresRegionContext =
-        (this.removeAllPRData[0].getKey() instanceof KeyWithRegionContext);
       for (int i = 0; i < this.removeAllPRDataSize; i++) {
         // If sender's version is >= 7.0.1 then we can send versions list.
         if (!hasTags && removeAllPRData[i].versionTag != null) {
@@ -273,7 +268,7 @@ public final class RemoveAllPRMessage extends PartitionMessageWithDirectReply
         VersionTag<?> tag = removeAllPRData[i].versionTag;
         versionTags.add(tag);
         removeAllPRData[i].versionTag = null;
-        removeAllPRData[i].toData(out, requiresRegionContext);
+        removeAllPRData[i].toData(out);
         removeAllPRData[i].versionTag = tag;
         // RemoveAllEntryData's toData did not serialize eventID to save
         // performance for DR, but in PR,
@@ -423,12 +418,8 @@ public final class RemoveAllPRMessage extends PartitionMessageWithDirectReply
     // Fix the updateMsg misorder issue
     // Lock the keys when doing postRemoveAll
     Object keys[] = new Object[removeAllPRDataSize];
-    final boolean keyRequiresRegionContext = r.keyRequiresRegionContext();
     for (int i = 0; i < removeAllPRDataSize; ++i) {
       keys[i] = removeAllPRData[i].getKey();
-      if (keyRequiresRegionContext) {
-        ((KeyWithRegionContext)keys[i]).setRegionContext(r);
-      }
     }
 
     if (!notificationOnly) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
index 6111561..44647b5 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
@@ -243,8 +243,7 @@ public class PartitionedRegionLoadModel {
         // [sumedh] remove from buckets array too to be consistent since
         // this method will be invoked repeatedly for all colocated regions,
         // and then we may miss some colocated regions for a bucket leading
-        // to all kinds of issues later (e.g. see SQLF test for #41472 that
-        //   shows some problems including NPEs, hangs etc.)
+        // to all kinds of issues later
         this.buckets[i] = null;
         continue;
       }
@@ -555,22 +554,12 @@ public class PartitionedRegionLoadModel {
   public Move findBestPrimaryMove() {
     Move bestMove= null;
     double bestImprovement = 0;
-    GemFireCacheImpl cache = null;
     for(Member source: this.members.values()) {
       for(Bucket bucket: source.getPrimaryBuckets()) {
         for(Member target: bucket.getMembersHosting()) {
           if(source.equals(target)) {
             continue;
           }
-          // If node is not fully initialized yet, then skip this node
-          // (SQLFabric DDL replay in progress).
-          if (cache == null) {
-            cache = GemFireCacheImpl.getInstance();
-          }
-          if (cache != null
-              && cache.isUnInitializedMember(target.getMemberId())) {
-            continue;
-          }
           double improvement = improvement(source.getPrimaryLoad(), source
               .getWeight(), target.getPrimaryLoad(), target.getWeight(), bucket.getPrimaryLoad(),
               getPrimaryAverage());
@@ -1211,12 +1200,6 @@ public class PartitionedRegionLoadModel {
       if(getBuckets().contains(bucket)) {
         return RefusalReason.ALREADY_HOSTING;
       }
-      // If node is not fully initialized yet, then skip this node (SQLFabric
-      // DDL replay in progress).
-      final GemFireCacheImpl cache = GemFireCacheImpl.getInstance();
-      if (cache != null && cache.isUnInitializedMember(getMemberId())) {
-        return RefusalReason.UNITIALIZED_MEMBER;
-      }
       //Check the ip address
       if(checkZone) {
         //If the source member is equivalent to the target member, go

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/GatewayReceiverCommand.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/GatewayReceiverCommand.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/GatewayReceiverCommand.java
index 448be92..e3a3d53 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/GatewayReceiverCommand.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/GatewayReceiverCommand.java
@@ -39,7 +39,6 @@ import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.EventIDHolder;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.KeyWithRegionContext;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.tier.CachedRegionHelper;
 import com.gemstone.gemfire.internal.cache.tier.Command;
@@ -320,9 +319,6 @@ public class GatewayReceiverCommand extends BaseCommand {
             try {
               byte[] value = valuePart.getSerializedForm();
               boolean isObject = valuePart.isObject();
-              if (region.keyRequiresRegionContext()) {
-                ((KeyWithRegionContext)key).setRegionContext(region);
-              }
               // [sumedh] This should be done on client while sending
               // since that is the WAN gateway
               AuthorizeRequest authzRequest = servConn.getAuthzRequest();
@@ -428,9 +424,6 @@ public class GatewayReceiverCommand extends BaseCommand {
             try {
               byte[] value = valuePart.getSerializedForm();
               boolean isObject = valuePart.isObject();
-              if (region.keyRequiresRegionContext()) {
-                ((KeyWithRegionContext)key).setRegionContext(region);
-              }
               AuthorizeRequest authzRequest = servConn.getAuthzRequest();
               if (authzRequest != null) {
                 PutOperationContext putContext = authzRequest.putAuthorize(
@@ -523,9 +516,6 @@ public class GatewayReceiverCommand extends BaseCommand {
             }
             handleMessageRetry(region, clientEvent);
             // Destroy the entry
-            if (region.keyRequiresRegionContext()) {
-              ((KeyWithRegionContext)key).setRegionContext(region);
-            }
             try {
               AuthorizeRequest authzRequest = servConn.getAuthzRequest();
               if (authzRequest != null) {
@@ -606,9 +596,6 @@ public class GatewayReceiverCommand extends BaseCommand {
               }
               
               // Update the version tag
-              if (region.keyRequiresRegionContext()) {
-                ((KeyWithRegionContext) key).setRegionContext(region);
-              }
               try {
 
                 region.basicBridgeUpdateVersionStamp(key, callbackArg, servConn.getProxyID(), false, clientEvent);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tx/DistTxEntryEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tx/DistTxEntryEvent.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tx/DistTxEntryEvent.java
index 6e7c21c..c84fb99 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tx/DistTxEntryEvent.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/tx/DistTxEntryEvent.java
@@ -138,12 +138,7 @@ public class DistTxEntryEvent extends EntryEventImpl {
     EntryVersionsList versionTags = new EntryVersionsList(
         this.putAllOp.putAllDataSize);
     boolean hasTags = false;
-    // get the "keyRequiresRegionContext" flag from first element assuming
-    // all key objects to be uniform
     final PutAllEntryData[] putAllData = this.putAllOp.getPutAllEntryData();
-    // final boolean requiresRegionContext =
-    // (putAllData[0].key instanceof KeyWithRegionContext);
-    final boolean requiresRegionContext = false;
     for (int i = 0; i < this.putAllOp.putAllDataSize; i++) {
       if (!hasTags && putAllData[i].versionTag != null) {
         hasTags = true;
@@ -151,7 +146,7 @@ public class DistTxEntryEvent extends EntryEventImpl {
       VersionTag<?> tag = putAllData[i].versionTag;
       versionTags.add(tag);
       putAllData[i].versionTag = null;
-      putAllData[i].toData(out, requiresRegionContext);
+      putAllData[i].toData(out);
       putAllData[i].versionTag = tag;
     }
     out.writeBoolean(hasTags);
@@ -206,13 +201,8 @@ public class DistTxEntryEvent extends EntryEventImpl {
         this.removeAllOp.removeAllDataSize);
   
     boolean hasTags = false;
-    // get the "keyRequiresRegionContext" flag from first element assuming
-    // all key objects to be uniform
-    // final boolean requiresRegionContext =
-    // (this.removeAllData[0].key instanceof KeyWithRegionContext);
     final RemoveAllEntryData[] removeAllData = this.removeAllOp
         .getRemoveAllEntryData();
-    final boolean requiresRegionContext = false;
     for (int i = 0; i < this.removeAllOp.removeAllDataSize; i++) {
       if (!hasTags && removeAllData[i].versionTag != null) {
         hasTags = true;
@@ -220,7 +210,7 @@ public class DistTxEntryEvent extends EntryEventImpl {
       VersionTag<?> tag = removeAllData[i].versionTag;
       versionTags.add(tag);
       removeAllData[i].versionTag = null;
-      removeAllData[i].toData(out, requiresRegionContext);
+      removeAllData[i].toData(out);
       removeAllData[i].versionTag = tag;
     }
     out.writeBoolean(hasTags);



[11/17] incubator-geode git commit: GEODE-1464: remove sqlf code

Posted by kl...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
index f0836d4..55bdde4 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
@@ -23,7 +23,6 @@ import com.gemstone.gemfire.cache.Operation;
 import com.gemstone.gemfire.cache.RegionDestroyedException;
 import com.gemstone.gemfire.cache.query.internal.CqStateImpl;
 import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.cache.query.internal.cq.CqService;
 import com.gemstone.gemfire.cache.query.internal.cq.ServerCQ;
 import com.gemstone.gemfire.distributed.DistributedMember;
@@ -764,10 +763,6 @@ public class InitialImageOperation  {
       if (entryCount <= 1000 && isDebugEnabled) {
         keys = new HashSet();
       }
-      final boolean keyRequiresRegionContext = this.region
-          .keyRequiresRegionContext();
-      // get SQLF index manager for the case of recovery from disk
-      final IndexUpdater indexUpdater = this.region.getIndexUpdater();
       final ByteArrayDataInput in = new ByteArrayDataInput();
       for (int i = 0; i < entryCount; i++) {
         // stream is null-terminated
@@ -816,33 +811,7 @@ public class InitialImageOperation  {
         Object tmpValue = entry.value;
         byte[] tmpBytes = null;
 
-        if (keyRequiresRegionContext) {
-          final KeyWithRegionContext key = (KeyWithRegionContext)entry.key;
-          Object keyObject = tmpValue;
-          if (tmpValue != null) {
-            if (entry.isEagerDeserialize()) {
-              tmpValue = CachedDeserializableFactory.create(tmpValue,
-                  CachedDeserializableFactory.getArrayOfBytesSize(
-                      (byte[][])tmpValue, true));
-              entry.setSerialized(false);
-            }
-            else if (entry.isSerialized()) {
-              tmpBytes = (byte[])tmpValue;
-              // force deserialization for passing to key
-              keyObject = EntryEventImpl.deserialize(tmpBytes,
-                  remoteVersion, in);
-              tmpValue = CachedDeserializableFactory.create(keyObject,
-                  CachedDeserializableFactory.getByteSize(tmpBytes));
-              entry.setSerialized(false);
-            }
-            else {
-              tmpBytes = (byte[])tmpValue;
-            }
-          }
-          key.setRegionContext(this.region);
-          entry.key = key.afterDeserializationWithValue(keyObject);
-        }
-        else {
+        {
           if (tmpValue instanceof byte[]) {
             tmpBytes = (byte[])tmpValue;
           }
@@ -879,32 +848,6 @@ public class InitialImageOperation  {
                 //actually are equal, keep don't put the received
                 //entry into the cache (this avoids writing a record to disk)
                 if(entriesEqual) {
-                  // explicit SQLF index maintenance here since
-                  // it was not done during recovery from disk
-                  if (indexUpdater != null && !Token.isInvalidOrRemoved(tmpValue)) {
-                    boolean success = false;
-                    if (entry.isSerialized()) {
-                      tmpValue = CachedDeserializableFactory
-                          .create((byte[])tmpValue);
-                    }
-                    // dummy EntryEvent to pass for SQLF index maintenance
-                    @Released final EntryEventImpl ev = EntryEventImpl.create(this.region,
-                        Operation.CREATE, null, null, null, true, null, false, false);
-                    try {
-                    ev.setKeyInfo(this.region.getKeyInfo(entry.key,
-                        tmpValue, null));
-                    ev.setNewValue(tmpValue);
-                    try {
-                      indexUpdater.onEvent(this.region, ev, re);
-                      success = true;
-                    } finally {
-                      indexUpdater.postEvent(this.region, ev, re,
-                          success);
-                    }
-                    } finally {
-                      ev.release();
-                    }
-                  }
                   continue;
                 }
                 if (entry.isSerialized() && !Token.isInvalidOrRemoved(tmpValue)) {
@@ -1864,7 +1807,6 @@ public class InitialImageOperation  {
 
       List chunkEntries = null;
       chunkEntries = new InitialImageVersionedEntryList(rgn.concurrencyChecksEnabled, MAX_ENTRIES_PER_CHUNK);
-      final boolean keyRequiresRegionContext = rgn.keyRequiresRegionContext();
       DiskRegion dr = rgn.getDiskRegion();
       if( dr!=null ){
         dr.setClearCountReference();
@@ -1926,9 +1868,6 @@ public class InitialImageOperation  {
                     entry = new InitialImageOperation.Entry();
                     entry.key = key;
                     entry.setVersionTag(stamp.asVersionTag());
-                    if (keyRequiresRegionContext) {
-                      entry.setEagerDeserialize();
-                    }
                     fillRes = mapEntry.fillInValue(rgn, entry, in, rgn.getDistributionManager());
                     if (versionVector != null) {
                       if (logger.isTraceEnabled(LogMarker.GII)) {
@@ -1939,9 +1878,6 @@ public class InitialImageOperation  {
                 } else {
                   entry = new InitialImageOperation.Entry();
                   entry.key = key;
-                  if (keyRequiresRegionContext) {
-                    entry.setEagerDeserialize();
-                  }
                   fillRes = mapEntry.fillInValue(rgn, entry, in, rgn.getDistributionManager());
                 }
               }
@@ -1961,11 +1897,6 @@ public class InitialImageOperation  {
               entry.setLastModified(rgn.getDistributionManager(), mapEntry
                   .getLastModified());
             }
-            if (keyRequiresRegionContext) {
-              entry.key = ((KeyWithRegionContext)key)
-                  .beforeSerializationWithValue(entry.isInvalid()
-                      || entry.isLocalInvalid());
-            }
 
             chunkEntries.add(entry);
             currentChunkSize += entry.calcSerializedSize();
@@ -2952,18 +2883,6 @@ public class InitialImageOperation  {
       this.entryBits = EntryBits.setSerialized(this.entryBits, isSerialized);
     }
 
-    public boolean isEagerDeserialize() {
-      return EntryBits.isEagerDeserialize(this.entryBits);
-    }
-
-    void setEagerDeserialize() {
-      this.entryBits = EntryBits.setEagerDeserialize(this.entryBits);
-    }
-
-    void clearEagerDeserialize() {
-      this.entryBits = EntryBits.clearEagerDeserialize(this.entryBits);
-    }
-
     public boolean isInvalid() {
       return (this.value == null) && !EntryBits.isLocalInvalid(this.entryBits);
     }
@@ -3005,12 +2924,7 @@ public class InitialImageOperation  {
       out.writeByte(flags);
       DataSerializer.writeObject(this.key, out);
       if (!EntryBits.isTombstone(this.entryBits)) {
-        if (!isEagerDeserialize()) {
-          DataSerializer.writeObjectAsByteArray(this.value, out);
-        }
-        else {
-          DataSerializer.writeArrayOfByteArrays((byte[][])this.value, out);
-        }
+        DataSerializer.writeObjectAsByteArray(this.value, out);
       }
       out.writeLong(this.lastModified);
       if (this.versionTag != null) {
@@ -3030,11 +2944,7 @@ public class InitialImageOperation  {
       if (EntryBits.isTombstone(this.entryBits)) {
         this.value = Token.TOMBSTONE;
       } else {
-        if (!isEagerDeserialize()) {
-          this.value = DataSerializer.readByteArray(in);
-        } else {
-          this.value = DataSerializer.readArrayOfByteArrays(in);
-        }
+        this.value = DataSerializer.readByteArray(in);
       }
       this.lastModified = in.readLong();
       if ((flags & HAS_VERSION) != 0) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
index 3a254d5..c403231 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
@@ -22,7 +22,6 @@ import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.cache.LocalRegion.TestCallable;
 import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
@@ -58,8 +57,6 @@ public final class InternalRegionArguments
   private DiskRegion diskRegion;
   private PartitionedRegion partitionedRegion;
   private TestCallable testCallable;
-  private IndexUpdater indexUpdater;
-  private boolean keyRequiresRegionContext;
 
   private AbstractGatewaySender parallelGatewaySender;
   private AbstractGatewaySender serialGatewaySender;
@@ -233,25 +230,6 @@ public final class InternalRegionArguments
     return this.testCallable;
   }
 
-  // SQLFabric index manager
-  public IndexUpdater getIndexUpdater() {
-    return this.indexUpdater;
-  }
-
-  public InternalRegionArguments setIndexUpdater(IndexUpdater indexUpdater) {
-    this.indexUpdater = indexUpdater;
-    return this;
-  }
-
-  public boolean keyRequiresRegionContext() {
-    return this.keyRequiresRegionContext;
-  }
-
-  public InternalRegionArguments setKeyRequiresRegionContext(boolean v) {
-    this.keyRequiresRegionContext = v;
-    return this;
-  }
-
   public InternalRegionArguments setUserAttribute(Object userAttr) {
     this.userAttribute = userAttr;
     return this;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InvalidateOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InvalidateOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InvalidateOperation.java
index 6e1d91e..1742ad3 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InvalidateOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InvalidateOperation.java
@@ -112,9 +112,6 @@ public class InvalidateOperation extends DistributedCacheOperation
     @Retained
     protected InternalCacheEvent createEvent(DistributedRegion rgn)
         throws EntryNotFoundException {
-      if (rgn.keyRequiresRegionContext()) {
-        ((KeyWithRegionContext)this.key).setRegionContext(rgn);
-      }
       @Retained EntryEventImpl ev = EntryEventImpl.create(
          rgn, getOperation(), this.key,
          null, this.callbackArg, true, getSender());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyInfo.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyInfo.java
index 30f30fc..3065b47 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyInfo.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyInfo.java
@@ -40,9 +40,8 @@ public class KeyInfo {
   private Object callbackArg;
   private int bucketId;
 
-  // Rahul: The value field is add since Sqlf Partition resolver also relies on the value
-  // part to calculate the routing object if the table is not partitioned on 
-  // primary key.
+  // The value field is added since a Partition resolver could also rely on the value
+  // part to calculate the routing object
   @Retained(ENTRY_EVENT_NEW_VALUE)
   private final Object value;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyWithRegionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyWithRegionContext.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyWithRegionContext.java
deleted file mode 100644
index b28a551..0000000
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/KeyWithRegionContext.java
+++ /dev/null
@@ -1,70 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-
-/**
- * Interface that can be implemented by region keys to allow passing the region
- * after deserialization for any region specific initialization. Note that the
- * {@link LocalRegion#setKeyRequiresRegionContext(boolean)} should also be set
- * for {@link #setRegionContext(LocalRegion)} to be invoked by the GemFire
- * layer. It is required that either all keys of the region implement this
- * interface (and the flag
- * {@link LocalRegion#setKeyRequiresRegionContext(boolean)} is set) or none do.
- * 
- * Currently used by SQLFabric for the optimized
- * <code>CompactCompositeRegionKey</code> key implementations that keeps the key
- * as a reference to the raw row bytes and requires a handle of the table schema
- * to interpret those in hashCode/equals/compareTo methods that have no region
- * context information.
- * 
- */
-public interface KeyWithRegionContext extends DataSerializableFixedID {
-
-  /**
-   * Pass the region of the key for setting up of any region specific context
-   * for the key. In case of recovery from disk the region may not have been
-   * fully initialized yet, so the implementation needs to take that into
-   * consideration.
-   * 
-   * @param region
-   *          the region of this key
-   */
-  public void setRegionContext(LocalRegion region);
-
-  /**
-   * Changes required to be done to the key, if any, to optimize serialization
-   * for sending across when value is also available.
-   * 
-   * SQLFabric will make the value bytes as null in the key so as to avoid
-   * serializing the row twice.
-   */
-  public KeyWithRegionContext beforeSerializationWithValue(boolean valueIsToken);
-
-  /**
-   * Changes required to be done to the key, if any, to after deserializing the
-   * key in reply with value available. The value is required to be provided in
-   * deserialized format (e.g. for {@link CachedDeserializable}s the
-   * deserialized value being wrapped must be passed).
-   * 
-   * SQLFabric will restore the value bytes that were set as null in
-   * {@link #beforeSerializationWithValue}.
-   */
-  public KeyWithRegionContext afterDeserializationWithValue(Object val);
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ListOfDeltas.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ListOfDeltas.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ListOfDeltas.java
deleted file mode 100644
index 6592863..0000000
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ListOfDeltas.java
+++ /dev/null
@@ -1,100 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.gemstone.gemfire.internal.cache;
-
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.List;
-
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.delta.Delta;
-
-
-/**
- * 
- *
- */
-public final class ListOfDeltas implements Delta {
-
-  private  List<Delta> listOfDeltas;
-  transient private int deltaAppliedIndex = 0;
-  public ListOfDeltas(final int size) {
-    this.listOfDeltas = new ArrayList<Delta>(size);
-  }
-
-  public ListOfDeltas(Delta deltaObj) {
-    this.listOfDeltas = new ArrayList<Delta>();
-    this.listOfDeltas.add(deltaObj);
-  }
-  
-  public ListOfDeltas() {    
-  }
-
-  
-
-  public Object apply(EntryEvent ev) {
-    if (ev != null && ev instanceof EntryEventImpl) {
-      EntryEventImpl putEvent = (EntryEventImpl)ev;
-      int last = this.listOfDeltas.size() -1;
-      for (int i = this.deltaAppliedIndex; i < listOfDeltas.size(); i++) {
-        Object o = listOfDeltas.get(i).apply(putEvent);
-        if(i < last) { 
-          putEvent.setOldValue(o);
-        }else {
-          putEvent.setNewValue(o);
-        }
-      }
-      return putEvent.getNewValue();
-    }
-    else {
-      throw new InternalGemFireException(
-          "ListOfDeltas.apply: putEvent is either null "
-              + "or is not of type EntryEventImpl");
-    }
-  }
-
-
-  public Object merge(Object toMerge, boolean isCreate)
-  {
-    throw new UnsupportedOperationException("Invocation not expected");
-  }
-  
-  public Object merge(Object toMerge)
-  {
-    this.listOfDeltas.add((Delta)toMerge); 
-    return this;
-  }
-  
-  public Object getResultantValue()
-  {
-    return this;
-  } 
-  
-  public int getNumDeltas() {
-    return this.listOfDeltas.size();
-  }
-  
-  public void setDeltaAppliedIndex(int deltaApplied) {
-    this.deltaAppliedIndex = deltaApplied;
-  }
-  
-  public List<Delta> getListOfDeltas() {
-    return Collections.unmodifiableList(this.listOfDeltas);
-  }
-}
-//SqlFabric changes END

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 6b664fe..8b9664f 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
@@ -36,7 +36,6 @@ import com.gemstone.gemfire.cache.query.*;
 import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
 import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
 import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.cache.query.internal.cq.CqService;
 import com.gemstone.gemfire.cache.query.internal.index.IndexCreationData;
 import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
@@ -428,26 +427,6 @@ public class LocalRegion extends AbstractRegion
     return initializingRegion.get();
   }
 
-  /**
-   * Return true if the keys of this region implement
-   * {@link KeyWithRegionContext} that require region specific context
-   * initialization after deserialization or recovery from disk.
-   * 
-   * Currently used by SQLFabric for the optimized
-   * <code>CompactCompositeRegionKey</code> that points to the raw row bytes and
-   * so requires a handle to table schema for interpretation of those bytes.
-   */
-  public boolean keyRequiresRegionContext() {
-    return this.keyRequiresRegionContext;
-  }
-
-  /**
-   * Set the {@link #keyRequiresRegionContext} flag to given value.
-   */
-  public final void setKeyRequiresRegionContext(boolean v) {
-    this.keyRequiresRegionContext = v;
-  }
-
   public CancelCriterion getCancelCriterion() {
     return this.stopper;
   }
@@ -502,11 +481,9 @@ public class LocalRegion extends AbstractRegion
     this.initializationLatchAfterGetInitialImage = new StoppableCountDownLatch(this.stopper, 1);
     this.afterRegionCreateEventLatch = new StoppableCountDownLatch(this.stopper, 1);
 
-    // set the user-attribute object upfront for SQLFabric
     if (internalRegionArgs.getUserAttribute() != null) {
       setUserAttribute(internalRegionArgs.getUserAttribute());
     }
-    setKeyRequiresRegionContext(internalRegionArgs.keyRequiresRegionContext());
     initializingRegion.set(this);
 
     if (internalRegionArgs.getCachePerfStatsHolder() != null) {
@@ -674,10 +651,6 @@ public class LocalRegion extends AbstractRegion
     }
   }
 
-  public IndexUpdater getIndexUpdater() {
-    return this.entries.getIndexUpdater();
-  }
-
   boolean isCacheClosing()
   {
     return this.cache.isClosed();
@@ -854,10 +827,7 @@ public class LocalRegion extends AbstractRegion
                 && internalRegionArgs.isUsedForPartitionedRegionBucket()) {
               final PartitionedRegion pr = internalRegionArgs
                   .getPartitionedRegion();
-              internalRegionArgs.setIndexUpdater(pr.getIndexUpdater());
               internalRegionArgs.setUserAttribute(pr.getUserAttribute());
-              internalRegionArgs.setKeyRequiresRegionContext(pr
-                  .keyRequiresRegionContext());
               if (pr.isShadowPR()) {
                 newRegion = new BucketRegionQueue(subregionName, regionAttributes,
                   this, this.cache, internalRegionArgs);
@@ -1016,8 +986,6 @@ public class LocalRegion extends AbstractRegion
       }
   }
 
-  // split into a separate newCreateEntryEvent since SQLFabric may need to
-  // manipulate event before doing the put (e.g. posDup flag)
   @Retained
   public final EntryEventImpl newCreateEntryEvent(Object key, Object value,
       Object aCallbackArgument) {
@@ -1076,8 +1044,6 @@ public class LocalRegion extends AbstractRegion
       }
   }
 
-  // split into a separate newDestroyEntryEvent since SQLFabric may need to
-  // manipulate event before doing the put (e.g. posDup flag)
   @Retained
   public final EntryEventImpl newDestroyEntryEvent(Object key,
       Object aCallbackArgument) {
@@ -1588,15 +1554,8 @@ public class LocalRegion extends AbstractRegion
         event.setNewEventId(cache.getDistributedSystem());
       }
       Object oldValue = null;
-      // Sqlf changes begin
-      // see #40294.
-
-      // Rahul: this has to be an update.
-      // so executing it as an update.
-      boolean forceUpdateForDelta = event.hasDelta();
-      // Sqlf Changes end.
       if (basicPut(event, false, // ifNew
-          forceUpdateForDelta, // ifOld
+          false, // ifOld
           null, // expectedOldValue
           false // requireOldValue
       )) {
@@ -1612,8 +1571,6 @@ public class LocalRegion extends AbstractRegion
       return handleNotAvailable(oldValue);
   }
 
-  // split into a separate newUpdateEntryEvent since SQLFabric may need to
-  // manipulate event before doing the put (e.g. posDup flag)
   @Retained
   public final EntryEventImpl newUpdateEntryEvent(Object key, Object value,
       Object aCallbackArgument) {
@@ -1643,17 +1600,6 @@ public class LocalRegion extends AbstractRegion
       if (!eventReturned) event.release();
     }
   }
-  /**
-   * Creates an EntryEventImpl that is optimized to not fetch data from HDFS.
-   * This is meant to be used by PUT dml from GemFireXD.
-   */
-  @Retained
-  public final EntryEventImpl newPutEntryEvent(Object key, Object value,
-      Object aCallbackArgument) {
-    EntryEventImpl ev = newUpdateEntryEvent(key, value, aCallbackArgument);
-    ev.setPutDML(true);
-    return ev;
-  }
   private void extractDeltaIntoEvent(Object value, EntryEventImpl event) {
     // 1. Check for DS-level delta property.
     // 2. Default value for operation type is UPDATE, so no need to check that here.
@@ -3579,8 +3525,6 @@ public class LocalRegion extends AbstractRegion
    * Returns the value of the entry with the given key as it is stored on disk.
    * While the value may be read from disk, it is <b>not </b> stored into the
    * entry in the VM. This method is intended for testing purposes only.
-   * DO NOT use in product code else it will break SQLFabric that has cases
-   * where routing object is not part of only the key.
    *
    * @throws EntryNotFoundException
    *           No entry with <code>key</code> exists
@@ -3619,8 +3563,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Get the serialized bytes from disk. This method only looks for the value on
    * the disk, ignoring heap data. This method is intended for testing purposes
-   * only. DO NOT use in product code else it will break SQLFabric that has
-   * cases where routing object is not part of only the key.
+   * only. 
    * 
    * @param key the object whose hashCode is used to find the value
    * @return either a byte array, a CacheDeserializable with the serialized value,
@@ -3675,9 +3618,6 @@ public class LocalRegion extends AbstractRegion
   /**
    * Does a get that attempts to not fault values in from disk or make the entry
    * the most recent in the LRU.
-   * 
-   * Originally implemented in WAN gateway code and moved here in the sqlfire
-   * "cheetah" branch.
    * @param adamant fault in and affect LRU as a last resort
    * @param allowTombstone also return Token.TOMBSTONE if the entry is deleted
    * @param serializedFormOkay if the serialized form can be returned
@@ -5069,9 +5009,6 @@ public class LocalRegion extends AbstractRegion
   
   /**
    * Get the best iterator for the region entries.
-   * 
-   * TODO there has been some work on this on the sqlfire branch that should
-   * be picked up here.
    */
   public Iterator<RegionEntry> getBestIterator(boolean includeValues) {
     if(this instanceof DistributedRegion) {
@@ -5395,12 +5332,6 @@ public class LocalRegion extends AbstractRegion
         callbackArg = new GatewaySenderEventCallbackArgument(callbackArg);
       }
     }
-    //Asif: Modified the call to this constructor by passing the new value obtained from remote site
-    //instead of null .
-    //The need for this arose, because creation of EntryEvent, makes call to PartitionResolver,
-    //to get Hash. If the partitioning column is different from primary key, 
-    //the resolver for Sqlfabric is not able to obtain the hash object used for creation of KeyInfo  
-     
     @Released final EntryEventImpl event = EntryEventImpl.create(this, Operation.CREATE, key,
        value, callbackArg,  false /* origin remote */, client.getDistributedMember(),
         true /* generateCallbacks */,
@@ -5420,9 +5351,6 @@ public class LocalRegion extends AbstractRegion
     }
 
     // Set the new value to the input byte[] if it isn't null
-    /// For SqlFabric, if the new value happens to be an serialized object, then 
-    //it needs to be converted into VMCachedDeserializable , or serializable delta 
-    // as the case may be
     if (value != null) {
       // If the byte[] represents an object, then store it serialized
       // in a CachedDeserializable; otherwise store it directly as a byte[]
@@ -6064,12 +5992,6 @@ public class LocalRegion extends AbstractRegion
     long lastModifiedTime = event.getEventTime(lastModified);
     updateStatsForPut(entry, lastModifiedTime, lruRecentUse);
     if (!isProxy()) {
-      //if (this.isUsedForPartitionedRegionBucket) {
-      //  if (this.sqlfIndexManager != null) {
-      //    this.sqlfIndexManager.onEvent(this, event, entry);
-      //  }
-      //}
-
       if (!clearConflict && this.indexManager != null) {
         try {
           if (!entry.isInvalid()) {
@@ -6340,7 +6262,6 @@ public class LocalRegion extends AbstractRegion
          }
        }
        isDup = this.eventTracker.hasSeenEvent(event);
-       // don't clobber existing posDup flag e.g. set from SQLFabric client
        if (isDup) {
          event.setPossibleDuplicate(true);
          if (this.concurrencyChecksEnabled && event.getVersionTag() == null) {
@@ -7844,25 +7765,9 @@ public class LocalRegion extends AbstractRegion
       }
     }
   }
-  void cleanUpOnIncompleteOp(EntryEventImpl event,   RegionEntry re, 
-      boolean eventRecorded, boolean updateStats, boolean isReplace) {
-    //TODO:Asif: This is incorrect implementation for replicated region in case of
-    //sql fabric, as sqlf index would already be  updated, if eventRecorded 
-    //flag is true.So if entry is being removed , 
-    //then the sqlfindex also needs to be corrected
-    IndexUpdater iu = this.getIndexUpdater(); // sqlf system
-    if(!eventRecorded || iu ==null || isReplace) {
-    //Ok to remove entry whether sqlfabric or gfe as index has not been modified yet by the operation
-      this.entries.removeEntry(event.getKey(), re, updateStats) ;      
-    }else {
-      // a sqlf system, with event recorded as true. we need to update index.
-      //Use the current event to indicate destroy.should be ok
-      Operation oldOp = event.getOperation();
-      event.setOperation(Operation.DESTROY);
-      this.entries.removeEntry(event.getKey(), re, updateStats, event, this, iu);
-      event.setOperation(oldOp);
-    } 
-    
+  void cleanUpOnIncompleteOp(EntryEventImpl event, RegionEntry re) {
+    //Ok to remove entry as index has not been modified yet by the operation
+    this.entries.removeEntry(event.getKey(), re, false) ;      
   }
 
   static void validateRegionName(String name)
@@ -10531,8 +10436,6 @@ public class LocalRegion extends AbstractRegion
   }
 
 
-  // split into a separate newPutAllOperation since SQLFabric may need to
-  // manipulate event before doing the put (e.g. posDup flag)
   public final DistributedPutAllOperation newPutAllOperation(Map<?, ?> map, Object callbackArg) {
     if (map == null) {
       throw new NullPointerException(LocalizedStrings
@@ -10556,12 +10459,6 @@ public class LocalRegion extends AbstractRegion
     DistributedPutAllOperation dpao = new DistributedPutAllOperation(event, map.size(), false);
     return dpao;
   }
-    public final DistributedPutAllOperation newPutAllForPUTDmlOperation(Map<?, ?> map, Object callbackArg) {
-    DistributedPutAllOperation dpao = newPutAllOperation(map, callbackArg);
-    dpao.getEvent().setPutDML(true);
-    return dpao;
-  }
-
   
   public final DistributedRemoveAllOperation newRemoveAllOperation(Collection<?> keys, Object callbackArg) {
     if (keys == null) {
@@ -10613,8 +10510,6 @@ public class LocalRegion extends AbstractRegion
         putallOp, this, Operation.PUTALL_CREATE, key, value);
 
     try {
-    event.setPutDML(putallOp.getEvent().isPutDML());
-    
     if (tagHolder != null) {
       event.setVersionTag(tagHolder.getVersionTag());
       event.setFromServer(tagHolder.isFromServer());
@@ -11015,8 +10910,7 @@ public class LocalRegion extends AbstractRegion
       final CacheProfile prof = (CacheProfile)profile;
 
       // if region in cache is not yet initialized, exclude
-      if (prof.regionInitialized // fix for bug 41102
-          && !prof.memberUnInitialized) {
+      if (prof.regionInitialized) { // fix for bug 41102
         // cut the visit short if we find a CacheLoader
         return !prof.hasCacheLoader;
       }
@@ -11033,8 +10927,8 @@ public class LocalRegion extends AbstractRegion
       assert profile instanceof CacheProfile;
       final CacheProfile prof = (CacheProfile)profile;
 
-      // if region in cache is in recovery, or member not initialized exclude
-      if (!prof.inRecovery && !prof.memberUnInitialized) {
+      // if region in cache is in recovery
+      if (!prof.inRecovery) {
         // cut the visit short if we find a CacheWriter
         return !prof.hasCacheWriter;
       }
@@ -11486,15 +11380,6 @@ public class LocalRegion extends AbstractRegion
     distributeUpdatedProfileOnSenderCreation();
   }
   
-  /**
-   * @since GemFire SqlFabric
-   *
-   */
-  void distributeUpdatedProfileOnHubCreation()
-  {
-    // No op
-  }  
-  
   void distributeUpdatedProfileOnSenderCreation()
   {
     // No op

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 4c04054..59b0893 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
@@ -1867,7 +1867,6 @@ public final class Oplog implements CompactableOplog, Flushable {
     CountingDataInputStream dis = null;
     try {
       final LocalRegion currentRegion = LocalRegion.getInitializingRegion();
-      final boolean keyRequiresRegionContext = currentRegion != null ? currentRegion.keyRequiresRegionContext() : false;
       final Version version = getProductVersionIfOld();
       final ByteArrayDataInput in = new ByteArrayDataInput();
       final HeapDataOutputStream hdos = new HeapDataOutputStream(Version.CURRENT);
@@ -1909,7 +1908,7 @@ public final class Oplog implements CompactableOplog, Flushable {
           }
             break;
           case OPLOG_NEW_ENTRY_0ID:
-            readNewEntry(dis, opCode, deletedIds, recoverValues, currentRegion, keyRequiresRegionContext, version, in, hdos);
+            readNewEntry(dis, opCode, deletedIds, recoverValues, currentRegion, version, in, hdos);
             recordCount++;
             break;
           case OPLOG_MOD_ENTRY_1ID:
@@ -1920,7 +1919,7 @@ public final class Oplog implements CompactableOplog, Flushable {
           case OPLOG_MOD_ENTRY_6ID:
           case OPLOG_MOD_ENTRY_7ID:
           case OPLOG_MOD_ENTRY_8ID:
-            readModifyEntry(dis, opCode, deletedIds, recoverValues, currentRegion, keyRequiresRegionContext, version, in, hdos);
+            readModifyEntry(dis, opCode, deletedIds, recoverValues, currentRegion, version, in, hdos);
             recordCount++;
             break;
           case OPLOG_MOD_ENTRY_WITH_KEY_1ID:
@@ -1931,7 +1930,7 @@ public final class Oplog implements CompactableOplog, Flushable {
           case OPLOG_MOD_ENTRY_WITH_KEY_6ID:
           case OPLOG_MOD_ENTRY_WITH_KEY_7ID:
           case OPLOG_MOD_ENTRY_WITH_KEY_8ID:
-            readModifyEntryWithKey(dis, opCode, deletedIds, recoverValues, currentRegion, keyRequiresRegionContext, version, in,
+            readModifyEntryWithKey(dis, opCode, deletedIds, recoverValues, currentRegion, version, in,
                 hdos);
             recordCount++;
             break;
@@ -2414,7 +2413,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * @throws IOException
    */
   private void readNewEntry(CountingDataInputStream dis, byte opcode, OplogEntryIdSet deletedIds, boolean recoverValue,
-      final LocalRegion currentRegion, boolean keyRequiresRegionContext, Version version, ByteArrayDataInput in,
+      final LocalRegion currentRegion, Version version, ByteArrayDataInput in,
       HeapDataOutputStream hdos) throws IOException {
     final boolean isPersistRecoveryDebugEnabled = logger.isTraceEnabled(LogMarker.PERSIST_RECOVERY);
     
@@ -2553,9 +2552,6 @@ public final class Oplog implements CompactableOplog, Flushable {
           }
         } else {
           Object key = deserializeKey(keyBytes, version, in);
-          if (keyRequiresRegionContext) {
-            ((KeyWithRegionContext) key).setRegionContext(currentRegion);
-          }
           {
             Object oldValue = getRecoveryMap().put(oplogKeyId, key);
             if (oldValue != null) {
@@ -2605,7 +2601,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * @throws IOException
    */
   private void readModifyEntry(CountingDataInputStream dis, byte opcode, OplogEntryIdSet deletedIds, boolean recoverValue,
-      LocalRegion currentRegion, boolean keyRequiresRegionContext, Version version, ByteArrayDataInput in, HeapDataOutputStream hdos)
+      LocalRegion currentRegion, Version version, ByteArrayDataInput in, HeapDataOutputStream hdos)
       throws IOException {
     final boolean isPersistRecoveryDebugEnabled = logger.isTraceEnabled(LogMarker.PERSIST_RECOVERY);
     
@@ -2711,9 +2707,6 @@ public final class Oplog implements CompactableOplog, Flushable {
         byte[] keyBytes = (byte[]) skippedKeyBytes.get(oplogKeyId);
         if (keyBytes != null) {
           key = deserializeKey(keyBytes, version, in);
-          if (keyRequiresRegionContext) {
-            ((KeyWithRegionContext) key).setRegionContext(currentRegion);
-          }
         }
       }
       if (isPersistRecoveryDebugEnabled) {
@@ -2829,7 +2822,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * @throws IOException
    */
   private void readModifyEntryWithKey(CountingDataInputStream dis, byte opcode, OplogEntryIdSet deletedIds, boolean recoverValue,
-      final LocalRegion currentRegion, final boolean keyRequiresRegionContext, Version version, ByteArrayDataInput in,
+      final LocalRegion currentRegion, Version version, ByteArrayDataInput in,
       HeapDataOutputStream hdos) throws IOException {
     long oplogOffset = -1;
 
@@ -2966,9 +2959,6 @@ public final class Oplog implements CompactableOplog, Flushable {
         }
       } else {
         Object key = deserializeKey(keyBytes, version, in);
-        if (keyRequiresRegionContext) {
-          ((KeyWithRegionContext) key).setRegionContext(currentRegion);
-        }
         Object oldValue = getRecoveryMap().put(oplogKeyId, key);
         if (oldValue != null) {
           throw new AssertionError(LocalizedStrings.Oplog_DUPLICATE_CREATE.toLocalizedString(oplogKeyId));
@@ -7039,8 +7029,6 @@ public final class Oplog implements CompactableOplog, Flushable {
     public void handleValueOverflow(RegionEntryContext context) {throw new IllegalStateException();}
 
     @Override
-    public void afterValueOverflow(RegionEntryContext context) {throw new IllegalStateException();}
-    @Override
     public Object prepareValueForCache(RegionEntryContext r, Object val, boolean isEntryUpdate) { throw new IllegalStateException("Should never be called");  }
 
     @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 f933024..c33efb7 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
@@ -432,8 +432,6 @@ public class PRHARedundancyProvider
       this.prRegion.checkReadiness();
       Set<InternalDistributedMember> available = this.prRegion
           .getRegionAdvisor().adviseInitializedDataStore();
-      // remove uninitialized members for bucket creation
-      this.prRegion.getCache().removeUnInitializedMembers(available);
       InternalDistributedMember target = null;
       available.removeAll(attempted);
       for (InternalDistributedMember member : available) {
@@ -575,8 +573,6 @@ public class PRHARedundancyProvider
         // Always go back to the advisor, see if any fresh data stores are
           // present.
         Set<InternalDistributedMember> allStores = getAllStores(partitionName);
-        // remove nodes that are not fully initialized
-        this.prRegion.getCache().removeUnInitializedMembers(allStores);
 
         loggedInsufficentStores  = checkSufficientStores(allStores, 
             loggedInsufficentStores);
@@ -776,7 +772,6 @@ public class PRHARedundancyProvider
       //  the parent's in case of colocation) so it is now passed
       //InternalDistributedMember targetPrimary = getPreferredDataStore(
       //    acceptedMembers, Collections.<InternalDistributedMember> emptySet());
-      this.prRegion.getCache().removeUnInitializedMembers(acceptedMembers);
       targetPrimary = getPreferredDataStore(acceptedMembers, Collections
           .<InternalDistributedMember> emptySet());
     }
@@ -1580,9 +1575,6 @@ public class PRHARedundancyProvider
     if (!PRHARedundancyProvider.this.prRegion.isDataStore()) {
       return;
     }
-    if (cache.isUnInitializedMember(cache.getMyId())) {
-      return;
-    }
     Runnable task = new RecoveryRunnable(this) {
       @Override
       public void run2()

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 47548f3..dd90a62 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
@@ -384,16 +384,6 @@ public class PartitionAttributesImpl implements PartitionAttributes,
       .append("]") .toString();
   }
 
-  public String getStringForSQLF() {
-    final StringBuilder sb = new StringBuilder();
-    return sb.append("redundantCopies=").append(getRedundantCopies()).append(
-        ",totalMaxMemory=").append(this.totalMaxMemory).append(
-        ",totalNumBuckets=").append(this.totalNumBuckets).append(
-        ",colocatedWith=").append(this.colocatedRegionName).append(
-        ",recoveryDelay=").append(this.recoveryDelay).append(
-        ",startupRecoveryDelay=").append(this.startupRecoveryDelay).toString();
-  }
-
   /**
    * @throws IllegalStateException if off-heap and the actual value is not yet known (because the DistributedSystem has not yet been created)
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 9375d04..26c91e0 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
@@ -1035,16 +1035,6 @@ public class PartitionedRegion extends LocalRegion implements
   }
   
   @Override
-  void distributeUpdatedProfileOnHubCreation()
-  {
-    if (!(this.isClosed || this.isLocallyDestroyed)) {
-      // tell others of the change in status
-      this.requiresNotification = true;
-      new UpdateAttributesProcessor(this).distribute(false);      
-    }
-  }
-
-  @Override
   void distributeUpdatedProfileOnSenderCreation()
   {
     if (!(this.isClosed || this.isLocallyDestroyed)) {
@@ -1376,11 +1366,7 @@ public class PartitionedRegion extends LocalRegion implements
     boolean colocatedLockAcquired = false;
     try {
       boolean colocationComplete = false;
-      if (colocatedRegion != null && !prConfig.isColocationComplete() &&
-        // if the current node is marked uninitialized (SQLF DDL replay in
-        // progress) then colocation will definitely not be marked complete so
-        // avoid taking the expensive region lock
-          !getCache().isUnInitializedMember(getDistributionManager().getId())) {
+      if (colocatedRegion != null && !prConfig.isColocationComplete()) {
         colocatedLock = colocatedRegion.getRegionLock();
         colocatedLock.lock();
         colocatedLockAcquired = true;
@@ -1389,16 +1375,7 @@ public class PartitionedRegion extends LocalRegion implements
         if (parentConf.isColocationComplete()
             && parentConf.hasSameDataStoreMembers(prConfig)) {
           colocationComplete = true;
-          // check if all the nodes have been initialized (SQLF bug #42089)
-          for (Node node : nodes) {
-            if (getCache().isUnInitializedMember(node.getMemberId())) {
-              colocationComplete = false;
-              break;
-            }
-          }
-          if (colocationComplete) {
-            prConfig.setColocationComplete();
-          }
+          prConfig.setColocationComplete();
         }
       }
 
@@ -1935,13 +1912,6 @@ public class PartitionedRegion extends LocalRegion implements
       if (targetNode == null) {
         try {
           bucketStorageAssigned=false;
-          // if this is a Delta update, then throw exception since the key doesn't
-          // exist if there is no bucket for it yet
-          if (event.hasDelta()) {
-            throw new EntryNotFoundException(LocalizedStrings.
-              PartitionedRegion_CANNOT_APPLY_A_DELTA_WITHOUT_EXISTING_ENTRY
-                .toLocalizedString());
-          }
           targetNode = createBucket(bucketId.intValue(), event.getNewValSizeForPR(),
               null);
         }
@@ -3462,10 +3432,8 @@ public class PartitionedRegion extends LocalRegion implements
       boolean isBucketSetAsFilter) {
     final Set routingKeys = execution.getFilter();
     final boolean primaryMembersNeeded = function.optimizeForWrite();
-    final boolean hasRoutingObjects = execution.hasRoutingObjects();
     HashMap<Integer, HashSet> bucketToKeysMap = FunctionExecutionNodePruner
-        .groupByBucket(this, routingKeys, primaryMembersNeeded,
-            hasRoutingObjects, isBucketSetAsFilter);
+        .groupByBucket(this, routingKeys, primaryMembersNeeded, false, isBucketSetAsFilter);
     HashMap<InternalDistributedMember, HashSet> memberToKeysMap = new HashMap<InternalDistributedMember, HashSet>();
     HashMap<InternalDistributedMember, HashSet<Integer>> memberToBuckets = FunctionExecutionNodePruner
     .groupByMemberToBuckets(this, bucketToKeysMap.keySet(), primaryMembersNeeded);    
@@ -3555,7 +3523,7 @@ public class PartitionedRegion extends LocalRegion implements
     else {
       localBucketSet = FunctionExecutionNodePruner
       .getBucketSet(PartitionedRegion.this, localKeys,
-                    hasRoutingObjects, isBucketSetAsFilter);
+                    false, isBucketSetAsFilter);
       
       remoteOnly = false;
     }
@@ -3591,7 +3559,7 @@ public class PartitionedRegion extends LocalRegion implements
         FunctionRemoteContext context = new FunctionRemoteContext(function,
             execution.getArgumentsForMember(recip.getId()), memKeys,
             FunctionExecutionNodePruner.getBucketSet(this, memKeys,
-                hasRoutingObjects, isBucketSetAsFilter), execution.isReExecute(),
+                false, isBucketSetAsFilter), execution.isReExecute(),
                 execution.isFnSerializationReqd());
         recipMap.put(recip, context);
       }
@@ -3621,15 +3589,8 @@ public class PartitionedRegion extends LocalRegion implements
     if (isBucketSetAsFilter) {
       bucketId = ((Integer) key).intValue();
     } else {
-      if (execution.hasRoutingObjects()) {
-        bucketId = Integer.valueOf(PartitionedRegionHelper
-            .getHashKey(this, key));
-      } else {
-        // bucketId = Integer.valueOf(PartitionedRegionHelper.getHashKey(this,
-        // Operation.FUNCTION_EXECUTION, key, null));
-        bucketId = Integer.valueOf(PartitionedRegionHelper.getHashKey(this,
+      bucketId = Integer.valueOf(PartitionedRegionHelper.getHashKey(this,
             Operation.FUNCTION_EXECUTION, key, null, null));
-      }
     }
     InternalDistributedMember targetNode = null;
     if (function.optimizeForWrite()) {
@@ -5066,21 +5027,6 @@ public class PartitionedRegion extends LocalRegion implements
   /**
    * generates new partitioned region ID globally.
    */
-  // !!!:ezoerner:20080321 made this function public and static.
-  // @todo should be moved to the Distributed System level as a general service
-  // for getting a unique id, with different "domains" for different
-  // contexts
-  // :soubhik:pr_func merge20914:21056: overloaded static and non-static version of generatePRId.
-  //   static version is used mainly with sqlf & non-static in gfe.
-  public static int generatePRId(InternalDistributedSystem sys, Cache cache) {
-    
-    GemFireCacheImpl gfcache = (GemFireCacheImpl) cache;
-    
-    if(gfcache == null) return 0;
-    
-    return _generatePRId(sys, gfcache.getPartitionedRegionLockService());
-  }
-  
   public int generatePRId(InternalDistributedSystem sys) {
     final DistributedLockService lockService = getPartitionedRegionLockService();
     return _generatePRId(sys, lockService);
@@ -6257,15 +6203,6 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * Currently used by SQLFabric to get a non-wrapped iterator for all entries
-   * for index consistency check.
-   */
-  public Set allEntries() {
-    return new PREntriesSet();
-  }
-
-
-  /**
    * Set view of entries. This currently extends the keySet iterator and
    * performs individual getEntry() operations using the keys
    * 
@@ -7678,20 +7615,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
         
   @Override
-  public void localDestroyRegion(Object aCallbackArgument) {
-    localDestroyRegion(aCallbackArgument, false);
-  }
-
-  /**
-   * Locally destroy a region.
-   * 
-   * SQLFabric change: The parameter "ignoreParent" has been added to allow
-   * skipping the check for parent colocated region. This is because SQLFabric
-   * DDLs are distributed in any case and are guaranteed to be atomic (i.e. no
-   * concurrent DMLs on that table). Without this it is quite ugly to implement
-   * "TRUNCATE TABLE" which first drops the table and recreates it.
-   */
-  public void localDestroyRegion(Object aCallbackArgument, boolean ignoreParent)
+  public void localDestroyRegion(Object aCallbackArgument)
   {
     getDataView().checkSupportsRegionDestroy();
     String prName = this.getColocatedWith();
@@ -7707,7 +7631,7 @@ public class PartitionedRegion extends LocalRegion implements
       }
     }
 
-    if ((!ignoreParent && prName != null)
+    if ((prName != null)
         || (!childRegionsWithoutSendersList.isEmpty())) {
       throw new UnsupportedOperationException(
           "Any Region in colocation chain cannot be destroyed locally.");
@@ -9430,8 +9354,6 @@ public class PartitionedRegion extends LocalRegion implements
 
   /**
    * This method is intended for testing purposes only.
-   * DO NOT use in product code else it will break SQLFabric that has cases
-   * where routing object is not part of only the key.
    */
   @Override
   public Object getValueOnDisk(Object key) throws EntryNotFoundException {
@@ -9444,8 +9366,6 @@ public class PartitionedRegion extends LocalRegion implements
   
   /**
    * This method is intended for testing purposes only.
-   * DO NOT use in product code else it will break SQLFabric that has cases
-   * where routing object is not part of only the key.
    */
   @Override
   public Object getValueOnDiskOrBuffer(Object key) throws EntryNotFoundException {
@@ -9565,33 +9485,13 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   public PartitionResolver getPartitionResolver() {
-    // [SQLFabric] use PartitionAttributes to get the the resolver
-    // since it may change after ALTER TABLE
     return this.partitionAttributes.getPartitionResolver();
   }
 
   public String getColocatedWith() {
-    // [SQLFabric] use PartitionAttributes to get colocated region
-    // since it may change after ALTER TABLE
     return this.partitionAttributes.getColocatedWith();
   }
 
-  // For SQLFabric ALTER TABLE. Need to set the colocated region using
-  // PartitionAttributesImpl and also reset the parentAdvisor for
-  // BucketAdvisors.
-  /**
-   * Set the colocated with region path and adjust the BucketAdvisor's. This
-   * should *only* be invoked when region is just newly created and has no data
-   * or existing buckets else will have undefined behaviour.
-   * 
-   * @since GemFire 6.5
-   */
-  public void setColocatedWith(String colocatedRegionFullPath) {
-    ((PartitionAttributesImpl)this.partitionAttributes)
-        .setColocatedWith(colocatedRegionFullPath);
-    this.getRegionAdvisor().resetBucketAdvisorParents();
-  }
-
   /**
    * Used to get membership events from our advisor to implement
    * RegionMembershipListener invocations. This is copied almost in whole from
@@ -9649,98 +9549,6 @@ public class PartitionedRegion extends LocalRegion implements
     }
   }
   
-  /*
-   * This is an internal API for sqlFabric only <br>
-   * This is usefull to execute a function on set of nodes irrelevant of the
-   * routinKeys <br>
-   * notes : This API uses DefaultResultCollector. If you want your Custome
-   * Result collector, let me know
-   * 
-   * @param functionName
-   * @param args
-   * @param nodes
-   *                Set of DistributedMembers on which this function will be
-   *                executed
-   * @throws Exception
-   *//*
-  public ResultCollector executeFunctionOnNodes(String functionName,
-      Serializable args, Set nodes) throws Exception {
-    Assert.assertTrue(functionName != null, "Error: functionName is null");
-    Assert.assertTrue(nodes != null, "Error: nodes set is null");
-    Assert.assertTrue(nodes.size() != 0, "Error: empty nodes Set");
-    ResultCollector rc = new DefaultResultCollector();
-    boolean isSelf = nodes.remove(getMyId());
-    PartitionedRegionFunctionResponse response = null;
-    //TODO Yogesh: this API is broken after Resultsender implementation
-    //response = new PartitionedRegionFunctionResponse(this.getSystem(), nodes,
-    //    rc);
-    Iterator i = nodes.iterator();
-    while (i.hasNext()) {
-      InternalDistributedMember recip = (InternalDistributedMember)i.next();
-      PartitionedRegionFunctionMessage.send(recip, this, functionName, args,
-          null routingKeys , response, null);
-    }
-    if (isSelf) {
-      // execute locally and collect the result
-      if (this.dataStore != null) {
-        this.dataStore.executeOnDataStore(
-            null routingKeys , functionName, args, 0,null,rc,null);
-      }
-    }
-    return response;
-  }*/
-
-
-  /*
-   * This is an internal API for sqlFabric only <br>
-   * API for invoking a function using primitive ints as the routing objects
-   * (i.e. passing the hashcodes of the routing objects directly). <br>
-   * notes : This API uses DefaultResultCollector. If you want to pass your
-   * Custom Result collector, let me know
-   * 
-   * @param functionName
-   * @param args
-   * @param hashcodes
-   *          hashcodes of the routing objects
-   * @throws Exception
-   *//*
-  public ResultCollector executeFunctionUsingHashCodes(String functionName,
-      Serializable args, int hashcodes[]) throws Exception {
-    Assert.assertTrue(functionName != null, "Error: functionName is null");
-    Assert.assertTrue(hashcodes != null, "Error: hashcodes array is null");
-    Assert.assertTrue(hashcodes.length != 0, "Error: empty hashcodes array");
-    Set nodes = new HashSet();
-    for (int i = 0; i < hashcodes.length; i++) {
-      int bucketId = hashcodes[i] % getTotalNumberOfBuckets();
-      InternalDistributedMember n = getNodeForBucketRead(bucketId);
-      nodes.add(n);
-    }
-    return executeFunctionOnNodes(functionName, args, nodes);
-  }*/
-
-  /**
-   * This is an internal API for sqlFabric only <br>
-   * Given a array of routing objects, returns a set of members on which the (owner of each
-   * buckets)
-   * 
-   * @param routingObjects array of routing objects passed 
-   * @return Set of  InternalDistributedMembers
-   */
-  public Set getMembersFromRoutingObjects(Object[] routingObjects) {
-    Assert.assertTrue(routingObjects != null, "Error: null routingObjects ");
-    Assert.assertTrue(routingObjects.length != 0, "Error: empty routingObjects ");
-    Set nodeSet = new HashSet();
-    int bucketId;
-    for (int i = 0; i < routingObjects.length; i++) {
-      bucketId = PartitionedRegionHelper.getHashKey(routingObjects[i],
-                                                    getTotalNumberOfBuckets());
-      InternalDistributedMember lnode = getOrCreateNodeForBucketRead(bucketId);
-      if (lnode != null) {
-        nodeSet.add(lnode);
-      }
-    }
-    return nodeSet;
-  }
   @Override
   protected RegionEntry basicGetTXEntry(KeyInfo keyInfo) {
     int bucketId = keyInfo.getBucketId();
@@ -10525,9 +10333,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * Returns the local BucketRegion given the key and value. Particularly useful
-   * for SQLFabric where the routing object may be part of value and determining
-   * from key alone will require an expensive global index lookup.
+   * Returns the local BucketRegion given the key and value.
    * Returns null if no BucketRegion exists.
    */
   public BucketRegion getBucketRegion(Object key, Object value) {
@@ -10754,74 +10560,6 @@ public class PartitionedRegion extends LocalRegion implements
     }  
   }
 
-  /**
-   * Clear local primary buckets.
-   * This is currently only used by gemfirexd truncate table
-   * to clear the partitioned region.
-   */
-  public void clearLocalPrimaries() {
- // rest of it should be done only if this is a store while RecoveryLock
-    // above still required even if this is an accessor
-    if (getLocalMaxMemory() > 0) {
-      // acquire the primary bucket locks
-      // do this in a loop to handle the corner cases where a primary
-      // bucket region ceases to be so when we actually take the lock
-      // (probably not required to do this in loop after the recovery lock)
-      // [sumedh] do we need both recovery lock and bucket locks?
-      boolean done = false;
-      Set<BucketRegion> lockedRegions = null;
-      while (!done) {
-        lockedRegions = getDataStore().getAllLocalPrimaryBucketRegions();
-        done = true;
-        for (BucketRegion br : lockedRegions) {
-          try {
-            br.doLockForPrimary(false);
-          } catch (RegionDestroyedException rde) {
-            done = false;
-            break;
-          } catch (PrimaryBucketException pbe) {
-            done = false;
-            break;
-          } catch (Exception e) {
-            // ignore any other exception
-            logger.debug(
-                "GemFireContainer#clear: ignoring exception "
-                    + "in bucket lock acquire", e);
-          }
-        }
-      }
-      
-      try {
-        // now clear the bucket regions; we go through the primary bucket
-        // regions so there is distribution for every bucket but that
-        // should be performant enough
-        for (BucketRegion br : lockedRegions) {
-          try {
-            br.clear();
-          } catch (Exception e) {
-            // ignore any other exception
-            logger.debug(
-                "GemFireContainer#clear: ignoring exception "
-                    + "in bucket clear", e);
-          }
-        }
-      } finally {
-        // release the bucket locks
-        for (BucketRegion br : lockedRegions) {
-          try {
-            br.doUnlockForPrimary();
-          } catch (Exception e) {
-            // ignore all exceptions at this stage
-            logger.debug(
-                "GemFireContainer#clear: ignoring exception "
-                    + "in bucket lock release", e);
-          }
-        }
-      }
-    }
-    
-  }
-
   public void shadowPRWaitForBucketRecovery() {
     assert this.isShadowPR();
     PartitionedRegion userPR = ColocationHelper.getLeaderRegion(this);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 3855adc..494c288 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
@@ -24,7 +24,6 @@ import com.gemstone.gemfire.cache.execute.Function;
 import com.gemstone.gemfire.cache.execute.FunctionException;
 import com.gemstone.gemfire.cache.execute.ResultSender;
 import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.cache.query.internal.QCompiler;
 import com.gemstone.gemfire.cache.query.internal.index.IndexCreationData;
 import com.gemstone.gemfire.cache.query.internal.index.PartitionedIndex;
@@ -431,19 +430,7 @@ public class PartitionedRegionDataStore implements HasCachePerfStats
               Object redundancyLock = lockRedundancyLock(moveSource,
                   possiblyFreeBucketId, replaceOffineData);
               //DAN - I hope this is ok to do without that bucket admin lock
-              // Take SQLF lock to wait for any ongoing index initializations.
-              // The lock is taken here in addition to that in
-              // DistributedRegion#initialize() so as to release only after
-              // assignBucketRegion() has been invoked (see bug #41877).
-              // Assumes that the IndexUpdater#lockForGII() lock is re-entrant.
-              final IndexUpdater indexUpdater = this.partitionedRegion
-              .getIndexUpdater();
-              boolean sqlfIndexLocked = false;
               try {
-                if (indexUpdater != null) {
-                  indexUpdater.lockForGII();
-                  sqlfIndexLocked = true;
-                }
                 buk.initializePrimaryElector(creationRequestor);
                 if (getPartitionedRegion().getColocatedWith() == null) {
                   buk.getBucketAdvisor().setShadowBucketDestroyed(false);
@@ -476,9 +463,6 @@ public class PartitionedRegionDataStore implements HasCachePerfStats
                   }
                 }
               } finally {
-                if (sqlfIndexLocked) {
-                  indexUpdater.unlockForGII();
-                }
                 releaseRedundancyLock(redundancyLock);
                 if(bukReg == null) {
                   buk.clearPrimaryElector();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 ee8e0c8..55d11fc 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
@@ -30,7 +30,6 @@ import com.gemstone.gemfire.cache.EntryNotFoundException;
 import com.gemstone.gemfire.cache.Operation;
 import com.gemstone.gemfire.cache.TimeoutException;
 import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.distributed.internal.DM;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.ByteArrayDataInput;
@@ -56,23 +55,10 @@ import com.gemstone.gemfire.internal.offheap.annotations.Released;
  */
 final class ProxyRegionMap implements RegionMap {
 
-  /** An internal Listener for index maintenance for SQLFabric. */
-  private final IndexUpdater indexUpdater;
-
   protected ProxyRegionMap(LocalRegion owner, Attributes attr,
       InternalRegionArguments internalRegionArgs) {
     this.owner = owner;
     this.attr = attr;
-    if (internalRegionArgs != null) {
-      this.indexUpdater = internalRegionArgs.getIndexUpdater();
-    }
-    else {
-      this.indexUpdater = null;
-    }
-  }
-
-  public final IndexUpdater getIndexUpdater() {
-    return this.indexUpdater;
   }
 
   /**
@@ -249,13 +235,6 @@ final class ProxyRegionMap implements RegionMap {
     lastModified = // fix for bug 40129
       this.owner.basicPutPart2(event, markerEntry, true,
         lastModified, false /*Clear conflict occurred */);
-    // invoke SQLFabric index manager if present
-    final IndexUpdater indexUpdater = getIndexUpdater();
-    if (indexUpdater != null) {
-      // postEvent not required to be invoked since this is currently used
-      // only for FK checks
-      indexUpdater.onEvent(this.owner, event, markerEntry);
-    }
     this.owner.basicPutPart3(event, markerEntry, true,
           lastModified, true, ifNew, ifOld, expectedOldValue, requireOldValue);
     return markerEntry;
@@ -399,7 +378,7 @@ final class ProxyRegionMap implements RegionMap {
   }
 
   public void removeEntry(Object key, RegionEntry re, boolean updateStat,
-      EntryEventImpl event, LocalRegion owner, IndexUpdater indexUpdater) {
+      EntryEventImpl event, LocalRegion owner) {
     // nothing to do
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 22f9903..7be2bb9 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
@@ -161,13 +161,7 @@ public class QueuedOperation
       key = DataSerializer.readObject(in);
       if (op.isUpdate() || op.isCreate()) {
         deserializationPolicy = in.readByte();
-        if (deserializationPolicy ==
-            DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER) {
-          valueObj = DataSerializer.readObject(in);
-        }
-        else {
-          value = DataSerializer.readByteArray(in);
-        }
+        value = DataSerializer.readByteArray(in);
       }
     }
     return new QueuedOperation(op, key, value, valueObj, deserializationPolicy,
@@ -183,13 +177,7 @@ public class QueuedOperation
       DataSerializer.writeObject(this.key, out);
       if (this.op.isUpdate() || this.op.isCreate()) {
         out.writeByte(this.deserializationPolicy);
-        if (this.deserializationPolicy !=
-            DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER) {
-          DataSerializer.writeByteArray(this.value, out);
-        }
-        else {
-          DataSerializer.writeObject(this.valueObj, out);
-        }
+        DataSerializer.writeByteArray(this.value, out);
       }
     }
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 b35eaa3..48ed5db 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
@@ -379,16 +379,14 @@ public interface RegionEntry {
   /**
    * Gets the value for this entry. For DiskRegions, unlike
    * {@link #getValue(RegionEntryContext)} this will not fault in the value rather
-   * return a temporary copy. For SQLFabric this is used during table scans in
-   * queries when faulting in every value will be only an unnecessary overhead.
+   * return a temporary copy.
    */
   public Object getValueInVMOrDiskWithoutFaultIn(LocalRegion owner);
 
   /**
    * Gets the value for this entry. For DiskRegions, unlike
    * {@link #getValue(RegionEntryContext)} this will not fault in the value rather
-   * return a temporary copy. For SQLFabric this is used during table scans in
-   * queries when faulting in every value will be only an unnecessary overhead.
+   * return a temporary copy.
    * The value returned will be kept off heap (and compressed) if possible.
    */
   @Retained

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 a16f1ec..57f8853 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
@@ -27,7 +27,6 @@ import com.gemstone.gemfire.cache.EntryNotFoundException;
 import com.gemstone.gemfire.cache.Operation;
 import com.gemstone.gemfire.cache.TimeoutException;
 import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.internal.cache.lru.LRUMapCallbacks;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
@@ -355,16 +354,13 @@ public interface RegionMap extends LRUMapCallbacks {
 
   /**
    * Removes the given key if the enclosing RegionEntry is still in this map for
-   * the given EntryEvent and updating the given {@link IndexUpdater} of the
-   * region ({@link #getIndexUpdater()}) for the event.
+   * the given EntryEvent
    */
   public void removeEntry(Object key, RegionEntry re, boolean updateStat,
-      EntryEventImpl event, LocalRegion owner, IndexUpdater indexUpdater);
+      EntryEventImpl event, LocalRegion owner);
 
   public void copyRecoveredEntries(RegionMap rm);
 
-  public IndexUpdater getIndexUpdater();
-  
   /**
    * Removes an entry that was previously destroyed and made into a tombstone.
    * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 a1b5d0c..d5a52d4 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
@@ -123,9 +123,6 @@ public final class RemoteContainsKeyValueMessage extends RemoteOperationMessageW
       r.waitOnInitialization(); // bug #43371 - accessing a region before it's initialized
     }
 
-    if (r.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext)this.key).setRegionContext(r);
-    }
     final boolean replyVal;
         if (this.valueCheck) {
           replyVal = r.containsValueForKey(this.key);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 822b317..2bec70f 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
@@ -357,9 +357,6 @@ public class RemoteDestroyMessage extends RemoteOperationMessageWithDirectReply
     if (eventSender == null) {
        eventSender = getSender();
     }
-    if (r.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext)this.key).setRegionContext(r);
-    }
     @Released EntryEventImpl event = null;
     try {
     if (this.bridgeContext != null) {
@@ -468,8 +465,6 @@ public class RemoteDestroyMessage extends RemoteOperationMessageWithDirectReply
     if (this.hasOldValue){
       //out.writeBoolean(this.hasOldValue);
       // below boolean is not strictly required, but this is for compatibility
-      // with SQLFire code which writes as byte here to indicate whether
-      // oldValue is an object, serialized object or byte[]
       in.readByte();
       setOldValBytes(DataSerializer.readByteArray(in));
     }
@@ -595,12 +590,8 @@ public class RemoteDestroyMessage extends RemoteOperationMessageWithDirectReply
   
   private void setOldValueIsSerialized(boolean isSerialized) {
     if (isSerialized) {
-      if (CachedDeserializableFactory.preferObject()) {
-        this.oldValueIsSerialized = true; //VALUE_IS_OBJECT;
-      } else {
-        // Defer serialization until toData is called.
-        this.oldValueIsSerialized = true; //VALUE_IS_SERIALIZED_OBJECT;
-      }
+      // Defer serialization until toData is called.
+      this.oldValueIsSerialized = true; //VALUE_IS_SERIALIZED_OBJECT;
     } else {
       this.oldValueIsSerialized = false; //VALUE_IS_BYTES;
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 b7cc393..b7a4a81 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
@@ -128,9 +128,6 @@ public final class RemoteFetchEntryMessage extends RemoteOperationMessage
     }
     EntrySnapshot val;
       try {
-        if (r.keyRequiresRegionContext()) {
-          ((KeyWithRegionContext)this.key).setRegionContext(r);
-        }
         final KeyInfo keyInfo = r.getKeyInfo(key);
         Region.Entry re = r.getDataView().getEntry(keyInfo, r, true);
         if(re==null) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 21590f6..124c9b5 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
@@ -122,9 +122,6 @@ public final class RemoteFetchVersionMessage extends RemoteOperationMessage {
     }
     VersionTag tag;
     try {
-      if (r.keyRequiresRegionContext()) {
-        ((KeyWithRegionContext) this.key).setRegionContext(r);
-      }
       RegionEntry re = r.getRegionEntry(key);
       if (re == null) {
         if (logger.isTraceEnabled(LogMarker.DM)) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 7e2be1f..05d62d4 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
@@ -118,9 +118,6 @@ public final class RemoteGetMessage extends RemoteOperationMessageWithDirectRepl
     RawValue valueBytes;
     Object val = null;
       try {
-        if (r.keyRequiresRegionContext()) {
-          ((KeyWithRegionContext)this.key).setRegionContext(r);
-        }
         KeyInfo keyInfo = r.getKeyInfo(key, cbArg);
         val = r.getDataView().getSerializedValue(r, keyInfo, false, this.context, null, false /*for replicate regions*/);
         valueBytes = val instanceof RawValue ? (RawValue)val : new RawValue(val);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 f975f6f..a4e020e 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
@@ -188,9 +188,6 @@ public final class RemoteInvalidateMessage extends RemoteDestroyMessage {
        eventSender = getSender();
     }
     final Object key = getKey();
-    if (r.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext)key).setRegionContext(r);
-    }
     @Released final EntryEventImpl event = EntryEventImpl.create(
         r,
         getOperation(),

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/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 045e51c..c0c56c9 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
@@ -82,7 +82,6 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
 
   protected static final short HAS_BRIDGE_CONTEXT = UNRESERVED_FLAGS_START;
   protected static final short SKIP_CALLBACKS = (HAS_BRIDGE_CONTEXT << 1);
-  protected static final short IS_PUT_DML = (SKIP_CALLBACKS << 1);
 
   private EventID eventId;
   
@@ -92,8 +91,6 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
 
 //  private boolean useOriginRemote;
 
-  private boolean isPutDML;
-  
   public void addEntry(PutAllEntryData entry) {
     this.putAllData[this.putAllDataCount++] = entry;
   }
@@ -190,7 +187,6 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
     this.eventId = event.getEventId();
     this.skipCallbacks = skipCallbacks;
     this.callbackArg = event.getCallbackArgument();
-	this.isPutDML = event.isPutDML();
   }
 
   public RemotePutAllMessage() {
@@ -241,7 +237,6 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
       this.bridgeContext = DataSerializer.readObject(in);
     }
     this.skipCallbacks = (flags & SKIP_CALLBACKS) != 0;
-    this.isPutDML = (flags & IS_PUT_DML) != 0;
     this.putAllDataCount = (int)InternalDataSerializer.readUnsignedVL(in);
     this.putAllData = new PutAllEntryData[putAllDataCount];
     if (this.putAllDataCount > 0) {
@@ -279,10 +274,6 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
       EntryVersionsList versionTags = new EntryVersionsList(putAllDataCount);
 
       boolean hasTags = false;
-      // get the "keyRequiresRegionContext" flag from first element assuming
-      // all key objects to be uniform
-      final boolean requiresRegionContext =
-        (this.putAllData[0].key instanceof KeyWithRegionContext);
       for (int i = 0; i < this.putAllDataCount; i++) {
         if (!hasTags && putAllData[i].versionTag != null) {
           hasTags = true;
@@ -290,7 +281,7 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
         VersionTag<?> tag = putAllData[i].versionTag;
         versionTags.add(tag);
         putAllData[i].versionTag = null;
-        this.putAllData[i].toData(out, requiresRegionContext);
+        this.putAllData[i].toData(out);
         this.putAllData[i].versionTag = tag;
       }
 
@@ -307,7 +298,6 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
     if (this.posDup) flags |= POS_DUP;
     if (this.bridgeContext != null) flags |= HAS_BRIDGE_CONTEXT;
     if (this.skipCallbacks) flags |= SKIP_CALLBACKS;
-    if (this.isPutDML) flags |= IS_PUT_DML;
     return flags;
   }
 
@@ -370,7 +360,6 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
       baseEvent.setContext(this.bridgeContext);
     }
     baseEvent.setPossibleDuplicate(this.posDup);
-	baseEvent.setPutDML(this.isPutDML);
     if (logger.isDebugEnabled()) {
       logger.debug("RemotePutAllMessage.doLocalPutAll: eventSender is {}, baseEvent is {}, msg is {}",
           eventSender, baseEvent, this);
@@ -384,7 +373,7 @@ public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectR
 //        final boolean requiresRegionContext = dr.keyRequiresRegionContext();
         InternalDistributedMember myId = r.getDistributionManager().getDistributionManagerId();
         for (int i = 0; i < putAllDataCount; ++i) {
-          @Released EntryEventImpl ev = PutAllPRMessage.getEventFromEntry(r, myId, eventSender, i, putAllData, false, bridgeContext, posDup, !skipCallbacks, isPutDML);
+          @Released EntryEventImpl ev = PutAllPRMessage.getEventFromEntry(r, myId, eventSender, i, putAllData, false, bridgeContext, posDup, !skipCallbacks);
           try {
           ev.setPutAllOperation(dpao);
           if (logger.isDebugEnabled()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutMessage.java
index 678927d..34d3585 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutMessage.java
@@ -135,8 +135,7 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
   
   /**
    * Indicates if and when the new value should be deserialized on the
-   * the receiver. Distinguishes between Deltas which need to be eagerly
-   * deserialized (DESERIALIZATION_POLICY_EAGER), a non-byte[] value that was
+   * the receiver. Distinguishes between a non-byte[] value that was
    * serialized (DESERIALIZATION_POLICY_LAZY) and a
    * byte[] array value that didn't need to be serialized
    * (DESERIALIZATION_POLICY_NONE). While this seems like an extra data, it
@@ -252,11 +251,7 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
     event.setOriginRemote(useOriginRemote);
 
     if (event.hasNewValue()) {
-      if (CachedDeserializableFactory.preferObject() || event.hasDelta()) {
-        this.deserializationPolicy = DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER;
-      } else {
-        this.deserializationPolicy = DistributedCacheOperation.DESERIALIZATION_POLICY_LAZY;
-      }
+      this.deserializationPolicy = DistributedCacheOperation.DESERIALIZATION_POLICY_LAZY;
       event.exportNewValue(this);
     }
     else {
@@ -568,13 +563,7 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
       this.oldValueIsSerialized = (in.readByte() == 1);
       setOldValBytes(DataSerializer.readByteArray(in));
     }
-    if (this.deserializationPolicy ==
-        DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER) {
-      setValObj(DataSerializer.readObject(in));
-    }
-    else {
-      setValBytes(DataSerializer.readByteArray(in));
-    }
+    setValBytes(DataSerializer.readByteArray(in));
     if ((flags & HAS_DELTA_BYTES) != 0) {
       this.applyDeltaBytes = true;
       this.deltaBytes = DataSerializer.readByteArray(in);
@@ -681,9 +670,6 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
     if (eventSender == null) {
        eventSender = getSender();
     }
-    if (r.keyRequiresRegionContext()) {
-      ((KeyWithRegionContext)this.key).setRegionContext(r);
-    }
     @Released EntryEventImpl eei = EntryEventImpl.create(
         r,
         getOperation(),
@@ -732,10 +718,6 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
         case DistributedCacheOperation.DESERIALIZATION_POLICY_NONE:
           event.setNewValue(getValBytes());
           break;
-        case DistributedCacheOperation.DESERIALIZATION_POLICY_EAGER:
-          // new value is a Delta
-          event.setNewValue(this.valObj); // sets the delta field
-          break;
         default:
           throw new AssertionError("unknown deserialization policy: "
               + deserializationPolicy);
@@ -1212,12 +1194,8 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
   
   private void setOldValueIsSerialized(boolean isSerialized) {
     if (isSerialized) {
-      if (CachedDeserializableFactory.preferObject()) {
-        this.oldValueIsSerialized = true; //VALUE_IS_OBJECT;
-      } else {
-        // Defer serialization until toData is called.
-        this.oldValueIsSerialized = true; //VALUE_IS_SERIALIZED_OBJECT;
-      }
+      // Defer serialization until toData is called.
+      this.oldValueIsSerialized = true; //VALUE_IS_SERIALIZED_OBJECT;
     } else {
       this.oldValueIsSerialized = false; //VALUE_IS_BYTES;
     }



[03/17] incubator-geode git commit: GEODE-1331: gfsh.bat on Windows is incorrect.

Posted by kl...@apache.org.
GEODE-1331: gfsh.bat on Windows is incorrect.

* Renamed internal variable from CLASSPATH to DEPENDENCIES.
* Verified @setlocal was not altering the System environment variables for the shell.
* Launch with -classpath param like the bash script does.
* Ensured command-line arguments match bash script's order of arguments.
* This closes #149


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/8e21638c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/8e21638c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/8e21638c

Branch: refs/heads/feature/GEODE-837
Commit: 8e21638ce336aee07bec33d140500c76d1cedc53
Parents: 41d9cff
Author: Kevin J. Duling <kd...@pivotal.io>
Authored: Thu May 26 09:46:03 2016 -0700
Committer: Jinmei Liao <ji...@pivotal.io>
Committed: Mon Jun 6 09:05:07 2016 -0700

----------------------------------------------------------------------
 geode-assembly/src/main/dist/bin/gfsh.bat | 33 +++++++++++++-------------
 1 file changed, 16 insertions(+), 17 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8e21638c/geode-assembly/src/main/dist/bin/gfsh.bat
----------------------------------------------------------------------
diff --git a/geode-assembly/src/main/dist/bin/gfsh.bat b/geode-assembly/src/main/dist/bin/gfsh.bat
index 6813243..706146a 100755
--- a/geode-assembly/src/main/dist/bin/gfsh.bat
+++ b/geode-assembly/src/main/dist/bin/gfsh.bat
@@ -37,25 +37,22 @@ REM echo %scriptdir%
 :gfok
 @set GEMFIRE=%gf%
 
-@set GEMFIRE_JARS=%GEMFIRE%\lib\gfsh-dependencies.jar
+@set GFSH_JARS=%GEMFIRE%\lib\gfsh-dependencies.jar
+REM if a system level classpath is set, append it to the classes gfsh will need
 @if defined CLASSPATH (
-@set GEMFIRE_JARS=%GEMFIRE_JARS%;%CLASSPATH%
+    @set DEPENDENCIES=%GFSH_JARS%;%CLASSPATH%
+) else (
+    @set DEPENDENCIES=%GFSH_JARS%
 )
 
 @if not defined GF_JAVA (
-@REM %GF_JAVA% is not defined, assume it is on the PATH
-@if defined JAVA_HOME (
-@set GF_JAVA=%JAVA_HOME%\bin\java.exe
+REM %GF_JAVA% is not defined, assume it is on the PATH
+    @if defined JAVA_HOME (
+    @set GF_JAVA=%JAVA_HOME%\bin\java.exe
 ) else (
-@set GF_JAVA=java
+    @set GF_JAVA=java
+  )
 )
-) 
-
-REM
-REM GFSH_JARS
-REM
-@set GFSH_JARS=;%GEMFIRE%\lib\gfsh-dependencies.jar
-@set CLASSPATH=%GFSH_JARS%;%GEMFIRE_JARS%
 
 REM
 REM Copy default .gfshrc to the home directory. Uncomment if needed.
@@ -71,17 +68,19 @@ REM @if not exist "%USERPROFILE%\.gemfire" (
 REM @mkdir "%USERPROFILE%\.gemfire"
 REM )
 
-REM  Consider java is from JDK
+REM  Expect to find the tools.jar from the JDK
 @set TOOLS_JAR=%JAVA_HOME%\lib\tools.jar
 @IF EXIST "%TOOLS_JAR%" (
-    @set CLASSPATH=%CLASSPATH%;%TOOLS_JAR%
+    @set DEPENDENCIES=%DEPENDENCIES%;%TOOLS_JAR%
 ) ELSE (
     set TOOLS_JAR=
 )
 
 @set LAUNCHER=com.gemstone.gemfire.management.internal.cli.Launcher
 @if defined JAVA_ARGS (
-@set JAVA_ARGS="%JAVA_ARGS%"
+    @set JAVA_ARGS="%JAVA_ARGS%"
 )
-@"%GF_JAVA%" -Dgfsh=true -Dlog4j.configurationFile=classpath:log4j2-cli.xml %JAVA_ARGS% %LAUNCHER% %*
+
+REM Call java with our classpath
+@"%GF_JAVA%" -Dgfsh=true -Dlog4j.configurationFile=classpath:log4j2-cli.xml -classpath %DEPENDENCIES% %JAVA_ARGS% %LAUNCHER% %*
 :done


[08/17] incubator-geode git commit: GEODE-1498 CI Failure: DurableClientCommandsDUnitTest.testCloseDurableClients

Posted by kl...@apache.org.
GEODE-1498 CI Failure: DurableClientCommandsDUnitTest.testCloseDurableClients

Use port 0 for cache server and return a random available port for durable client.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/6967ac19
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/6967ac19
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/6967ac19

Branch: refs/heads/feature/GEODE-837
Commit: 6967ac19f2a53cf4c71b69ae06ff8fb39003de4f
Parents: 0815e1b
Author: Jianxia Chen <jc...@pivotal.io>
Authored: Mon Jun 6 13:45:15 2016 -0700
Committer: Jianxia Chen <jc...@pivotal.io>
Committed: Mon Jun 6 13:45:15 2016 -0700

----------------------------------------------------------------------
 .../cli/commands/DurableClientCommandsDUnitTest.java   | 13 +++++++------
 1 file changed, 7 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/6967ac19/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
index c51f875..e8a5577 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
@@ -239,15 +239,14 @@ public class DurableClientCommandsDUnitTest extends CliCommandTestBase {
   
   private void setupSystem() throws Exception {
     disconnectAllFromDS();
-    final int[] port = AvailablePortHelper.getRandomAvailableTCPPorts(2);
     setUpJmxManagerOnVm0ThenConnect(getServerProperties());
     
     final VM manager = Host.getHost(0).getVM(0);
     final VM server1 = Host.getHost(0).getVM(1);
     final VM client1 = Host.getHost(0).getVM(2);
     
-    startCacheServer(server1, port[0], false, regionName);
-    startDurableClient(client1, server1, port[0], clientName, "300");
+    int listeningPort = startCacheServer(server1, 0, false, regionName);
+    startDurableClient(client1, server1, listeningPort, clientName, "300");
   }
   
   /**
@@ -303,10 +302,10 @@ public class DurableClientCommandsDUnitTest extends CliCommandTestBase {
     });
   }
   
-  private void startCacheServer(VM server, final int port, 
+  private int startCacheServer(VM server, final int port,
       final boolean createPR, final String regionName) throws Exception {
 
-    server.invoke(new SerializableCallable() {
+    Integer listeningPort = (Integer) server.invoke(new SerializableCallable() {
       public Object call() throws Exception {
         getSystem(getServerProperties());
         
@@ -331,9 +330,11 @@ public class DurableClientCommandsDUnitTest extends CliCommandTestBase {
         cacheServer.setPort(port);
         cacheServer.start();
        
-        return null;
+        return cacheServer.getPort();
       }
     });
+
+    return listeningPort.intValue();
   }
   
   private void startDurableClient(VM client, final VM server, final int port,


[15/17] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-837

Posted by kl...@apache.org.
Merge remote-tracking branch 'origin/develop' into feature/GEODE-837


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/5c048b38
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/5c048b38
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/5c048b38

Branch: refs/heads/feature/GEODE-837
Commit: 5c048b388d61ca3685af5f9425e53e406ee080cf
Parents: 1c41d7c 103a6bc
Author: Kirk Lund <kl...@apache.org>
Authored: Tue Jun 7 14:38:57 2016 -0700
Committer: Kirk Lund <kl...@apache.org>
Committed: Tue Jun 7 14:38:57 2016 -0700

----------------------------------------------------------------------
 geode-assembly/src/main/dist/bin/gfsh.bat       |  33 +-
 .../cache/query/internal/IndexUpdater.java      | 123 ----
 .../internal/DistributionMessage.java           |   2 +-
 .../internal/InternalDistributedSystem.java     |  43 +-
 .../distributed/internal/ReplyProcessor21.java  |   6 +-
 .../com/gemstone/gemfire/internal/DSCODE.java   |  16 +-
 .../gemstone/gemfire/internal/DSFIDFactory.java | 187 -------
 .../internal/DataSerializableFixedID.java       |  58 +-
 .../gemfire/internal/GemFireUtilLauncher.java   | 165 ------
 .../internal/InternalDataSerializer.java        |   7 -
 .../gemstone/gemfire/internal/SystemAdmin.java  |   2 -
 .../com/gemstone/gemfire/internal/Version.java  |  21 +-
 .../gemfire/internal/VersionedDataStream.java   |   5 +-
 .../internal/cache/AbstractDiskRegionEntry.java |   5 -
 .../internal/cache/AbstractRegionEntry.java     |  30 +-
 .../internal/cache/AbstractRegionMap.java       | 238 +-------
 .../gemfire/internal/cache/BucketAdvisor.java   |   6 -
 .../gemfire/internal/cache/BucketRegion.java    |  45 +-
 .../cache/CacheDistributionAdvisor.java         |  50 +-
 .../internal/cache/CacheServerLauncher.java     |   2 +-
 .../internal/cache/CacheServiceProfile.java     |  40 ++
 .../cache/CachedDeserializableFactory.java      |   7 -
 .../internal/cache/ColocationHelper.java        |  67 +--
 .../internal/cache/CreateRegionProcessor.java   |  23 +-
 .../internal/cache/DestroyOperation.java        |   3 -
 .../gemfire/internal/cache/DiskEntry.java       | 152 +----
 .../gemfire/internal/cache/DiskInitFile.java    |   2 -
 .../gemfire/internal/cache/DiskRegion.java      |   2 -
 .../internal/cache/DiskWriteAttributesImpl.java |  91 ---
 .../gemfire/internal/cache/DistTXState.java     |   4 +-
 .../cache/DistTXStateOnCoordinator.java         |   2 +-
 .../cache/DistributedCacheOperation.java        |  31 +-
 .../cache/DistributedPutAllOperation.java       |  52 +-
 .../internal/cache/DistributedRegion.java       |  37 +-
 ...stributedRegionFunctionStreamingMessage.java |   2 -
 .../cache/DistributedRemoveAllOperation.java    |  24 +-
 .../gemfire/internal/cache/EntryBits.java       |  22 -
 .../gemfire/internal/cache/EntryEventImpl.java  | 255 +--------
 .../internal/cache/EntryOperationImpl.java      |  15 +-
 .../internal/cache/GemFireCacheImpl.java        | 161 +++---
 .../gemfire/internal/cache/GridAdvisor.java     |   6 +-
 .../internal/cache/InitialImageOperation.java   |  96 +---
 .../internal/cache/InternalRegionArguments.java |  38 +-
 .../internal/cache/InvalidateOperation.java     |   3 -
 .../gemfire/internal/cache/KeyInfo.java         |   5 +-
 .../internal/cache/KeyWithRegionContext.java    |  70 ---
 .../gemfire/internal/cache/ListOfDeltas.java    | 100 ----
 .../gemfire/internal/cache/LocalRegion.java     | 142 +----
 .../gemstone/gemfire/internal/cache/Oplog.java  |  24 +-
 .../internal/cache/PRHARedundancyProvider.java  |   8 -
 .../internal/cache/PartitionAttributesImpl.java |  10 -
 .../internal/cache/PartitionedRegion.java       | 288 +---------
 .../cache/PartitionedRegionDataStore.java       |  16 -
 .../gemfire/internal/cache/ProxyRegionMap.java  |  23 +-
 .../gemfire/internal/cache/QueuedOperation.java |  16 +-
 .../gemfire/internal/cache/RegionEntry.java     |   6 +-
 .../gemfire/internal/cache/RegionMap.java       |   8 +-
 .../cache/RemoteContainsKeyValueMessage.java    |   3 -
 .../internal/cache/RemoteDestroyMessage.java    |  13 +-
 .../internal/cache/RemoteFetchEntryMessage.java |   3 -
 .../cache/RemoteFetchVersionMessage.java        |   3 -
 .../internal/cache/RemoteGetMessage.java        |   3 -
 .../internal/cache/RemoteInvalidateMessage.java |   3 -
 .../internal/cache/RemotePutAllMessage.java     |  15 +-
 .../internal/cache/RemotePutMessage.java        |  32 +-
 .../internal/cache/RemoteRemoveAllMessage.java  |   6 +-
 .../cache/SearchLoadAndWriteProcessor.java      |   3 -
 .../gemfire/internal/cache/TXEntry.java         |  11 -
 .../gemfire/internal/cache/TXEntryState.java    |  32 +-
 .../gemfire/internal/cache/TXManagerImpl.java   |  20 +-
 .../internal/cache/TXRegionLockRequestImpl.java |  14 +-
 .../gemfire/internal/cache/TXRegionState.java   |   5 -
 .../gemfire/internal/cache/TXState.java         |   5 +-
 .../internal/cache/TXStateInterface.java        |   1 -
 .../cache/UpdateAttributesProcessor.java        |   9 +-
 .../cache/UpdateEntryVersionOperation.java      |   5 -
 .../gemfire/internal/cache/UpdateOperation.java |  36 +-
 .../internal/cache/ValidatingDiskRegion.java    |   3 -
 .../internal/cache/WrappedCallbackArgument.java |  26 +-
 .../gemfire/internal/cache/delta/Delta.java     |  56 --
 .../cache/execute/AbstractExecution.java        |  18 -
 .../FunctionStreamingResultCollector.java       |   3 +-
 .../cache/execute/InternalExecution.java        |  27 +-
 .../cache/execute/InternalFunctionService.java  |   2 +-
 .../execute/InternalRegionFunctionContext.java  |   5 -
 .../cache/execute/MemberFunctionExecutor.java   |   7 -
 .../execute/MultiRegionFunctionExecutor.java    |   7 -
 .../execute/RegionFunctionContextImpl.java      |  13 -
 .../cache/execute/ServerFunctionExecutor.java   |   7 -
 .../partitioned/ContainsKeyValueMessage.java    |   4 -
 .../cache/partitioned/DestroyMessage.java       |   4 -
 .../partitioned/FetchBulkEntriesMessage.java    |   6 -
 .../cache/partitioned/FetchEntriesMessage.java  |   6 -
 .../cache/partitioned/FetchEntryMessage.java    |   4 -
 .../cache/partitioned/FetchKeysMessage.java     |   6 -
 .../internal/cache/partitioned/GetMessage.java  |  16 +-
 .../cache/partitioned/InvalidateMessage.java    |   4 -
 .../cache/partitioned/PREntriesIterator.java    |   8 +-
 .../PRUpdateEntryVersionMessage.java            |   5 -
 .../cache/partitioned/PartitionMessage.java     |  20 +-
 .../cache/partitioned/PutAllPRMessage.java      |  26 +-
 .../internal/cache/partitioned/PutMessage.java  |  36 +-
 .../cache/partitioned/RegionAdvisor.java        |  17 -
 .../partitioned/RemoteFetchKeysMessage.java     |   6 -
 .../cache/partitioned/RemoveAllPRMessage.java   |  11 +-
 .../rebalance/PartitionedRegionLoadModel.java   |  19 +-
 .../sockets/command/GatewayReceiverCommand.java |  13 -
 .../tier/sockets/command/RollbackCommand.java   |   5 +
 .../internal/cache/tx/DistTxEntryEvent.java     |  14 +-
 .../cache/wan/AbstractGatewaySender.java        |   2 +-
 .../AbstractGatewaySenderEventProcessor.java    |   2 +-
 .../wan/GatewaySenderEventCallbackArgument.java |   8 +-
 .../cache/wan/GatewaySenderEventImpl.java       |  13 +-
 .../parallel/ParallelGatewaySenderQueue.java    |   9 +-
 .../cache/xmlcache/AsyncEventQueueCreation.java |   3 +-
 .../xmlcache/RegionAttributesCreation.java      |   2 -
 .../gemfire/internal/i18n/LocalizedStrings.java |  21 +-
 .../internal/logging/LoggingThreadGroup.java    |   2 -
 .../internal/logging/ManagerLogWriter.java      |  34 --
 .../gemfire/internal/logging/PureLogWriter.java |   2 -
 .../gemfire/internal/offheap/OffHeapHelper.java |   1 -
 .../offheap/ReferenceCountHelperImpl.java       |   1 -
 .../offheap/annotations/OffHeapIdentifier.java  |   4 -
 .../gemfire/internal/shared/NativeCalls.java    |  33 +-
 .../gemfire/internal/util/ArrayUtils.java       |   2 +-
 .../CustomEntryConcurrentHashMap.java           |   2 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  | 138 -----
 .../gemfire/distributed/LocatorDUnitTest.java   |   2 +-
 .../disttx/DistributedTransactionDUnitTest.java |  13 -
 ...wardCompatibilitySerializationDUnitTest.java |   9 -
 .../PartitionedRegionTestUtilsDUnitTest.java    |  43 +-
 .../internal/cache/TXManagerImplTest.java       |  70 ++-
 .../execute/PRCustomPartitioningDUnitTest.java  |   3 +-
 .../FetchEntriesMessageJUnitTest.java           |   1 -
 .../cache/wan/MyAsyncEventListener.java         |   7 +-
 .../cache/wan/MyGatewayEventFilter.java         |  69 +++
 .../AsyncEventQueueValidationsJUnitTest.java    |  56 ++
 .../gemfire/test/dunit/standalone/ChildVM.java  |  28 +-
 geode-core/src/test/java/hydra/GsRandom.java    | 311 -----------
 .../test/java/hydra/HydraRuntimeException.java  |  33 --
 geode-core/src/test/java/hydra/Log.java         | 219 --------
 .../src/test/java/hydra/LogVersionHelper.java   |  45 --
 .../src/test/java/hydra/log/AnyLogWriter.java   | 555 -------------------
 .../java/hydra/log/CircularOutputStream.java    | 131 -----
 .../parReg/query/unittest/NewPortfolio.java     |  37 +-
 .../src/test/java/perffmwk/Formatter.java       |  14 +-
 .../sanctionedDataSerializables.txt             | 173 +++---
 .../codeAnalysis/sanctionedSerializables.txt    |   1 -
 ...ntQueueConfiguredFromXmlUsesFilter.cache.xml |  40 ++
 ...ntQueueConfiguredFromXmlUsesFilter.cache.xml |  40 ++
 .../PartitionedRegionCqQueryDUnitTest.java      | 135 ++---
 .../DurableClientCommandsDUnitTest.java         |  13 +-
 .../internal/LuceneIndexCreationProfile.java    | 189 +++++++
 .../lucene/internal/LuceneServiceImpl.java      |  15 +-
 .../internal/xml/LuceneIndexCreation.java       |   9 +-
 .../gemfire/cache/lucene/LuceneDUnitTest.java   |  38 ++
 .../lucene/LuceneIndexCreationDUnitTest.java    | 281 ++++++++++
 .../gemfire/cache/lucene/LuceneQueriesBase.java |  18 +-
 .../LuceneIndexCreationProfileJUnitTest.java    | 144 +++++
 .../cache/lucene/test/LuceneTestUtilities.java  |  11 +
 ...ifferentFieldAnalyzerSizesFails1.1.cache.xml |  37 ++
 ...ifferentFieldAnalyzerSizesFails1.2.cache.xml |  36 ++
 ...ifferentFieldAnalyzerSizesFails2.1.cache.xml |  36 ++
 ...ifferentFieldAnalyzerSizesFails2.2.cache.xml |  37 ++
 ...ifyDifferentFieldAnalyzersFails1.1.cache.xml |  36 ++
 ...ifyDifferentFieldAnalyzersFails1.2.cache.xml |  36 ++
 ...ifyDifferentFieldAnalyzersFails2.1.cache.xml |  37 ++
 ...ifyDifferentFieldAnalyzersFails2.2.cache.xml |  37 ++
 ...ifyDifferentFieldAnalyzersFails3.1.cache.xml |  37 ++
 ...ifyDifferentFieldAnalyzersFails3.2.cache.xml |  37 ++
 ...tTest.verifyDifferentFieldsFails.1.cache.xml |  36 ++
 ...tTest.verifyDifferentFieldsFails.2.cache.xml |  37 ++
 ...t.verifyDifferentIndexNamesFails.1.cache.xml |  36 ++
 ...t.verifyDifferentIndexNamesFails.2.cache.xml |  36 ++
 ...est.verifyDifferentIndexesFails1.1.cache.xml |  36 ++
 ...est.verifyDifferentIndexesFails1.2.cache.xml |  32 ++
 ...est.verifyDifferentIndexesFails2.1.cache.xml |  36 ++
 ...est.verifyDifferentIndexesFails2.2.cache.xml |  39 ++
 178 files changed, 2220 insertions(+), 4987 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
index b56f84a,4ecf3e3..37ff587
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
@@@ -106,8 -107,9 +106,7 @@@ import com.gemstone.gemfire.internal.ca
  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;
  import com.gemstone.gemfire.internal.cache.versions.VersionTag;
  import com.gemstone.gemfire.internal.logging.LogService;
  import com.gemstone.gemfire.internal.offheap.MemoryAllocatorImpl;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
index 76d5603,06d0e08..1684586
--- a/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
@@@ -59,22 -28,16 +59,19 @@@ import com.gemstone.gemfire.internal.ca
  import com.gemstone.gemfire.internal.cache.execute.data.Customer;
  import com.gemstone.gemfire.internal.cache.execute.data.Order;
  import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 -import com.gemstone.gemfire.test.dunit.*;
 -
 -import java.util.HashMap;
 -import java.util.Map;
 -import java.util.Properties;
 -import java.util.Set;
 -import java.util.concurrent.CountDownLatch;
 +import com.gemstone.gemfire.test.dunit.Assert;
 +import com.gemstone.gemfire.test.dunit.Host;
 +import com.gemstone.gemfire.test.dunit.Invoke;
 +import com.gemstone.gemfire.test.dunit.LogWriterUtils;
 +import com.gemstone.gemfire.test.dunit.SerializableCallable;
 +import com.gemstone.gemfire.test.dunit.VM;
 +import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
 +import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
- /**
-  * Port of GemFireXD's corresponding test for distributed transactions
-  */
  @SuppressWarnings("deprecation")
 -public class DistributedTransactionDUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class DistributedTransactionDUnitTest extends JUnit4CacheTestCase {
 +
    final protected String CUSTOMER_PR = "customerPRRegion";
    final protected String ORDER_PR = "orderPRRegion";
    final protected String D_REFERENCE = "distrReference";
@@@ -374,15 -337,9 +371,7 @@@
      });
    }
    
--  
--
--  
-   /**
-    * From GemFireXD: testTransactionalInsertOnReplicatedTable
-    * 
-    * @throws Exception
-    */
 +  @Test
    public void testTransactionalPutOnReplicatedRegion() throws Exception {
      Host host = Host.getHost(0);
      VM server1 = host.getVM(0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-core/src/test/java/com/gemstone/gemfire/internal/BackwardCompatibilitySerializationDUnitTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
index 3bb3ecb,d1083ad..1bd35f9
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
@@@ -17,26 -17,15 +17,20 @@@
  
  package com.gemstone.gemfire.internal.cache;
  
- import org.junit.experimental.categories.Category;
- import org.junit.Test;
- 
 +import static org.junit.Assert.*;
 +
- import com.gemstone.gemfire.test.dunit.cache.internal.JUnit4CacheTestCase;
- import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
- import com.gemstone.gemfire.test.junit.categories.DistributedTest;
- 
- import hydra.GsRandom;
- 
  import java.io.DataInput;
  import java.io.DataOutput;
  import java.io.IOException;
  import java.io.Serializable;
- import java.util.HashSet;
  import java.util.Iterator;
  import java.util.List;
+ import java.util.Random;
  import java.util.Set;
  
++import org.junit.Test;
++import org.junit.experimental.categories.Category;
++
  import com.gemstone.gemfire.DataSerializable;
  import com.gemstone.gemfire.cache.AttributesFactory;
  import com.gemstone.gemfire.cache.Cache;
@@@ -49,27 -38,25 +43,23 @@@ import com.gemstone.gemfire.test.dunit.
  import com.gemstone.gemfire.test.dunit.Host;
  import com.gemstone.gemfire.test.dunit.LogWriterUtils;
  import com.gemstone.gemfire.test.dunit.VM;
++import com.gemstone.gemfire.test.junit.categories.DistributedTest;
  
  /**
   * Confirm that the utils used for testing work as advertised
-- * @since GemFire 5.0
   *
++ * @since GemFire 5.0
   */
 -public class PartitionedRegionTestUtilsDUnitTest extends
 -    PartitionedRegionDUnitTestCase
 -{
 +@Category(DistributedTest.class)
- public class PartitionedRegionTestUtilsDUnitTest extends
-     PartitionedRegionDUnitTestCase
- {
++public class PartitionedRegionTestUtilsDUnitTest extends PartitionedRegionDUnitTestCase {
++
    final int totalNumBuckets = 5;
-   public PartitionedRegionTestUtilsDUnitTest() {
-     super();
 -  public PartitionedRegionTestUtilsDUnitTest(String name) {
 -    super(name);
--  }
  
    /**
     * Test the {@link PartitionedRegion#getSomeKeys(java.util.Random)} method, making sure it 
     * returns keys when there are keys and {@link java.util.Collections#EMPTY_SET} when there are none.
--   * @throws Exception
     */
 +  @Test
    public void testGetKeys() throws Exception {
      final String r = getUniqueName();
      Host host = Host.getHost(0);
@@@ -153,7 -140,7 +143,6 @@@
     * Verify that it returns nodes after a value has been placed into the PartitionedRegion.
     * @see PartitionedRegion#getAllNodes()
     */
--  
    public static class TestGetNodesKey implements DataSerializable {
      int hc; 
      public TestGetNodesKey(int hc) { this.hc = hc; }
@@@ -162,7 -149,6 +151,8 @@@
      public void toData(DataOutput out) throws IOException  {out.writeInt(this.hc); }
      public void fromData(DataInput in) throws IOException, ClassNotFoundException { this.hc = in.readInt(); } 
    }
++
 +  @Test
    public void testGetNodes() throws Exception {
      final String r = getUniqueName();
      Host host = Host.getHost(0);
@@@ -202,7 -188,7 +192,6 @@@
        }
      };
  
--    
      validator.invoke(createAndTest);
      validator.invoke(new CacheSerializableRunnable("AssertGetNodesCreation1") {
        public void run2() throws CacheException
@@@ -243,15 -229,14 +232,13 @@@
    }
  
    /** 
--   * Test the test utiltities that allow investigation of a PartitionedRegion's local cache. 
--   * @throws Exception
++   * Test the test utilities that allow investigation of a PartitionedRegion's local cache.
     */
 +  @Test
    public void testLocalCacheOps() throws Exception {
      final String r = getUniqueName();
      Host host = Host.getHost(0);
      VM vm0 = host.getVM(0);
--//    VM vm1 = host.getVM(1);
      VM vm2 = host.getVM(2);
      
      vm0.invoke(new CacheSerializableRunnable("CreatePR") {
@@@ -358,10 -343,9 +345,8 @@@
     * Test the test method PartitionedRegion.getAllNodes
     * Verify that it returns nodes after a value has been placed into the PartitionedRegion.
     * @see PartitionedRegion#getAllNodes()
--   * 
--   * @throws Exception
     */
 +  @Test
    public void testGetBucketKeys() throws Exception {
      final String r = getUniqueName();
      Host host = Host.getHost(0);
@@@ -454,9 -438,8 +439,8 @@@
    /**
     * Test the test method {@link PartitionedRegion#getBucketOwnersForValidation(int)}
     * Verify that the information it discovers is the same as the local advisor.
--   * @throws Exception
     */
 +  @Test
    public void testGetBucketOwners() throws Exception {
      final String rName0 = getUniqueName() + "-r0";
      final String rName1 = getUniqueName() + "-r1";
@@@ -585,6 -568,6 +569,5 @@@
      datastore1.invoke(oneBucketOwner);
      datastore2.invoke(oneBucketOwner);
      datastore3.invoke(oneBucketOwner);
--
    }
  }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
----------------------------------------------------------------------
diff --cc geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
index e8ecdc9,3055c8e..5d2e8ac
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueValidationsJUnitTest.java
@@@ -19,20 -19,39 +19,35 @@@
   */
  package com.gemstone.gemfire.internal.cache.wan.asyncqueue;
  
 +import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
++import static junitparams.JUnitParamsRunner.*;
 +import static org.junit.Assert.*;
 +
++import java.util.List;
++import java.util.concurrent.TimeUnit;
++
++import com.jayway.awaitility.Awaitility;
++import junitparams.JUnitParamsRunner;
++import junitparams.Parameters;
++import org.junit.After;
 +import org.junit.Test;
 +import org.junit.experimental.categories.Category;
++import org.junit.runner.RunWith;
 +
  import com.gemstone.gemfire.cache.Cache;
  import com.gemstone.gemfire.cache.CacheFactory;
+ import com.gemstone.gemfire.cache.Region;
+ import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
  import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueueFactory;
+ import com.gemstone.gemfire.cache.wan.GatewayEventFilter;
  import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
  import com.gemstone.gemfire.internal.cache.wan.AsyncEventQueueConfigurationException;
+ import com.gemstone.gemfire.internal.cache.wan.MyGatewayEventFilter;
  import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+ import com.gemstone.gemfire.util.test.TestUtil;
 -import com.jayway.awaitility.Awaitility;
 -import junitparams.JUnitParamsRunner;
 -import junitparams.Parameters;
 -import org.junit.After;
 -import org.junit.Test;
 -import org.junit.experimental.categories.Category;
 -import org.junit.runner.RunWith;
  
 -import java.util.List;
 -import java.util.concurrent.TimeUnit;
 -
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.CACHE_XML_FILE;
 -import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.MCAST_PORT;
 -import static junitparams.JUnitParamsRunner.$;
 -import static org.junit.Assert.assertTrue;
 -import static org.junit.Assert.fail;
 -
 -/**
 - *
 - */
  @Category(IntegrationTest.class)
+ @RunWith(JUnitParamsRunner.class)
  public class AsyncEventQueueValidationsJUnitTest {
  
    private Cache cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5c048b38/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
----------------------------------------------------------------------
diff --cc geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
index 378986a,f306cb9..2b34dbd
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
@@@ -17,8 -17,6 +17,7 @@@
  package com.gemstone.gemfire.cache.query.cq.dunit;
  
  import static com.gemstone.gemfire.distributed.DistributedSystemConfigProperties.*;
 +import static com.gemstone.gemfire.test.dunit.Assert.*;
- import static com.gemstone.gemfire.test.dunit.LogWriterUtils.*;
  
  import java.io.IOException;
  import java.util.HashSet;
@@@ -65,17 -59,20 +64,17 @@@ import com.gemstone.gemfire.test.junit.
   * 
   * @since GemFire 5.5
   */
 -public class PartitionedRegionCqQueryDUnitTest extends CacheTestCase {
 +@Category(DistributedTest.class)
 +public class PartitionedRegionCqQueryDUnitTest extends JUnit4CacheTestCase {
  
 -  public PartitionedRegionCqQueryDUnitTest(String name) {
 -    super(name);
 -  }
 -  
--  static public final String[] regions = new String[] {
++  public static final String[] regions = new String[] {
        "regionA",
        "regionB"
    };
-   
-   static public final String KEY = "key-";
++
++  public static final String KEY = "key-";
    
 -  static public final String KEY = "key-";
 -  
 -  protected final CqQueryDUnitTest cqHelper = new CqQueryDUnitTest("HelperPartitonedRegionCqTest");
 +  protected final CqQueryDUnitTest cqHelper = new CqQueryDUnitTest();
    
    public final String[] cqs = new String [] {
        //0 - Test for ">" 
@@@ -167,7 -166,7 +166,6 @@@
      
      cqHelper.closeClient(client);
      Wait.pause(10 * 1000);
--    //cc1 = server1.invoke(() -> PartitionedRegionCqQueryDUnitTest.getCqCountFromRegionProfile());
      cc2 = server2.invoke(() -> PartitionedRegionCqQueryDUnitTest.getCqCountFromRegionProfile());
      
      //assertIndexDetailsEquals("Should have one", 0, cc1);
@@@ -220,8 -218,8 +218,6 @@@
          /* queryDeletes: */ 0,
          /* totalEvents: */ size);
      
--    //size = 2;
--    
      // do updates
      createValues(server1, regions[0], size);
      
@@@ -244,8 -243,9 +240,8 @@@
      
      cqHelper.waitForDestroyed(client, "testCQEvents_0", KEY+numDestroys);
      
--    // validate cqs after destroyes on server2.
++    // validate cqs after destroys on server2.
   
 -        
      cqHelper.validateCQ(client, "testCQEvents_0",
          /* resultSize: */ CqQueryDUnitTest.noTest,
          /* creates: */ size,
@@@ -256,30 -256,30 +252,6 @@@
          /* queryDeletes: */ numDestroys,
          /* totalEvents: */ (size+size+numDestroys));
      
--    // invalidate some entries.
--    /*final int numInvalidates = 5;
--    
--    server2.invoke(new CacheSerializableRunnable("Invalidate values") {
--      public void run2() throws CacheException {
--        Region region1 = getRootRegion().getSubregion(regions[0]);
--        for (int i = numInvalidates; i <= (numInvalidates+4); i++) {
--          region1.invalidate(KEY+i);
--        }
--      }
--    });
--     
--    cqHelper.waitForInvalidated(client, "testCQEvents_0", KEY+(numInvalidates+4));
--    */
--   // cqHelper.validateCQ(client, "testCQEvents_0",
--    //    /* resultSize: */ cqHelper.noTest,
--    //    /* creates: */ size,
--    //    /* updates: */ size,
--    //    /* deletes; */ (numDestroys+numInvalidates),
--    //    /* queryInserts: */ size,
--     //   /* queryUpdates: */ size,
--     //   /* queryDeletes: */ (numDestroys+numInvalidates),
--    //    /* totalEvents: */ (size+size+numDestroys + numInvalidates));
--    
      cqHelper.closeClient(client);
      cqHelper.closeServer(server2);
      cqHelper.closeServer(server1);
@@@ -334,8 -333,8 +306,6 @@@
          /* queryDeletes: */ 0,
          /* totalEvents: */ size);
      
--    //size = 2;
--    
      // do updates
      createValues(server1, regions[0], size);
      
@@@ -363,9 -362,9 +333,8 @@@
        cqHelper.waitForDestroyed(client, "testCQEvents_0", KEY+i);
      }
      
--    // validate cqs after destroyes on server2.
++    // validate cqs after destroys on server2.
   
--        
      cqHelper.validateCQ(client, "testCQEvents_0",
          /* resultSize: */ CqQueryDUnitTest.noTest,
          /* creates: */ size,
@@@ -425,8 -424,8 +394,6 @@@
          /* queryDeletes: */ 0,
          /* totalEvents: */ size);
      
--    //size = 2;
--    
      // do updates
      createValues(server1, regions[0], size);
      
@@@ -445,7 -444,7 +412,6 @@@
          /* queryDeletes: */ 0,
          /* totalEvents: */ (size+size));
      
--    
      // destroy all the values.
      int numDestroys = size;
      cqHelper.deleteValues(server1,regions[0], numDestroys);
@@@ -631,7 -637,7 +597,6 @@@
          /* queryDeletes: */ 0,
          /* totalEvents: */ (size+size));
      
--    
      // invalidate all the values.
      int numInvalidates = size;
      cqHelper.invalidateValues(server2,regions[0], numInvalidates);
@@@ -911,8 -927,11 +876,7 @@@
      // do updates
      createValues(client2, regions[0], size);
      createValues(client2, regions[1], size);
--    
-- 
++
      for (int i=1; i <= size; i++){
        cqHelper.waitForUpdated(client, "testCQEvents_0", KEY+i);
        cqHelper.waitForUpdated(client, "testCQEvents_1", KEY+i);
@@@ -1275,7 -1394,7 +1239,6 @@@
            region.put("KEY-"+i, p);
          }
        }
--      
      });
      
      client1.invokeAsync(new CacheSerializableRunnable("Wait for CqEvent") {
@@@ -1375,27 -1496,36 +1336,27 @@@
          "Create Cache Server") {
        public void run2() throws CacheException
        {
--          LogWriterUtils.getLogWriter().info("### Create Cache Server. ###");
 -          //AttributesFactory factory = new AttributesFactory();
 -          //factory.setScope(Scope.DISTRIBUTED_ACK);
 -          //factory.setMirrorType(MirrorType.KEYS_VALUES);
 -          
 -          //int maxMem = 0;
--          AttributesFactory attr = new AttributesFactory();
 -          //attr.setValueConstraint(valueConstraint);
--          PartitionAttributesFactory paf = new PartitionAttributesFactory();
--          if (isAccessor){
--            paf.setLocalMaxMemory(0);
--          }
--          PartitionAttributes prAttr = paf.setTotalNumBuckets(197).setRedundantCopies(redundantCopies).create();
--          attr.setPartitionAttributes(prAttr);
--          
--          assertFalse(getSystem().isLoner());
--          //assertTrue(getSystem().getDistributionManager().getOtherDistributionManagerIds().size() > 0);
--          for (int i = 0; i < regions.length; i++) {
--            Region r = createRegion(regions[i], attr.create());
--            LogWriterUtils.getLogWriter().info("Server created the region: "+r);
--          }
 -//          pause(2000);
--          try {
--            startBridgeServer(port, true);
--          }
--          catch (Exception ex) {
--            Assert.fail("While starting CacheServer", ex);
--          }
 -//          pause(2000);
 -       
++        LogWriterUtils.getLogWriter().info("### Create Cache Server. ###");
++        AttributesFactory attr = new AttributesFactory();
++        PartitionAttributesFactory paf = new PartitionAttributesFactory();
++        if (isAccessor){
++          paf.setLocalMaxMemory(0);
++        }
++        PartitionAttributes prAttr = paf.setTotalNumBuckets(197).setRedundantCopies(redundantCopies).create();
++        attr.setPartitionAttributes(prAttr);
++
++        assertFalse(getSystem().isLoner());
++        //assertTrue(getSystem().getDistributionManager().getOtherDistributionManagerIds().size() > 0);
++        for (int i = 0; i < regions.length; i++) {
++          Region r = createRegion(regions[i], attr.create());
++          LogWriterUtils.getLogWriter().info("Server created the region: "+r);
++        }
++        try {
++          startBridgeServer(port, true);
++        }
++        catch (Exception ex) {
++          Assert.fail("While starting CacheServer", ex);
++        }
        }
      };
  
@@@ -1415,27 -1545,35 +1376,27 @@@
          "Create Cache Server") {
        public void run2() throws CacheException
        {
--          LogWriterUtils.getLogWriter().info("### Create Cache Server. ###");
 -          //AttributesFactory factory = new AttributesFactory();
 -          //factory.setScope(Scope.DISTRIBUTED_ACK);
 -          //factory.setMirrorType(MirrorType.KEYS_VALUES);
 -          
 -          //int maxMem = 0;
--          AttributesFactory attr = new AttributesFactory();
 -          //attr.setValueConstraint(valueConstraint);
--          PartitionAttributesFactory paf = new PartitionAttributesFactory();
--          if (isAccessor){
--            paf.setLocalMaxMemory(0);
--          }
--          PartitionAttributes prAttr = paf.setTotalNumBuckets(1).setRedundantCopies(redundantCopies).create();
--          attr.setPartitionAttributes(prAttr);
--          
--          assertFalse(getSystem().isLoner());
--          //assertTrue(getSystem().getDistributionManager().getOtherDistributionManagerIds().size() > 0);
--          for (int i = 0; i < regions.length; i++) {
--            Region r = createRegionWithoutRoot(regions[i], attr.create());
--            LogWriterUtils.getLogWriter().info("Server created the region: "+r);
--          }
 -//          pause(2000);
--          try {
--            startBridgeServer(port, true);
--          }
--          catch (Exception ex) {
--            Assert.fail("While starting CacheServer", ex);
--          }
 -//          pause(2000);
++        LogWriterUtils.getLogWriter().info("### Create Cache Server. ###");
++        AttributesFactory attr = new AttributesFactory();
++        PartitionAttributesFactory paf = new PartitionAttributesFactory();
++        if (isAccessor){
++          paf.setLocalMaxMemory(0);
++        }
++        PartitionAttributes prAttr = paf.setTotalNumBuckets(1).setRedundantCopies(redundantCopies).create();
++        attr.setPartitionAttributes(prAttr);
++
++        assertFalse(getSystem().isLoner());
++        //assertTrue(getSystem().getDistributionManager().getOtherDistributionManagerIds().size() > 0);
++        for (int i = 0; i < regions.length; i++) {
++          Region r = createRegionWithoutRoot(regions[i], attr.create());
++          LogWriterUtils.getLogWriter().info("Server created the region: "+r);
++        }
++        try {
++          startBridgeServer(port, true);
++        }
++        catch (Exception ex) {
++          Assert.fail("While starting CacheServer", ex);
++        }
        }
  
        private Region createRegionWithoutRoot(String regionName,


[02/17] incubator-geode git commit: This closes #150

Posted by kl...@apache.org.
 This closes #150


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/41d9cff3
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/41d9cff3
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/41d9cff3

Branch: refs/heads/feature/GEODE-837
Commit: 41d9cff33e33bbeacd2be2101bee4a5d956e8f87
Parents: fb719d0
Author: Jinmei Liao <ji...@pivotal.io>
Authored: Fri Jun 3 14:18:32 2016 -0700
Committer: Jinmei Liao <ji...@pivotal.io>
Committed: Fri Jun 3 14:18:32 2016 -0700

----------------------------------------------------------------------
 .../cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java     | 1 -
 1 file changed, 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/41d9cff3/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
index de93c75..f306cb9 100644
--- a/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
+++ b/geode-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
@@ -61,7 +61,6 @@ import com.gemstone.gemfire.test.dunit.Wait;
  */
 public class PartitionedRegionCqQueryDUnitTest extends CacheTestCase {
 
-  
   public PartitionedRegionCqQueryDUnitTest(String name) {
     super(name);
   }


[17/17] incubator-geode git commit: Fixup

Posted by kl...@apache.org.
Fixup


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/470cd73e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/470cd73e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/470cd73e

Branch: refs/heads/feature/GEODE-837
Commit: 470cd73eaeba2f47b691b8418cfb46905c540561
Parents: 5c048b3
Author: Kirk Lund <kl...@apache.org>
Authored: Tue Jun 7 14:52:50 2016 -0700
Committer: Kirk Lund <kl...@apache.org>
Committed: Tue Jun 7 14:52:50 2016 -0700

----------------------------------------------------------------------
 ...tributedAckPersistentRegionCCEDUnitTest.java |   9 +-
 .../DistributedAckRegionCCEDUnitTest.java       |   1 +
 .../gemfire/cache30/MultiVMRegionTestCase.java  | 462 ++++++++++++++++---
 3 files changed, 408 insertions(+), 64 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/470cd73e/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
index d87fe4b..3e62425 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
@@ -48,17 +48,20 @@ public class DistributedAckPersistentRegionCCEDUnitTest extends DistributedAckRe
   @Ignore("Skip test for this configuration")
   @Override
   @Test
-  public void testClearOnNonReplicateWithConcurrentEvents() {}
+  public void testClearOnNonReplicateWithConcurrentEvents() {
+  }
 
   @Ignore("Skip test for this configuration")
   @Override
   @Test
-  public void testConcurrentEventsOnNonReplicatedRegion() {}
+  public void testConcurrentEventsOnNonReplicatedRegion() {
+  }
 
   @Ignore("Skip test for this configuration")
   @Override
   @Test
-  public void testGetAllWithVersions() {}
+  public void testGetAllWithVersions() {
+  }
 
   private VersionTag getVersionTag(VM vm, final String key) {
     SerializableCallable getVersionTag = new SerializableCallable("verify recovered entry") {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/470cd73e/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
index d91b803..3794b37 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
@@ -283,6 +283,7 @@ public class DistributedAckRegionCCEDUnitTest extends DistributedAckRegionDUnitT
     versionTestClearWithConcurrentEventsAsync();
   }
 
+  @Category(FlakyTest.class) // bug #45704
   @Test
   public void testClearOnNonReplicateWithConcurrentEvents() throws Exception {
     versionTestClearOnNonReplicateWithConcurrentEvents();


[13/17] incubator-geode git commit: GEODE-1464: remove sqlf code

Posted by kl...@apache.org.
GEODE-1464: remove sqlf code


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/880f8648
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/880f8648
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/880f8648

Branch: refs/heads/feature/GEODE-837
Commit: 880f86483f6b75775f34e6821046ba18deb933f0
Parents: 6967ac1
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Mon Jun 6 18:01:18 2016 -0700
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Mon Jun 6 18:01:18 2016 -0700

----------------------------------------------------------------------
 .../cache/query/internal/IndexUpdater.java      | 123 --------
 .../internal/DistributionMessage.java           |   2 +-
 .../internal/InternalDistributedSystem.java     |  43 +--
 .../distributed/internal/ReplyProcessor21.java  |   6 +-
 .../com/gemstone/gemfire/internal/DSCODE.java   |  16 +-
 .../gemstone/gemfire/internal/DSFIDFactory.java | 187 -------------
 .../internal/DataSerializableFixedID.java       |  56 +---
 .../gemfire/internal/GemFireUtilLauncher.java   | 165 -----------
 .../internal/InternalDataSerializer.java        |   7 -
 .../gemstone/gemfire/internal/SystemAdmin.java  |   2 -
 .../com/gemstone/gemfire/internal/Version.java  |  21 +-
 .../gemfire/internal/VersionedDataStream.java   |   5 +-
 .../internal/cache/AbstractDiskRegionEntry.java |   5 -
 .../internal/cache/AbstractRegionEntry.java     |  30 +-
 .../internal/cache/AbstractRegionMap.java       | 238 ++--------------
 .../gemfire/internal/cache/BucketAdvisor.java   |   6 -
 .../gemfire/internal/cache/BucketRegion.java    |  45 +--
 .../cache/CacheDistributionAdvisor.java         |  28 +-
 .../internal/cache/CacheServerLauncher.java     |   2 +-
 .../cache/CachedDeserializableFactory.java      |   7 -
 .../internal/cache/ColocationHelper.java        |  67 +----
 .../internal/cache/DestroyOperation.java        |   3 -
 .../gemfire/internal/cache/DiskEntry.java       | 152 ++--------
 .../gemfire/internal/cache/DiskInitFile.java    |   2 -
 .../gemfire/internal/cache/DiskRegion.java      |   2 -
 .../internal/cache/DiskWriteAttributesImpl.java |  91 ------
 .../gemfire/internal/cache/DistTXState.java     |   4 +-
 .../cache/DistTXStateOnCoordinator.java         |   2 +-
 .../cache/DistributedCacheOperation.java        |  31 +-
 .../cache/DistributedPutAllOperation.java       |  52 +---
 .../internal/cache/DistributedRegion.java       |  37 +--
 ...stributedRegionFunctionStreamingMessage.java |   2 -
 .../cache/DistributedRemoveAllOperation.java    |  24 +-
 .../gemfire/internal/cache/EntryBits.java       |  22 --
 .../gemfire/internal/cache/EntryEventImpl.java  | 255 +----------------
 .../internal/cache/EntryOperationImpl.java      |  15 +-
 .../internal/cache/GemFireCacheImpl.java        | 159 +++++------
 .../gemfire/internal/cache/GridAdvisor.java     |   6 +-
 .../internal/cache/InitialImageOperation.java   |  96 +------
 .../internal/cache/InternalRegionArguments.java |  22 --
 .../internal/cache/InvalidateOperation.java     |   3 -
 .../gemfire/internal/cache/KeyInfo.java         |   5 +-
 .../internal/cache/KeyWithRegionContext.java    |  70 -----
 .../gemfire/internal/cache/ListOfDeltas.java    | 100 -------
 .../gemfire/internal/cache/LocalRegion.java     | 131 +--------
 .../gemstone/gemfire/internal/cache/Oplog.java  |  24 +-
 .../internal/cache/PRHARedundancyProvider.java  |   8 -
 .../internal/cache/PartitionAttributesImpl.java |  10 -
 .../internal/cache/PartitionedRegion.java       | 280 +------------------
 .../cache/PartitionedRegionDataStore.java       |  16 --
 .../gemfire/internal/cache/ProxyRegionMap.java  |  23 +-
 .../gemfire/internal/cache/QueuedOperation.java |  16 +-
 .../gemfire/internal/cache/RegionEntry.java     |   6 +-
 .../gemfire/internal/cache/RegionMap.java       |   8 +-
 .../cache/RemoteContainsKeyValueMessage.java    |   3 -
 .../internal/cache/RemoteDestroyMessage.java    |  13 +-
 .../internal/cache/RemoteFetchEntryMessage.java |   3 -
 .../cache/RemoteFetchVersionMessage.java        |   3 -
 .../internal/cache/RemoteGetMessage.java        |   3 -
 .../internal/cache/RemoteInvalidateMessage.java |   3 -
 .../internal/cache/RemotePutAllMessage.java     |  15 +-
 .../internal/cache/RemotePutMessage.java        |  32 +--
 .../internal/cache/RemoteRemoveAllMessage.java  |   6 +-
 .../cache/SearchLoadAndWriteProcessor.java      |   3 -
 .../gemfire/internal/cache/TXEntry.java         |  11 -
 .../gemfire/internal/cache/TXEntryState.java    |  32 +--
 .../internal/cache/TXRegionLockRequestImpl.java |  14 +-
 .../gemfire/internal/cache/TXRegionState.java   |   5 -
 .../gemfire/internal/cache/TXState.java         |   5 +-
 .../internal/cache/TXStateInterface.java        |   1 -
 .../cache/UpdateAttributesProcessor.java        |   9 +-
 .../cache/UpdateEntryVersionOperation.java      |   5 -
 .../gemfire/internal/cache/UpdateOperation.java |  36 +--
 .../internal/cache/ValidatingDiskRegion.java    |   3 -
 .../internal/cache/WrappedCallbackArgument.java |  26 +-
 .../gemfire/internal/cache/delta/Delta.java     |  56 ----
 .../cache/execute/AbstractExecution.java        |  18 --
 .../FunctionStreamingResultCollector.java       |   3 +-
 .../cache/execute/InternalExecution.java        |  27 +-
 .../cache/execute/InternalFunctionService.java  |   2 +-
 .../execute/InternalRegionFunctionContext.java  |   5 -
 .../cache/execute/MemberFunctionExecutor.java   |   7 -
 .../execute/MultiRegionFunctionExecutor.java    |   7 -
 .../execute/RegionFunctionContextImpl.java      |  13 -
 .../cache/execute/ServerFunctionExecutor.java   |   7 -
 .../partitioned/ContainsKeyValueMessage.java    |   4 -
 .../cache/partitioned/DestroyMessage.java       |   4 -
 .../partitioned/FetchBulkEntriesMessage.java    |   6 -
 .../cache/partitioned/FetchEntriesMessage.java  |   6 -
 .../cache/partitioned/FetchEntryMessage.java    |   4 -
 .../cache/partitioned/FetchKeysMessage.java     |   6 -
 .../internal/cache/partitioned/GetMessage.java  |  16 +-
 .../cache/partitioned/InvalidateMessage.java    |   4 -
 .../cache/partitioned/PREntriesIterator.java    |   8 +-
 .../PRUpdateEntryVersionMessage.java            |   5 -
 .../cache/partitioned/PartitionMessage.java     |  18 --
 .../cache/partitioned/PutAllPRMessage.java      |  26 +-
 .../internal/cache/partitioned/PutMessage.java  |  36 +--
 .../cache/partitioned/RegionAdvisor.java        |  17 --
 .../partitioned/RemoteFetchKeysMessage.java     |   6 -
 .../cache/partitioned/RemoveAllPRMessage.java   |  11 +-
 .../rebalance/PartitionedRegionLoadModel.java   |  19 +-
 .../sockets/command/GatewayReceiverCommand.java |  13 -
 .../internal/cache/tx/DistTxEntryEvent.java     |  14 +-
 .../cache/wan/AbstractGatewaySender.java        |   2 +-
 .../AbstractGatewaySenderEventProcessor.java    |   2 +-
 .../wan/GatewaySenderEventCallbackArgument.java |   8 +-
 .../cache/wan/GatewaySenderEventImpl.java       |  13 +-
 .../parallel/ParallelGatewaySenderQueue.java    |   9 +-
 .../xmlcache/RegionAttributesCreation.java      |   2 -
 .../gemfire/internal/i18n/LocalizedStrings.java |  11 -
 .../internal/logging/LoggingThreadGroup.java    |   2 -
 .../internal/logging/ManagerLogWriter.java      |  34 ---
 .../gemfire/internal/logging/PureLogWriter.java |   2 -
 .../gemfire/internal/offheap/OffHeapHelper.java |   1 -
 .../offheap/ReferenceCountHelperImpl.java       |   1 -
 .../offheap/annotations/OffHeapIdentifier.java  |   4 -
 .../gemfire/internal/shared/NativeCalls.java    |  33 +--
 .../gemfire/internal/util/ArrayUtils.java       |   2 +-
 .../CustomEntryConcurrentHashMap.java           |   2 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  | 140 ----------
 .../gemfire/distributed/LocatorDUnitTest.java   |   2 +-
 .../disttx/DistributedTransactionDUnitTest.java |  12 -
 ...wardCompatibilitySerializationDUnitTest.java |   9 -
 .../execute/PRCustomPartitioningDUnitTest.java  |   3 +-
 .../FetchEntriesMessageJUnitTest.java           |   1 -
 .../sanctionedDataSerializables.txt             |  27 +-
 .../codeAnalysis/sanctionedSerializables.txt    |   1 -
 128 files changed, 292 insertions(+), 3368 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/cache/query/internal/IndexUpdater.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/cache/query/internal/IndexUpdater.java b/geode-core/src/main/java/com/gemstone/gemfire/cache/query/internal/IndexUpdater.java
deleted file mode 100644
index facbdf2..0000000
--- a/geode-core/src/main/java/com/gemstone/gemfire/cache/query/internal/IndexUpdater.java
+++ /dev/null
@@ -1,123 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package com.gemstone.gemfire.cache.query.internal;
-
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.LockNotHeldException;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-
-public interface IndexUpdater {
-
-  /**
-   * This method is invoked when an entry is added, updated or destroyed in a
-   * region for index maintenance. This method will do some pre-update
-   * operations for the index like constraint checks or any other logging that
-   * may be required, and any index updates if required.
-   * 
-   * @param owner
-   *          the {@link Region} that owns this event; will be different from
-   *          {@link EntryEvent#getRegion()} for partitioned regions
-   * @param event
-   *          the {@link EntryEvent} representing the operation.
-   * @param entry
-   *          the region entry.
-   */
-  public void onEvent(LocalRegion owner, EntryEventImpl event, RegionEntry entry);
-
-  /**
-   * This method is invoked after an entry has been added, updated or destroyed
-   * in a region for index maintenance. This method will commit the changes to
-   * the indexes or may rollback some of the changes done in {@link #onEvent} if
-   * the entry operation failed for some reason.
-   * 
-   * @param owner
-   *          the {@link Region} that owns this event; will be different from
-   *          {@link EntryEvent#getRegion()} for partitioned regions
-   * @param event
-   *          the {@link EntryEvent} representing the operation.
-   * @param entry
-   *          the region entry.
-   * @param success
-   *          true if the entry operation succeeded and false otherwise.
-   */
-  public void postEvent(LocalRegion owner, EntryEventImpl event,
-      RegionEntry entry, boolean success);
-
-  /**
-   * Invoked to clear all index entries for a bucket before destroying it.
-   * 
-   * @param baseBucket
-   *          the {@link BucketRegion} being destroyed
-   * @param bucketId
-   *          the ID of the bucket being destroyed
-   */
-  public void clearIndexes(BucketRegion baseBucket, int bucketId);
-
-  /**
-   * Take a read lock indicating that bucket/region GII is in progress to block
-   * index list updates during the process.
-   * 
-   * This is required to be a reentrant lock. The corresponding write lock that
-   * will be taken by the implementation internally should also be reentrant.
-   * 
-   * @throws TimeoutException
-   *           in case of timeout in acquiring the lock
-   */
-  public void lockForGII() throws TimeoutException;
-
-  /**
-   * Release the read lock taken for GII by {@link #lockForGII()}.
-   * 
-   * @throws LockNotHeldException
-   *           if the current thread does not hold the read lock for GII
-   */
-  public void unlockForGII() throws LockNotHeldException;
-
-  /**
-   * Take a read lock to wait for completion of any index load in progress
-   * during initial DDL replay. This is required since no table level locks are
-   * acquired during initial DDL replay to avoid blocking most (if not all) DMLs
-   * in the system whenever a new node comes up.
-   * 
-   * This will be removed at some point when we allow for concurrent loading and
-   * initialization of index even while operations are in progress using
-   * something similar to region GII token mode for indexes or equivalent (bug
-   * 40899).
-   * 
-   * This is required to be a reentrant lock. The corresponding write lock that
-   * will be taken by the implementation internally should also be reentrant.
-   * 
-   * @return true if locking was required and was acquired and false if it was
-   *         not required
-   * @throws TimeoutException
-   *           in case of timeout in acquiring the lock
-   */
-  public boolean lockForIndexGII() throws TimeoutException;
-
-  /**
-   * Release the read lock taken for GII by {@link #lockForIndexGII()}.
-   * 
-   * @throws LockNotHeldException
-   *           if the current thread does not hold the read lock
-   */
-  public void unlockForIndexGII() throws LockNotHeldException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionMessage.java
index 3a64d06..85a4269 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionMessage.java
@@ -192,7 +192,7 @@ public abstract class DistributionMessage
         return true;
       case DistributionManager.REGION_FUNCTION_EXECUTION_EXECUTOR:
         // allow nested distributed functions to be executed from within the
-        // execution of a function; this is required particularly for SQLFabric
+        // execution of a function
         // TODO: this can later be adjusted to use a separate property
         return false;
       default:

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
index 9d49b49..af81cc1 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
@@ -184,9 +184,6 @@ public class InternalDistributedSystem
    * a live locator can be contacted.
    */
   private QuorumChecker quorumChecker;
-  
-  /** sqlfire disconnect listener */
-  private DisconnectListener sqlfDisconnectListener;
 
   /**
    * A Constant that matches the ThreadGroup name of the shutdown hook.
@@ -2115,40 +2112,6 @@ public class InternalDistributedSystem
       }
     }
   }
-  
-  /**
-   * sqlfire's disconnect listener is invoked before the cache is closed when
-   * there is a forced disconnect
-   */
-  public void setSqlfForcedDisconnectListener(DisconnectListener listener) {
-    synchronized(this.listeners) { 
-      this.sqlfDisconnectListener = listener;
-    }
-  }
-  
-  private void notifySqlfForcedDisconnectListener() {
-    if (this.sqlfDisconnectListener != null) {
-      final boolean isDebugEnabled = logger.isDebugEnabled();
-      try {
-        if (isDebugEnabled) {
-          logger.debug("notifying sql disconnect listener");
-        }
-        this.sqlfDisconnectListener.onDisconnect(this);
-      } catch (VirtualMachineError e) {
-        SystemFailure.initiateFailure(e);
-        throw e;
-      } catch (Throwable e) {
-        SystemFailure.checkFailure();
-        // TODO: should these be logged or ignored?  We need to see them
-        logger.info("", e);
-      }
-      if (isDebugEnabled) {
-        logger.debug("finished notifying sql disconnect listener");
-      }
-    }
-  }
-  
-  
 
   /**
    * Makes note of a <code>DisconnectListener</code> whose
@@ -2485,12 +2448,9 @@ public class InternalDistributedSystem
           }
 
           if (isDebugEnabled) {
-            logger.debug("tryReconnect: forcedDisconnect={} sqlf listener={}", forcedDisconnect, this.sqlfDisconnectListener);
+            logger.debug("tryReconnect: forcedDisconnect={}", forcedDisconnect);
           }
           if (forcedDisconnect) {
-            // allow the fabric-service to stop before dismantling everything
-            notifySqlfForcedDisconnectListener();
-
             if (config.getDisableAutoReconnect()) {
               if (isDebugEnabled) {
                 logger.debug("tryReconnect: auto reconnect after forced disconnect is disabled");
@@ -2717,7 +2677,6 @@ public class InternalDistributedSystem
 
         DM newDM = this.reconnectDS.getDistributionManager();
         if (newDM instanceof DistributionManager) {
-          // sqlfire will have already replayed DDL and recovered.
           // Admin systems don't carry a cache, but for others we can now create
           // a cache
           if (((DistributionManager)newDM).getDMType() != DistributionManager.ADMIN_ONLY_DM_TYPE) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/ReplyProcessor21.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/ReplyProcessor21.java b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/ReplyProcessor21.java
index 49e11df..21171b2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/ReplyProcessor21.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/ReplyProcessor21.java
@@ -609,8 +609,7 @@ public class ReplyProcessor21
   }
 
   // start waiting for replies without explicitly waiting for all of them using
-  // waitForReplies* methods; useful for streaming of results in function
-  // execution and SQLFabric
+  // waitForReplies* methods; useful for streaming of results in function execution
   public final void startWait() {
     if (!this.waiting && stillWaiting()) {
       preWait();
@@ -618,8 +617,7 @@ public class ReplyProcessor21
   }
 
   // end waiting for replies without explicitly invoking waitForReplies*
-  // methods; useful for streaming of results in function execution and
-  // SQLFabric
+  // methods; useful for streaming of results in function execution
   public final void endWait(boolean doCleanup) {
     try {
       postWait();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/DSCODE.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/DSCODE.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/DSCODE.java
index cef660a..583b2ab 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/DSCODE.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/DSCODE.java
@@ -322,25 +322,13 @@ public interface DSCODE {
    */
   public static final byte HUGE_STRING = 89;
 
-  /**
-   * A header byte meaning that the next element in the stream is an
-   * SQLFabric DataValueDescriptor array.
-   * 
-   * @since GemFire 6.0
-   */
-  public static final byte SQLF_DVD_ARR = 90;
+  // 90 unused
 
   /** A header byte meaning that the next element in the stream is a
    * <code>byte[][]</code>. */
   public static final byte ARRAY_OF_BYTE_ARRAYS = 91;
 
-  /**
-   * A header byte meaning that the next element in the stream is an
-   * object of SQLFabric XML type.
-   * 
-   * @since GemFire 6.5
-   */
-  public static final byte SQLF_XML = 92;
+  // 92 unused
 
   /**
    * A header byte meaning that the next element in the stream is a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
index 5f0002a..ab76d5c 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
@@ -1064,16 +1064,6 @@ public final class DSFIDFactory implements DataSerializableFixedID {
         return readUndefined(in);
       case RESULTS_BAG:
         return readResultsBag(in);
-      case SQLF_TYPE:
-        return readSqlfMessage(in);
-      case SQLF_DVD_OBJECT:
-        return readDVD(in);
-      case SQLF_GLOBAL_ROWLOC:
-        return readGlobalRowLocation(in);
-      case SQLF_GEMFIRE_KEY:
-        return readGemFireKey(in);
-      case SQLF_FORMATIBLEBITSET:
-        return readSqlFormatibleBitSet(in);
       case TOKEN_INVALID:
         return Token.INVALID;
       case TOKEN_LOCAL_INVALID:
@@ -1175,183 +1165,6 @@ public final class DSFIDFactory implements DataSerializableFixedID {
     serializable.fromData(in);
     return serializable;
   }
-  /**
-   * Map for SQLFabric specific classIds to the {@link Class} of an
-   * implementation. We maintain this separate map for SQLFabric to allow
-   * separation of GemFire and SQLFabric trees. This is particularly required
-   * when implementing a new <code>DistributionMessage</code>. This requires the
-   * classes to have a zero argument constructor.
-   */
-  @SuppressWarnings("unchecked")
-  private static Class<? extends DataSerializableFixedID>[] sqlfDSFIDClassMap =
-    new Class[Byte.MAX_VALUE + 1 - Byte.MIN_VALUE];
-  
-  /**
-   * Map for SQLFabric specific classIds to the {@link DataSerializableFixedID} 
-   * singleton instance. We maintain this separate map for SQLFabric to allow
-   * separation of GemFire and SQLFabric trees. This approach is needed to 
-   * allow transparent serialization of singleton objects
-   */
-  private static DataSerializableFixedID[] sqlfDSFIDFixedInstanceMap =
-    new DataSerializableFixedID[Byte.MAX_VALUE + 1 - Byte.MIN_VALUE];
-
-  /**
-   * Exception to indicate SQLFabric specific serialization exceptions
-   */
-  public static class SqlfSerializationException extends
-      NotSerializableException {
-
-    private static final long serialVersionUID = 5076687296705595933L;
-
-    /**
-     * Constructs a SqlfSerializationException object with message string.
-     * 
-     * @param msg
-     *          exception message
-     */
-    public SqlfSerializationException(String msg) {
-      super(msg);
-    }
-  }
-
-  private static DataSerializableFixedID readSqlfMessage(DataInput in)
-      throws IOException, ClassNotFoundException {
-    // Use the first byte as the typeId of SQLFabric messages
-    final byte sqlfId = in.readByte();
-    final int sqlfIdIndex = sqlfId & 0xFF;
-    final Class<? extends DataSerializableFixedID> sqlfClass =
-      sqlfDSFIDClassMap[sqlfIdIndex];
-    if (sqlfClass != null) {
-      try {
-        final DataSerializableFixedID sqlfObj = sqlfClass.newInstance();
-        InternalDataSerializer.invokeFromData(sqlfObj, in);
-        return sqlfObj;
-      } catch (InstantiationException ex) {
-        throw new SqlfSerializationException(LocalizedStrings.
-            DSFIDFactory_COULD_NOT_INSTANTIATE_SQLFABRIC_MESSAGE_CLASSID_0_1
-              .toLocalizedString(new Object[] { sqlfId, ex }));
-      } catch (IllegalAccessException ex) {
-        throw new SqlfSerializationException(LocalizedStrings.
-            DSFIDFactory_ILLEGAL_ACCESS_FOR_SQLFABRIC_MESSAGE_CLASSID_0_1
-              .toLocalizedString(new Object[] { sqlfId, ex }));
-      }
-    }//check for fixed instance
-    DataSerializableFixedID fixedInstance = sqlfDSFIDFixedInstanceMap[sqlfIdIndex];
-    if (fixedInstance != null) {
-      InternalDataSerializer.invokeFromData(fixedInstance, in);
-      return fixedInstance;
-    }
-    // if possible set the processor ID before throwing exception so
-    // that failure exception is received by the sender
-    if (sqlfIdIndex < 60) {
-      try {
-        // both SqlfMessage and SqlfReplyMessage write a byte for status first
-        // followed by the processor ID, if any
-        final byte status = in.readByte();
-        int processorId = 0;
-        if ((status & ReplyMessage.PROCESSOR_ID_FLAG) != 0) {
-          processorId = in.readInt();
-        }
-        ReplyProcessor21.setMessageRPId(processorId);
-      } catch (IOException ex) {
-        // give up
-      }
-    }
-    throw new SqlfSerializationException(
-        LocalizedStrings.DSFIDFactory_UNKNOWN_CLASSID_0_FOR_SQLFABRIC_MESSAGE
-            .toLocalizedString(sqlfId));
-  }
-
-  public static synchronized void registerSQLFabricClass(byte classId,
-      Class<? extends DataSerializableFixedID> c) {
-    final int sqlfIdIndex = classId & 0xFF;
-    Class<?> oldClass = sqlfDSFIDClassMap[sqlfIdIndex];
-    if (oldClass != null) {
-      throw new AssertionError("DSFIDFactory#registerSQLFabricClass: cannot "
-          + "re-register classId " + classId + " for class " + c
-          + "; existing class: " + oldClass);
-    }
-    sqlfDSFIDClassMap[sqlfIdIndex] = c;
-  }
-  
-  public static synchronized void registerSQLFabricFixedInstance(byte classId,
-      DataSerializableFixedID fixedInstance)
-  {
-    final int sqlfIdIndex = classId & 0xFF;
-    DataSerializableFixedID oldInstance = sqlfDSFIDFixedInstanceMap[sqlfIdIndex];
-    if (oldInstance != null) {
-      throw new AssertionError("DSFIDFactory#registerSQLFabricClass: cannot "
-          + "re-register classId " + classId + " for instance " + fixedInstance
-          + "; existing instance: " + oldInstance);
-    }
-    sqlfDSFIDFixedInstanceMap[sqlfIdIndex] = fixedInstance;
-  }
-
-  public static synchronized void unregisterSQLFabricClass(byte classId,
-      Class<? extends DataSerializableFixedID> c) {
-    final int sqlfIdIndex = classId & 0xFF;
-    sqlfDSFIDClassMap[sqlfIdIndex] = null;
-  }
-  
-  public static synchronized void unregisterSQLFabricFixedInstance(
-      byte classId, Object dataSerializableFixedID)
-  {
-    final int sqlfIdIndex = classId & 0xFF;
-    sqlfDSFIDFixedInstanceMap[sqlfIdIndex] = null;
-  }
-
-  public static synchronized void clearSQLFabricClasses() {
-    for (int index = 0; index < sqlfDSFIDClassMap.length; ++index) {
-      sqlfDSFIDClassMap[index] = null;
-    }
-    for (int index = 0; index < sqlfDSFIDFixedInstanceMap.length; ++index) {
-      sqlfDSFIDFixedInstanceMap[index] = null;
-    }
-  }  
-
-  public interface DeserializeDVD {
-
-    public DataSerializableFixedID getDSFID(DataInput in) throws IOException,
-        ClassNotFoundException;
-
-    public DataSerializableFixedID getGlobalRowLocation(DataInput in)
-        throws IOException, ClassNotFoundException;
-
-    public DataSerializableFixedID getGemFireKey(DataInput in)
-        throws IOException, ClassNotFoundException;
-
-    public DataSerializableFixedID getSqlPSQArgs(DataInput in)
-        throws IOException, ClassNotFoundException;
-
-    public DataSerializableFixedID getSqlFormatibleBitSet(DataInput in)
-        throws IOException, ClassNotFoundException;
-  }
-
-  private static DeserializeDVD dvdDeserializer;
-
-  private static DataSerializableFixedID readDVD(DataInput in)
-      throws IOException, ClassNotFoundException {
-    return dvdDeserializer.getDSFID(in);
-  }
-
-  private static DataSerializableFixedID readGlobalRowLocation(DataInput in)
-      throws IOException, ClassNotFoundException {
-    return dvdDeserializer.getGlobalRowLocation(in);
-  }
-
-  private static DataSerializableFixedID readGemFireKey(DataInput in)
-      throws IOException, ClassNotFoundException {
-    return dvdDeserializer.getGemFireKey(in);
-  }
-
-  private static DataSerializableFixedID readSqlFormatibleBitSet(DataInput in)
-      throws IOException, ClassNotFoundException {
-    return dvdDeserializer.getSqlFormatibleBitSet(in);
-  }
-
-  public static void registerDVDDeserializer(DeserializeDVD d) {
-    dvdDeserializer = d;
-  }
 
   private static DataSerializableFixedID readSnappyCompressedCachedDeserializable(DataInput in) 
   throws IOException, ClassNotFoundException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
index 0788503..d3e4846 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
@@ -136,8 +136,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
   public static final byte ADD_CACHESERVER_PROFILE_UPDATE = -118;  
   public static final byte SERVER_INTEREST_REGISTRATION_MESSAGE = -117;
   public static final byte FILTER_PROFILE_UPDATE = -116;
-  // [sumedh] below two IDs are no longer used in new TX model and will be
-  // removed at some point after SQLF upmerge
   public static final byte JTA_AFTER_COMPLETION_MESSAGE = -115;
   public static final byte JTA_BEFORE_COMPLETION_MESSAGE = -114;
   public static final byte INVALIDATE_PARTITIONED_REGION_MESSAGE = -113;
@@ -169,8 +167,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
 
   public static final byte CREATE_REGION_MESSAGE = -89;
   public static final byte DESTROY_PARTITIONED_REGION_MESSAGE = -88;
-  // [sumedh] below two IDs are no longer used in new TX model and will be
-  // removed at some point after SQLF upmerge
   public static final byte COMMIT_PROCESS_QUERY_MESSAGE = -87;
   public static final byte COMMIT_PROCESS_QUERY_REPLY_MESSAGE = -86;
   public static final byte DESTROY_REGION_WITH_CONTEXT_MESSAGE = -85;
@@ -182,8 +178,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
   public static final byte STATE_STABILIZATION_MESSAGE = -79;
   public static final byte STATE_STABILIZED_MESSAGE = -78;
   public static final byte CLIENT_MARKER_MESSAGE_IMPL = -77;
-  // [sumedh] below three IDs are no longer used in new TX model and will be
-  // removed at some point after SQLF upmerge
   public static final byte TX_LOCK_UPDATE_PARTICIPANTS_MESSAGE = -76;
   public static final byte TX_ORIGINATOR_RECOVERY_MESSAGE = -75;
   public static final byte TX_ORIGINATOR_RECOVERY_REPLY_MESSAGE = -74;
@@ -193,8 +187,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
   public static final byte NON_GRANTOR_DESTROYED_REPLY_MESSAGE = -70;
   public static final byte TOMBSTONE_MESSAGE = -69;
   public static final byte IDS_REGISTRATION_MESSAGE = -68;
-  // [sumedh] below ID is no longer used in new TX model and will be
-  // removed at some point after SQLF upmerge
   public static final byte TX_LOCK_UPDATE_PARTICIPANTS_REPLY_MESSAGE = -67;
   public static final byte STREAMING_REPLY_MESSAGE = -66;
   public static final byte PREFER_BYTES_CACHED_DESERIALIZABLE = -65;
@@ -223,8 +215,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
   public static final byte GET_ALL_SERVERS_REQUEST = -43;
   public static final byte GET_ALL_SERVRES_RESPONSE = -42;
 
-  // [sumedh] below two IDs are no longer used in new TX model and will be
-  // removed at some point after SQLF upmerge
   public static final byte FIND_REMOTE_TX_REPLY = -41;
   public static final byte FIND_REMOTE_TX_MESSAGE = -40;
 
@@ -257,40 +247,7 @@ public interface DataSerializableFixedID extends SerializationVersions {
   
   public static final byte CLIENT_INTEREST_MESSAGE = -21;
 
-  /**
-   * A header byte meaning that the next element in the stream is a
-   * type meant for SQL Fabric.
-   */
-  public static final byte SQLF_TYPE = -20;
-
-  /**
-   * A header byte meaning that the next element in the stream is a
-   * DVD object used for SQL Fabric.
-   */
-  public static final byte SQLF_DVD_OBJECT = -19;
-  
-  /**
-   * A header byte meaning that the next element in the stream is a
-   * GlobalRowLocation object used for SQL Fabric.
-   */
-  public static final byte SQLF_GLOBAL_ROWLOC = -18;
-  
-  /**
-   * A header byte meaning that the next element in the stream is a
-   * GemFireKey object used for SQL Fabric.
-   */
-  public static final byte SQLF_GEMFIRE_KEY = -17;
-  
-  /**
-   * A header byte meaning that the next element in the stream is a
-   * FormatibleBitSet object in SQLFabric.
-   */
-  public static final byte SQLF_FORMATIBLEBITSET = -16;
-
-  // IDs -15 .. -10 are not used in trunk yet but only in SQLFire, so marking
-  // as used so that GemFire does not use them until the SQLF upmerge else
-  // there will be big problems in backward compatibility after upmerge which
-  // is required for both >= SQLF 1.1 and >= GFE 7.1
+  // IDs -20 .. -16 are not used
 
   /**
    * A header byte meaning that the next element in the stream is a
@@ -541,8 +498,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
   // TXId
   public static final byte TRANSACTION_ID = 109;
 
-  // [sumedh] below ID is no longer used in new TX model and will be
-  // removed at some point after SQLF upmerge
   public static final byte TX_COMMIT_MESSAGE = 110;
 
   public static final byte HA_PROFILE = 111;
@@ -565,8 +520,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
 
   public static final byte PR_GET_MESSAGE = 120;
 
-  // [sumedh] below two IDs are no longer used in new TX model and will be
-  // removed at some point after SQLF upmerge
   // TXLockIdImpl
   public static final byte TRANSACTION_LOCK_ID = 121;
   // TXCommitMessage.CommitProcessForLockIdMessage
@@ -876,9 +829,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
    * class. e.g. if msg format changed in version 80, create toDataPre_GFE_8_0_0_0, add
    * Version.GFE_80 to the getSerializationVersions array and copy previous toData contents 
    * to this newly created toDataPre_GFE_X_X_X_X() method.
-   * <p>
-   * For GemFireXD use "GFXD" (or whatever we decide on as a product identifier
-   * in Version) instead of "GFE" in method names.
    * @throws IOException
    *           A problem occurs while writing to <code>out</code>
    */
@@ -894,10 +844,6 @@ public interface DataSerializableFixedID extends SerializationVersions {
    * class. e.g. if msg format changed in version 80, create fromDataPre_GFE_8_0_0_0, add
    * Version.GFE_80 to the getSerializationVersions array  and copy previous fromData 
    * contents to this newly created fromDataPre_GFE_X_X_X_X() method.
-   * <p>
-   * For GemFireXD use "GFXD" (or whatever we decide on as a product identifier
-   * in Version) instead of "GFE" in method names.
-   * 
    * @throws IOException
    *           A problem occurs while reading from <code>in</code>
    * @throws ClassNotFoundException

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/GemFireUtilLauncher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/GemFireUtilLauncher.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/GemFireUtilLauncher.java
deleted file mode 100644
index f7a3628..0000000
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/GemFireUtilLauncher.java
+++ /dev/null
@@ -1,165 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package com.gemstone.gemfire.internal;
-
-import java.lang.reflect.InvocationTargetException;
-import java.lang.reflect.Method;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.regex.Matcher;
-import java.util.regex.Pattern;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.admin.jmx.internal.AgentLauncher;
-import com.gemstone.gemfire.internal.SystemAdmin;
-import com.gemstone.gemfire.internal.cache.CacheServerLauncher;
-
-/**
- * Maps the GemFire utilities to the launcher that starts them and then invokes
- * that class's main method. Currently this class is only a base class for the 
- * SqlFabric implementation, but eventually the gemfire scripts will be 
- * consolidated to use this class.
- * Current GemFire utilities (as of 6.0):
- * <ul>
- * <li> agent 
- * <li> gemfire
- * <li> cacheserver 
- * </ul>
- * Usage:
- * notYetWritenScript <utility> <utility arguments>
- *
- * @since GemFire 6.0
- */
-public class GemFireUtilLauncher {
-
-  /**
-   * Returns a mapping of utility names to the class used to spawn them.
-   * This method is overridedn by SqlFabricUtilLauncher to handle that product's
-   * own utility tools.
-   **/
-  protected Map<String, Class<?>> getTypes() {
-    Map<String, Class<?>> m = new HashMap<String, Class<?>>();
-    m.put("agent", AgentLauncher.class);
-    m.put("gemfire", SystemAdmin.class);
-    m.put("cacheserver", CacheServerLauncher.class);
-    return m;
-  }
-
-  /** 
-   * A simple constructor was needed so that {@link #usage(String)} 
-   * and {@link #getTypes()} could be non-static methods.
-   **/
-  protected GemFireUtilLauncher() {}
-
-  /** 
-   * This method should be overridden if the name of the script is different.
-   * @return the name of the script used to launch this utility. 
-   **/
-  protected String scriptName() {
-    return "gemfire"; 
-  }
-
-  /** 
-   * Print help information for this utility.
-   * This method is intentionally non-static so that getTypes() can dynamically
-   * display the list of supported utilites supported by child classes.
-   * @param context print this message before displaying the regular help text
-   **/
-  private void usage(String context) {
-    System.out.println(context);
-    StringBuffer sb = new StringBuffer();
-    sb.append("help|");
-    for(String key : getTypes().keySet()) {
-      sb.append(key).append("|");
-    }
-    sb.deleteCharAt(sb.length()-1); // remove the extra "|"
-    String msg = LocalizedStrings.GemFireUtilLauncher_ARGUMENTS
-                   .toLocalizedString(new Object[] {scriptName(), sb});
-    System.out.println(msg);
-    System.exit(1);
-  }
-
-  /**
-   * Spawn the utilty passed in as args[0] or display help information
-   * @param args a utilty and the arguments to pass to it.
-   */
-  public static void main(String[] args) {
-    GemFireUtilLauncher launcher = new GemFireUtilLauncher();
-        launcher.validateArgs(args);
-    launcher.invoke(args);
-  }
-  
-  /**
-   * Calls the <code>public static void main(String[] args)</code> method
-   * of the class associated with the utility name.  
-   * @param args the first argument is the utility name, the remainder 
-   *             comprises the arguments to be passed
-   */
-  protected void invoke(String[] args) {
-    Class<?> clazz = getTypes().get(args[0]);
-    if(clazz == null) {
-      usage(LocalizedStrings.GemFireUtilLauncher_INVALID_UTILITY_0
-            .toLocalizedString(args[0]));
-    }
-    int len = args.length-1;
-    String[] argv = new String[len];
-    System.arraycopy(args, 1, argv, 0, len);
-    
-    Exception ex = null;
-    try {
-      Method m = clazz.getDeclaredMethod("main", new Class[] {argv.getClass()});
-      m.invoke(null, (Object)argv);
-    } catch (SecurityException se) {
-      ex = se;
-    } catch (NoSuchMethodException nsme) {
-      ex = nsme;    
-    } catch (IllegalArgumentException iae) {
-      ex = iae;
-    } catch (IllegalAccessException iae) {
-      ex = iae;
-    } catch (InvocationTargetException ite) {
-      ex = ite;
-    } finally {
-      if (ex != null) {
-        String msg = LocalizedStrings.GemFireUtilLauncher_PROBLEM_STARTING_0
-                                     .toLocalizedString(args[0]); 
-        throw new RuntimeException(msg, ex);
-      }
-    }
-  }
- 
-  /**
-   * Look for variations on help and validate the arguments make sense.
-   * A usage mesage is displayed if necesary.
-   * The following forms of help are accepted:
-   * <code>--help, -help, /help, --h, -h, /h</code>
-   **/ 
-  protected void validateArgs(String[] args) {
-    if (args.length == 0) {
-      usage(LocalizedStrings.GemFireUtilLauncher_MISSING_COMMAND
-                            .toLocalizedString());
-    }
-    //Match all major variations on --help
-    Pattern help = Pattern.compile("(?:--|-|/){0,1}h(?:elp)*", 
-        Pattern.UNICODE_CASE | Pattern.CASE_INSENSITIVE);
-    Matcher matcher = help.matcher(args[0]); 
-
-    if( matcher.matches() ) {
-      usage(LocalizedStrings.GemFireUtilLauncher_HELP.toLocalizedString());
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/InternalDataSerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/InternalDataSerializer.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/InternalDataSerializer.java
index 0df656a..33cd410 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/InternalDataSerializer.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/InternalDataSerializer.java
@@ -74,11 +74,6 @@ public abstract class InternalDataSerializer extends DataSerializer implements D
    */
   private static final ConcurrentHashMap<String, DataSerializer> classesToSerializers = new ConcurrentHashMap<String, DataSerializer>();
   
-  // used by sqlFire
-  public static ConcurrentHashMap<String, DataSerializer> getClassesToSerializers() {
-    return classesToSerializers;
-  }
-
   private static final String serializationVersionTxt = System.getProperty(DistributionConfig.GEMFIRE_PREFIX + "serializationVersion");
   /**
    * Any time new serialization format is added then a new enum needs to be added here.
@@ -2791,8 +2786,6 @@ public abstract class InternalDataSerializer extends DataSerializer implements D
       return DSFIDFactory.create(in.readInt(), in);
     case DS_NO_FIXED_ID:
       return readDataSerializableFixedID(in);
-    case SQLF_DVD_ARR:
-      return dvddeserializer.fromData(in);
     case NULL:
       return null;
     case NULL_STRING:

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/SystemAdmin.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/SystemAdmin.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/SystemAdmin.java
index 7cb7df1..5e561ed 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/SystemAdmin.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/SystemAdmin.java
@@ -1256,8 +1256,6 @@ public class SystemAdmin {
   }
 
   public SystemAdmin() {
-    // no instances allowed
-    // [sumedh] now is overridden by SQLF
     // register DSFID types first; invoked explicitly so that all message type
     // initializations do not happen in first deserialization on a possibly
     // "precious" thread

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/Version.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/Version.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/Version.java
index 513b5bd..1b8543e 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/Version.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/Version.java
@@ -56,7 +56,7 @@ public final class Version implements Comparable<Version> {
 
   /**
    * Set to non-null if the underlying GemFire version is different from product
-   * version (e.g. for SQLFire)
+   * version
    */
   private Version gemfireVersion;
 
@@ -142,19 +142,6 @@ public final class Version implements Comparable<Version> {
   public static final Version GFE_701 = new Version("GFE", "7.0.1", (byte)7,
       (byte)0, (byte)1, (byte)0, GFE_701_ORDINAL);
 
-  /**
-   * SQLFire 1.1 has a separate version since it has changed the RowFormatter
-   * formatting for ALTER TABLE add/drop column support. However, its underlying
-   * GemFire version will remain at GFE_7x.
-   * 
-   * This version is an intermediate one created to test rolling upgrades. It is
-   * compatible with <code>SQLF_11</code> in all respects except for artifical
-   * changes in a couple of P2P messages and marking as compatible with GFE_701.
-   * 
-   * This is the GemFire conterpart of SQLF_1099 for testing rolling upgrades
-   * and it uses the same ordinal as GFE_701 to maintain compatibility with the
-   * ordinals being used on SQLFire branch.
-   */
   private static final byte GFE_7099_ORDINAL = 21;
 
   public static final Version GFE_7099 = new Version("GFE", "7.0.99", (byte)7,
@@ -199,7 +186,7 @@ public final class Version implements Comparable<Version> {
       (byte)0, (byte)0, (byte)0, GFE_90_ORDINAL);
 
   /**
-   * This constant must be set to the most current version of GFE/SQLF.
+   * This constant must be set to the most current version of the product.
    * !!! NOTE: update HIGHEST_VERSION when changing CURRENT !!!
    */
   public static final Version CURRENT = GFE_90;
@@ -261,8 +248,8 @@ public final class Version implements Comparable<Version> {
     if (ordinal == TOKEN_ORDINAL) {
       return TOKEN;
     }
-    // for GFE clients also check that there must be a commands object mapping
-    // for processing (SQLF product versions will not work)
+    // for clients also check that there must be a commands object mapping
+    // for processing
     if ((VALUES.length < ordinal + 1) || VALUES[ordinal] == null
         || (forGFEClients && CommandInitializer.getCommands(VALUES[ordinal]) == null)) {
       throw new UnsupportedVersionException(

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/VersionedDataStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/VersionedDataStream.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/VersionedDataStream.java
index 7c5ca11..3e8bd98 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/VersionedDataStream.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/VersionedDataStream.java
@@ -25,10 +25,7 @@ import com.gemstone.gemfire.DataSerializable;
 /**
  * An extension to {@link DataOutput}, {@link DataInput} used internally in
  * product to indicate that the input/output stream is attached to a GemFire
- * peer having a different version. See the spec on rolling upgrades for more
- * details: <a
- * href="https://wiki.gemstone.com/display/SQLF/Rolling+upgrades">Rolling
- * Upgrades</a>.
+ * peer having a different version.
  * 
  * Internal product classes that implement {@link DataSerializableFixedID} and
  * {@link DataSerializable} and change serialization format must check this on

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractDiskRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractDiskRegionEntry.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractDiskRegionEntry.java
index b65b7ad..41cd110 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractDiskRegionEntry.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractDiskRegionEntry.java
@@ -67,9 +67,4 @@ public abstract class AbstractDiskRegionEntry
       GatewaySenderEventImpl.release(this._getValue()); // OFFHEAP _getValue ok
     }
   }
-  @Override
-  public void afterValueOverflow(RegionEntryContext context) {
-    //NO OP
-    //Overridden in sqlf RegionEntry
-  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionEntry.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionEntry.java
index 35f16bc..6ee4c17 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionEntry.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionEntry.java
@@ -150,7 +150,7 @@ public abstract class AbstractRegionEntry implements RegionEntry,
         // by the RegionMap. It is unclear why this code is needed. ARM destroy
         // does this also and we are now doing it as phase3 of the ARM destroy.
         removePhase2();
-        rgn.getRegionMap().removeEntry(event.getKey(), this, true, event, rgn, rgn.getIndexUpdater());
+        rgn.getRegionMap().removeEntry(event.getKey(), this, true, event, rgn);
       }
     }
   }
@@ -291,10 +291,6 @@ public abstract class AbstractRegionEntry implements RegionEntry,
       }
     }
 
-    final boolean isEagerDeserialize = dst.isEagerDeserialize();
-    if (isEagerDeserialize) {
-      dst.clearEagerDeserialize();
-    }
     dst.setLastModified(mgr, getLastModified()); // fix for bug 31059
     if (v == Token.INVALID) {
       dst.setInvalid();
@@ -307,17 +303,11 @@ public abstract class AbstractRegionEntry implements RegionEntry,
     }
     else if (v instanceof CachedDeserializable) {
       // don't serialize here if it is not already serialized
-//      if(v instanceof ByteSource && CachedDeserializableFactory.preferObject()) {
-//        // For SQLFire we prefer eager deserialized
-//        dst.setEagerDeserialize();         
-//      }
       CachedDeserializable cd = (CachedDeserializable) v;
       if (!cd.isSerialized()) {
         dst.value = cd.getDeserializedForReading();
       } else {
-        /*if (v instanceof ByteSource && CachedDeserializableFactory.preferObject()) {
-          dst.value = v;
-        } else */ {
+        {
           Object tmp = cd.getValue();
           if (tmp instanceof byte[]) {
             byte[] bb = (byte[]) tmp;
@@ -352,11 +342,7 @@ public abstract class AbstractRegionEntry implements RegionEntry,
           return false;
         }
       }
-    if (CachedDeserializableFactory.preferObject()) {
-      dst.value = preparedValue;
-      dst.setEagerDeserialize();
-    }
-    else {
+    {
       try {
         HeapDataOutputStream hdos = new HeapDataOutputStream(Version.CURRENT);
         BlobHelper.serializeTo(preparedValue, hdos);
@@ -412,7 +398,7 @@ public abstract class AbstractRegionEntry implements RegionEntry,
       ReferenceCountHelper.setReferenceCountOwner(null);
       return null;
     } else {
-      result = OffHeapHelper.copyAndReleaseIfNeeded(result); // sqlf does not dec ref count in this call
+      result = OffHeapHelper.copyAndReleaseIfNeeded(result);
       ReferenceCountHelper.setReferenceCountOwner(null);
       setRecentlyUsed();
       return result;
@@ -749,9 +735,7 @@ public abstract class AbstractRegionEntry implements RegionEntry,
       } 
       else {
         FilterProfile fp = region.getFilterProfile();
-        // rdubey: Old value also required for SqlfIndexManager.
-        if (fp != null && ((fp.getCqCount() > 0) || expectedOldValue != null
-            || event.getRegion().getIndexUpdater() != null)) {
+        if (fp != null && ((fp.getCqCount() > 0) || expectedOldValue != null)) {
           //curValue = getValue(region); can cause deadlock will fault in the value
           // and will confuse LRU. rdubey.
           curValue = getValueOnDiskOrBuffer(region);
@@ -1393,10 +1377,6 @@ public abstract class AbstractRegionEntry implements RegionEntry,
       }
     }
   }
-  /**
-   * soubhik: this method is overridden in sqlf flavor of entries.
-   * Instead of overriding this method; override areSetValue.
-   */
   protected final void _setValue(Object val) {
     setValueField(val);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionMap.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionMap.java
index a512750..bc919fc 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionMap.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/AbstractRegionMap.java
@@ -22,7 +22,6 @@ import com.gemstone.gemfire.InvalidDeltaException;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.cache.query.IndexMaintenanceException;
 import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
 import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
 import com.gemstone.gemfire.distributed.DistributedMember;
@@ -31,7 +30,6 @@ import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedM
 import com.gemstone.gemfire.internal.Assert;
 import com.gemstone.gemfire.internal.cache.DiskInitFile.DiskRegionFlag;
 import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.delta.Delta;
 import com.gemstone.gemfire.internal.cache.ha.HAContainerWrapper;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
 import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
@@ -69,21 +67,12 @@ import java.util.concurrent.atomic.AtomicInteger;
  *
  */
 
-//Asif: In case of sqlFabric System, we are creating a different set of RegionEntry 
-// which are derived from the concrete  GFE RegionEntry classes.
-// In future if any new concrete  RegionEntry class is defined, the new  SqlFabric
-// RegionEntry Classes need to be created. There is a junit test in sqlfabric
-// which checks for RegionEntry classes of GFE and validates the same with its 
-// own classes.
-
 public abstract class AbstractRegionMap implements RegionMap {
 
   private static final Logger logger = LogService.getLogger();
   
   /** The underlying map for this region. */
   protected CustomEntryConcurrentHashMap<Object, Object> map;
-  /** An internal Listener for index maintenance for SQLFabric. */
-  private final IndexUpdater indexUpdater;
 
   /**
    * This test hook is used to force the conditions for defect 48182.
@@ -96,16 +85,6 @@ public abstract class AbstractRegionMap implements RegionMap {
   private transient Object owner; // the region that owns this map
   
   protected AbstractRegionMap(InternalRegionArguments internalRegionArgs) {
-    if (internalRegionArgs != null) {
-      this.indexUpdater = internalRegionArgs.getIndexUpdater();
-    }
-    else {
-      this.indexUpdater = null;
-    }
-  }
-
-  public final IndexUpdater getIndexUpdater() {
-    return this.indexUpdater;
   }
 
   protected void initialize(Object owner,
@@ -299,28 +278,17 @@ public abstract class AbstractRegionMap implements RegionMap {
   }
 
   public final void removeEntry(Object key, RegionEntry re, boolean updateStat,
-      EntryEventImpl event, final LocalRegion owner,
-      final IndexUpdater indexUpdater) {
+      EntryEventImpl event, final LocalRegion owner) {
     boolean success = false;
     if (re.isTombstone()&& _getMap().get(key) == re) {
       logger.fatal(LocalizedMessage.create(LocalizedStrings.AbstractRegionMap_ATTEMPT_TO_REMOVE_TOMBSTONE), new Exception("stack trace"));
       return; // can't remove tombstones except from the tombstone sweeper
     }
-    try {
-      if (indexUpdater != null) {
-        indexUpdater.onEvent(owner, event, re);
-      }
-
-      if (_getMap().remove(key, re)) {
-        re.removePhase2();
-        success = true;
-        if (updateStat) {
-          incEntryCount(-1);
-        }
-      }
-    } finally {
-      if (indexUpdater != null) {
-        indexUpdater.postEvent(owner, event, re, success);
+    if (_getMap().remove(key, re)) {
+      re.removePhase2();
+      success = true;
+      if (updateStat) {
+        incEntryCount(-1);
       }
     }
   }
@@ -759,7 +727,6 @@ public abstract class AbstractRegionMap implements RegionMap {
                                        boolean deferLRUCallback,
                                        VersionTag entryVersion, InternalDistributedMember sender, boolean isSynchronizing)
   {
-    assert indexUpdater == null : "indexUpdater should only exist if sqlfire";
     boolean result = false;
     boolean done = false;
     boolean cleared = false;
@@ -1377,8 +1344,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                       if (!inTokenMode) {
                         if ( re.getVersionStamp() == null) {
                           re.removePhase2();
-                          removeEntry(event.getKey(), re, true, event, owner,
-                              indexUpdater);
+                          removeEntry(event.getKey(), re, true, event, owner);
                           removed = true;
                         }
                       }
@@ -1399,8 +1365,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                         owner.recordEvent(event);
                         if (re.getVersionStamp() == null) {
                           re.removePhase2();
-                          removeEntry(event.getKey(), re, true, event, owner,
-                              indexUpdater);
+                          removeEntry(event.getKey(), re, true, event, owner);
                           lruEntryDestroy(re);
                         } else {
                           if (re.isTombstone()) {
@@ -1430,8 +1395,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                   finally {
                     if (re.isRemoved() && !re.isTombstone()) {
                       if (!removed) {
-                        removeEntry(event.getKey(), re, true, event, owner,
-                            indexUpdater);
+                        removeEntry(event.getKey(), re, true, event, owner);
                       }
                     }
                   }
@@ -1543,7 +1507,6 @@ public abstract class AbstractRegionMap implements RegionMap {
         try {
           synchronized (re) {
             if (!re.isRemoved() || re.isTombstone()) {
-              EntryEventImpl sqlfEvent = null;
               Object oldValue = re.getValueInVM(owner);
               final int oldSize = owner.calculateRegionEntryValueSize(re);
               // Create an entry event only if the calling context is
@@ -1554,15 +1517,10 @@ public abstract class AbstractRegionMap implements RegionMap {
                   key, null, txId, txEvent, eventId, aCallbackArgument, filterRoutingInfo, bridgeContext, txEntryState, versionTag, tailKey);
               try {
               
-              if (/* owner.isUsedForPartitionedRegionBucket() && */ 
-                  indexUpdater != null) {
-                 sqlfEvent = cbEvent;
-              } else {
                 if (owner.isUsedForPartitionedRegionBucket()) {
                   txHandleWANEvent(owner, cbEvent, txEntryState);
                 }
                 cbEvent.setRegionEntry(re);
-              }
               cbEvent.setOldValue(oldValue);
               if (isDebugEnabled) {
                 logger.debug("txApplyDestroy cbEvent={}", cbEvent);
@@ -1583,11 +1541,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                 }
                 else {
                   if (!re.isTombstone()) {
-                    if (sqlfEvent != null) {
-                      re.removePhase1(owner, false); // fix for bug 43063
-                      re.removePhase2();
-                      removeEntry(key, re, true, sqlfEvent, owner, indexUpdater);
-                    } else {
+                    {
                       if (shouldPerformConcurrencyChecks(owner, cbEvent) && cbEvent.getVersionTag() != null) {
                         re.makeTombstone(owner, cbEvent.getVersionTag());
                       } else {
@@ -2616,80 +2570,6 @@ public abstract class AbstractRegionMap implements RegionMap {
     return retVal;
   }
 
-  protected static final MapCallbackAdapter<Object, Object, Object, Object>
-      listOfDeltasCreator = new MapCallbackAdapter<Object, Object,
-          Object, Object>() {
-    @Override
-    public Object newValue(Object key, Object context, Object createParams,
-        final MapResult result) {
-      return new ListOfDeltas(4);
-    }
-  };
-  
-  /**
-   * Neeraj: The below if block is to handle the special
-   * scenario witnessed in Sqlfabric for now. (Though its
-   * a general scenario). The scenario is that the updates start coming 
-   * before the base value reaches through GII. In that scenario the updates
-   * essentially the deltas are added to a list and kept as oldValue in the
-   * map and this method returns. When through GII the actual base value arrives
-   * these updates or deltas are applied on it and the new value thus got is put
-   * in the map.
-   * @param event 
-   * @param ifOld 
-   * @return true if delta was enqued
-   */
-  private boolean enqueDelta(EntryEventImpl event, boolean ifOld) {
-    final IndexUpdater indexManager = getIndexUpdater();
-    LocalRegion owner = _getOwner();
-    if (indexManager != null && !owner.isInitialized() && event.hasDelta()) {
-      boolean isOldValueDelta = true;
-      try {
-        if (ifOld) {
-          final Delta delta = event.getDeltaNewValue();
-		  RegionEntry re = getOrCreateRegionEntry(owner, event, null,
-          	  listOfDeltasCreator, false, false);
-          assert re != null;
-          synchronized (re) {
-            @Retained @Released Object oVal = re.getValueOffHeapOrDiskWithoutFaultIn(owner);
-            if (oVal != null) {
-              try {
-              if (oVal instanceof ListOfDeltas) {
-                if (logger.isDebugEnabled()) {
-                  logger.debug("basicPut: adding delta to list of deltas: {}", delta);
-                }
-                ((ListOfDeltas)oVal).merge(delta);
-                @Retained Object newVal = ((AbstractRegionEntry)re).prepareValueForCache(owner, oVal, true);              
-                re.setValue(owner, newVal); // TODO:KIRK:48068 prevent orphan
-              }
-              else {
-                isOldValueDelta = false;
-              }
-              }finally {
-                OffHeapHelper.release(oVal);
-              }
-            }
-            else {
-              if (logger.isDebugEnabled()) {
-                logger.debug("basicPut: new list of deltas with delta: {}", delta);
-              }
-              @Retained Object newVal = new ListOfDeltas(delta);
-              // TODO no need to call AbstractRegionMap.prepareValueForCache here?
-              newVal = ((AbstractRegionEntry)re).prepareValueForCache(owner, newVal, true);
-              re.setValue(owner, newVal); // TODO:KIRK:48068 prevent orphan
-            }
-          }
-        }
-      } catch (RegionClearedException ex) {
-        // Neeraj: We can just ignore this exception because we are returning after this block
-      }
-      if (isOldValueDelta) {
-        return true;
-      }
-    }
-    return false;
-  }
-
   /*
    * returns null if the operation fails
    */
@@ -2747,31 +2627,11 @@ public abstract class AbstractRegionMap implements RegionMap {
     // reference of the diskSegmentRegion as a ThreadLocal so that if the diskRegionSegment
     // is later changed by another thread, we can do the necessary.
     boolean uninitialized = !owner.isInitialized();
-    // SqlFabric Changes - BEGIN
-    if (enqueDelta(event, ifOld)) {
-      return null;
-    }
-
-    final IndexUpdater indexManager = getIndexUpdater();
-
-    boolean sqlfIndexLocked = false;
-    // SqlFabric Changes - END
-
     boolean retrieveOldValueForDelta = event.getDeltaBytes() != null
         && event.getRawNewValue() == null;
     lockForCacheModification(owner, event);
     IndexManager oqlIndexManager = null;
     try {
-      // take read lock for SQLF index initializations if required; the index
-      // GII lock is for any updates that may come in while index is being
-      // loaded during replay see bug #41377; this will go away once we allow
-      // for indexes to be loaded completely in parallel (#40899); need to
-      // take this lock before the RegionEntry lock else a deadlock can happen
-      // between this thread and index loading thread that will first take the
-      // corresponding write lock on the IndexUpdater
-      if (indexManager != null) {
-        sqlfIndexLocked = indexManager.lockForIndexGII();
-      }
       // Fix for Bug #44431. We do NOT want to update the region and wait
       // later for index INIT as region.clear() can cause inconsistency if
       // happened in parallel as it also does index INIT.
@@ -2883,8 +2743,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                 } finally {
                   OffHeapHelper.release(oldValueForDelta);
                   if (re != null && !onlyExisting && !isOpComplete(re, event)) {
-                    owner.cleanUpOnIncompleteOp(event, re, eventRecorded,
-                        false/* updateStats */, replaceOnClient);
+                    owner.cleanUpOnIncompleteOp(event, re);
                   }
                   else if (re != null && owner.isUsedForPartitionedRegionBucket()) {
                   BucketRegion br = (BucketRegion)owner;
@@ -2902,9 +2761,6 @@ public abstract class AbstractRegionMap implements RegionMap {
       throw dae;
     } finally {
         releaseCacheModificationLock(owner, event);
-        if (sqlfIndexLocked) {
-          indexManager.unlockForIndexGII();
-        }
         if (oqlIndexManager != null) {
           oqlIndexManager.countDownIndexUpdaters();
         }
@@ -2914,22 +2770,6 @@ public abstract class AbstractRegionMap implements RegionMap {
             final boolean invokeListeners = event.basicGetNewValue() != Token.TOMBSTONE;
             owner.basicPutPart3(event, result, !uninitialized,
                 lastModifiedTime, invokeListeners, ifNew, ifOld, expectedOldValue, requireOldValue);
-          } catch (EntryExistsException eee) {
-            // SQLFabric changes BEGIN
-            // ignore EntryExistsException in distribution from a non-empty
-            // region since actual check will be done in this put itself
-            // and it can happen in distribution if put comes in from
-            // GII as well as distribution channel
-            if (indexManager != null) {
-              if (logger.isTraceEnabled()) {
-                logger.trace("basicPut: ignoring EntryExistsException in distribution {}", eee);
-              }
-            }
-            else {
-              // can this happen for non-SQLFabric case?
-              throw eee;
-            }
-            // SQLFabric changes END
           } finally {
             // bug 32589, post update may throw an exception if exception occurs
             // for any recipients
@@ -2985,23 +2825,11 @@ public abstract class AbstractRegionMap implements RegionMap {
     return true;
   }
 
-  // Asif: If the new value is an instance of SerializableDelta, then
-  // the old value requirement is a must & it needs to be faulted in
-  // if overflown to disk without affecting LRU? This is needed for
-  // Sql Fabric.
-  // [sumedh] store both the value in VM and the value in VM or disk;
-  // the former is used for updating the VM size calculations, while
-  // the latter is used in other places like passing to
-  // SqlfIndexManager or setting the old value in the event; this is
-  // required since using the latter for updating the size
-  // calculations will be incorrect in case the value was read from
-  // disk but not brought into the VM like what getValueInVMOrDisk
-  // method does when value is not found in VM
   // PRECONDITION: caller must be synced on re
   private void setOldValueInEvent(EntryEventImpl event, RegionEntry re, boolean cacheWrite, boolean requireOldValue) {
-    boolean needToSetOldValue = getIndexUpdater() != null || cacheWrite || requireOldValue || event.getOperation().guaranteesOldValue();
+    boolean needToSetOldValue = cacheWrite || requireOldValue || event.getOperation().guaranteesOldValue();
     if (needToSetOldValue) {
-      if (event.hasDelta() || event.getOperation().guaranteesOldValue()) {
+      if (event.getOperation().guaranteesOldValue()) {
         // In these cases we want to even get the old value from disk if it is not in memory
         ReferenceCountHelper.skipRefCountTracking();
         @Released Object oldValueInVMOrDisk = re.getValueOffHeapOrDiskWithoutFaultIn(event.getLocalRegion());
@@ -3186,7 +3014,6 @@ public abstract class AbstractRegionMap implements RegionMap {
     final boolean isClientTXOriginator = owner.cache.isClient() && !hasRemoteOrigin;
     final boolean isRegionReady = owner.isInitialized();
     @Released EntryEventImpl cbEvent = null;
-    @Released EntryEventImpl sqlfEvent = null;
     boolean invokeCallbacks = shouldCreateCBEvent(owner, isRegionReady);
     boolean cbEventInPending = false;
     cbEvent = createCBEvent(owner, putOp, key, newValue, txId, 
@@ -3202,12 +3029,6 @@ public abstract class AbstractRegionMap implements RegionMap {
       txHandleWANEvent(owner, cbEvent, txEntryState);
     }
     
-    if (/*owner.isUsedForPartitionedRegionBucket() && */ 
-       (getIndexUpdater() != null ||
-       (newValue instanceof com.gemstone.gemfire.internal.cache.delta.Delta))) {
-      sqlfEvent = createCBEvent(owner, putOp, key, newValue, txId, 
-          txEvent, eventId, aCallbackArgument,filterRoutingInfo,bridgeContext, txEntryState, versionTag, tailKey);
-    }
     boolean opCompleted = false;
     // Fix for Bug #44431. We do NOT want to update the region and wait
     // later for index INIT as region.clear() can cause inconsistency if
@@ -3240,9 +3061,6 @@ public abstract class AbstractRegionMap implements RegionMap {
                     cbEvent.setRegionEntry(re);
                     cbEvent.setOldValue(re.getValueInVM(owner)); // OFFHEAP eei
                   }
-                  if (sqlfEvent != null) {
-                    sqlfEvent.setOldValue(re.getValueInVM(owner)); // OFFHEAP eei
-                  }
 
                   boolean clearOccured = false;
                   // Set RegionEntry updateInProgress
@@ -3259,14 +3077,8 @@ public abstract class AbstractRegionMap implements RegionMap {
                     }
                     re.setValueResultOfSearch(putOp.isNetSearch());
                     try {
-                      // Rahul: applies the delta and sets the new value in 
-                      // region entry (required for sqlfabric delta).
                       processAndGenerateTXVersionTag(owner, cbEvent, re, txEntryState);
-                      if (newValue instanceof com.gemstone.gemfire.internal.cache.delta.Delta 
-                          && sqlfEvent != null) {
-                        //cbEvent.putExistingEntry(owner, re);
-                        sqlfEvent.putExistingEntry(owner, re);
-                      } else {
+                      {
                         re.setValue(owner, re.prepareValueForCache(owner, newValue, cbEvent, !putOp.isCreate()));
                       }
                       if (putOp.isCreate()) {
@@ -3276,9 +3088,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                         // an issue with normal GFE Delta and will have to be fixed 
                         // in a similar manner and may be this fix the the one for 
                         // other delta can be combined.
-                        if (sqlfEvent != null) {
-                          owner.updateSizeOnPut(key, oldSize, sqlfEvent.getNewValueBucketSize());
-                        } else {
+                        {
                           owner.updateSizeOnPut(key, oldSize, owner.calculateRegionEntryValueSize(re));
                         }
                       }
@@ -3350,9 +3160,6 @@ public abstract class AbstractRegionMap implements RegionMap {
                     cbEvent.setRegionEntry(oldRe);
                     cbEvent.setOldValue(oldRe.getValueInVM(owner)); // OFFHEAP eei
                   }
-                  if (sqlfEvent != null) {
-                    sqlfEvent.setOldValue(oldRe.getValueInVM(owner)); // OFFHEAP eei
-                  }
                   boolean clearOccured = false;
                   // Set RegionEntry updateInProgress
                   if (owner.indexMaintenanceSynchronous) {
@@ -3370,11 +3177,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                     try {
                       processAndGenerateTXVersionTag(owner, cbEvent, oldRe, txEntryState);
                       boolean wasTombstone = oldRe.isTombstone();
-                      if (newValue instanceof com.gemstone.gemfire.internal.cache.delta.Delta 
-                          && sqlfEvent != null ) {
-                        //cbEvent.putExistingEntry(owner, oldRe);
-                        sqlfEvent.putExistingEntry(owner, oldRe);
-                      } else {
+                      {
                         oldRe.setValue(owner, oldRe.prepareValueForCache(owner, newValue, cbEvent, !putOp.isCreate()));
                         if (wasTombstone) {
                           owner.unscheduleTombstone(oldRe);
@@ -3387,9 +3190,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                         // an issue with normal GFE Delta and will have to be fixed 
                         // in a similar manner and may be this fix the the one for 
                         // other delta can be combined.
-                        if (sqlfEvent != null) {
-                          owner.updateSizeOnPut(key, oldSize, sqlfEvent.getNewValueBucketSize());
-                        } else {
+                        {
                           owner.updateSizeOnPut(key, oldSize, owner.calculateRegionEntryValueSize(oldRe));
                         }
                       }
@@ -3452,9 +3253,7 @@ public abstract class AbstractRegionMap implements RegionMap {
                 try {
                   
                   processAndGenerateTXVersionTag(owner, cbEvent, newRe, txEntryState);
-                  if (sqlfEvent != null ) {
-                    sqlfEvent.putNewEntry(owner,newRe);
-                  } else {
+                  {
                     newRe.setValue(owner, newRe.prepareValueForCache(owner, newValue, cbEvent, !putOp.isCreate()));
                   }
                   owner.updateSizeOnCreate(newRe.getKey(), owner.calculateRegionEntryValueSize(newRe));
@@ -3514,7 +3313,6 @@ public abstract class AbstractRegionMap implements RegionMap {
     }
     } finally {
       if (!cbEventInPending) cbEvent.release();
-      if (sqlfEvent != null) sqlfEvent.release();
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
index f8e04a6..d085c52 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
@@ -192,7 +192,6 @@ public class BucketAdvisor extends CacheDistributionAdvisor  {
     return advisor;
   }
 
-  // For SQLFabric ALTER TABLE that may change colocation
   public void resetParentAdvisor(int bucketId) {
     PartitionedRegion colocatedRegion = ColocationHelper
         .getColocatedRegion(this.pRegion);
@@ -1117,11 +1116,6 @@ public class BucketAdvisor extends CacheDistributionAdvisor  {
         // only one thread should be attempting to volunteer at one time
         return;
       }
-      // if member is still not initialized then don't volunteer for primary
-      final GemFireCacheImpl cache = (GemFireCacheImpl)getBucket().getCache();
-      if (!cache.doVolunteerForPrimary(this)) {
-        return;
-      }
       if (this.volunteeringDelegate == null) {
         this.volunteeringDelegate = new VolunteeringDelegate();
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketRegion.java
index c87cc3d..e0f6fa2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketRegion.java
@@ -19,7 +19,6 @@ package com.gemstone.gemfire.internal.cache;
 import com.gemstone.gemfire.*;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.cache.partition.PartitionListener;
-import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.AtomicLongWithTerminalState;
@@ -34,8 +33,15 @@ import com.gemstone.gemfire.internal.Version;
 import com.gemstone.gemfire.internal.cache.BucketAdvisor.BucketProfile;
 import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
 import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
-import com.gemstone.gemfire.internal.cache.delta.Delta;
-import com.gemstone.gemfire.internal.cache.partitioned.*;
+import com.gemstone.gemfire.internal.cache.partitioned.Bucket;
+import com.gemstone.gemfire.internal.cache.partitioned.DestroyMessage;
+import com.gemstone.gemfire.internal.cache.partitioned.InvalidateMessage;
+import com.gemstone.gemfire.internal.cache.partitioned.LockObject;
+import com.gemstone.gemfire.internal.cache.partitioned.PRTombstoneMessage;
+import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
+import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
+import com.gemstone.gemfire.internal.cache.partitioned.PutMessage;
+import com.gemstone.gemfire.internal.cache.partitioned.RemoveAllPRMessage;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientTombstoneMessage;
@@ -1470,7 +1476,6 @@ implements Bucket
     .append("[path='").append(getFullPath())
     .append(";serial=").append(getSerialNumber())
     .append(";primary=").append(getBucketAdvisor().getProxyBucketRegion().isPrimary())
-    .append(";indexUpdater=").append(getIndexUpdater())
     .append("]")
     .toString();
   }
@@ -1695,10 +1700,8 @@ implements Bucket
       setDeltaIfNeeded(event);
     }
     if (msg != null) {
-      // The primary bucket member which is being modified remotely by a GemFire
+      // The primary bucket member which is being modified remotely by a
       // thread via a received PartitionedMessage
-      //Asif: Some of the adjunct recepients include those members which 
-      // are sqlFabricHub & would need old value along with news
       msg = msg.getMessageForRelayToListeners(event, adjunctRecipients);
       msg.setSender(this.partitionedRegion.getDistributionManager()
           .getDistributionManagerId());
@@ -1987,28 +1990,6 @@ implements Bucket
   public CacheWriter basicGetWriter() {
     return this.partitionedRegion.basicGetWriter();
   }
-   @Override
-  void cleanUpOnIncompleteOp(EntryEventImpl event,   RegionEntry re, 
-      boolean eventRecorded, boolean updateStats, boolean isReplace) {
-     
-    
-    if(!eventRecorded || isReplace) {
-      //No indexes updated so safe to remove.
-      this.entries.removeEntry(event.getKey(), re, updateStats) ;      
-    }/*else {
-      //if event recorded is true, that means as per event tracker entry is in
-      //system. As per sqlfabric, indexes have been updated. What is not done
-      // is basicPutPart2( distribution etc). So we do nothing as PR's re-attempt
-      // will do the required basicPutPart2. If we remove the entry here, than 
-      //event tracker will not allow re insertion. So either we do nothing or
-      //if we remove ,than we have to update sqlfindexes as well as undo recording
-      // of event.
-       //TODO:OQL indexes? : Hope they get updated during retry. The issue is that oql indexes
-       // get updated after distribute , so it is entirely possible that oql index are 
-        // not updated. what if retry fails?
-       
-    }*/
-  }
 
   /* (non-Javadoc)
    * @see com.gemstone.gemfire.internal.cache.partitioned.Bucket#getBucketOwners()
@@ -2058,7 +2039,7 @@ implements Bucket
       return 0;
     }
     if (!(value instanceof byte[]) && !(value instanceof CachedDeserializable)
-        && !(value instanceof com.gemstone.gemfire.Delta) && !(value instanceof Delta)
+        && !(value instanceof com.gemstone.gemfire.Delta)
         && !(value instanceof GatewaySenderEventImpl)) {
     // ezoerner:20090401 it's possible this value is a Delta
       throw new InternalGemFireError("DEBUG: calcMemSize: weird value (class " 
@@ -2198,10 +2179,6 @@ implements Bucket
   
 
   public void preDestroyBucket(int bucketId) {
-    final IndexUpdater indexUpdater = getIndexUpdater();
-    if (indexUpdater != null) {
-      indexUpdater.clearIndexes(this, bucketId);
-    }
   }
   @Override
   public void cleanupFailedInitialization()


[06/17] incubator-geode git commit: GEODE-11: Added support for lucene index profile exchange

Posted by kl...@apache.org.
GEODE-11: Added support for lucene index profile exchange


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/c742c4e5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/c742c4e5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/c742c4e5

Branch: refs/heads/feature/GEODE-837
Commit: c742c4e54c0b3ab16ce7845e2534e746cefbbce1
Parents: 8e21638
Author: Barry Oglesby <bo...@pivotal.io>
Authored: Thu Jun 2 13:38:23 2016 -0700
Committer: Barry Oglesby <bo...@pivotal.io>
Committed: Mon Jun 6 09:56:48 2016 -0700

----------------------------------------------------------------------
 .../internal/DataSerializableFixedID.java       |   2 +-
 .../cache/CacheDistributionAdvisor.java         |  22 +-
 .../internal/cache/CacheServiceProfile.java     |  40 +++
 .../internal/cache/CreateRegionProcessor.java   |  23 +-
 .../internal/cache/GemFireCacheImpl.java        |   2 +-
 .../internal/cache/InternalRegionArguments.java |  16 ++
 .../gemfire/internal/cache/LocalRegion.java     |  11 +-
 .../internal/cache/PartitionedRegion.java       |   8 +-
 .../gemfire/internal/i18n/LocalizedStrings.java |  10 +-
 .../sanctionedDataSerializables.txt             | 150 +++++-----
 .../internal/LuceneIndexCreationProfile.java    | 189 +++++++++++++
 .../lucene/internal/LuceneServiceImpl.java      |  15 +-
 .../internal/xml/LuceneIndexCreation.java       |   9 +-
 .../gemfire/cache/lucene/LuceneDUnitTest.java   |  38 +++
 .../lucene/LuceneIndexCreationDUnitTest.java    | 281 +++++++++++++++++++
 .../gemfire/cache/lucene/LuceneQueriesBase.java |  18 +-
 .../LuceneIndexCreationProfileJUnitTest.java    | 144 ++++++++++
 .../cache/lucene/test/LuceneTestUtilities.java  |  11 +
 ...ifferentFieldAnalyzerSizesFails1.1.cache.xml |  37 +++
 ...ifferentFieldAnalyzerSizesFails1.2.cache.xml |  36 +++
 ...ifferentFieldAnalyzerSizesFails2.1.cache.xml |  36 +++
 ...ifferentFieldAnalyzerSizesFails2.2.cache.xml |  37 +++
 ...ifyDifferentFieldAnalyzersFails1.1.cache.xml |  36 +++
 ...ifyDifferentFieldAnalyzersFails1.2.cache.xml |  36 +++
 ...ifyDifferentFieldAnalyzersFails2.1.cache.xml |  37 +++
 ...ifyDifferentFieldAnalyzersFails2.2.cache.xml |  37 +++
 ...ifyDifferentFieldAnalyzersFails3.1.cache.xml |  37 +++
 ...ifyDifferentFieldAnalyzersFails3.2.cache.xml |  37 +++
 ...tTest.verifyDifferentFieldsFails.1.cache.xml |  36 +++
 ...tTest.verifyDifferentFieldsFails.2.cache.xml |  37 +++
 ...t.verifyDifferentIndexNamesFails.1.cache.xml |  36 +++
 ...t.verifyDifferentIndexNamesFails.2.cache.xml |  36 +++
 ...est.verifyDifferentIndexesFails1.1.cache.xml |  36 +++
 ...est.verifyDifferentIndexesFails1.2.cache.xml |  32 +++
 ...est.verifyDifferentIndexesFails2.1.cache.xml |  36 +++
 ...est.verifyDifferentIndexesFails2.2.cache.xml |  39 +++
 36 files changed, 1531 insertions(+), 112 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
index beaadb1..0788503 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
@@ -848,7 +848,7 @@ public interface DataSerializableFixedID extends SerializationVersions {
   public static final short LUCENE_ENTRY_SCORE = 2174;
   public static final short LUCENE_TOP_ENTRIES = 2175;
   public static final short LUCENE_TOP_ENTRIES_COLLECTOR = 2176;
-  
+
   // NOTE, codes > 65535 will take 4 bytes to serialize
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
index 2e60c55..c4a8e27 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor.java
@@ -99,6 +99,8 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
 
   private static final int ASYNC_EVENT_QUEUE_IDS_MASK = 0x400000;
   private static final int IS_OFF_HEAP_MASK =           0x800000;
+  private static final int CACHE_SERVICE_PROFILES_MASK = 0x1000000;
+
   
   // moved initializ* to DistributionAdvisor
 
@@ -567,6 +569,8 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
      */
     public boolean hasCacheServer = false;
 
+    public List<CacheServiceProfile> cacheServiceProfiles = new ArrayList<>();
+
     /** for internal use, required for DataSerializer.readObject */
     public CacheProfile() {
     }
@@ -619,6 +623,7 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
       if (!this.gatewaySenderIds.isEmpty()) s |= GATEWAY_SENDER_IDS_MASK;
       if (!this.asyncEventQueueIds.isEmpty()) s |= ASYNC_EVENT_QUEUE_IDS_MASK;
       if (this.isOffHeap) s |= IS_OFF_HEAP_MASK;
+      if (!this.cacheServiceProfiles.isEmpty()) s |= CACHE_SERVICE_PROFILES_MASK;
       Assert.assertTrue(!this.scope.isLocal());
       return s;
     }
@@ -724,6 +729,14 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
       return this.subscriptionAttributes.getInterestPolicy().isAll();
     }
 
+    public void addCacheServiceProfile(CacheServiceProfile profile) {
+      this.cacheServiceProfiles.add(profile);
+    }
+
+    private boolean hasCacheServiceProfiles(int bits) {
+      return (bits & CACHE_SERVICE_PROFILES_MASK) != 0;
+    }
+
     /**
      * Used to process an incoming cache profile.
      */
@@ -829,9 +842,12 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
         writeSet(asyncEventQueueIds, out);
       }
       DataSerializer.writeObject(this.filterProfile, out);
+      if (!cacheServiceProfiles.isEmpty()) {
+        DataSerializer.writeObject(cacheServiceProfiles, out);
+      }
     }
 
-    private void writeSet(Set<String> set, DataOutput out) throws IOException {
+    private void writeSet(Set<?> set, DataOutput out) throws IOException {
       // to fix bug 47205 always serialize the Set as a HashSet.
       out.writeByte(DSCODE.HASH_SET);
       InternalDataSerializer.writeSet(set, out);
@@ -853,6 +869,9 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
         asyncEventQueueIds = DataSerializer.readObject(in);
       }
       this.filterProfile = DataSerializer.readObject(in);
+      if (hasCacheServiceProfiles(bits)) {
+        cacheServiceProfiles = DataSerializer.readObject(in);
+      }
     }
 
     @Override
@@ -885,6 +904,7 @@ public class CacheDistributionAdvisor extends DistributionAdvisor  {
       sb.append("; gatewaySenderIds =" + this.gatewaySenderIds);
       sb.append("; asyncEventQueueIds =" + this.asyncEventQueueIds);
       sb.append("; IsOffHeap=" + this.isOffHeap);
+      sb.append("; cacheServiceProfiles=" + this.cacheServiceProfiles);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServiceProfile.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServiceProfile.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServiceProfile.java
new file mode 100644
index 0000000..d25e92a
--- /dev/null
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheServiceProfile.java
@@ -0,0 +1,40 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.internal.cache;
+
+import com.gemstone.gemfire.cache.Region;
+
+/**
+ * CacheServiceProfiles track additions to a {@link Region} made by a {@link CacheService}.
+ * They are added to the {@link CacheDistributionAdvisor.CacheProfile} during {@link Region}
+ * creation and are exchanged by the {@link CreateRegionProcessor}.
+ */
+public interface CacheServiceProfile {
+
+  /**
+   * Return the id of this profile
+   * @return the id of this profile
+   */
+  String getId();
+
+  /**
+   * @param regionPath The path of the region to which this profile is associated
+   * @param profile The CacheServiceProfile to check compatibility against
+   * @return A string message of incompatibility or null if the profiles are compatible
+   */
+  String checkCompatibility(String regionPath, CacheServiceProfile profile);
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CreateRegionProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CreateRegionProcessor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CreateRegionProcessor.java
index d063a54..bc44c1c 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CreateRegionProcessor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CreateRegionProcessor.java
@@ -572,8 +572,7 @@ public class CreateRegionProcessor implements ProfileExchangeProcessor {
         if (!rgn.getFullPath().contains( 
             DynamicRegionFactoryImpl.dynamicRegionListName)) { 
           result = LocalizedStrings.CreateRegionProcessor_CANNOT_CREATE_REGION_0_WITH_1_GATEWAY_SENDER_IDS_BECAUSE_ANOTHER_CACHE_HAS_THE_SAME_REGION_WITH_2_GATEWAY_SENDER_IDS
-            .toLocalizedString(new Object[] { this.regionPath,
-                otherGatewaySenderIds, myGatewaySenderIds });
+            .toLocalizedString(this.regionPath, myGatewaySenderIds, otherGatewaySenderIds);
         }
       }
       
@@ -582,8 +581,7 @@ public class CreateRegionProcessor implements ProfileExchangeProcessor {
       if (!isLocalOrRemoteAccessor(rgn, profile) && !otherAsynEventQueueIds
           .equals(myAsyncEventQueueIds)) {
         result = LocalizedStrings.CreateRegionProcessor_CANNOT_CREATE_REGION_0_WITH_1_ASYNC_EVENT_IDS_BECAUSE_ANOTHER_CACHE_HAS_THE_SAME_REGION_WITH_2_ASYNC_EVENT_IDS
-            .toLocalizedString(new Object[] { this.regionPath,
-                otherAsynEventQueueIds, myAsyncEventQueueIds });
+            .toLocalizedString(this.regionPath, myAsyncEventQueueIds, otherAsynEventQueueIds);
       }
       
       final PartitionAttributes pa = rgn.getAttributes()
@@ -611,7 +609,22 @@ public class CreateRegionProcessor implements ProfileExchangeProcessor {
         result = LocalizedStrings.CreateRegionProcessor_CANNOT_CREATE_REGION_0_WITH_OFF_HEAP_EQUALS_1_BECAUSE_ANOTHER_CACHE_2_HAS_SAME_THE_REGION_WITH_OFF_HEAP_EQUALS_3
             .toLocalizedString(new Object[] { this.regionPath, profile.isOffHeap, myId, otherIsOffHeap });
       }
-      
+
+      String cspResult = null;
+      // TODO Compares set sizes and equivalent entries.
+      if (profile.cacheServiceProfiles != null) {
+        for (CacheServiceProfile remoteProfile : profile.cacheServiceProfiles) {
+          CacheServiceProfile localProfile = ((LocalRegion) rgn).getCacheServiceProfile(remoteProfile.getId());
+          cspResult = remoteProfile.checkCompatibility(rgn.getFullPath(), localProfile);
+          if (cspResult != null) {
+            break;
+          }
+        }
+        // Don't overwrite result with null in case it has already been set in a previous compatibility check.
+        if (cspResult != null) {
+          result = cspResult;
+        }
+      }
       if (logger.isDebugEnabled()) {
         logger.debug("CreateRegionProcessor.checkCompatibility: this={}; other={}; result={}", rgn, profile, result);
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
index b08c480..5355a2b 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
@@ -1066,7 +1066,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
       this.services.put(service.getInterface(), service);
     }
   }
-  
+
   private boolean isNotJmxManager(){
     return (this.system.getConfig().getJmxManagerStart() != true);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
index 7974418..3a254d5 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
@@ -17,7 +17,10 @@
 package com.gemstone.gemfire.internal.cache;
 
 import java.io.InputStream;
+import java.util.HashMap;
 import java.util.List;
+import java.util.Map;
+import java.util.Set;
 
 import com.gemstone.gemfire.cache.query.internal.IndexUpdater;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
@@ -66,6 +69,7 @@ public final class InternalRegionArguments
   private List indexes;
   private boolean declarativeIndexCreation;
 
+  private Map<String,CacheServiceProfile> cacheServiceProfiles;
 
   /* methods that set and retrieve internal state used to configure a Region */
 
@@ -317,4 +321,16 @@ public final class InternalRegionArguments
   public boolean getDeclarativeIndexCreation() {
     return this.declarativeIndexCreation;
   }
+
+  public InternalRegionArguments addCacheServiceProfile(CacheServiceProfile profile) {
+    if(this.cacheServiceProfiles == null) {
+      this.cacheServiceProfiles = new HashMap<>();
+    }
+    this.cacheServiceProfiles.put(profile.getId(), profile);
+    return this;
+  }
+
+  public Map<String,CacheServiceProfile> getCacheServiceProfiles() {
+    return this.cacheServiceProfiles;
+  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/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 31a0aae..6b664fe 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
@@ -452,6 +452,8 @@ public class LocalRegion extends AbstractRegion
     return this.stopper;
   }
 
+  protected Map<String,CacheServiceProfile> cacheServiceProfiles;
+
   ////////////////// Public Methods ///////////////////////////////////////////
 
   static String calcFullPath(String regionName, LocalRegion parentRegion) {
@@ -550,7 +552,10 @@ public class LocalRegion extends AbstractRegion
     this.isUsedForSerialGatewaySenderQueue = internalRegionArgs.isUsedForSerialGatewaySenderQueue();
     this.isUsedForParallelGatewaySenderQueue = internalRegionArgs.isUsedForParallelGatewaySenderQueue();
     this.serialGatewaySender = internalRegionArgs.getSerialGatewaySender();
-    
+    this.cacheServiceProfiles = internalRegionArgs.getCacheServiceProfiles() == null
+        ? null
+        : Collections.unmodifiableMap(internalRegionArgs.getCacheServiceProfiles());
+
     if (!isUsedForMetaRegion && !isUsedForPartitionedRegionAdmin
         && !isUsedForPartitionedRegionBucket
         && !isUsedForSerialGatewaySenderQueue
@@ -10989,6 +10994,10 @@ public class LocalRegion extends AbstractRegion
            || isUsedForPartitionedRegionBucket();
   }
 
+  public CacheServiceProfile getCacheServiceProfile(String id) {
+    return this.cacheServiceProfiles.get(id);
+  }
+
   public LoaderHelper createLoaderHelper(Object key, Object callbackArgument,
       boolean netSearchAllowed, boolean netLoadAllowed,
       SearchLoadAndWriteProcessor searcher)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/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 667c765..9375d04 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
@@ -5181,7 +5181,13 @@ public class PartitionedRegion extends LocalRegion implements
     }
     
     fillInProfile((PartitionProfile) profile);
-    
+
+    if (cacheServiceProfiles != null) {
+      for (CacheServiceProfile csp : cacheServiceProfiles.values()) {
+        profile.addCacheServiceProfile(csp);
+      }
+    }
+
     profile.isOffHeap = getOffHeap();
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/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 954d2c8..13eca56 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
@@ -3761,7 +3761,15 @@ public class LocalizedStrings {
   public static final StringId SwaggerConfig_DOC_TITLE = new StringId(6621, "Apache Geode Documentation");
   public static final StringId SwaggerConfig_DOC_LINK = new StringId(6622, "http://geode.incubator.apache.org/docs/");
 
-  public static final StringId LuceneXmlParser_CLASS_0_IS_NOT_AN_INSTANCE_OF_ANALYZER = new StringId(6623, "Class \"{0}\" is not an instance of Analyzer.");
+  public static final StringId LuceneXmlParser_CLASS_0_IS_NOT_AN_INSTANCE_OF_ANALYZER = new StringId(6623, "Class {0} is not an instance of Analyzer.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_FIELDS_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_FIELDS_3 = new StringId(6624, "Cannot create Lucene index {0} on region {1} with fields {2} because another member defines the same index with fields {3}.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_ANALYZER_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_ANALYZER_3 = new StringId(6625, "Cannot create Lucene index {0} on region {1} with analyzer {2} because another member defines the same index with analyzer {3}.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_FIELD_ANALYZERS_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_NO_FIELD_ANALYZERS = new StringId(6626, "Cannot create Lucene index {0} on region {1} with field analyzers {2} because another member defines the same index with no field analyzers.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_NO_FIELD_ANALYZERS_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_FIELD_ANALYZERS_2 = new StringId(6627, "Cannot create Lucene index {0} on region {1} with no field analyzers because another member defines the same index with field analyzers {2}.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_FIELD_ANALYZERS_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_FIELD_ANALYZERS_3 = new StringId(6628, "Cannot create Lucene index {0} on region {1} with field analyzers {2} because another member defines the same index with field analyzers {3}.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_NO_ANALYZER_ON_FIELD_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_ANALYZER_3_ON_THAT_FIELD = new StringId(6629, "Cannot create Lucene index {0} on region {1} with no analyzer on field {2} because another member defines the same index with analyzer {3} on that field.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_ANALYZER_2_ON_FIELD_3_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_NO_ANALYZER_ON_THAT_FIELD = new StringId(6630, "Cannot create Lucene index {0} on region {1} with analyzer {2} on field {3} because another member defines the same index with no analyzer on that field.");
+  public static final StringId LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_ANALYZER_2_ON_FIELD_3_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_ANALYZER_4_ON_THAT_FIELD = new StringId(6631, "Cannot create Lucene index {0} on region {1} with analyzer {2} on field {3} because another member defines the same index with analyzer {4} on that field.");
 
   /** Testing strings, messageId 90000-99999 **/
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/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 d2204a0..cd659e6 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
@@ -285,12 +285,12 @@ fromData,16,2a2bb700172a2bb900180100b50008b1
 toData,16,2a2bb700192b2ab40008b9001a0200b1
 
 com/gemstone/gemfire/distributed/internal/membership/InternalDistributedMember,6
-fromData,33,2a2bb6009a2ab4001ab20090b60070a100112ab400282bb900910200a700044db1
-fromDataPre_GFE_7_1_0_0,292,2bb8009b4d2bb9009c01003e2a2bb80088b500062ab2000399000e2c2ab40006b8009da700072cb60007b500062bb9009e010036041504047e99000704a700040336051504057e99000704a700040336062a1504077e99000704a7000403b500392a2bb9009c0100b500102a2bb9009c0100b500022a2bb9009e0100b500122a2bb8008ab5001f2a2bb80088b500172ab40012100da0000e2a2bb80088b50018a700172bb800883a071907c6000c2a1907b8009fb500132bb800883a072bb8008bb6008c36082abb008d5919071508b7008eb5001dbb0033592ab400102ab400022ab400122ab400132ab400172ab4001f2ab4001db700343a092a2c1d150515062bb800a0b600701909b80027b500282ab7000b2ab400129e000704a7000403b80042b1
-fromDataPre_GFE_9_0_0_0,296,2bb8009b4d2bb9009c01003e2a2bb80088b500062ab2000399000e2c2ab40006b8009da700072cb60007b500062bb9009e010036041504047e99000704a700040336051504057e99000704a700040336062a1504077e99000704a7000403b500392a2bb9009c0100b500102a2bb9009c0100b500022a2bb9009e0100b500122a2bb8008ab5001f2a2bb80088b500172ab40012100da0000e2a2bb80088b50018a700172bb800883a071907c6000c2a1907b8009fb500132bb800883a072bb8008bb6008c36082abb008d5919071508b7008eb5001d2a15042bb7008fbb0033592ab400102ab400022ab400122ab400132ab400172ab4001f2ab4001db700343a092a2c1d150515062ab4001a1909b80027b500282ab7000b2ab400129e000704a7000403b80042b1
-toData,29,2a2bb600942ab4001ab20090b60070a1000d2ab600952bb900840200b1
-toDataPre_GFE_7_1_0_0,226,2ab400129e000704a7000403b800422ab6004e2bb800962b2ab6004db9009702002ab400062bb8007b033d2ab40028b9007c01009900071c04803d2ab40028b9006b01009900071c05803d2ab400399900071c07803d2b1c1100ff7e91b9009802002b2ab40010b9009702002b2ab40002b9009702002b2ab40012b9009802002ab4001f2bb8007e2ab400172bb8007b2ab40012100da0000e2ab400182bb8007ba7000e2ab40013b800992bb8007b2ab4001dc700081246a7000a2ab4001db6007f2bb8007b2ab4001dc7000911012ca7000a2ab4001db60080b800812bb80082b1
-toDataPre_GFE_9_0_0_0,240,2ab400129e000704a7000403b800422ab6004e2bb800962b2ab6004db9009702002ab400062bb8007b033d2ab40028b9007c01009900071c04803d2ab40028b9006b01009900071c05803d2ab400399900071c07803d1c1008803d2b1c1100ff7e91b9009802002b2ab40010b9009702002b2ab40002b9009702002b2ab40012b9009802002ab4001f2bb8007e2ab400172bb8007b2ab40012100da0000e2ab400182bb8007ba7000e2ab40013b800992bb8007b2ab4001dc700081246a7000a2ab4001db6007f2bb8007b2ab4001dc7000911012ca7000a2ab4001db60080b800812bb800822b2ab4001a04b80083b1
+fromData,33,2a2bb6009b2ab4001bb20091b60071a100112ab400292bb900920200a700044db1
+fromDataPre_GFE_7_1_0_0,292,2bb8009c4d2bb9009d01003e2a2bb80089b500062ab2000399000e2c2ab40006b8009ea700072cb60007b500062bb9009f010036041504047e99000704a700040336051504057e99000704a700040336062a1504077e99000704a7000403b5003a2a2bb9009d0100b500112a2bb9009d0100b500022a2bb9009f0100b500132a2bb8008bb500202a2bb80089b500182ab40013100da0000e2a2bb80089b50019a700172bb800893a071907c6000c2a1907b800a0b500142bb800893a072bb8008cb6008d36082abb008e5919071508b7008fb5001ebb0034592ab400112ab400022ab400132ab400142ab400182ab400202ab4001eb700353a092a2c1d150515062bb800a1b600711909b80028b500292ab7000b2ab400139e000704a7000403b80043b1
+fromDataPre_GFE_9_0_0_0,296,2bb8009c4d2bb9009d01003e2a2bb80089b500062ab2000399000e2c2ab40006b8009ea700072cb60007b500062bb9009f010036041504047e99000704a700040336051504057e99000704a700040336062a1504077e99000704a7000403b5003a2a2bb9009d0100b500112a2bb9009d0100b500022a2bb9009f0100b500132a2bb8008bb500202a2bb80089b500182ab40013100da0000e2a2bb80089b50019a700172bb800893a071907c6000c2a1907b800a0b500142bb800893a072bb8008cb6008d36082abb008e5919071508b7008fb5001e2a15042bb70090bb0034592ab400112ab400022ab400132ab400142ab400182ab400202ab4001eb700353a092a2c1d150515062ab4001b1909b80028b500292ab7000b2ab400139e000704a7000403b80043b1
+toData,29,2a2bb600952ab4001bb20091b60071a1000d2ab600962bb900850200b1
+toDataPre_GFE_7_1_0_0,226,2ab400139e000704a7000403b800432ab6004f2bb800972b2ab6004eb9009802002ab400062bb8007c033d2ab40029b9007d01009900071c04803d2ab40029b9006c01009900071c05803d2ab4003a9900071c07803d2b1c1100ff7e91b9009902002b2ab40011b9009802002b2ab40002b9009802002b2ab40013b9009902002ab400202bb8007f2ab400182bb8007c2ab40013100da0000e2ab400192bb8007ca7000e2ab40014b8009a2bb8007c2ab4001ec700081247a7000a2ab4001eb600802bb8007c2ab4001ec7000911012ca7000a2ab4001eb60081b800822bb80083b1
+toDataPre_GFE_9_0_0_0,240,2ab400139e000704a7000403b800432ab6004f2bb800972b2ab6004eb9009802002ab400062bb8007c033d2ab40029b9007d01009900071c04803d2ab40029b9006c01009900071c05803d2ab4003a9900071c07803d1c1008803d2b1c1100ff7e91b9009902002b2ab40011b9009802002b2ab40002b9009802002b2ab40013b9009902002ab400202bb8007f2ab400182bb8007c2ab40013100da0000e2ab400192bb8007ca7000e2ab40014b8009a2bb8007c2ab4001ec700081247a7000a2ab4001eb600802bb8007c2ab4001ec7000911012ca7000a2ab4001eb60081b800822bb800832b2ab4001b04b80084b1
 
 com/gemstone/gemfire/distributed/internal/membership/NetView,2
 fromData,69,2a2bb8005bc00023b5000e2a2bb9005c0100b500032a2bb8005db500062abb0007592ab40006b70008b500092a2bb8005eb5000b2a2bb8005eb5000d2a2bb8005fb50002b1
@@ -687,8 +687,8 @@ fromData,217,2a2bb900420100b500032a2bb900430100b5000a2a2bb900430100b500102a2bb90
 toData,217,2b2ab40003b9003b02002b2ab4000ab9003c02002b2ab40010b9003c02002b2ab40012b9003b02002b2ab40016b9003b02002b2ab4000eb9003b02002b2ab40018b9003b02002b2ab4001ab9003b02002b2ab40014b9003b02002ab400052bb8003d2ab4001c2bb8003e2ab400072bb8003d2ab4001f2bb8003f2ab400212bb800402b2ab4000cb9003b02002b2ab40023b9003c02002b2ab60041b900280100b9003b02002ab60041b9002601002bb8003d2ab60041b9002a01002bb8003d2ab60041b9002a0100c700102ab60041b9002c01002bb8003db1
 
 com/gemstone/gemfire/internal/admin/remote/RemoteCacheInfo,2
-fromData,106,2a2bb8002fb500032a2bb900300100b500052a2bb900310100b500072a2bb900300100b500092a2bb900300100b5000b2a2bb900300100b5000d2a2bb900300100b5000f2a2bb80032b500102a2bb80033c0001fb500112a2bb80034b500122a2bb900310100b50028b1
-toData,103,2ab400032bb800292b2ab40005b9002a02002b2ab40007b9002b02002b2ab40009b9002a02002b2ab4000bb9002a02002b2ab4000db9002a02002b2ab4000fb9002a02002ab400102bb8002c2ab400112bb8002d2ab400122bb8002e2b2ab40028b9002b0200b1
+fromData,106,2a2bb80030b500032a2bb900310100b500052a2bb900320100b500072a2bb900310100b500092a2bb900310100b5000b2a2bb900310100b5000d2a2bb900310100b5000f2a2bb80033b500102a2bb80034c00020b500112a2bb80035b500122a2bb900320100b50029b1
+toData,103,2ab400032bb8002a2b2ab40005b9002b02002b2ab40007b9002c02002b2ab40009b9002b02002b2ab4000bb9002b02002b2ab4000db9002b02002b2ab4000fb9002b02002ab400102bb8002d2ab400112bb8002e2ab400122bb8002f2b2ab40029b9002c0200b1
 
 com/gemstone/gemfire/internal/admin/remote/RemoteCacheStatistics,2
 fromData,51,2a2bb900100100b500032a2bb900100100b500052a2bb900100100b500072a2bb900100100b500092a2bb900110100b5000bb1
@@ -747,8 +747,8 @@ fromData,6,2a2bb7000bb1
 toData,6,2a2bb7000ab1
 
 com/gemstone/gemfire/internal/admin/remote/RootRegionResponse,2
-fromData,34,2a2bb700222a2bb80023c00018c00018b500192a2bb80023c00018c00018b5001ab1
-toData,22,2a2bb700202ab400192bb800212ab4001a2bb80021b1
+fromData,34,2a2bb700232a2bb80024c00019c00019b5001a2a2bb80024c00019c00019b5001bb1
+toData,22,2a2bb700212ab4001a2bb800222ab4001b2bb80022b1
 
 com/gemstone/gemfire/internal/admin/remote/ShutdownAllGatewayHubsRequest,2
 fromData,16,2a2bb700072a2bb900080100b50005b1
@@ -871,8 +871,8 @@ fromData,93,2a2bb7000a2a2bb8000bb6000cb500032a2bb8000db6000eb500042a2bb8000fb600
 toData,91,2a2bb700132ab40003b800142bb800152ab40004b800162bb800172ab40005b800182bb800192b2ab40009b9001a02002ab400099e00262ab400074d2cbe3e03360415041da200152c1504323a0519052bb8001b840401a7ffebb1
 
 com/gemstone/gemfire/internal/cache/CacheDistributionAdvisor$CacheProfile,2
-fromData,94,2a2bb700662bb9006701003d2a1cb6001c2a1cb700689900162abb006959b7006ab500272ab400272bb8006b2a1cb7006c99000e2a2bb8006dc0006eb5000e2a1cb7006f99000e2a2bb8006dc0006eb5000f2a2bb8006dc00070b50017b1
-toData,81,2a2bb7005e2b2ab6001bb9005f02002ab40027c6000b2ab400272bb800602ab4000eb9002d01009a000c2a2ab4000e2bb700612ab4000fb9002d01009a000c2a2ab4000f2bb700612ab400172bb80062b1
+fromData,113,2a2bb7006c2bb9006d01003d2a1cb6001f2a1cb7006e9900162abb006f59b70070b5002a2ab4002a2bb800712a1cb7007299000e2a2bb80073c00074b5000e2a1cb7007599000e2a2bb80073c00074b5000f2a2bb80073c00076b5001a2a1cb7007799000e2a2bb80073c00078b50019b1
+toData,101,2a2bb700642b2ab6001eb9006502002ab4002ac6000b2ab4002a2bb800662ab4000eb9003001009a000c2a2ab4000e2bb700672ab4000fb9003001009a000c2a2ab4000f2bb700672ab4001a2bb800682ab40019b9003401009a000b2ab400192bb80068b1
 
 com/gemstone/gemfire/internal/cache/CacheServerAdvisor$CacheServerProfile,2
 fromData,53,2a2bb700112a2bb80012b500042a2bb900130100b500062abb001459b70015b500052ab400052bb800162a2bb900170100b60018b1
@@ -891,8 +891,8 @@ fromData,6,2a2bb70007b1
 toData,6,2a2bb70006b1
 
 com/gemstone/gemfire/internal/cache/CreateRegionProcessor$CreateRegionMessage,2
-fromData,45,2a2bb7008c2a2bb8008db5000a2a2bb8008ec00055b500432a2bb9008f0100b500032a2bb900900100b50064b1
-toData,42,2a2bb700922ab4000a2bb800932ab400432bb800942b2ab40003b9009502002b2ab40064b900960200b1
+fromData,45,2a2bb700942a2bb80095b5000a2a2bb80096c00055b500432a2bb900970100b500032a2bb900980100b50064b1
+toData,42,2a2bb7009a2ab4000a2bb8009b2ab400432bb8009c2b2ab40003b9009d02002b2ab40064b9009e0200b1
 
 com/gemstone/gemfire/internal/cache/CreateRegionProcessor$CreateRegionReplyMessage,2
 fromData,161,2a2bb700062bb90007010099000e2a2bb80008c00009b5000a2bb9000b01003d1c9a000b2a01b5000ca700352abb000d591cb7000eb5000c033e1d1ca20022bb000f59b700103a0419042bb800112ab4000c1904b6001257840301a7ffdf2bb90007010099000c2a2b03b80013b500142bb9000701009900162abb001559b70016b500172ab400172bb800112a2bb900070100b500182a2bb900190100b50004b1
@@ -947,8 +947,8 @@ fromData,14,2a2bb7001a2a2bb8001bb50004b1
 toData,14,2a2bb700182ab400042bb80019b1
 
 com/gemstone/gemfire/internal/cache/DistributedCacheOperation$CacheOperationMessage,2
-fromData,318,2bb9009501003d2bb9009501003e2a1cb500962a1c2bb600972a2bb80098b500232a2bb900990100b8009ab500092a1c1100807e99000704a7000403b500042a1c10087e99000704a7000403b500581c1102007e99000b2a2bb8009bb500882a1c1104007e99000704a7000403b500072a1c10407e99000704a7000403b5001d2ab4001d9900382bb900990100360415049a000b2a03b5001ea7001b150404a0000b2a04b5001ea7000dbb009c59129db7009ebf2a2bb8009fb5001f1c1101007e99000704a700040336042a1c1108007e99000704a7000403b500a015049900162abb00a159b700a2b5000e2ab4000e2bb800a31c1110007e99001c1c1120007e99000704a700040336052a15052bb800a4b5000a1d1104007e9900232a04b5000f2ac100a59900172ac000a51d1101007e99000704a7000403b600a6b1
-toData,202,033d033e2a1cb600a73d2a1db600a83e2b1cb900a902002b1db900a902002ab4000d9e000d2b2ab4000db900aa02002ab400232bb800ab2b2ab40009b400acb900ad02002ab40088c6000b2ab400882bb800ae2ab4001d9900542b2ab4001e99000704a7000403b900ad02002ab4001eb800af36042ab4001e9a001f2ab4001fc10020990015013a052ab4001fc00020c000203a06a7000c2ab4001f3a05013a061504190519062bb800b02ab4000ec6000b2ab4000e2bb800b12ab4000ac6000b2ab4000a2bb800b1b1
+fromData,318,2bb9009301003d2bb9009301003e2a1cb500942a1c2bb600952a2bb80096b500212a2bb900970100b80098b500072a1c1100807e99000704a7000403b500022a1c10087e99000704a7000403b500561c1102007e99000b2a2bb8009ab500862a1c1104007e99000704a7000403b500052a1c10407e99000704a7000403b5001b2ab4001b9900382bb900970100360415049a000b2a03b5001ca7001b150404a0000b2a04b5001ca7000dbb009b59129cb7009dbf2a2bb8009eb5001d1c1101007e99000704a700040336042a1c1108007e99000704a7000403b5009f15049900162abb00a059b700a1b5000c2ab4000c2bb800a21c1110007e99001c1c1120007e99000704a700040336052a15052bb800a3b500081d1104007e9900232a04b5000d2ac100a49900172ac000a41d1101007e99000704a7000403b600a5b1
+toData,202,033d033e2a1cb600a63d2a1db600a73e2b1cb900a802002b1db900a802002ab4000b9e000d2b2ab4000bb900a902002ab400212bb800aa2b2ab40007b400abb900ac02002ab40086c6000b2ab400862bb800ad2ab4001b9900542b2ab4001c99000704a7000403b900ac02002ab4001cb800ae36042ab4001c9a001f2ab4001dc1001e990015013a052ab4001dc0001ec0001e3a06a7000c2ab4001d3a05013a061504190519062bb800af2ab4000cc6000b2ab4000c2bb800b02ab40008c6000b2ab400082bb800b0b1
 
 com/gemstone/gemfire/internal/cache/DistributedClearOperation$ClearRegionMessage,2
 fromData,53,2a2bb700212ab800222bb90023010032b500022a2bb80024c00025b500062a2bb80024c00026b500172a2bb80024c00027b50011b1
@@ -966,19 +966,19 @@ com/gemstone/gemfire/internal/cache/DistributedPutAllOperation$PutAllEntryData,1
 toData,236,2ab4000a4e2ab4000c3a042d2bb8003d1904c1003e9a00081904c700192b03b9003f02001904c0003ec0003e2bb80040a700341904c1004199001f1904c000413a052b04b9003f02001905b9004201002bb80040a700102b04b9003f020019042bb800432b2ab40012b40044b9003f02002ab4000636052ab40026c6000a150507809136052ab40017c6001d15051008809136052ab40017c1004599000b150510208091360515051080809136052b1505b9003f02002ab40026c6000b2ab400262bb8003d2ab40017c6000b2ab400172bb800462ab6002899000b2ab400142bb800462ab400082bb80047b1
 
 com/gemstone/gemfire/internal/cache/DistributedPutAllOperation$PutAllMessage,2
-fromData,197,2a2bb7003e2a2bb8003fc00040b500072a2bb8004188b500172a2ab40017bd0042b500082ab400179e00722bb800434dbb004459b700454e03360415042ab40017a200202ab400081504bb0042592b2ab4000715042c2db7004653840401a7ffdd2bb9004701003604150499002f2bb800483a0503360615062ab40017a2001d2ab4000815063219051506b60049c0004ab50030840601a7ffe02ab4004b1140007e99000e2a2bb8003fc0004cb5000d2a2ab4004b1180007e99000704a7000403b5001cb1
-toData,181,2a2bb7004d2ab400072bb8004e2ab40017852bb8004f2ab400179e008bbb0050592ab40017b700514d033e2ab400080332b40052c10026360403360515052ab40017a200531d9a00122ab40008150532b40030c60005043e2ab40008150532b400303a062c1906b60053572ab4000815053201b500302ab400081505322b1504b600542ab400081505321906b50030840501a7ffaa2b1db9005502001d9900082c2bb800562ab4000dc6000b2ab4000d2bb8004eb1
+fromData,197,2a2bb7003c2a2bb8003dc0003eb500052a2bb8003f88b500152a2ab40015bd0040b500062ab400159e00722bb800414dbb004259b700434e03360415042ab40015a200202ab400061504bb0040592b2ab4000515042c2db7004453840401a7ffdd2bb9004501003604150499002f2bb800463a0503360615062ab40015a2001d2ab4000615063219051506b60047c00048b5002e840601a7ffe02ab400491140007e99000e2a2bb8003dc0004bb5000b2a2ab400491180007e99000704a7000403b5001ab1
+toData,181,2a2bb7004c2ab400052bb8004d2ab40015852bb8004e2ab400159e008bbb004f592ab40015b700504d033e2ab400060332b40051c10024360403360515052ab40015a200531d9a00122ab40006150532b4002ec60005043e2ab40006150532b4002e3a062c1906b60052572ab4000615053201b5002e2ab400061505322b1504b600532ab400061505321906b5002e840501a7ffaa2b1db9005402001d9900082c2bb800552ab4000bc6000b2ab4000b2bb8004db1
 
 com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage,2
-fromData,171,2a2bb700622bb9006301003d1c047e9900142a2bb900640100b500092ab40009b800651c077e99000d2a2bb900640100b500061c057e99000e2a2bb80066c00067b500072bb800664e2dc100689900252a03b5000e2a2dc00068b80069b500082ab40008c7001b2a2dc00068b5004da700102a2dc0006ab500082a04b5000e2a2bb80066c0006bb5000a2a2bb8006cb5000c2a2bb8006db5000b2a1c10407e99000704a7000403b5000db1
-toData,173,2a2bb7006f033d2ab400099900081c0480933d2ab40006029f00081c0780933d2ab40007c600081c0580933d2ab4000d9900091c104080933d2b1cb9007002002ab4000999000d2b2ab40009b9007102002ab40006029f000d2b2ab40006b9007102002ab40007c6000b2ab400072bb800722ab4000e99000e2ab400082bb80072a700102ab40008b9005801002bb800722ab4000a2bb800722ab4000cc000732bb800742ab4000b2bb80075b1
+fromData,171,2a2bb700612bb9006201003d1c047e9900142a2bb900640100b500082ab40008b800651c077e99000d2a2bb900640100b500051c057e99000e2a2bb80066c00067b500062bb800664e2dc100689900252a03b5000d2a2dc00068b80069b500072ab40007c7001b2a2dc00068b5004ca700102a2dc0006ab500072a04b5000d2a2bb80066c0006bb500092a2bb8006cb5000b2a2bb8006db5000a2a1c10407e99000704a7000403b5000cb1
+toData,173,2a2bb7006f033d2ab400089900081c0480933d2ab40005029f00081c0780933d2ab40006c600081c0580933d2ab4000c9900091c104080933d2b1cb9007002002ab4000899000d2b2ab40008b9007102002ab40005029f000d2b2ab40005b9007102002ab40006c6000b2ab400062bb800722ab4000d99000e2ab400072bb80072a700102ab40007b9005701002bb800722ab400092bb800722ab4000bc000732bb800742ab4000a2bb80075b1
 
 com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation$RemoveAllEntryData,1
 toData,146,2ab4000a4e2d2bb8003f2b2ab40010b40040b9004102002ab4000636042ab40022c6000a150407809136042ab40015c6001d15041008809136042ab40015c1004299000b150410208091360415041080809136042b1504b9004102002ab40022c6000b2ab400222bb8003f2ab40015c6000b2ab400152bb800432ab6002499000b2ab400122bb800432ab400082bb80044b1
 
 com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation$RemoveAllMessage,2
-fromData,197,2a2bb7003a2a2bb8003bc0003cb500052a2bb8003d88b500152a2ab40015bd003eb500062ab400159e00722bb8003f4dbb004059b700414e03360415042ab40015a200202ab400061504bb003e592b2ab4000515042c2db7004253840401a7ffdd2bb9004301003604150499002f2bb800443a0503360615062ab40015a2001d2ab4000615063219051506b60045c00046b5002d840601a7ffe02ab400471140007e99000e2a2bb8003bc00048b5000b2a2ab400471180007e99000704a7000403b5001ab1
-toData,181,2a2bb700492ab400052bb8004a2ab40015852bb8004b2ab400159e008bbb004c592ab40015b7004d4d033e2ab400060332b4004ec10028360403360515052ab40015a200531d9a00122ab40006150532b4002dc60005043e2ab40006150532b4002d3a062c1906b6004f572ab4000615053201b5002d2ab400061505322b1504b600502ab400061505321906b5002d840501a7ffaa2b1db9005102001d9900082c2bb800522ab4000bc6000b2ab4000b2bb8004ab1
+fromData,197,2a2bb700382a2bb80039c0003ab500032a2bb8003b88b500132a2ab40013bd003cb500042ab400139e00722bb8003d4dbb003e59b7003f4e03360415042ab40013a200202ab400041504bb003c592b2ab4000315042c2db7004053840401a7ffdd2bb9004101003604150499002f2bb800423a0503360615062ab40013a2001d2ab4000415063219051506b60043c00044b5002b840601a7ffe02ab400451140007e99000e2a2bb80039c00047b500092a2ab400451180007e99000704a7000403b50018b1
+toData,181,2a2bb700482ab400032bb800492ab40013852bb8004a2ab400139e008bbb004b592ab40013b7004c4d033e2ab400040332b4004dc10026360403360515052ab40013a200531d9a00122ab40004150532b4002bc60005043e2ab40004150532b4002b3a062c1906b6004e572ab4000415053201b5002b2ab400041505322b1504b6004f2ab400041505321906b5002b840501a7ffaa2b1db9005002001d9900082c2bb800512ab40009c6000b2ab400092bb80049b1
 
 com/gemstone/gemfire/internal/cache/DistributedTombstoneOperation$TombstoneMessage,2
 fromData,125,2a2bb700162ab800172bb90018010032b500192bb9001a01003d2abb001b591cb7001cb500112bb9001d01003e03360415041ca2003e1d990019bb001e59b7001f3a0619062bb8002019063a05a700092bb800213a052ab4001119052bb900220100b80023b90024030057840401a7ffc22a2bb80025c00026b50003b1
@@ -989,8 +989,8 @@ fromData,17,2a2bb80005b500022a2bb80005b50003b1
 toData,17,2ab400022bb800042ab400032bb80004b1
 
 com/gemstone/gemfire/internal/cache/EntryEventImpl,2
-fromData,214,2a2bb8001bc0001cb5001d2bb8001b4d2bb8001b4e2abb001e592c2d01b7001fb500202a2bb900210100b80022b500232a2bb900240100b500092ab400202bb8001bb600252a2bb8001bc00026b5000a2bb9002701009900112a2bb8001bc00028b50008a700322bb9002701009900212a2bb80029b5002a2a2ab4002ab500062a2ab4002ab8002bb50005a7000b2a2bb8001bb500052bb9002701009900192a2bb80029b5002c2a2ab4002cb8002bb50007a7000b2a2bb8001bb500072a2bb8002db5002e2a2bb8002fb5000b2a2bb80030b50014b1
-toData,312,2ab4001d2bb801602ab6008c2bb801602ab40020b6018d2bb801602b2ab40023b4018eb9018f02002b2ab4000911c03f7eb9019002002ab6004b2bb801602ab4000a2bb801602ab40008c6000704a70004033d2b1cb9019102001c99000e2ab400082bb80160a700682ab600414e2dc100823604150499000e2dc00082b900b8010036042b1504b901910200150499003b2ab4002ac6000e2ab4002a2bb80192a7002e2ab40006c6000e2ab400062bb80192a7001c2dc000823a051905b900c601002bb80193a700082d2bb801602ab700434d2cc100823e1d99000d2cc00082b900b801003e2b1db9019102001d9900292ab4002cc6000e2ab4002c2bb80192a7001c2cc000823a041904b900c601002bb80193a700082c2bb801602ab4002ec001942bb801952ab600582bb801602ab400142bb80196b1
+fromData,214,2a2bb80016c00017b500182bb800164d2bb800164e2abb0019592c2d01b7001ab5001b2a2bb9001c0100b8001db5001e2a2bb9001f0100b500092ab4001b2bb80016b600202a2bb80016c00021b5000a2bb9002201009900112a2bb80016c00023b50008a700322bb9002201009900212a2bb80024b500252a2ab40025b500062a2ab40025b80026b50005a7000b2a2bb80016b500052bb9002201009900192a2bb80024b500272a2ab40027b80026b50007a7000b2a2bb80016b500072a2bb80028b500292a2bb8002ab5000b2a2bb8002bb50014b1
+toData,312,2ab400182bb8015a2ab600882bb8015a2ab4001bb601872bb8015a2b2ab4001eb40188b9018902002b2ab4000911c03f7eb9018a02002ab600462bb8015a2ab4000a2bb8015a2ab40008c6000704a70004033d2b1cb9018b02001c99000e2ab400082bb8015aa700682ab6003c4e2dc1007e3604150499000e2dc0007eb900b4010036042b1504b9018b0200150499003b2ab40025c6000e2ab400252bb8018ca7002e2ab40006c6000e2ab400062bb8018ca7001c2dc0007e3a051905b900c201002bb8018da700082d2bb8015a2ab7003e4d2cc1007e3e1d99000d2cc0007eb900b401003e2b1db9018b02001d9900292ab40027c6000e2ab400272bb8018ca7001c2cc0007e3a041904b900c201002bb8018da700082c2bb8015a2ab40029c0018e2bb8018f2ab600542bb8015a2ab400142bb80190b1
 
 com/gemstone/gemfire/internal/cache/EntrySnapshot,2
 fromData,50,2a03b500052bb9004101003d1c9900112abb000759b70042b50004a7000e2abb000359b70043b500042ab400042bb60044b1
@@ -1063,8 +1063,8 @@ fromData,64,2a2bb700112a2bb900120100b5000c2a2bb900130100b5000d2a2bb900120100b500
 toData,90,2a2bb700192b2ab4000cb9001a02002b2ab4000db9001b02002b2ab40004b9001a02002ab4000e2bb8001ca7002e4d2cc1001d99000cbb001e592cb7001fbfbb0016592ab4000eb60020b60021b700224e2d2cb60018572dbfb1
 
 com/gemstone/gemfire/internal/cache/GridAdvisor$GridProfile,2
-fromData,26,2a2bb7001f2a2bb80020b500052a2bb80021b500062ab60007b1
-toData,22,2a2bb7001c2ab400052bb8001d2ab400062bb8001eb1
+fromData,26,2a2bb7001e2a2bb8001fb500052a2bb80020b500062ab60007b1
+toData,22,2a2bb7001b2ab400052bb8001c2ab400062bb8001db1
 
 com/gemstone/gemfire/internal/cache/HARegion$HARegionAdvisor$HAProfile,2
 fromData,47,2a2bb700032bb9000401003d2a1cb200057e99000704a7000403b500062a1cb200077e99000704a7000403b50008b1
@@ -1139,8 +1139,8 @@ fromData,26,2a2bb700242a2bb900250100b500042a2bb900250100b50002b1
 toData,26,2a2bb700222b2ab40004b9002302002b2ab40002b900230200b1
 
 com/gemstone/gemfire/internal/cache/MemberFunctionStreamingMessage,2
-fromData,163,2a2bb700512bb9005201003d1c047e9900142a2bb900530100b500082ab40008b800541c077e99000d2a2bb900530100b500051c057e99000e2a2bb80055c00056b500062bb800554e2dc1002a9900252a03b5000a2a2dc0002ab80057b500072ab40007c7001b2a2dc0002ab5001aa700102a2dc00058b500072a04b5000a2a2bb80055b500092a2bb80055c00059b500102a1c10407e99000704a7000403b5000bb1
-toData,162,2a2bb7005b033d2ab400089900081c0480933d2ab40005029f00081c0780933d2ab40006c600081c0580933d2ab4000b9900091c104080933d2b1cb9005c02002ab4000899000d2b2ab40008b9005d02002ab40005029f000d2b2ab40005b9005d02002ab40006c6000b2ab400062bb8005e2ab4000a99000e2ab400072bb8005ea700102ab40007b9001f01002bb8005e2ab400092bb8005e2ab400102bb8005eb1
+fromData,163,2a2bb700502bb9005101003d1c047e9900142a2bb900530100b500072ab40007b800541c077e99000d2a2bb900530100b500041c057e99000e2a2bb80055c00056b500052bb800554e2dc100299900252a03b500092a2dc00029b80057b500062ab40006c7001b2a2dc00029b50019a700102a2dc00058b500062a04b500092a2bb80055b500082a2bb80055c00059b5000f2a1c10407e99000704a7000403b5000ab1
+toData,162,2a2bb7005b033d2ab400079900081c0480933d2ab40004029f00081c0780933d2ab40005c600081c0580933d2ab4000a9900091c104080933d2b1cb9005c02002ab4000799000d2b2ab40007b9005d02002ab40004029f000d2b2ab40004b9005d02002ab40005c6000b2ab400052bb8005e2ab4000999000e2ab400062bb8005ea700102ab40006b9001e01002bb8005e2ab400082bb8005e2ab4000f2bb8005eb1
 
 com/gemstone/gemfire/internal/cache/Node,2
 fromData,60,2abb001c59b7001db500052ab400052bb8001e2a2bb9001f0100b500032a2bb900200100b500042a2bb900210100b500152a2bb9001f0100b50006b1
@@ -1171,8 +1171,8 @@ fromData,145,2a2bb80032b500032a2bb80032b500052a2bb80032b500072a2bb80032b500092a2
 toData,145,2ab400032bb8002d2ab400052bb8002d2ab400072bb8002d2ab400092bb8002d2ab4000a2bb8002d2ab4000b2bb8002d2ab4000f2bb8002d2ab4000e2bb8002e2ab400122bb8002e2ab400162bb8002d2ab400182bb8002d2ab400082bb8002f2ab400142bb8002f2ab4001b2bb800302ab4001f2bb800312ab400202bb800312ab400132bb8002d2ab4001c2bb8002fb1
 
 com/gemstone/gemfire/internal/cache/PreferBytesCachedDeserializable,2
-fromData,9,2a2bb8000fb50003b1
-toData,9,2ab400032bb80010b1
+fromData,9,2a2bb8000eb50002b1
+toData,9,2ab400022bb8000fb1
 
 com/gemstone/gemfire/internal/cache/QueuedOperation,1
 toData,97,2b2ab40002b40035b9003602002ab400072bb800372ab40002b600319900442ab400032bb800372ab40002b600169a000d2ab40002b600159900282b2ab40006b9003602002ab40006049f000e2ab400042bb80038a7000b2ab400052bb80037b1
@@ -1186,16 +1186,16 @@ fromData,24,2a2bb700222a2bb80023b500022a2bb900240100b50003b1
 toData,24,2a2bb700252ab400022bb800262b2ab40003b900270200b1
 
 com/gemstone/gemfire/internal/cache/RemoteContainsKeyValueMessage,2
-fromData,33,2a2bb700312a2bb80032b500062a2ab4003310407e99000704a7000403b50005b1
-toData,14,2a2bb700342ab400062bb80035b1
+fromData,33,2a2bb700302a2bb80031b500052a2ab4003210407e99000704a7000403b50004b1
+toData,14,2a2bb700332ab400052bb80034b1
 
 com/gemstone/gemfire/internal/cache/RemoteContainsKeyValueMessage$RemoteContainsKeyValueReplyMessage,2
 fromData,16,2a2bb700152a2bb900160100b50003b1
 toData,16,2a2bb700172b2ab40003b900180200b1
 
 com/gemstone/gemfire/internal/cache/RemoteDestroyMessage,2
-fromData,131,2a2bb7008b2a2bb8008cb7008d2a2bb8008cb5000c2a2bb9008e0100b8008fb5000e2ab400901102007e99000e2a2bb8008cc00091b500102ab400901104007e99000e2a2bb8008cc00034b500662a2bb8008cc00092b500122ab400059900122bb9008e0100572a2bb80093b700222a2bb8008cb500082a2bb8008cc00094b50017b1
-toData,135,2a2bb700952ab6006c2bb800962ab4000c2bb800962b2ab4000eb40097b9009802002ab40010c6000b2ab400102bb800962ab40066c6000b2ab400662bb800962ab400122bb800962ab4000599002a2b2ab4000699000704a7000403b9009802002ab40006b800993d1c2ab7009a2ab600702bb8009b2ab400082bb800962ab400172bb80096b1
+fromData,131,2a2bb7008b2a2bb8008cb7008d2a2bb8008cb5000a2a2bb9008e0100b8008fb5000c2ab400901102007e99000e2a2bb8008cc00091b5000e2ab400901104007e99000e2a2bb8008cc00033b500662a2bb8008cc00092b500102ab400039900122bb9008e0100572a2bb80093b700202a2bb8008cb500062a2bb8008cc00094b50015b1
+toData,135,2a2bb700952ab6006c2bb800962ab4000a2bb800962b2ab4000cb40097b9009802002ab4000ec6000b2ab4000e2bb800962ab40066c6000b2ab400662bb800962ab400102bb800962ab4000399002a2b2ab4000499000704a7000403b9009802002ab40004b800993d1c2ab7009a2ab600702bb8009b2ab400062bb800962ab400152bb80096b1
 
 com/gemstone/gemfire/internal/cache/RemoteDestroyMessage$DestroyReplyMessage,2
 fromData,52,2a2bb700232bb9002401003d1c047e99000704a70004033e1c057e99000704a700040336041d99000d2a15042bb80025b50009b1
@@ -1230,20 +1230,20 @@ fromData,52,2a2bb700242bb9002501003d1c047e99000704a70004033e1c057e99000704a70004
 toData,57,2a2bb70020033d2ab40003c600081c0480913d2ab40003c100219900081c0580913d2b1cb9002202002ab40003c6000b2ab400032bb80023b1
 
 com/gemstone/gemfire/internal/cache/RemoteOperationMessage,2
-fromData,43,2a2bb700542a2bb900550100b500562a2ab400562bb600572a2bb80058b5000a2a2bb900590100b50006b1
-toData,103,2a2bb7005a2ab6005b3d2b1cb9005c02002ab4000c99000d2b2ab4000cb9005d02002ab4005e99000d2b2ab4005eb9005f02002ab60015029f000d2b2ab60015b9005d02002ab60016c6000b2ab600162bb800602ab4000a2bb800612b2ab40006b900620200b1
+fromData,43,2a2bb7005c2a2bb9005d0100b5005e2a2ab4005e2bb6005f2a2bb80060b5000a2a2bb900610100b50006b1
+toData,103,2a2bb700622ab600633d2b1cb9006402002ab4000c99000d2b2ab4000cb9006502002ab4006699000d2b2ab40066b9006702002ab60015029f000d2b2ab60015b9006502002ab60016c6000b2ab600162bb800682ab4000a2bb800692b2ab40006b9006a0200b1
 
 com/gemstone/gemfire/internal/cache/RemotePutAllMessage,2
-fromData,243,2a2bb700522a2bb80053c00054b500392a2bb80053b5003b2a2ab4005510087e99000704a7000403b500062ab4005510407e99000e2a2bb80053c00056b500502a2ab400551100807e99000704a7000403b500052a2ab400551101007e99000704a7000403b500042a2bb8005788b500082a2ab40008bd0058b500072ab400089e00722bb800594dbb005a59b7005b4e03360415042ab40008a200202ab400071504bb0058592b2ab4003915042c2db7005c53840401a7ffdd2bb9005d01003604150499002f2bb8005e3a0503360615062ab40008a2001d2ab4000715063219051506b6005fc00020b50021840601a7ffe0b1
-toData,189,2a2bb700602ab400392bb800612ab4003b2bb800612ab40050c6000b2ab400502bb800612ab40008852bb800622ab400089e008bbb0063592ab40008b700644d033e2ab400070332b40065c10066360403360515052ab40008a200531d9a00122ab40007150532b40021c60005043e2ab40007150532b400213a062c1906b60067572ab4000715053201b500212ab400071505322b1504b600682ab400071505321906b50021840501a7ffaa2b1db9006902001d9900082c2bb8006ab1
+fromData,243,2a2bb700512a2bb80052c00053b500372a2bb80052b500392a2ab4005410087e99000704a7000403b500042ab4005410407e99000e2a2bb80052c00056b5004f2a2ab400541100807e99000704a7000403b500032a2ab400541101007e99000704a7000403b500022a2bb8005788b500062a2ab40006bd0058b500052ab400069e00722bb800594dbb005a59b7005b4e03360415042ab40006a200202ab400051504bb0058592b2ab4003715042c2db7005c53840401a7ffdd2bb9005d01003604150499002f2bb8005e3a0503360615062ab40006a2001d2ab4000515063219051506b6005fc0001eb5001f840601a7ffe0b1
+toData,189,2a2bb700602ab400372bb800612ab400392bb800612ab4004fc6000b2ab4004f2bb800612ab40006852bb800622ab400069e008bbb0063592ab40006b700644d033e2ab400050332b40065c10066360403360515052ab40006a200531d9a00122ab40005150532b4001fc60005043e2ab40005150532b4001f3a062c1906b60067572ab4000515053201b5001f2ab400051505322b1504b600682ab400051505321906b5001f840501a7ffaa2b1db9006902001d9900082c2bb8006ab1
 
 com/gemstone/gemfire/internal/cache/RemotePutAllMessage$PutAllReplyMessage,2
 fromData,17,2a2bb7001a2a2bb8001bc0001cb50001b1
 toData,14,2a2bb7001d2ab400012bb8001eb1
 
 com/gemstone/gemfire/internal/cache/RemotePutMessage,2
-fromData,242,2a2bb700752a2bb80076b600772bb9007801003d2a1cb200797e91b500072a2bb80076b500222a2bb9007a0100b500232a2bb9007b0100b8007cb500251cb2007d7e99000e2a2bb80076c0007eb500271cb2007f7e99000e2a2bb80076c00041b500802abb008159b70082b500292ab400292bb800832ab400841120007e99000b2a2bb80076b500112ab4000a99001e2a2bb9007b010004a0000704a7000403b500082a2bb80085b700862ab4000704a0000e2a2bb80076b70087a7000b2a2bb80085b700882ab400841104007e9900102a04b5000c2a2bb80085b500891cb2008a7e99000e2a2bb80076c0008bb5002eb1
-toData,252,2a03b5000b2a2bb7008d2ab6008e2bb8008f2ab400073d2ab40027c600091cb2007d803d2ab40080c600091cb2007f803d2ab4002ec600091cb2008a803d2b1cb9009002002ab600912bb8008f2b2ab40023b9009203002b2ab40025b40093b9009002002ab40027c6000b2ab400272bb8008f2ab40080c6000b2ab400802bb8008f2ab400292bb800942ab40011c6000b2ab400112bb8008f2ab4000a99002a2b2ab4000899000704a7000403b9009002002ab40008b800953e1d2ab700962ab600972bb800982ab400072ab400722ab600992bb800982ab4000eb6009ac6000e2ab4000eb6009a2bb8009b2ab4002ec6000b2ab4002e2bb8008fb1
+fromData,242,2a2bb700742a2bb80075b600762bb9007701003d2a1cb200787e91b500052a2bb80075b500202a2bb900790100b500212a2bb9007a0100b8007bb500231cb2007c7e99000e2a2bb80075c0007db500251cb2007e7e99000e2a2bb80075c0003fb5007f2abb008059b70081b500272ab400272bb800822ab400831120007e99000b2a2bb80075b5000f2ab4000899001e2a2bb9007a010004a0000704a7000403b500062a2bb80084b700852ab4000504a0000e2a2bb80075b70086a7000b2a2bb80084b700872ab400831104007e9900102a04b5000a2a2bb80084b500881cb200897e99000e2a2bb80075c0008ab5002cb1
+toData,252,2a03b500092a2bb7008c2ab6008d2bb8008e2ab400053d2ab40025c600091cb2007c803d2ab4007fc600091cb2007e803d2ab4002cc600091cb20089803d2b1cb9008f02002ab600902bb8008e2b2ab40021b9009103002b2ab40023b40092b9008f02002ab40025c6000b2ab400252bb8008e2ab4007fc6000b2ab4007f2bb8008e2ab400272bb800932ab4000fc6000b2ab4000f2bb8008e2ab4000899002a2b2ab4000699000704a7000403b9008f02002ab40006b800943e1d2ab700952ab600962bb800972ab400052ab400712ab600982bb800972ab4000cb60099c6000e2ab4000cb600992bb8009a2ab4002cc6000b2ab4002c2bb8008eb1
 
 com/gemstone/gemfire/internal/cache/RemotePutMessage$PutReplyMessage,2
 fromData,81,2a2bb700262bb9002701001100ff7e913d2a1c047e99000704a7000403b500032a2bb900270100b80028b500022a2bb80029b500061c057e9900181c077e99000704a70004033e2a1d2bb8002ab50007b1
@@ -1258,8 +1258,8 @@ fromData,6,2a2bb70014b1
 toData,6,2a2bb70015b1
 
 com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage,2
-fromData,203,2a2bb7004e2a2bb8004fc00050b500362a2bb8004fb500382a2ab4005110087e99000704a7000403b500032ab4005110407e99000e2a2bb8004fc00052b5004c2a2bb8005388b500052a2ab40005bd0054b500042ab400059e00722bb800554dbb005659b700574e03360415042ab40005a200202ab400041504bb0054592b2ab4003615042c2db7005853840401a7ffdd2bb9005901003604150499002f2bb8005a3a0503360615062ab40005a2001d2ab4000415063219051506b6005bc0001db5001e840601a7ffe0b1
-toData,189,2a2bb7005c2ab400362bb8005d2ab400382bb8005d2ab4004cc6000b2ab4004c2bb8005d2ab40005852bb8005e2ab400059e008bbb005f592ab40005b700604d033e2ab400040332b40061c10062360403360515052ab40005a200531d9a00122ab40004150532b4001ec60005043e2ab40004150532b4001e3a062c1906b60063572ab4000415053201b5001e2ab400041505322b1504b600642ab400041505321906b5001e840501a7ffaa2b1db9006502001d9900082c2bb80066b1
+fromData,203,2a2bb7004d2a2bb8004ec0004fb500352a2bb8004eb500372a2ab4005010087e99000704a7000403b500022ab4005010407e99000e2a2bb8004ec00052b5004b2a2bb8005388b500042a2ab40004bd0054b500032ab400049e00722bb800554dbb005659b700574e03360415042ab40004a200202ab400031504bb0054592b2ab4003515042c2db7005853840401a7ffdd2bb9005901003604150499002f2bb8005a3a0503360615062ab40004a2001d2ab4000315063219051506b6005bc0001cb5001d840601a7ffe0b1
+toData,189,2a2bb7005c2ab400352bb8005d2ab400372bb8005d2ab4004bc6000b2ab4004b2bb8005d2ab40004852bb8005e2ab400049e008bbb005f592ab40004b700604d033e2ab400030332b40061c10062360403360515052ab40004a200531d9a00122ab40003150532b4001dc60005043e2ab40003150532b4001d3a062c1906b60063572ab4000315053201b5001d2ab400031505322b1504b600642ab400031505321906b5001d840501a7ffaa2b1db9006502001d9900082c2bb80066b1
 
 com/gemstone/gemfire/internal/cache/RemoteRemoveAllMessage$RemoveAllReplyMessage,2
 fromData,17,2a2bb7001a2a2bb8001bc0001cb50001b1
@@ -1282,8 +1282,8 @@ fromData,131,2a2bb700252a2bb900260100b500072a2bb80027b500082ab40008c6000c2a2ab40
 toData,145,2a2bb7001d2b2ab40007b9001e02002ab40009c6000e2ab400092bb8001fa7000f2ab400082ab4000a2bb800202b2ab4000bb900210300033d2ab4000c9900081c0480913d2ab4000d9900081c0580913d2ab4000e9900081c0780913d2ab4000fc600091c100880913d2ab4000fc100229900091c101080913d2b1cb9002302002ab4000fc6000b2ab4000f2bb80024b1
 
 com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor$NetSearchRequestMessage,2
-fromData,97,2a2bb7001c2bb9001d01003d1c047e9900142a2bb9001e0100b5000b2ab4000bb8001f2a2bb900200100b5000c2a2bb80021b5000d2a2bb9001e0100b5000e1c10407e99000c2a2bb8002288b5000f1c1100807e99000c2a2bb8002288b50010b1
-toData,131,2a2bb70016033d2ab4000b9900081c0480933d2ab4000f9900091c104080933d2ab4001099000a1c11008080933d2b1cb9001702002ab4000b99000d2b2ab4000bb9001802002b2ab4000cb9001902002ab4000d2bb8001a2b2ab4000eb9001802002ab4000f99000c2ab4000f852bb8001b2ab4001099000c2ab40010852bb8001bb1
+fromData,97,2a2bb7001c2bb9001d01003d1c047e9900142a2bb9001e0100b5000a2ab4000ab8001f2a2bb900200100b5000b2a2bb80021b5000c2a2bb9001e0100b5000d1c10407e99000c2a2bb8002288b5000e1c1100807e99000c2a2bb8002288b5000fb1
+toData,131,2a2bb70015033d2ab4000a9900081c0480933d2ab4000e9900091c104080933d2ab4000f99000a1c11008080933d2b1cb9001702002ab4000a99000d2b2ab4000ab9001802002b2ab4000bb9001902002ab4000c2bb8001a2b2ab4000db9001802002ab4000e99000c2ab4000e852bb8001b2ab4000f99000c2ab4000f852bb8001bb1
 
 com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor$NetWriteReplyMessage,2
 fromData,47,2a2bb700182a2bb900190100b500072a2bb9001a0100b500082a2bb8001bc0001cb500092a2bb9001a0100b5000ab1
@@ -1294,8 +1294,8 @@ fromData,57,2a2bb700182a2bb900190100b5000a2a2bb9001a0100b5000b2a2bb900190100b500
 toData,54,2a2bb700142b2ab4000ab9001502002b2ab4000bb9001602002b2ab4000cb9001502002ab4000d2bb800172b2ab4000eb900150200b1
 
 com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor$QueryMessage,2
-fromData,114,2a2bb7001f2bb9002001003d1c047e9900142a2bb900210100b5000c2ab4000cb800222a2bb900230100b5000d2a2bb80024b5000f2a2bb900210100b500101c10407e99000c2a2bb8002588b500111c1100807e99000c2a2bb8002588b500122a1c1101007e99000704a7000403b50008b1
-toData,145,2a2bb70019033d2ab4000c9900081c0480933d2ab400119900091c104080933d2ab4001299000a1c11008080933d2ab4000899000a1c11010080933d2b1cb9001a02002ab4000c99000d2b2ab4000cb9001b02002b2ab4000db9001c02002ab4000f2bb8001d2b2ab40010b9001b02002ab4001199000c2ab40011852bb8001e2ab4001299000c2ab40012852bb8001eb1
+fromData,114,2a2bb7001f2bb9002001003d1c047e9900142a2bb900210100b5000b2ab4000bb800222a2bb900230100b5000c2a2bb80024b5000e2a2bb900210100b5000f1c10407e99000c2a2bb8002588b500101c1100807e99000c2a2bb8002588b500112a1c1101007e99000704a7000403b50007b1
+toData,145,2a2bb70018033d2ab4000b9900081c0480933d2ab400109900091c104080933d2ab4001199000a1c11008080933d2ab4000799000a1c11010080933d2b1cb9001a02002ab4000b99000d2b2ab4000bb9001b02002b2ab4000cb9001c02002ab4000e2bb8001d2b2ab4000fb9001b02002ab4001099000c2ab40010852bb8001e2ab4001199000c2ab40011852bb8001eb1
 
 com/gemstone/gemfire/internal/cache/SearchLoadAndWriteProcessor$ResponseMessage,2
 fromData,83,2a2bb7001f2a2bb80020b500072a2bb900210100b500082a2bb80020b500092a2bb900220100b5000a2a2bb900230100b5000b2a2bb900230100b5000c2a2bb900230100b5000d2a2bb80020c00024b5000eb1
@@ -1322,8 +1322,8 @@ fromData,17,2a2bb7000e2a2bb8000fc00010b50002b1
 toData,14,2a2bb7000b2ab400022bb8000cb1
 
 com/gemstone/gemfire/internal/cache/StoreAllCachedDeserializable,2
-fromData,20,2a2bb8000fb500072a2ab40007b80008b50009b1
-toData,9,2ab400072bb80010b1
+fromData,20,2a2bb8000eb500062a2ab40006b80007b50008b1
+toData,9,2ab400062bb8000fb1
 
 com/gemstone/gemfire/internal/cache/TXCommitMessage,2
 fromData,211,2bb900f601003d2ab700049900122a1cb5009f2ab4009fb800f7a700082a02b5009f2a2bb800f8b500152bb900f9010099000b2a2bb800fab500162bb900f601003e2a2bb800fbb5001f2a2bb900fc0100b500202a2bb900fc0100b500212a2bb900f90100b800fdb500022bb900f6010036042abb00d9591504b700dbb500172abb00d9591db700dbb500ae03360515051504a2002fbb0025592ab700fe3a0619062bb600ffa7000c3a072a1907b600bcb12ab400171906b6004957840501a7ffd02a2bb80100b500032a2bb80101b5001bb1
@@ -1426,19 +1426,19 @@ fromData,14,2a2bb700132a2bb80014b50009b1
 toData,14,2a2bb700152ab400092bb80016b1
 
 com/gemstone/gemfire/internal/cache/VMCachedDeserializable,2
-fromData,17,2bb800214d2a2cbeb500092a2cb50007b1
-toData,9,2ab600222bb80023b1
+fromData,17,2bb800204d2a2cbeb500082a2cb50006b1
+toData,9,2ab600212bb80022b1
 
 com/gemstone/gemfire/internal/cache/WrappedCallbackArgument,2
 fromData,9,2a2bb80005b50003b1
 toData,24,2ab4000299000e2ab400032bb80004a70008012bb80004b1
 
 com/gemstone/gemfire/internal/cache/compression/CompressedCachedDeserializable,2
-fromData,18,2a2ab600082bb8000fb900090200b50003b1
-toData,18,2ab600082ab40003b9000d02002bb8000eb1
+fromData,18,2a2ab600072bb8000eb900080200b50002b1
+toData,18,2ab600072ab40002b9000c02002bb8000db1
 
 com/gemstone/gemfire/internal/cache/control/MemoryThresholds,1
-toData,31,2b2ab4000cb9003803002b2ab4000db9003902002b2ab40013b900390200b1
+toData,31,2b2ab4000bb9003703002b2ab4000cb9003802002b2ab40012b900380200b1
 
 com/gemstone/gemfire/internal/cache/control/MemoryThresholds$MemoryState,1
 toData,12,2ab60009b8000a2bb8000bb1
@@ -1552,8 +1552,8 @@ fromData,6,2a2bb7001db1
 toData,6,2a2bb7001bb1
 
 com/gemstone/gemfire/internal/cache/partitioned/DestroyMessage,2
-fromData,134,2a2bb700682a2bb80069b7006a2a2bb80069b500092a2bb9006b0100b8006cb5000b2a2bb9006d0100b5000c2a2bb8006eb5000e2a2bb80069c0006fb500192a2bb80069c00070b500102a2bb80069b500052ab400711104007e99000704a70004033d1c9900162abb007259b70073b500742ab400742bb800752a2bb80069c00076b50012b1
-toData,100,2a2bb700772ab600782bb800792ab400092bb800792b2ab4000bb4007ab9007b02002b2ab4000cb9007c02002ab4000e2bb800792ab400192bb800792ab400102bb800792ab400052bb800792ab40074c6000b2ab400742bb8007d2ab400122bb80079b1
+fromData,134,2a2bb700672a2bb80068b700692a2bb80068b500082a2bb9006a0100b8006bb5000a2a2bb9006c0100b5000b2a2bb8006db5000d2a2bb80068c0006eb500182a2bb80068c0006fb5000f2a2bb80068b500042ab400701104007e99000704a70004033d1c9900162abb007259b70073b500742ab400742bb800752a2bb80068c00076b50011b1
+toData,100,2a2bb700772ab600782bb800792ab400082bb800792b2ab4000ab4007ab9007b02002b2ab4000bb9007c02002ab4000d2bb800792ab400182bb800792ab4000f2bb800792ab400042bb800792ab40074c6000b2ab400742bb8007d2ab400112bb80079b1
 
 com/gemstone/gemfire/internal/cache/partitioned/DestroyMessage$DestroyReplyMessage,2
 fromData,52,2a2bb700262bb9002701003d1c047e99000704a70004033e1c057e99000704a700040336041d99000d2a15042bb80028b5000bb1
@@ -1584,8 +1584,8 @@ fromData,67,2a2bb700282a2bb80029b6002ab500082ab4000804a0000e2a2bb8002bb50004a700
 toData,67,2a2bb7002f2ab40008b800302bb800312ab4000804a0000e2ab400042bb80032a700122ab400089a000b2ab400052bb800332ab400062bb800342ab400092bb80035b1
 
 com/gemstone/gemfire/internal/cache/partitioned/FetchBulkEntriesMessage$FetchBulkEntriesReplyMessage,2
-fromData,40,2a2bb700542a2bb900550100b500062a2bb80056b500022a2bb80057b500582a2bb80059b50001b1
-toData,40,2a2bb7004f2b2ab40006b9005002002ab400022bb800312ab400072bb800512ab400012bb80052b1
+fromData,40,2a2bb700552a2bb900560100b500062a2bb80057b500022a2bb80058b500592a2bb8005ab50001b1
+toData,40,2a2bb700502b2ab40006b9005102002ab400022bb800322ab400072bb800522ab400012bb80053b1
 
 com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessage,2
 fromData,16,2a2bb7002e2a2bb9002f0100b50004b1
@@ -1596,8 +1596,8 @@ fromData,74,2a2bb700522a2bb900530100b500062a2bb900530100b500072a2bb900530100b500
 toData,74,2a2bb7004d2b2ab40006b9004e02002b2ab40007b9004e02002b2ab40008b9004e02002b2ab40009b9004e02002b2ab4000ab9004f02002ab4000b2bb800502b2ab40001b9004f0200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/FetchEntryMessage,2
-fromData,14,2a2bb7003b2a2bb8003cb50005b1
-toData,14,2a2bb7003e2ab400052bb8003fb1
+fromData,14,2a2bb7003a2a2bb8003bb50004b1
+toData,14,2a2bb7003d2ab400042bb8003eb1
 
 com/gemstone/gemfire/internal/cache/partitioned/FetchEntryMessage$FetchEntryReplyMessage,2
 fromData,58,2a2bb700202bb9002101003d1c9a002c2ab40003b80022c000234e2dc7000dbb0024591225b70026bf2abb0027592b2db40028b70029b50004b1
@@ -1624,8 +1624,8 @@ fromData,36,2a2bb700252a2bb900260100b500022a2bb900260100b500032a2bb900260100b500
 toData,36,2a2bb700272b2ab40002b9002802002b2ab40003b9002802002b2ab40004b900280200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/GetMessage,2
-fromData,43,2a2bb700542a2bb80055b500052a2bb80055b500062a2bb80055c00056b500072a2bb900570100b50008b1
-toData,40,2a2bb700582ab400052bb800592ab400062bb800592ab400072bb800592b2ab40008b9005a0200b1
+fromData,43,2a2bb700532a2bb80054b500042a2bb80054b500052a2bb80054c00055b500062a2bb900560100b50007b1
+toData,40,2a2bb700572ab400042bb800582ab400052bb800582ab400062bb800582b2ab40007b900590200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/GetMessage$GetReplyMessage,2
 fromData,77,2a2bb7002a2bb9002b01003d1c10087e99000704a7000403593e9900091c10f77e913d2a1cb500072a2bb8002cb5002d1c049f000b2a2bb8002eb5002f1d99000e2a2bb80030c00031b5000ab1
@@ -1712,8 +1712,8 @@ fromData,49,2a2bb700392a2bb8003ab500062a2bb9003b0100b8003cb500082a2bb8003ac0003d
 toData,43,2a2bb7003f2ab700122bb800402b2ab40008b40041b9004202002ab4000a2bb800402ab4000c2bb80040b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PartitionMessage,2
-fromData,58,2a2bb700742a2bb900750100b500052a2ab400052bb600762a2bb900770100b5000e2bb80078b20079b6007a9b000d2a2bb9007b0100b5000ab1
-toData,104,2a2bb7007f033d2a1cb600803d2b1cb9008102002ab4001099000d2b2ab40010b9008202002ab40008029f000d2b2ab40008b9008202002ab40006c6000b2ab400062bb800832b2ab4000eb9008202002bb80084b20079b6007a9b000d2b2ab4000ab900850200b1
+fromData,58,2a2bb7007b2a2bb9007c0100b500032a2ab400032bb6007d2a2bb9007e0100b5000c2bb8007fb20080b600819b000d2a2bb900820100b50008b1
+toData,104,2a2bb70088033d2a1cb600893d2b1cb9008a02002ab4000e99000d2b2ab4000eb9008b02002ab40006029f000d2b2ab40006b9008b02002ab40004c6000b2ab400042bb8008c2b2ab4000cb9008b02002bb8008db20080b600819b000d2b2ab40008b9008e0200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionFunctionStreamingMessage,2
 fromData,17,2a2bb7003c2a2bb8003dc0003eb50003b1
@@ -1728,16 +1728,16 @@ fromData,16,2a2bb700092a2bb9000a0100b50007b1
 toData,16,2a2bb7000b2b2ab40007b9000c0200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage,2
-fromData,183,2a2bb7003f2a2bb8004088b80009b5000a2ab400411110007e99000e2a2bb80042c00043b5003d2a2bb80042b500102a2bb8004488b500052a2ab40005bd000bb5000c2ab400059e006f2bb800454dbb004659b700474e03360415042ab40005a2001d2ab4000c1504bb000b592b0115042c2db7004853840401a7ffe02bb9004901003604150499002f2bb8004a3a0503360615062ab40005a2001d2ab4000c15063219051506b6004bc0004cb5004d840601a7ffe0b1
-toData,210,2a2bb7004e2ab4000ac7000d14004f2bb80051a7000f2ab4000ab60052852bb800512ab4003dc6000b2ab4003d2bb800532ab400102bb800532ab40005852bb800542ab400059e008bbb0055592ab40005b700564d033e2ab4000c0332b60022c10057360403360515052ab40005a200531d9a00122ab4000c150532b4004dc60005043e2ab4000c150532b4004d3a062c1906b60058572ab4000c15053201b5004d2ab4000c1505322b1504b600592ab4000c1505321906b5004d840501a7ffaa2b1db9005a02001d9900082c2bb8005bb1
+fromData,183,2a2bb7003d2a2bb8003e88b80007b500082ab4003f1110007e99000e2a2bb80041c00042b5003b2a2bb80041b5000e2a2bb8004388b500032a2ab40003bd0009b5000a2ab400039e006f2bb800444dbb004559b700464e03360415042ab40003a2001d2ab4000a1504bb0009592b0115042c2db7004753840401a7ffe02bb9004801003604150499002f2bb800493a0503360615062ab40003a2001d2ab4000a15063219051506b6004ac0004bb5004c840601a7ffe0b1
+toData,210,2a2bb7004d2ab40008c7000d14004e2bb80050a7000f2ab40008b60051852bb800502ab4003bc6000b2ab4003b2bb800522ab4000e2bb800522ab40003852bb800532ab400039e008bbb0054592ab40003b700554d033e2ab4000a0332b60020c10056360403360515052ab40003a200531d9a00122ab4000a150532b4004cc60005043e2ab4000a150532b4004c3a062c1906b60057572ab4000a15053201b5004c2ab4000a1505322b1504b600582ab4000a1505321906b5004c840501a7ffaa2b1db9005902001d9900082c2bb8005ab1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutAllPRMessage$PutAllReplyMessage,2
 fromData,27,2a2bb7001b2a2bb9001c0100b500032a2bb8001dc0001eb50002b1
 toData,24,2a2bb7001f2b2ab40003b9002002002ab400022bb80021b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutMessage,2
-fromData,260,2a2bb7005d2bb9005e01003d2a2bb8005fb600602a2bb8005fb500172a2bb900610100b500182a2bb900620100b80063b500191cb200647e99000b2a2bb80065b5001a1cb200667e99000e2a2bb8005fc00067b5001c2abb006859b70069b5001d2ab4001d2bb8006a2ab4006b1120007e99000b2a2bb8005fb500222ab4006c9900162abb006d59b7006eb500282ab400282bb8006a2a1cb2006f7e91b500072ab4000999000e2a2bb80070b5000da7002e2ab4000704a0000e2a2bb8005fb70071a7000b2a2bb80070b700721cb200737e99000b2a2bb80070b5000d2ab4006b1140007e99000e2a2bb8005fc00074b500252ab4006b1180007e9900082a04b50075b1
-toData,358,014d2ab40021b60076b9007701003e2ab4000cb60078c600161d9900122ab4000b99000b2a04b50009a700082a03b50009a7000d4ebb007a592db7007bbf2a2bb7007c2ab400073e2ab4001ac600091db20064803e2ab400079900282ab40011c7000a2ab6007dc6001a2ab4007e9900132ab4000cb60078c600091db20073803e2ab4001cc600091db20066803e2b1db9007f02002ab600802bb800812ab600822bb800812b2ab40018b9008303002b2ab40019b40084b9007f02002ab4001ac6000b2ab4001a2bb800812ab4001cc6000b2ab4001c2bb800812ab4001d2bb800852ab40022c6000b2ab400222bb800812ab4006c99000b2ab400282bb800852ab4000999002f2ab40086b800874da7000f3a04bb008959128ab7008bbf2ab4000cb600782bb8008c2cb6008db6008ea700262ab400072ab400112ab6007d2bb8008f1db200737e99000e2ab4000cb600782bb8008c2ab40025c6000b2ab400252bb80081b1
+fromData,260,2a2bb7005c2bb9005d01003d2a2bb8005eb6005f2a2bb8005eb500152a2bb900600100b500162a2bb900610100b80062b500171cb200637e99000b2a2bb80064b500181cb200657e99000e2a2bb8005ec00066b5001a2abb006759b70068b5001b2ab4001b2bb800692ab4006a1120007e99000b2a2bb8005eb500202ab4006b9900162abb006c59b7006db500262ab400262bb800692a1cb2006e7e91b500052ab4000799000e2a2bb8006fb5000ba7002e2ab4000504a0000e2a2bb8005eb70070a7000b2a2bb8006fb700711cb200727e99000b2a2bb8006fb5000b2ab4006a1140007e99000e2a2bb8005ec00073b500232ab4006a1180007e9900082a04b50074b1
+toData,358,014d2ab4001fb60075b9007601003e2ab4000ab60077c600161d9900122ab4000999000b2a04b50007a700082a03b50007a7000d4ebb0079592db7007abf2a2bb7007b2ab400053e2ab40018c600091db20063803e2ab400059900282ab4000fc7000a2ab6007cc6001a2ab4007d9900132ab4000ab60077c600091db20072803e2ab4001ac600091db20065803e2b1db9007e02002ab6007f2bb800802ab600812bb800802b2ab40016b9008203002b2ab40017b40083b9007e02002ab40018c6000b2ab400182bb800802ab4001ac6000b2ab4001a2bb800802ab4001b2bb800842ab40020c6000b2ab400202bb800802ab4006b99000b2ab400262bb800842ab4000799002f2ab40085b800864da7000f3a04bb0088591289b7008abf2ab4000ab600772bb8008b2cb6008cb6008da700262ab400052ab4000f2ab6007c2bb8008e1db200727e99000e2ab4000ab600772bb8008b2ab40023c6000b2ab400232bb80080b1
 
 com/gemstone/gemfire/internal/cache/partitioned/PutMessage$PutReplyMessage,2
 fromData,48,2a2bb700252a2bb900260100b500032a2bb900270100b80028b500022a2bb80029b500062a2bb80029c0002ab50007b1
@@ -1772,8 +1772,8 @@ fromData,16,2a2bb7001e2a2bb9001f0100b50003b1
 toData,16,2a2bb7001b2b2ab40003b9001c0200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage,2
-fromData,190,2a2bb7003e2a2bb8003f88b80009b5000a2ab400401110007e99000e2a2bb80041c00042b5003c2bb800434d2a2bb80041b500102a2bb8004488b500052a2ab40005bd000bb5000c2ab400059e00712bb800454ebb004659b700473a0403360515052ab40005a2001e2ab4000c1505bb000b592b0115052d1904b7004853840501a7ffdf2bb9004901003605150599002f2bb8004a3a0603360715072ab40005a2001d2ab4000c15073219061507b6004bc0004cb5004d840701a7ffe0b1
-toData,210,2a2bb7004e2ab4000ac7000d14004f2bb80051a7000f2ab4000ab60052852bb800512ab4003cc6000b2ab4003c2bb800532ab400102bb800532ab40005852bb800542ab400059e008bbb0055592ab40005b700564d033e2ab4000c0332b60021c10057360403360515052ab40005a200531d9a00122ab4000c150532b4004dc60005043e2ab4000c150532b4004d3a062c1906b60058572ab4000c15053201b5004d2ab4000c1505322b1504b600592ab4000c1505321906b5004d840501a7ffaa2b1db9005a02001d9900082c2bb8005bb1
+fromData,190,2a2bb7003c2a2bb8003d88b80007b500082ab4003e1110007e99000e2a2bb80040c00041b5003a2bb800424d2a2bb80040b5000e2a2bb8004388b500032a2ab40003bd0009b5000a2ab400039e00712bb800444ebb004559b700463a0403360515052ab40003a2001e2ab4000a1505bb0009592b0115052d1904b7004753840501a7ffdf2bb9004801003605150599002f2bb800493a0603360715072ab40003a2001d2ab4000a15073219061507b6004ac0004bb5004c840701a7ffe0b1
+toData,210,2a2bb7004d2ab40008c7000d14004e2bb80050a7000f2ab40008b60051852bb800502ab4003ac6000b2ab4003a2bb800522ab4000e2bb800522ab40003852bb800532ab400039e008bbb0054592ab40003b700554d033e2ab4000a0332b6001fc10056360403360515052ab40003a200531d9a00122ab4000a150532b4004cc60005043e2ab4000a150532b4004c3a062c1906b60057572ab4000a15053201b5004c2ab4000a1505322b1504b600582ab4000a1505321906b5004c840501a7ffaa2b1db9005902001d9900082c2bb8005ab1
 
 com/gemstone/gemfire/internal/cache/partitioned/RemoveAllPRMessage$RemoveAllReplyMessage,2
 fromData,27,2a2bb7001b2a2bb9001c0100b500032a2bb8001dc0001eb50002b1
@@ -1796,8 +1796,8 @@ fromData,36,2a2bb700082a2bb900090100b500032a2bb9000a0100b500042a2bb9000a0100b500
 toData,36,2a2bb7000b2b2ab40003b9000c02002b2ab40004b9000d02002b2ab40005b9000d0200b1
 
 com/gemstone/gemfire/internal/cache/partitioned/SizeMessage,2
-fromData,14,2a2bb700362a2bb80037b50006b1
-toData,14,2a2bb700382ab400062bb80039b1
+fromData,14,2a2bb700352a2bb80036b50005b1
+toData,14,2a2bb700372ab400052bb80038b1
 
 com/gemstone/gemfire/internal/cache/partitioned/SizeMessage$SizeReplyMessage,2
 fromData,17,2a2bb7001d2a2bb8001ec0001fb50003b1
@@ -1904,8 +1904,8 @@ fromData,1,b1
 toData,1,b1
 
 com/gemstone/gemfire/internal/cache/tier/sockets/ClientProxyMembershipID,2
-fromData,19,2a2bb8004fb500082a2bb900500100b5000ab1
-toData,19,2ab400082bb8004d2b2ab4000ab9004e0200b1
+fromData,19,2a2bb80051b500092a2bb900520100b5000bb1
+toData,19,2ab400092bb8004f2b2ab4000bb900500200b1
 
 com/gemstone/gemfire/internal/cache/tier/sockets/ClientTombstoneMessage,2
 fromData,63,2ab800222bb90023010032b500072a2bb900230100b80024b5001c2a2bb80025b6000a2a2bb80026b500082a2bb80027b500202a2bb80026c00028b50021b1
@@ -2001,8 +2001,8 @@ fromData,6,2a2bb7001fb1
 toData,6,2a2bb7001db1
 
 com/gemstone/gemfire/internal/cache/wan/parallel/ParallelQueueRemovalMessage,2
-fromData,14,2a2bb700582a2bb80059b50002b1
-toData,14,2a2bb700562ab400022bb80057b1
+fromData,14,2a2bb700592a2bb8005ab50002b1
+toData,14,2a2bb700572ab400022bb80058b1
 
 com/gemstone/gemfire/internal/cache/wan/serial/BatchDestroyOperation$DestroyMessage,2
 fromData,45,2a2bb700452a2bb80046c00047b500022a2bb80046b5000d2bb800484d2cb6004999000b2a2bb8004ab50005b1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfile.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfile.java b/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfile.java
new file mode 100644
index 0000000..ceb7aa9
--- /dev/null
+++ b/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexCreationProfile.java
@@ -0,0 +1,189 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.cache.lucene.internal;
+
+import com.gemstone.gemfire.DataSerializable;
+import com.gemstone.gemfire.DataSerializer;
+import com.gemstone.gemfire.internal.Version;
+import com.gemstone.gemfire.internal.cache.CacheServiceProfile;
+import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.lucene.analysis.Analyzer;
+
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+import java.util.*;
+
+public class LuceneIndexCreationProfile implements CacheServiceProfile, DataSerializable {
+
+  private String indexName;
+
+  private String[] fieldNames;
+
+  private Class<? extends Analyzer> analyzerClass;
+
+  private Map<String, Class<? extends Analyzer>> fieldAnalyzers;
+
+  /* Used by DataSerializer */
+  public LuceneIndexCreationProfile() {}
+
+  public LuceneIndexCreationProfile(String indexName, String[] fieldNames, Analyzer analyzer,
+      Map<String, Analyzer> fieldAnalyzers) {
+    this.indexName = indexName;
+    this.fieldNames = fieldNames;
+    this.analyzerClass = analyzer.getClass();
+    initializeFieldAnalyzers(fieldAnalyzers);
+  }
+
+  public String getIndexName() {
+    return this.indexName;
+  }
+
+  public String[] getFieldNames() {
+    return this.fieldNames;
+  }
+
+  public Class<? extends Analyzer> getAnalyzerClass() {
+    return this.analyzerClass;
+  }
+
+  public Map<String, Class<? extends Analyzer>> getFieldAnalyzers() {
+    return this.fieldAnalyzers;
+  }
+
+  protected void initializeFieldAnalyzers(Map<String, Analyzer> fieldAnalyzers) {
+    if (fieldAnalyzers != null && !fieldAnalyzers.isEmpty()) {
+      this.fieldAnalyzers = new HashMap<>();
+      for (Map.Entry<String, Analyzer> entry : fieldAnalyzers.entrySet()) {
+        // Null values are allowed in analyzers which means the default Analyzer is used
+        this.fieldAnalyzers.put(entry.getKey(), entry.getValue() == null ? null : entry.getValue().getClass());
+      }
+    }
+  }
+
+  @Override
+  public String getId() {
+    return this.indexName;
+  }
+
+  @Override
+  public String checkCompatibility(String regionPath, CacheServiceProfile profile) {
+    String result = null;
+    LuceneIndexCreationProfile myProfile = (LuceneIndexCreationProfile) profile;
+    if (myProfile == null) {
+      // TODO This can occur if one member defines no indexes but another one does. Currently this is caught by the async event id checks.
+    } else {
+      // Verify fields are the same
+      if (!Arrays.equals(myProfile.getFieldNames(), getFieldNames())) {
+        result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_FIELDS_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_FIELDS_3
+            .toString(myProfile.getIndexName(), regionPath, Arrays.toString(getFieldNames()),
+                Arrays.toString(myProfile.getFieldNames()));
+      }
+
+      // Verify the analyzer class is the same
+      // Note: This test will currently only fail if per-field analyzers are used in one member but not another,
+      // This condition will be caught in the tests below so this test is commented out. If we ever allow the user
+      // to configure a single analyzer for all fields, then this test will be useful again.
+      /*
+      if (!remoteLuceneIndexProfile.getAnalyzerClass().isInstance(getAnalyzer())) {
+        result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_ANALYZER_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_ANALYZER_3
+            .toString(indexName, regionPath, remoteLuceneIndexProfile.getAnalyzerClass().getName(), analyzer.getClass().getName());
+      }
+      */
+
+      // Verify the field analyzer fields and classes are the same if either member sets field analyzers
+      if (myProfile.getFieldAnalyzers() != null || getFieldAnalyzers() != null) {
+        // Check for one member defining field analyzers while the other member does not
+        if (myProfile.getFieldAnalyzers() == null) {
+          result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_FIELD_ANALYZERS_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_NO_FIELD_ANALYZERS
+              .toString(myProfile.getIndexName(), regionPath, getFieldAnalyzers());
+        } else if (getFieldAnalyzers() == null) {
+          result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_NO_FIELD_ANALYZERS_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_FIELD_ANALYZERS_2
+              .toString(myProfile.getIndexName(), regionPath, myProfile.getFieldAnalyzers());
+        } else {
+          // Both local and remote analyzers are set. Verify the sizes of the field analyzers are identical
+          if (myProfile.getFieldAnalyzers().size() != getFieldAnalyzers().size()) {
+            result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_FIELD_ANALYZERS_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_FIELD_ANALYZERS_3
+                .toString(myProfile.getIndexName(), regionPath, getFieldAnalyzers(),
+                    myProfile.getFieldAnalyzers());
+          }
+
+          // Iterate the existing analyzers and compare them to the input analyzers
+          // Note: This is currently destructive to the input field analyzers map which should be ok since its a transient object.
+          for (Iterator<Map.Entry<String, Class<? extends Analyzer>>> i = myProfile.getFieldAnalyzers().entrySet().iterator(); i.hasNext(); ) {
+            Map.Entry<String, Class<? extends Analyzer>> entry = i.next();
+            // Remove the existing field's analyzer from the input analyzers
+            Class<? extends Analyzer> analyzerClass = getFieldAnalyzers().remove(entry.getKey());
+
+            // Verify the input field analyzer matches the current analyzer
+            if (analyzerClass == null && entry.getValue() != null) {
+              // The input field analyzers do not include the existing field analyzer
+              result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_NO_ANALYZER_ON_FIELD_2_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_ANALYZER_3_ON_THAT_FIELD
+                  .toString(myProfile.getIndexName(), regionPath, entry.getKey(), entry.getValue().getName());
+              break;
+            } else if (analyzerClass != null && entry.getValue() == null) {
+              // The existing field analyzers do not include the input field analyzer
+              result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_ANALYZER_2_ON_FIELD_3_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_NO_ANALYZER_ON_THAT_FIELD
+                  .toString(myProfile.getIndexName(), regionPath, analyzerClass.getName(), entry.getKey());
+              break;
+            } else {
+              if (analyzerClass != entry.getValue()) {
+                // The class of the input analyzer does not match the existing analyzer for the field
+                result = LocalizedStrings.LuceneService_CANNOT_CREATE_INDEX_0_ON_REGION_1_WITH_ANALYZER_2_ON_FIELD_3_BECAUSE_ANOTHER_MEMBER_DEFINES_THE_SAME_INDEX_WITH_ANALYZER_4_ON_THAT_FIELD
+                    .toString(myProfile.getIndexName(), regionPath, analyzerClass.getName(), entry.getKey(), entry.getValue().getName());
+                break;
+              }
+            }
+          }
+        }
+      }
+    }
+    return result;
+  }
+
+  @Override
+  public void toData(DataOutput out) throws IOException {
+    DataSerializer.writeString(this.indexName, out);
+    DataSerializer.writeStringArray(this.fieldNames, out);
+    DataSerializer.writeClass(this.analyzerClass, out);
+    DataSerializer.writeHashMap(this.fieldAnalyzers, out);
+  }
+
+  @Override
+  public void fromData(DataInput in) throws IOException, ClassNotFoundException {
+    this.indexName = DataSerializer.readString(in);
+    this.fieldNames = DataSerializer.readStringArray(in);
+    this.analyzerClass = (Class<? extends Analyzer>) DataSerializer.readClass(in);
+    this.fieldAnalyzers = DataSerializer.readHashMap(in);
+  }
+
+  public String toString() {
+    return new StringBuilder()
+        .append(getClass().getSimpleName())
+        .append("[")
+        .append("indexName=")
+        .append(this.indexName)
+        .append("; fieldNames=")
+        .append(Arrays.toString(this.fieldNames))
+        .append("; analyzerClass=")
+        .append(this.analyzerClass)
+        .append("; fieldAnalyzers=")
+        .append(this.fieldAnalyzers)
+        .append("]")
+        .toString();
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c742c4e5/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
----------------------------------------------------------------------
diff --git a/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java b/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
index 67edc6d..47c4d76 100644
--- a/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
+++ b/geode-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
@@ -47,12 +47,12 @@ import com.gemstone.gemfire.cache.lucene.internal.filesystem.File;
 import com.gemstone.gemfire.cache.lucene.internal.xml.LuceneServiceXmlGenerator;
 import com.gemstone.gemfire.internal.DSFIDFactory;
 import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import com.gemstone.gemfire.internal.cache.extension.Extensible;
 import com.gemstone.gemfire.internal.cache.CacheService;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.RegionListener;
-import com.gemstone.gemfire.internal.cache.extension.Extensible;
 import com.gemstone.gemfire.internal.cache.xmlcache.XmlGenerator;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.internal.logging.LogService;
@@ -65,10 +65,10 @@ import com.gemstone.gemfire.internal.logging.LogService;
  */
 public class LuceneServiceImpl implements InternalLuceneService {
   private static final Logger logger = LogService.getLogger();
-  
+
   private GemFireCacheImpl cache;
   private final HashMap<String, LuceneIndex> indexMap = new HashMap<String, LuceneIndex>();;
-  
+
   public LuceneServiceImpl() {
     
   }
@@ -116,7 +116,7 @@ public class LuceneServiceImpl implements InternalLuceneService {
     createIndex(indexName, regionPath, analyzer, fieldAnalyzers, fields);
   }
 
-  private void createIndex(final String indexName, String regionPath,
+  public void createIndex(final String indexName, String regionPath,
       final Analyzer analyzer, final Map<String, Analyzer> fieldAnalyzers,
       final String... fields) {
 
@@ -127,7 +127,7 @@ public class LuceneServiceImpl implements InternalLuceneService {
     if(region != null) {
       throw new IllegalStateException("The lucene index must be created before region");
     }
-    
+
     final String dataRegionPath = regionPath;
     cache.addRegionListener(new RegionListener() {
       @Override
@@ -142,6 +142,9 @@ public class LuceneServiceImpl implements InternalLuceneService {
             af.addAsyncEventQueueId(aeqId);
             updatedRA = af.create();
           }
+
+          // Add index creation profile
+          internalRegionArgs.addCacheServiceProfile(new LuceneIndexCreationProfile(indexName, fields, analyzer, fieldAnalyzers));
         }
         return updatedRA;
       }
@@ -284,7 +287,7 @@ public class LuceneServiceImpl implements InternalLuceneService {
     DSFIDFactory.registerDSFID(
         DataSerializableFixedID.LUCENE_TOP_ENTRIES,
         TopEntries.class);
-    
+
     DSFIDFactory.registerDSFID(
         DataSerializableFixedID.LUCENE_TOP_ENTRIES_COLLECTOR,
         TopEntriesCollector.class);