You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by bs...@apache.org on 2015/11/17 21:54:11 UTC

[01/50] [abbrv] incubator-geode git commit: Adding a microbenchmark of create and query performance.

Repository: incubator-geode
Updated Branches:
  refs/heads/feature/GEODE-77 fd98f62f8 -> 766dfd05b


Adding a microbenchmark of create and query performance.


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

Branch: refs/heads/feature/GEODE-77
Commit: 1f597bb707fb8482a3808e085c86d3c6b9d25fcf
Parents: d623cf6
Author: Dan Smith <up...@apache.org>
Authored: Fri Oct 16 14:53:58 2015 -0700
Committer: Dan Smith <up...@apache.org>
Committed: Fri Oct 16 14:54:50 2015 -0700

----------------------------------------------------------------------
 ...IndexRepositoryImplJUnitPerformanceTest.java | 422 +++++++++++++++++++
 1 file changed, 422 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/1f597bb7/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java
new file mode 100644
index 0000000..8641254
--- /dev/null
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java
@@ -0,0 +1,422 @@
+package com.gemstone.gemfire.cache.lucene.internal.repository;
+
+import static org.junit.Assert.*;
+
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+import java.util.ArrayList;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Random;
+import java.util.Set;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.lucene.analysis.standard.StandardAnalyzer;
+import org.apache.lucene.document.Document;
+import org.apache.lucene.document.Field.Store;
+import org.apache.lucene.document.TextField;
+import org.apache.lucene.index.IndexWriter;
+import org.apache.lucene.index.IndexWriterConfig;
+import org.apache.lucene.index.Term;
+import org.apache.lucene.queryparser.classic.QueryParser;
+import org.apache.lucene.search.IndexSearcher;
+import org.apache.lucene.search.Query;
+import org.apache.lucene.search.SearcherManager;
+import org.apache.lucene.search.TermQuery;
+import org.apache.lucene.store.RAMDirectory;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.carrotsearch.randomizedtesting.generators.RandomStrings;
+import com.gemstone.gemfire.DataSerializable;
+import com.gemstone.gemfire.DataSerializer;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionShortcut;
+import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
+import com.gemstone.gemfire.cache.lucene.LuceneIndex;
+import com.gemstone.gemfire.cache.lucene.LuceneQuery;
+import com.gemstone.gemfire.cache.lucene.LuceneQueryProvider;
+import com.gemstone.gemfire.cache.lucene.LuceneQueryResults;
+import com.gemstone.gemfire.cache.lucene.LuceneService;
+import com.gemstone.gemfire.cache.lucene.LuceneServiceProvider;
+import com.gemstone.gemfire.cache.lucene.internal.LuceneServiceImpl;
+import com.gemstone.gemfire.cache.lucene.internal.directory.RegionDirectory;
+import com.gemstone.gemfire.cache.lucene.internal.distributed.TopEntriesCollector;
+import com.gemstone.gemfire.cache.lucene.internal.filesystem.ChunkKey;
+import com.gemstone.gemfire.cache.lucene.internal.filesystem.File;
+import com.gemstone.gemfire.cache.lucene.internal.repository.serializer.HeterogenousLuceneSerializer;
+import com.gemstone.gemfire.cache.query.QueryException;
+import com.gemstone.gemfire.test.junit.categories.PerformanceTest;
+
+/**
+ * Microbenchmark of the IndexRepository to compare an
+ * IndexRepository built on top of cache with a 
+ * stock lucene IndexWriter with a RAMDirectory.
+ */
+@Category(PerformanceTest.class)
+public class IndexRepositoryImplJUnitPerformanceTest {
+  
+  private static final int NUM_WORDS = 1000;
+  private static int[] COMMIT_INTERVAL = new int[] {100, 1000, 5000};
+  private static int NUM_ENTRIES = 500_000;
+  private static int NUM_QUERIES = 500_000;
+
+  private StandardAnalyzer analyzer = new StandardAnalyzer();
+  
+  @Test
+  public  void testIndexRepository() throws Exception {
+    
+
+    doTest("IndexRepository", new TestCallbacks() {
+
+      private Cache cache;
+      private IndexRepositoryImpl repo;
+      private IndexWriter writer;
+
+      @Override
+      public void addObject(String key, String text) throws Exception {
+        repo.create(key, new TestObject(text));
+      }
+
+      @Override
+      public void commit()  throws Exception {
+        repo.commit();
+      }
+
+      @Override
+      public void init() throws Exception {
+        cache = new CacheFactory().set("mcast-port", "0")
+            .set("log-level", "error")
+            .create();
+        Region<String, File> fileRegion = cache.<String, File>createRegionFactory(RegionShortcut.REPLICATE).create("files");
+        Region<ChunkKey, byte[]> chunkRegion = cache.<ChunkKey, byte[]>createRegionFactory(RegionShortcut.REPLICATE).create("chunks");
+
+        RegionDirectory dir = new RegionDirectory(fileRegion, chunkRegion);
+        
+        
+        IndexWriterConfig config = new IndexWriterConfig(analyzer);
+        writer = new IndexWriter(dir, config);
+        String[] indexedFields= new String[] {"text"};
+        HeterogenousLuceneSerializer mapper = new HeterogenousLuceneSerializer(indexedFields);
+        repo = new IndexRepositoryImpl(fileRegion, writer, mapper);
+      }
+
+      @Override
+      public void cleanup() throws IOException {
+        writer.close();
+        cache.close();
+      }
+
+      @Override
+      public void waitForAsync() throws Exception {
+        //do nothing
+      }
+
+      @Override
+      public int query(Query query) throws IOException {
+        TopEntriesCollector collector = new TopEntriesCollector();
+        repo.query(query, 100, collector);
+        return collector.size();
+      }
+    });
+  }
+  
+  /**
+   * Test our full lucene index implementation
+   * @throws Exception
+   */
+  @Test
+  public void testLuceneIndex() throws Exception {
+    
+
+    doTest("LuceneIndex", new TestCallbacks() {
+
+      private Cache cache;
+      private Region<String, TestObject> region;
+      private LuceneService service;
+
+      @Override
+      public void addObject(String key, String text) throws Exception {
+        region.create(key, new TestObject(text));
+      }
+
+      @Override
+      public void commit()  throws Exception {
+        //NA
+      }
+
+      @Override
+      public void init() throws Exception {
+        cache = new CacheFactory().set("mcast-port", "0")
+            .set("log-level", "warning")
+            .create();
+        service = LuceneServiceProvider.get(cache);
+        service.createIndex("index", "/region", "text");
+        region = cache.<String, TestObject>createRegionFactory(RegionShortcut.PARTITION)
+            .setPartitionAttributes(new PartitionAttributesFactory<>().setTotalNumBuckets(1).create())
+            .create("region");
+      }
+
+      @Override
+      public void cleanup() throws IOException {
+        cache.close();
+      }
+      
+      @Override
+      public void waitForAsync() throws Exception {
+        AsyncEventQueue aeq = cache.getAsyncEventQueue(LuceneServiceImpl.getUniqueIndexName("index", "/region"));
+        
+        //We will be at most 10 ms off
+        while(aeq.size() > 0) {
+          Thread.sleep(10);
+        }
+      }
+
+      @Override
+      public int query(final Query query) throws Exception {
+        LuceneQuery<Object, Object> luceneQuery = service.createLuceneQueryFactory().create("index", "/region", new LuceneQueryProvider() {
+          
+          @Override
+          public Query getQuery(LuceneIndex index) throws QueryException {
+            return query;
+          }
+        });
+        
+        LuceneQueryResults<Object, Object> results = luceneQuery.search();
+        return results.size();
+      }
+    });
+  }
+  
+  @Test
+  public  void testLuceneWithRegionDirectory() throws Exception {
+    doTest("RegionDirectory", new TestCallbacks() {
+
+      private IndexWriter writer;
+      private SearcherManager searcherManager;
+
+      @Override
+      public void init() throws Exception {
+        RegionDirectory dir = new RegionDirectory(new ConcurrentHashMap<String, File>(), new ConcurrentHashMap<ChunkKey, byte[]>());
+        IndexWriterConfig config = new IndexWriterConfig(analyzer);
+        writer = new IndexWriter(dir, config);
+        searcherManager = new SearcherManager(writer, true, null);
+      }
+
+      @Override
+      public void addObject(String key, String text) throws Exception {
+        Document doc = new Document();
+        doc.add(new TextField("key", key, Store.YES));
+        doc.add(new TextField("text", text, Store.NO));
+        writer.addDocument(doc);
+      }
+
+      @Override
+      public void commit() throws Exception {
+        writer.commit();
+        searcherManager.maybeRefresh();
+      }
+
+      @Override
+      public void cleanup() throws Exception {
+        writer.close();
+      }
+      
+      @Override
+      public void waitForAsync() throws Exception {
+        //do nothing
+      }
+
+      @Override
+      public int query(Query query) throws Exception {
+        IndexSearcher searcher = searcherManager.acquire();
+        try {
+          return searcher.count(query);
+        } finally {
+          searcherManager.release(searcher);
+        }
+      }
+      
+    });
+    
+  }
+  
+  @Test
+  public  void testLucene() throws Exception {
+    doTest("Lucene", new TestCallbacks() {
+
+      private IndexWriter writer;
+      private SearcherManager searcherManager;
+
+      @Override
+      public void init() throws Exception {
+        RAMDirectory dir = new RAMDirectory();
+        IndexWriterConfig config = new IndexWriterConfig(analyzer);
+        writer = new IndexWriter(dir, config);
+        searcherManager = new SearcherManager(writer, true, null);
+      }
+
+      @Override
+      public void addObject(String key, String text) throws Exception {
+        Document doc = new Document();
+        doc.add(new TextField("key", key, Store.YES));
+        doc.add(new TextField("text", text, Store.NO));
+        writer.addDocument(doc);
+      }
+
+      @Override
+      public void commit() throws Exception {
+        writer.commit();
+        searcherManager.maybeRefresh();
+      }
+
+      @Override
+      public void cleanup() throws Exception {
+        writer.close();
+      }
+      
+      @Override
+      public void waitForAsync() throws Exception {
+        //do nothing
+      }
+
+      @Override
+      public int query(Query query) throws Exception {
+        IndexSearcher searcher = searcherManager.acquire();
+        try {
+          return searcher.count(query);
+        } finally {
+          searcherManager.release(searcher);
+        }
+      }
+      
+    });
+    
+  }
+  
+  private void doTest(String testName, TestCallbacks callbacks) throws Exception {
+
+    //Create some random words. We need to be careful
+    //to make sure we get NUM_WORDS distinct words here
+    Set<String> wordSet = new HashSet<String>();
+    Random rand = new Random();
+    while(wordSet.size() < NUM_WORDS) {
+      int length = rand.nextInt(12) + 3;
+      char[] text = new char[length];
+      for(int i = 0; i < length; i++) {
+        text[i] = (char) (rand.nextInt(26) + 97);
+      }
+      wordSet.add(new String(text));
+    }
+    List<String> words = new ArrayList<String>(wordSet.size());
+    words.addAll(wordSet);
+    
+    
+    
+    //warm up
+    writeRandomWords(callbacks, words, rand, NUM_ENTRIES / 10, NUM_QUERIES / 10, COMMIT_INTERVAL[0]);
+    
+    //Do the actual test
+    
+    for(int i = 0; i < COMMIT_INTERVAL.length; i++) {
+      Results results = writeRandomWords(callbacks, words, rand, NUM_ENTRIES, NUM_QUERIES / 10, COMMIT_INTERVAL[i]);
+    
+      System.out.println(testName + " writes(entries=" + NUM_ENTRIES + ", commit=" + COMMIT_INTERVAL[i] + "): " + TimeUnit.NANOSECONDS.toMillis(results.writeTime));
+      System.out.println(testName + " queries(entries=" + NUM_ENTRIES + ", commit=" + COMMIT_INTERVAL[i] + "): " + TimeUnit.NANOSECONDS.toMillis(results.queryTime));
+    }
+  }
+
+  private Results writeRandomWords(TestCallbacks callbacks, List<String> words,
+      Random rand, int numEntries, int numQueries, int commitInterval) throws Exception {
+    Results results  = new Results();
+    callbacks.init();
+    int[] counts = new int[words.size()];
+    long start = System.nanoTime();
+    try {
+      for(int i =0; i < numEntries; i++) {
+        int word1 = rand.nextInt(words.size());
+        int word2 = rand.nextInt(words.size());
+        counts[word1]++;
+        counts[word2]++;
+        String value = words.get(word1) + " " + words.get(word2);
+        callbacks.addObject("key" + i, value);
+
+        if(i % commitInterval == 0 && i != 0) {
+          callbacks.commit();
+        }
+      }
+      callbacks.commit();
+      callbacks.waitForAsync();
+      long end = System.nanoTime();
+      results.writeTime = end - start;
+      
+      
+      start = System.nanoTime();
+      for(int i=0; i < numQueries; i++) {
+        int wordIndex = rand.nextInt(words.size());
+        String word = words.get(wordIndex);
+        Query query = new TermQuery(new Term("text", word));
+        int size  = callbacks.query(query);
+//        int size  = callbacks.query(parser.parse(word));
+        //All of my tests sometimes seem to be missing a couple of words, including the stock lucene
+//        assertEquals("Error on query " + i + " word=" + word, counts[wordIndex], size);
+      }
+      end = System.nanoTime();
+      results.queryTime = end - start;
+      
+      return results;
+    } finally {
+      callbacks.cleanup();
+    }
+  }
+
+  private static class TestObject implements DataSerializable {
+    private String text;
+
+    public TestObject() {
+      
+    }
+    
+    public TestObject(String text) {
+      super();
+      this.text = text;
+    }
+
+    @Override
+    public void toData(DataOutput out) throws IOException {
+      DataSerializer.writeString(text, out);
+    }
+
+    @Override
+    public void fromData(DataInput in)
+        throws IOException, ClassNotFoundException {
+      text = DataSerializer.readString(in);
+    }
+
+    @Override
+    public String toString() {
+      return text;
+    }
+    
+    
+  }
+  
+  private interface TestCallbacks {
+    public void init() throws Exception;
+    public int query(Query query) throws Exception;
+    public void addObject(String key, String text)  throws Exception;
+    public void commit() throws Exception;
+    public void waitForAsync() throws Exception;
+    public void cleanup() throws Exception;
+  }
+  
+  private static class Results {
+    long writeTime;
+    long queryTime;
+  }
+}


[46/50] [abbrv] incubator-geode git commit: GEODE-565 Update guava dependency to 15.0

Posted by bs...@apache.org.
GEODE-565 Update guava dependency to 15.0


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

Branch: refs/heads/feature/GEODE-77
Commit: 3dc3addd2d2b2c346ab59b32911694291350eee6
Parents: c7024bd
Author: Jens Deppe <jd...@pivotal.io>
Authored: Mon Nov 16 12:56:30 2015 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Mon Nov 16 12:56:30 2015 -0800

----------------------------------------------------------------------
 gradle/dependency-versions.properties | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3dc3addd/gradle/dependency-versions.properties
----------------------------------------------------------------------
diff --git a/gradle/dependency-versions.properties b/gradle/dependency-versions.properties
index 8be0f15..c86d45d 100644
--- a/gradle/dependency-versions.properties
+++ b/gradle/dependency-versions.properties
@@ -20,7 +20,7 @@ commons-logging.version = 1.1.1
 commons-modeler.version = 2.0
 derby.version = 10.2.2.0
 fastutil.version = 7.0.2
-guava.version = 11.0.2
+guava.version = 15.0
 hadoop.version = 2.4.1
 hamcrest-all.version = 1.3
 hbase.version = 0.94.27


[28/50] [abbrv] incubator-geode git commit: GEM-111: Cannot use 8.0.0.9+ clients with 8.1+ servers Added support for version 8009

Posted by bs...@apache.org.
GEM-111: Cannot use 8.0.0.9+ clients with 8.1+ servers Added support for version 8009


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

Branch: refs/heads/feature/GEODE-77
Commit: e1eb74effef800fa67db1c4010ecd67f05ea3b6b
Parents: b313362
Author: Barry Oglesby <bo...@pivotal.io>
Authored: Mon Nov 2 17:42:43 2015 -0800
Committer: Barry Oglesby <bo...@pivotal.io>
Committed: Tue Nov 10 10:26:06 2015 -0800

----------------------------------------------------------------------
 .../src/main/java/com/gemstone/gemfire/internal/Version.java    | 5 +++++
 .../gemfire/internal/cache/tier/sockets/CommandInitializer.java | 4 ++++
 .../internal/cache/tier/sockets/command/ExecuteFunction66.java  | 2 +-
 .../cache/tier/sockets/command/ExecuteRegionFunction66.java     | 2 +-
 .../tier/sockets/command/ExecuteRegionFunctionSingleHop.java    | 2 +-
 5 files changed, 12 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e1eb74ef/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
index 936ae79..8726ba8 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
@@ -175,6 +175,11 @@ public final class Version implements Comparable<Version> {
   
   // 31-34 available for 8.0.x variants
   
+  private static final byte GFE_8009_ORDINAL = 31;
+
+  public static final Version GFE_8009 = new Version("GFE", "8.0.0.9", (byte)8,
+      (byte)0, (byte)0, (byte)9, GFE_8009_ORDINAL);
+
   private static final byte GFE_81_ORDINAL = 35;
 
   public static final Version GFE_81 = new Version("GFE", "8.1", (byte)8,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e1eb74ef/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
index 7e49d7a..26ed47b 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
@@ -301,6 +301,10 @@ public class CommandInitializer {
     gfe80Commands.put(MessageType.PUTALL, PutAll80.getCommand());
     ALL_COMMANDS.put(Version.GFE_80, gfe80Commands);
 
+    Map<Integer, Command> gfe8009Commands = new HashMap<Integer, Command>();
+    gfe8009Commands.putAll(ALL_COMMANDS.get(Version.GFE_80));
+    ALL_COMMANDS.put(Version.GFE_8009, gfe8009Commands);
+
     {
       Map<Integer, Command> gfe81Commands = new HashMap<Integer, Command>();
       gfe81Commands.putAll(ALL_COMMANDS.get(Version.GFE_80));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e1eb74ef/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
index 3baac92..9160c11 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
@@ -108,7 +108,7 @@ public class ExecuteFunction66 extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e1eb74ef/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
index 329332b..6d9ca49 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
@@ -90,7 +90,7 @@ public class ExecuteRegionFunction66 extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
       if (functionState != 1) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e1eb74ef/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
index 1c18cb1..15b01fc 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
@@ -88,7 +88,7 @@ public class ExecuteRegionFunctionSingleHop extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
       if(functionState != 1) {


[22/50] [abbrv] incubator-geode git commit: GEODE-11: ADD Apache License header

Posted by bs...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImplJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImplJUnitTest.java
index 6cb5368..0614e62 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImplJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImplJUnitTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
index e26ab00..3975ac3 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImplJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImplJUnitTest.java
index 7009255..91556a9 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImplJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImplJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpJUnitTest.java
index bc9ad33..7893940 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImplJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImplJUnitTest.java
index 0cfd989..159fd46 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImplJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImplJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManagerJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManagerJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManagerJUnitTest.java
index 23518e1..41376f5 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManagerJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManagerJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProviderJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProviderJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProviderJUnitTest.java
index 673fdf2..a16b019 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProviderJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProviderJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectoryJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectoryJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectoryJUnitTest.java
index 9dd1d6b..d20b052 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectoryJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectoryJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.directory;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/DistributedScoringJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/DistributedScoringJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/DistributedScoringJUnitTest.java
index d18c520..bec2da8 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/DistributedScoringJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/DistributedScoringJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScoreJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScoreJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScoreJUnitTest.java
index c05fb61..abdf8ec 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScoreJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScoreJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import org.junit.Assert;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContextJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContextJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContextJUnitTest.java
index 98b48d8..46ea67f 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContextJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContextJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
index 419aa26..750ec0f 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
index b3460b7..4ba1fc7 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorJUnitTest.java
index 8acdd5a..b36d8cc 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollectorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollectorJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollectorJUnitTest.java
index f17200b..4f93587 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollectorJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollectorJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesJUnitTest.java
index 6c2e08b..d849c8e 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKeyJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKeyJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKeyJUnitTest.java
index 90cfca0..f28b84a 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKeyJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKeyJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileJUnitTest.java
index a30e69b..e4e8752 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystemJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystemJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystemJUnitTest.java
index 8f1b7dc..83d9e03 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystemJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystemJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import static org.junit.Assert.assertArrayEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java
index 8641254..ab2db78 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitPerformanceTest.java
@@ -1,6 +1,23 @@
-package com.gemstone.gemfire.cache.lucene.internal.repository;
+/*
+ * 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.
+ */
 
-import static org.junit.Assert.*;
+package com.gemstone.gemfire.cache.lucene.internal.repository;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -20,7 +37,6 @@ import org.apache.lucene.document.TextField;
 import org.apache.lucene.index.IndexWriter;
 import org.apache.lucene.index.IndexWriterConfig;
 import org.apache.lucene.index.Term;
-import org.apache.lucene.queryparser.classic.QueryParser;
 import org.apache.lucene.search.IndexSearcher;
 import org.apache.lucene.search.Query;
 import org.apache.lucene.search.SearcherManager;
@@ -29,7 +45,6 @@ import org.apache.lucene.store.RAMDirectory;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
-import com.carrotsearch.randomizedtesting.generators.RandomStrings;
 import com.gemstone.gemfire.DataSerializable;
 import com.gemstone.gemfire.DataSerializer;
 import com.gemstone.gemfire.cache.Cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitTest.java
index ede267c..617879f 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImplJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializerJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializerJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializerJUnitTest.java
index 7322311..e54856a 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializerJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializerJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxFieldMapperJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxFieldMapperJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxFieldMapperJUnitTest.java
index e6e6b79..ec31da9 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxFieldMapperJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxFieldMapperJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionFieldMapperJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionFieldMapperJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionFieldMapperJUnitTest.java
index 5731ffc..3ca8fbf 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionFieldMapperJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionFieldMapperJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type1.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type1.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type1.java
index b82d0be..e7f2ca4 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type1.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type1.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type2.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type2.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type2.java
index 10cc11e..81210ab 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type2.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/Type2.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorIntegrationJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorIntegrationJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorIntegrationJUnitTest.java
index e991643..8272522 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorIntegrationJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorIntegrationJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorJUnitTest.java
index 3db5d73..c1e93ad 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGeneratorJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserIntegrationJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserIntegrationJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserIntegrationJUnitTest.java
index d97e160..62b4f5a 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserIntegrationJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserIntegrationJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserJUnitTest.java
index ff271dd..298c92f 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlParserJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import static org.junit.Assert.*;


[12/50] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-11

Posted by bs...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/build.gradle
----------------------------------------------------------------------
diff --cc gemfire-core/build.gradle
index 185be12,b44525c..80761ed
--- a/gemfire-core/build.gradle
+++ b/gemfire-core/build.gradle
@@@ -11,61 -11,63 +11,59 @@@ configurations 
  }
  
  dependencies {
+    // Source Dependencies
+   // External 
    provided files("${System.getProperty('java.home')}/../lib/tools.jar")
-   compile 'antlr:antlr:2.7.7'
-   compile 'com.fasterxml.jackson.core:jackson-annotations:2.2.0'
-   compile 'com.fasterxml.jackson.core:jackson-core:2.2.0'
-   compile 'com.fasterxml.jackson.core:jackson-databind:2.2.0'
-   compile 'com.google.code.findbugs:annotations:3.0.0'
-   compile 'commons-io:commons-io:2.3'
-   compile 'commons-logging:commons-logging:1.1.1'
-   compile 'commons-modeler:commons-modeler:2.0'
-   compile 'it.unimi.dsi:fastutil:7.0.2'
-   compile 'javax.activation:activation:1.1.1'
-   compile 'javax.mail:javax.mail-api:1.4.5'
-   compile 'javax.resource:javax.resource-api:1.7'
-   compile 'javax.servlet:javax.servlet-api:3.1.0'
-   compile 'javax.transaction:javax.transaction-api:1.2'
-   compile 'mx4j:mx4j:3.0.1'
-   compile 'mx4j:mx4j-remote:3.0.1'
-   compile 'mx4j:mx4j-tools:3.0.1'
-   compile 'net.java.dev.jna:jna:4.0.0'
-   compile 'net.sourceforge.jline:jline:1.0.S2-B'
-   compile 'org.eclipse.jetty:jetty-http:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-io:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-security:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-server:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-servlet:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-util:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-webapp:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-xml:9.2.3.v20140905'
-   compile 'org.fusesource.jansi:jansi:1.8'
-   compile 'org.apache.logging.log4j:log4j-api:2.1'
-   compile 'org.apache.logging.log4j:log4j-core:2.1'
-   runtime 'org.apache.logging.log4j:log4j-slf4j-impl:2.1'
-   runtime 'org.apache.logging.log4j:log4j-jcl:2.1'
-   runtime 'org.apache.logging.log4j:log4j-jul:2.1'
-   compile 'org.slf4j:slf4j-api:1.7.7'
-   compile 'org.springframework.data:spring-data-commons:1.9.1.RELEASE'
-   provided 'org.springframework.data:spring-data-gemfire:1.5.1.RELEASE'
-   compile 'org.springframework:spring-tx:3.2.12.RELEASE'
-   compile 'org.springframework.shell:spring-shell:1.0.0.RELEASE'
-   compile 'org.xerial.snappy:snappy-java:1.1.1.6'
-   provided 'org.apache.hadoop:hadoop-common:2.4.1'
-   provided 'org.apache.hadoop:hadoop-annotations:2.4.1'
-   provided 'org.apache.hadoop:hadoop-hdfs:2.4.1'
-   provided 'org.apache.hadoop:hadoop-mapreduce-client-core:2.4.1'
-   compile 'org.apache.hbase:hbase:0.94.27'
-   provided 'commons-lang:commons-lang:2.5'
-   provided 'com.google.guava:guava:11.0.2'
-   compile 'io.netty:netty-all:4.0.4.Final'
- 
-   testRuntime 'org.apache.hadoop:hadoop-auth:2.4.1'
-   testRuntime 'commons-collections:commons-collections:3.2.1'
-   testRuntime 'commons-configuration:commons-configuration:1.6'
-   testRuntime 'commons-io:commons-io:2.1'
-   testRuntime 'log4j:log4j:1.2.17'
-   
+   compile 'antlr:antlr:' + project.'antlr.version'
+   compile 'com.fasterxml.jackson.core:jackson-annotations:' + project.'jackson.version'
+   compile 'com.fasterxml.jackson.core:jackson-core:' + project.'jackson.version'
+   compile 'com.fasterxml.jackson.core:jackson-databind:' + project.'jackson.version'
+   compile 'com.google.code.findbugs:annotations:' + project.'annotations.version'
+   provided 'com.google.guava:guava:' + project.'guava.version'
+   compile 'commons-io:commons-io:' + project.'commons-io.version'
+   provided 'commons-lang:commons-lang:' + project.'commons-lang.version'
+   compile 'commons-logging:commons-logging:' + project.'commons-logging.version'
+   compile 'commons-modeler:commons-modeler:' + project.'commons-modeler.version'
+   compile 'io.netty:netty-all:' + project.'netty-all.version'
+   compile 'it.unimi.dsi:fastutil:' + project.'fastutil.version'
+   compile 'javax.activation:activation:' + project.'activation.version'
+   compile 'javax.mail:javax.mail-api:' + project.'javax.mail-api.version'
+   compile 'javax.resource:javax.resource-api:' + project.'javax.resource-api.version'
+   compile 'javax.servlet:javax.servlet-api:' + project.'javax.servlet-api.version'
+   compile 'javax.transaction:javax.transaction-api:' + project.'javax.transaction-api.version'
+   compile 'mx4j:mx4j:' + project.'mx4j.version'
+   compile 'mx4j:mx4j-remote:' + project.'mx4j.version'
+   compile 'mx4j:mx4j-tools:' + project.'mx4j.version'
+   compile 'net.java.dev.jna:jna:' + project.'jna.version'
+   compile 'net.sourceforge.jline:jline:' + project.'jline.version'
+   provided 'org.apache.hadoop:hadoop-common:' + project.'hadoop.version'
+   provided 'org.apache.hadoop:hadoop-annotations:' + project.'hadoop.version'
+   provided 'org.apache.hadoop:hadoop-hdfs:' + project.'hadoop.version'
+   provided 'org.apache.hadoop:hadoop-mapreduce-client-core:' + project.'hadoop.version'
+   compile 'org.apache.hbase:hbase:' + project.'hbase.version'
+   compile 'org.apache.logging.log4j:log4j-api:' + project.'log4j.version'
+   compile 'org.apache.logging.log4j:log4j-core:' + project.'log4j.version'
+   runtime 'org.apache.logging.log4j:log4j-slf4j-impl:' + project.'log4j.version'
+   runtime 'org.apache.logging.log4j:log4j-jcl:' + project.'log4j.version'
+   runtime 'org.apache.logging.log4j:log4j-jul:' + project.'log4j.version'
 -  compile 'org.apache.lucene:lucene-analyzers-common:' + project.'lucene.version'
 -  compile 'org.apache.lucene:lucene-core:' + project.'lucene.version'
 -  compile 'org.apache.lucene:lucene-queries:' + project.'lucene.version'
 -  compile 'org.apache.lucene:lucene-queryparser:' + project.'lucene.version'
+   compile 'org.eclipse.jetty:jetty-http:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-io:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-security:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-server:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-servlet:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-util:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-webapp:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-xml:' + project.'jetty.version'
+   compile 'org.fusesource.jansi:jansi:' + project.'jansi.version'
+   compile 'org.slf4j:slf4j-api:' + project.'slf4j-api.version'
+   compile 'org.springframework.data:spring-data-commons:' + project.'spring-data-commons.version'
+   provided 'org.springframework.data:spring-data-gemfire:' + project.'spring-data-gemfire.version'
+   compile 'org.springframework:spring-tx:' + project.'springframework.version'
+   compile 'org.springframework.shell:spring-shell:' + project.'spring-shell.version'
+   compile 'org.xerial.snappy:snappy-java:' + project.'snappy-java.version'
+   compile 'org.apache.hbase:hbase:' + project.'hbase.version'
+  
+   compile project(':gemfire-common')
    compile project(':gemfire-jgroups')
    compile project(':gemfire-joptsimple')
    compile project(':gemfire-json')

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
----------------------------------------------------------------------
diff --cc gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
index f5ad158,c7cce3c..9425706
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
@@@ -18,8 -27,7 +27,6 @@@ import com.gemstone.gemfire.LogWriter
  import com.gemstone.gemfire.cache.client.ClientCache;
  import com.gemstone.gemfire.cache.client.ClientCacheFactory;
  import com.gemstone.gemfire.cache.control.ResourceManager;
- import com.gemstone.gemfire.cache.hdfs.HDFSStore;
- import com.gemstone.gemfire.cache.hdfs.HDFSStoreFactory;
 -import com.gemstone.gemfire.cache.lucene.LuceneService;
  import com.gemstone.gemfire.cache.wan.GatewaySenderFactory;
  import com.gemstone.gemfire.distributed.DistributedSystem;
  import com.gemstone.gemfire.pdx.PdxSerializer;
@@@ -252,20 -260,10 +259,4 @@@ public interface GemFireCache extends R
     * @since 6.6
     */
    public Properties getInitializerProps();
--
--  /**
-    * Returns the HDFSStore by name or <code>null</code> if no HDFSStore is
-    * found.
-    * 
-    * @param name the name of the HDFSStore to find.
 -   * Returns the LuceneService singleton instance.
 -   * @since 8.5
--   */
-   public HDFSStore findHDFSStore(String name);
- 
-    /**
- 	* Creates a {@link HDFSStoreFactory} for creating a {@link HDFSStore}
- 	* 
- 	* @return the HDFS store factory
- 	*/
-   public HDFSStoreFactory createHDFSStoreFactory();
-   
 -  public LuceneService getLuceneService();
  }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/cache/asyncqueue/internal/AsyncEventQueueFactoryImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/cache/asyncqueue/internal/AsyncEventQueueImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketRegion.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCache.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataStore.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/extension/SimpleExtensionPoint.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderAttributes.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/CacheCreation.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/DefaultEntityResolver2.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/PivotalEntityResolver.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CopyOnWriteHashMap.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CopyOnWriteWeakHashMap.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/extension/mock/DestroyMockCacheExtensionFunction.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
----------------------------------------------------------------------
diff --cc gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
index fc9752a,0000000..49b74b1
mode 100644,000000..100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
@@@ -1,49 -1,0 +1,58 @@@
- /*=========================================================================
-  * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
-  * This product is protected by U.S. and international copyright
-  * and intellectual property laws. Pivotal products are covered by
-  * more patents listed at http://www.pivotal.io/patents.
-  *========================================================================
++/*
++ * 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 java.util.Map;
 +
 +import org.apache.lucene.analysis.Analyzer;
 +
 +
 +/**
 + * An lucene index is built over the data stored in a GemFire Region.
 + * <p>
 + * An index is specified using a index name, field names, region name.
 + * <p>
 + * The index name and region name together uniquely identifies the lucene index.
 + * <p>
 + * 
 + * @author Xiaojian Zhou
 + * @since 8.5
 + */
 +public interface LuceneIndex {
 +
 +  /**
 +   * @return the index name of this index
 +   */
 +  public String getName();
 +
 +  /**
 +   * @return the region name for this index
 +   */
 +  public String getRegionPath();
 +      
 +  /**
 +   * @return the indexed field names in a Set
 +   */
 +  public String[] getFieldNames();
 +  
 +  /**
 +   * @return the field to analyzer map
 +   */
 +  public Map<String, Analyzer> getFieldAnalyzerMap();
 +  
 +}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
----------------------------------------------------------------------
diff --cc gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
index 09d3a07,0000000..e10b686
mode 100644,000000..100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
@@@ -1,29 -1,0 +1,45 @@@
++/*
++ * 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;
 +
 +/**
 + * Provides wrapper object of Lucene's Query object and execute the search. 
 + * <p>Instances of this interface are created using
 + * {@link LuceneQueryFactory#create}.
 + * 
 + */
 +public interface LuceneQuery<K, V> {
 +  /**
 +   * Execute the search and get results. 
 +   */
 +  public LuceneQueryResults<K, V> search();
 +  
 +  /**
 +   * Get page size setting of current query. 
 +   */
 +  public int getPageSize();
 +  
 +  /**
 +   * Get limit size setting of current query. 
 +   */
 +  public int getLimit();
 +
 +  /**
 +   * Get projected fields setting of current query. 
 +   */
 +  public String[] getProjectedFieldNames();
 +}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
----------------------------------------------------------------------
diff --cc gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
index eea4b88,0000000..6604926
mode 100644,000000..100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
@@@ -1,83 -1,0 +1,99 @@@
++/*
++ * 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 org.apache.lucene.queryparser.classic.ParseException;
 +
 +/**
 + * Factory for creating instances of {@link LuceneQuery}.
 + * To get an instance of this factory call {@link LuceneService#createLuceneQueryFactory}.
 + * <P>
 + * To use this factory configure it with the <code>set</code> methods and then
 + * call {@link #create} to produce a {@link LuceneQuery} instance.
 + * 
 + * @author Xiaojian Zhou
 + * @since 8.5
 + */
 +public interface LuceneQueryFactory {
 +  
 +  /**
 +   * Default query result limit is 100
 +   */
 +  public static final int DEFAULT_LIMIT = 100;
 +  
 +  /**
 +   *  Default page size of result is 0, which means no pagination
 +   */
 +  public static final int DEFAULT_PAGESIZE = 0;
 +  
 +  /**
 +   * Set page size for a query result. The default page size is 0 which means no pagination.
 +   * If specified negative value, throw IllegalArgumentException
 +   * @param pageSize
 +   * @return itself
 +   */
 +  LuceneQueryFactory setPageSize(int pageSize);
 +  
 +  /**
 +   * Set max limit of result for a query
 +   * If specified limit is less or equal to zero, throw IllegalArgumentException
 +   * @param limit
 +   * @return itself
 +   */
 +  LuceneQueryFactory setResultLimit(int limit);
 +  
 +  /**
 +   * Set a list of fields for result projection.
 +   * 
 +   * @param fieldNames
 +   * @return itself
 +   * 
 +   * @deprecated TODO This feature is not yet implemented
 +   */
 +  @Deprecated
 +  LuceneQueryFactory setProjectionFields(String... fieldNames);
 +  
 +  /**
 +   * Create wrapper object for lucene's QueryParser object using default standard analyzer.
 +   * The queryString is using lucene QueryParser's syntax. QueryParser is for easy-to-use 
 +   * with human understandable syntax. 
 +   *  
 +   * @param regionName region name
 +   * @param indexName index name
 +   * @param queryString query string in lucene QueryParser's syntax
 +   * @param K the key type in the query results
 +   * @param V the value type in the query results
 +   * @return LuceneQuery object
 +   * @throws ParseException
 +   */
 +  public <K, V> LuceneQuery<K, V> create(String indexName, String regionName, String queryString) 
 +      throws ParseException;
 +
 +  /**
 +   * Creates a wrapper object for Lucene's Query object. This {@link LuceneQuery} builder method could be used in
 +   * advanced cases, such as cases where Lucene's Query object construction needs Lucene's API over query string. The
 +   * {@link QueryDeserializer} will be used to re-construct the Lucene Query object on remote hosts.
 +   * 
 +   * @param indexName index name
 +   * @param regionName region name
 +   * @param provider constructs and provides a Lucene Query object
 +   * @param K the key type in the query results
 +   * @param V the value type in the query results
 +   * @return LuceneQuery object
 +   */
 +  public <K, V> LuceneQuery<K, V> create(String indexName, String regionName, LuceneQueryProvider provider);
 +}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
----------------------------------------------------------------------
diff --cc gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
index 6ed0b99,0000000..1cf3c7c
mode 100644,000000..100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
@@@ -1,45 -1,0 +1,61 @@@
++/*
++ * 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;
 +
 +
 +/**
 + * <p>
 + * Abstract data structure for one item in query result.
 + * 
 + * @author Xiaojian Zhou
 + * @since 8.5
 + */
 +public interface LuceneResultStruct<K, V> {
 +  /**
 +   * Return the value associated with the given field name
 +   *
 +   * @param fieldName the String name of the field
 +   * @return the value associated with the specified field
 +   * @throws IllegalArgumentException If this struct does not have a field named fieldName
 +   */
 +  public Object getProjectedField(String fieldName);
 +  
 +  /**
 +   * Return key of the entry
 +   *
 +   * @return key
 +   * @throws IllegalArgumentException If this struct does not contain key
 +   */
 +  public K getKey();
 +  
 +  /**
 +   * Return value of the entry
 +   *
 +   * @return value the whole domain object
 +   * @throws IllegalArgumentException If this struct does not contain value
 +   */
 +  public V getValue();
 +  
 +  /**
 +   * Return score of the query 
 +   *
 +   * @return score
 +   * @throws IllegalArgumentException If this struct does not contain score
 +   */
 +  public float getScore();
 +}
 +

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
----------------------------------------------------------------------
diff --cc gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
index 6c629de,0000000..6bbb4fd
mode 100644,000000..100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
@@@ -1,110 -1,0 +1,126 @@@
++/*
++ * 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 java.util.Collection;
 +import java.util.Map;
 +
 +import org.apache.lucene.analysis.Analyzer;
 +
 +import com.gemstone.gemfire.cache.Cache;
 +import com.gemstone.gemfire.cache.GemFireCache;
 +import com.gemstone.gemfire.cache.lucene.internal.LuceneServiceImpl;
 +import com.gemstone.gemfire.internal.cache.extension.Extensible;
 +
 +/**
 + * LuceneService instance is a singleton for each cache. It will be created in cache 
 + * constructor and get its reference via {@link GemFireCache#getLuceneService()}.
 + * 
 + * It provides handle for managing the {@link LuceneIndex} and create the {@link LuceneQuery}
 + * via {@link LuceneQueryFactory}
 + * 
 + * </p>
 + * Example: <br>
 + * 
 + * <pre>
 + * At client and server JVM, initializing cache will create the LuceneServiceImpl object, 
 + * which is a singleton at each JVM. 
 + * 
 + * At each server JVM, for data region to create index, create the index on fields with default analyzer:
 + * LuceneIndex index = luceneService.createIndex(indexName, regionName, "field1", "field2", "field3"); 
 + * or create index on fields with specified analyzer:
 + * LuceneIndex index = luceneService.createIndex(indexName, regionName, analyzerPerField);
 + * 
 + * We can also create index via cache.xml or gfsh.
 + * 
 + * At client side, create query and run the search:
 + * 
 + * LuceneQuery query = luceneService.createLuceneQueryFactory().setLimit(200).setPageSize(20)
 + * .setResultTypes(SCORE, VALUE, KEY).setFieldProjection("field1", "field2")
 + * .create(indexName, regionName, querystring, analyzer);
 + * 
 + * The querystring is using lucene's queryparser syntax, such as "field1:zhou* AND field2:gzhou@pivotal.io"
 + *  
 + * LuceneQueryResults results = query.search();
 + * 
 + * If pagination is not specified:
 + * List list = results.getNextPage(); // return all results in one getNextPage() call
 + * or if paging is specified:
 + * if (results.hasNextPage()) {
 + *   List page = results.nextPage(); // return resules page by page
 + * }
 + * 
 + * The item of the list is either the domain object or instance of {@link LuceneResultStruct}
 + * </pre>
 + * 
 + * @author Xiaojian Zhou
 + *
 + */
 +public interface LuceneService {
 +  
 +  /**
 +   * Create a lucene index using default analyzer.
 +   * 
 +   * @param indexName
 +   * @param regionPath
 +   * @param fields
 +   * @return LuceneIndex object
 +   */
 +  public void createIndex(String indexName, String regionPath, String... fields);
 +  
 +  /**
 +   * Create a lucene index using specified analyzer per field
 +   * 
 +   * @param indexName index name
 +   * @param regionPath region name
 +   * @param analyzerPerField analyzer per field map
 +   * @return LuceneIndex object
 +   * @deprecated TODO This feature is not yet implemented
 +   */
 +  @Deprecated
 +  public void createIndex(String indexName, String regionPath,  
 +      Map<String, Analyzer> analyzerPerField);
 +
 +  /**
 +   * Destroy the lucene index
 +   * 
 +   * @param index index object
 +   * @deprecated TODO This feature is not yet implemented
 +   */
 +  @Deprecated
 +  public void destroyIndex(LuceneIndex index);
 +  
 +  /**
 +   * Get the lucene index object specified by region name and index name
 +   * @param indexName index name
 +   * @param regionPath region name
 +   * @return LuceneIndex object
 +   */
 +  public LuceneIndex getIndex(String indexName, String regionPath);
 +  
 +  /**
 +   * get all the lucene indexes.
 +   * @return all index objects in a Collection
 +   */
 +  public Collection<LuceneIndex> getAllIndexes();
 +
 +  /**
 +   * create LuceneQueryFactory
 +   * @return LuceneQueryFactory object
 +   */
 +  public LuceneQueryFactory createLuceneQueryFactory();
 +}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f189ff52/settings.gradle
----------------------------------------------------------------------


[23/50] [abbrv] incubator-geode git commit: GEODE-11: ADD Apache License header

Posted by bs...@apache.org.
GEODE-11: ADD Apache License header


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

Branch: refs/heads/feature/GEODE-77
Commit: 300397c17203fccda28436779ede46ee23fc32a3
Parents: 3e87134
Author: Ashvin Agrawal <as...@apache.org>
Authored: Sun Nov 8 22:02:39 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Mon Nov 9 10:31:42 2015 -0800

----------------------------------------------------------------------
 .../cache/lucene/LuceneQueryProvider.java       | 19 ++++++++++++
 .../cache/lucene/LuceneQueryResults.java        | 19 ++++++++++++
 .../cache/lucene/LuceneServiceProvider.java     | 19 ++++++++++++
 .../lucene/internal/InternalLuceneIndex.java    | 19 ++++++++++++
 .../lucene/internal/InternalLuceneService.java  | 19 ++++++++++++
 .../lucene/internal/LuceneEventListener.java    | 19 ++++++++++++
 .../LuceneIndexForPartitionedRegion.java        | 19 ++++++++++++
 .../LuceneIndexForReplicatedRegion.java         | 19 ++++++++++++
 .../cache/lucene/internal/LuceneIndexImpl.java  | 24 ++++++++++++---
 .../lucene/internal/LuceneQueryFactoryImpl.java | 19 ++++++++++++
 .../cache/lucene/internal/LuceneQueryImpl.java  | 19 ++++++++++++
 .../lucene/internal/LuceneQueryResultsImpl.java | 19 ++++++++++++
 .../lucene/internal/LuceneResultStructImpl.java | 19 ++++++++++++
 .../lucene/internal/LuceneServiceImpl.java      | 19 ++++++++++++
 .../internal/PartitionedRepositoryManager.java  | 19 ++++++++++++
 .../lucene/internal/StringQueryProvider.java    | 20 +++++++++++-
 .../internal/directory/FileIndexInput.java      | 19 ++++++++++++
 .../internal/directory/RegionDirectory.java     | 32 ++++++++++++--------
 .../internal/distributed/CollectorManager.java  | 19 ++++++++++++
 .../lucene/internal/distributed/EntryScore.java | 19 ++++++++++++
 .../internal/distributed/LuceneFunction.java    | 20 +++++++++++-
 .../distributed/LuceneFunctionContext.java      | 19 ++++++++++++
 .../lucene/internal/distributed/TopEntries.java | 19 ++++++++++++
 .../distributed/TopEntriesCollector.java        | 19 ++++++++++++
 .../distributed/TopEntriesCollectorManager.java | 19 ++++++++++++
 .../TopEntriesFunctionCollector.java            | 19 ++++++++++++
 .../lucene/internal/filesystem/ChunkKey.java    | 19 ++++++++++++
 .../cache/lucene/internal/filesystem/File.java  | 19 ++++++++++++
 .../internal/filesystem/FileInputStream.java    | 20 +++++++++++-
 .../internal/filesystem/FileOutputStream.java   | 19 ++++++++++++
 .../lucene/internal/filesystem/FileSystem.java  | 19 ++++++++++++
 .../filesystem/SeekableInputStream.java         | 19 ++++++++++++
 .../internal/repository/IndexRepository.java    | 19 ++++++++++++
 .../repository/IndexRepositoryImpl.java         | 19 ++++++++++++
 .../repository/IndexResultCollector.java        | 19 ++++++++++++
 .../internal/repository/RepositoryManager.java  | 19 ++++++++++++
 .../HeterogenousLuceneSerializer.java           | 19 ++++++++++++
 .../repository/serializer/LuceneSerializer.java | 19 ++++++++++++
 .../serializer/PdxLuceneSerializer.java         | 19 ++++++++++++
 .../serializer/ReflectionLuceneSerializer.java  | 19 ++++++++++++
 .../repository/serializer/SerializerUtil.java   | 19 ++++++++++++
 .../internal/xml/LuceneIndexCreation.java       | 19 ++++++++++++
 .../internal/xml/LuceneIndexXmlGenerator.java   | 19 ++++++++++++
 .../internal/xml/LuceneServiceXmlGenerator.java | 19 ++++++++++++
 .../lucene/internal/xml/LuceneXmlConstants.java | 19 ++++++++++++
 .../lucene/internal/xml/LuceneXmlParser.java    | 19 ++++++++++++
 .../internal/LuceneEventListenerJUnitTest.java  | 19 ++++++++++++
 .../LuceneIndexRecoveryHAJUnitTest.java         | 19 ++++++++++++
 .../LuceneQueryFactoryImplJUnitTest.java        | 18 +++++++++++
 .../internal/LuceneQueryImplJUnitTest.java      | 19 ++++++++++++
 .../LuceneQueryResultsImplJUnitTest.java        | 19 ++++++++++++
 .../LuceneResultStructImpJUnitTest.java         | 19 ++++++++++++
 .../internal/LuceneServiceImplJUnitTest.java    | 19 ++++++++++++
 .../PartitionedRepositoryManagerJUnitTest.java  | 19 ++++++++++++
 .../internal/StringQueryProviderJUnitTest.java  | 19 ++++++++++++
 .../directory/RegionDirectoryJUnitTest.java     | 19 ++++++++++++
 .../DistributedScoringJUnitTest.java            | 19 ++++++++++++
 .../distributed/EntryScoreJUnitTest.java        | 19 ++++++++++++
 .../LuceneFunctionContextJUnitTest.java         | 19 ++++++++++++
 .../distributed/LuceneFunctionJUnitTest.java    | 19 ++++++++++++
 .../LuceneFunctionReadPathDUnitTest.java        | 19 ++++++++++++
 .../TopEntriesCollectorJUnitTest.java           | 19 ++++++++++++
 .../TopEntriesFunctionCollectorJUnitTest.java   | 19 ++++++++++++
 .../distributed/TopEntriesJUnitTest.java        | 19 ++++++++++++
 .../internal/filesystem/ChunkKeyJUnitTest.java  | 19 ++++++++++++
 .../internal/filesystem/FileJUnitTest.java      | 19 ++++++++++++
 .../filesystem/FileSystemJUnitTest.java         | 19 ++++++++++++
 ...IndexRepositoryImplJUnitPerformanceTest.java | 23 +++++++++++---
 .../IndexRepositoryImplJUnitTest.java           | 19 ++++++++++++
 .../HeterogenousLuceneSerializerJUnitTest.java  | 19 ++++++++++++
 .../serializer/PdxFieldMapperJUnitTest.java     | 19 ++++++++++++
 .../ReflectionFieldMapperJUnitTest.java         | 19 ++++++++++++
 .../internal/repository/serializer/Type1.java   | 19 ++++++++++++
 .../internal/repository/serializer/Type2.java   | 19 ++++++++++++
 ...neIndexXmlGeneratorIntegrationJUnitTest.java | 19 ++++++++++++
 .../xml/LuceneIndexXmlGeneratorJUnitTest.java   | 19 ++++++++++++
 ...uceneIndexXmlParserIntegrationJUnitTest.java | 19 ++++++++++++
 .../xml/LuceneIndexXmlParserJUnitTest.java      | 19 ++++++++++++
 78 files changed, 1481 insertions(+), 25 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
index 82f486c..8e3500e 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
index cdc8b10..68d4ec2 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
index 72ec554..bbd2b83 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
@@ -1,3 +1,22 @@
+/*
+ * 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.annotations.Experimental;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneIndex.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneIndex.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneIndex.java
index ab2c924..951b0f9 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneIndex.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneIndex.java
@@ -1,3 +1,22 @@
+/*
+ * 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.cache.lucene.LuceneIndex;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneService.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneService.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneService.java
index cd78c2c..403853e 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneService.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/InternalLuceneService.java
@@ -1,3 +1,22 @@
+/*
+ * 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.cache.Cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListener.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListener.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListener.java
index 049fb64..9fdfd43 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListener.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListener.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForPartitionedRegion.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForPartitionedRegion.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForPartitionedRegion.java
index 0e5b424..7002567 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForPartitionedRegion.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForPartitionedRegion.java
@@ -1,3 +1,22 @@
+/*
+ * 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.cache.Cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForReplicatedRegion.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForReplicatedRegion.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForReplicatedRegion.java
index 7288399..7c585cf 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForReplicatedRegion.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexForReplicatedRegion.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
index c8d4bb6..f869755 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
@@ -1,6 +1,24 @@
+/*
+ * 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 java.util.HashSet;
 import java.util.Map;
 
 import org.apache.logging.log4j.Logger;
@@ -16,10 +34,6 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.logging.LogService;
 
 public abstract class LuceneIndexImpl implements InternalLuceneIndex {
-
-  static private final boolean CREATE_CACHE = Boolean.getBoolean("lucene.createCache");
-  static private final boolean USE_FS = Boolean.getBoolean("lucene.useFileSystem");
-  
   protected static final Logger logger = LogService.getLogger();
   
 //  protected HashSet<String> searchableFieldNames = new HashSet<String>();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
index b377949..c6087ea 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
@@ -1,3 +1,22 @@
+/*
+ * 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.cache.Cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
index 222acdc..a876b40 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
@@ -1,3 +1,22 @@
+/*
+ * 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.cache.Region;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
index d77dbc5..f0e98c8 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
index 35cf086..a3794f2 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
@@ -1,3 +1,22 @@
+/*
+ * 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.cache.lucene.LuceneResultStruct;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
index 5efe300..ab48b19 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManager.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManager.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManager.java
index e276cff..07050e2 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManager.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/PartitionedRepositoryManager.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProvider.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProvider.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProvider.java
index 7e50bae..1e2b63d 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProvider.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/StringQueryProvider.java
@@ -1,3 +1,22 @@
+/*
+ * 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 java.io.DataInput;
@@ -5,7 +24,6 @@ import java.io.DataOutput;
 import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
-import org.apache.lucene.analysis.core.SimpleAnalyzer;
 import org.apache.lucene.analysis.standard.StandardAnalyzer;
 import org.apache.lucene.queryparser.classic.MultiFieldQueryParser;
 import org.apache.lucene.queryparser.classic.ParseException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/FileIndexInput.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/FileIndexInput.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/FileIndexInput.java
index 235cd3a..9ebef51 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/FileIndexInput.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/FileIndexInput.java
@@ -1,3 +1,22 @@
+/*
+ * 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.directory;
 
 import java.io.EOFException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectory.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectory.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectory.java
index 38e7714..e25dc77 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectory.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/directory/RegionDirectory.java
@@ -1,3 +1,22 @@
+/*
+ * 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.directory;
 
 import java.io.IOException;
@@ -5,27 +24,16 @@ import java.io.OutputStream;
 import java.util.Collection;
 import java.util.concurrent.ConcurrentMap;
 
-import org.apache.logging.log4j.Logger;
 import org.apache.lucene.store.BaseDirectory;
-import org.apache.lucene.store.BufferedIndexInput;
 import org.apache.lucene.store.IOContext;
 import org.apache.lucene.store.IndexInput;
 import org.apache.lucene.store.IndexOutput;
 import org.apache.lucene.store.OutputStreamIndexOutput;
 import org.apache.lucene.store.SingleInstanceLockFactory;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionShortcut;
 import com.gemstone.gemfire.cache.lucene.internal.filesystem.ChunkKey;
 import com.gemstone.gemfire.cache.lucene.internal.filesystem.File;
 import com.gemstone.gemfire.cache.lucene.internal.filesystem.FileSystem;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
 
 /**
  * An implementation of Directory that stores data in geode regions.
@@ -36,8 +44,6 @@ import com.gemstone.gemfire.internal.logging.LogService;
  */
 public class RegionDirectory extends BaseDirectory {
 
-  private static final Logger logger = LogService.getLogger();
-  
   private final FileSystem fs;
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
index 904a47e..45750d1 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScore.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScore.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScore.java
index 456b3ba..6690342 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScore.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/EntryScore.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunction.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunction.java
index b8552fa..c3b79c5 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunction.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunction.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.IOException;
@@ -12,7 +31,6 @@ import com.gemstone.gemfire.cache.execute.FunctionAdapter;
 import com.gemstone.gemfire.cache.execute.FunctionContext;
 import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
 import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.cache.lucene.LuceneQueryFactory;
 import com.gemstone.gemfire.cache.lucene.LuceneQueryProvider;
 import com.gemstone.gemfire.cache.lucene.LuceneService;
 import com.gemstone.gemfire.cache.lucene.LuceneServiceProvider;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContext.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContext.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContext.java
index d36bcc2..b0b2c60 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContext.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionContext.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntries.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntries.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntries.java
index 3417615..5813d75 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntries.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntries.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollector.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollector.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollector.java
index 37797d9..94b8a3a 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollector.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollector.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorManager.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorManager.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorManager.java
index 417d80f..b19e104 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorManager.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesCollectorManager.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
index 96ec296..2e8f2dc 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
@@ -1,3 +1,22 @@
+/*
+ * 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.distributed;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKey.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKey.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKey.java
index d13f3f5..8fbe356 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKey.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/ChunkKey.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/File.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/File.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/File.java
index 1ad0808..2937af5 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/File.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/File.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileInputStream.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileInputStream.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileInputStream.java
index bcb0821..18194aa 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileInputStream.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileInputStream.java
@@ -1,8 +1,26 @@
+/*
+ * 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.filesystem;
 
 import java.io.EOFException;
 import java.io.IOException;
-import java.io.InputStream;
 
 /**
  * An input stream that reads chunks from

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileOutputStream.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileOutputStream.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileOutputStream.java
index ea80d78..3f9f614 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileOutputStream.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileOutputStream.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystem.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystem.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystem.java
index 5e29437..b84dc92 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystem.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/FileSystem.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import java.io.FileNotFoundException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/SeekableInputStream.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/SeekableInputStream.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/SeekableInputStream.java
index abf3268..e10e0c4 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/SeekableInputStream.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/filesystem/SeekableInputStream.java
@@ -1,3 +1,22 @@
+/*
+ * 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.filesystem;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepository.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepository.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepository.java
index b852b82..f1e63e0 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepository.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepository.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImpl.java
index fbbc5db..a9c463e 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexRepositoryImpl.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
index fa867e1..7fd9e2a 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository;
 
 import com.gemstone.gemfire.annotations.Experimental;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/RepositoryManager.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/RepositoryManager.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/RepositoryManager.java
index cea4f89..20c2d51 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/RepositoryManager.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/RepositoryManager.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializer.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializer.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializer.java
index 798f34e..7cb25bb 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializer.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/HeterogenousLuceneSerializer.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/LuceneSerializer.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/LuceneSerializer.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/LuceneSerializer.java
index a06617a..421dc0b 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/LuceneSerializer.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/LuceneSerializer.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import org.apache.lucene.document.Document;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxLuceneSerializer.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxLuceneSerializer.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxLuceneSerializer.java
index 338edb2..c5c55a9 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxLuceneSerializer.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/PdxLuceneSerializer.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import org.apache.lucene.document.Document;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionLuceneSerializer.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionLuceneSerializer.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionLuceneSerializer.java
index 0b54fdd..953f31f 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionLuceneSerializer.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/ReflectionLuceneSerializer.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import java.lang.reflect.Field;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/SerializerUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/SerializerUtil.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/SerializerUtil.java
index 30224b4..7ffc5db 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/SerializerUtil.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/serializer/SerializerUtil.java
@@ -1,3 +1,22 @@
+/*
+ * 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.repository.serializer;
 
 import java.io.ByteArrayOutputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
index b2f2645..e664895 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexCreation.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGenerator.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGenerator.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGenerator.java
index dcfbec6..6399a80 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGenerator.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneIndexXmlGenerator.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import static com.gemstone.gemfire.cache.lucene.internal.xml.LuceneXmlConstants.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneServiceXmlGenerator.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneServiceXmlGenerator.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneServiceXmlGenerator.java
index 6c0da01..c449f47 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneServiceXmlGenerator.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneServiceXmlGenerator.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import org.xml.sax.SAXException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlConstants.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlConstants.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlConstants.java
index 45c08b6..303424e 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlConstants.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlConstants.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 public class LuceneXmlConstants {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlParser.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlParser.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlParser.java
index 25aac41..764f461 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlParser.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/xml/LuceneXmlParser.java
@@ -1,3 +1,22 @@
+/*
+ * 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.xml;
 
 import static com.gemstone.gemfire.cache.lucene.internal.xml.LuceneXmlConstants.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListenerJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListenerJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListenerJUnitTest.java
index 617020b..85a5333 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListenerJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneEventListenerJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.mockito.Matchers.any;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/300397c1/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexRecoveryHAJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexRecoveryHAJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexRecoveryHAJUnitTest.java
index 3ee1345..405c986 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexRecoveryHAJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexRecoveryHAJUnitTest.java
@@ -1,3 +1,22 @@
+/*
+ * 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 static org.junit.Assert.assertNotNull;



[24/50] [abbrv] incubator-geode git commit: GEODE-11: Move Lucene dependency version info to versions file

Posted by bs...@apache.org.
GEODE-11: Move Lucene dependency version info to versions file

See commit dc5d343 or GEODE 227 for additional details.


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

Branch: refs/heads/feature/GEODE-77
Commit: 37cc70edf7c6e519684b1ce9903a364c251d7d22
Parents: 300397c
Author: Ashvin Agrawal <as...@apache.org>
Authored: Mon Nov 9 10:32:16 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Mon Nov 9 10:33:45 2015 -0800

----------------------------------------------------------------------
 gemfire-lucene/build.gradle           | 22 +++++++++++-----------
 gradle/dependency-versions.properties |  2 +-
 2 files changed, 12 insertions(+), 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/37cc70ed/gemfire-lucene/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-lucene/build.gradle b/gemfire-lucene/build.gradle
index 40313c5..6c3adda 100644
--- a/gemfire-lucene/build.gradle
+++ b/gemfire-lucene/build.gradle
@@ -2,27 +2,27 @@ dependencies {
     provided project(':gemfire-core')
     provided project(':gemfire-common')
 
-    compile 'org.apache.lucene:lucene-analyzers-common:5.3.0'
-    compile 'org.apache.lucene:lucene-core:5.3.0'
-    compile 'org.apache.lucene:lucene-queries:5.3.0'
-    compile 'org.apache.lucene:lucene-queryparser:5.3.0'
+    compile 'org.apache.lucene:lucene-analyzers-common:' + project.'lucene.version'
+    compile 'org.apache.lucene:lucene-core:' + project.'lucene.version'
+    compile 'org.apache.lucene:lucene-queries:' + project.'lucene.version'
+    compile 'org.apache.lucene:lucene-queryparser:' + project.'lucene.version'
 
     provided project(path: ':gemfire-junit', configuration: 'testOutput')
 
     //Lucene test framework.
-    testCompile 'org.apache.lucene:lucene-test-framework:5.3.0'
-    testCompile 'org.apache.lucene:lucene-codecs:5.3.0'
+    testCompile 'org.apache.lucene:lucene-test-framework:' + project.'lucene.version'
+    testCompile 'org.apache.lucene:lucene-codecs:' + project.'lucene.version'
     testCompile project(path: ':gemfire-core', configuration: 'testOutput', transitive: false)
-    //Dependency ot lucene-test-framework. Can we turn on transitive depencies for
+    //Dependency of lucene-test-framework. Can we turn on transitive dependencies for
     //the test framework somehow? We've disabled them globally in the parent
     //build.gadle.
     testCompile 'com.carrotsearch.randomizedtesting:randomizedtesting-runner:2.1.6'
 
     // the following test dependencies are needed for mocking cache instance
-    testRuntime 'org.apache.hadoop:hadoop-common:2.4.1'
-    testRuntime 'org.apache.hadoop:hadoop-hdfs:2.4.1'
-    testRuntime 'com.google.guava:guava:11.0.2'
-    testRuntime 'commons-collections:commons-collections:3.2.1'
+    testRuntime 'org.apache.hadoop:hadoop-common:' + project.'hadoop.version'
+    testRuntime 'org.apache.hadoop:hadoop-hdfs:' + project.'hadoop.version'
+    testRuntime 'com.google.guava:guava:' + project.'guava.version'
+    testRuntime 'commons-collections:commons-collections:' + project.'commons-collections.version'
 }
 
 //The lucene integration tests don't have any issues that requiring forking

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/37cc70ed/gradle/dependency-versions.properties
----------------------------------------------------------------------
diff --git a/gradle/dependency-versions.properties b/gradle/dependency-versions.properties
index 5fc6fbc..8be0f15 100644
--- a/gradle/dependency-versions.properties
+++ b/gradle/dependency-versions.properties
@@ -40,7 +40,7 @@ json4s.version = 3.2.4
 junit.version = 4.12
 JUnitParams.version = 1.0.4
 log4j.version = 2.1
-lucene.version = 5.0.0
+lucene.version = 5.3.0
 mockito-core.version = 1.10.19
 multithreadedtc.version = 1.01
 mx4j.version = 3.0.1


[33/50] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-11

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


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

Branch: refs/heads/feature/GEODE-77
Commit: 3af1540f6ab3555744b794c74a131cf75aa1f969
Parents: 2cf4fb1 79aa0be
Author: Ashvin Agrawal <as...@apache.org>
Authored: Wed Nov 11 13:19:51 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Wed Nov 11 13:19:51 2015 -0800

----------------------------------------------------------------------
 .../cache/partition/PartitionManager.java       |  2 +-
 .../com/gemstone/gemfire/internal/Version.java  |  5 ++
 .../cache/tier/sockets/CommandInitializer.java  |  4 ++
 .../tier/sockets/command/CommitCommand.java     |  4 +-
 .../tier/sockets/command/ExecuteFunction66.java |  2 +-
 .../command/ExecuteRegionFunction66.java        |  2 +-
 .../command/ExecuteRegionFunctionSingleHop.java |  2 +-
 .../partition/PartitionManagerDUnitTest.java    | 75 --------------------
 .../tier/sockets/command/CommitCommandTest.java | 39 ++++++++++
 .../management/DistributedSystemDUnitTest.java  | 12 ++--
 10 files changed, 59 insertions(+), 88 deletions(-)
----------------------------------------------------------------------



[42/50] [abbrv] incubator-geode git commit: GEODE-402: MembershipListener callbacks are not always invoked

Posted by bs...@apache.org.
GEODE-402: MembershipListener callbacks are not always invoked


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

Branch: refs/heads/feature/GEODE-77
Commit: 8703abc4a7578d2667a800f47f9e771946ef82e4
Parents: 9438c8b
Author: Barry Oglesby <bo...@pivotal.io>
Authored: Tue Nov 10 18:55:22 2015 -0800
Committer: Barry Oglesby <bo...@pivotal.io>
Committed: Fri Nov 13 09:10:56 2015 -0800

----------------------------------------------------------------------
 .../internal/DistributionManager.java           | 322 ++++---------------
 1 file changed, 66 insertions(+), 256 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8703abc4/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
index f32f408..9c06fa1 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
@@ -2478,43 +2478,6 @@ public class DistributionManager
     }
   }
 
-  private void handleJoinEvent(MemberJoinedEvent ev) {
-    InternalDistributedMember id = ev.getId();
-    for (Iterator iter = membershipListeners.keySet().iterator();
-         iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.memberJoined(id);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-    for (Iterator iter = allMembershipListeners.iterator();
-         iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try  {
-        listener.memberJoined(id);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-  }
   /**
    * Returns true if this DM or the DistributedSystem owned by
    * it is closing or is closed.
@@ -2529,120 +2492,6 @@ public class DistributionManager
     }
     return false;
   }
-  private void handleCrashEvent(MemberCrashedEvent ev) {
-    InternalDistributedMember id = ev.getId();
-    for (Iterator iter = membershipListeners.keySet().iterator();
-         iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.memberDeparted(id, true/*crashed*/);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-    for (Iterator iter = allMembershipListeners.iterator();
-         iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.memberDeparted(id, true/*crashed*/);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-    
-    MembershipLogger.logCrash(id);
-  }
-  private void handleDepartEvent(MemberDepartedEvent ev) {
-    InternalDistributedMember id = ev.getId();
-    for (Iterator iter = membershipListeners.keySet().iterator();
-         iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.memberDeparted(id, false);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-    for (Iterator iter = allMembershipListeners.iterator();
-         iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.memberDeparted(id, false);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-  }
-  private void handleSuspectEvent(MemberSuspectEvent ev) {
-    InternalDistributedMember id = ev.getId();
-    InternalDistributedMember whoSuspected = ev.whoSuspected();
-    for (Iterator iter = membershipListeners.keySet().iterator();
-         iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.memberSuspect(id, whoSuspected);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-    for (Iterator iter = allMembershipListeners.iterator();
-    iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.memberSuspect(id, whoSuspected);
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-  }
   
   private void handleViewInstalledEvent(ViewInstalledEvent ev) {
     synchronized(this.membershipViewIdGuard) {
@@ -2651,43 +2500,6 @@ public class DistributionManager
     }
   }
   
-  private void handleQuorumLostEvent(QuorumLostEvent ev) {
-    for (Iterator iter = membershipListeners.keySet().iterator();
-    iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.quorumLost(ev.getFailures(), ev.getRemaining());
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-    for (Iterator iter = allMembershipListeners.iterator();
-    iter.hasNext(); ) {
-      MembershipListener listener = (MembershipListener) iter.next();
-      try {
-        listener.quorumLost(ev.getFailures(), ev.getRemaining());
-      } catch (CancelException e) {
-        if (isCloseInProgress()) {
-          if (logger.isTraceEnabled()) {
-            logger.trace("MemberEventInvoker: cancelled");
-          }
-        }
-        else {
-          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
-        }
-        break;
-      }
-    }
-  }
-  
   /**
    * This stalls waiting for the current membership view (as seen by the
    * membership manager) to be acknowledged by all membership listeners
@@ -2707,44 +2519,8 @@ public class DistributionManager
   }
 
   protected void handleMemberEvent(MemberEvent ev) {
-    try {
-      switch (ev.eventType()) {
-      case MemberEvent.MEMBER_JOINED:
-        handleJoinEvent((MemberJoinedEvent)ev);
-        break;
-      case MemberEvent.MEMBER_DEPARTED:
-        handleDepartEvent((MemberDepartedEvent)ev);
-        break;
-      case MemberEvent.MEMBER_CRASHED:
-        handleCrashEvent((MemberCrashedEvent)ev);
-        break;
-      case MemberEvent.MEMBER_SUSPECT:
-        handleSuspectEvent((MemberSuspectEvent)ev);
-        break;
-      case MemberEvent.VIEW_INSTALLED:
-        // we're done processing events for a view
-        handleViewInstalledEvent((ViewInstalledEvent)ev);
-        break;
-      case MemberEvent.QUORUM_LOST:
-        handleQuorumLostEvent((QuorumLostEvent)ev);
-        break;
-      default:
-        logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNKNOWN_TYPE_OF_MEMBERSHIP_EVENT_RECEIVED_0, ev));
-        break;
-      }
-    }
-    catch (CancelException ex) {
-      // bug 37198...don't print a stack trace
-      logger.debug("Cancellation while calling membership listener for event <{}>: {}", ev, ex.getMessage(), ex);
-      
-      // ...and kill the caller...
-      throw ex;
-    }
-    catch (RuntimeException ex) {
-      logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_EXCEPTION_WHILE_CALLING_MEMBERSHIP_LISTENER_FOR_EVENT__0, ev), ex);
-    }
+    ev.handleEvent(this);
   }
-  
 
   /**
    * This thread processes member events as they occur.
@@ -4766,12 +4542,6 @@ public class DistributionManager
   
  
   private static abstract class MemberEvent  {
-    static final int MEMBER_JOINED = 0;
-    static final int MEMBER_DEPARTED = 1;
-    static final int MEMBER_CRASHED = 2;
-    static final int MEMBER_SUSPECT = 3;
-    static final int VIEW_INSTALLED = 4;
-    static final int QUORUM_LOST = 5;
     
     private InternalDistributedMember id;
     MemberEvent(InternalDistributedMember id) {
@@ -4780,9 +4550,45 @@ public class DistributionManager
     public InternalDistributedMember getId() {
       return this.id;
     }
-    /** return the type of event: MEMBER_JOINED, MEMBER_DEPARTED, etc */
-    public abstract int eventType();
-  }
+
+    public void handleEvent(DistributionManager manager) {
+      handleEvent(manager, manager.membershipListeners.keySet());
+      handleEvent(manager, manager.allMembershipListeners);
+    }
+
+    protected abstract void handleEvent(MembershipListener listener);
+
+    protected void handleEvent(DistributionManager manager, Set<MembershipListener> membershipListeners) {
+      for (MembershipListener listener : membershipListeners) {
+        try {
+          handleEvent(listener);
+        } catch (CancelException e) {
+          if (manager.isCloseInProgress()) {
+            if (logger.isTraceEnabled()) {
+              logger.trace("MemberEventInvoker: cancelled");
+            }
+          }
+          else {
+            logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_UNEXPECTED_CANCELLATION), e);
+          }
+          break;
+        } catch (VirtualMachineError err) {
+          SystemFailure.initiateFailure(err);
+          // If this ever returns, rethrow the error.  We're poisoned
+          // now, so don't let this thread continue.
+          throw err;
+        } catch (Throwable t) {
+          // Whenever you catch Error or Throwable, you must also
+          // catch VirtualMachineError (see above).  However, there is
+          // _still_ a possibility that you are dealing with a cascading
+          // error condition, so you also need to check to see if the JVM
+          // is still usable:
+          SystemFailure.checkFailure();
+          logger.warn(LocalizedMessage.create(LocalizedStrings.DistributionManager_EXCEPTION_WHILE_CALLING_MEMBERSHIP_LISTENER_FOR_EVENT__0, this), t);
+        }
+      }
+    }
+}
   
   /**
    * This is an event reflecting that a InternalDistributedMember has joined
@@ -4800,8 +4606,8 @@ public class DistributionManager
       return "member " + getId() + " joined";
     }
     @Override
-    public int eventType() {
-      return MEMBER_JOINED;
+    protected void handleEvent(MembershipListener listener) {
+      listener.memberJoined(getId());	
     }
   }
   
@@ -4818,13 +4624,13 @@ public class DistributionManager
       reason = r;
     }
     @Override
-    public int eventType() {
-      return MEMBER_DEPARTED;
-    }
-    @Override
     public String toString() {
       return "member " + getId() + " departed (" + reason + ")";
     }
+    @Override
+    protected void handleEvent(MembershipListener listener) {
+     listener.memberDeparted(getId(), false);	
+    }
   }
   
   /**
@@ -4842,13 +4648,13 @@ public class DistributionManager
       reason = r;
     }
     @Override
-    public int eventType() {
-      return MEMBER_CRASHED;
-    }
-    @Override
     public String toString() {
       return "member " + getId() + " crashed: " + reason;
     }
+    @Override
+    protected void handleEvent(MembershipListener listener) {
+      listener.memberDeparted(getId(), true/*crashed*/);	
+    }
   }
 
   /**
@@ -4866,13 +4672,13 @@ public class DistributionManager
       return this.whoSuspected;
     }
     @Override
-    public int eventType() {
-      return MEMBER_SUSPECT;
-    }
-    @Override
     public String toString() {
       return "member " + getId() + " suspected by: " + this.whoSuspected;
     }
+    @Override
+    protected void handleEvent(MembershipListener listener) {
+      listener.memberSuspect(getId(), whoSuspected());	
+    }
   }
   
   private static final class ViewInstalledEvent extends MemberEvent {
@@ -4885,13 +4691,17 @@ public class DistributionManager
       return view.getViewNumber();
     }
     @Override
-    public int eventType() {
-      return VIEW_INSTALLED;
-    }
-    @Override
     public String toString() {
       return "view installed: " + this.view;
     }
+    @Override
+    public void handleEvent(DistributionManager manager) {
+      manager.handleViewInstalledEvent(this);
+    }
+    @Override
+    protected void handleEvent(MembershipListener listener) {
+      throw new UnsupportedOperationException();
+    }
   }
 
   private static final class QuorumLostEvent extends MemberEvent {
@@ -4910,13 +4720,13 @@ public class DistributionManager
       return this.remaining;
     }
     @Override
-    public int eventType() {
-      return QUORUM_LOST;
-    }
-    @Override
     public String toString() {
       return "quorum lost.  failures=" + failures + "; remaining=" + remaining;
     }
+    @Override
+    protected void handleEvent(MembershipListener listener) {
+      listener.quorumLost(getFailures(), getRemaining());	
+    }
   }
 
 


[03/50] [abbrv] incubator-geode git commit: GEODE-11: Pass limit to Collectors while searching

Posted by bs...@apache.org.
GEODE-11: Pass limit to Collectors while searching

User provides result limit while creating query. Query needs to relay the limit
information to CollectorManager and ResultCollector before executing search so
that the result list is trimmed.


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

Branch: refs/heads/feature/GEODE-77
Commit: b59c57d553d61689711c8e0e8532bede3a1a4322
Parents: 28a0eb8
Author: Ashvin Agrawal <as...@apache.org>
Authored: Sat Oct 17 15:24:59 2015 -0700
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Sat Oct 17 15:24:59 2015 -0700

----------------------------------------------------------------------
 .../lucene/internal/LuceneQueryFactoryImpl.java | 10 +--
 .../cache/lucene/internal/LuceneQueryImpl.java  |  7 +--
 .../TopEntriesFunctionCollector.java            |  2 +-
 .../internal/LuceneQueryImplJUnitTest.java      | 66 +++++++++++++-------
 .../distributed/LuceneFunctionJUnitTest.java    |  9 +--
 5 files changed, 51 insertions(+), 43 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b59c57d5/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
index 2a602a5..b377949 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
@@ -1,10 +1,5 @@
 package com.gemstone.gemfire.cache.lucene.internal;
 
-import java.util.HashSet;
-import java.util.Set;
-
-import org.apache.lucene.queryparser.classic.ParseException;
-
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.lucene.LuceneQuery;
@@ -34,13 +29,12 @@ public class LuceneQueryFactoryImpl implements LuceneQueryFactory {
   }
 
   @Override
-  public <K, V> LuceneQuery<K, V> create(String indexName, String regionName,
-      String queryString) {
+  public <K, V> LuceneQuery<K, V> create(String indexName, String regionName, String queryString) {
     return create(indexName, regionName, new StringQueryProvider(queryString));
   }
   
   public <K, V> LuceneQuery<K, V> create(String indexName, String regionName, LuceneQueryProvider provider) {
-    Region region = cache.getRegion(regionName);
+    Region<K, V> region = cache.getRegion(regionName);
     LuceneQueryImpl<K, V> luceneQuery = new LuceneQueryImpl<K, V>(indexName, region, provider, projectionFields, limit, pageSize);
     return luceneQuery;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b59c57d5/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
index c3e367b..222acdc 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
@@ -36,9 +36,9 @@ public class LuceneQueryImpl<K, V> implements LuceneQuery<K, V> {
 
   @Override
   public LuceneQueryResults<K, V> search() {
-    LuceneFunctionContext<TopEntriesCollector> context = new LuceneFunctionContext<>(query, indexName,
-        new TopEntriesCollectorManager());
-    TopEntriesFunctionCollector collector = new TopEntriesFunctionCollector();
+    TopEntriesCollectorManager manager = new TopEntriesCollectorManager(null, limit);
+    LuceneFunctionContext<TopEntriesCollector> context = new LuceneFunctionContext<>(query, indexName, manager, limit);
+    TopEntriesFunctionCollector collector = new TopEntriesFunctionCollector(context);
 
     ResultCollector<TopEntriesCollector, TopEntries> rc = (ResultCollector<TopEntriesCollector, TopEntries>) FunctionService.onRegion(region)
         .withArgs(context)
@@ -65,5 +65,4 @@ public class LuceneQueryImpl<K, V> implements LuceneQuery<K, V> {
   public String[] getProjectedFieldNames() {
     return this.projectedFieldNames;
   }
-  
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b59c57d5/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
index 032e136..96ec296 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/TopEntriesFunctionCollector.java
@@ -43,7 +43,7 @@ public class TopEntriesFunctionCollector implements ResultCollector<TopEntriesCo
   private TopEntriesCollector mergedResults;
 
   public TopEntriesFunctionCollector() {
-    this(null, null);
+    this(null);
   }
 
   public TopEntriesFunctionCollector(LuceneFunctionContext<TopEntriesCollector> context) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b59c57d5/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
index d3ffd19..e26ab00 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImplJUnitTest.java
@@ -1,6 +1,7 @@
 package com.gemstone.gemfire.cache.lucene.internal;
 
-import static org.junit.Assert.*;
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertTrue;
 
 import java.util.List;
 
@@ -17,62 +18,81 @@ import com.gemstone.gemfire.cache.execute.FunctionAdapter;
 import com.gemstone.gemfire.cache.execute.FunctionContext;
 import com.gemstone.gemfire.cache.execute.FunctionService;
 import com.gemstone.gemfire.cache.lucene.LuceneQueryResults;
+import com.gemstone.gemfire.cache.lucene.LuceneResultStruct;
 import com.gemstone.gemfire.cache.lucene.internal.distributed.LuceneFunction;
 import com.gemstone.gemfire.cache.lucene.internal.distributed.LuceneFunctionContext;
 import com.gemstone.gemfire.cache.lucene.internal.distributed.TopEntriesCollector;
+import com.gemstone.gemfire.cache.lucene.internal.distributed.TopEntriesCollectorManager;
+import com.gemstone.gemfire.cache.lucene.internal.repository.IndexResultCollector;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
 @Category(IntegrationTest.class)
 public class LuceneQueryImplJUnitTest {
-
+  private static int LIMIT = 123;
   private Cache cache;
   private Region<Object, Object> region;
+
   @Before
   public void createCache() {
     cache = new CacheFactory().set("mcast-port", "0").create();
     region = cache.createRegionFactory(RegionShortcut.REPLICATE).create("region");
   }
-  
+
   @After
   public void removeCache() {
     FunctionService.unregisterFunction(LuceneFunction.ID);
     cache.close();
   }
+
   @Test
   public void test() {
-    //Register a fake function to observe the function invocation
+    // Register a fake function to observe the function invocation
     FunctionService.unregisterFunction(LuceneFunction.ID);
     TestLuceneFunction function = new TestLuceneFunction();
     FunctionService.registerFunction(function);
-    
-    
+
     StringQueryProvider provider = new StringQueryProvider();
-    LuceneQueryImpl query = new LuceneQueryImpl("index", region, provider, null, 100, 20);
-    LuceneQueryResults results = query.search();
-    List nextPage = results.getNextPage();
-    assertEquals(3, nextPage.size());
-    assertEquals(.3f, results.getMaxScore(), 0.01);
+    LuceneQueryImpl<Object, Object> query = new LuceneQueryImpl<>("index", region, provider, null, LIMIT, 20);
+    LuceneQueryResults<Object, Object> results = query.search();
+
     assertTrue(function.wasInvoked);
-    
-    LuceneFunctionContext args = (LuceneFunctionContext) function.args;
-    assertEquals(provider.getQueryString(), ((StringQueryProvider) args.getQueryProvider()).getQueryString());
-    assertEquals("index", args.getIndexName());
-    assertEquals(100, args.getLimit());
+    assertEquals(2f * LIMIT, results.getMaxScore(), 0.01);
+    int resultCount = 0;
+    while (results.hasNextPage()) {
+      List<LuceneResultStruct<Object, Object>> nextPage = results.getNextPage();
+      resultCount += nextPage.size();
+      if (results.hasNextPage()) {
+        assertEquals(20, nextPage.size());
+      }
+    }
+    assertEquals(LIMIT, resultCount);
+
+    LuceneFunctionContext<? extends IndexResultCollector> funcArgs = function.args;
+    assertEquals(provider.getQueryString(), ((StringQueryProvider) funcArgs.getQueryProvider()).getQueryString());
+    assertEquals("index", funcArgs.getIndexName());
+    assertEquals(LIMIT, funcArgs.getLimit());
   }
 
   private static class TestLuceneFunction extends FunctionAdapter {
-
+    private static final long serialVersionUID = 1L;
     private boolean wasInvoked;
-    private Object args;
+    private LuceneFunctionContext<? extends IndexResultCollector> args;
 
     @Override
     public void execute(FunctionContext context) {
-      this.args = context.getArguments();
+      this.args = (LuceneFunctionContext<?>) context.getArguments();
+      TopEntriesCollectorManager manager = (TopEntriesCollectorManager) args.getCollectorManager();
+
+      assertEquals(LIMIT, manager.getLimit());
+
       wasInvoked = true;
-      TopEntriesCollector lastResult = new TopEntriesCollector();
-      lastResult.collect(3, .3f);
-      lastResult.collect(2, .2f);
-      lastResult.collect(1, .1f);
+      TopEntriesCollector lastResult = new TopEntriesCollector(null, 2 * LIMIT);
+      // put more than LIMIT entries. The resultCollector should trim the results
+      for (int i = LIMIT * 2; i >= 0; i--) {
+        lastResult.collect(i, i * 1f);
+      }
+      assertEquals(LIMIT * 2, lastResult.getEntries().getHits().size());
+
       context.getResultSender().lastResult(lastResult);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b59c57d5/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
index 431ed4c..419aa26 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionJUnitTest.java
@@ -1,6 +1,6 @@
 package com.gemstone.gemfire.cache.lucene.internal.distributed;
 
-import static org.junit.Assert.*;
+import static org.junit.Assert.assertEquals;
 
 import java.io.IOException;
 import java.util.ArrayList;
@@ -21,11 +21,9 @@ import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
 import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
 import com.gemstone.gemfire.cache.execute.ResultSender;
 import com.gemstone.gemfire.cache.lucene.LuceneQueryFactory;
 import com.gemstone.gemfire.cache.lucene.LuceneQueryProvider;
-import com.gemstone.gemfire.cache.lucene.LuceneService;
 import com.gemstone.gemfire.cache.lucene.internal.InternalLuceneIndex;
 import com.gemstone.gemfire.cache.lucene.internal.InternalLuceneService;
 import com.gemstone.gemfire.cache.lucene.internal.StringQueryProvider;
@@ -36,7 +34,6 @@ import com.gemstone.gemfire.cache.query.QueryException;
 import com.gemstone.gemfire.internal.cache.BucketNotFoundException;
 import com.gemstone.gemfire.internal.cache.InternalCache;
 import com.gemstone.gemfire.internal.cache.execute.InternalRegionFunctionContext;
-import com.gemstone.gemfire.internal.cache.extension.ExtensionPoint;
 import com.gemstone.gemfire.test.junit.categories.UnitTest;
 
 @Category(UnitTest.class)
@@ -63,7 +60,7 @@ public class LuceneFunctionJUnitTest {
   InternalLuceneIndex mockIndex;
 
   ArrayList<IndexRepository> repos;
-  LuceneFunctionContext searchArgs;
+  LuceneFunctionContext<IndexResultCollector> searchArgs;
   LuceneQueryProvider queryProvider;
   Query query;
 
@@ -381,7 +378,6 @@ public class LuceneFunctionJUnitTest {
     
     searchArgs = new LuceneFunctionContext<IndexResultCollector>(queryProvider, "indexName");
     
-    final ExtensionPoint mockExtensionPoint = mocker.mock(ExtensionPoint.class);
     mocker.checking(new Expectations() {{
       allowing(mockRegion).getCache();
       will(returnValue(mockCache));
@@ -395,7 +391,6 @@ public class LuceneFunctionJUnitTest {
       will(returnValue(mockRepoManager));
       allowing(mockIndex).getFieldNames();
       will(returnValue(new String[] {"gemfire"}));
-      
     }});
     
     query = queryProvider.getQuery(mockIndex);


[15/50] [abbrv] incubator-geode git commit: Merge commit 'refs/pull/30/head' of https://github.com/apache/incubator-geode into develop

Posted by bs...@apache.org.
Merge commit 'refs/pull/30/head' of https://github.com/apache/incubator-geode into develop


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

Branch: refs/heads/feature/GEODE-77
Commit: 8fe291010f7b97f8a28f30c0c4929d09abef7d39
Parents: 1b8a357 66d9da6
Author: Dan Smith <up...@apache.org>
Authored: Fri Nov 6 09:24:42 2015 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Fri Nov 6 09:24:42 2015 -0800

----------------------------------------------------------------------
 .../gemfire/internal/i18n/BasicI18nJUnitTest.java       | 12 ------------
 1 file changed, 12 deletions(-)
----------------------------------------------------------------------



[31/50] [abbrv] incubator-geode git commit: GEODE-541: The latest GemFire 800x clients can't connect to Geode servers

Posted by bs...@apache.org.
GEODE-541: The latest GemFire 800x clients can't connect to Geode servers


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

Branch: refs/heads/feature/GEODE-77
Commit: 79aa0be5fe4b5efb2526a76f960ef96a4294e862
Parents: 7dc4b2d
Author: Barry Oglesby <bo...@pivotal.io>
Authored: Mon Nov 2 17:42:43 2015 -0800
Committer: Barry Oglesby <bo...@pivotal.io>
Committed: Tue Nov 10 17:14:52 2015 -0800

----------------------------------------------------------------------
 .../src/main/java/com/gemstone/gemfire/internal/Version.java    | 5 +++++
 .../gemfire/internal/cache/tier/sockets/CommandInitializer.java | 4 ++++
 .../internal/cache/tier/sockets/command/ExecuteFunction66.java  | 2 +-
 .../cache/tier/sockets/command/ExecuteRegionFunction66.java     | 2 +-
 .../tier/sockets/command/ExecuteRegionFunctionSingleHop.java    | 2 +-
 5 files changed, 12 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/79aa0be5/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
index 936ae79..8726ba8 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
@@ -175,6 +175,11 @@ public final class Version implements Comparable<Version> {
   
   // 31-34 available for 8.0.x variants
   
+  private static final byte GFE_8009_ORDINAL = 31;
+
+  public static final Version GFE_8009 = new Version("GFE", "8.0.0.9", (byte)8,
+      (byte)0, (byte)0, (byte)9, GFE_8009_ORDINAL);
+
   private static final byte GFE_81_ORDINAL = 35;
 
   public static final Version GFE_81 = new Version("GFE", "8.1", (byte)8,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/79aa0be5/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
index 7e49d7a..26ed47b 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
@@ -301,6 +301,10 @@ public class CommandInitializer {
     gfe80Commands.put(MessageType.PUTALL, PutAll80.getCommand());
     ALL_COMMANDS.put(Version.GFE_80, gfe80Commands);
 
+    Map<Integer, Command> gfe8009Commands = new HashMap<Integer, Command>();
+    gfe8009Commands.putAll(ALL_COMMANDS.get(Version.GFE_80));
+    ALL_COMMANDS.put(Version.GFE_8009, gfe8009Commands);
+
     {
       Map<Integer, Command> gfe81Commands = new HashMap<Integer, Command>();
       gfe81Commands.putAll(ALL_COMMANDS.get(Version.GFE_80));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/79aa0be5/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
index 3baac92..9160c11 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
@@ -108,7 +108,7 @@ public class ExecuteFunction66 extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/79aa0be5/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
index 329332b..6d9ca49 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
@@ -90,7 +90,7 @@ public class ExecuteRegionFunction66 extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
       if (functionState != 1) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/79aa0be5/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
index 1c18cb1..15b01fc 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
@@ -88,7 +88,7 @@ public class ExecuteRegionFunctionSingleHop extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
       if(functionState != 1) {


[21/50] [abbrv] incubator-geode git commit: GEODE-11: Mark Lucene API as experimental

Posted by bs...@apache.org.
GEODE-11: Mark Lucene API as experimental


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

Branch: refs/heads/feature/GEODE-77
Commit: 3e87134eb5aeee6514286727c294cef87fdbf6ee
Parents: afa0a6e
Author: Ashvin Agrawal <as...@apache.org>
Authored: Sun Nov 8 21:37:25 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Sun Nov 8 21:37:25 2015 -0800

----------------------------------------------------------------------
 gemfire-lucene/build.gradle                                     | 2 ++
 .../java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java     | 4 +++-
 .../java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java     | 3 +++
 .../com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java   | 4 +++-
 .../com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java  | 2 ++
 .../com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java   | 5 +++--
 .../com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java   | 3 ++-
 .../java/com/gemstone/gemfire/cache/lucene/LuceneService.java   | 5 ++---
 .../gemstone/gemfire/cache/lucene/LuceneServiceProvider.java    | 2 ++
 .../cache/lucene/internal/distributed/CollectorManager.java     | 2 ++
 .../cache/lucene/internal/repository/IndexResultCollector.java  | 3 +++
 11 files changed, 27 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-lucene/build.gradle b/gemfire-lucene/build.gradle
index 3303a69..40313c5 100644
--- a/gemfire-lucene/build.gradle
+++ b/gemfire-lucene/build.gradle
@@ -1,5 +1,7 @@
 dependencies {
     provided project(':gemfire-core')
+    provided project(':gemfire-common')
+
     compile 'org.apache.lucene:lucene-analyzers-common:5.3.0'
     compile 'org.apache.lucene:lucene-core:5.3.0'
     compile 'org.apache.lucene:lucene-queries:5.3.0'

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
index 49b74b1..11c4e95 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneIndex.java
@@ -21,6 +21,8 @@ import java.util.Map;
 
 import org.apache.lucene.analysis.Analyzer;
 
+import com.gemstone.gemfire.annotations.Experimental;
+
 
 /**
  * An lucene index is built over the data stored in a GemFire Region.
@@ -31,8 +33,8 @@ import org.apache.lucene.analysis.Analyzer;
  * <p>
  * 
  * @author Xiaojian Zhou
- * @since 8.5
  */
+@Experimental
 public interface LuceneIndex {
 
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
index e10b686..2de9c0b 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
@@ -16,12 +16,15 @@
  */
 package com.gemstone.gemfire.cache.lucene;
 
+import com.gemstone.gemfire.annotations.Experimental;
+
 /**
  * Provides wrapper object of Lucene's Query object and execute the search. 
  * <p>Instances of this interface are created using
  * {@link LuceneQueryFactory#create}.
  * 
  */
+@Experimental
 public interface LuceneQuery<K, V> {
   /**
    * Execute the search and get results. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
index 6604926..b707c52 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
@@ -18,6 +18,8 @@ package com.gemstone.gemfire.cache.lucene;
 
 import org.apache.lucene.queryparser.classic.ParseException;
 
+import com.gemstone.gemfire.annotations.Experimental;
+
 /**
  * Factory for creating instances of {@link LuceneQuery}.
  * To get an instance of this factory call {@link LuceneService#createLuceneQueryFactory}.
@@ -26,8 +28,8 @@ import org.apache.lucene.queryparser.classic.ParseException;
  * call {@link #create} to produce a {@link LuceneQuery} instance.
  * 
  * @author Xiaojian Zhou
- * @since 8.5
  */
+@Experimental
 public interface LuceneQueryFactory {
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
index cad9095..82f486c 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryProvider.java
@@ -4,6 +4,7 @@ import java.io.Serializable;
 
 import org.apache.lucene.search.Query;
 
+import com.gemstone.gemfire.annotations.Experimental;
 import com.gemstone.gemfire.cache.query.QueryException;
 
 /**
@@ -14,6 +15,7 @@ import com.gemstone.gemfire.cache.query.QueryException;
  * distributed system. Implementation of DataSerializable can provide a zero-argument constructor that will be invoked
  * when they are read with DataSerializer.readObject.
  */
+@Experimental
 public interface LuceneQueryProvider extends Serializable {
   /**
    * @return A Lucene Query object which could be used for executing Lucene Search on indexed data

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
index 62aada2..cdc8b10 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
@@ -2,17 +2,18 @@ package com.gemstone.gemfire.cache.lucene;
 
 import java.util.List;
 
+import com.gemstone.gemfire.annotations.Experimental;
+
 /**
  * <p>
  * Defines the interface for a container of lucene query result collected from function execution.<br>
  * 
  * @author Xiaojian Zhou
- * @since 8.5
  * 
  * @param <K> The type of the key
  * @param <V> The type of the value
  */
-
+@Experimental
 public interface LuceneQueryResults<K, V> {
   /**
    * @return total number of hits for this query

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
index 1cf3c7c..f904d93 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
@@ -16,14 +16,15 @@
  */
 package com.gemstone.gemfire.cache.lucene;
 
+import com.gemstone.gemfire.annotations.Experimental;
 
 /**
  * <p>
  * Abstract data structure for one item in query result.
  * 
  * @author Xiaojian Zhou
- * @since 8.5
  */
+@Experimental
 public interface LuceneResultStruct<K, V> {
   /**
    * Return the value associated with the given field name

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
index 6bbb4fd..fbd6dad 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
@@ -21,10 +21,8 @@ import java.util.Map;
 
 import org.apache.lucene.analysis.Analyzer;
 
-import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.annotations.Experimental;
 import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.lucene.internal.LuceneServiceImpl;
-import com.gemstone.gemfire.internal.cache.extension.Extensible;
 
 /**
  * LuceneService instance is a singleton for each cache. It will be created in cache 
@@ -70,6 +68,7 @@ import com.gemstone.gemfire.internal.cache.extension.Extensible;
  * @author Xiaojian Zhou
  *
  */
+@Experimental
 public interface LuceneService {
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
index 35427ae..72ec554 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
@@ -1,5 +1,6 @@
 package com.gemstone.gemfire.cache.lucene;
 
+import com.gemstone.gemfire.annotations.Experimental;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.lucene.internal.InternalLuceneService;
 import com.gemstone.gemfire.internal.cache.InternalCache;
@@ -9,6 +10,7 @@ import com.gemstone.gemfire.internal.cache.InternalCache;
  * instance of the LuceneService.
  *
  */
+@Experimental
 public class LuceneServiceProvider {
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
index 41c3f5f..904a47e 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/distributed/CollectorManager.java
@@ -3,6 +3,7 @@ package com.gemstone.gemfire.cache.lucene.internal.distributed;
 import java.io.IOException;
 import java.util.Collection;
 
+import com.gemstone.gemfire.annotations.Experimental;
 import com.gemstone.gemfire.cache.lucene.internal.repository.IndexRepository;
 import com.gemstone.gemfire.cache.lucene.internal.repository.IndexResultCollector;
 
@@ -16,6 +17,7 @@ import com.gemstone.gemfire.cache.lucene.internal.repository.IndexResultCollecto
  * 
  * @param <C> Type of IndexResultCollector created by this manager
  */
+@Experimental
 public interface CollectorManager<C extends IndexResultCollector> {
   /**
    * @param name Name/Identifier for this collector. For e.g. region/bucketId.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e87134e/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
index 94931a4..fa867e1 100644
--- a/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
+++ b/gemfire-lucene/src/main/java/com/gemstone/gemfire/cache/lucene/internal/repository/IndexResultCollector.java
@@ -1,9 +1,12 @@
 package com.gemstone.gemfire.cache.lucene.internal.repository;
 
+import com.gemstone.gemfire.annotations.Experimental;
+
 /**
  * Interface for collection results of a query on
  * an IndexRepository. See {@link IndexRepository#query(org.apache.lucene.search.Query, int, IndexResultCollector)}
  */
+@Experimental
 public interface IndexResultCollector {
   /**
    * @return Name/identifier of this collector


[41/50] [abbrv] incubator-geode git commit: GEODE-544: Removes soplog code and tests

Posted by bs...@apache.org.
GEODE-544: Removes soplog code and tests

The "soplog" code was a partial implementation of a concurrent
LSM tree stored on local disk. This is not currently used anywhere
so is being cleaned up.  The interfaces used by the HDFS feature
have not been deleted.


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

Branch: refs/heads/feature/GEODE-77
Commit: 9438c8b18dcbc1e903780efdeff5928be175c8b1
Parents: 781bd8d
Author: Anthony Baker <ab...@pivotal.io>
Authored: Thu Nov 12 14:39:48 2015 -0800
Committer: Anthony Baker <ab...@pivotal.io>
Committed: Thu Nov 12 21:22:48 2015 -0800

----------------------------------------------------------------------
 .../persistence/soplog/AbstractCompactor.java   | 533 -------------
 .../soplog/AbstractKeyValueIterator.java        |  76 --
 .../soplog/AbstractSortedReader.java            | 135 ----
 .../soplog/ArraySerializedComparator.java       | 144 ----
 .../cache/persistence/soplog/Compactor.java     | 174 -----
 .../soplog/CompositeSerializedComparator.java   |  57 --
 .../soplog/IndexSerializedComparator.java       | 127 ---
 .../cache/persistence/soplog/LevelTracker.java  | 120 ---
 .../soplog/LexicographicalComparator.java       | 460 -----------
 .../cache/persistence/soplog/NonCompactor.java  | 110 ---
 .../soplog/ReversingSerializedComparator.java   |  67 --
 .../persistence/soplog/SizeTieredCompactor.java | 198 -----
 .../cache/persistence/soplog/SoplogToken.java   | 116 ---
 .../cache/persistence/soplog/SortedBuffer.java  | 367 ---------
 .../cache/persistence/soplog/SortedOplog.java   | 158 ----
 .../persistence/soplog/SortedOplogFactory.java  | 278 -------
 .../persistence/soplog/SortedOplogSet.java      | 118 ---
 .../persistence/soplog/SortedOplogSetImpl.java  | 780 -------------------
 .../soplog/hfile/BlockCacheHolder.java          |  39 -
 .../soplog/hfile/HFileSortedOplog.java          | 694 -----------------
 .../soplog/hfile/HFileSortedOplogFactory.java   |  80 --
 .../soplog/nofile/NoFileSortedOplog.java        | 244 ------
 .../soplog/nofile/NoFileSortedOplogFactory.java |  41 -
 .../cache/persistence/soplog/AppendLog.java     |  65 --
 .../ArraySerializedComparatorJUnitTest.java     |  95 ---
 .../CompactionSortedOplogSetTestCase.java       | 134 ----
 .../persistence/soplog/CompactionTestCase.java  | 206 -----
 .../persistence/soplog/ComparisonTestCase.java  |  77 --
 .../soplog/IndexComparatorJUnitTest.java        |  79 --
 .../LexicographicalComparatorJUnitTest.java     | 204 -----
 .../soplog/RecoverableSortedOplogSet.java       | 221 ------
 .../soplog/SizeTieredCompactorJUnitTest.java    | 110 ---
 .../SizeTieredSortedOplogSetJUnitTest.java      |  43 -
 .../soplog/SortedBufferJUnitTest.java           |  39 -
 .../soplog/SortedOplogSetJUnitTest.java         | 273 -------
 .../soplog/SortedReaderTestCase.java            | 295 -------
 .../nofile/NoFileSortedOplogJUnitTest.java      |  48 --
 37 files changed, 7005 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractCompactor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractCompactor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractCompactor.java
deleted file mode 100644
index 0b62313..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractCompactor.java
+++ /dev/null
@@ -1,533 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.io.InterruptedIOException;
-import java.nio.ByteBuffer;
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.EnumMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Queue;
-import java.util.concurrent.ConcurrentLinkedQueue;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.Executor;
-import java.util.concurrent.atomic.AtomicBoolean;
-import java.util.concurrent.atomic.AtomicReference;
-import java.util.concurrent.locks.ReadWriteLock;
-import java.util.concurrent.locks.ReentrantReadWriteLock;
-
-import org.apache.logging.log4j.Logger;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogReader;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogWriter;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogSetImpl.MergedIterator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.Metadata;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedIterator;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.util.AbortableTaskService;
-import com.gemstone.gemfire.internal.util.AbortableTaskService.AbortableTask;
-
-public abstract class AbstractCompactor<T extends Comparable<T>> implements Compactor {
-  protected static final Logger logger = LogService.getLogger();
-  
-  /** the soplog factory */
-  protected final SortedOplogFactory factory;
-  
-  /** the fileset */
-  protected final Fileset<T> fileset;
-  
-  /** the soplog tracker */
-  protected final CompactionTracker<T> tracker;
-
-  /** thread for background compaction */
-  protected final AbortableTaskService compactor;
-  
-  /** inactive files waiting to be deleted */
-  private final Queue<TrackedReference<SortedOplogReader>> inactive;
-  
-  /** the soplogs */
-  protected final List<Level> levels;
-  
-  /** provides consistent view of all levels */
-  private final ReadWriteLock levelLock;
-
-  /** test flag to abort compaction */
-  volatile boolean testAbortDuringCompaction;
-  
-  /** test flag to delay compaction */
-  volatile CountDownLatch testDelayDuringCompaction;
-  
-  protected final String logPrefix;
-  
-  public AbstractCompactor(SortedOplogFactory factory, 
-      Fileset<T> fileset, CompactionTracker<T> tracker,
-      Executor exec) {
-    assert factory != null;
-    assert fileset != null;
-    assert tracker != null;
-    assert exec != null;
-    
-    this.factory = factory;
-    this.fileset = fileset;
-    this.tracker = tracker;
-    
-    compactor = new AbortableTaskService(exec);
-    inactive = new ConcurrentLinkedQueue<TrackedReference<SortedOplogReader>>();
-
-    levelLock = new ReentrantReadWriteLock();
-    levels = new ArrayList<Level>();
-    
-    this.logPrefix = "<" + factory.getConfiguration().getName() + "> ";
-  }
-  
-  @Override
-  public final void add(SortedOplog soplog) throws IOException {
-    levels.get(0).add(soplog);
-  }
-  
-  @Override
-  public final boolean compact() throws IOException {
-    final CountDownLatch done = new CountDownLatch(1);
-    final AtomicReference<Object> result = new AtomicReference<Object>(null);
-    
-    compact(true, new CompactionHandler() {
-      @Override
-      public void complete(boolean compacted) {
-        result.set(compacted);
-        done.countDown();
-      }
-
-      @Override
-      public void failed(Throwable ex) {
-        result.set(ex);
-        done.countDown();
-      }
-    });
-    
-    try {
-      done.await();
-    } catch (InterruptedException e) {
-      Thread.currentThread().interrupt();
-      throw new InterruptedIOException();
-    }
-    
-    Object val = result.get();
-    if (val instanceof Throwable) {
-      throw new IOException((Throwable) val);
-    }
-    
-    assert val != null;
-    return (Boolean) val;
-  }
-  
-  @Override
-  public final void compact(final boolean force, final CompactionHandler ch) {
-    // TODO implement force=true, results in a single soplog
-    AbortableTask task = new AbortableTask() {
-      @Override
-      public void runOrAbort(AtomicBoolean aborted) {
-        final boolean isDebugEnabled = logger.isDebugEnabled();
-        if (isDebugEnabled) {
-          logger.debug("{}Beginning compaction", AbstractCompactor.this.logPrefix);
-        }
-
-        // TODO could do this in one go instead of level-by-level
-        try {
-          boolean compacted = false;
-          for (Level level : levels) {
-            if (aborted.get()) {
-              if (isDebugEnabled) {
-                logger.debug("{}Aborting compaction", AbstractCompactor.this.logPrefix);
-              }
-              break;
-            }
-      
-            checkTestDelay();
-            if (force || level.needsCompaction()) {
-              if (isDebugEnabled) {
-                logger.debug("{}Compacting level {}", AbstractCompactor.this.logPrefix, level);
-              }
-              
-              long start = factory.getConfiguration().getStatistics().getMinorCompaction().begin();
-              try {
-                compacted |= level.compact(aborted);
-                factory.getConfiguration().getStatistics().getMinorCompaction().end(start);
-                
-              } catch (IOException e) {
-                factory.getConfiguration().getStatistics().getMinorCompaction().error(start);
-              }
-            }
-          }
-          
-          cleanupInactive();
-          if (ch != null) {
-            if (isDebugEnabled) {
-              logger.debug("{}Completed compaction", AbstractCompactor.this.logPrefix);
-            }
-            ch.complete(compacted);
-          }
-        } catch (Exception e) {
-          if (isDebugEnabled) {
-            logger.debug("{}Encountered an error during compaction", AbstractCompactor.this.logPrefix, e);
-          }
-          if (ch != null) {
-            ch.failed(e);
-          }
-        }
-      }
-      
-      @Override
-      public void abortBeforeRun() {
-        if (ch != null) {
-          ch.complete(false);
-        }
-      }
-    };
-    compactor.execute(task);
-  }
-  
-  @Override
-  public final CompactionTracker<?> getTracker() {
-    return tracker;
-  }
-
-  @Override
-  public final Fileset<?> getFileset() {
-    return fileset;
-  }
-  
-  @Override
-  public final Collection<TrackedReference<SortedOplogReader>> getActiveReaders(
-      byte[] start, byte[] end) {
-    
-    // need to coordinate with clear() so we can get a consistent snapshot
-    // across levels
-    levelLock.readLock().lock();
-    try {
-      // TODO this seems very garbage-y
-      List<TrackedReference<SortedOplogReader>> soplogs = new ArrayList<TrackedReference<SortedOplogReader>>();
-      for (Level level : levels) {
-        soplogs.addAll(level.getSnapshot(start, end));
-      }
-      return soplogs;
-    } finally {
-      levelLock.readLock().unlock();
-    }
-  }
-  
-  @Override
-  public final void clear() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Clearing compactor", this.logPrefix);
-    }
-    
-    compactor.abortAll();
-    releaseTestDelay();
-    compactor.waitForCompletion();
-
-    levelLock.writeLock().lock();
-    try {
-      for (Level l : levels) {
-        l.clear();
-      }
-    } finally {
-      levelLock.writeLock().unlock();
-    }
-    
-    cleanupInactive();
-  }
-
-  @Override
-  public final void close() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Closing compactor", this.logPrefix);
-    }
-
-    compactor.abortAll();
-    releaseTestDelay();
-    compactor.waitForCompletion();
-    
-    levelLock.writeLock().lock();
-    try {
-      for (Level l : levels) {
-        l.close();
-      }
-    } finally {
-      levelLock.writeLock().unlock();
-    }
-    
-    TrackedReference<SortedOplogReader> tr;
-    while ((tr = inactive.poll()) != null) {
-      deleteInactive(tr);
-    }
-    inactive.clear();
-  }
-  
-  /**
-   * Creates a new soplog by merging the supplied soplog readers.
-   * 
-   * @param readers the readers to merge
-   * @param collect true if deleted entries should be removed
-   * @return the merged soplog
-   * 
-   * @throws IOException error during merge operation
-   */
-  protected SortedOplog merge(
-      Collection<TrackedReference<SortedOplogReader>> readers, 
-      boolean collect,
-      AtomicBoolean aborted) throws IOException {
-    
-    SerializedComparator sc = null;
-    List<SortedIterator<ByteBuffer>> iters = new ArrayList<SortedIterator<ByteBuffer>>();
-    for (TrackedReference<SortedOplogReader> tr : readers) {
-      iters.add(tr.get().scan());
-      sc = tr.get().getComparator();
-    }
-    
-    SortedIterator<ByteBuffer> scan = new MergedIterator(sc, readers, iters);
-    try {
-      if (!scan.hasNext()) {
-        checkAbort(aborted);
-        if (logger.isDebugEnabled()) {
-          logger.debug("{}No entries left after compaction with readers {} ", this.logPrefix, readers);
-        }
-        return null;
-      }
-
-      File f = fileset.getNextFilename();
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Compacting soplogs {} into {}", this.logPrefix, readers, f);
-      }
-
-      if (testAbortDuringCompaction) {
-        aborted.set(true);
-      }
-
-      SortedOplog soplog = factory.createSortedOplog(f);
-      SortedOplogWriter wtr = soplog.createWriter();
-      try {
-        while (scan.hasNext()) {
-          checkAbort(aborted);
-          scan.next();
-          if (!(collect && isDeleted(scan.value()))) {
-            wtr.append(scan.key(), scan.value());
-          }
-        }
-
-        EnumMap<Metadata, byte[]> metadata = mergeMetadata(readers);
-        wtr.close(metadata);
-        return soplog;
-        
-      } catch (IOException e) {
-        wtr.closeAndDelete();
-        throw e;
-      }
-    } finally {
-      scan.close();
-    }
-  }
-  
-  protected EnumMap<Metadata, byte[]> mergeMetadata(
-      Collection<TrackedReference<SortedOplogReader>> readers)
-      throws IOException {
-    // merge the metadata into the compacted file
-    EnumMap<Metadata, byte[]> metadata = new EnumMap<Metadata, byte[]>(Metadata.class);
-    for (Metadata meta : Metadata.values()) {
-      byte[] val = null;
-      for (TrackedReference<SortedOplogReader> tr : readers) {
-        byte[] tmp = tr.get().getMetadata(meta);
-        if (val == null) {
-          val = tmp;
-          
-        } else if (tmp != null) {
-          val = factory.getConfiguration().getMetadataCompactor(meta).compact(val, tmp);
-        }
-      }
-      if (val != null) {
-        metadata.put(meta, val);
-      }
-    }
-    return metadata;
-  }
-  
-  protected void releaseTestDelay() {
-    if (testDelayDuringCompaction != null) {
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Releasing testDelayDuringCompaction", this.logPrefix);
-      }
-      testDelayDuringCompaction.countDown();
-    }
-  }
-
-  protected void checkTestDelay() {
-    if (testDelayDuringCompaction != null) {
-      try {
-        if (logger.isDebugEnabled()) {
-          logger.debug("{}Waiting for testDelayDuringCompaction", this.logPrefix);
-        }
-        testDelayDuringCompaction.await();
-        
-      } catch (InterruptedException e) {
-        Thread.currentThread().interrupt();
-      }
-    }
-  }
-
-  
-  /**
-   * Returns the number of inactive readers.
-   * @return the inactive readers
-   */
-  protected int countInactiveReaders() {
-    return inactive.size();
-  }
-  
-  /**
-   * Returns the requested level for testing purposes.
-   * @param level the level ordinal
-   * @return the level
-   */
-  protected Level getLevel(int level) {
-    return levels.get(level);
-  }
-
-  protected void cleanupInactive() throws IOException {
-    for (Iterator<TrackedReference<SortedOplogReader>> iter = inactive.iterator(); iter.hasNext(); ) {
-      TrackedReference<SortedOplogReader> tr = iter.next();
-      if (!tr.inUse() && inactive.remove(tr)) {
-        deleteInactive(tr);
-      }
-    }
-  }
-
-  protected void markAsInactive(Iterable<TrackedReference<SortedOplogReader>> snapshot, T attach) throws IOException {
-    final boolean isDebugEnabled = logger.isDebugEnabled();
-    for (Iterator<TrackedReference<SortedOplogReader>> iter = snapshot.iterator(); iter.hasNext(); ) {
-      TrackedReference<SortedOplogReader> tr = iter.next();
-      if (isDebugEnabled) {
-        logger.debug("{}Marking {} as inactive", this.logPrefix, tr);
-      }
-      
-      inactive.add(tr);
-      tracker.fileRemoved(tr.get().getFile(), attach);
-      
-      factory.getConfiguration().getStatistics().incActiveFiles(-1);
-      factory.getConfiguration().getStatistics().incInactiveFiles(1);
-    }
-  }
-
-  private boolean isDeleted(ByteBuffer value) {
-    //first byte determines the value type
-    byte valType = value.get(value.position());
-    return SoplogToken.isTombstone(valType) || SoplogToken.isRemovedPhase2(valType);
-  }
-  
-  private void checkAbort(AtomicBoolean aborted)
-      throws InterruptedIOException {
-    if (aborted.get()) {
-      throw new InterruptedIOException();
-    }
-  }
-
-  private void deleteInactive(TrackedReference<SortedOplogReader> tr)
-      throws IOException {
-    tr.get().close();
-    if (tr.get().getFile().delete()) {
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Deleted inactive soplog {}", this.logPrefix, tr.get().getFile());
-      }
-      
-      tracker.fileDeleted(tr.get().getFile());
-      factory.getConfiguration().getStatistics().incInactiveFiles(-1);
-    }
-  }
-  
-  /**
-   * Organizes a set of soplogs for a given level.
-   */
-  protected static abstract class Level {
-    /** the level ordinal position */
-    protected final int level;
-    
-    public Level(int level) {
-      this.level = level;
-    }
-    
-    @Override
-    public String toString() {
-      return String.valueOf(level);
-    }
-    
-    /**
-     * Returns true if the level needs compaction.
-     * @return true if compaction is needed
-     */
-    protected abstract boolean needsCompaction();
-
-    /**
-     * Obtains the current set of active soplogs for this level.
-     * @return the soplog snapshot
-     */
-    protected List<TrackedReference<SortedOplogReader>> getSnapshot() {
-      return getSnapshot(null, null);
-    }
-
-    /**
-     * Obtains the current set of active soplogs for this level, optionally 
-     * bounded by the start and end keys.
-     * 
-     * @param start the start key
-     * @param end the end key
-     * @return the soplog snapshot
-     */
-    protected abstract List<TrackedReference<SortedOplogReader>> getSnapshot(byte[] start, byte[] end);
-    
-    /**
-     * Clears the soplogs that match the metadata filter.
-     * @throws IOException error during close
-     */
-    protected abstract void clear() throws IOException;
-    
-    /**
-     * Closes the soplogs managed by this level.
-     * @throws IOException error closing soplogs
-     */
-    protected abstract void close() throws IOException;
-    
-    /**
-     * Adds a new soplog to this level.
-     * 
-     * @param soplog the soplog
-     * @throws IOException error creating reader
-     */
-    protected abstract void add(SortedOplog soplog) throws IOException;
-    
-    /**
-     * Merges the current soplogs into a new soplog and promotes it to the next
-     * level.  The previous soplogs are marked for deletion.
-     * 
-     * @param aborted true if the compaction should be aborted
-     * @throws IOException error unable to perform compaction
-     */
-    protected abstract boolean compact(AtomicBoolean aborted) throws IOException;    
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractKeyValueIterator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractKeyValueIterator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractKeyValueIterator.java
deleted file mode 100644
index 1326d5c..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractKeyValueIterator.java
+++ /dev/null
@@ -1,76 +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.persistence.soplog;
-
-import java.util.Iterator;
-import java.util.NoSuchElementException;
-
-/**
- * Provides an {@link Iterator} view over a collection of keys and values.  The
- * implementor must provide access to the current key/value as well as a means
- * to move to the next pair.
- * 
- * @author bakera
- *
- * @param <K> the key type
- * @param <V> the value type
- */
-public abstract class AbstractKeyValueIterator<K, V> implements KeyValueIterator<K, V> {
-  /** true if the iterator has been advanced to the next element */
-  private boolean foundNext = false;
-  
-  @Override
-  public boolean hasNext() {
-    if (!foundNext) {
-      foundNext = step();
-    }
-    return foundNext;
-  }
-
-  @Override
-  public K next() {
-    if (!foundNext && !step()) {
-      throw new NoSuchElementException();
-    }
-
-    foundNext = false;
-    return key();
-  }
-  
-  @Override
-  public void remove() {
-    throw new UnsupportedOperationException();
-  }
-  
-  /**
-   * Returns the key at the current position.
-   * @return the key
-   */
-  public abstract K key();
-  
-  /**
-   * Returns the value at the current position.
-   * @return the value
-   */
-  public abstract V value();
-  
-  /**
-   * Steps the iteration to the next position.
-   * @return true if the step succeeded
-   */
-  protected abstract boolean step();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractSortedReader.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractSortedReader.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractSortedReader.java
deleted file mode 100644
index c11e1e0..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AbstractSortedReader.java
+++ /dev/null
@@ -1,135 +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.persistence.soplog;
-
-import java.io.IOException;
-import java.nio.ByteBuffer;
-
-
-/**
- * Provides default behavior for range scans.
- *  
- * @author bakera
- */
-public abstract class AbstractSortedReader implements SortedReader<ByteBuffer> {
-  @Override
-  public final SortedIterator<ByteBuffer> scan() throws IOException {
-    return scan(null, true, null, true);
-  }
-
-  @Override
-  public final SortedIterator<ByteBuffer> head(byte[] to, boolean inclusive)  throws IOException{
-    return scan(null, true, to, inclusive);
-  }
-
-  @Override
-  public final SortedIterator<ByteBuffer> tail(byte[] from, boolean inclusive)  throws IOException{
-    return scan(from, inclusive, null, true);
-  }
-
-  @Override
-  public final SortedIterator<ByteBuffer> scan(byte[] from, byte[] to)  throws IOException{
-    return scan(from, true, to, false);
-  }
-
-  @Override
-  public final SortedIterator<ByteBuffer> scan(byte[] equalTo)  throws IOException{
-    return scan(equalTo, true, equalTo, true);
-  }
-
-  @Override
-  public SortedIterator<ByteBuffer> scan(byte[] from, boolean fromInclusive, byte[] to,
-      boolean toInclusive)  throws IOException{
-    return scan(from, fromInclusive, to, toInclusive, true, null);
-  }
-
-  @Override
-  public final SortedReader<ByteBuffer> withAscending(boolean ascending) {
-    if (this instanceof DelegateSortedReader) {
-      DelegateSortedReader tmp = (DelegateSortedReader) this;
-      return new DelegateSortedReader(tmp.delegate, ascending, tmp.filter);
-    }
-    return new DelegateSortedReader(this, ascending, null);
-  }
-
-  @Override
-  public final SortedReader<ByteBuffer> withFilter(MetadataFilter filter) {
-    if (this instanceof DelegateSortedReader) {
-      DelegateSortedReader tmp = (DelegateSortedReader) this;
-      return new DelegateSortedReader(tmp.delegate, tmp.ascending, filter);
-    }
-    return new DelegateSortedReader(this, true, filter);
-  }
-  
-  protected class DelegateSortedReader extends AbstractSortedReader {
-    /** the embedded reader */
-    private final AbstractSortedReader delegate;
-    
-    /** true if ascending */
-    private final boolean ascending;
-    
-    /** the filter */
-    private final MetadataFilter filter;
-    
-    public DelegateSortedReader(AbstractSortedReader reader, boolean ascending, MetadataFilter filter) {
-      this.delegate = reader;
-      this.ascending = ascending;
-      this.filter = filter;
-    }
-    
-    @Override
-    public boolean mightContain(byte[] key) throws IOException {
-      return delegate.mightContain(key);
-    }
-
-    @Override
-    public ByteBuffer read(byte[] key) throws IOException {
-      return delegate.read(key);
-    }
-
-    @Override
-    public SerializedComparator getComparator() {
-      return delegate.getComparator();
-    }
-
-    @Override
-    public SortedStatistics getStatistics() throws IOException {
-      return delegate.getStatistics();
-    }
-
-    @Override
-    public void close() throws IOException {
-      delegate.close();
-    }
-
-    @Override
-    public SortedIterator<ByteBuffer> scan(
-        byte[] from, boolean fromInclusive, 
-        byte[] to, boolean toInclusive) throws IOException {
-      return scan(from, fromInclusive, to, toInclusive, ascending, filter);
-    }
-
-    @Override
-    public SortedIterator<ByteBuffer> scan(
-        byte[] from, boolean fromInclusive,
-        byte[] to, boolean toInclusive, 
-        boolean ascending, 
-        MetadataFilter filter) throws IOException {
-      return delegate.scan(from, fromInclusive, to, toInclusive, ascending, filter);
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparator.java
deleted file mode 100644
index 139b3cb..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparator.java
+++ /dev/null
@@ -1,144 +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.persistence.soplog;
-
-import java.nio.ByteBuffer;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-import com.gemstone.gemfire.internal.util.Bytes;
-
-/**
- * Provides comparisons of composite keys by comparing each of the constituent
- * parts of the key in order.  A subkey will only be evaluated if the preceeding
- * keys have compared as equal.
- * <p>
- * Prior to use, an instance must be configured with the ordered list of
- * comparators to apply.
- * <p>
- * The keys for an N-composite are stored as follows:
- * <pre>
- * | len[0] | key[0] | len[1] | key[1] | ... | len[N-2] | key[N-2] | key[N-1] |
- * </pre>
- * where the key length is stored as a protobuf varint.
- * 
- * @author bakera
- */
-public class ArraySerializedComparator implements CompositeSerializedComparator, 
-DelegatingSerializedComparator {
-
-  /** the comparators */
-  private volatile SerializedComparator[] comparators;
-  
-  /**
-   * Injects the comparators to be used on composite keys.  The number and order
-   * must match the key.
-   * 
-   * @param comparators the comparators
-   */
-  public void setComparators(SerializedComparator[] comparators) {
-    this.comparators = comparators;
-  }
-  
-  @Override
-  public int compare(byte[] o1, byte[] o2) {
-    return compare(o1, 0, o1.length, o2, 0, o2.length);
-  }
-
-  @Override
-  public int compare(byte[] b1, int o1, int l1, byte[] b2, int o2, int l2) {
-    SerializedComparator[] sc = comparators;
-    
-    int off1 = o1;
-    int off2 = o2;
-    for (int i = 0; i < sc.length - 1; i++) {
-      int klen1 = Bytes.getVarInt(b1, off1);
-      int klen2 = Bytes.getVarInt(b2, off2);
-
-      off1 += Bytes.sizeofVarInt(klen1);
-      off2 += Bytes.sizeofVarInt(klen2);
-      
-      if (!SoplogToken.isWildcard(b1, off1, b2, off2)) {
-        int diff = sc[i].compare(b1, off1, klen1, b2, off2, klen2);
-        if (diff != 0) {
-          return diff;
-        }
-      }
-      off1 += klen1;
-      off2 += klen2;
-    }
-    
-    if (!SoplogToken.isWildcard(b1, off1, b2, off2)) {
-      l1 -= (off1 - o1);
-      l2 -= (off2 - o2);
-      return sc[sc.length - 1].compare(b1, off1, l1, b2, off2, l2);
-    }
-    return 0;
-  }
-
-  @Override
-  public SerializedComparator[] getComparators() {
-    return comparators;
-  }
-
-  @Override
-  public byte[] createCompositeKey(byte[] key1, byte[] key2) {
-    return createCompositeKey(new byte[][] { key1, key2 });
-  }
-  
-  @Override
-  public byte[] createCompositeKey(byte[]... keys) {
-    assert comparators.length == keys.length;
-    
-    int size = 0;
-    for (int i = 0; i < keys.length - 1; i++) {
-      size += keys[i].length + Bytes.sizeofVarInt(keys[i].length);
-    }
-    size += keys[keys.length - 1].length;
-    
-    // TODO do we have to do a copy here or can we delay until the disk write?
-    int off = 0;
-    byte[] buf = new byte[size];
-    for (int i = 0; i < keys.length - 1; i++) {
-      off = Bytes.putVarInt(keys[i].length, buf, off);
-      System.arraycopy(keys[i], 0, buf, off, keys[i].length);
-      off += keys[i].length;
-    }
-    System.arraycopy(keys[keys.length - 1], 0, buf, off, keys[keys.length - 1].length);
-    return buf;
-  }
-
-  @Override
-  public ByteBuffer getKey(ByteBuffer key, int ordinal) {
-    assert ordinal < comparators.length;
-    
-    for (int i = 0; i < comparators.length - 1; i++) {
-      int klen = Bytes.getVarInt(key);
-      if (i == ordinal) {
-        ByteBuffer subkey = (ByteBuffer) key.slice().limit(klen);
-        key.rewind();
-        
-        return subkey;
-      }
-      key.position(key.position() + klen);
-    }
-    
-    ByteBuffer subkey = key.slice();
-    key.rewind();
-    
-    return subkey;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/Compactor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/Compactor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/Compactor.java
deleted file mode 100644
index c80f118..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/Compactor.java
+++ /dev/null
@@ -1,174 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.Collection;
-import java.util.SortedMap;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogReader;
-
-/**
- * Defines a mechanism to track and compact soplogs.
- * 
- * @author bakera
- */
-public interface Compactor {
-  /**
-   * Compares metadata values.
-   */
-  public interface MetadataCompactor {
-    /**
-     * Combines two metadata values into a single value.  Used during compaction
-     * to merge metadata between soplog files.
-     * 
-     * @param metadata1 the first value
-     * @param metadata2 the second value
-     * @return the combined metadata
-     */
-    byte[] compact(byte[] metadata1, byte[] metadata2);
-  }
-
-  /**
-   * Provides notification on the status of a compaction.
-   */
-  public interface CompactionHandler {
-    /**
-     * Invoked when a compaction operation has completed successfully.
-     * @param compacted true if any files were compacted
-     */
-    void complete(boolean compacted);
-    
-    /**
-     * Invoked when a compaction operation has failed.
-     * @param ex the failure
-     */
-    void failed(Throwable ex);
-  }
-
-  /**
-   * Provides external configuration of file operations for recovering and
-   * new file creation.
-   *
-   * @param <T> the compaction info
-   */
-  public interface Fileset<T extends Comparable<T>> {
-    /**
-     * Returns the set of active soplogs.
-     * @return the active files
-     */
-    SortedMap<T, ? extends Iterable<File>> recover();
-    
-    /**
-     * Returns the pathname for the next soplog.
-     * @return the soplog filename
-     */
-    File getNextFilename();
-  }
-  
-  /**
-   * Provides a mechanism to coordinate file changes to the levels managed
-   * by the compactor.
-   * 
-   * @param T the attachment type
-   */
-  public interface CompactionTracker<T extends Comparable<T>> {
-    /**
-     * Invoked when a new file is added.
-     * @param f the file
-     * @param attach the attachment
-     */
-    void fileAdded(File f, T attach);
-    
-    /**
-     * Invoked when a file is removed.
-     * @param f the file
-     * @param attach the attachment
-     */
-    void fileRemoved(File f, T attach);
-    
-    /**
-     * Invoked when a file is deleted.
-     * @param f the attachment
-     */
-    void fileDeleted(File f);
-  }
-  
-  /**
-   * Synchronously invokes the force compaction operation and waits for completion.
-   * 
-   * @return true if any files were compacted
-   * @throws IOException error during compaction
-   */
-  boolean compact() throws IOException;
-
-  /**
-   * Requests a compaction operation be performed on the soplogs.  This invocation
-   * may block if there are too many outstanding write requests.
-   * 
-   * @param force if false, compaction will only be performed if necessary
-   * @param ch invoked when the compaction is complete, optionally null
-   * @throws IOException error during compaction
-   */
-  void compact(boolean force, CompactionHandler ch);
-  
-  /**
-   * Returns the active readers for the given key range.  The caller is responsible
-   * for decrementing the use count of each reader when finished.
-   * 
-   * @param start the start key inclusive, or null for beginning
-   * @param end the end key inclusive, or null for last
-   * @return the readers
-   * 
-   * @see TrackedReference
-   */
-  Collection<TrackedReference<SortedOplogReader>> getActiveReaders(
-      byte[] start, byte[] end);
-  
-  /**
-   * Adds a new soplog to the active set.
-   * @param soplog the soplog
-   * @throws IOException unable to add soplog 
-   */
-  void add(SortedOplog soplog) throws IOException;
-  
-  /**
-   * Returns the compaction tracker for coordinating changes to the file set.
-   * @return the tracker
-   */
-  CompactionTracker<?> getTracker();
-  
-  /**
-   * Returns the file manager for managing the soplog files.
-   * @return the fileset
-   */
-  Fileset<?> getFileset();
-  
-  /**
-   * Clears the active files managed by the compactor.  Files will be marked as
-   * inactive and eventually deleted.
-   * 
-   * @throws IOException unable to clear
-   */
-  void clear() throws IOException;
-  /**
-   * Closes the compactor.
-   * @throws IOException unable to close
-   */
-  void close() throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompositeSerializedComparator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompositeSerializedComparator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompositeSerializedComparator.java
deleted file mode 100644
index 8d9aae5..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompositeSerializedComparator.java
+++ /dev/null
@@ -1,57 +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.persistence.soplog;
-
-import java.nio.ByteBuffer;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-
-/**
- * Creates and compares composite keys.
- * 
- * @author bakera
- */
-public interface CompositeSerializedComparator extends SerializedComparator  {
-  /**
-   * Constructs a composite key consisting of a primary key and a secondary key.
-   * 
-   * @param key1 the primary key
-   * @param key2 the secondary key
-   * @return the composite key
-   */
-  public byte[] createCompositeKey(byte[] key1, byte[] key2);
-  
-  /**
-   * Constructs a composite key by combining the supplied keys.  The number of
-   * keys and their order must match the comparator set.
-   * <p>
-   * The <code>WILDCARD_KEY</code> token may be used to match all subkeys in the
-   * given ordinal position.  This is useful when constructing a search key to
-   * retrieve all keys for a given primary key, ignoring the remaining subkeys.
-   * 
-   * @param keys the keys, ordered by sort priority
-   * @return the composite key
-   */
-  public byte[] createCompositeKey(byte[]... keys);
-  
-  /**
-   * Returns subkey for the given ordinal position.
-   * @param key the composite key
-   * @return the subkey
-   */
-  public ByteBuffer getKey(ByteBuffer key, int ordinal);
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexSerializedComparator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexSerializedComparator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexSerializedComparator.java
deleted file mode 100644
index 816eea0..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexSerializedComparator.java
+++ /dev/null
@@ -1,127 +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.persistence.soplog;
-
-import java.nio.ByteBuffer;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-import com.gemstone.gemfire.internal.util.Bytes;
-
-/**
- * Provides a comparator for composite keys of the form (k0, k1).  The primary 
- * keys are compared lexicographically while the secondary keys are compared 
- * bitwise.  The key format includes the primary key length to avoid deserialization 
- * the secondary key when reading:
- * <pre>
- * | varint | primary key | secondary key |
- * </pre>
- * The key length is encoded using a protobuf-style varint.
- * <p>
- * 
- * @author bakera
- */
-public class IndexSerializedComparator implements CompositeSerializedComparator, 
-DelegatingSerializedComparator {
-  
-  private volatile SerializedComparator primary;
-  private volatile SerializedComparator secondary;
-  
-  public IndexSerializedComparator() {
-    primary = new LexicographicalComparator();
-    secondary = new ByteComparator();
-  }
-  
-  @Override
-  public void setComparators(SerializedComparator[] comparators) {
-    assert comparators.length == 2;
-    
-    primary = comparators[0];
-    secondary = comparators[1];
-  }
-
-  @Override
-  public SerializedComparator[] getComparators() {
-    return new SerializedComparator[] { primary, secondary };
-  }
-
-  @Override
-  public int compare(byte[] o1, byte[] o2) {
-    return compare(o1, 0, o1.length, o2, 0, o2.length);
-  }
-  
-  @Override
-  public int compare(byte[] b1, int o1, int l1, byte[] b2, int o2, int l2) {
-    int klen1 = Bytes.getVarInt(b1, o1);
-    int klen2 = Bytes.getVarInt(b2, o2);
-    
-    int off1 = o1 + Bytes.sizeofVarInt(klen1);
-    int off2 = o2 + Bytes.sizeofVarInt(klen2);
-    
-    // skip the comparison operation if there is a SearchToken.WILDCARD
-    if (!SoplogToken.isWildcard(b1, off1, b2, off2)) {
-      int diff = primary.compare(b1, off1, klen1, b2, off2, klen2);
-      if (diff != 0) {
-        return diff;
-      }
-    }
-    off1 += klen1;
-    off2 += klen2;
-
-    if (!SoplogToken.isWildcard(b1, off1, b2, off2)) {
-      l1 -= (off1 - o1);
-      l2 -= (off2 - o2);
-      return secondary.compare(b1, off1, l1, b2, off2, l2);
-    }
-    return 0;
-  }
-
-  @Override
-  public ByteBuffer getKey(ByteBuffer key, int ordinal) {
-    assert ordinal < 2;
-    
-    ByteBuffer subkey;
-    int klen = Bytes.getVarInt(key);
-    if (ordinal == 0) {
-      subkey = (ByteBuffer) key.slice().limit(klen);
-      
-    } else {
-      subkey = ((ByteBuffer) key.position(key.position() + klen)).slice();
-    }
-    
-    key.rewind();
-    return subkey;
-  }
-
-  @Override
-  public byte[] createCompositeKey(byte[] key1, byte[] key2) {
-    int vlen = Bytes.sizeofVarInt(key1.length);
-    byte[] buf = new byte[vlen + key1.length + key2.length];
-    
-    Bytes.putVarInt(key1.length, buf, 0);
-    System.arraycopy(key1, 0, buf, vlen, key1.length);
-    System.arraycopy(key2, 0, buf, vlen + key1.length, key2.length);
-    
-    return buf;
-  }
-
-  @Override
-  public byte[] createCompositeKey(byte[]... keys) {
-    assert keys.length == 2;
-    
-    return createCompositeKey(keys[0], keys[1]);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LevelTracker.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LevelTracker.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LevelTracker.java
deleted file mode 100644
index a590283..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LevelTracker.java
+++ /dev/null
@@ -1,120 +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.persistence.soplog;
-
-import java.io.Closeable;
-import java.io.File;
-import java.io.FileReader;
-import java.io.FileWriter;
-import java.io.IOException;
-import java.io.LineNumberReader;
-import java.io.Writer;
-import java.util.HashSet;
-import java.util.Map;
-import java.util.Set;
-import java.util.SortedMap;
-import java.util.TreeMap;
-import java.util.concurrent.atomic.AtomicLong;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.Compactor.CompactionTracker;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.Compactor.Fileset;
-
-/**
- * A simple, non-robust file tracker for tracking soplogs by level.
- * 
- * @author bakera
- */
-public class LevelTracker implements Fileset<Integer>, CompactionTracker<Integer>, Closeable {
-  private final String name;
-  private final File manifest;
-  
-  private final SortedMap<Integer, Set<File>> levels;
-  private final AtomicLong file;
-  
-  public LevelTracker(String name, File manifest) throws IOException {
-    this.name = name;
-    this.manifest = manifest;
-    file = new AtomicLong(0);
-    
-    levels = new TreeMap<Integer, Set<File>>();
-    if (!manifest.exists()) {
-      return;
-    }
-    
-    LineNumberReader rdr = new LineNumberReader(new FileReader(manifest));
-    try {
-      String line;
-      while ((line = rdr.readLine()) != null) {
-        String[] parts = line.split(",");
-        int level = Integer.parseInt(parts[0]);
-        File f = new File(parts[1]);
-        add(f, level);
-      }
-    } finally {
-      rdr.close();
-    }
-  }
-  
-  @Override
-  public SortedMap<Integer, ? extends Iterable<File>> recover() {
-    return levels;
-  }
-
-  @Override
-  public File getNextFilename() {
-    return new File(manifest.getParentFile(),  name + "-" + System.currentTimeMillis() 
-        + "-" + file.getAndIncrement() + ".soplog");
-  }
-
-  @Override
-  public void fileAdded(File f, Integer attach) {
-    add(f, attach);
-  }
-
-  @Override
-  public void fileRemoved(File f, Integer attach) {
-    levels.get(attach).remove(f);
-  }
-
-  @Override
-  public void fileDeleted(File f) {
-  }
-
-  @Override
-  public void close() throws IOException {
-    Writer wtr = new FileWriter(manifest);
-    try {
-      for (Map.Entry<Integer, Set<File>> entry : levels.entrySet()) {
-        for (File f : entry.getValue()) {
-          wtr.write(entry.getKey() + "," + f + "\n");
-        }
-      }
-    } finally {
-      wtr.flush();
-      wtr.close();
-    }
-  }
-  
-  private void add(File f, int level) {
-    Set<File> files = levels.get(level);
-    if (files == null) {
-      files = new HashSet<File>();
-      levels.put(level, files);
-    }
-    files.add(f);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparator.java
deleted file mode 100644
index 24fba50..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparator.java
+++ /dev/null
@@ -1,460 +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.persistence.soplog;
-
-import java.io.ByteArrayInputStream;
-import java.io.DataInput;
-import java.io.DataInputStream;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-import com.gemstone.gemfire.internal.util.Bytes;
-
-/**
- * Provides type-optimized comparisons for serialized objects.  All data is
- * assumed to have been serialized via a call to 
- * {@link DataSerializer#writeObject(Object, java.io.DataOutput) }.  The following
- * data types have optimized comparisons:
- * <ul>
- *  <li>boolean
- *  <li>byte
- *  <li>short
- *  <li>char
- *  <li>int
- *  <li>long
- *  <li>float
- *  <li>double
- *  <li>String (not {@link DSCODE#HUGE_STRING} or {@link DSCODE#HUGE_STRING_BYTES})
- * </ul>
- * Types that are not listed above fallback to deserialization and comparison
- * via the {@link Comparable} API.
- * <p>
- * Any numeric type may be compared against another numeric type (e.g. double
- * to int).
- * <p>
- * <strong>Any changes to the serialized format may cause version incompatibilities.
- * In addition, the comparison operations will need to be updated.</strong>
- * <p>
- * 
- * @author bakera
- */
-public class LexicographicalComparator implements SerializedComparator {
-
-  //////////////////////////////////////////////////////////////////////////////
-  //
-  // constants for any-to-any numeric comparisons 
-  //
-  //////////////////////////////////////////////////////////////////////////////
-
-  private static final int BYTE_TO_BYTE     = DSCODE.BYTE   << 8 | DSCODE.BYTE;
-  private static final int BYTE_TO_SHORT    = DSCODE.BYTE   << 8 | DSCODE.SHORT;
-  private static final int BYTE_TO_INT      = DSCODE.BYTE   << 8 | DSCODE.INTEGER;
-  private static final int BYTE_TO_LONG     = DSCODE.BYTE   << 8 | DSCODE.LONG;
-  private static final int BYTE_TO_FLOAT    = DSCODE.BYTE   << 8 | DSCODE.FLOAT;
-  private static final int BYTE_TO_DOUBLE   = DSCODE.BYTE   << 8 | DSCODE.DOUBLE;
-
-  private static final int SHORT_TO_BYTE    = DSCODE.SHORT  << 8 | DSCODE.BYTE;
-  private static final int SHORT_TO_SHORT   = DSCODE.SHORT  << 8 | DSCODE.SHORT;
-  private static final int SHORT_TO_INT     = DSCODE.SHORT  << 8 | DSCODE.INTEGER;
-  private static final int SHORT_TO_LONG    = DSCODE.SHORT  << 8 | DSCODE.LONG;
-  private static final int SHORT_TO_FLOAT   = DSCODE.SHORT  << 8 | DSCODE.FLOAT;
-  private static final int SHORT_TO_DOUBLE  = DSCODE.SHORT  << 8 | DSCODE.DOUBLE;
-
-  private static final int LONG_TO_BYTE     = DSCODE.LONG   << 8 | DSCODE.BYTE;
-  private static final int LONG_TO_SHORT    = DSCODE.LONG   << 8 | DSCODE.SHORT;
-  private static final int LONG_TO_INT      = DSCODE.LONG   << 8 | DSCODE.INTEGER;
-  private static final int LONG_TO_LONG     = DSCODE.LONG   << 8 | DSCODE.LONG;
-  private static final int LONG_TO_FLOAT    = DSCODE.LONG   << 8 | DSCODE.FLOAT;
-  private static final int LONG_TO_DOUBLE   = DSCODE.LONG   << 8 | DSCODE.DOUBLE;
-  
-  private static final int INT_TO_BYTE      = DSCODE.INTEGER<< 8 | DSCODE.BYTE;
-  private static final int INT_TO_SHORT     = DSCODE.INTEGER<< 8 | DSCODE.SHORT;
-  private static final int INT_TO_INT       = DSCODE.INTEGER<< 8 | DSCODE.INTEGER;
-  private static final int INT_TO_LONG      = DSCODE.INTEGER<< 8 | DSCODE.LONG;
-  private static final int INT_TO_FLOAT     = DSCODE.INTEGER<< 8 | DSCODE.FLOAT;
-  private static final int INT_TO_DOUBLE    = DSCODE.INTEGER<< 8 | DSCODE.DOUBLE;
-
-  private static final int FLOAT_TO_BYTE    = DSCODE.FLOAT  << 8 | DSCODE.BYTE;
-  private static final int FLOAT_TO_SHORT   = DSCODE.FLOAT  << 8 | DSCODE.SHORT;
-  private static final int FLOAT_TO_INT     = DSCODE.FLOAT  << 8 | DSCODE.INTEGER;
-  private static final int FLOAT_TO_LONG    = DSCODE.FLOAT  << 8 | DSCODE.LONG;
-  private static final int FLOAT_TO_FLOAT   = DSCODE.FLOAT  << 8 | DSCODE.FLOAT;
-  private static final int FLOAT_TO_DOUBLE  = DSCODE.FLOAT  << 8 | DSCODE.DOUBLE;
-
-  private static final int DOUBLE_TO_BYTE   = DSCODE.DOUBLE << 8 | DSCODE.BYTE;
-  private static final int DOUBLE_TO_SHORT  = DSCODE.DOUBLE << 8 | DSCODE.SHORT;
-  private static final int DOUBLE_TO_INT    = DSCODE.DOUBLE << 8 | DSCODE.INTEGER;
-  private static final int DOUBLE_TO_LONG   = DSCODE.DOUBLE << 8 | DSCODE.LONG;
-  private static final int DOUBLE_TO_FLOAT  = DSCODE.DOUBLE << 8 | DSCODE.FLOAT;
-  private static final int DOUBLE_TO_DOUBLE = DSCODE.DOUBLE << 8 | DSCODE.DOUBLE;
-  
-  //////////////////////////////////////////////////////////////////////////////
-  //
-  // constants for any-to-any string comparisons 
-  //
-  //////////////////////////////////////////////////////////////////////////////
-
-  private static final int STRING_TO_STRING             = DSCODE.STRING       << 8 | DSCODE.STRING;
-  private static final int STRING_TO_STRING_BYTES       = DSCODE.STRING       << 8 | DSCODE.STRING_BYTES;
-  private static final int STRING_BYTES_TO_STRING       = DSCODE.STRING_BYTES << 8 | DSCODE.STRING;
-  private static final int STRING_BYTES_TO_STRING_BYTES = DSCODE.STRING_BYTES << 8 | DSCODE.STRING_BYTES;
-  
-  @Override
-  public int compare(byte[] o1, byte[] o2) {
-    return compare(o1, 0, o1.length, o2, 0, o2.length);
-  }
-  
-  @Override
-  public int compare(byte[] b1, int o1, int l1, byte[] b2, int o2, int l2) {
-    byte type1 = b1[o1];
-    byte type2 = b2[o2];
-
-    // optimized comparisons
-    if (isString(type1) && isString(type2)) {
-      return compareAsString(type1, b1, o1, type2, b2, o2);
-      
-    } else if (isNumeric(type1) && isNumeric(type2)) {
-      return compareAsNumeric(type1, b1, o1, type2, b2, o2);
-      
-    } else if (type1 == DSCODE.BOOLEAN && type2 == DSCODE.BOOLEAN) {
-      return compareAsBoolean(getBoolean(b1, o1), getBoolean(b2, o2));
-
-    } else if (type1 == DSCODE.CHARACTER && type2 == DSCODE.CHARACTER) {
-      return compareAsChar(getChar(b1, o1), getChar(b2, o2));
-
-    } else if (type1 == DSCODE.NULL || type2 == DSCODE.NULL) {
-      // null check, assumes NULLs sort last
-      return type1 == type2 ? 0 : type1 == DSCODE.NULL ? 1 : -1;
-    }
-    
-    // fallback, will deserialize to Comparable 
-    return compareAsObject(b1, o1, l1, b2, o2, l2);
-  }
-
-  private static boolean isNumeric(int type) {
-    return type == DSCODE.BYTE 
-        || type == DSCODE.SHORT 
-        || type == DSCODE.INTEGER 
-        || type == DSCODE.LONG 
-        || type == DSCODE.FLOAT 
-        || type == DSCODE.DOUBLE;
-  }
-  
-  private static boolean isString(int type) {
-    return type == DSCODE.STRING 
-        || type == DSCODE.STRING_BYTES;
-  }
-  
-  //////////////////////////////////////////////////////////////////////////////
-  //
-  // type comparisons
-  //
-  //////////////////////////////////////////////////////////////////////////////
-  
-  private static int compareAsString(byte type1, byte[] b1, int o1, byte type2, byte[] b2, int o2) {
-    // TODO these comparisons do not provide true alphabetical collation 
-    // support (for example upper case sort before lower case).  Need to use a
-    // collation key instead of unicode ordinal number comparison
-    switch (type1 << 8 | type2) {
-    case STRING_TO_STRING:
-      return compareAsStringOfUtf(b1, o1, b2, o2);
-    
-    case STRING_TO_STRING_BYTES:
-      return -compareAsStringOfByteToUtf(b2, o2, b1, o1);
-    
-    case STRING_BYTES_TO_STRING:
-      return compareAsStringOfByteToUtf(b1, o1, b2, o2);
-
-    case STRING_BYTES_TO_STRING_BYTES:
-      return compareAsStringOfByte(b1, o1, b2, o2);
-
-    default:
-      throw new ClassCastException(String.format("Incomparable types: %d %d", type1, type2));
-    }
-  }
-  
-  private static int compareAsNumeric(byte type1, byte[] b1, int o1, byte type2, byte[] b2, int o2) {
-    switch (type1 << 8 | type2) {
-    case BYTE_TO_BYTE:     return compareAsShort (getByte  (b1, o1), getByte  (b2, o2));
-    case BYTE_TO_SHORT:    return compareAsShort (getByte  (b1, o1), getShort (b2, o2));
-    case BYTE_TO_INT:      return compareAsInt   (getByte  (b1, o1), getInt   (b2, o2));
-    case BYTE_TO_LONG:     return compareAsLong  (getByte  (b1, o1), getLong  (b2, o2));
-    case BYTE_TO_FLOAT:    return compareAsFloat (getByte  (b1, o1), getFloat (b2, o2));
-    case BYTE_TO_DOUBLE:   return compareAsDouble(getByte  (b1, o1), getDouble(b2, o2));
-
-    case SHORT_TO_BYTE:    return compareAsShort (getShort (b1, o1), getByte  (b2, o2));
-    case SHORT_TO_SHORT:   return compareAsShort (getShort (b1, o1), getShort (b2, o2));
-    case SHORT_TO_INT:     return compareAsInt   (getShort (b1, o1), getInt   (b2, o2));
-    case SHORT_TO_LONG:    return compareAsLong  (getShort (b1, o1), getLong  (b2, o2));
-    case SHORT_TO_FLOAT:   return compareAsFloat (getShort (b1, o1), getFloat (b2, o2));
-    case SHORT_TO_DOUBLE:  return compareAsDouble(getShort (b1, o1), getDouble(b2, o2));
-
-    case INT_TO_BYTE:      return compareAsInt   (getInt   (b1, o1), getByte  (b2, o2));
-    case INT_TO_SHORT:     return compareAsInt   (getInt   (b1, o1), getShort (b2, o2));
-    case INT_TO_INT:       return compareAsInt   (getInt   (b1, o1), getInt   (b2, o2));
-    case INT_TO_LONG:      return compareAsLong  (getInt   (b1, o1), getLong  (b2, o2));
-    case INT_TO_FLOAT:     return compareAsFloat (getInt   (b1, o1), getFloat (b2, o2));
-    case INT_TO_DOUBLE:    return compareAsDouble(getInt   (b1, o1), getDouble(b2, o2));
-
-    case LONG_TO_BYTE:     return compareAsLong  (getLong  (b1, o1), getByte  (b2, o2));
-    case LONG_TO_SHORT:    return compareAsLong  (getLong  (b1, o1), getShort (b2, o2));
-    case LONG_TO_INT:      return compareAsLong  (getLong  (b1, o1), getInt   (b2, o2));
-    case LONG_TO_LONG:     return compareAsLong  (getLong  (b1, o1), getLong  (b2, o2));
-    case LONG_TO_FLOAT:    return compareAsDouble(getLong  (b1, o1), getFloat (b2, o2));
-    case LONG_TO_DOUBLE:   return compareAsDouble(getLong  (b1, o1), getDouble(b2, o2));
-
-    case FLOAT_TO_BYTE:    return compareAsFloat (getFloat (b1, o1), getByte  (b2, o2));
-    case FLOAT_TO_SHORT:   return compareAsFloat (getFloat (b1, o1), getShort (b2, o2));
-    case FLOAT_TO_INT:     return compareAsFloat (getFloat (b1, o1), getInt   (b2, o2));
-    case FLOAT_TO_LONG:    return compareAsFloat (getFloat (b1, o1), getLong  (b2, o2));
-    case FLOAT_TO_FLOAT:   return compareAsFloat (getFloat (b1, o1), getFloat (b2, o2));
-    case FLOAT_TO_DOUBLE:  return compareAsDouble(getFloat (b1, o1), getDouble(b2, o2));
-
-    case DOUBLE_TO_BYTE:   return compareAsDouble(getDouble(b1, o1), getByte  (b2, o2));
-    case DOUBLE_TO_SHORT:  return compareAsDouble(getDouble(b1, o1), getShort (b2, o2));
-    case DOUBLE_TO_INT:    return compareAsDouble(getDouble(b1, o1), getInt   (b2, o2));
-    case DOUBLE_TO_LONG:   return compareAsDouble(getDouble(b1, o1), getLong  (b2, o2));
-    case DOUBLE_TO_FLOAT:  return compareAsDouble(getDouble(b1, o1), getFloat (b2, o2));
-    case DOUBLE_TO_DOUBLE: return compareAsDouble(getDouble(b1, o1), getDouble(b2, o2));
-    
-    default:
-      throw new ClassCastException(String.format("Incomparable types: %d %d", type1, type2));
-    }
-  }
-  
-  private static int compareAsBoolean(boolean b1, boolean b2) {
-    return (b1 == b2) ? 0 : (b1 ? 1 : -1);
-  }
-  
-  private static int compareAsShort(short s1, short s2) {
-    return s1 - s2;
-  }
-  
-  private static int compareAsChar(char c1, char c2) {
-    // TODO non-collating sort
-    return c1 - c2;
-  }
-  
-  private static int compareAsInt(long l1, long l2) {
-    return (int) (l1 - l2);
-  }
-  
-  private static int compareAsLong(long l1, long l2) {
-    return (l1 < l2) ? -1 : ((l1 == l2) ? 0 : 1);
-  }
-  
-  private static int compareAsFloat(float f1, float f2) {
-    return Float.compare(f1, f2);
-  }
-
-  private static int compareAsDouble(double d1, double d2) {
-    return Double.compare(d1, d2);
-  }
-
-  private static int compareAsStringOfByte(byte[] b1, int o1, byte[] b2, int o2) {
-    int offset = 3;
-    int l1 = Bytes.toUnsignedShort(b1[o1 + 1], b1[o1 + 2]);
-    int l2 = Bytes.toUnsignedShort(b2[o1 + 1], b2[o1 + 2]);
-    
-    assert b1.length >= o1 + offset + l1;
-    assert b2.length >= o2 + offset + l2;
-    
-    int end = o1 + offset + Math.min(l1, l2);
-    for (int i = o1 + offset, j = o2 + offset; i < end; i++, j++) {
-      int diff = b1[i] - b2[j];
-      if (diff != 0) {
-        return diff;
-      }
-    }
-    return l1 - l2;
-  }
-
-  private static int compareAsStringOfUtf(byte[] b1, int o1, byte[] b2, int o2) {
-    int offset = 3;
-    int l1 = Bytes.toUnsignedShort(b1[o1 + 1], b1[o1 + 2]);
-    int l2 = Bytes.toUnsignedShort(b2[o1 + 1], b2[o1 + 2]);
-
-    assert b1.length >= o1 + offset + l1;
-    assert b2.length >= o2 + offset + l2;
-    
-    int i = 0;
-    int j = 0;
-    while (i < l1 && j < l2) {
-      final int idx = o1 + offset + i;
-      final int ilen = getUtfLength(b1[idx]);
-      final char c1 = getUtfChar(b1, idx, ilen);
-      i += ilen;
-      
-      final int jdx = o2 + offset + j;
-      final int jlen = getUtfLength(b2[jdx]);
-      char c2 = getUtfChar(b2, jdx, jlen);
-      j += jlen;
-      
-      int diff = compareAsChar(c1, c2);
-      if (diff != 0) {
-        return diff;
-      }
-    }
-    return (l1 - i) - (l2 - j);
-  }
-
-  private static int compareAsStringOfByteToUtf(byte[] b1, int o1, byte[] b2, int o2) {
-    int offset = 3;
-    int l1 = Bytes.toUnsignedShort(b1[o1 + 1], b1[o1 + 2]);
-    int l2 = Bytes.toUnsignedShort(b2[o1 + 1], b2[o1 + 2]);
-
-    assert b1.length >= o1 + offset + l1;
-    assert b2.length >= o2 + offset + l2;
-    
-    int i = 0;
-    int j = 0;
-    while (i < l1 && j < l2) {
-      final int idx = o1 + offset + i;
-      final char c1 = (char) b1[idx];
-      i++;
-      
-      final int jdx = o2 + offset + j;
-      final int jlen = getUtfLength(b2[jdx]);
-      char c2 = getUtfChar(b2, jdx, jlen);
-      j += jlen;
-      
-      int diff = compareAsChar(c1, c2);
-      if (diff != 0) {
-        return diff;
-      }
-    }
-    return (l1 - i) - (l2 - j);
-  }
-  
-  private static int compareAsObject(byte[] b1, int o1, int l1, byte[] b2, int o2, int l2) {
-    DataInput in1 = new DataInputStream(new ByteArrayInputStream(b1, o1, l1));
-    DataInput in2 = new DataInputStream(new ByteArrayInputStream(b2, o2, l2));
-  
-    try {
-      Comparable<Object> obj1 = DataSerializer.readObject(in1);
-      Comparable<Object> obj2 = DataSerializer.readObject(in2);
-  
-      return obj1.compareTo(obj2);
-      
-    } catch (Exception e) {
-      throw (RuntimeException) new ClassCastException().initCause(e);
-    }
-  }
-  
-  //////////////////////////////////////////////////////////////////////////////
-  //
-  //
-  // Get a char from modified UTF8, as defined by DataInput.readUTF().
-  //
-  //////////////////////////////////////////////////////////////////////////////
-
-  private static int getUtfLength(byte b) {
-    int c = b & 0xff;
-    
-    // 0xxxxxxx
-    if (c < 0x80) {
-      return 1;
-    
-    // 110xxxxx 10xxxxxx
-    } else if (c < 0xe0) {
-      return 2;
-    } 
-
-    // 1110xxxx 10xxxxxx 10xxxxxx
-    return 3;
-  }
-  
-  private static char getUtfChar(byte[] b, int off, int len) {
-    assert b.length >= off + len;
-    switch (len) {
-    case 1: 
-      return (char) b[off];
-    case 2: 
-      return getUtf2(b, off);
-    case 3: 
-    default:
-      return getUtf3(b, off);
-    }
-  }
-
-  private static char getUtf2(byte[] b, int off) {
-    assert b.length >= off + 2;
-    assert (b[off] & 0xff) >= 0xc0;
-    assert (b[off] & 0xff) < 0xe0;
-    assert (b[off + 1] & 0xff) >= 0x80;
-    
-    return (char) (((b[off] & 0x1f) << 6) | (b[off + 1] & 0x3f));
-  }
-  
-  private static char getUtf3(byte[] b, int off) {
-    assert b.length >= off + 3;
-    assert (b[off]     & 0xff) >= 0xe0;
-    assert (b[off + 1] & 0xff) >= 0x80;
-    assert (b[off + 2] & 0xff) >= 0x80;
-    
-    return (char) (((b[off] & 0x0f) << 12) | ((b[off + 1] & 0x3f) << 6) | (b[off + 2] & 0x3f));
-  }
-
-
-  //////////////////////////////////////////////////////////////////////////////
-  //
-  // Get a serialized primitive from byte[];  b[0] is the DSCODE.
-  //
-  //////////////////////////////////////////////////////////////////////////////
-  
-  private static boolean getBoolean(byte[] b, int off) {
-    assert b.length >= off + 2;
-    return b[off + 1] != 0;  
-  }
-  
-  private static byte getByte(byte[] b, int off) {
-    assert b.length >= off + 2;
-    return b[off + 1];
-  }
-
-  private static short getShort(byte[] b, int off) {
-    assert b.length >= off + 3;
-    return Bytes.toShort(b[off + 1], b[off + 2]);
-  }
-  
-  private static char getChar(byte[] b, int off) {
-    assert b.length >= off + 3;
-    return Bytes.toChar(b[off + 1], b[off + 2]);
-  }
-
-  private static int getInt(byte[] b, int off) {
-    assert b.length >= off + 5;
-    return Bytes.toInt(b[off + 1], b[off + 2], b[off + 3], b[off + 4]);
-  }
-
-  private static long getLong(byte[] b, int off) {
-    assert b.length >= off + 9;
-    return Bytes.toLong(b[off + 1], b[off + 2], b[off + 3], b[off + 4], 
-                        b[off + 5], b[off + 6], b[off + 7], b[off + 8]);
-  }
-
-  private static float getFloat(byte[] b, int off) {
-    assert b.length >= off + 5;
-    return Float.intBitsToFloat(getInt(b, off));
-  }
-
-  private static double getDouble(byte[] b, int off) {
-    assert b.length >= off + 9;
-    return Double.longBitsToDouble(getLong(b, off));
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/NonCompactor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/NonCompactor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/NonCompactor.java
deleted file mode 100644
index 697ac18..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/NonCompactor.java
+++ /dev/null
@@ -1,110 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.ArrayDeque;
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Deque;
-import java.util.SortedMap;
-import java.util.TreeMap;
-import java.util.concurrent.atomic.AtomicLong;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogReader;
-
-/**
- * Provides a compactor that does no compaction, primarily for testing purposes.
- *  
- * @author bakera
- */
-public class NonCompactor implements Compactor {
-  /** the fileset */
-  private final Fileset<Integer> fileset;
-  
-  /** the current readers */
-  private final Deque<TrackedReference<SortedOplogReader>> readers;
-  
-  public static Fileset<Integer> createFileset(final String name, final File dir) {
-    return new Fileset<Integer>() {
-      private final AtomicLong file = new AtomicLong(0);
-      
-      @Override
-      public SortedMap<Integer, ? extends Iterable<File>> recover() {
-        return new TreeMap<Integer, Iterable<File>>();
-      }
-
-      @Override
-      public File getNextFilename() {
-        return new File(dir, name + "-" + System.currentTimeMillis() + "-" 
-            + file.getAndIncrement() + ".soplog");
-      }
-    };
-  }
-  public NonCompactor(String name, File dir) {
-    fileset = createFileset(name, dir);
-    readers = new ArrayDeque<TrackedReference<SortedOplogReader>>();
-  }
-  
-  @Override
-  public boolean compact() throws IOException {
-    // liar!
-    return true;
-  }
-
-  @Override
-  public void compact(boolean force, CompactionHandler cd) {
-  }
-
-  @Override
-  public synchronized Collection<TrackedReference<SortedOplogReader>> getActiveReaders(
-      byte[] start, byte[] end) {
-    for (TrackedReference<SortedOplogReader> tr : readers) {
-      tr.increment();
-    }
-    return new ArrayList<TrackedReference<SortedOplogReader>>(readers);
-  }
-
-  @Override
-  public void add(SortedOplog soplog) throws IOException {
-    readers.addFirst(new TrackedReference<SortedOplogReader>(soplog.createReader()));
-  }
-
-  @Override
-  public synchronized void clear() throws IOException {
-    for (TrackedReference<SortedOplogReader> tr : readers) {
-      tr.get().close();
-      readers.remove(tr);
-    }
-  }
-
-  @Override
-  public synchronized void close() throws IOException {
-    clear();
-  }
-
-  @Override
-  public CompactionTracker<Integer> getTracker() {
-    return null;
-  }
-  
-  @Override
-  public Fileset<Integer> getFileset() {
-    return fileset;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ReversingSerializedComparator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ReversingSerializedComparator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ReversingSerializedComparator.java
deleted file mode 100644
index b18919d..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ReversingSerializedComparator.java
+++ /dev/null
@@ -1,67 +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.persistence.soplog;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-
-/**
- * Reverses the ordering imposed by the underlying comparator.  Use this to 
- * change from an ascending to a descending order or vice versa.
- * <p>
- * Prior to use, an instance must be configured with a comparator for delegation
- * of the comparison operations.
- *  
- * @author bakera
- */
-public class ReversingSerializedComparator implements DelegatingSerializedComparator {
-  private volatile SerializedComparator delegate;
-
-  @Override
-  public void setComparators(SerializedComparator[] sc) {
-    assert sc.length == 0;
-    delegate = sc[0];
-  }
-  
-  @Override
-  public SerializedComparator[] getComparators() {
-    return new SerializedComparator[] { delegate };
-  }
-  
-  @Override
-  public int compare(byte[] o1, byte[] o2) {
-    return compare(o1, 0, o1.length, o2, 0, o2.length);
-  }
-  
-  @Override
-  public int compare(byte[] b1, int o1, int l1, byte[] b2, int o2, int l2) {
-    return delegate.compare(b2, o2, l2, b1, o1, l1);
-  }
-  
-  /**
-   * Returns a comparator that reverses the ordering imposed by the supplied
-   * comparator.
-   * 
-   * @param sc the original comparator
-   * @return the reversed comparator
-   */
-  public static SerializedComparator reverse(SerializedComparator sc) {
-    ReversingSerializedComparator rev = new ReversingSerializedComparator();
-    rev.delegate = sc;
-    
-    return rev;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactor.java
deleted file mode 100644
index 5976ad0..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactor.java
+++ /dev/null
@@ -1,198 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.io.InterruptedIOException;
-import java.util.ArrayDeque;
-import java.util.ArrayList;
-import java.util.Deque;
-import java.util.List;
-import java.util.Map;
-import java.util.concurrent.Executor;
-import java.util.concurrent.atomic.AtomicBoolean;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogReader;
-
-/**
- * Implements a size-tiered compaction scheme in which the soplogs are organized
- * by levels of increasing size.  Each level is limited to a fixed number of 
- * files, <code>M</code>. Given an initial size of <code>N</code> the amount of
- * disk space consumed by a level <code>L</code> is <code>M * N^(L+1)</code>.
- * <p>
- * During compaction, this approach will temporarily double the amount of space
- * consumed by the level.  Compactions are performed on a background thread.
- * <p>
- * Soplogs that have been compacted will be moved to the inactive list where they
- * will be deleted once they are no longer in use.
- * 
- * @author bakera
- */
-public class SizeTieredCompactor extends AbstractCompactor<Integer> {
-  /** restricts the number of soplogs per level */
-  private final int maxFilesPerLevel;
-  
-  // TODO consider relaxing the upper bound so the levels are created dynamically
-  /** restricts the number of levels; files in maxLevel are not compacted */
-  private final int maxLevels;
-  
-  public SizeTieredCompactor(SortedOplogFactory factory, 
-      Fileset<Integer> fileset, CompactionTracker<Integer> tracker,
-      Executor exec, int maxFilesPerLevel, int maxLevels)
-      throws IOException {
-    super(factory, fileset, tracker, exec);
-
-    assert maxFilesPerLevel > 0;
-    assert maxLevels > 0;
-    
-    this.maxFilesPerLevel = maxFilesPerLevel;
-    this.maxLevels = maxLevels;
-    
-    final boolean isDebugEnabled = logger.isDebugEnabled();
-    if (isDebugEnabled) {
-      logger.debug("{}Creating size-tiered compactor", super.logPrefix);
-    }
-
-    for (int i = 0; i < maxLevels; i++) {
-      levels.add(new OrderedLevel(i));
-    }
-    
-    for (Map.Entry<Integer, ? extends Iterable<File>> entry : fileset.recover().entrySet()) {
-      int level = Math.min(maxLevels - 1, entry.getKey());
-      for (File f : entry.getValue()) {
-        if (isDebugEnabled) {
-          logger.debug("{}Adding {} to level {}", super.logPrefix, f, level);
-        }
-        levels.get(level).add(factory.createSortedOplog(f));
-      }
-    }
-  }
-
-  @Override
-  public String toString() {
-    return String.format("%s <%d/%d>", factory.getConfiguration().getName(), maxFilesPerLevel, maxLevels);
-  }
-  
-  /**
-   * Organizes a set of soplogs for a given level.  All operations on the 
-   * soplogs are synchronized via the instance monitor.
-   */
-  protected class OrderedLevel extends Level {
-    /** the ordered set of soplog readers */
-    private final Deque<TrackedReference<SortedOplogReader>> soplogs;
-    
-    /** true if the level is being compacted */
-    private final AtomicBoolean isCompacting;
-    
-    public OrderedLevel(int level) {
-      super(level);
-      soplogs = new ArrayDeque<TrackedReference<SortedOplogReader>>(maxFilesPerLevel);
-      isCompacting = new AtomicBoolean(false);
-    }
-    
-    @Override
-    protected synchronized boolean needsCompaction() {
-      // TODO this is safe but overly conservative...we need to allow parallel
-      // compaction of a level such that we guarantee completion order and handle
-      // errors
-      return !isCompacting.get() 
-          && soplogs.size() >= maxFilesPerLevel 
-          && level != maxLevels - 1;
-    }
-    
-    @Override
-    protected List<TrackedReference<SortedOplogReader>> getSnapshot(byte[] start, byte[] end) {
-      // ignoring range limits since keys are stored in overlapping files
-      List<TrackedReference<SortedOplogReader>> snap;
-      synchronized (this) {
-        snap = new ArrayList<TrackedReference<SortedOplogReader>>(soplogs);
-      }
-
-      for (TrackedReference<SortedOplogReader> tr : snap) {
-        tr.increment();
-      }
-      return snap; 
-    }
-
-    @Override
-    protected synchronized void clear() throws IOException {
-      for (TrackedReference<SortedOplogReader> tr : soplogs) {
-        tr.get().close();
-      }
-      markAsInactive(soplogs, level);
-      soplogs.clear();
-    }
-    
-    @Override
-    protected synchronized void close() throws IOException {
-      for (TrackedReference<SortedOplogReader> tr : soplogs) {
-        tr.get().close();
-        factory.getConfiguration().getStatistics().incActiveFiles(-1);
-      }
-      soplogs.clear();
-    }
-
-    @Override
-    protected void add(SortedOplog soplog) throws IOException {
-      SortedOplogReader rdr = soplog.createReader();
-      synchronized (this) {
-        soplogs.addFirst(new TrackedReference<SortedOplogReader>(rdr));
-      }
-      
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Added file {} to level {}", SizeTieredCompactor.super.logPrefix, rdr, level);
-      }
-      tracker.fileAdded(rdr.getFile(), level);
-      factory.getConfiguration().getStatistics().incActiveFiles(1);
-    }
-
-    @Override
-    protected boolean compact(AtomicBoolean aborted) throws IOException {
-      assert level < maxLevels : "Can't compact level: " + level;
-      
-      if (!isCompacting.compareAndSet(false, true)) {
-        // another thread won so gracefully bow out
-        return false;
-      }
-      
-      try {
-        List<TrackedReference<SortedOplogReader>> snapshot = getSnapshot(null, null);
-        try {
-          SortedOplog merged = merge(snapshot, level == maxLevels - 1, aborted);
-          
-          synchronized (this) {
-            if (merged != null) {
-              levels.get(Math.min(level + 1, maxLevels - 1)).add(merged);
-            }
-            markAsInactive(snapshot, level);
-            soplogs.removeAll(snapshot);
-          }
-        } catch (InterruptedIOException e) {
-          if (logger.isDebugEnabled()) {
-            logger.debug("{}Aborting compaction of level {}", SizeTieredCompactor.super.logPrefix, level);
-          }
-          return false;
-        }
-        return true;
-      } finally {
-        boolean set = isCompacting.compareAndSet(true, false);
-        assert set;
-      }
-    }
-  }
-}


[10/50] [abbrv] incubator-geode git commit: GEODE-227: Extract all dependency version information into a single file

Posted by bs...@apache.org.
GEODE-227: Extract all dependency version information into a single file

Currently, versions are scattered throughout the code, making it hard to manage
when there is a version change. This change extracts all versions into a single
file so only one place needs to change when a dependency version needs to be updated.

Tested by 'clean precheckin'


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

Branch: refs/heads/feature/GEODE-77
Commit: dc5d343b77a52f2ebad8ac1ebfa9a06c7c451fc5
Parents: e1f6530
Author: Mark Bretl <mb...@pivotal.io>
Authored: Tue Oct 27 16:22:07 2015 -0700
Committer: Mark Bretl <mb...@pivotal.io>
Committed: Thu Nov 5 16:42:40 2015 -0800

----------------------------------------------------------------------
 build.gradle                          |  52 +++++++-----
 gemfire-assembly/build.gradle         |   2 +-
 gemfire-core/build.gradle             | 129 +++++++++++++++--------------
 gemfire-jgroups/build.gradle          |   8 +-
 gemfire-rebalancer/build.gradle       |  10 +--
 gemfire-web-api/build.gradle          |  46 +++++-----
 gemfire-web/build.gradle              |  12 +--
 gradle/dependency-versions.properties |  64 ++++++++++++++
 8 files changed, 198 insertions(+), 125 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/build.gradle
----------------------------------------------------------------------
diff --git a/build.gradle b/build.gradle
index 9aa967b..e3b1033 100755
--- a/build.gradle
+++ b/build.gradle
@@ -1,5 +1,11 @@
 apply plugin: 'wrapper'
 
+
+// Load all properties in dependency-version.properties as project properties, so all projects can read them
+Properties dependencyVersions = new Properties()
+dependencyVersions.load(new FileInputStream("${project.projectDir}/gradle/dependency-versions.properties"))
+dependencyVersions.keys().each{ k -> project.ext[k] = dependencyVersions[k]}
+
 allprojects {
   version = versionNumber + '-' + releaseType
   // We want to see all test results.  This is equivalatent to setting --continue
@@ -275,30 +281,30 @@ subprojects {
   javadoc.classpath += configurations.provided
   
   dependencies {
-    compile 'org.springframework:spring-aop:3.2.12.RELEASE'
-    compile 'org.springframework:spring-beans:3.2.12.RELEASE'
-    compile 'org.springframework:spring-context:3.2.12.RELEASE'
-    compile 'org.springframework:spring-context-support:3.2.12.RELEASE'
-    compile 'org.springframework:spring-core:3.2.12.RELEASE'
-    compile 'org.springframework:spring-expression:3.2.12.RELEASE'
-    compile 'org.springframework:spring-web:3.2.12.RELEASE'
-    compile 'org.springframework:spring-webmvc:3.2.12.RELEASE'
-
-    testCompile 'com.github.stefanbirkner:system-rules:1.12.1'
-    testCompile 'com.jayway.awaitility:awaitility:1.6.5'
-    testCompile 'edu.umd.cs.mtc:multithreadedtc:1.01'
-    testCompile 'junit:junit:4.12'
-    testCompile 'org.assertj:assertj-core:2.1.0'
-    testCompile 'org.mockito:mockito-core:1.10.19'
-    testCompile 'org.hamcrest:hamcrest-all:1.3'
-    testCompile 'org.jmock:jmock:2.8.1'
-    testCompile 'org.jmock:jmock-junit4:2.8.1'
-    testCompile 'org.jmock:jmock-legacy:2.8.1'
-    testCompile 'pl.pragmatists:JUnitParams:1.0.4'
+    compile 'org.springframework:spring-aop:' + project.'springframework.version'
+    compile 'org.springframework:spring-beans:' + project.'springframework.version'
+    compile 'org.springframework:spring-context:' + project.'springframework.version'
+    compile 'org.springframework:spring-context-support:' + project.'springframework.version'
+    compile 'org.springframework:spring-core:' + project.'springframework.version'
+    compile 'org.springframework:spring-expression:' + project.'springframework.version'
+    compile 'org.springframework:spring-web:' + project.'springframework.version'
+    compile 'org.springframework:spring-webmvc:' + project.'springframework.version'
+
+    testCompile 'com.jayway.awaitility:awaitility:' + project.'awaitility.version'
+    testCompile 'com.github.stefanbirkner:system-rules:' + project.'system-rules.version'
+    testCompile 'edu.umd.cs.mtc:multithreadedtc:' + project.'multithreadedtc.version'
+    testCompile 'junit:junit:' + project.'junit.version'
+    testCompile 'org.assertj:assertj-core:' + project.'assertj-core.version'
+    testCompile 'org.mockito:mockito-core:' + project.'mockito-core.version'
+    testCompile 'org.hamcrest:hamcrest-all:' + project.'hamcrest-all.version'
+    testCompile 'org.jmock:jmock:' + project.'jmock.version'
+    testCompile 'org.jmock:jmock-junit4:' + project.'jmock.version'
+    testCompile 'org.jmock:jmock-legacy:' + project.'jmock.version'
+    testCompile 'pl.pragmatists:JUnitParams:' + project.'JUnitParams.version'
     
-    testRuntime 'cglib:cglib:3.1'
-    testRuntime 'org.objenesis:objenesis:2.1'
-    testRuntime 'org.ow2.asm:asm:5.0.3'
+    testRuntime 'cglib:cglib:' + project.'cglib.version'
+    testRuntime 'org.objenesis:objenesis:' + project.'objenesis.version'
+    testRuntime 'org.ow2.asm:asm:' + project.'asm.version'
   }
 
   test {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/gemfire-assembly/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-assembly/build.gradle b/gemfire-assembly/build.gradle
index ed0bb86..4181476 100755
--- a/gemfire-assembly/build.gradle
+++ b/gemfire-assembly/build.gradle
@@ -3,7 +3,7 @@ buildscript {
         mavenCentral()
     }
     dependencies {
-        classpath group: 'org.hibernate.build.gradle', name: 'gradle-maven-publish-auth', version: '2.0.1'
+        classpath group: 'org.hibernate.build.gradle', name: 'gradle-maven-publish-auth', version: project.'gradle-maven-publish-auth.version'
     }
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/gemfire-core/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-core/build.gradle b/gemfire-core/build.gradle
index 47a84f3..b44525c 100755
--- a/gemfire-core/build.gradle
+++ b/gemfire-core/build.gradle
@@ -11,78 +11,81 @@ configurations {
 }
 
 dependencies {
+   // Source Dependencies
+  // External 
   provided files("${System.getProperty('java.home')}/../lib/tools.jar")
-  compile 'antlr:antlr:2.7.7'
-  compile 'com.fasterxml.jackson.core:jackson-annotations:2.2.0'
-  compile 'com.fasterxml.jackson.core:jackson-core:2.2.0'
-  compile 'com.fasterxml.jackson.core:jackson-databind:2.2.0'
-  compile 'com.google.code.findbugs:annotations:3.0.0'
-  compile 'commons-io:commons-io:2.3'
-  compile 'commons-logging:commons-logging:1.1.1'
-  compile 'commons-modeler:commons-modeler:2.0'
-  compile 'org.apache.lucene:lucene-analyzers-common:5.0.0'
-  compile 'org.apache.lucene:lucene-core:5.0.0'
-  compile 'org.apache.lucene:lucene-queries:5.0.0'
-  compile 'org.apache.lucene:lucene-queryparser:5.0.0'
-  compile 'it.unimi.dsi:fastutil:7.0.2'
-  compile 'javax.activation:activation:1.1.1'
-  compile 'javax.mail:javax.mail-api:1.4.5'
-  compile 'javax.resource:javax.resource-api:1.7'
-  compile 'javax.servlet:javax.servlet-api:3.1.0'
-  compile 'javax.transaction:javax.transaction-api:1.2'
-  compile 'mx4j:mx4j:3.0.1'
-  compile 'mx4j:mx4j-remote:3.0.1'
-  compile 'mx4j:mx4j-tools:3.0.1'
-  compile 'net.java.dev.jna:jna:4.0.0'
-  compile 'net.sourceforge.jline:jline:1.0.S2-B'
-  compile 'org.eclipse.jetty:jetty-http:9.2.3.v20140905'
-  compile 'org.eclipse.jetty:jetty-io:9.2.3.v20140905'
-  compile 'org.eclipse.jetty:jetty-security:9.2.3.v20140905'
-  compile 'org.eclipse.jetty:jetty-server:9.2.3.v20140905'
-  compile 'org.eclipse.jetty:jetty-servlet:9.2.3.v20140905'
-  compile 'org.eclipse.jetty:jetty-util:9.2.3.v20140905'
-  compile 'org.eclipse.jetty:jetty-webapp:9.2.3.v20140905'
-  compile 'org.eclipse.jetty:jetty-xml:9.2.3.v20140905'
-  compile 'org.fusesource.jansi:jansi:1.8'
-  compile 'org.apache.logging.log4j:log4j-api:2.1'
-  compile 'org.apache.logging.log4j:log4j-core:2.1'
-  runtime 'org.apache.logging.log4j:log4j-slf4j-impl:2.1'
-  runtime 'org.apache.logging.log4j:log4j-jcl:2.1'
-  runtime 'org.apache.logging.log4j:log4j-jul:2.1'
-  compile 'org.slf4j:slf4j-api:1.7.7'
-  compile 'org.springframework.data:spring-data-commons:1.9.1.RELEASE'
-  provided 'org.springframework.data:spring-data-gemfire:1.5.1.RELEASE'
-  compile 'org.springframework:spring-tx:3.2.12.RELEASE'
-  compile 'org.springframework.shell:spring-shell:1.0.0.RELEASE'
-  compile 'org.xerial.snappy:snappy-java:1.1.1.6'
-  provided 'org.apache.hadoop:hadoop-common:2.4.1'
-  provided 'org.apache.hadoop:hadoop-annotations:2.4.1'
-  provided 'org.apache.hadoop:hadoop-hdfs:2.4.1'
-  provided 'org.apache.hadoop:hadoop-mapreduce-client-core:2.4.1'
-  compile 'org.apache.hbase:hbase:0.94.27'
-  provided 'commons-lang:commons-lang:2.5'
-  provided 'com.google.guava:guava:11.0.2'
-  compile 'io.netty:netty-all:4.0.4.Final'
-
-  testRuntime 'org.apache.hadoop:hadoop-auth:2.4.1'
-  testRuntime 'commons-collections:commons-collections:3.2.1'
-  testRuntime 'commons-configuration:commons-configuration:1.6'
-  testRuntime 'commons-io:commons-io:2.1'
-  testRuntime 'log4j:log4j:1.2.17'
-  
+  compile 'antlr:antlr:' + project.'antlr.version'
+  compile 'com.fasterxml.jackson.core:jackson-annotations:' + project.'jackson.version'
+  compile 'com.fasterxml.jackson.core:jackson-core:' + project.'jackson.version'
+  compile 'com.fasterxml.jackson.core:jackson-databind:' + project.'jackson.version'
+  compile 'com.google.code.findbugs:annotations:' + project.'annotations.version'
+  provided 'com.google.guava:guava:' + project.'guava.version'
+  compile 'commons-io:commons-io:' + project.'commons-io.version'
+  provided 'commons-lang:commons-lang:' + project.'commons-lang.version'
+  compile 'commons-logging:commons-logging:' + project.'commons-logging.version'
+  compile 'commons-modeler:commons-modeler:' + project.'commons-modeler.version'
+  compile 'io.netty:netty-all:' + project.'netty-all.version'
+  compile 'it.unimi.dsi:fastutil:' + project.'fastutil.version'
+  compile 'javax.activation:activation:' + project.'activation.version'
+  compile 'javax.mail:javax.mail-api:' + project.'javax.mail-api.version'
+  compile 'javax.resource:javax.resource-api:' + project.'javax.resource-api.version'
+  compile 'javax.servlet:javax.servlet-api:' + project.'javax.servlet-api.version'
+  compile 'javax.transaction:javax.transaction-api:' + project.'javax.transaction-api.version'
+  compile 'mx4j:mx4j:' + project.'mx4j.version'
+  compile 'mx4j:mx4j-remote:' + project.'mx4j.version'
+  compile 'mx4j:mx4j-tools:' + project.'mx4j.version'
+  compile 'net.java.dev.jna:jna:' + project.'jna.version'
+  compile 'net.sourceforge.jline:jline:' + project.'jline.version'
+  provided 'org.apache.hadoop:hadoop-common:' + project.'hadoop.version'
+  provided 'org.apache.hadoop:hadoop-annotations:' + project.'hadoop.version'
+  provided 'org.apache.hadoop:hadoop-hdfs:' + project.'hadoop.version'
+  provided 'org.apache.hadoop:hadoop-mapreduce-client-core:' + project.'hadoop.version'
+  compile 'org.apache.hbase:hbase:' + project.'hbase.version'
+  compile 'org.apache.logging.log4j:log4j-api:' + project.'log4j.version'
+  compile 'org.apache.logging.log4j:log4j-core:' + project.'log4j.version'
+  runtime 'org.apache.logging.log4j:log4j-slf4j-impl:' + project.'log4j.version'
+  runtime 'org.apache.logging.log4j:log4j-jcl:' + project.'log4j.version'
+  runtime 'org.apache.logging.log4j:log4j-jul:' + project.'log4j.version'
+  compile 'org.apache.lucene:lucene-analyzers-common:' + project.'lucene.version'
+  compile 'org.apache.lucene:lucene-core:' + project.'lucene.version'
+  compile 'org.apache.lucene:lucene-queries:' + project.'lucene.version'
+  compile 'org.apache.lucene:lucene-queryparser:' + project.'lucene.version'
+  compile 'org.eclipse.jetty:jetty-http:' + project.'jetty.version'
+  compile 'org.eclipse.jetty:jetty-io:' + project.'jetty.version'
+  compile 'org.eclipse.jetty:jetty-security:' + project.'jetty.version'
+  compile 'org.eclipse.jetty:jetty-server:' + project.'jetty.version'
+  compile 'org.eclipse.jetty:jetty-servlet:' + project.'jetty.version'
+  compile 'org.eclipse.jetty:jetty-util:' + project.'jetty.version'
+  compile 'org.eclipse.jetty:jetty-webapp:' + project.'jetty.version'
+  compile 'org.eclipse.jetty:jetty-xml:' + project.'jetty.version'
+  compile 'org.fusesource.jansi:jansi:' + project.'jansi.version'
+  compile 'org.slf4j:slf4j-api:' + project.'slf4j-api.version'
+  compile 'org.springframework.data:spring-data-commons:' + project.'spring-data-commons.version'
+  provided 'org.springframework.data:spring-data-gemfire:' + project.'spring-data-gemfire.version'
+  compile 'org.springframework:spring-tx:' + project.'springframework.version'
+  compile 'org.springframework.shell:spring-shell:' + project.'spring-shell.version'
+  compile 'org.xerial.snappy:snappy-java:' + project.'snappy-java.version'
+  compile 'org.apache.hbase:hbase:' + project.'hbase.version'
+ 
   compile project(':gemfire-common')
   compile project(':gemfire-jgroups')
   compile project(':gemfire-joptsimple')
   compile project(':gemfire-json')
   
-  testCompile 'org.apache.bcel:bcel:5.2'
-  testRuntime 'org.apache.derby:derby:10.2.2.0'
-  testCompile 'net.spy:spymemcached:2.9.0'
-  testCompile 'redis.clients:jedis:2.7.2'
-
   jcaCompile sourceSets.main.output
 
   provided project(path: ':gemfire-junit', configuration: 'testOutput')
+
+  // Test Dependencies
+  // External
+  testCompile 'org.apache.bcel:bcel:' + project.'bcel.version'
+  testRuntime 'org.apache.derby:derby:' + project.'derby.version'
+  testRuntime 'org.apache.hadoop:hadoop-auth:' + project.'hadoop.version'
+  testRuntime 'commons-collections:commons-collections:' + project.'commons-collections.version'
+  testRuntime 'commons-configuration:commons-configuration:' + project.'commons-configuration.version'
+  testRuntime 'commons-io:commons-io:' + project.'commons-io.version'
+  testCompile 'net.spy:spymemcached:' + project.'spymemcached.version'
+  testCompile 'redis.clients:jedis:' + project.'jedis.version'
 }
 
 def generatedResources = "$buildDir/generated-resources/main"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/gemfire-jgroups/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-jgroups/build.gradle b/gemfire-jgroups/build.gradle
index 30587bb..7e6835c 100644
--- a/gemfire-jgroups/build.gradle
+++ b/gemfire-jgroups/build.gradle
@@ -1,7 +1,7 @@
 dependencies {
-  compile 'com.google.code.findbugs:annotations:3.0.0'
-  compile 'org.apache.logging.log4j:log4j-api:2.1'
-  compile 'org.apache.logging.log4j:log4j-core:2.1'
+  compile 'com.google.code.findbugs:annotations:' + project.'annotations.version'
+  compile 'org.apache.logging.log4j:log4j-api:' + project.'log4j.version'
+  compile 'org.apache.logging.log4j:log4j-core:' + project.'log4j.version'
 
   provided project(path: ':gemfire-junit', configuration: 'testOutput')
 }
@@ -36,4 +36,4 @@ jar {
   dependsOn jgMagic
 
   from sourceSets.main.output
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/gemfire-rebalancer/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-rebalancer/build.gradle b/gemfire-rebalancer/build.gradle
index 1226a7e..cbb6803 100644
--- a/gemfire-rebalancer/build.gradle
+++ b/gemfire-rebalancer/build.gradle
@@ -3,11 +3,11 @@ dependencies {
     provided project(':gemfire-core')
     provided project(path: ':gemfire-junit', configuration: 'testOutput')
 
-    compile 'org.quartz-scheduler:quartz:2.2.1'
+    compile 'org.quartz-scheduler:quartz:' + project.'quartz.version'
 
     // the following test dependencies are needed for mocking cache instance
-    testRuntime 'org.apache.hadoop:hadoop-common:2.4.1'
-    testRuntime 'org.apache.hadoop:hadoop-hdfs:2.4.1'
-    testRuntime 'com.google.guava:guava:11.0.2'
-    testRuntime 'commons-collections:commons-collections:3.2.1'
+    testRuntime 'org.apache.hadoop:hadoop-common:' + project.'hadoop.version'
+    testRuntime 'org.apache.hadoop:hadoop-hdfs:' + project.'hadoop.version'
+    testRuntime 'com.google.guava:guava:' + project.'guava.version'
+    testRuntime 'commons-collections:commons-collections:' + project.'commons-collections.version'
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/gemfire-web-api/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-web-api/build.gradle b/gemfire-web-api/build.gradle
index 81eec6d..476872f 100755
--- a/gemfire-web-api/build.gradle
+++ b/gemfire-web-api/build.gradle
@@ -1,30 +1,30 @@
 apply plugin: 'war'
 
 dependencies {
-  compile 'commons-lang:commons-lang:2.4'
-  compile 'commons-fileupload:commons-fileupload:1.3.1'
-  compile 'com.fasterxml:classmate:0.9.0'
-  compile 'com.fasterxml.jackson.core:jackson-annotations:2.2.0'
-  compile 'com.fasterxml.jackson.core:jackson-core:2.2.0'
-  compile 'com.fasterxml.jackson.core:jackson-databind:2.2.0'
-  compile 'com.fasterxml.jackson.module:jackson-module-scala_2.10:2.1.5'
-  compile 'com.google.guava:guava:15.0'
-  compile 'com.mangofactory:swagger-springmvc:0.8.2'
-  compile 'org.json4s:json4s-ast_2.10:3.2.4'
-  compile 'org.json4s:json4s-ext_2.10:3.2.4'
-  compile 'org.json4s:json4s-core_2.10:3.2.4'
-  compile 'org.json4s:json4s-jackson_2.10:3.2.4'
-  compile 'org.json4s:json4s-native_2.10:3.2.4'
-  compile 'org.scala-lang:scala-reflect:2.10.0'
-  compile 'org.scala-lang:scala-library:2.10.0'
-  compile 'org.springframework.hateoas:spring-hateoas:0.16.0.RELEASE'
-  compile 'org.springframework:spring-aspects:3.2.12.RELEASE'
-  compile 'org.springframework:spring-oxm:3.2.12.RELEASE'
-  compile 'com.thoughtworks.paranamer:paranamer:2.3'
-  compile 'com.wordnik:swagger-annotations:1.3.2'
-  compile 'com.wordnik:swagger-core_2.10:1.3.2'
+  compile 'commons-lang:commons-lang:' + project.'commons-lang.version'
+  compile 'commons-fileupload:commons-fileupload:' + project.'commons-fileupload.version'
+  compile 'com.fasterxml:classmate:' + project.'classmate.version'
+  compile 'com.fasterxml.jackson.core:jackson-annotations:' + project.'jackson.version'
+  compile 'com.fasterxml.jackson.core:jackson-core:' + project.'jackson.version'
+  compile 'com.fasterxml.jackson.core:jackson-databind:' + project.'jackson.version'
+  compile 'com.fasterxml.jackson.module:jackson-module-scala_2.10:' + project.'jackson-module-scala_2.10.version'
+  compile 'com.google.guava:guava:' + project.'guava.version'
+  compile 'com.mangofactory:swagger-springmvc:' + project.'swagger-springmvc.version'
+  compile 'com.thoughtworks.paranamer:paranamer:' + project.'paranamer.version'
+  compile 'com.wordnik:swagger-annotations:' + project.'swagger.version'
+  compile 'com.wordnik:swagger-core_2.10:' + project.'swagger.version'
+  compile 'org.json4s:json4s-ast_2.10:' + project.'json4s.version'
+  compile 'org.json4s:json4s-ext_2.10:' + project.'json4s.version'
+  compile 'org.json4s:json4s-core_2.10:' + project.'json4s.version'
+  compile 'org.json4s:json4s-jackson_2.10:' + project.'json4s.version'
+  compile 'org.json4s:json4s-native_2.10:' + project.'json4s.version'
+  compile 'org.scala-lang:scala-library:' + project.'scala.version'
+  compile 'org.scala-lang:scala-reflect:' + project.'scala.version'
+  compile 'org.springframework.hateoas:spring-hateoas:' + project.'spring-hateos.version'
+  compile 'org.springframework:spring-aspects:' + project.'springframework.version'
+  compile 'org.springframework:spring-oxm:' + project.'springframework.version'
 
-  provided 'javax.servlet:javax.servlet-api:3.1.0'
+  provided 'javax.servlet:javax.servlet-api:' + project.'javax.servlet-api.version'
   provided project(':gemfire-core')
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/gemfire-web/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-web/build.gradle b/gemfire-web/build.gradle
index 564b07d..c438de4 100755
--- a/gemfire-web/build.gradle
+++ b/gemfire-web/build.gradle
@@ -1,14 +1,14 @@
 apply plugin: 'war'
 
 dependencies {
-  runtime 'org.springframework:spring-aspects:3.2.12.RELEASE'
-  runtime 'org.springframework:spring-oxm:3.2.12.RELEASE'
-  runtime 'commons-fileupload:commons-fileupload:1.3.1'
+  runtime 'org.springframework:spring-aspects:' + project.'springframework.version'
+  runtime 'org.springframework:spring-oxm:' + project.'springframework.version'
+  runtime 'commons-fileupload:commons-fileupload:' + project.'commons-fileupload.version'
 
-  testCompile 'org.springframework:spring-test:3.2.12.RELEASE'
-  
-  provided 'javax.servlet:javax.servlet-api:3.1.0'
+  testCompile 'org.springframework:spring-test:' + project.'springframework.version'
   
+  provided 'javax.servlet:javax.servlet-api:' + project.'javax.servlet-api.version'
+   
   // have to use output since we exclude the dependent classes from jar :(
   provided project(path: ':gemfire-core', configuration: 'classesOutput')
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/dc5d343b/gradle/dependency-versions.properties
----------------------------------------------------------------------
diff --git a/gradle/dependency-versions.properties b/gradle/dependency-versions.properties
new file mode 100644
index 0000000..5fc6fbc
--- /dev/null
+++ b/gradle/dependency-versions.properties
@@ -0,0 +1,64 @@
+# Buildscript Dependencies
+gradle-maven-publish-auth.version = 2.0.1
+
+# Dependency versions
+activation.version = 1.1.1
+annotations.version = 3.0.0
+antlr.version = 2.7.7
+asm.version = 5.0.3
+assertj-core.version = 2.1.0
+awaitility.version = 1.6.5
+bcel.version = 5.2
+cglib.version = 3.1
+classmate.version = 0.9.0
+commons-collections.version = 3.2.1
+commons-configuration.version = 1.6
+commons-fileupload.version = 1.3.1
+commons-io.version = 2.3
+commons-lang.version = 2.5
+commons-logging.version = 1.1.1
+commons-modeler.version = 2.0
+derby.version = 10.2.2.0
+fastutil.version = 7.0.2
+guava.version = 11.0.2
+hadoop.version = 2.4.1
+hamcrest-all.version = 1.3
+hbase.version = 0.94.27
+jackson.version = 2.2.0
+jackson-module-scala_2.10.version = 2.1.5
+jansi.version = 1.8
+javax.mail-api.version = 1.4.5
+javax.resource-api.version = 1.7
+javax.servlet-api.version = 3.1.0
+javax.transaction-api.version = 1.2
+jedis.version = 2.7.2
+jetty.version = 9.2.3.v20140905
+jline.version = 1.0.S2-B
+jmock.version = 2.8.1
+jna.version = 4.0.0
+json4s.version = 3.2.4
+junit.version = 4.12
+JUnitParams.version = 1.0.4
+log4j.version = 2.1
+lucene.version = 5.0.0
+mockito-core.version = 1.10.19
+multithreadedtc.version = 1.01
+mx4j.version = 3.0.1
+mx4j-remote.version = 3.0.1
+mx4j-tools.version = 3.0.1
+netty-all.version = 4.0.4.Final
+objenesis.version = 2.1
+paranamer.version = 2.3
+quartz.version = 2.2.1
+scala.version = 2.10.0
+slf4j-api.version = 1.7.7
+snappy-java.version = 1.1.1.6
+spring-data-commons.version = 1.9.1.RELEASE
+spring-data-gemfire.version = 1.5.1.RELEASE
+spring-hateos.version = 0.16.0.RELEASE
+spring-shell.version = 1.0.0.RELEASE
+springframework.version = 3.2.12.RELEASE
+spymemcached.version = 2.9.0
+swagger.version = 1.3.2
+swagger-springmvc.version = 0.8.2
+system-rules.version = 1.12.1


[30/50] [abbrv] incubator-geode git commit: Revert "GEM-111: Cannot use 8.0.0.9+ clients with 8.1+ servers Added support for version 8009"

Posted by bs...@apache.org.
Revert "GEM-111: Cannot use 8.0.0.9+ clients with 8.1+ servers Added support for version 8009"

This reverts commit e1eb74effef800fa67db1c4010ecd67f05ea3b6b.


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

Branch: refs/heads/feature/GEODE-77
Commit: 7dc4b2d27e200e36bbbb535de8058d0afa919690
Parents: 7cbaadc
Author: Barry Oglesby <bo...@pivotal.io>
Authored: Tue Nov 10 16:57:07 2015 -0800
Committer: Barry Oglesby <bo...@pivotal.io>
Committed: Tue Nov 10 16:57:07 2015 -0800

----------------------------------------------------------------------
 .../src/main/java/com/gemstone/gemfire/internal/Version.java    | 5 -----
 .../gemfire/internal/cache/tier/sockets/CommandInitializer.java | 4 ----
 .../internal/cache/tier/sockets/command/ExecuteFunction66.java  | 2 +-
 .../cache/tier/sockets/command/ExecuteRegionFunction66.java     | 2 +-
 .../tier/sockets/command/ExecuteRegionFunctionSingleHop.java    | 2 +-
 5 files changed, 3 insertions(+), 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/7dc4b2d2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
index 8726ba8..936ae79 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
@@ -175,11 +175,6 @@ public final class Version implements Comparable<Version> {
   
   // 31-34 available for 8.0.x variants
   
-  private static final byte GFE_8009_ORDINAL = 31;
-
-  public static final Version GFE_8009 = new Version("GFE", "8.0.0.9", (byte)8,
-      (byte)0, (byte)0, (byte)9, GFE_8009_ORDINAL);
-
   private static final byte GFE_81_ORDINAL = 35;
 
   public static final Version GFE_81 = new Version("GFE", "8.1", (byte)8,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/7dc4b2d2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
index 26ed47b..7e49d7a 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CommandInitializer.java
@@ -301,10 +301,6 @@ public class CommandInitializer {
     gfe80Commands.put(MessageType.PUTALL, PutAll80.getCommand());
     ALL_COMMANDS.put(Version.GFE_80, gfe80Commands);
 
-    Map<Integer, Command> gfe8009Commands = new HashMap<Integer, Command>();
-    gfe8009Commands.putAll(ALL_COMMANDS.get(Version.GFE_80));
-    ALL_COMMANDS.put(Version.GFE_8009, gfe8009Commands);
-
     {
       Map<Integer, Command> gfe81Commands = new HashMap<Integer, Command>();
       gfe81Commands.putAll(ALL_COMMANDS.get(Version.GFE_80));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/7dc4b2d2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
index 9160c11..3baac92 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteFunction66.java
@@ -108,7 +108,7 @@ public class ExecuteFunction66 extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/7dc4b2d2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
index 6d9ca49..329332b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunction66.java
@@ -90,7 +90,7 @@ public class ExecuteRegionFunction66 extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
       if (functionState != 1) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/7dc4b2d2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
index 15b01fc..1c18cb1 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/ExecuteRegionFunctionSingleHop.java
@@ -88,7 +88,7 @@ public class ExecuteRegionFunctionSingleHop extends BaseCommand {
     try {
       byte[] bytes = msg.getPart(0).getSerializedForm();
       functionState = bytes[0];
-      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_8009.ordinal()) {
+      if (bytes.length >= 5 && servConn.getClientVersion().ordinal() >= Version.GFE_81.ordinal()) {
         functionTimeout = Part.decodeInt(bytes, 1);
       }
       if(functionState != 1) {


[49/50] [abbrv] incubator-geode git commit: GEODE-192: Removing TransactionFunctionService

Posted by bs...@apache.org.
GEODE-192: Removing TransactionFunctionService

This internal class was added for a use case that is no longer
supported. It has a bug, in that the client may never have connected to
the server that it supposed to be able to look up and invoke the
function on. Deleting the class rather than trying to fix the bug
because the class is no longer needed.


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

Branch: refs/heads/feature/GEODE-77
Commit: 3fc29923007f92011f4bfd4e985d1854536a98cb
Parents: e8ddd33
Author: Dan Smith <up...@apache.org>
Authored: Tue Oct 27 13:35:49 2015 -0700
Committer: Dan Smith <up...@apache.org>
Committed: Tue Nov 17 10:53:56 2015 -0800

----------------------------------------------------------------------
 .../client/internal/EndpointManagerImpl.java    |   2 -
 .../cache/execute/ServerFunctionExecutor.java   |  18 --
 .../execute/TransactionFunctionService.java     | 193 -------------------
 .../cache/execute/util/CommitFunction.java      |   1 -
 .../cache/execute/util/RollbackFunction.java    |   1 -
 .../cache/ClientServerTransactionDUnitTest.java |  31 +--
 6 files changed, 8 insertions(+), 238 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3fc29923/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/EndpointManagerImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/EndpointManagerImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/EndpointManagerImpl.java
index 5c03be8..853ab36 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/EndpointManagerImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/EndpointManagerImpl.java
@@ -34,7 +34,6 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.ServerLocation;
 import com.gemstone.gemfire.internal.DummyStatisticsFactory;
 import com.gemstone.gemfire.internal.cache.PoolStats;
-import com.gemstone.gemfire.internal.cache.execute.TransactionFunctionService;
 import com.gemstone.gemfire.internal.cache.tier.InternalClientMembership;
 import com.gemstone.gemfire.internal.logging.LogService;
 
@@ -59,7 +58,6 @@ public class EndpointManagerImpl implements EndpointManager {
     this.cancelCriterion = cancelCriterion;
     this.poolStats = poolStats;
     listener.addListener(new EndpointListenerForBridgeMembership());
-    listener.addListener(new TransactionFunctionService.ListenerForTransactionFunctionService());
   }
   
   /* (non-Javadoc)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3fc29923/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
index ba87bb5..bf00268 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/ServerFunctionExecutor.java
@@ -45,8 +45,6 @@ public class ServerFunctionExecutor extends AbstractExecution {
 
   private final boolean allServers;
   
-  private boolean onBehalfOfTXFunctionService;
-
   private String[] groups;
 
   public ServerFunctionExecutor(Pool p, boolean allServers, String... groups) {
@@ -68,7 +66,6 @@ public class ServerFunctionExecutor extends AbstractExecution {
       this.pool = sfe.pool;
     }
     this.allServers = sfe.allServers;
-    this.onBehalfOfTXFunctionService = sfe.onBehalfOfTXFunctionService;
     this.groups = sfe.groups;
   }
   
@@ -114,9 +111,6 @@ public class ServerFunctionExecutor extends AbstractExecution {
     }
     } finally {
       UserAttributes.userAttributes.set(null);
-      if (isOnBehalfOfTXFunctionService()) {
-        pool.releaseServerAffinity();
-      }
     }
   }
 
@@ -148,9 +142,6 @@ public class ServerFunctionExecutor extends AbstractExecution {
     }
     finally {
       UserAttributes.userAttributes.set(null);
-      if (isOnBehalfOfTXFunctionService()) {
-        pool.releaseServerAffinity();
-      }
     }
 
   }
@@ -434,13 +425,4 @@ public class ServerFunctionExecutor extends AbstractExecution {
       return executeFunction(functionObject);      
     }
   }
-
-  public void setOnBehalfOfTXFunctionService(boolean onBehalfOfTXFunctionService) {
-    this.onBehalfOfTXFunctionService = onBehalfOfTXFunctionService;
-  }
-
-  public boolean isOnBehalfOfTXFunctionService() {
-    return onBehalfOfTXFunctionService;
-  }
-  
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3fc29923/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/TransactionFunctionService.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/TransactionFunctionService.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/TransactionFunctionService.java
deleted file mode 100644
index e56e647..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/TransactionFunctionService.java
+++ /dev/null
@@ -1,193 +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.execute;
-
-import java.util.Collection;
-import java.util.Iterator;
-import java.util.Map;
-import java.util.concurrent.ConcurrentHashMap;
-import java.util.concurrent.ConcurrentMap;
-
-import com.gemstone.gemfire.cache.TransactionDataNodeHasDepartedException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.internal.Endpoint;
-import com.gemstone.gemfire.cache.client.internal.EndpointManager;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PoolManagerImpl;
-import com.gemstone.gemfire.internal.cache.TXId;
-import com.gemstone.gemfire.internal.cache.execute.util.CommitFunction;
-import com.gemstone.gemfire.internal.cache.execute.util.RollbackFunction;
-
-/**
- * Access point for executing functions that should be targeted to
- * execute on member where the transaction is hosted.
- * </p> To commit a transaction which is not hosted locally, this
- * functionService can be used to obtain an execution object on which
- * {@link CommitFunction} and {@link RollbackFunction} can be called.
- * 
- * @author sbawaska
- * @since 6.6.1
- */
-public final class TransactionFunctionService {
-
-  private TransactionFunctionService() {
-  }
-
-  /**
-   * This is a convenience method to obtain execution objects for transactional
-   * functions. This method can be invoked from clients as well as peer members.
-   * When invoked from a client this method makes sure that the function is
-   * executed on the member where the transaction is hosted. This prevents the
-   * need for fanning out the function to multiple servers. e.g. A remotely
-   * hosted transaction can be committed as:
-   * 
-   * <pre>
-   * Execution exe = TransactionFunctionService.onTransaction(txId);
-   * List l = (List) exe.execute(transactionalFunction).getResult();
-   * </pre>
-   * 
-   * @param transactionId
-   *          the transaction identifier
-   * @return the execution object
-   * @see CommitFunction
-   * @see RollbackFunction
-   * @since 6.6.1
-   */
-  public static Execution onTransaction(TransactionId transactionId) {
-    Execution execution = null;
-    GemFireCacheImpl cache = GemFireCacheImpl
-        .getExisting("getting transaction execution");
-    if (cache.hasPool()) {
-      if (cache.getLoggerI18n().fineEnabled()) {
-        cache.getLoggerI18n().fine("TxFunctionService: inClientMode");
-      }
-      PoolImpl pool = (PoolImpl) getPool(cache);
-      
-      DistributedMember member = ((TXId)transactionId).getMemberId();
-      ServerLocation loc = memberToServerLocation.get(member);
-      if (loc == null) {
-        loc = getServerLocationForMember(pool, member);
-        if (loc == null) {
-          throw new TransactionDataNodeHasDepartedException("Could not connect to member:"+member);
-        }
-        memberToServerLocation.put(member, loc);
-      }
-      // setup server affinity so that the function is executed
-      // on the member hosting the transaction
-      pool.setupServerAffinity(false/*allowFailover*/);
-      pool.setServerAffinityLocation(loc);
-      if (cache.getLoggerI18n().fineEnabled()) {
-        cache.getLoggerI18n().fine(
-            "TxFunctionService: setting server affinity to:" + loc
-                + " which represents member:" + member);
-      }
-      execution = FunctionService.onServer(pool).withArgs(
-          transactionId);
-      // this serverAffinity is cleared up in the finally blocks
-      // of ServerFunctionExecutor
-      ((ServerFunctionExecutor)execution).setOnBehalfOfTXFunctionService(true);
-    } else {
-      if (cache.getLoggerI18n().fineEnabled()) {
-        cache.getLoggerI18n().fine("TxFunctionService: inPeerMode");
-      }
-      TXId txId = (TXId) transactionId;
-      DistributedMember member = txId.getMemberId();
-      execution = FunctionService
-          .onMember(cache.getDistributedSystem(), member).withArgs(
-              transactionId);
-    }
-    return execution;
-  }
-  
-  /**
-   * keep a mapping of DistributedMemeber to ServerLocation so that we can still
-   * connect to the same server when the poolLoadConditioningMonitor closes
-   * connection. fix for bug 43810
-   */
-  private static final ConcurrentMap<DistributedMember, ServerLocation> memberToServerLocation =
-    new ConcurrentHashMap<DistributedMember, ServerLocation>();
-  
-  /**
-   * Get the ServerLocation corresponding to the given DistributedMember
-   * or null if there is no endPoint to the member
-   * @param pool
-   * @param member
-   */
-  private static ServerLocation getServerLocationForMember(PoolImpl pool,
-      DistributedMember member) {
-    Map<ServerLocation, Endpoint> endPoints = pool.getEndpointMap();
-    for (Endpoint endPoint : endPoints.values()) {
-      if (endPoint.getMemberId().equals(member)) {
-        return endPoint.getLocation();
-      }
-    }
-    return null;
-  }
-
-  private static Pool getPool(GemFireCacheImpl cache) {
-    Pool pool = cache.getDefaultPool();
-    if (pool == null) {
-      Collection<Pool> pools = getPools();
-      if (pools.size() > 1) {
-        throw new IllegalStateException("More than one pools found");
-      }
-      pool = pools.iterator().next();
-    }
-    return pool;
-  }
-  
-  private static Collection<Pool> getPools() {
-    Collection<Pool> pools = PoolManagerImpl.getPMI().getMap().values();
-    for(Iterator<Pool> itr= pools.iterator(); itr.hasNext(); ) {
-      PoolImpl pool = (PoolImpl) itr.next();
-      if(pool.isUsedByGateway()) {
-        itr.remove();
-      }
-    }
-    return pools;
-  }
-  
-  /**
-   * When an EndPoint becomes available we remember the mapping of
-   * DistributedMember to ServerLocation so that we can reconnect to the server.
-   * fix for bug 43817
-   * 
-   * @author sbawaska
-   */
-  public static class ListenerForTransactionFunctionService implements
-      EndpointManager.EndpointListener {
-
-    public void endpointNoLongerInUse(Endpoint endpoint) {
-    }
-
-    public void endpointCrashed(Endpoint endpoint) {
-    }
-
-    public void endpointNowInUse(Endpoint endpoint) {
-      assert endpoint != null;
-      memberToServerLocation.put(endpoint.getMemberId(),
-          endpoint.getLocation());
-    }
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3fc29923/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
index bafafa9..b0f4d93 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
@@ -34,7 +34,6 @@ import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
 import com.gemstone.gemfire.cache.execute.FunctionService;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.internal.cache.TXId;
-import com.gemstone.gemfire.internal.cache.execute.TransactionFunctionService;
 import com.gemstone.gemfire.internal.logging.LogService;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3fc29923/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
index 7dbfc62..459cd47 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
@@ -33,7 +33,6 @@ import com.gemstone.gemfire.cache.execute.FunctionException;
 import com.gemstone.gemfire.cache.execute.FunctionService;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.internal.cache.TXId;
-import com.gemstone.gemfire.internal.cache.execute.TransactionFunctionService;
 import com.gemstone.gemfire.internal.logging.LogService;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3fc29923/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
index b361110..b5e8437 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
@@ -17,6 +17,7 @@
 package com.gemstone.gemfire.internal.cache;
 
 import java.util.ArrayList;
+import java.util.Arrays;
 import java.util.HashMap;
 import java.util.HashSet;
 import java.util.Iterator;
@@ -39,6 +40,7 @@ import com.gemstone.gemfire.cache.client.ClientCache;
 import com.gemstone.gemfire.cache.client.ClientCacheFactory;
 import com.gemstone.gemfire.cache.client.ClientRegionFactory;
 import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
+import com.gemstone.gemfire.cache.client.Pool;
 import com.gemstone.gemfire.cache.client.PoolFactory;
 import com.gemstone.gemfire.cache.client.PoolManager;
 import com.gemstone.gemfire.cache.execute.Execution;
@@ -56,7 +58,6 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.AvailablePort;
-import com.gemstone.gemfire.internal.cache.execute.TransactionFunctionService;
 import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.Customer;
 import com.gemstone.gemfire.internal.cache.execute.data.Order;
@@ -2607,22 +2608,6 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
     }
   }
   
-  class TestCommitFunction extends FunctionAdapter {
-    @Override
-    public void execute(FunctionContext context) {
-      CacheTransactionManager mgr = getCache().getCacheTransactionManager();
-      TransactionId txId = (TransactionId) context.getArguments();
-      assertTrue(mgr.isSuspended(txId));
-      mgr.resume(txId);
-      mgr.commit();
-      context.getResultSender().lastResult(Boolean.TRUE);
-    }
-    @Override
-    public String getId() {
-      return "CommitFunction";
-    }
-  }
-  
   public void testBasicResumableTX() {
     disconnectAllFromDS();
     Host host = Host.getHost(0);
@@ -2649,7 +2634,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         result = (List) FunctionService.onRegion(cust).withArgs(args).execute(new TXFunction()).getResult();
         TransactionId txId2 = (TransactionId) result.get(0);
         assertEquals(txId, txId2);
-        result = (List) TransactionFunctionService.onTransaction(txId).execute(new TestCommitFunction()).getResult();
+        result = (List) FunctionService.onServer(getCache()).withArgs(txId).execute(new CommitFunction()).getResult();
         Boolean b = (Boolean) result.get(0);
         assertEquals(Boolean.TRUE, b);
         assertEquals(new Customer("name0", "address0"), cust.get(new CustId(0)));
@@ -2667,8 +2652,8 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
   public void testClientCommitFunction() {
     doFunctionWork(true);
   }
-  @Ignore("Bug 52331")
-  public void DISABLED_testClientRollbackFunction() {
+  
+  public void testClientRollbackFunction() {
     doFunctionWork(false);
   }
   private void doFunctionWork(final boolean commit) {
@@ -2741,9 +2726,9 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
           }
           List list = null;
           if (commit) {
-            list = (List) TransactionFunctionService.onTransaction(txId).execute(new CommitFunction()).getResult();
+            list = (List) FunctionService.onServer(getCache()).withArgs(txId).execute(new CommitFunction()).getResult();
           } else {
-            list = (List) TransactionFunctionService.onTransaction(txId).execute(new RollbackFunction()).getResult();
+            list = (List) FunctionService.onServer(getCache()).withArgs(txId).execute(new RollbackFunction()).getResult();
           }
           assertEquals(Boolean.TRUE, list.get(0));
           if (commit) {
@@ -2889,7 +2874,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
     
     accessor.invoke(new SerializableCallable() {
       public Object call() throws Exception {
-        Execution exe = TransactionFunctionService.onTransaction(txId);
+        Execution exe = FunctionService.onMember(((TXId) txId).getMemberId()).withArgs(txId);
         List list = null;
         if (commit) {
           list = (List) exe.execute(new CommitFunction()).getResult();


[17/50] [abbrv] incubator-geode git commit: GEODE-534: change test to not use disabled cipher

Posted by bs...@apache.org.
GEODE-534: change test to not use disabled cipher


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

Branch: refs/heads/feature/GEODE-77
Commit: 2933ccd111ec9f54165acaeb421e920e2d27561c
Parents: 4103c1e
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Fri Nov 6 10:46:14 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Fri Nov 6 13:27:12 2015 -0800

----------------------------------------------------------------------
 .../java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java    | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2933ccd1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
index c5ae1a1..44d8a4e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
@@ -102,7 +102,7 @@ public class JSSESocketJUnitTest {
       System.setProperty( "gemfire.mcast-port", "0");
       System.setProperty( "gemfire.ssl-enabled", "true" );
       System.setProperty( "gemfire.ssl-require-authentication", "true" );
-      System.setProperty( "gemfire.ssl-ciphers", "SSL_RSA_WITH_RC4_128_MD5" );
+      System.setProperty( "gemfire.ssl-ciphers", "any" );
       System.setProperty( "gemfire.ssl-protocols", "TLSv1.2" );
       
       File jks = findTestJKS();


[19/50] [abbrv] incubator-geode git commit: GEODE-535: change test to start server on port 0

Posted by bs...@apache.org.
GEODE-535: change test to start server on port 0


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

Branch: refs/heads/feature/GEODE-77
Commit: cfbeaf241d6c77ad47ba062bb4268c88b798ce90
Parents: 06509f3
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Fri Nov 6 13:56:13 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Fri Nov 6 13:56:13 2015 -0800

----------------------------------------------------------------------
 .../gemfire/distributed/internal/ProductUseLogDUnitTest.java      | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/cfbeaf24/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
index b16ed2d..8abd7d6 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
@@ -71,7 +71,8 @@ public class ProductUseLogDUnitTest extends DistributedTestCase {
       public void run() {
         InternalDistributedSystem system = getSystem();
         Cache cache = CacheFactory.create(system);
-        CacheServer server = cache.addCacheServer();
+        CacheServer server = cache.addCacheServer();
+        server.setPort(0);
         try {
           server.start();
         } catch (IOException e) {


[11/50] [abbrv] incubator-geode git commit: GEODE-532 Remove testDefaults in BasicI18nJUnitTest

Posted by bs...@apache.org.
GEODE-532 Remove testDefaults in BasicI18nJUnitTest


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

Branch: refs/heads/feature/GEODE-77
Commit: 66d9da67570ed915ad4e479a94c7b1c3c081d6d8
Parents: e9aa18b
Author: shtykh_roman <rs...@yahoo.com>
Authored: Fri Nov 6 11:13:21 2015 +0900
Committer: shtykh_roman <rs...@yahoo.com>
Committed: Fri Nov 6 11:13:21 2015 +0900

----------------------------------------------------------------------
 .../gemfire/internal/i18n/BasicI18nJUnitTest.java       | 12 ------------
 1 file changed, 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/66d9da67/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
index 806c51e..28934b3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
@@ -209,18 +209,6 @@ public class BasicI18nJUnitTest extends TestCase {
     StringIdImpl.setLocale(DEFAULT_LOCALE);
   }
 
-  public void testDefaults() {
-    Locale l = getCurrentLocale();
-    AbstractStringIdResourceBundle r = getActiveResourceBundle();
-    assertNotNull(l);
-    assertNotNull(r);
-    final String currentLang = l.getLanguage();
-    final String expectedLang = new Locale("en", "", "").getLanguage();
-    final String frenchLang = new Locale("fr", "", "").getLanguage();
-    // TODO this will fail if run under a locale with a language other than french or english
-    assertTrue(currentLang.equals(expectedLang) || currentLang.equals(frenchLang));
-  }
-
   public void testSetLocale() {
     //Verify we are starting in a known state
     assertTrue(DEFAULT_LOCALE.equals(getCurrentLocale()));


[09/50] [abbrv] incubator-geode git commit: GEODE-500: fix race in OffHeapMemoryUsageListener

Posted by bs...@apache.org.
GEODE-500: fix race in OffHeapMemoryUsageListener

A race in the run loop existed that caused the usage
listener to quit delivering off-heap events.
This should fix a number of intermittent off-heap
resource manager bugs.


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

Branch: refs/heads/feature/GEODE-77
Commit: e1f653056e70e71116d2ec681b262bb4480721f1
Parents: c67a08f
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Wed Nov 4 17:20:42 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Nov 5 16:26:35 2015 -0800

----------------------------------------------------------------------
 .../cache/control/OffHeapMemoryMonitor.java        | 17 +++++++++++++----
 1 file changed, 13 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e1f65305/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
index bbdb27a..0a6674c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
@@ -511,11 +511,20 @@ public class OffHeapMemoryMonitor implements ResourceMonitor, MemoryUsageListene
         updateStateAndSendEvent(lastOffHeapMemoryUsed);
 
         synchronized (this) {
-          if (lastOffHeapMemoryUsed == this.offHeapMemoryUsed && !this.stopRequested) {
-            try {
+          long newOffHeapMemoryUsed = this.offHeapMemoryUsed;
+          if (this.stopRequested) {
+            // no need to wait since we are stopping
+          } else if (lastOffHeapMemoryUsed != newOffHeapMemoryUsed) {
+            // no need to wait since memory used has changed
+            // This fixes a race like bug GEODE-500
+            lastOffHeapMemoryUsed = newOffHeapMemoryUsed;
+          } else {
+            // wait for memory used to change
+            try {  
               do {
                 this.wait(1000);
-                if (this.offHeapMemoryUsed == lastOffHeapMemoryUsed) {
+                newOffHeapMemoryUsed = this.offHeapMemoryUsed;
+                if (newOffHeapMemoryUsed == lastOffHeapMemoryUsed) {
                   // The wait timed out. So tell the OffHeapMemoryMonitor
                   // that we need an event if the state is not normal.
                   deliverNextAbnormalEvent();
@@ -536,7 +545,7 @@ public class OffHeapMemoryMonitor implements ResourceMonitor, MemoryUsageListene
                 } else {
                   // we have been notified so exit the inner while loop
                   // and call updateStateAndSendEvent.
-                  lastOffHeapMemoryUsed = this.offHeapMemoryUsed;
+                  lastOffHeapMemoryUsed = newOffHeapMemoryUsed;
                   break;
                 }
               } while (!this.stopRequested);


[45/50] [abbrv] incubator-geode git commit: GEODE-151: Convert to use Gradle Git plugin

Posted by bs...@apache.org.
GEODE-151: Convert to use Gradle Git plugin

The build was using the executable git command to populate version
information, which created big blocks of Gradle code and could be
unstable. All Git executable commands have been changed to use the
Gradle Git plugin. If directory is not a valid Git workspace, then
it will log a warning and use default values to populate version
information.

Tested with and without Git workspace


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

Branch: refs/heads/feature/GEODE-77
Commit: c7024bd846e5075fe87b1b2b6c1707950241370b
Parents: 88da702
Author: Mark Bretl <mb...@pivotal.io>
Authored: Mon Nov 16 10:44:50 2015 -0800
Committer: Mark Bretl <mb...@pivotal.io>
Committed: Mon Nov 16 12:16:58 2015 -0800

----------------------------------------------------------------------
 build.gradle              | 13 +++++++++-
 gemfire-core/build.gradle | 59 +++++++-----------------------------------
 2 files changed, 22 insertions(+), 50 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c7024bd8/build.gradle
----------------------------------------------------------------------
diff --git a/build.gradle b/build.gradle
index e3b1033..a186710 100755
--- a/build.gradle
+++ b/build.gradle
@@ -1,5 +1,15 @@
-apply plugin: 'wrapper'
+buildscript {
+  repositories {
+    maven {
+      url "https://plugins.gradle.org/m2/"
+    }
+  }
+  dependencies {
+    classpath "org.ajoberstar:gradle-git:1.3.2"
+  }
+}
 
+apply plugin: 'wrapper'
 
 // Load all properties in dependency-version.properties as project properties, so all projects can read them
 Properties dependencyVersions = new Properties()
@@ -25,6 +35,7 @@ allprojects {
 
   group = "org.apache.geode"
 
+  apply plugin: 'org.ajoberstar.grgit'
   apply plugin: 'idea'
   apply plugin: 'eclipse'
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c7024bd8/gemfire-core/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-core/build.gradle b/gemfire-core/build.gradle
index 80761ed..f03066f 100755
--- a/gemfire-core/build.gradle
+++ b/gemfire-core/build.gradle
@@ -99,55 +99,16 @@ task createVersionPropertiesFile {
   inputs.dir compileJava.destinationDir
 
   doLast {
-    new ByteArrayOutputStream().withStream { gitWorkspaceStream ->
-      def result = exec {
-        workingDir = "${projectDir}"
-        standardOutput = gitWorkspaceStream
-        ignoreExitValue = true
-        executable = "git"
-        args = ['rev-parse', '--is-inside-work-tree']
-      }
-      ext.isGitWorkspace = gitWorkspaceStream.toString()
-      ext.isGitWorkspace = ext.isGitWorkspace.trim()
-    }
 
-    if ( isGitWorkspace.equalsIgnoreCase('true') ) {
-      new ByteArrayOutputStream().withStream { gitBranchStream ->
-        def result = exec {
-          workingDir = "${projectDir}"
-          standardOutput = gitBranchStream
-          executable = "git"
-          args = ['rev-parse', '--abbrev-ref', 'HEAD']
-        }
-        ext.gitBranchString = gitBranchStream.toString()
-        ext.gitBranch = ext.gitBranchString.trim()
-      }
-
-      new ByteArrayOutputStream().withStream { commitStream ->
-        def result = exec {
-          workingDir = "${projectDir}"
-          standardOutput = commitStream
-          executable = "git"
-          args = ['rev-parse', 'HEAD']
-        }
-        ext.commitIdString = commitStream.toString()
-        ext.commitId = ext.commitIdString.trim()
-      }
-
-      new ByteArrayOutputStream().withStream { sourceDateStream ->
-        def result = exec {
-          workingDir = "${projectDir}"
-          standardOutput = sourceDateStream
-          executable = "git"
-          args = ['show', '-s', '--format=%ci', "${ext.commitId}"]
-        }
-        ext.sourceDateString = sourceDateStream.toString()
-        ext.sourceDate = ext.sourceDateString.trim()
-      }
-    }
-    else {
-      // Not in SCM workspace, use default values
-      ext.gitBranch = 'UNKNOWN'
+    try {
+      def grgit = org.ajoberstar.grgit.Grgit.open()
+      ext.branch = grgit.branch.getCurrent().name
+      ext.commitId = grgit.head().id
+      ext.sourceDate = grgit.head().getDate().format('yyyy-MM-dd HH:mm:ss Z')
+      grgit.close()
+    } catch (Exception e) {
+      logger.warn( '***** Unable to find Git workspace. Using default version information *****' )
+      ext.branch = 'UNKNOWN'
       ext.commitId = 'UNKNOWN'
       ext.sourceDate = new Date().format('yyyy-MM-dd HH:mm:ss Z')
     }
@@ -168,7 +129,7 @@ task createVersionPropertiesFile {
       "Build-Java-Version": ext.jdkVersion,
       "Source-Date"       : ext.sourceDate,
       "Source-Revision"   : ext.commitId,
-      "Source-Repository" : ext.gitBranch
+      "Source-Repository" : ext.branch
     ] as Properties
 
     propertiesFile.getParentFile().mkdirs();


[35/50] [abbrv] incubator-geode git commit: GEODE-540: prevent hang by not joining while synchronized

Posted by bs...@apache.org.
GEODE-540: prevent hang by not joining while synchronized


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

Branch: refs/heads/feature/GEODE-77
Commit: 8b04c3d7f24cc5d3cb6ab9739c698c5996e17381
Parents: 05e047c
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Wed Nov 11 16:09:41 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Wed Nov 11 16:32:02 2015 -0800

----------------------------------------------------------------------
 .../cache/control/OffHeapMemoryMonitor.java        | 17 ++++++++++-------
 1 file changed, 10 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8b04c3d7/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
index 0a6674c..721e9a6 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/OffHeapMemoryMonitor.java
@@ -115,6 +115,7 @@ public class OffHeapMemoryMonitor implements ResourceMonitor, MemoryUsageListene
     stopMonitoring(false);
   }
   public void stopMonitoring(boolean waitForThread) {
+    Thread threadToWaitFor = null;
     synchronized (this) {
       if (!this.started) {
         return;
@@ -126,17 +127,19 @@ public class OffHeapMemoryMonitor implements ResourceMonitor, MemoryUsageListene
       synchronized (this.offHeapMemoryUsageListener) {
         this.offHeapMemoryUsageListener.notifyAll();
       }
-
-      if (waitForThread && this.memoryListenerThread != null) {
-        try {
-          this.memoryListenerThread.join();
-        } catch (InterruptedException e) {
-          Thread.currentThread().interrupt();
-        }
+      if (waitForThread) {
+        threadToWaitFor = this.memoryListenerThread;
       }
       this.memoryListenerThread = null;
       this.started = false;
     }
+    if (threadToWaitFor != null) {
+      try {
+        threadToWaitFor.join();
+      } catch (InterruptedException e) {
+        Thread.currentThread().interrupt();
+      }
+    }
   }
 
   public volatile OffHeapMemoryMonitorObserver testHook;


[44/50] [abbrv] incubator-geode git commit: GEODE-542: Send a function response after a CancelException

Posted by bs...@apache.org.
GEODE-542: Send a function response after a CancelException

There was a catch clause of a CancelException that was causing us not to
reply to a function call if a CacheClosedException was thrown from the
function. That caused as hang waiting for replies.


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

Branch: refs/heads/feature/GEODE-77
Commit: 88da702593157d8a0c014295cab16149fc088dfc
Parents: 5a0d43e
Author: Dan Smith <up...@apache.org>
Authored: Wed Nov 11 12:24:16 2015 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Fri Nov 13 15:22:42 2015 -0800

----------------------------------------------------------------------
 .../cache/MemberFunctionStreamingMessage.java   |  9 ++--
 .../MemberFunctionExecutionDUnitTest.java       | 49 ++++++++++++++++++++
 2 files changed, 54 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/88da7025/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/MemberFunctionStreamingMessage.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/MemberFunctionStreamingMessage.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/MemberFunctionStreamingMessage.java
index 9ea6f28..b3bdc85 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/MemberFunctionStreamingMessage.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/MemberFunctionStreamingMessage.java
@@ -32,6 +32,7 @@ import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.execute.Function;
 import com.gemstone.gemfire.cache.execute.FunctionException;
+import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
 import com.gemstone.gemfire.cache.execute.FunctionService;
 import com.gemstone.gemfire.cache.execute.ResultSender;
 import com.gemstone.gemfire.cache.query.QueryException;
@@ -213,10 +214,10 @@ public class MemberFunctionStreamingMessage extends DistributionMessage implemen
       // bug 37026: this is too noisy...
       // throw new CacheClosedException("remote system shutting down");
       // thr = se; cache is closed, no point trying to send a reply
-      thr = null;
-      if (logger.isDebugEnabled()) {
-        logger.debug("shutdown caught, abandoning message: {}",exception.getMessage(), exception);
-      }
+      thr = new FunctionInvocationTargetException(exception);
+      stats.endFunctionExecutionWithException(this.functionObject.hasResult());
+      rex = new ReplyException(thr);
+      replyWithException(dm, rex);
     }
     catch (Exception exception) {
       if (logger.isDebugEnabled()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/88da7025/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
index 129cd18..4b8f009 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
@@ -25,12 +25,16 @@ import java.util.List;
 import java.util.Map;
 import java.util.Properties;
 import java.util.Set;
+import java.util.concurrent.TimeUnit;
 
+import com.gemstone.gemfire.cache.CacheClosedException;
+import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.cache.execute.Execution;
 import com.gemstone.gemfire.cache.execute.Function;
 import com.gemstone.gemfire.cache.execute.FunctionAdapter;
 import com.gemstone.gemfire.cache.execute.FunctionContext;
 import com.gemstone.gemfire.cache.execute.FunctionException;
+import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
 import com.gemstone.gemfire.cache.execute.FunctionService;
 import com.gemstone.gemfire.cache.execute.ResultCollector;
 import com.gemstone.gemfire.cache30.CacheTestCase;
@@ -46,6 +50,8 @@ import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 
 import dunit.Host;
+import dunit.SerializableCallable;
+import dunit.SerializableRunnable;
 import dunit.VM;
 
 public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
@@ -300,6 +306,49 @@ public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
     member1.invoke(MemberFunctionExecutionDUnitTest.class, "bug41118");
   }
   
+  public void testOnMembersWithoutCache()
+      throws Exception {
+    DistributedMember member1Id = (DistributedMember) member1.invoke(new SerializableCallable() {
+      
+      @Override
+      public Object call() {
+        disconnectFromDS();
+        return getSystem().getDistributedMember();
+      }
+    });
+    
+    member2.invoke(new SerializableRunnable() {
+      
+      @Override
+      public void run() {
+        getSystem();
+        ResultCollector<?, ?> rc = FunctionService.onMember(member1Id).execute(new FunctionAdapter() {
+          
+          @Override
+          public String getId() {
+            return getClass().getName();
+          }
+          
+          @Override
+          public void execute(FunctionContext context) {
+            //This will throw an exception because the cache is not yet created.
+            CacheFactory.getAnyInstance();
+          }
+        });
+        
+        try {
+          rc.getResult(30, TimeUnit.SECONDS);
+          fail("Should have seen an exception");
+        } catch (Exception e) {
+          if(!(e.getCause() instanceof FunctionInvocationTargetException)) {
+            fail("failed", e);
+          }
+        }
+        
+      }
+    });
+  }
+  
   public static void bug41118(){
     ds = new MemberFunctionExecutionDUnitTest("temp").getSystem();
     assertNotNull(ds);


[34/50] [abbrv] incubator-geode git commit: Merge branch 'feature/GEODE-11' into develop

Posted by bs...@apache.org.
Merge branch 'feature/GEODE-11' into develop


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

Branch: refs/heads/feature/GEODE-77
Commit: 05e047cafdfa76100b92ae2239ef1f839552f5ea
Parents: 79aa0be 3af1540
Author: Ashvin Agrawal <as...@apache.org>
Authored: Wed Nov 11 13:22:31 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Wed Nov 11 13:22:31 2015 -0800

----------------------------------------------------------------------
 gemfire-core/build.gradle                       |   4 -
 .../gemstone/gemfire/cache/GemFireCache.java    |   7 -
 .../internal/AsyncEventQueueFactoryImpl.java    |   9 +-
 .../internal/AsyncEventQueueImpl.java           |   3 +
 .../gemfire/cache/lucene/LuceneIndex.java       |  59 --
 .../gemfire/cache/lucene/LuceneQuery.java       |  53 --
 .../cache/lucene/LuceneQueryFactory.java        | 137 -----
 .../cache/lucene/LuceneQueryResults.java        |  45 --
 .../cache/lucene/LuceneResultStruct.java        |  75 ---
 .../gemfire/cache/lucene/LuceneService.java     | 119 ----
 .../cache/lucene/LuceneServiceFactory.java      |  30 -
 .../cache/lucene/LuceneServiceProvider.java     |  52 --
 .../cache/lucene/internal/LuceneIndexImpl.java  |  70 ---
 .../lucene/internal/LuceneQueryFactoryImpl.java | 104 ----
 .../cache/lucene/internal/LuceneQueryImpl.java  |  78 ---
 .../lucene/internal/LuceneQueryResultsImpl.java |  82 ---
 .../lucene/internal/LuceneResultStructImpl.java |  61 --
 .../internal/LuceneServiceFactoryImpl.java      |  32 -
 .../lucene/internal/LuceneServiceImpl.java      | 106 ----
 .../internal/DataSerializableFixedID.java       |   9 +
 .../gemfire/internal/cache/BucketRegion.java    |   2 +-
 .../gemfire/internal/cache/CacheService.java    |  26 +
 .../internal/cache/GemFireCacheImpl.java        |  79 ++-
 .../gemfire/internal/cache/InternalCache.java   |   5 +-
 .../gemfire/internal/cache/LocalRegion.java     |   8 +-
 .../cache/PartitionedRegionDataStore.java       |   2 +-
 .../gemfire/internal/cache/RegionListener.java  |  30 +
 .../cache/extension/SimpleExtensionPoint.java   |   2 +-
 .../cache/wan/AbstractGatewaySender.java        |   7 +
 .../cache/wan/GatewaySenderAttributes.java      |   5 +
 .../internal/cache/xmlcache/CacheCreation.java  |  14 +-
 .../cache/xmlcache/DefaultEntityResolver2.java  |   2 +-
 .../cache/xmlcache/GeodeEntityResolver.java     |  49 ++
 .../cache/xmlcache/PivotalEntityResolver.java   |   2 +-
 .../util/concurrent/CopyOnWriteHashMap.java     |  46 +-
 .../util/concurrent/CopyOnWriteWeakHashMap.java |  12 +
 .../services/org.xml.sax.ext.EntityResolver2    |   1 +
 .../internal/cache/CacheServiceJUnitTest.java   |  43 ++
 .../internal/cache/MockCacheService.java        |   8 +
 .../internal/cache/MockCacheServiceImpl.java    |  23 +
 .../internal/cache/RegionListenerJUnitTest.java |  47 ++
 .../mock/DestroyMockCacheExtensionFunction.java |   2 +-
 .../concurrent/CopyOnWriteHashMapJUnitTest.java | 496 ++++++++++++++++
 ...gemstone.gemfire.internal.cache.CacheService |   1 +
 .../codeAnalysis/sanctionedSerializables.txt    |   2 +-
 gemfire-lucene/build.gradle                     |  29 +
 .../gemfire/cache/lucene/LuceneIndex.java       |  60 ++
 .../gemfire/cache/lucene/LuceneQuery.java       |  48 ++
 .../cache/lucene/LuceneQueryFactory.java        | 101 ++++
 .../cache/lucene/LuceneQueryProvider.java       |  45 ++
 .../cache/lucene/LuceneQueryResults.java        |  58 ++
 .../cache/lucene/LuceneResultStruct.java        |  62 ++
 .../gemfire/cache/lucene/LuceneService.java     | 125 ++++
 .../cache/lucene/LuceneServiceProvider.java     |  46 ++
 .../lucene/internal/InternalLuceneIndex.java    |  29 +
 .../lucene/internal/InternalLuceneService.java  |  29 +
 .../lucene/internal/LuceneEventListener.java    |  99 ++++
 .../LuceneIndexForPartitionedRegion.java        | 136 +++++
 .../LuceneIndexForReplicatedRegion.java         |  48 ++
 .../cache/lucene/internal/LuceneIndexImpl.java  | 107 ++++
 .../lucene/internal/LuceneQueryFactoryImpl.java |  67 +++
 .../cache/lucene/internal/LuceneQueryImpl.java  |  87 +++
 .../lucene/internal/LuceneQueryResultsImpl.java | 120 ++++
 .../lucene/internal/LuceneResultStructImpl.java |  94 +++
 .../lucene/internal/LuceneServiceImpl.java      | 273 +++++++++
 .../internal/PartitionedRepositoryManager.java  | 163 ++++++
 .../lucene/internal/StringQueryProvider.java    | 106 ++++
 .../internal/directory/FileIndexInput.java      | 131 +++++
 .../internal/directory/RegionDirectory.java     | 119 ++++
 .../internal/distributed/CollectorManager.java  |  55 ++
 .../lucene/internal/distributed/EntryScore.java |  82 +++
 .../internal/distributed/LuceneFunction.java    | 137 +++++
 .../distributed/LuceneFunctionContext.java      | 115 ++++
 .../lucene/internal/distributed/TopEntries.java | 133 +++++
 .../distributed/TopEntriesCollector.java        | 102 ++++
 .../distributed/TopEntriesCollectorManager.java | 178 ++++++
 .../TopEntriesFunctionCollector.java            | 163 ++++++
 .../lucene/internal/filesystem/ChunkKey.java    | 123 ++++
 .../cache/lucene/internal/filesystem/File.java  | 155 +++++
 .../internal/filesystem/FileInputStream.java    | 166 ++++++
 .../internal/filesystem/FileOutputStream.java   | 103 ++++
 .../lucene/internal/filesystem/FileSystem.java  | 156 +++++
 .../filesystem/SeekableInputStream.java         |  43 ++
 .../internal/repository/IndexRepository.java    |  74 +++
 .../repository/IndexRepositoryImpl.java         | 113 ++++
 .../repository/IndexResultCollector.java        |  47 ++
 .../internal/repository/RepositoryManager.java  |  45 ++
 .../HeterogenousLuceneSerializer.java           |  83 +++
 .../repository/serializer/LuceneSerializer.java |  35 ++
 .../serializer/PdxLuceneSerializer.java         |  47 ++
 .../serializer/ReflectionLuceneSerializer.java  |  74 +++
 .../repository/serializer/SerializerUtil.java   | 168 ++++++
 .../internal/xml/LuceneIndexCreation.java       | 111 ++++
 .../internal/xml/LuceneIndexXmlGenerator.java   |  65 +++
 .../internal/xml/LuceneServiceXmlGenerator.java |  39 ++
 .../lucene/internal/xml/LuceneXmlConstants.java |  31 +
 .../lucene/internal/xml/LuceneXmlParser.java    |  97 ++++
 .../lucene/lucene-1.0.xsd                       |  42 ++
 ...gemstone.gemfire.internal.cache.CacheService |   1 +
 ...ne.gemfire.internal.cache.xmlcache.XmlParser |   1 +
 .../internal/LuceneEventListenerJUnitTest.java  | 109 ++++
 .../LuceneIndexRecoveryHAJUnitTest.java         | 201 +++++++
 .../LuceneQueryFactoryImplJUnitTest.java        |  50 ++
 .../internal/LuceneQueryImplJUnitTest.java      | 123 ++++
 .../LuceneQueryResultsImplJUnitTest.java        | 126 ++++
 .../LuceneResultStructImpJUnitTest.java         |  51 ++
 .../internal/LuceneServiceImplJUnitTest.java    | 226 ++++++++
 .../PartitionedRepositoryManagerJUnitTest.java  | 230 ++++++++
 .../internal/StringQueryProviderJUnitTest.java  |  90 +++
 .../directory/RegionDirectoryJUnitTest.java     |  56 ++
 .../DistributedScoringJUnitTest.java            | 155 +++++
 .../distributed/EntryScoreJUnitTest.java        |  40 ++
 .../LuceneFunctionContextJUnitTest.java         |  64 ++
 .../distributed/LuceneFunctionJUnitTest.java    | 423 ++++++++++++++
 .../LuceneFunctionReadPathDUnitTest.java        | 241 ++++++++
 .../TopEntriesCollectorJUnitTest.java           | 139 +++++
 .../TopEntriesFunctionCollectorJUnitTest.java   | 323 +++++++++++
 .../distributed/TopEntriesJUnitTest.java        | 146 +++++
 .../internal/filesystem/ChunkKeyJUnitTest.java  |  48 ++
 .../internal/filesystem/FileJUnitTest.java      |  53 ++
 .../filesystem/FileSystemJUnitTest.java         | 578 +++++++++++++++++++
 ...IndexRepositoryImplJUnitPerformanceTest.java | 437 ++++++++++++++
 .../IndexRepositoryImplJUnitTest.java           | 208 +++++++
 .../HeterogenousLuceneSerializerJUnitTest.java  |  90 +++
 .../serializer/PdxFieldMapperJUnitTest.java     |  85 +++
 .../ReflectionFieldMapperJUnitTest.java         |  85 +++
 .../internal/repository/serializer/Type1.java   |  48 ++
 .../internal/repository/serializer/Type2.java   |  34 ++
 ...neIndexXmlGeneratorIntegrationJUnitTest.java |  78 +++
 .../xml/LuceneIndexXmlGeneratorJUnitTest.java   |  80 +++
 ...uceneIndexXmlParserIntegrationJUnitTest.java | 107 ++++
 .../xml/LuceneIndexXmlParserJUnitTest.java      |  72 +++
 ...erIntegrationJUnitTest.createIndex.cache.xml |  24 +
 ...serIntegrationJUnitTest.parseIndex.cache.xml |  24 +
 gradle/dependency-versions.properties           |   2 +-
 settings.gradle                                 |   1 +
 136 files changed, 10705 insertions(+), 1157 deletions(-)
----------------------------------------------------------------------



[47/50] [abbrv] incubator-geode git commit: GEODE-543: upgrade the Jline and Spring Shell libraries and fix the compilation erros

Posted by bs...@apache.org.
GEODE-543: upgrade the Jline and Spring Shell libraries and fix the compilation erros

Closes #34


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

Branch: refs/heads/feature/GEODE-77
Commit: 058aad3663cb00de3ac83f76b9c9b72a32952ca3
Parents: 3dc3add
Author: Jinmei Liao <ji...@pivotal.io>
Authored: Wed Nov 11 12:06:22 2015 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Mon Nov 16 13:13:55 2015 -0800

----------------------------------------------------------------------
 gemfire-core/build.gradle                       |   2 +-
 .../management/internal/cli/CliUtil.java        |   2 +-
 .../management/internal/cli/Launcher.java       |   4 +-
 .../internal/cli/commands/ShellCommands.java    |   4 +-
 .../management/internal/cli/shell/Gfsh.java     |  15 +-
 .../internal/cli/shell/jline/ANSIBuffer.java    | 433 +++++++++++++++++++
 .../internal/cli/shell/jline/ANSIHandler.java   |   5 +-
 .../cli/shell/jline/CygwinMinttyTerminal.java   | 137 +-----
 .../internal/cli/shell/jline/GfshHistory.java   |  13 +-
 .../shell/jline/GfshUnsupportedTerminal.java    |   2 +-
 .../internal/cli/util/CLIConsoleBufferUtil.java |   8 +-
 .../PersistentPartitionedRegionTestBase.java    |   2 +-
 gradle/dependency-versions.properties           |   4 +-
 13 files changed, 468 insertions(+), 163 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-core/build.gradle b/gemfire-core/build.gradle
index f03066f..aa83bb9 100755
--- a/gemfire-core/build.gradle
+++ b/gemfire-core/build.gradle
@@ -35,7 +35,7 @@ dependencies {
   compile 'mx4j:mx4j-remote:' + project.'mx4j.version'
   compile 'mx4j:mx4j-tools:' + project.'mx4j.version'
   compile 'net.java.dev.jna:jna:' + project.'jna.version'
-  compile 'net.sourceforge.jline:jline:' + project.'jline.version'
+  compile 'jline:jline:' + project.'jline.version'
   provided 'org.apache.hadoop:hadoop-common:' + project.'hadoop.version'
   provided 'org.apache.hadoop:hadoop-annotations:' + project.'hadoop.version'
   provided 'org.apache.hadoop:hadoop-hdfs:' + project.'hadoop.version'

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
index bc1f7b7..09f8bd8 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
@@ -105,7 +105,7 @@ public class CliUtil {
 
     if (includeGfshDependencies) {
       // ConsoleReader from jline
-      jarProductName = checkLibraryByLoadingClass("jline.ConsoleReader", "JLine");
+      jarProductName = checkLibraryByLoadingClass("jline.console.ConsoleReader", "JLine");
       if (jarProductName != null) {
         return jarProductName;
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
index 8bf1ce1..12e2c50 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
@@ -166,7 +166,7 @@ public final class Launcher {
           System.err.println(CliStrings.format(MSG_INVALID_COMMAND_OR_OPTION, CliUtil.arrayToString(args)));
           exitRequest = ExitShellRequest.FATAL_EXIT;
         } else {
-          if (!gfsh.executeCommand(commandLineCommand)) {
+          if (!gfsh.executeScriptLine(commandLineCommand)) {
               if (gfsh.getLastExecutionStatus() != 0) 
                 exitRequest = ExitShellRequest.FATAL_EXIT;
           } else if (gfsh.getLastExecutionStatus() != 0) {
@@ -224,7 +224,7 @@ public final class Launcher {
             String command = commandsToExecute.get(i);
             System.out.println(GfshParser.LINE_SEPARATOR + "(" + (i + 1) + ") Executing - " + command
                 + GfshParser.LINE_SEPARATOR);
-            if (!gfsh.executeCommand(command) || gfsh.getLastExecutionStatus() != 0) {
+            if (!gfsh.executeScriptLine(command) || gfsh.getLastExecutionStatus() != 0) {
               exitRequest = ExitShellRequest.FATAL_EXIT;
             }
           }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
index edab207..1bd7692 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
@@ -853,8 +853,8 @@ private void configureHttpsURLConnection(Map<String, String> sslConfigProps) thr
       int historySizeWordLength = historySizeString.length();
 
       GfshHistory gfshHistory = gfsh.getGfshHistory();
-      List<?> gfshHistoryList = gfshHistory.getHistoryList();
-      Iterator<?> it = gfshHistoryList.iterator();
+      //List<?> gfshHistoryList = gfshHistory.getHistoryList();
+      Iterator<?> it = gfshHistory.entries();
       boolean flagForLineNumbers = (saveHistoryTo != null && saveHistoryTo
           .length() > 0) ? false : true;
       long lineNumber = 0;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
index 1d14c5b..67a8ccb 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
@@ -36,9 +36,9 @@ import java.util.logging.Level;
 import java.util.logging.LogManager;
 import java.util.logging.Logger;
 
-import jline.ConsoleReader;
 import jline.Terminal;
 
+import jline.console.ConsoleReader;
 import org.springframework.shell.core.AbstractShell;
 import org.springframework.shell.core.CommandMarker;
 import org.springframework.shell.core.Converter;
@@ -380,7 +380,6 @@ public class Gfsh extends JLineShell {
   /**
    * See findResources in {@link AbstractShell}
    */
-  @Override
   protected Collection<URL> findResources(String resourceName) {
 //    return Collections.singleton(ClassPathLoader.getLatest().getResource(resourceName));
     return null;
@@ -420,7 +419,7 @@ public class Gfsh extends JLineShell {
    * @return true if execution is successful; false otherwise
    */
   @Override
-  public boolean executeCommand(final String line) {
+  public boolean executeScriptLine(final String line) {
     boolean success = false;
     String withPropsExpanded = line;
 
@@ -440,7 +439,7 @@ public class Gfsh extends JLineShell {
       if (gfshFileLogger.fineEnabled()) {
         gfshFileLogger.fine(logMessage + withPropsExpanded);
       }
-      success = super.executeCommand(withPropsExpanded);
+      success = super.executeScriptLine(withPropsExpanded);
     } catch (Exception e) {
       //TODO: should there be a way to differentiate error in shell & error on
       //server. May be by exception type.
@@ -633,12 +632,12 @@ public class Gfsh extends JLineShell {
   ///////////////////// JLineShell Class Methods End  //////////////////////////
 
   public int getTerminalHeight() {
-    return terminal != null ? terminal.getTerminalHeight() : DEFAULT_HEIGHT;
+    return terminal != null ? terminal.getHeight() : DEFAULT_HEIGHT;
   }
 
   public int getTerminalWidth() {
     if (terminal != null) {
-      return terminal.getTerminalWidth();
+      return terminal.getWidth();
     }
 
     Map<String, String> env = System.getenv();
@@ -805,7 +804,7 @@ public class Gfsh extends JLineShell {
                 ++commandSrNum;
                 Gfsh.println(commandSrNum+". Executing - " + cmdLet);                
                 Gfsh.println();
-                boolean executeSuccess = executeCommand(cmdLet);
+                boolean executeSuccess = executeScriptLine(cmdLet);
                 if (!executeSuccess) {
                   setLastExecutionStatus(-1);
                 }
@@ -922,7 +921,7 @@ public class Gfsh extends JLineShell {
       readLine = reader.readLine(prompt);
     } catch (IndexOutOfBoundsException e) {
       if (earlierLine.length() == 0) {
-        reader.printNewline();
+        reader.println();
         readLine = LINE_SEPARATOR;
         reader.getCursorBuffer().cursor = 0;
       } else {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java
new file mode 100644
index 0000000..572f899
--- /dev/null
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java
@@ -0,0 +1,433 @@
+/*
+ * Copyright (c) 2002-2007, Marc Prud'hommeaux. All rights reserved.
+ *
+ * This software is distributable under the BSD license. See the terms of the
+ * BSD license in the documentation provided with this software.
+ */
+package com.gemstone.gemfire.management.internal.cli.shell.jline;
+
+import org.springframework.shell.support.util.OsUtils;
+
+import java.io.BufferedReader;
+import java.io.InputStreamReader;
+
+/**
+ *  A buffer that can contain ANSI text.
+ *
+ *  @author  <a href="mailto:mwp1@cornell.edu">Marc Prud'hommeaux</a>
+ */
+public class ANSIBuffer {
+    private boolean ansiEnabled = true;
+    private final StringBuffer ansiBuffer = new StringBuffer();
+    private final StringBuffer plainBuffer = new StringBuffer();
+
+    public ANSIBuffer() {
+    }
+
+    public ANSIBuffer(final String str) {
+        append(str);
+    }
+
+    public void setAnsiEnabled(final boolean ansi) {
+        this.ansiEnabled = ansi;
+    }
+
+    public boolean getAnsiEnabled() {
+        return this.ansiEnabled;
+    }
+
+    public String getAnsiBuffer() {
+        return ansiBuffer.toString();
+    }
+
+    public String getPlainBuffer() {
+        return plainBuffer.toString();
+    }
+
+    public String toString(final boolean ansi) {
+        return ansi ? getAnsiBuffer() : getPlainBuffer();
+    }
+
+    public String toString() {
+        return toString(ansiEnabled);
+    }
+
+    public ANSIBuffer append(final String str) {
+        ansiBuffer.append(str);
+        plainBuffer.append(str);
+
+        return this;
+    }
+
+    public ANSIBuffer attrib(final String str, final int code) {
+        ansiBuffer.append(ANSICodes.attrib(code)).append(str)
+                  .append(ANSICodes.attrib(ANSICodes.OFF));
+        plainBuffer.append(str);
+
+        return this;
+    }
+
+    public ANSIBuffer red(final String str) {
+        return attrib(str, ANSICodes.FG_RED);
+    }
+
+    public ANSIBuffer blue(final String str) {
+        return attrib(str, ANSICodes.FG_BLUE);
+    }
+
+    public ANSIBuffer green(final String str) {
+        return attrib(str, ANSICodes.FG_GREEN);
+    }
+
+    public ANSIBuffer black(final String str) {
+        return attrib(str, ANSICodes.FG_BLACK);
+    }
+
+    public ANSIBuffer yellow(final String str) {
+        return attrib(str, ANSICodes.FG_YELLOW);
+    }
+
+    public ANSIBuffer magenta(final String str) {
+        return attrib(str, ANSICodes.FG_MAGENTA);
+    }
+
+    public ANSIBuffer cyan(final String str) {
+        return attrib(str, ANSICodes.FG_CYAN);
+    }
+
+    public ANSIBuffer bold(final String str) {
+        return attrib(str, ANSICodes.BOLD);
+    }
+
+    public ANSIBuffer underscore(final String str) {
+        return attrib(str, ANSICodes.UNDERSCORE);
+    }
+
+    public ANSIBuffer blink(final String str) {
+        return attrib(str, ANSICodes.BLINK);
+    }
+
+    public ANSIBuffer reverse(final String str) {
+        return attrib(str, ANSICodes.REVERSE);
+    }
+
+    public static class ANSICodes {
+        static final int OFF = 0;
+        static final int BOLD = 1;
+        static final int UNDERSCORE = 4;
+        static final int BLINK = 5;
+        static final int REVERSE = 7;
+        static final int CONCEALED = 8;
+        static final int FG_BLACK = 30;
+        static final int FG_RED = 31;
+        static final int FG_GREEN = 32;
+        static final int FG_YELLOW = 33;
+        static final int FG_BLUE = 34;
+        static final int FG_MAGENTA = 35;
+        static final int FG_CYAN = 36;
+        static final int FG_WHITE = 37;
+        static final char ESC = 27;
+
+        /**
+         *  Constructor is private since this is a utility class.
+         */
+        private ANSICodes() {
+        }
+
+        /**
+          * Sets the screen mode. The mode will be one of the following values:
+          * <pre>
+          * mode     description
+          * ----------------------------------------
+          *   0      40 x 148 x 25 monochrome (text)
+          *   1      40 x 148 x 25 color (text)
+          *   2      80 x 148 x 25 monochrome (text)
+          *   3      80 x 148 x 25 color (text)
+          *   4      320 x 148 x 200 4-color (graphics)
+          *   5      320 x 148 x 200 monochrome (graphics)
+          *   6      640 x 148 x 200 monochrome (graphics)
+          *   7      Enables line wrapping
+          *  13      320 x 148 x 200 color (graphics)
+          *  14      640 x 148 x 200 color (16-color graphics)
+          *  15      640 x 148 x 350 monochrome (2-color graphics)
+          *  16      640 x 148 x 350 color (16-color graphics)
+          *  17      640 x 148 x 480 monochrome (2-color graphics)
+          *  18      640 x 148 x 480 color (16-color graphics)
+          *  19      320 x 148 x 200 color (256-color graphics)
+          * </pre>
+          */
+        public static String setmode(final int mode) {
+            return ESC + "[=" + mode + "h";
+        }
+
+        /**
+          * Same as setmode () except for mode = 7, which disables line
+          * wrapping (useful for writing the right-most column without
+          * scrolling to the next line).
+          */
+        public static String resetmode(final int mode) {
+            return ESC + "[=" + mode + "l";
+        }
+
+        /**
+          * Clears the screen and moves the cursor to the home postition.
+          */
+        public static String clrscr() {
+            return ESC + "[2J";
+        }
+
+        /**
+          * Removes all characters from the current cursor position until
+          * the end of the line.
+          */
+        public static String clreol() {
+            return ESC + "[K";
+        }
+
+        /**
+          * Moves the cursor n positions to the left. If n is greater or
+          * equal to the current cursor column, the cursor is moved to the
+          * first column.
+          */
+        public static String left(final int n) {
+            return ESC + "[" + n + "D";
+        }
+
+        /**
+          * Moves the cursor n positions to the right. If n plus the current
+          * cursor column is greater than the rightmost column, the cursor
+          * is moved to the rightmost column.
+          */
+        public static String right(final int n) {
+            return ESC + "[" + n + "C";
+        }
+
+        /**
+          * Moves the cursor n rows up without changing the current column.
+          * If n is greater than or equal to the current row, the cursor is
+          * placed in the first row.
+          */
+        public static String up(final int n) {
+            return ESC + "[" + n + "A";
+        }
+
+        /**
+          * Moves the cursor n rows down. If n plus the current row is greater
+          * than the bottom row, the cursor is moved to the bottom row.
+          */
+        public static String down(final int n) {
+            return ESC + "[" + n + "B";
+        }
+
+        /*
+          * Moves the cursor to the given row and column. (1,1) represents
+          * the upper left corner. The lower right corner of a usual DOS
+          * screen is (25, 80).
+          */
+        public static String gotoxy(final int row, final int column) {
+            return ESC + "[" + row + ";" + column + "H";
+        }
+
+        /**
+          * Saves the current cursor position.
+          */
+        public static String save() {
+            return ESC + "[s";
+        }
+
+        /**
+          * Restores the saved cursor position.
+          */
+        public static String restore() {
+            return ESC + "[u";
+        }
+
+        /**
+          * Sets the character attribute. It will be
+         * one of the following character attributes:
+          *
+          * <pre>
+          * Text attributes
+          *    0    All attributes off
+          *    1    Bold on
+          *    4    Underscore (on monochrome display adapter only)
+          *    5    Blink on
+          *    7    Reverse video on
+          *    8    Concealed on
+          *
+          *   Foreground colors
+          *    30    Black
+          *    31    Red
+          *    32    Green
+          *    33    Yellow
+          *    34    Blue
+          *    35    Magenta
+          *    36    Cyan
+          *    37    White
+          *
+          *   Background colors
+          *    40    Black
+          *    41    Red
+          *    42    Green
+          *    43    Yellow
+          *    44    Blue
+          *    45    Magenta
+          *    46    Cyan
+          *    47    White
+          * </pre>
+          *
+          * The attributes remain in effect until the next attribute command
+          * is sent.
+          */
+        public static String attrib(final int attr) {
+            return ESC + "[" + attr + "m";
+        }
+
+        /**
+          * Sets the key with the given code to the given value. code must be
+          * derived from the following table, value must
+         * be any semicolon-separated
+          * combination of String (enclosed in double quotes) and numeric values.
+          * For example, to set F1 to the String "Hello F1", followed by a CRLF
+          * sequence, one can use: ANSI.setkey ("0;59", "\"Hello F1\";13;10").
+          * Heres's the table of key values:
+          * <pre>
+          * Key                       Code      SHIFT+code  CTRL+code  ALT+code
+          * ---------------------------------------------------------------
+          * F1                        0;59      0;84        0;94       0;104
+          * F2                        0;60      0;85        0;95       0;105
+          * F3                        0;61      0;86        0;96       0;106
+          * F4                        0;62      0;87        0;97       0;107
+          * F5                        0;63      0;88        0;98       0;108
+          * F6                        0;64      0;89        0;99       0;109
+          * F7                        0;65      0;90        0;100      0;110
+          * F8                        0;66      0;91        0;101      0;111
+          * F9                        0;67      0;92        0;102      0;112
+          * F10                       0;68      0;93        0;103      0;113
+          * F11                       0;133     0;135       0;137      0;139
+          * F12                       0;134     0;136       0;138      0;140
+          * HOME (num keypad)         0;71      55          0;119      --
+          * UP ARROW (num keypad)     0;72      56          (0;141)    --
+          * PAGE UP (num keypad)      0;73      57          0;132      --
+          * LEFT ARROW (num keypad)   0;75      52          0;115      --
+          * RIGHT ARROW (num keypad)  0;77      54          0;116      --
+          * END (num keypad)          0;79      49          0;117      --
+          * DOWN ARROW (num keypad)   0;80      50          (0;145)    --
+          * PAGE DOWN (num keypad)    0;81      51          0;118      --
+          * INSERT (num keypad)       0;82      48          (0;146)    --
+          * DELETE  (num keypad)      0;83      46          (0;147)    --
+          * HOME                      (224;71)  (224;71)    (224;119)  (224;151)
+          * UP ARROW                  (224;72)  (224;72)    (224;141)  (224;152)
+          * PAGE UP                   (224;73)  (224;73)    (224;132)  (224;153)
+          * LEFT ARROW                (224;75)  (224;75)    (224;115)  (224;155)
+          * RIGHT ARROW               (224;77)  (224;77)    (224;116)  (224;157)
+          * END                       (224;79)  (224;79)    (224;117)  (224;159)
+          * DOWN ARROW                (224;80)  (224;80)    (224;145)  (224;154)
+          * PAGE DOWN                 (224;81)  (224;81)    (224;118)  (224;161)
+          * INSERT                    (224;82)  (224;82)    (224;146)  (224;162)
+          * DELETE                    (224;83)  (224;83)    (224;147)  (224;163)
+          * PRINT SCREEN              --        --          0;114      --
+          * PAUSE/BREAK               --        --          0;0        --
+          * BACKSPACE                 8         8           127        (0)
+          * ENTER                     13        --          10         (0
+          * TAB                       9         0;15        (0;148)    (0;165)
+          * NULL                      0;3       --          --         --
+          * A                         97        65          1          0;30
+          * B                         98        66          2          0;48
+          * C                         99        66          3          0;46
+          * D                         100       68          4          0;32
+          * E                         101       69          5          0;18
+          * F                         102       70          6          0;33
+          * G                         103       71          7          0;34
+          * H                         104       72          8          0;35
+          * I                         105       73          9          0;23
+          * J                         106       74          10         0;36
+          * K                         107       75          11         0;37
+          * L                         108       76          12         0;38
+          * M                         109       77          13         0;50
+          * N                         110       78          14         0;49
+          * O                         111       79          15         0;24
+          * P                         112       80          16         0;25
+          * Q                         113       81          17         0;16
+          * R                         114       82          18         0;19
+          * S                         115       83          19         0;31
+          * T                         116       84          20         0;20
+          * U                         117       85          21         0;22
+          * V                         118       86          22         0;47
+          * W                         119       87          23         0;17
+          * X                         120       88          24         0;45
+          * Y                         121       89          25         0;21
+          * Z                         122       90          26         0;44
+          * 1                         49        33          --         0;120
+          * 2                         50        64          0          0;121
+          * 3                         51        35          --         0;122
+          * 4                         52        36          --         0;123
+          * 5                         53        37          --         0;124
+          * 6                         54        94          30         0;125
+          * 7                         55        38          --         0;126
+          * 8                         56        42          --         0;126
+          * 9                         57        40          --         0;127
+          * 0                         48        41          --         0;129
+          * -                         45        95          31         0;130
+          * =                         61        43          ---        0;131
+          * [                         91        123         27         0;26
+          * ]                         93        125         29         0;27
+          *                           92        124         28         0;43
+          * ;                         59        58          --         0;39
+          * '                         39        34          --         0;40
+          * ,                         44        60          --         0;51
+          * .                         46        62          --         0;52
+          * /                         47        63          --         0;53
+          * `                         96        126         --         (0;41)
+          * ENTER (keypad)            13        --          10         (0;166)
+          * / (keypad)                47        47          (0;142)    (0;74)
+          * * (keypad)                42        (0;144)     (0;78)     --
+          * - (keypad)                45        45          (0;149)    (0;164)
+          * + (keypad)                43        43          (0;150)    (0;55)
+          * 5 (keypad)                (0;76)    53          (0;143)    --
+          */
+        public static String setkey(final String code, final String value) {
+            return ESC + "[" + code + ";" + value + "p";
+        }
+    }
+
+    public static void main(final String[] args) throws Exception {
+        // sequence, one can use: ANSI.setkey ("0;59", "\"Hello F1\";13;10").
+        BufferedReader reader =
+            new BufferedReader(new InputStreamReader(System.in));
+        System.out.print(ANSICodes.setkey("97", "97;98;99;13")
+                         + ANSICodes.attrib(ANSICodes.OFF));
+        System.out.flush();
+
+        String line;
+
+        while ((line = reader.readLine()) != null) {
+            System.out.println("GOT: " + line);
+        }
+    }
+
+    private static final boolean ROO_BRIGHT_COLORS = Boolean.getBoolean("roo.bright");
+    private static final boolean SHELL_BRIGHT_COLORS = Boolean.getBoolean("spring.shell.bright");
+    private static final boolean BRIGHT_COLORS = ROO_BRIGHT_COLORS || SHELL_BRIGHT_COLORS;
+
+    public static ANSIBuffer getANSIBuffer() {
+        final char esc = (char) 27;
+        return new ANSIBuffer() {
+            @Override
+            public ANSIBuffer reverse(final String str) {
+                if (OsUtils.isWindows()) {
+                    return super.reverse(str).append(ANSICodes.attrib(esc));
+                }
+                return super.reverse(str);
+            };
+            @Override
+            public ANSIBuffer attrib(final String str, final int code) {
+                if (BRIGHT_COLORS && 30 <= code && code <= 37) {
+                    // This is a color code: add a 'bright' code
+                    return append(esc + "[" + code + ";1m").append(str).append(ANSICodes.attrib(0));
+                }
+                return super.attrib(str, code);
+            }
+        };
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
index ccd9864..c8102ae 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
@@ -18,8 +18,6 @@ package com.gemstone.gemfire.management.internal.cli.shell.jline;
 
 import org.springframework.shell.core.JLineLogHandler;
 
-import jline.ANSIBuffer;
-
 /**
  * Overrides jline.History to add History without newline characters.
  * 
@@ -50,7 +48,8 @@ public class ANSIHandler {
     String decoratedInput = input;
     
     if (isAnsiEnabled()) {
-      ANSIBuffer ansiBuffer = JLineLogHandler.getANSIBuffer();
+      ANSIBuffer ansiBuffer = ANSIBuffer.getANSIBuffer();
+
 
       for (ANSIStyle ansiStyle : styles) {
         switch (ansiStyle) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
index d84bbe7..f486774 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
@@ -39,147 +39,18 @@ public class CygwinMinttyTerminal extends UnixTerminal {
   
   
   String encoding = System.getProperty("input.encoding", "UTF-8");
-  ReplayPrefixOneCharInputStream replayStream = new ReplayPrefixOneCharInputStream(encoding);
   InputStreamReader replayReader;
 
-  public CygwinMinttyTerminal() {
-      try {
-          replayReader = new InputStreamReader(replayStream, encoding);
-      } catch (Exception e) {
-          throw new RuntimeException(e);
-      }
+  public CygwinMinttyTerminal() throws Exception{
   }
 
   @Override
-  public void initializeTerminal() throws IOException, InterruptedException {
+  public void init() throws Exception{
 
   }
 
   @Override
-  public void restoreTerminal() throws Exception {
-    resetTerminal();
+  public void restore() throws Exception {
+    reset();
   }
-
-  @Override
-  public int readVirtualKey(InputStream in) throws IOException {
-    int c = readCharacter(in);
-
-    //if (backspaceDeleteSwitched)
-        if (c == DELETE)
-            c = BACKSPACE;
-        else if (c == BACKSPACE)
-            c = DELETE;
-
-    // in Unix terminals, arrow keys are represented by
-    // a sequence of 3 characters. E.g., the up arrow
-    // key yields 27, 91, 68
-    if (c == ARROW_START && in.available() > 0) {
-        // Escape key is also 27, so we use InputStream.available()
-        // to distinguish those. If 27 represents an arrow, there
-        // should be two more chars immediately available.
-        while (c == ARROW_START) {
-            c = readCharacter(in);
-        }
-        if (c == ARROW_PREFIX || c == O_PREFIX) {
-            c = readCharacter(in);
-            if (c == ARROW_UP) {
-                return CTRL_P;
-            } else if (c == ARROW_DOWN) {
-                return CTRL_N;
-            } else if (c == ARROW_LEFT) {
-                return CTRL_B;
-            } else if (c == ARROW_RIGHT) {
-                return CTRL_F;
-            } else if (c == HOME_CODE) {
-                return CTRL_A;
-            } else if (c == END_CODE) {
-                return CTRL_E;
-            } else if (c == DEL_THIRD) {
-                c = readCharacter(in); // read 4th
-                return DELETE;
-            }
-        } 
-    } 
-    // handle unicode characters, thanks for a patch from amyi@inf.ed.ac.uk
-    if (c > 128) {      
-      // handle unicode characters longer than 2 bytes,
-      // thanks to Marc.Herbert@continuent.com        
-        replayStream.setInput(c, in);
-//      replayReader = new InputStreamReader(replayStream, encoding);
-        c = replayReader.read();
-        
-    }
-    return c;
-  }
-  
-  /**
-   * This is awkward and inefficient, but probably the minimal way to add
-   * UTF-8 support to JLine
-   *
-   * @author <a href="mailto:Marc.Herbert@continuent.com">Marc Herbert</a>
-   */
-  static class ReplayPrefixOneCharInputStream extends InputStream {
-      byte firstByte;
-      int byteLength;
-      InputStream wrappedStream;
-      int byteRead;
-
-      final String encoding;
-      
-      public ReplayPrefixOneCharInputStream(String encoding) {
-          this.encoding = encoding;
-      }
-      
-      public void setInput(int recorded, InputStream wrapped) throws IOException {
-          this.byteRead = 0;
-          this.firstByte = (byte) recorded;
-          this.wrappedStream = wrapped;
-
-          byteLength = 1;
-          if (encoding.equalsIgnoreCase("UTF-8"))
-              setInputUTF8(recorded, wrapped);
-          else if (encoding.equalsIgnoreCase("UTF-16"))
-              byteLength = 2;
-          else if (encoding.equalsIgnoreCase("UTF-32"))
-              byteLength = 4;
-      }
-          
-          
-      public void setInputUTF8(int recorded, InputStream wrapped) throws IOException {
-          // 110yyyyy 10zzzzzz
-          if ((firstByte & (byte) 0xE0) == (byte) 0xC0)
-              this.byteLength = 2;
-          // 1110xxxx 10yyyyyy 10zzzzzz
-          else if ((firstByte & (byte) 0xF0) == (byte) 0xE0)
-              this.byteLength = 3;
-          // 11110www 10xxxxxx 10yyyyyy 10zzzzzz
-          else if ((firstByte & (byte) 0xF8) == (byte) 0xF0)
-              this.byteLength = 4;
-          else
-              throw new IOException("invalid UTF-8 first byte: " + firstByte);
-      }
-
-      public int read() throws IOException {
-          if (available() == 0)
-              return -1;
-
-          byteRead++;
-
-          if (byteRead == 1)
-              return firstByte;
-
-          return wrappedStream.read();
-      }
-
-      /**
-      * InputStreamReader is greedy and will try to read bytes in advance. We
-      * do NOT want this to happen since we use a temporary/"losing bytes"
-      * InputStreamReader above, that's why we hide the real
-      * wrappedStream.available() here.
-      */
-      public int available() {
-          return byteLength - byteRead;
-      }
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
index 9f18cae..dc3fbe1 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
@@ -18,7 +18,10 @@ package com.gemstone.gemfire.management.internal.cli.shell.jline;
 
 import com.gemstone.gemfire.management.internal.cli.parser.preprocessor.PreprocessorUtils;
 
-import jline.History;
+import jline.console.history.MemoryHistory;
+
+import java.io.File;
+import java.io.IOException;
 
 /**
  * Overrides jline.History to add History without newline characters.
@@ -26,14 +29,14 @@ import jline.History;
  * @author Abhishek Chaudhari
  * @since 7.0
  */
-public class GfshHistory extends History {
+public class GfshHistory extends MemoryHistory {
+
   // let the history from history file get added initially
   private boolean autoFlush = true;
-  
-  @Override
+
   public void addToHistory(String buffer) {
     if (isAutoFlush()) {
-      super.addToHistory(toHistoryLoggable(buffer));
+      super.add(toHistoryLoggable(buffer));
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
index 59609ba..3bc839e 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
@@ -27,7 +27,7 @@ import jline.UnsupportedTerminal;
  */
 public class GfshUnsupportedTerminal extends UnsupportedTerminal {
   @Override
-  public boolean isANSISupported() {
+  public synchronized boolean isAnsiSupported() {
     return false;
   }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
index 70a00a1..9d1bdbe 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
@@ -16,7 +16,7 @@
  */
 package com.gemstone.gemfire.management.internal.cli.util;
 
-import jline.ConsoleReader;
+import jline.console.ConsoleReader;
 import com.gemstone.gemfire.management.internal.cli.shell.Gfsh;
 
 public class CLIConsoleBufferUtil {
@@ -24,9 +24,9 @@ public class CLIConsoleBufferUtil {
     
     ConsoleReader reader = Gfsh.getConsoleReader();    
     if (reader != null) {
-      StringBuffer buffer = reader.getCursorBuffer().getBuffer();    
-      if(buffer.length() > messege.length()){
-        int appendSpaces = buffer.length() - messege.length();
+      int bufferLength = reader.getCursorBuffer().length();
+      if(bufferLength > messege.length()){
+        int appendSpaces = bufferLength - messege.length();
         for(int i = 0; i < appendSpaces; i++){
           messege = messege + " ";
         }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
index 6ce1a13..057be81 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
@@ -172,7 +172,7 @@ public abstract class PersistentPartitionedRegionTestBase extends CacheTestCase
           public void run() {
             Cache cache = getCache();
             Region region = cache.getRegion(regionName);
-            
+
             for(int i =startKey; i < endKey; i++) {
               assertEquals("For key " + i, value, region.get(i));
             }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/058aad36/gradle/dependency-versions.properties
----------------------------------------------------------------------
diff --git a/gradle/dependency-versions.properties b/gradle/dependency-versions.properties
index c86d45d..9c47763 100644
--- a/gradle/dependency-versions.properties
+++ b/gradle/dependency-versions.properties
@@ -33,7 +33,7 @@ javax.servlet-api.version = 3.1.0
 javax.transaction-api.version = 1.2
 jedis.version = 2.7.2
 jetty.version = 9.2.3.v20140905
-jline.version = 1.0.S2-B
+jline.version = 2.12
 jmock.version = 2.8.1
 jna.version = 4.0.0
 json4s.version = 3.2.4
@@ -56,7 +56,7 @@ snappy-java.version = 1.1.1.6
 spring-data-commons.version = 1.9.1.RELEASE
 spring-data-gemfire.version = 1.5.1.RELEASE
 spring-hateos.version = 0.16.0.RELEASE
-spring-shell.version = 1.0.0.RELEASE
+spring-shell.version = 1.1.0.RELEASE
 springframework.version = 3.2.12.RELEASE
 spymemcached.version = 2.9.0
 swagger.version = 1.3.2



[32/50] [abbrv] incubator-geode git commit: Fix AnalyzeSerializablesJUnitTest, add CopyOnWriteHashMap to sanctionedSerializables.txt

Posted by bs...@apache.org.
Fix AnalyzeSerializablesJUnitTest, add CopyOnWriteHashMap to sanctionedSerializables.txt


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

Branch: refs/heads/feature/GEODE-77
Commit: 2cf4fb1ab5fe899b5bfe01b2e8b22e4eb67157ef
Parents: 37cc70e
Author: Ashvin Agrawal <as...@apache.org>
Authored: Wed Nov 11 13:07:06 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Wed Nov 11 13:07:06 2015 -0800

----------------------------------------------------------------------
 .../com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt  | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2cf4fb1a/gemfire-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt b/gemfire-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
index 25e8813..b9252f7 100644
--- a/gemfire-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
+++ b/gemfire-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
@@ -143,7 +143,6 @@ com/gemstone/gemfire/cache/hdfs/internal/hoplog/HdfsSortedOplogOrganizer$HoplogR
 com/gemstone/gemfire/cache/hdfs/internal/hoplog/Hoplog$HoplogVersion,false
 com/gemstone/gemfire/cache/hdfs/internal/hoplog/Hoplog$Meta,false
 com/gemstone/gemfire/cache/hdfs/internal/org/apache/hadoop/io/SequenceFile$CompressionType,false
-com/gemstone/gemfire/cache/lucene/LuceneQueryFactory$ResultType,false
 com/gemstone/gemfire/cache/operations/PutAllOperationContext$UpdateOnlyMap,true,-1034234728574286014,m:java/util/Map
 com/gemstone/gemfire/cache/partition/PartitionNotAvailableException,true,1
 com/gemstone/gemfire/cache/persistence/ConflictingPersistentDataException,true,-2629287782021455875
@@ -635,6 +634,7 @@ com/gemstone/gemfire/internal/tcp/VersionedByteBufferInputStream,false,version:c
 com/gemstone/gemfire/internal/util/Breadcrumbs$CrumbType,false
 com/gemstone/gemfire/internal/util/SingletonValue$ValueState,false
 com/gemstone/gemfire/internal/util/SunAPINotFoundException,false
+com/gemstone/gemfire/internal/util/concurrent/CopyOnWriteHashMap,false,map:java/util/Map
 com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap,true,-7056732555635108300,compareValues:boolean,entryCreator:com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap$HashEntryCreator,segmentMask:int,segmentShift:int,segments:com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap$Segment[]
 com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap$DefaultHashEntryCreator,true,3765680607280951726
 com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap$IdentitySegment,true,3086228147110819882


[38/50] [abbrv] incubator-geode git commit: GEODE-539: remove XD off-heap artifacts

Posted by bs...@apache.org.
GEODE-539: remove XD off-heap artifacts

The OffHeapReference interface has been removed.
Use the StoredObject interface instead.

The XD SRC_TYPE constants have been renamed to
unused and a comment added explaining why we might
want to keep the SRC_TYPE/ChunkType feature around
for future off-heap extensions.


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

Branch: refs/heads/feature/GEODE-77
Commit: 781bd8d74e4ffcfbb12b286dd7a582a1de586f78
Parents: 5118ad0
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Thu Nov 12 16:24:40 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Nov 12 16:35:54 2015 -0800

----------------------------------------------------------------------
 .../gemfire/internal/cache/EntryEventImpl.java  |  1 -
 .../gemfire/internal/offheap/OffHeapHelper.java |  4 +-
 .../internal/offheap/OffHeapReference.java      | 72 --------------------
 .../offheap/SimpleMemoryAllocatorImpl.java      | 28 +++++---
 .../gemfire/internal/offheap/StoredObject.java  | 42 +++++++++++-
 5 files changed, 63 insertions(+), 84 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/781bd8d7/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
index b7fbf1e..0786a69 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
@@ -73,7 +73,6 @@ import com.gemstone.gemfire.internal.logging.LogService;
 import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
 import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
 import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
-import com.gemstone.gemfire.internal.offheap.OffHeapReference;
 import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
 import com.gemstone.gemfire.internal.offheap.Releasable;
 import com.gemstone.gemfire.internal.offheap.SimpleMemoryAllocatorImpl;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/781bd8d7/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
index 3d62fdf..b5677cd 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
@@ -37,8 +37,8 @@ public class OffHeapHelper {
    * 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 OffHeapReference) {
-      return ((OffHeapReference) o).getValueAsDeserializedHeapObject();
+    if (o instanceof StoredObject) {
+      return ((StoredObject) o).getValueAsDeserializedHeapObject();
     } else {
       return o;
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/781bd8d7/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapReference.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapReference.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapReference.java
deleted file mode 100644
index 1507273..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapReference.java
+++ /dev/null
@@ -1,72 +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.offheap;
-
-import com.gemstone.gemfire.internal.Sendable;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-
-/**
- * Instances of this interface are references to off-heap.
- * Note: this interface is part of building the odbc drivers. Any classes or interfaces it references
- * need to be added to SQLFire.xml -sqlf-odbc-java-list.
- * Because of odbc we do not want this interface to extend CachedDeserializable because it pulls in too many of the GemFire code base.
- * 
- * @author darrel
- * @since 9.0
- */
-public interface OffHeapReference extends Releasable, Sendable {
-
-  /**
-   * Call to indicate that this object's memory is in use by the caller.
-   * The memory will stay allocated until {@link #release()} is called.
-   * It is ok for a thread other than the one that called this method to call release.
-   * This method is called implicitly at the time the chunk is allocated.
-   * Note: @Retained tells you that "this" is retained by this method.
-   * 
-   * @throws IllegalStateException if the max ref count is exceeded.
-   * @return true if we are able to retain this chunk; false if we need to retry
-   */
-  @Retained
-  public boolean retain();
-
-  /**
-   * Returns true if the value stored in this memory chunk is a serialized object. Returns false if it is a byte array.
-   */
-  public boolean isSerialized();
-
-  /**
-   * Returns true if the value stored in this memory chunk is compressed. Returns false if it is uncompressed.
-   */
-  public boolean isCompressed();
-
-  /**
-   * Returns the data stored in this object as a deserialized heap object.
-   * If it is not serialized then the result will be a byte[].
-   * Otherwise the deserialized heap form of the stored object is returned.
-   * @return the data stored in this object as a deserialized heap object.
-   */
-  public Object getValueAsDeserializedHeapObject();
-
-  /**
-   * Returns the data stored in this object as a heap byte array.
-   * If it is not serialized then the result will only contain the raw bytes stored in this object.
-   * Otherwise the serialized heap form of the stored object is returned.
-   * @return the data stored in this object as a heap byte array.
-   */
-  public byte[] getValueAsHeapByteArray();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/781bd8d7/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
index a38daa6..c800335 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
@@ -1729,15 +1729,27 @@ public final class SimpleMemoryAllocatorImpl implements MemoryAllocator, MemoryI
     final static long FILL_PATTERN = 0x3c3c3c3c3c3c3c3cL;
     final static byte FILL_BYTE = 0x3c;
     
-    public final static int SRC_TYPE_NO_LOB_NO_DELTA = 0 << SRC_TYPE_SHIFT;
-    public final static int SRC_TYPE_WITH_LOBS = 1 << SRC_TYPE_SHIFT;
-    public final static int SRC_TYPE_WITH_SINGLE_DELTA = 2 << SRC_TYPE_SHIFT;
-    public final static int SRC_TYPE_WITH_MULTIPLE_DELTAS = 3 << SRC_TYPE_SHIFT;
-    //public final static int SRC_TYPE_IS_LOB = 4 << SRC_TYPE_SHIFT;
+    // The 8 bits reserved for SRC_TYPE are basically no longer used.
+    // So we could free up these 8 bits for some other use or we could
+    // keep them for future extensions.
+    // If we ever want to allocate other "types" into a chunk of off-heap
+    // memory then the SRC_TYPE would be the way to go.
+    // For example we may want to allocate the memory for the off-heap
+    // RegionEntry in off-heap memory without it being of type GFE.
+    // When it is of type GFE then it either needs to be the bytes
+    // of a byte array or it needs to be a serialized java object.
+    // For the RegionEntry we may want all the primitive fields of
+    // the entry at certain offsets in the off-heap memory so we could
+    // access them directly in native byte format (i.e. no serialization).
+    // Note that for every SRC_TYPE we should have a ChunkType subclass.
+    public final static int SRC_TYPE_UNUSED0 = 0 << SRC_TYPE_SHIFT;
+    public final static int SRC_TYPE_UNUSED1 = 1 << SRC_TYPE_SHIFT;
+    public final static int SRC_TYPE_UNUSED2 = 2 << SRC_TYPE_SHIFT;
+    public final static int SRC_TYPE_UNUSED3 = 3 << SRC_TYPE_SHIFT;
     public final static int SRC_TYPE_GFE = 4 << SRC_TYPE_SHIFT;
-    public final static int SRC_TYPE_UNUSED1 = 5 << SRC_TYPE_SHIFT;
-    public final static int SRC_TYPE_UNUSED2 = 6 << SRC_TYPE_SHIFT;
-    public final static int SRC_TYPE_UNUSED3 = 7 << SRC_TYPE_SHIFT;
+    public final static int SRC_TYPE_UNUSED5 = 5 << SRC_TYPE_SHIFT;
+    public final static int SRC_TYPE_UNUSED6 = 6 << SRC_TYPE_SHIFT;
+    public final static int SRC_TYPE_UNUSED7 = 7 << SRC_TYPE_SHIFT;
     
     protected Chunk(long memoryAddress, int chunkSize, ChunkType chunkType) {
       validateAddressAndSize(memoryAddress, chunkSize);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/781bd8d7/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/StoredObject.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/StoredObject.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/StoredObject.java
index 083c5ff..4d93a07 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/StoredObject.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/StoredObject.java
@@ -19,7 +19,9 @@ package com.gemstone.gemfire.internal.offheap;
 import java.io.DataOutput;
 import java.io.IOException;
 
+import com.gemstone.gemfire.internal.Sendable;
 import com.gemstone.gemfire.internal.cache.CachedDeserializable;
+import com.gemstone.gemfire.internal.offheap.annotations.Retained;
 
 /**
  * Represents an object stored in the cache.
@@ -29,7 +31,45 @@ import com.gemstone.gemfire.internal.cache.CachedDeserializable;
  * @author darrel
  * @since 9.0
  */
-public interface StoredObject extends OffHeapReference, CachedDeserializable {
+public interface StoredObject extends Releasable, Sendable, CachedDeserializable {
+  /**
+   * Call to indicate that this object's memory is in use by the caller.
+   * The memory will stay allocated until {@link #release()} is called.
+   * It is ok for a thread other than the one that called this method to call release.
+   * This method is called implicitly at the time the chunk is allocated.
+   * Note: @Retained tells you that "this" is retained by this method.
+   * 
+   * @throws IllegalStateException if the max ref count is exceeded.
+   * @return true if we are able to retain this chunk; false if we need to retry
+   */
+  @Retained
+  public boolean retain();
+
+  /**
+   * Returns true if the value stored in this memory chunk is a serialized object. Returns false if it is a byte array.
+   */
+  public boolean isSerialized();
+
+  /**
+   * Returns true if the value stored in this memory chunk is compressed. Returns false if it is uncompressed.
+   */
+  public boolean isCompressed();
+
+  /**
+   * Returns the data stored in this object as a deserialized heap object.
+   * If it is not serialized then the result will be a byte[].
+   * Otherwise the deserialized heap form of the stored object is returned.
+   * @return the data stored in this object as a deserialized heap object.
+   */
+  public Object getValueAsDeserializedHeapObject();
+
+  /**
+   * Returns the data stored in this object as a heap byte array.
+   * If it is not serialized then the result will only contain the raw bytes stored in this object.
+   * Otherwise the serialized heap form of the stored object is returned.
+   * @return the data stored in this object as a heap byte array.
+   */
+  public byte[] getValueAsHeapByteArray();
   /**
    * Take all the bytes in the object and write them to the data output as a byte array.
    * If the StoredObject is not serialized then its raw byte array is sent.


[05/50] [abbrv] incubator-geode git commit: GEODE-526: Fix oplog unit test race condition

Posted by bs...@apache.org.
GEODE-526: Fix oplog unit test race condition

KRF files are created asynchronously. The test needs to wait for the files to be
created before checking header content.


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

Branch: refs/heads/feature/GEODE-77
Commit: 066c11ebdb26fffbdad89d1bf2a045b6cca1fc56
Parents: ee4cc01
Author: Ashvin Agrawal <as...@apache.org>
Authored: Wed Nov 4 13:54:45 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Wed Nov 4 13:54:45 2015 -0800

----------------------------------------------------------------------
 .../gemstone/gemfire/internal/cache/Oplog.java  |  1 -
 .../gemfire/internal/cache/OplogJUnitTest.java  | 46 +++++++++++---------
 2 files changed, 26 insertions(+), 21 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/066c11eb/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
index f0b33f1..cd197f2 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
@@ -107,7 +107,6 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.internal.logging.LogService;
 import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
 import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.MemoryChunkWithRefCount;
 import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
 import com.gemstone.gemfire.internal.offheap.SimpleMemoryAllocatorImpl;
 import com.gemstone.gemfire.internal.offheap.StoredObject;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/066c11eb/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
index 1fc39bf..433af3d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
@@ -27,15 +27,18 @@ import java.io.File;
 import java.io.FileInputStream;
 import java.io.IOException;
 import java.nio.ByteBuffer;
+import java.util.ArrayList;
 import java.util.Arrays;
 import java.util.HashSet;
+import java.util.List;
 import java.util.Random;
+import java.util.concurrent.TimeUnit;
 import java.util.concurrent.atomic.AtomicBoolean;
-
-import junit.framework.Assert;
+import java.util.stream.IntStream;
 
 import org.apache.commons.io.FileUtils;
 import org.junit.After;
+import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
@@ -55,6 +58,7 @@ import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.internal.InternalDataSerializer;
 import com.gemstone.gemfire.internal.cache.Oplog.OPLOG_TYPE;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import com.jayway.awaitility.Awaitility;
 
 import dunit.DistributedTestCase;
 import dunit.DistributedTestCase.WaitCriterion;
@@ -3806,8 +3810,8 @@ public class OplogJUnitTest extends DiskRegionTestingBase
     return sum;
   }
    
-  // disabled - this test frequently fails.  See bug #52213
-  public void disabledtestMagicSeqPresence() throws Exception {
+  @Test
+  public void testMagicSeqPresence() throws Exception {
     final int MAX_OPLOG_SIZE = 200;
     diskProps.setMaxOplogSize(MAX_OPLOG_SIZE);
     diskProps.setPersistBackup(true);
@@ -3815,34 +3819,35 @@ public class OplogJUnitTest extends DiskRegionTestingBase
     diskProps.setSynchronous(true);
     diskProps.setOverflow(false);
     diskProps.setDiskDirsAndSizes(new File[] { dirs[0] }, new int[] { 4000 });
-    region = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache, diskProps,
-        Scope.LOCAL);
+    region = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache, diskProps, Scope.LOCAL);
 
-    // at least 3 kinds of files will be verified
-    assertEquals(3, verifyOplogHeader(dirs[0]));
+    // 3 types of oplog files will be verified
+    verifyOplogHeader(dirs[0], ".if", ".crf", ".drf");
 
     try {
       LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER = true;
-      for (int i = 0; i < 10; ++i) {
-        region.put("key-" + i, "value-");
-      }
-      assertEquals(4, verifyOplogHeader(dirs[0]));
+      IntStream.range(0, 20).forEach(i -> region.put("key-" + i, "value-" + i));
+      // krf is created, so 4 types of oplog files will be verified
+      verifyOplogHeader(dirs[0], ".if", ".crf", ".drf", ".krf");
 
       region.close();
-      region = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache,
-          diskProps, Scope.LOCAL);
+      region = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache, diskProps, Scope.LOCAL);
 
-      assertEquals(4, verifyOplogHeader(dirs[0]));
+      verifyOplogHeader(dirs[0], ".if", ".crf", ".drf", ".krf");
       region.close();
     } finally {
       LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER = false;
     }
   }
 
-  /*
-   * returns number of types of files verified
-   */
-  private int verifyOplogHeader(File dir) throws IOException {
+  private void verifyOplogHeader(File dir, String ... oplogTypes) throws IOException {
+    
+    Awaitility.await().atMost(5, TimeUnit.SECONDS).until(() -> {
+      List<String> types = new ArrayList<>(Arrays.asList(oplogTypes));
+      Arrays.stream(dir.listFiles()).map(File::getName).map(f -> f.substring(f.indexOf("."))).forEach(types::remove);
+      return types.isEmpty();
+    });
+    
     File[] files = dir.listFiles();
      HashSet<String> verified = new HashSet<String>();
      for (File file : files) {
@@ -3880,7 +3885,8 @@ public class OplogJUnitTest extends DiskRegionTestingBase
        assertEquals("expected a read to return 8 but it returned " + count + " for file " + file, 8, count);
        assertTrue(Arrays.equals(expect, buf));
      }
-    return verified.size();
+     
+     assertEquals(oplogTypes.length, verified.size());
   }
   
    /**


[13/50] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-11

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


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

Branch: refs/heads/feature/GEODE-77
Commit: f189ff52dbf61c0f718a33aaa0ea92471309842c
Parents: b59c57d dc5d343
Author: Ashvin Agrawal <as...@apache.org>
Authored: Thu Nov 5 22:46:47 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Thu Nov 5 22:46:47 2015 -0800

----------------------------------------------------------------------
 README.md                                       |    9 +
 build.gradle                                    |   68 +-
 dev-tools/docker/base/Dockerfile                |   54 +
 dev-tools/docker/base/build-base-docker.sh      |   30 +
 dev-tools/docker/compile/Dockerfile             |   21 +
 .../docker/compile/start-compile-docker.sh      |   62 +
 docker/Dockerfile                               |   56 +-
 docker/README.md                                |    6 +-
 docker/build-runtime-docker.sh                  |   32 +
 gemfire-assembly/build.gradle                   |   19 +-
 gemfire-assembly/src/main/dist/bin/gfsh         |    2 +-
 gemfire-assembly/src/main/dist/bin/gfsh.bat     |    2 +-
 gemfire-common/build.gradle                     |    3 +
 .../gemfire/annotations/Experimental.java       |   40 +
 .../annotations/ExperimentalJUnitTest.java      |  183 ++
 .../ClassInExperimentalPackage.java             |   11 +
 .../experimentalpackage/package-info.java       |   11 +
 .../ClassInNonExperimentalPackage.java          |   11 +
 .../nonexperimentalpackage/package-info.java    |    8 +
 gemfire-core/build.gradle                       |  122 +-
 .../internal/ra/GFConnectionFactoryImpl.java    |   21 +-
 .../gemfire/internal/ra/GFConnectionImpl.java   |   21 +-
 .../internal/ra/spi/JCALocalTransaction.java    |   21 +-
 .../internal/ra/spi/JCAManagedConnection.java   |   21 +-
 .../ra/spi/JCAManagedConnectionFactory.java     |   21 +-
 .../ra/spi/JCAManagedConnectionMetaData.java    |   21 +-
 gemfire-core/src/jca/ra.xml                     |    2 +-
 .../com/gemstone/gemfire/CancelCriterion.java   |   21 +-
 .../com/gemstone/gemfire/CancelException.java   |   21 +-
 .../gemstone/gemfire/CanonicalInstantiator.java |   21 +-
 .../com/gemstone/gemfire/CopyException.java     |   21 +-
 .../java/com/gemstone/gemfire/CopyHelper.java   |   21 +-
 .../com/gemstone/gemfire/DataSerializable.java  |   21 +-
 .../com/gemstone/gemfire/DataSerializer.java    |   21 +-
 .../main/java/com/gemstone/gemfire/Delta.java   |   21 +-
 .../gemfire/DeltaSerializationException.java    |   21 +-
 .../gemfire/ForcedDisconnectException.java      |   21 +-
 .../gemstone/gemfire/GemFireCacheException.java |   21 +-
 .../gemfire/GemFireCheckedException.java        |   21 +-
 .../gemfire/GemFireConfigException.java         |   21 +-
 .../com/gemstone/gemfire/GemFireException.java  |   21 +-
 .../gemstone/gemfire/GemFireIOException.java    |   21 +-
 .../gemstone/gemfire/GemFireRethrowable.java    |   21 +-
 .../gemfire/IncompatibleSystemException.java    |   21 +-
 .../java/com/gemstone/gemfire/Instantiator.java |   21 +-
 .../gemstone/gemfire/InternalGemFireError.java  |   21 +-
 .../gemfire/InternalGemFireException.java       |   21 +-
 .../gemstone/gemfire/InvalidDeltaException.java |   21 +-
 .../gemstone/gemfire/InvalidValueException.java |   21 +-
 .../gemfire/InvalidVersionException.java        |   16 +
 .../com/gemstone/gemfire/LicenseException.java  |   21 +-
 .../java/com/gemstone/gemfire/LogWriter.java    |   21 +-
 .../com/gemstone/gemfire/NoSystemException.java |   21 +-
 .../gemfire/OutOfOffHeapMemoryException.java    |   21 +-
 .../gemfire/SerializationException.java         |   21 +-
 .../gemstone/gemfire/StatisticDescriptor.java   |   21 +-
 .../java/com/gemstone/gemfire/Statistics.java   |   21 +-
 .../com/gemstone/gemfire/StatisticsFactory.java |   21 +-
 .../com/gemstone/gemfire/StatisticsType.java    |   21 +-
 .../gemstone/gemfire/StatisticsTypeFactory.java |   21 +-
 .../gemfire/SystemConnectException.java         |   21 +-
 .../com/gemstone/gemfire/SystemFailure.java     |   21 +-
 .../gemfire/SystemIsRunningException.java       |   21 +-
 .../gemfire/ThreadInterruptedException.java     |   18 +-
 .../com/gemstone/gemfire/ToDataException.java   |   21 +-
 .../gemfire/UncreatedSystemException.java       |   21 +-
 .../gemstone/gemfire/UnmodifiableException.java |   21 +-
 .../gemfire/UnstartedSystemException.java       |   21 +-
 .../com/gemstone/gemfire/admin/AdminConfig.java |   21 +-
 .../gemfire/admin/AdminDistributedSystem.java   |   21 +-
 .../admin/AdminDistributedSystemFactory.java    |   21 +-
 .../gemstone/gemfire/admin/AdminException.java  |   21 +-
 .../gemfire/admin/AdminXmlException.java        |   21 +-
 .../java/com/gemstone/gemfire/admin/Alert.java  |   21 +-
 .../com/gemstone/gemfire/admin/AlertLevel.java  |   21 +-
 .../gemstone/gemfire/admin/AlertListener.java   |   21 +-
 .../gemstone/gemfire/admin/BackupStatus.java    |   21 +-
 .../admin/CacheDoesNotExistException.java       |   21 +-
 .../gemfire/admin/CacheHealthConfig.java        |   21 +-
 .../com/gemstone/gemfire/admin/CacheServer.java |   21 +-
 .../gemfire/admin/CacheServerConfig.java        |   21 +-
 .../com/gemstone/gemfire/admin/CacheVm.java     |   21 +-
 .../gemstone/gemfire/admin/CacheVmConfig.java   |   21 +-
 .../gemfire/admin/ConfigurationParameter.java   |   21 +-
 .../gemfire/admin/DistributedSystemConfig.java  |   21 +-
 .../admin/DistributedSystemHealthConfig.java    |   21 +-
 .../gemfire/admin/DistributionLocator.java      |   21 +-
 .../admin/DistributionLocatorConfig.java        |   21 +-
 .../gemstone/gemfire/admin/GemFireHealth.java   |   21 +-
 .../gemfire/admin/GemFireHealthConfig.java      |   21 +-
 .../gemfire/admin/GemFireMemberStatus.java      |   21 +-
 .../gemstone/gemfire/admin/ManagedEntity.java   |   21 +-
 .../gemfire/admin/ManagedEntityConfig.java      |   21 +-
 .../gemfire/admin/MemberHealthConfig.java       |   21 +-
 .../admin/OperationCancelledException.java      |   21 +-
 .../gemfire/admin/RegionNotFoundException.java  |   21 +-
 .../gemfire/admin/RegionSubRegionSnapshot.java  |   21 +-
 .../gemfire/admin/RuntimeAdminException.java    |   21 +-
 .../com/gemstone/gemfire/admin/Statistic.java   |   21 +-
 .../gemfire/admin/StatisticResource.java        |   21 +-
 .../gemstone/gemfire/admin/SystemMember.java    |   21 +-
 .../gemfire/admin/SystemMemberBridgeServer.java |   21 +-
 .../gemfire/admin/SystemMemberCache.java        |   21 +-
 .../gemfire/admin/SystemMemberCacheEvent.java   |   16 +
 .../admin/SystemMemberCacheListener.java        |   21 +-
 .../gemfire/admin/SystemMemberCacheServer.java  |   21 +-
 .../gemfire/admin/SystemMemberRegion.java       |   21 +-
 .../gemfire/admin/SystemMemberRegionEvent.java  |   16 +
 .../gemfire/admin/SystemMemberType.java         |   21 +-
 .../gemfire/admin/SystemMembershipEvent.java    |   21 +-
 .../gemfire/admin/SystemMembershipListener.java |   21 +-
 .../UnmodifiableConfigurationException.java     |   21 +-
 .../admin/internal/AbstractHealthEvaluator.java |   21 +-
 .../internal/AdminDistributedSystemImpl.java    |   21 +-
 .../admin/internal/BackupStatusImpl.java        |   21 +-
 .../admin/internal/CacheHealthConfigImpl.java   |   21 +-
 .../admin/internal/CacheHealthEvaluator.java    |   21 +-
 .../admin/internal/CacheServerConfigImpl.java   |   21 +-
 .../gemfire/admin/internal/CacheServerImpl.java |   21 +-
 .../internal/ConfigurationParameterImpl.java    |   21 +-
 .../ConfigurationParameterListener.java         |   21 +-
 .../DisabledManagedEntityController.java        |   21 +-
 .../internal/DistributedSystemConfigImpl.java   |   21 +-
 .../DistributedSystemHealthConfigImpl.java      |   21 +-
 .../DistributedSystemHealthEvaluator.java       |   21 +-
 .../DistributedSystemHealthMonitor.java         |   21 +-
 .../internal/DistributionLocatorConfigImpl.java |   21 +-
 .../admin/internal/DistributionLocatorImpl.java |   21 +-
 .../EnabledManagedEntityController.java         |   21 +-
 .../admin/internal/FinishBackupRequest.java     |   21 +-
 .../admin/internal/FinishBackupResponse.java    |   21 +-
 .../admin/internal/FlushToDiskRequest.java      |   21 +-
 .../admin/internal/FlushToDiskResponse.java     |   21 +-
 .../admin/internal/GemFireHealthConfigImpl.java |   21 +-
 .../admin/internal/GemFireHealthEvaluator.java  |   21 +-
 .../admin/internal/GemFireHealthImpl.java       |   21 +-
 .../gemfire/admin/internal/InetAddressUtil.java |   21 +-
 .../admin/internal/InternalManagedEntity.java   |   21 +-
 .../gemfire/admin/internal/LogCollator.java     |   21 +-
 .../admin/internal/ManagedEntityConfigImpl.java |   21 +-
 .../admin/internal/ManagedEntityConfigXml.java  |   21 +-
 .../ManagedEntityConfigXmlGenerator.java        |   21 +-
 .../internal/ManagedEntityConfigXmlParser.java  |   21 +-
 .../admin/internal/ManagedEntityController.java |   21 +-
 .../ManagedEntityControllerFactory.java         |   21 +-
 .../admin/internal/ManagedSystemMemberImpl.java |   21 +-
 .../admin/internal/MemberHealthConfigImpl.java  |   21 +-
 .../admin/internal/MemberHealthEvaluator.java   |   21 +-
 .../admin/internal/PrepareBackupRequest.java    |   21 +-
 .../admin/internal/PrepareBackupResponse.java   |   21 +-
 .../gemfire/admin/internal/StatisticImpl.java   |   21 +-
 .../admin/internal/StatisticResourceImpl.java   |   20 +-
 .../internal/SystemMemberBridgeServerImpl.java  |   21 +-
 .../internal/SystemMemberCacheEventImpl.java    |   21 +-
 .../SystemMemberCacheEventProcessor.java        |   21 +-
 .../admin/internal/SystemMemberCacheImpl.java   |   21 +-
 .../admin/internal/SystemMemberImpl.java        |   21 +-
 .../internal/SystemMemberRegionEventImpl.java   |   21 +-
 .../admin/internal/SystemMemberRegionImpl.java  |   21 +-
 .../internal/SystemMembershipEventImpl.java     |   21 +-
 .../com/gemstone/gemfire/admin/jmx/Agent.java   |   21 +-
 .../gemstone/gemfire/admin/jmx/AgentConfig.java |   21 +-
 .../gemfire/admin/jmx/AgentFactory.java         |   21 +-
 .../internal/AdminDistributedSystemJmxImpl.java |   21 +-
 .../admin/jmx/internal/AgentConfigImpl.java     |   21 +-
 .../gemfire/admin/jmx/internal/AgentImpl.java   |   20 +-
 .../admin/jmx/internal/AgentLauncher.java       |   21 +-
 .../admin/jmx/internal/CacheServerJmxImpl.java  |   21 +-
 .../admin/jmx/internal/ConfigAttributeInfo.java |   20 +-
 .../internal/ConfigurationParameterJmxImpl.java |   21 +-
 .../DistributedSystemHealthConfigJmxImpl.java   |   21 +-
 .../internal/DistributionLocatorJmxImpl.java    |   22 +-
 .../admin/jmx/internal/DynamicManagedBean.java  |   20 +-
 .../internal/GemFireHealthConfigJmxImpl.java    |   21 +-
 .../jmx/internal/GemFireHealthJmxImpl.java      |   21 +-
 .../admin/jmx/internal/GenerateMBeanHTML.java   |   21 +-
 .../gemfire/admin/jmx/internal/MBeanUtil.java   |   20 +-
 .../admin/jmx/internal/MX4JModelMBean.java      |   21 +-
 .../jmx/internal/MX4JServerSocketFactory.java   |   22 +-
 .../gemfire/admin/jmx/internal/MailManager.java |   21 +-
 .../admin/jmx/internal/ManagedResource.java     |   21 +-
 .../admin/jmx/internal/ManagedResourceType.java |   21 +-
 .../jmx/internal/MemberInfoWithStatsMBean.java  |   21 +-
 .../admin/jmx/internal/RMIRegistryService.java  |   20 +-
 .../jmx/internal/RMIRegistryServiceMBean.java   |   20 +-
 .../jmx/internal/RefreshNotificationType.java   |   21 +-
 .../jmx/internal/StatAlertNotification.java     |   21 +-
 .../jmx/internal/StatAlertsAggregator.java      |   21 +-
 .../jmx/internal/StatisticAttributeInfo.java    |   20 +-
 .../jmx/internal/StatisticResourceJmxImpl.java  |   21 +-
 .../SystemMemberBridgeServerJmxImpl.java        |   21 +-
 .../jmx/internal/SystemMemberCacheJmxImpl.java  |   21 +-
 .../admin/jmx/internal/SystemMemberJmx.java     |   21 +-
 .../admin/jmx/internal/SystemMemberJmxImpl.java |   21 +-
 .../jmx/internal/SystemMemberRegionJmxImpl.java |   21 +-
 .../gemfire/cache/AttributesFactory.java        |   70 +-
 .../gemfire/cache/AttributesMutator.java        |   21 +-
 .../java/com/gemstone/gemfire/cache/Cache.java  |   23 +-
 .../gemstone/gemfire/cache/CacheCallback.java   |   21 +-
 .../gemfire/cache/CacheClosedException.java     |   21 +-
 .../com/gemstone/gemfire/cache/CacheEvent.java  |   21 +-
 .../gemstone/gemfire/cache/CacheException.java  |   21 +-
 .../gemfire/cache/CacheExistsException.java     |   21 +-
 .../gemstone/gemfire/cache/CacheFactory.java    |   21 +-
 .../gemstone/gemfire/cache/CacheListener.java   |   21 +-
 .../com/gemstone/gemfire/cache/CacheLoader.java |   21 +-
 .../gemfire/cache/CacheLoaderException.java     |   21 +-
 .../gemfire/cache/CacheRuntimeException.java    |   21 +-
 .../gemstone/gemfire/cache/CacheStatistics.java |   21 +-
 .../gemfire/cache/CacheTransactionManager.java  |   21 +-
 .../com/gemstone/gemfire/cache/CacheWriter.java |   21 +-
 .../gemfire/cache/CacheWriterException.java     |   21 +-
 .../gemfire/cache/CacheXmlException.java        |   21 +-
 .../gemstone/gemfire/cache/ClientSession.java   |   21 +-
 .../gemfire/cache/CommitConflictException.java  |   21 +-
 .../cache/CommitDistributionException.java      |   21 +-
 .../cache/CommitIncompleteException.java        |   16 +
 .../gemfire/cache/CustomEvictionAttributes.java |   22 +-
 .../gemstone/gemfire/cache/CustomExpiry.java    |   21 +-
 .../com/gemstone/gemfire/cache/DataPolicy.java  |   40 +-
 .../com/gemstone/gemfire/cache/Declarable.java  |   21 +-
 .../gemfire/cache/DiskAccessException.java      |   21 +-
 .../com/gemstone/gemfire/cache/DiskStore.java   |   21 +-
 .../gemfire/cache/DiskStoreFactory.java         |   21 +-
 .../gemfire/cache/DiskWriteAttributes.java      |   21 +-
 .../cache/DiskWriteAttributesFactory.java       |   21 +-
 .../DuplicatePrimaryPartitionException.java     |   21 +-
 .../gemfire/cache/DynamicRegionFactory.java     |   21 +-
 .../gemfire/cache/DynamicRegionListener.java    |   21 +-
 .../gemfire/cache/EntryDestroyedException.java  |   21 +-
 .../com/gemstone/gemfire/cache/EntryEvent.java  |   21 +-
 .../gemfire/cache/EntryExistsException.java     |   21 +-
 .../gemfire/cache/EntryNotFoundException.java   |   21 +-
 .../gemfire/cache/EntryNotFoundInRegion.java    |   21 +-
 .../gemstone/gemfire/cache/EntryOperation.java  |   23 +-
 .../gemstone/gemfire/cache/EvictionAction.java  |   23 +-
 .../gemfire/cache/EvictionAlgorithm.java        |   23 +-
 .../gemfire/cache/EvictionAttributes.java       |   20 +-
 .../cache/EvictionAttributesMutator.java        |   23 +-
 .../gemfire/cache/EvictionCriteria.java         |   22 +-
 .../gemfire/cache/ExpirationAction.java         |   21 +-
 .../gemfire/cache/ExpirationAttributes.java     |   21 +-
 .../cache/FailedSynchronizationException.java   |   21 +-
 .../gemfire/cache/FixedPartitionAttributes.java |   21 +-
 .../gemfire/cache/FixedPartitionResolver.java   |   20 +-
 .../cache/GatewayConfigurationException.java    |   21 +-
 .../gemfire/cache/GatewayException.java         |   21 +-
 .../gemstone/gemfire/cache/GemFireCache.java    |   39 +-
 .../cache/IncompatibleVersionException.java     |   21 +-
 .../gemstone/gemfire/cache/InterestPolicy.java  |   21 +-
 .../cache/InterestRegistrationEvent.java        |   21 +-
 .../cache/InterestRegistrationListener.java     |   21 +-
 .../gemfire/cache/InterestResultPolicy.java     |   21 +-
 .../gemstone/gemfire/cache/LoaderHelper.java    |   21 +-
 .../com/gemstone/gemfire/cache/LossAction.java  |   21 +-
 .../gemfire/cache/LowMemoryException.java       |   21 +-
 .../gemfire/cache/MembershipAttributes.java     |   21 +-
 .../com/gemstone/gemfire/cache/MirrorType.java  |   21 +-
 .../cache/NoQueueServersAvailableException.java |   21 +-
 ...NoSubscriptionServersAvailableException.java |   21 +-
 .../com/gemstone/gemfire/cache/Operation.java   |   21 +-
 .../cache/OperationAbortedException.java        |   21 +-
 .../gemfire/cache/PartitionAttributes.java      |   21 +-
 .../cache/PartitionAttributesFactory.java       |   20 +-
 .../gemfire/cache/PartitionResolver.java        |   20 +-
 .../PartitionedRegionDistributionException.java |   21 +-
 .../PartitionedRegionStorageException.java      |   21 +-
 .../java/com/gemstone/gemfire/cache/Region.java |   21 +-
 .../gemfire/cache/RegionAccessException.java    |   21 +-
 .../gemfire/cache/RegionAttributes.java         |   21 +-
 .../gemfire/cache/RegionDestroyedException.java |   21 +-
 .../cache/RegionDistributionException.java      |   21 +-
 .../com/gemstone/gemfire/cache/RegionEvent.java |   21 +-
 .../gemfire/cache/RegionExistsException.java    |   21 +-
 .../gemstone/gemfire/cache/RegionFactory.java   |   46 +-
 .../gemfire/cache/RegionMembershipListener.java |   21 +-
 .../cache/RegionReinitializedException.java     |   21 +-
 .../gemfire/cache/RegionRoleException.java      |   21 +-
 .../gemfire/cache/RegionRoleListener.java       |   21 +-
 .../gemstone/gemfire/cache/RegionService.java   |   23 +-
 .../gemstone/gemfire/cache/RegionShortcut.java  |   71 +-
 .../cache/RemoteTransactionException.java       |   21 +-
 .../gemstone/gemfire/cache/RequiredRoles.java   |   21 +-
 .../gemfire/cache/ResourceException.java        |   21 +-
 .../gemfire/cache/ResumptionAction.java         |   21 +-
 .../com/gemstone/gemfire/cache/RoleEvent.java   |   21 +-
 .../gemstone/gemfire/cache/RoleException.java   |   21 +-
 .../java/com/gemstone/gemfire/cache/Scope.java  |   21 +-
 .../gemfire/cache/SerializedCacheValue.java     |   21 +-
 .../cache/StatisticsDisabledException.java      |   21 +-
 .../gemfire/cache/SubscriptionAttributes.java   |   21 +-
 .../SynchronizationCommitConflictException.java |   21 +-
 .../gemfire/cache/TimeoutException.java         |   21 +-
 ...TransactionDataNodeHasDepartedException.java |   21 +-
 .../TransactionDataNotColocatedException.java   |   21 +-
 .../TransactionDataRebalancedException.java     |   21 +-
 .../gemfire/cache/TransactionEvent.java         |   21 +-
 .../gemfire/cache/TransactionException.java     |   21 +-
 .../gemstone/gemfire/cache/TransactionId.java   |   21 +-
 .../cache/TransactionInDoubtException.java      |   21 +-
 .../gemfire/cache/TransactionListener.java      |   21 +-
 .../gemfire/cache/TransactionWriter.java        |   21 +-
 .../cache/TransactionWriterException.java       |   21 +-
 ...upportedOperationInTransactionException.java |   21 +-
 .../cache/UnsupportedVersionException.java      |   21 +-
 .../gemfire/cache/VersionException.java         |   21 +-
 .../gemfire/cache/asyncqueue/AsyncEvent.java    |   21 +-
 .../cache/asyncqueue/AsyncEventListener.java    |   21 +-
 .../cache/asyncqueue/AsyncEventQueue.java       |   21 +-
 .../asyncqueue/AsyncEventQueueFactory.java      |   23 +-
 .../internal/AsyncEventQueueFactoryImpl.java    |   21 +-
 .../internal/AsyncEventQueueImpl.java           |   21 +-
 .../internal/AsyncEventQueueStats.java          |   21 +-
 .../internal/ParallelAsyncEventQueueImpl.java   |   16 +
 .../internal/SerialAsyncEventQueueImpl.java     |   16 +
 .../client/AllConnectionsInUseException.java    |   21 +-
 .../gemfire/cache/client/ClientCache.java       |   21 +-
 .../cache/client/ClientCacheFactory.java        |   21 +-
 .../cache/client/ClientNotReadyException.java   |   21 +-
 .../cache/client/ClientRegionFactory.java       |   21 +-
 .../cache/client/ClientRegionShortcut.java      |   23 +-
 .../client/NoAvailableLocatorsException.java    |   21 +-
 .../client/NoAvailableServersException.java     |   21 +-
 .../com/gemstone/gemfire/cache/client/Pool.java |   21 +-
 .../gemfire/cache/client/PoolFactory.java       |   21 +-
 .../gemfire/cache/client/PoolManager.java       |   21 +-
 .../client/ServerConnectivityException.java     |   21 +-
 .../cache/client/ServerOperationException.java  |   21 +-
 .../ServerRefusedConnectionException.java       |   21 +-
 .../client/SubscriptionNotEnabledException.java |   21 +-
 .../cache/client/internal/AbstractOp.java       |   21 +-
 .../cache/client/internal/AddPDXEnumOp.java     |   21 +-
 .../cache/client/internal/AddPDXTypeOp.java     |   21 +-
 .../client/internal/AuthenticateUserOp.java     |   21 +-
 .../internal/AutoConnectionSourceImpl.java      |   21 +-
 .../client/internal/CacheServerLoadMessage.java |   21 +-
 .../gemfire/cache/client/internal/ClearOp.java  |   21 +-
 .../client/internal/ClientMetadataService.java  |   20 +-
 .../client/internal/ClientPartitionAdvisor.java |   21 +-
 .../internal/ClientRegionFactoryImpl.java       |   21 +-
 .../cache/client/internal/ClientUpdater.java    |   21 +-
 .../client/internal/CloseConnectionOp.java      |   21 +-
 .../gemfire/cache/client/internal/CommitOp.java |   21 +-
 .../cache/client/internal/Connection.java       |   21 +-
 .../client/internal/ConnectionFactory.java      |   21 +-
 .../client/internal/ConnectionFactoryImpl.java  |   45 +-
 .../cache/client/internal/ConnectionImpl.java   |   49 +-
 .../cache/client/internal/ConnectionSource.java |   21 +-
 .../cache/client/internal/ConnectionStats.java  |   21 +-
 .../cache/client/internal/ContainsKeyOp.java    |   21 +-
 .../DataSerializerRecoveryListener.java         |   21 +-
 .../cache/client/internal/DestroyOp.java        |   21 +-
 .../cache/client/internal/DestroyRegionOp.java  |   21 +-
 .../gemfire/cache/client/internal/Endpoint.java |   21 +-
 .../cache/client/internal/EndpointManager.java  |   21 +-
 .../client/internal/EndpointManagerImpl.java    |   21 +-
 .../cache/client/internal/ExecutablePool.java   |   21 +-
 .../client/internal/ExecuteFunctionHelper.java  |   21 +-
 .../client/internal/ExecuteFunctionNoAckOp.java |   21 +-
 .../client/internal/ExecuteFunctionOp.java      |   21 +-
 .../internal/ExecuteRegionFunctionNoAckOp.java  |   21 +-
 .../internal/ExecuteRegionFunctionOp.java       |   21 +-
 .../ExecuteRegionFunctionSingleHopOp.java       |   21 +-
 .../internal/ExplicitConnectionSourceImpl.java  |   21 +-
 .../gemfire/cache/client/internal/GetAllOp.java |   21 +-
 .../client/internal/GetClientPRMetaDataOp.java  |   20 +-
 .../GetClientPartitionAttributesOp.java         |   20 +-
 .../cache/client/internal/GetEntryOp.java       |   21 +-
 .../cache/client/internal/GetEventValueOp.java  |   20 +-
 .../client/internal/GetFunctionAttributeOp.java |   21 +-
 .../gemfire/cache/client/internal/GetOp.java    |   21 +-
 .../cache/client/internal/GetPDXEnumByIdOp.java |   21 +-
 .../cache/client/internal/GetPDXEnumsOp.java    |   21 +-
 .../client/internal/GetPDXIdForEnumOp.java      |   21 +-
 .../client/internal/GetPDXIdForTypeOp.java      |   21 +-
 .../cache/client/internal/GetPDXTypeByIdOp.java |   21 +-
 .../cache/client/internal/GetPDXTypesOp.java    |   21 +-
 .../internal/InstantiatorRecoveryListener.java  |   21 +-
 .../cache/client/internal/InternalPool.java     |   21 +-
 .../cache/client/internal/InvalidateOp.java     |   21 +-
 .../gemfire/cache/client/internal/KeySetOp.java |   21 +-
 .../cache/client/internal/LiveServerPinger.java |   21 +-
 .../internal/LocatorDiscoveryCallback.java      |   21 +-
 .../LocatorDiscoveryCallbackAdapter.java        |   21 +-
 .../cache/client/internal/MakePrimaryOp.java    |   21 +-
 .../gemfire/cache/client/internal/Op.java       |   23 +-
 .../cache/client/internal/OpExecutorImpl.java   |   21 +-
 .../internal/PdxRegistryRecoveryListener.java   |   21 +-
 .../gemfire/cache/client/internal/PingOp.java   |   21 +-
 .../gemfire/cache/client/internal/PoolImpl.java |   21 +-
 .../cache/client/internal/PrimaryAckOp.java     |   21 +-
 .../cache/client/internal/ProxyCache.java       |   21 +-
 .../client/internal/ProxyCacheCloseOp.java      |   21 +-
 .../cache/client/internal/ProxyRegion.java      |   21 +-
 .../gemfire/cache/client/internal/PutAllOp.java |   21 +-
 .../gemfire/cache/client/internal/PutOp.java    |   21 +-
 .../gemfire/cache/client/internal/QueryOp.java  |   21 +-
 .../client/internal/QueueConnectionImpl.java    |   21 +-
 .../cache/client/internal/QueueManager.java     |   21 +-
 .../cache/client/internal/QueueManagerImpl.java |   21 +-
 .../cache/client/internal/QueueState.java       |   16 +
 .../cache/client/internal/QueueStateImpl.java   |   21 +-
 .../cache/client/internal/ReadyForEventsOp.java |   21 +-
 .../internal/RegisterDataSerializersOp.java     |   21 +-
 .../internal/RegisterInstantiatorsOp.java       |   21 +-
 .../client/internal/RegisterInterestListOp.java |   21 +-
 .../client/internal/RegisterInterestOp.java     |   21 +-
 .../internal/RegisterInterestTracker.java       |   21 +-
 .../cache/client/internal/RemoveAllOp.java      |   21 +-
 .../cache/client/internal/RollbackOp.java       |   21 +-
 .../cache/client/internal/ServerBlackList.java  |   21 +-
 .../cache/client/internal/ServerProxy.java      |   21 +-
 .../client/internal/ServerRegionDataAccess.java |   23 +-
 .../client/internal/ServerRegionProxy.java      |   21 +-
 .../internal/SingleHopClientExecutor.java       |   21 +-
 .../internal/SingleHopOperationCallable.java    |   21 +-
 .../gemfire/cache/client/internal/SizeOp.java   |   21 +-
 .../cache/client/internal/TXFailoverOp.java     |   21 +-
 .../client/internal/TXSynchronizationOp.java    |   21 +-
 .../internal/UnregisterInterestListOp.java      |   21 +-
 .../client/internal/UnregisterInterestOp.java   |   21 +-
 .../cache/client/internal/UserAttributes.java   |   21 +-
 .../locator/ClientConnectionRequest.java        |   21 +-
 .../locator/ClientConnectionResponse.java       |   21 +-
 .../locator/ClientReplacementRequest.java       |   21 +-
 .../internal/locator/GetAllServersRequest.java  |   20 +-
 .../internal/locator/GetAllServersResponse.java |   20 +-
 .../internal/locator/LocatorListRequest.java    |   21 +-
 .../internal/locator/LocatorListResponse.java   |   21 +-
 .../internal/locator/LocatorStatusRequest.java  |   20 +-
 .../internal/locator/LocatorStatusResponse.java |   20 +-
 .../locator/QueueConnectionRequest.java         |   21 +-
 .../locator/QueueConnectionResponse.java        |   21 +-
 .../internal/locator/SerializationHelper.java   |   21 +-
 .../internal/locator/ServerLocationRequest.java |   23 +-
 .../locator/ServerLocationResponse.java         |   23 +-
 .../locator/wan/LocatorMembershipListener.java  |   21 +-
 .../pooling/ConnectionDestroyedException.java   |   21 +-
 .../internal/pooling/ConnectionManager.java     |   21 +-
 .../internal/pooling/ConnectionManagerImpl.java |   26 +-
 .../internal/pooling/PooledConnection.java      |   21 +-
 .../gemfire/cache/control/RebalanceFactory.java |   21 +-
 .../cache/control/RebalanceOperation.java       |   21 +-
 .../gemfire/cache/control/RebalanceResults.java |   21 +-
 .../gemfire/cache/control/ResourceManager.java  |   21 +-
 .../execute/EmtpyRegionFunctionException.java   |   21 +-
 .../gemfire/cache/execute/Execution.java        |   20 +-
 .../gemfire/cache/execute/Function.java         |   20 +-
 .../gemfire/cache/execute/FunctionAdapter.java  |   20 +-
 .../gemfire/cache/execute/FunctionContext.java  |   20 +-
 .../cache/execute/FunctionException.java        |   20 +-
 .../FunctionInvocationTargetException.java      |   20 +-
 .../gemfire/cache/execute/FunctionService.java  |   20 +-
 .../cache/execute/RegionFunctionContext.java    |   21 +-
 .../gemfire/cache/execute/ResultCollector.java  |   20 +-
 .../gemfire/cache/execute/ResultSender.java     |   20 +-
 .../internal/FunctionServiceManager.java        |   24 +-
 .../gemfire/cache/hdfs/HDFSIOException.java     |   21 +-
 .../gemstone/gemfire/cache/hdfs/HDFSStore.java  |   21 +-
 .../gemfire/cache/hdfs/HDFSStoreFactory.java    |   21 +-
 .../gemfire/cache/hdfs/HDFSStoreMutator.java    |   21 +-
 .../cache/hdfs/StoreExistsException.java        |   21 +-
 .../cache/hdfs/internal/FailureTracker.java     |   21 +-
 .../cache/hdfs/internal/FlushObserver.java      |   16 +
 .../hdfs/internal/HDFSBucketRegionQueue.java    |   21 +-
 .../cache/hdfs/internal/HDFSEntriesSet.java     |   21 +-
 .../cache/hdfs/internal/HDFSEventListener.java  |   21 +-
 .../hdfs/internal/HDFSEventQueueFilter.java     |   21 +-
 .../hdfs/internal/HDFSGatewayEventImpl.java     |   22 +-
 .../hdfs/internal/HDFSIntegrationUtil.java      |   21 +-
 .../HDFSParallelGatewaySenderQueue.java         |   21 +-
 .../hdfs/internal/HDFSStoreConfigHolder.java    |   23 +-
 .../cache/hdfs/internal/HDFSStoreCreation.java  |   23 +-
 .../hdfs/internal/HDFSStoreFactoryImpl.java     |   21 +-
 .../cache/hdfs/internal/HDFSStoreImpl.java      |   21 +-
 .../hdfs/internal/HDFSStoreMutatorImpl.java     |   23 +-
 .../HDFSWriteOnlyStoreEventListener.java        |   21 +-
 .../hdfs/internal/HoplogListenerForRegion.java  |   21 +-
 .../cache/hdfs/internal/PersistedEventImpl.java |   21 +-
 .../hdfs/internal/QueuedPersistentEvent.java    |   16 +
 .../hdfs/internal/SignalledFlushObserver.java   |   16 +
 .../internal/SortedHDFSQueuePersistedEvent.java |   21 +-
 .../internal/SortedHoplogPersistedEvent.java    |   21 +-
 .../UnsortedHDFSQueuePersistedEvent.java        |   21 +-
 .../internal/UnsortedHoplogPersistedEvent.java  |   21 +-
 .../cache/hdfs/internal/cardinality/Bits.java   |   21 +-
 .../cardinality/CardinalityMergeException.java  |   21 +-
 .../hdfs/internal/cardinality/HyperLogLog.java  |   21 +-
 .../hdfs/internal/cardinality/IBuilder.java     |   21 +-
 .../hdfs/internal/cardinality/ICardinality.java |   21 +-
 .../hdfs/internal/cardinality/MurmurHash.java   |   21 +-
 .../hdfs/internal/cardinality/RegisterSet.java  |   21 +-
 .../hdfs/internal/hoplog/AbstractHoplog.java    |   21 +-
 .../hoplog/AbstractHoplogOrganizer.java         |   21 +-
 .../cache/hdfs/internal/hoplog/BloomFilter.java |   21 +-
 .../hoplog/CloseTmpHoplogsTimerTask.java        |   21 +-
 .../hdfs/internal/hoplog/CompactionStatus.java  |   21 +-
 .../cache/hdfs/internal/hoplog/FlushStatus.java |   16 +
 .../internal/hoplog/HDFSCompactionManager.java  |   21 +-
 .../internal/hoplog/HDFSFlushQueueArgs.java     |   16 +
 .../internal/hoplog/HDFSFlushQueueFunction.java |   16 +
 .../hoplog/HDFSForceCompactionArgs.java         |   21 +-
 .../hoplog/HDFSForceCompactionFunction.java     |   21 +-
 .../HDFSForceCompactionResultCollector.java     |   21 +-
 .../hoplog/HDFSLastCompactionTimeFunction.java  |   21 +-
 .../internal/hoplog/HDFSRegionDirector.java     |   21 +-
 .../hdfs/internal/hoplog/HDFSStoreDirector.java |   21 +-
 .../hoplog/HDFSUnsortedHoplogOrganizer.java     |   21 +-
 .../hdfs/internal/hoplog/HFileSortedOplog.java  |   21 +-
 .../hoplog/HdfsSortedOplogOrganizer.java        |   21 +-
 .../cache/hdfs/internal/hoplog/Hoplog.java      |   21 +-
 .../hdfs/internal/hoplog/HoplogConfig.java      |   21 +-
 .../hdfs/internal/hoplog/HoplogListener.java    |   21 +-
 .../hdfs/internal/hoplog/HoplogOrganizer.java   |   21 +-
 .../hdfs/internal/hoplog/HoplogSetIterator.java |   21 +-
 .../hdfs/internal/hoplog/HoplogSetReader.java   |   21 +-
 .../internal/hoplog/SequenceFileHoplog.java     |   21 +-
 .../hoplog/mapred/AbstractGFRecordReader.java   |   21 +-
 .../internal/hoplog/mapred/GFInputFormat.java   |   21 +-
 .../internal/hoplog/mapred/GFOutputFormat.java  |   21 +-
 .../mapreduce/AbstractGFRecordReader.java       |   21 +-
 .../hoplog/mapreduce/GFInputFormat.java         |   21 +-
 .../hdfs/internal/hoplog/mapreduce/GFKey.java   |   21 +-
 .../hoplog/mapreduce/GFOutputFormat.java        |   21 +-
 .../hoplog/mapreduce/HDFSSplitIterator.java     |   21 +-
 .../internal/hoplog/mapreduce/HoplogUtil.java   |   21 +-
 .../hoplog/mapreduce/RWSplitIterator.java       |   21 +-
 .../hoplog/mapreduce/StreamSplitIterator.java   |   21 +-
 .../org/apache/hadoop/io/SequenceFile.java      |   21 +-
 .../operations/CloseCQOperationContext.java     |   21 +-
 .../operations/DestroyOperationContext.java     |   21 +-
 .../operations/ExecuteCQOperationContext.java   |   21 +-
 .../ExecuteFunctionOperationContext.java        |   21 +-
 .../GetDurableCQsOperationContext.java          |   21 +-
 .../cache/operations/GetOperationContext.java   |   21 +-
 .../operations/InterestOperationContext.java    |   21 +-
 .../gemfire/cache/operations/InterestType.java  |   21 +-
 .../operations/InvalidateOperationContext.java  |   21 +-
 .../cache/operations/KeyOperationContext.java   |   21 +-
 .../operations/KeySetOperationContext.java      |   21 +-
 .../operations/KeyValueOperationContext.java    |   21 +-
 .../cache/operations/OperationContext.java      |   21 +-
 .../operations/PutAllOperationContext.java      |   21 +-
 .../cache/operations/PutOperationContext.java   |   21 +-
 .../cache/operations/QueryOperationContext.java |   21 +-
 .../operations/RegionClearOperationContext.java |   21 +-
 .../RegionCreateOperationContext.java           |   21 +-
 .../RegionDestroyOperationContext.java          |   21 +-
 .../operations/RegionOperationContext.java      |   21 +-
 .../RegisterInterestOperationContext.java       |   21 +-
 .../operations/RemoveAllOperationContext.java   |   21 +-
 .../operations/StopCQOperationContext.java      |   21 +-
 .../UnregisterInterestOperationContext.java     |   21 +-
 .../internal/GetOperationContextImpl.java       |   16 +
 .../cache/partition/PartitionListener.java      |   20 +-
 .../partition/PartitionListenerAdapter.java     |   23 +-
 .../cache/partition/PartitionManager.java       |   20 +-
 .../cache/partition/PartitionMemberInfo.java    |   21 +-
 .../PartitionNotAvailableException.java         |   21 +-
 .../cache/partition/PartitionRebalanceInfo.java |   21 +-
 .../cache/partition/PartitionRegionHelper.java  |   20 +-
 .../cache/partition/PartitionRegionInfo.java    |   21 +-
 .../ConflictingPersistentDataException.java     |   21 +-
 .../persistence/PartitionOfflineException.java  |   21 +-
 .../gemfire/cache/persistence/PersistentID.java |   23 +-
 .../PersistentReplicatesOfflineException.java   |   21 +-
 .../persistence/RevokeFailedException.java      |   21 +-
 .../RevokedPersistentDataException.java         |   21 +-
 .../gemfire/cache/query/Aggregator.java         |   16 +
 .../cache/query/AmbiguousNameException.java     |   21 +-
 .../gemfire/cache/query/CqAttributes.java       |   21 +-
 .../cache/query/CqAttributesFactory.java        |   21 +-
 .../cache/query/CqAttributesMutator.java        |   21 +-
 .../gemfire/cache/query/CqClosedException.java  |   21 +-
 .../gemstone/gemfire/cache/query/CqEvent.java   |   21 +-
 .../gemfire/cache/query/CqException.java        |   21 +-
 .../gemfire/cache/query/CqExistsException.java  |   21 +-
 .../gemfire/cache/query/CqListener.java         |   21 +-
 .../gemstone/gemfire/cache/query/CqQuery.java   |   21 +-
 .../gemstone/gemfire/cache/query/CqResults.java |   21 +-
 .../cache/query/CqServiceStatistics.java        |   21 +-
 .../gemstone/gemfire/cache/query/CqState.java   |   21 +-
 .../gemfire/cache/query/CqStatistics.java       |   21 +-
 .../gemfire/cache/query/CqStatusListener.java   |   21 +-
 .../cache/query/FunctionDomainException.java    |   21 +-
 .../com/gemstone/gemfire/cache/query/Index.java |   21 +-
 .../cache/query/IndexCreationException.java     |   21 +-
 .../cache/query/IndexExistsException.java       |   21 +-
 .../cache/query/IndexInvalidException.java      |   21 +-
 .../cache/query/IndexMaintenanceException.java  |   21 +-
 .../cache/query/IndexNameConflictException.java |   21 +-
 .../gemfire/cache/query/IndexStatistics.java    |   21 +-
 .../gemstone/gemfire/cache/query/IndexType.java |   21 +-
 .../query/MultiIndexCreationException.java      |   16 +
 .../cache/query/NameNotFoundException.java      |   21 +-
 .../cache/query/NameResolutionException.java    |   21 +-
 .../query/ParameterCountInvalidException.java   |   21 +-
 .../com/gemstone/gemfire/cache/query/Query.java |   21 +-
 .../gemfire/cache/query/QueryException.java     |   21 +-
 .../query/QueryExecutionLowMemoryException.java |   21 +-
 .../query/QueryExecutionTimeoutException.java   |   21 +-
 .../cache/query/QueryInvalidException.java      |   21 +-
 .../query/QueryInvocationTargetException.java   |   21 +-
 .../gemfire/cache/query/QueryService.java       |   21 +-
 .../gemfire/cache/query/QueryStatistics.java    |   21 +-
 .../cache/query/RegionNotFoundException.java    |   21 +-
 .../gemfire/cache/query/SelectResults.java      |   21 +-
 .../gemstone/gemfire/cache/query/Struct.java    |   21 +-
 .../cache/query/TypeMismatchException.java      |   21 +-
 .../query/internal/AbstractCompiledValue.java   |   22 +-
 .../internal/AbstractGroupOrRangeJunction.java  |   21 +-
 .../cache/query/internal/AllGroupJunction.java  |   21 +-
 .../query/internal/AttributeDescriptor.java     |   22 +-
 .../gemfire/cache/query/internal/Bag.java       |   21 +-
 .../internal/CompiledAggregateFunction.java     |   16 +
 .../query/internal/CompiledBindArgument.java    |   22 +-
 .../query/internal/CompiledComparison.java      |   22 +-
 .../query/internal/CompiledConstruction.java    |   22 +-
 .../cache/query/internal/CompiledFunction.java  |   22 +-
 .../query/internal/CompiledGroupBySelect.java   |   16 +
 .../cache/query/internal/CompiledID.java        |   22 +-
 .../cache/query/internal/CompiledIn.java        |   22 +-
 .../query/internal/CompiledIndexOperation.java  |   22 +-
 .../query/internal/CompiledIteratorDef.java     |   21 +-
 .../cache/query/internal/CompiledJunction.java  |   22 +-
 .../cache/query/internal/CompiledLike.java      |   21 +-
 .../cache/query/internal/CompiledLiteral.java   |   22 +-
 .../cache/query/internal/CompiledNegation.java  |   22 +-
 .../cache/query/internal/CompiledOperation.java |   22 +-
 .../cache/query/internal/CompiledPath.java      |   22 +-
 .../cache/query/internal/CompiledRegion.java    |   22 +-
 .../cache/query/internal/CompiledSelect.java    |   22 +-
 .../query/internal/CompiledSortCriterion.java   |   21 +-
 .../query/internal/CompiledUnaryMinus.java      |   21 +-
 .../cache/query/internal/CompiledUndefined.java |   22 +-
 .../cache/query/internal/CompiledValue.java     |   22 +-
 .../query/internal/CompositeGroupJunction.java  |   21 +-
 .../gemfire/cache/query/internal/CqEntry.java   |   21 +-
 .../cache/query/internal/CqQueryVsdStats.java   |   21 +-
 .../cache/query/internal/CqStateImpl.java       |   22 +-
 .../internal/CumulativeNonDistinctResults.java  |   16 +
 .../cache/query/internal/DefaultQuery.java      |   22 +-
 .../query/internal/DefaultQueryService.java     |   22 +-
 .../cache/query/internal/ExecutionContext.java  |   22 +-
 .../gemfire/cache/query/internal/Filter.java    |   22 +-
 .../gemfire/cache/query/internal/Functions.java |   22 +-
 .../cache/query/internal/GroupJunction.java     |   21 +-
 .../cache/query/internal/HashingStrategy.java   |   21 +-
 .../gemfire/cache/query/internal/IndexInfo.java |   21 +-
 .../internal/IndexTrackingQueryObserver.java    |   28 +-
 .../cache/query/internal/IndexUpdater.java      |   21 +-
 .../gemfire/cache/query/internal/Indexable.java |   21 +-
 .../cache/query/internal/LinkedResultSet.java   |   21 +-
 .../cache/query/internal/LinkedStructSet.java   |   21 +-
 .../cache/query/internal/MapIndexable.java      |   16 +
 .../cache/query/internal/MethodDispatch.java    |   22 +-
 .../cache/query/internal/NWayMergeResults.java  |   16 +
 .../gemfire/cache/query/internal/Negatable.java |   22 +-
 .../gemfire/cache/query/internal/NullToken.java |   23 +-
 .../cache/query/internal/ObjectIntHashMap.java  |   21 +-
 .../cache/query/internal/OrderByComparator.java |   18 +-
 .../internal/OrderByComparatorUnmapped.java     |   16 +
 .../gemfire/cache/query/internal/Ordered.java   |   16 +
 .../cache/query/internal/OrganizedOperands.java |   21 +-
 .../cache/query/internal/PRQueryTraceInfo.java  |   22 +-
 .../gemfire/cache/query/internal/PathUtils.java |   22 +-
 .../gemfire/cache/query/internal/PlanInfo.java  |   22 +-
 .../cache/query/internal/ProxyQueryService.java |   21 +-
 .../gemfire/cache/query/internal/QCompiler.java |   22 +-
 .../gemfire/cache/query/internal/QRegion.java   |   21 +-
 .../gemfire/cache/query/internal/QScope.java    |   22 +-
 .../QueryExecutionCanceledException.java        |   21 +-
 .../query/internal/QueryExecutionContext.java   |   24 +-
 .../cache/query/internal/QueryExecutor.java     |   21 +-
 .../cache/query/internal/QueryMonitor.java      |   21 +-
 .../cache/query/internal/QueryObserver.java     |   22 +-
 .../query/internal/QueryObserverAdapter.java    |   22 +-
 .../query/internal/QueryObserverHolder.java     |   22 +-
 .../cache/query/internal/QueryUtils.java        |   21 +-
 .../cache/query/internal/RangeJunction.java     |   21 +-
 .../cache/query/internal/ResultsBag.java        |   16 +
 .../ResultsCollectionCopyOnReadWrapper.java     |   21 +-
 ...ResultsCollectionPdxDeserializerWrapper.java |   21 +-
 .../internal/ResultsCollectionWrapper.java      |   21 +-
 .../cache/query/internal/ResultsSet.java        |   21 +-
 .../cache/query/internal/RuntimeIterator.java   |   22 +-
 .../query/internal/SelectResultsComparator.java |   21 +-
 .../cache/query/internal/SortedResultSet.java   |   21 +-
 .../cache/query/internal/SortedResultsBag.java  |   16 +
 .../cache/query/internal/SortedStructBag.java   |   16 +
 .../cache/query/internal/SortedStructSet.java   |   21 +-
 .../gemfire/cache/query/internal/StructBag.java |   21 +-
 .../cache/query/internal/StructFields.java      |   16 +
 .../cache/query/internal/StructImpl.java        |   21 +-
 .../gemfire/cache/query/internal/StructSet.java |   21 +-
 .../gemfire/cache/query/internal/Support.java   |   22 +-
 .../gemfire/cache/query/internal/Undefined.java |   22 +-
 .../internal/aggregate/AbstractAggregator.java  |   16 +
 .../cache/query/internal/aggregate/Avg.java     |   16 +
 .../query/internal/aggregate/AvgBucketNode.java |   16 +
 .../query/internal/aggregate/AvgDistinct.java   |   16 +
 .../aggregate/AvgDistinctPRQueryNode.java       |   16 +
 .../internal/aggregate/AvgPRQueryNode.java      |   16 +
 .../cache/query/internal/aggregate/Count.java   |   16 +
 .../query/internal/aggregate/CountDistinct.java |   16 +
 .../aggregate/CountDistinctPRQueryNode.java     |   16 +
 .../internal/aggregate/CountPRQueryNode.java    |   16 +
 .../internal/aggregate/DistinctAggregator.java  |   16 +
 .../cache/query/internal/aggregate/MaxMin.java  |   16 +
 .../cache/query/internal/aggregate/Sum.java     |   16 +
 .../query/internal/aggregate/SumDistinct.java   |   16 +
 .../aggregate/SumDistinctPRQueryNode.java       |   16 +
 .../cache/query/internal/cq/ClientCQ.java       |   16 +
 .../cache/query/internal/cq/CqService.java      |   16 +
 .../query/internal/cq/CqServiceProvider.java    |   16 +
 .../query/internal/cq/InternalCqQuery.java      |   16 +
 .../query/internal/cq/MissingCqService.java     |   16 +
 .../internal/cq/MissingCqServiceStatistics.java |   16 +
 .../cache/query/internal/cq/ServerCQ.java       |   16 +
 .../query/internal/cq/spi/CqServiceFactory.java |   16 +
 .../query/internal/index/AbstractIndex.java     |   44 +-
 .../query/internal/index/AbstractMapIndex.java  |   21 +-
 .../internal/index/CompactMapRangeIndex.java    |   21 +-
 .../query/internal/index/CompactRangeIndex.java |   21 +-
 .../query/internal/index/DummyQRegion.java      |   21 +-
 .../index/FunctionalIndexCreationHelper.java    |   21 +-
 .../cache/query/internal/index/HashIndex.java   |   21 +-
 .../query/internal/index/HashIndexSet.java      |   21 +-
 .../query/internal/index/HashIndexStrategy.java |   21 +-
 .../query/internal/index/IMQException.java      |   21 +-
 .../internal/index/IndexConcurrentHashSet.java  |   21 +-
 .../query/internal/index/IndexCreationData.java |   21 +-
 .../internal/index/IndexCreationHelper.java     |   21 +-
 .../cache/query/internal/index/IndexData.java   |   21 +-
 .../query/internal/index/IndexElemArray.java    |   21 +-
 .../query/internal/index/IndexManager.java      |   24 +-
 .../query/internal/index/IndexProtocol.java     |   20 +-
 .../cache/query/internal/index/IndexStats.java  |   21 +-
 .../cache/query/internal/index/IndexStore.java  |   23 +-
 .../cache/query/internal/index/IndexUtils.java  |   21 +-
 .../index/IndexedExpressionEvaluator.java       |   21 +-
 .../query/internal/index/MapIndexStore.java     |   21 +-
 .../query/internal/index/MapRangeIndex.java     |   21 +-
 .../query/internal/index/MemoryIndexStore.java  |   21 +-
 .../query/internal/index/PartitionedIndex.java  |   21 +-
 .../query/internal/index/PrimaryKeyIndex.java   |   21 +-
 .../index/PrimaryKeyIndexCreationHelper.java    |   21 +-
 .../cache/query/internal/index/RangeIndex.java  |   21 +-
 .../query/internal/parse/ASTAggregateFunc.java  |   16 +
 .../cache/query/internal/parse/ASTAnd.java      |   21 +-
 .../query/internal/parse/ASTCombination.java    |   21 +-
 .../query/internal/parse/ASTCompareOp.java      |   21 +-
 .../query/internal/parse/ASTConstruction.java   |   21 +-
 .../query/internal/parse/ASTConversionExpr.java |   21 +-
 .../cache/query/internal/parse/ASTDummy.java    |   16 +
 .../cache/query/internal/parse/ASTGroupBy.java  |   21 +-
 .../cache/query/internal/parse/ASTHint.java     |   21 +-
 .../query/internal/parse/ASTHintIdentifier.java |   21 +-
 .../query/internal/parse/ASTIdentifier.java     |   21 +-
 .../cache/query/internal/parse/ASTImport.java   |   21 +-
 .../cache/query/internal/parse/ASTIn.java       |   21 +-
 .../query/internal/parse/ASTIteratorDef.java    |   21 +-
 .../cache/query/internal/parse/ASTLike.java     |   21 +-
 .../cache/query/internal/parse/ASTLimit.java    |   23 +-
 .../cache/query/internal/parse/ASTLiteral.java  |   21 +-
 .../internal/parse/ASTMethodInvocation.java     |   21 +-
 .../cache/query/internal/parse/ASTOr.java       |   21 +-
 .../cache/query/internal/parse/ASTOrderBy.java  |   21 +-
 .../query/internal/parse/ASTParameter.java      |   21 +-
 .../cache/query/internal/parse/ASTPostfix.java  |   21 +-
 .../query/internal/parse/ASTProjection.java     |   21 +-
 .../query/internal/parse/ASTRegionPath.java     |   21 +-
 .../cache/query/internal/parse/ASTSelect.java   |   21 +-
 .../query/internal/parse/ASTSortCriterion.java  |   21 +-
 .../cache/query/internal/parse/ASTTrace.java    |   21 +-
 .../cache/query/internal/parse/ASTType.java     |   21 +-
 .../cache/query/internal/parse/ASTTypeCast.java |   21 +-
 .../cache/query/internal/parse/ASTUnary.java    |   21 +-
 .../query/internal/parse/ASTUndefinedExpr.java  |   21 +-
 .../query/internal/parse/ASTUnsupported.java    |   21 +-
 .../cache/query/internal/parse/GemFireAST.java  |   21 +-
 .../cache/query/internal/parse/UtilParser.java  |   21 +-
 .../internal/types/CollectionTypeImpl.java      |   21 +-
 .../types/ExtendedNumericComparator.java        |   22 +-
 .../cache/query/internal/types/MapTypeImpl.java |   21 +-
 .../query/internal/types/NumericComparator.java |   22 +-
 .../query/internal/types/ObjectTypeImpl.java    |   21 +-
 .../query/internal/types/StructTypeImpl.java    |   21 +-
 .../internal/types/TemporalComparator.java      |   22 +-
 .../cache/query/internal/types/TypeUtils.java   |   22 +-
 .../query/internal/utils/LimitIterator.java     |   16 +
 .../cache/query/internal/utils/PDXUtils.java    |   16 +
 .../cache/query/types/CollectionType.java       |   21 +-
 .../gemfire/cache/query/types/MapType.java      |   21 +-
 .../gemfire/cache/query/types/ObjectType.java   |   21 +-
 .../gemfire/cache/query/types/StructType.java   |   21 +-
 .../gemfire/cache/server/CacheServer.java       |   21 +-
 .../cache/server/ClientSubscriptionConfig.java  |   21 +-
 .../gemfire/cache/server/ServerLoad.java        |   21 +-
 .../gemfire/cache/server/ServerLoadProbe.java   |   21 +-
 .../cache/server/ServerLoadProbeAdapter.java    |   21 +-
 .../gemfire/cache/server/ServerMetrics.java     |   21 +-
 .../server/internal/ConnectionCountProbe.java   |   21 +-
 .../cache/server/internal/LoadMonitor.java      |   21 +-
 .../server/internal/ServerMetricsImpl.java      |   21 +-
 .../cache/snapshot/CacheSnapshotService.java    |   21 +-
 .../cache/snapshot/RegionSnapshotService.java   |   21 +-
 .../gemfire/cache/snapshot/SnapshotFilter.java  |   21 +-
 .../cache/snapshot/SnapshotIterator.java        |   21 +-
 .../gemfire/cache/snapshot/SnapshotOptions.java |   21 +-
 .../gemfire/cache/snapshot/SnapshotReader.java  |   21 +-
 .../cache/util/BoundedLinkedHashMap.java        |   21 +-
 .../cache/util/CacheListenerAdapter.java        |   21 +-
 .../gemfire/cache/util/CacheWriterAdapter.java  |   21 +-
 .../gemfire/cache/util/CqListenerAdapter.java   |   21 +-
 .../gemstone/gemfire/cache/util/Gateway.java    |   16 +
 .../cache/util/GatewayConflictHelper.java       |   21 +-
 .../cache/util/GatewayConflictResolver.java     |   21 +-
 .../gemfire/cache/util/GatewayEvent.java        |   21 +-
 .../gemfire/cache/util/ObjectSizer.java         |   21 +-
 .../gemfire/cache/util/ObjectSizerImpl.java     |   16 +
 .../util/RegionMembershipListenerAdapter.java   |   21 +-
 .../cache/util/RegionRoleListenerAdapter.java   |   21 +-
 .../cache/util/TimestampedEntryEvent.java       |   21 +-
 .../cache/util/TransactionListenerAdapter.java  |   21 +-
 .../gemfire/cache/wan/EventSequenceID.java      |   21 +-
 .../gemfire/cache/wan/GatewayEventFilter.java   |   20 +-
 .../wan/GatewayEventSubstitutionFilter.java     |   21 +-
 .../gemfire/cache/wan/GatewayQueueEvent.java    |   21 +-
 .../gemfire/cache/wan/GatewayReceiver.java      |   20 +-
 .../cache/wan/GatewayReceiverFactory.java       |   20 +-
 .../gemfire/cache/wan/GatewaySender.java        |   20 +-
 .../gemfire/cache/wan/GatewaySenderFactory.java |   20 +-
 .../cache/wan/GatewayTransportFilter.java       |   20 +-
 .../compression/CompressionException.java       |   23 +-
 .../gemfire/compression/Compressor.java         |   23 +-
 .../gemfire/compression/SnappyCompressor.java   |   21 +-
 .../gemfire/distributed/AbstractLauncher.java   |   20 +-
 .../distributed/ClientSocketFactory.java        |   21 +-
 .../distributed/DistributedLockService.java     |   21 +-
 .../gemfire/distributed/DistributedMember.java  |   21 +-
 .../gemfire/distributed/DistributedSystem.java  |   21 +-
 .../DistributedSystemDisconnectedException.java |   23 +-
 .../distributed/DurableClientAttributes.java    |   21 +-
 .../distributed/FutureCancelledException.java   |   21 +-
 .../distributed/GatewayCancelledException.java  |   23 +-
 .../distributed/LeaseExpiredException.java      |   21 +-
 .../gemstone/gemfire/distributed/Locator.java   |   21 +-
 .../gemfire/distributed/LocatorLauncher.java    |   22 +-
 .../distributed/LockNotHeldException.java       |   21 +-
 .../LockServiceDestroyedException.java          |   21 +-
 .../distributed/OplogCancelledException.java    |   23 +-
 .../distributed/PoolCancelledException.java     |   23 +-
 .../com/gemstone/gemfire/distributed/Role.java  |   21 +-
 .../gemfire/distributed/ServerLauncher.java     |   22 +-
 .../TXManagerCancelledException.java            |   23 +-
 .../internal/AbstractDistributionConfig.java    |   21 +-
 .../distributed/internal/AdminMessageType.java  |   16 +
 .../internal/AtomicLongWithTerminalState.java   |   21 +-
 .../internal/CollectingReplyProcessor.java      |   21 +-
 .../distributed/internal/ConflationKey.java     |   21 +-
 .../gemfire/distributed/internal/DM.java        |   21 +-
 .../gemfire/distributed/internal/DMStats.java   |   21 +-
 .../gemfire/distributed/internal/DSClock.java   |   18 +-
 .../internal/DirectReplyProcessor.java          |   21 +-
 .../distributed/internal/DistributedState.java  |   21 +-
 .../internal/DistributionAdvisee.java           |   21 +-
 .../internal/DistributionAdvisor.java           |   21 +-
 .../internal/DistributionChannel.java           |   21 +-
 .../internal/DistributionConfig.java            |   21 +-
 .../internal/DistributionConfigImpl.java        |   21 +-
 .../internal/DistributionConfigSnapshot.java    |   21 +-
 .../internal/DistributionException.java         |   21 +-
 .../internal/DistributionManager.java           |   63 +-
 .../internal/DistributionManagerConfig.java     |   21 +-
 .../internal/DistributionMessage.java           |   21 +-
 .../internal/DistributionMessageObserver.java   |   23 +-
 .../distributed/internal/DistributionStats.java |   21 +-
 .../distributed/internal/FlowControlParams.java |   21 +-
 .../internal/ForceDisconnectOperation.java      |   21 +-
 .../FunctionExecutionPooledExecutor.java        |   21 +-
 .../distributed/internal/HealthMonitor.java     |   21 +-
 .../distributed/internal/HealthMonitorImpl.java |   21 +-
 .../internal/HighPriorityAckedMessage.java      |   21 +-
 .../HighPriorityDistributionMessage.java        |   21 +-
 .../distributed/internal/IgnoredByManager.java  |   16 +
 .../internal/InternalDistributedSystem.java     |   19 +-
 .../distributed/internal/InternalLocator.java   |   21 +-
 .../internal/LocatorLoadSnapshot.java           |   20 +-
 .../distributed/internal/LocatorStats.java      |   21 +-
 .../internal/LonerDistributionManager.java      |   21 +-
 .../gemfire/distributed/internal/MQueue.java    |   16 +
 .../internal/MembershipListener.java            |   21 +-
 .../distributed/internal/MessageFactory.java    |   21 +-
 .../distributed/internal/MessageWithReply.java  |   21 +-
 .../internal/OverflowQueueWithDMStats.java      |   21 +-
 .../distributed/internal/PoolStatHelper.java    |   21 +-
 .../internal/PooledDistributionMessage.java     |   21 +-
 .../internal/PooledExecutorWithDMStats.java     |   21 +-
 .../distributed/internal/ProcessorKeeper21.java |   21 +-
 .../distributed/internal/ProductUseLog.java     |   21 +-
 .../distributed/internal/ProfileListener.java   |   21 +-
 .../distributed/internal/QueueStatHelper.java   |   21 +-
 .../internal/ReliableReplyException.java        |   21 +-
 .../internal/ReliableReplyProcessor21.java      |   21 +-
 .../distributed/internal/ReplyException.java    |   21 +-
 .../distributed/internal/ReplyMessage.java      |   21 +-
 .../distributed/internal/ReplyProcessor21.java  |   21 +-
 .../distributed/internal/ReplySender.java       |   21 +-
 .../distributed/internal/ResourceEvent.java     |   20 +-
 .../internal/ResourceEventsListener.java        |   20 +-
 .../internal/RuntimeDistributionConfigImpl.java |   21 +-
 .../internal/SerialAckedMessage.java            |   21 +-
 .../internal/SerialDistributionMessage.java     |   21 +-
 .../SerialQueuedExecutorWithDMStats.java        |   21 +-
 .../distributed/internal/ServerLocation.java    |   21 +-
 .../distributed/internal/ServerLocator.java     |   21 +-
 .../internal/SharedConfiguration.java           |   21 +-
 .../distributed/internal/ShutdownMessage.java   |   21 +-
 .../gemfire/distributed/internal/Sizeable.java  |   16 +
 .../distributed/internal/SizeableRunnable.java  |   21 +-
 .../distributed/internal/StartupMessage.java    |   21 +-
 .../internal/StartupMessageData.java            |   21 +-
 .../internal/StartupMessageReplyProcessor.java  |   21 +-
 .../distributed/internal/StartupOperation.java  |   21 +-
 .../internal/StartupResponseMessage.java        |   21 +-
 .../StartupResponseWithVersionMessage.java      |   23 +-
 .../internal/ThrottledMemQueueStatHelper.java   |   21 +-
 .../internal/ThrottledQueueStatHelper.java      |   21 +-
 .../ThrottlingMemLinkedQueueWithDMStats.java    |   21 +-
 .../internal/WaitForViewInstallation.java       |   21 +-
 .../internal/WanLocatorDiscoverer.java          |   16 +
 .../deadlock/DLockDependencyMonitor.java        |   21 +-
 .../internal/deadlock/DeadlockDetector.java     |   21 +-
 .../internal/deadlock/Dependency.java           |   21 +-
 .../internal/deadlock/DependencyGraph.java      |   21 +-
 .../internal/deadlock/DependencyMonitor.java    |   21 +-
 .../deadlock/DependencyMonitorManager.java      |   21 +-
 .../deadlock/GemFireDeadlockDetector.java       |   21 +-
 .../internal/deadlock/LocalLockInfo.java        |   23 +-
 .../internal/deadlock/LocalThread.java          |   23 +-
 .../deadlock/MessageDependencyMonitor.java      |   21 +-
 .../internal/deadlock/ThreadReference.java      |   21 +-
 .../internal/deadlock/UnsafeThreadLocal.java    |   21 +-
 .../internal/direct/DirectChannel.java          |   21 +-
 .../internal/direct/MissingStubException.java   |   21 +-
 .../internal/locks/Collaboration.java           |   21 +-
 .../distributed/internal/locks/DLockBatch.java  |   21 +-
 .../internal/locks/DLockBatchId.java            |   21 +-
 .../internal/locks/DLockGrantor.java            |   21 +-
 .../locks/DLockLessorDepartureHandler.java      |   21 +-
 .../internal/locks/DLockQueryProcessor.java     |   21 +-
 .../locks/DLockRecoverGrantorProcessor.java     |   21 +-
 .../internal/locks/DLockReleaseProcessor.java   |   21 +-
 .../internal/locks/DLockRemoteToken.java        |   21 +-
 .../internal/locks/DLockRequestProcessor.java   |   21 +-
 .../internal/locks/DLockService.java            |   21 +-
 .../distributed/internal/locks/DLockStats.java  |   21 +-
 .../distributed/internal/locks/DLockToken.java  |   21 +-
 .../internal/locks/DeposeGrantorProcessor.java  |   21 +-
 .../internal/locks/DistributedLockStats.java    |   21 +-
 .../internal/locks/DistributedMemberLock.java   |   21 +-
 .../internal/locks/DummyDLockStats.java         |   21 +-
 .../internal/locks/ElderInitProcessor.java      |   21 +-
 .../distributed/internal/locks/ElderState.java  |   21 +-
 .../distributed/internal/locks/GrantorInfo.java |   21 +-
 .../internal/locks/GrantorRequestProcessor.java |   21 +-
 .../locks/LockGrantorDestroyedException.java    |   21 +-
 .../internal/locks/LockGrantorId.java           |   21 +-
 .../locks/NonGrantorDestroyedProcessor.java     |   21 +-
 .../internal/locks/RemoteThread.java            |   21 +-
 .../DistributedMembershipListener.java          |   21 +-
 .../membership/InternalDistributedMember.java   |   21 +-
 .../internal/membership/InternalRole.java       |   21 +-
 .../internal/membership/MemberAttributes.java   |   21 +-
 .../internal/membership/MemberFactory.java      |   21 +-
 .../internal/membership/MemberServices.java     |   21 +-
 .../internal/membership/MembershipManager.java  |   21 +-
 .../internal/membership/MembershipTestHook.java |   21 +-
 .../internal/membership/NetMember.java          |   21 +-
 .../internal/membership/NetView.java            |   21 +-
 .../internal/membership/QuorumChecker.java      |   21 +-
 .../membership/jgroup/GFJGBasicAdapter.java     |   16 +
 .../membership/jgroup/GFJGPeerAdapter.java      |   16 +
 .../membership/jgroup/JGroupMember.java         |   21 +-
 .../membership/jgroup/JGroupMemberFactory.java  |   21 +-
 .../jgroup/JGroupMembershipManager.java         |   21 +-
 .../internal/membership/jgroup/LocatorImpl.java |   16 +
 .../membership/jgroup/QuorumCheckerImpl.java    |   21 +-
 .../internal/membership/jgroup/ViewMessage.java |   21 +-
 .../internal/streaming/StreamingOperation.java  |   21 +-
 .../internal/tcpserver/InfoRequest.java         |   20 +-
 .../internal/tcpserver/InfoResponse.java        |   20 +-
 .../internal/tcpserver/ShutdownRequest.java     |   20 +-
 .../internal/tcpserver/ShutdownResponse.java    |   20 +-
 .../internal/tcpserver/TcpClient.java           |   16 +
 .../internal/tcpserver/TcpHandler.java          |   16 +
 .../internal/tcpserver/TcpServer.java           |   16 +
 .../internal/tcpserver/VersionRequest.java      |   16 +
 .../internal/tcpserver/VersionResponse.java     |   16 +
 .../unsafe/RegisterSignalHandlerSupport.java    |   20 +-
 .../gemstone/gemfire/i18n/LogWriterI18n.java    |   21 +-
 .../com/gemstone/gemfire/i18n/StringIdImpl.java |   21 +-
 .../gemfire/internal/AbstractConfig.java        |   27 +-
 .../internal/AbstractStatisticsFactory.java     |   21 +-
 .../gemfire/internal/ArchiveSplitter.java       |   21 +-
 .../com/gemstone/gemfire/internal/Assert.java   |   21 +-
 .../gemfire/internal/AvailablePort.java         |   21 +-
 .../com/gemstone/gemfire/internal/Banner.java   |   49 +-
 .../gemfire/internal/ByteArrayDataInput.java    |   21 +-
 .../internal/ByteBufferOutputStream.java        |   21 +-
 .../gemfire/internal/ByteBufferWriter.java      |   16 +
 .../gemfire/internal/ClassLoadUtil.java         |   21 +-
 .../gemfire/internal/ClassPathLoader.java       |   21 +-
 .../com/gemstone/gemfire/internal/Config.java   |   21 +-
 .../gemstone/gemfire/internal/ConfigSource.java |   21 +-
 .../gemfire/internal/CopyOnWriteHashSet.java    |   21 +-
 .../com/gemstone/gemfire/internal/DSCODE.java   |   21 +-
 .../gemstone/gemfire/internal/DSFIDFactory.java |   21 +-
 .../internal/DSFIDNotFoundException.java        |   21 +-
 .../internal/DataSerializableFixedID.java       |   21 +-
 .../gemfire/internal/DistributionLocator.java   |   21 +-
 .../internal/DummyStatisticsFactory.java        |   21 +-
 .../gemfire/internal/DummyStatisticsImpl.java   |   21 +-
 .../gemfire/internal/ExternalizableDSFID.java   |   21 +-
 .../com/gemstone/gemfire/internal/FileUtil.java |   21 +-
 .../gemfire/internal/GemFireStatSampler.java    |   21 +-
 .../gemfire/internal/GemFireUtilLauncher.java   |   21 +-
 .../gemfire/internal/GemFireVersion.java        |   21 +-
 .../internal/GfeConsoleReaderFactory.java       |   20 +-
 .../gemfire/internal/HeapDataOutputStream.java  |   21 +-
 .../gemfire/internal/HistogramStats.java        |   21 +-
 .../gemfire/internal/HostStatHelper.java        |   21 +-
 .../gemfire/internal/HostStatSampler.java       |   25 +-
 .../InsufficientDiskSpaceException.java         |   21 +-
 .../internal/InternalDataSerializer.java        |   32 +-
 .../gemfire/internal/InternalEntity.java        |   16 +
 .../gemfire/internal/InternalInstantiator.java  |   21 +-
 .../InternalStatisticsDisabledException.java    |   21 +-
 .../gemfire/internal/JarClassLoader.java        |   20 +-
 .../gemstone/gemfire/internal/JarDeployer.java  |   20 +-
 .../gemfire/internal/LinuxProcFsStatistics.java |   21 +-
 .../gemfire/internal/LinuxProcessStats.java     |   21 +-
 .../gemfire/internal/LinuxSystemStats.java      |   21 +-
 .../gemfire/internal/LocalStatListener.java     |   21 +-
 .../internal/LocalStatisticsFactory.java        |   21 +-
 .../gemfire/internal/LocalStatisticsImpl.java   |   21 +-
 .../gemstone/gemfire/internal/ManagerInfo.java  |   20 +-
 .../gemfire/internal/MigrationClient.java       |   21 +-
 .../gemfire/internal/MigrationServer.java       |   21 +-
 .../gemstone/gemfire/internal/NanoTimer.java    |   21 +-
 .../gemfire/internal/NullDataOutputStream.java  |   21 +-
 .../gemstone/gemfire/internal/OSProcess.java    |   19 +-
 .../gemfire/internal/OSXProcessStats.java       |   21 +-
 .../gemfire/internal/OSXSystemStats.java        |   21 +-
 .../gemfire/internal/ObjIdConcurrentMap.java    |   21 +-
 .../com/gemstone/gemfire/internal/ObjIdMap.java |   21 +-
 .../internal/ObjToByteArraySerializer.java      |   21 +-
 .../gemfire/internal/OneTaskOnlyExecutor.java   |   21 +-
 .../gemfire/internal/OsStatisticsFactory.java   |   21 +-
 .../gemfire/internal/PdxSerializerObject.java   |   21 +-
 .../gemfire/internal/ProcessOutputReader.java   |   21 +-
 .../gemstone/gemfire/internal/ProcessStats.java |   21 +-
 .../gemstone/gemfire/internal/PureJavaMode.java |   21 +-
 ...cheduledThreadPoolExecutorWithKeepAlive.java |   21 +-
 .../com/gemstone/gemfire/internal/Sendable.java |   18 +-
 .../gemfire/internal/SerializationVersions.java |   21 +-
 .../com/gemstone/gemfire/internal/SetUtils.java |   20 +-
 .../gemfire/internal/SharedLibrary.java         |   21 +-
 .../gemfire/internal/SimpleStatSampler.java     |   21 +-
 .../com/gemstone/gemfire/internal/SmHelper.java |   21 +-
 .../gemstone/gemfire/internal/SocketCloser.java |   16 +
 .../gemfire/internal/SocketCreator.java         |   61 +-
 .../gemfire/internal/SolarisProcessStats.java   |   21 +-
 .../gemfire/internal/SolarisSystemStats.java    |   21 +-
 .../gemfire/internal/StatArchiveFormat.java     |   21 +-
 .../gemfire/internal/StatArchiveReader.java     |   21 +-
 .../gemfire/internal/StatArchiveWriter.java     |   21 +-
 .../gemfire/internal/StatSamplerStats.java      |   21 +-
 .../internal/StatisticDescriptorImpl.java       |   21 +-
 .../gemfire/internal/StatisticsImpl.java        |   21 +-
 .../gemfire/internal/StatisticsManager.java     |   21 +-
 .../internal/StatisticsTypeFactoryImpl.java     |   21 +-
 .../gemfire/internal/StatisticsTypeImpl.java    |   21 +-
 .../gemfire/internal/StatisticsTypeXml.java     |   21 +-
 .../gemstone/gemfire/internal/SystemAdmin.java  |   21 +-
 .../gemfire/internal/SystemFailureTestHook.java |   21 +-
 .../gemstone/gemfire/internal/SystemTimer.java  |   21 +-
 .../gemfire/internal/UniqueIdGenerator.java     |   21 +-
 .../com/gemstone/gemfire/internal/VMStats.java  |   21 +-
 .../gemfire/internal/VMStatsContract.java       |   21 +-
 .../internal/VMStatsContractFactory.java        |   21 +-
 .../com/gemstone/gemfire/internal/Version.java  |   21 +-
 .../internal/VersionedDataInputStream.java      |   21 +-
 .../internal/VersionedDataOutputStream.java     |   21 +-
 .../internal/VersionedDataSerializable.java     |   16 +
 .../gemfire/internal/VersionedDataStream.java   |   21 +-
 .../gemfire/internal/VersionedObjectInput.java  |   21 +-
 .../gemfire/internal/VersionedObjectOutput.java |   21 +-
 .../gemfire/internal/WindowsProcessStats.java   |   21 +-
 .../gemfire/internal/WindowsSystemStats.java    |   21 +-
 .../internal/admin/AdminBridgeServer.java       |   16 +
 .../gemstone/gemfire/internal/admin/Alert.java  |   21 +-
 .../gemfire/internal/admin/AlertListener.java   |   21 +-
 .../gemfire/internal/admin/ApplicationVM.java   |   21 +-
 .../gemfire/internal/admin/CacheCollector.java  |   21 +-
 .../gemfire/internal/admin/CacheInfo.java       |   21 +-
 .../gemfire/internal/admin/CacheSnapshot.java   |   21 +-
 .../admin/ClientHealthMonitoringRegion.java     |   21 +-
 .../internal/admin/ClientMembershipMessage.java |   21 +-
 .../internal/admin/ClientStatsManager.java      |   21 +-
 .../internal/admin/CompoundEntrySnapshot.java   |   21 +-
 .../internal/admin/CompoundRegionSnapshot.java  |   21 +-
 .../gemfire/internal/admin/DLockInfo.java       |   21 +-
 .../gemfire/internal/admin/EntrySnapshot.java   |   21 +-
 .../gemfire/internal/admin/EntryValueNode.java  |   23 +-
 .../gemfire/internal/admin/GemFireVM.java       |   21 +-
 .../gemfire/internal/admin/GfManagerAgent.java  |   21 +-
 .../internal/admin/GfManagerAgentConfig.java    |   21 +-
 .../internal/admin/GfManagerAgentFactory.java   |   21 +-
 .../gemfire/internal/admin/GfObject.java        |   21 +-
 .../gemfire/internal/admin/HealthListener.java  |   21 +-
 .../internal/admin/JoinLeaveListener.java       |   21 +-
 .../gemfire/internal/admin/ListenerIdMap.java   |   21 +-
 .../gemfire/internal/admin/RegionSnapshot.java  |   21 +-
 .../gemfire/internal/admin/SSLConfig.java       |   21 +-
 .../gemfire/internal/admin/SnapshotClient.java  |   21 +-
 .../gemstone/gemfire/internal/admin/Stat.java   |   21 +-
 .../gemfire/internal/admin/StatAlert.java       |   21 +-
 .../internal/admin/StatAlertDefinition.java     |   21 +-
 .../internal/admin/StatAlertsManager.java       |   21 +-
 .../gemfire/internal/admin/StatListener.java    |   21 +-
 .../gemfire/internal/admin/StatResource.java    |   21 +-
 .../gemfire/internal/admin/TransportConfig.java |   21 +-
 .../admin/remote/AddHealthListenerRequest.java  |   21 +-
 .../admin/remote/AddHealthListenerResponse.java |   21 +-
 .../admin/remote/AddStatListenerRequest.java    |   21 +-
 .../admin/remote/AddStatListenerResponse.java   |   21 +-
 .../remote/AdminConsoleDisconnectMessage.java   |   21 +-
 .../admin/remote/AdminConsoleMessage.java       |   21 +-
 .../admin/remote/AdminFailureResponse.java      |   21 +-
 .../remote/AdminMultipleReplyProcessor.java     |   21 +-
 .../internal/admin/remote/AdminRegion.java      |   21 +-
 .../admin/remote/AdminReplyProcessor.java       |   21 +-
 .../internal/admin/remote/AdminRequest.java     |   21 +-
 .../internal/admin/remote/AdminResponse.java    |   21 +-
 .../internal/admin/remote/AdminWaiters.java     |   21 +-
 .../admin/remote/AlertLevelChangeMessage.java   |   21 +-
 .../admin/remote/AlertListenerMessage.java      |   21 +-
 .../admin/remote/AlertsNotificationMessage.java |   21 +-
 .../admin/remote/AppCacheSnapshotMessage.java   |   21 +-
 .../admin/remote/BridgeServerRequest.java       |   21 +-
 .../admin/remote/BridgeServerResponse.java      |   21 +-
 .../admin/remote/CacheConfigRequest.java        |   21 +-
 .../admin/remote/CacheConfigResponse.java       |   21 +-
 .../internal/admin/remote/CacheDisplay.java     |   21 +-
 .../internal/admin/remote/CacheInfoRequest.java |   21 +-
 .../admin/remote/CacheInfoResponse.java         |   21 +-
 .../admin/remote/CancelStatListenerRequest.java |   21 +-
 .../remote/CancelStatListenerResponse.java      |   21 +-
 .../internal/admin/remote/Cancellable.java      |   21 +-
 .../admin/remote/CancellationMessage.java       |   23 +-
 .../admin/remote/CancellationRegistry.java      |   23 +-
 .../remote/ChangeRefreshIntervalMessage.java    |   21 +-
 .../internal/admin/remote/CliLegacyMessage.java |   16 +
 .../admin/remote/ClientHealthStats.java         |   21 +-
 .../internal/admin/remote/CompactRequest.java   |   21 +-
 .../internal/admin/remote/CompactResponse.java  |   21 +-
 .../admin/remote/DestroyEntryMessage.java       |   23 +-
 .../admin/remote/DestroyRegionMessage.java      |   23 +-
 .../admin/remote/DistributionLocatorId.java     |   21 +-
 .../internal/admin/remote/DummyEntry.java       |   21 +-
 .../admin/remote/DurableClientInfoRequest.java  |   20 +-
 .../admin/remote/DurableClientInfoResponse.java |   20 +-
 .../admin/remote/EntryValueNodeImpl.java        |   23 +-
 .../admin/remote/FetchDistLockInfoRequest.java  |   21 +-
 .../admin/remote/FetchDistLockInfoResponse.java |   21 +-
 .../remote/FetchHealthDiagnosisRequest.java     |   21 +-
 .../remote/FetchHealthDiagnosisResponse.java    |   21 +-
 .../internal/admin/remote/FetchHostRequest.java |   21 +-
 .../admin/remote/FetchHostResponse.java         |   21 +-
 .../remote/FetchResourceAttributesRequest.java  |   21 +-
 .../remote/FetchResourceAttributesResponse.java |   21 +-
 .../admin/remote/FetchStatsRequest.java         |   21 +-
 .../admin/remote/FetchStatsResponse.java        |   20 +-
 .../admin/remote/FetchSysCfgRequest.java        |   21 +-
 .../admin/remote/FetchSysCfgResponse.java       |   21 +-
 .../remote/FlushAppCacheSnapshotMessage.java    |   21 +-
 .../admin/remote/HealthListenerMessage.java     |   21 +-
 .../remote/InspectionClasspathManager.java      |   21 +-
 .../admin/remote/LicenseInfoRequest.java        |   21 +-
 .../admin/remote/LicenseInfoResponse.java       |   21 +-
 .../remote/MissingPersistentIDsRequest.java     |   21 +-
 .../remote/MissingPersistentIDsResponse.java    |   21 +-
 .../admin/remote/ObjectDetailsRequest.java      |   21 +-
 .../admin/remote/ObjectDetailsResponse.java     |   21 +-
 .../admin/remote/ObjectNamesRequest.java        |   21 +-
 .../admin/remote/ObjectNamesResponse.java       |   21 +-
 .../PrepareRevokePersistentIDRequest.java       |   21 +-
 .../remote/RefreshMemberSnapshotRequest.java    |   21 +-
 .../remote/RefreshMemberSnapshotResponse.java   |   21 +-
 .../admin/remote/RegionAdminMessage.java        |   21 +-
 .../admin/remote/RegionAdminRequest.java        |   21 +-
 .../admin/remote/RegionAttributesRequest.java   |   21 +-
 .../admin/remote/RegionAttributesResponse.java  |   21 +-
 .../internal/admin/remote/RegionRequest.java    |   21 +-
 .../internal/admin/remote/RegionResponse.java   |   21 +-
 .../admin/remote/RegionSizeRequest.java         |   21 +-
 .../admin/remote/RegionSizeResponse.java        |   21 +-
 .../admin/remote/RegionStatisticsRequest.java   |   21 +-
 .../admin/remote/RegionStatisticsResponse.java  |   21 +-
 .../remote/RegionSubRegionSizeRequest.java      |   20 +-
 .../remote/RegionSubRegionsSizeResponse.java    |   20 +-
 .../internal/admin/remote/RemoteAlert.java      |   21 +-
 .../admin/remote/RemoteApplicationVM.java       |   21 +-
 .../admin/remote/RemoteBridgeServer.java        |   21 +-
 .../internal/admin/remote/RemoteCacheInfo.java  |   21 +-
 .../admin/remote/RemoteCacheStatistics.java     |   21 +-
 .../internal/admin/remote/RemoteDLockInfo.java  |   21 +-
 .../admin/remote/RemoteEntrySnapshot.java       |   21 +-
 .../internal/admin/remote/RemoteGemFireVM.java  |   21 +-
 .../admin/remote/RemoteGfManagerAgent.java      |   21 +-
 .../internal/admin/remote/RemoteObjectName.java |   21 +-
 .../admin/remote/RemoteRegionAttributes.java    |   23 +-
 .../admin/remote/RemoteRegionSnapshot.java      |   21 +-
 .../internal/admin/remote/RemoteStat.java       |   21 +-
 .../admin/remote/RemoteStatResource.java        |   21 +-
 .../admin/remote/RemoteTransportConfig.java     |   21 +-
 .../remote/RemoveHealthListenerRequest.java     |   21 +-
 .../remote/RemoveHealthListenerResponse.java    |   21 +-
 .../admin/remote/ResetHealthStatusRequest.java  |   21 +-
 .../admin/remote/ResetHealthStatusResponse.java |   21 +-
 .../admin/remote/RevokePersistentIDRequest.java |   21 +-
 .../remote/RevokePersistentIDResponse.java      |   21 +-
 .../admin/remote/RootRegionRequest.java         |   21 +-
 .../admin/remote/RootRegionResponse.java        |   21 +-
 .../remote/ShutdownAllGatewayHubsRequest.java   |   16 +
 .../admin/remote/ShutdownAllRequest.java        |   21 +-
 .../admin/remote/ShutdownAllResponse.java       |   21 +-
 .../admin/remote/SnapshotResultMessage.java     |   21 +-
 .../remote/StatAlertsManagerAssignMessage.java  |   21 +-
 .../admin/remote/StatListenerMessage.java       |   21 +-
 .../admin/remote/StoreSysCfgRequest.java        |   21 +-
 .../admin/remote/StoreSysCfgResponse.java       |   21 +-
 .../internal/admin/remote/SubRegionRequest.java |   21 +-
 .../admin/remote/SubRegionResponse.java         |   21 +-
 .../internal/admin/remote/TailLogRequest.java   |   21 +-
 .../internal/admin/remote/TailLogResponse.java  |   21 +-
 .../remote/UpdateAlertDefinitionMessage.java    |   21 +-
 .../admin/remote/VersionInfoRequest.java        |   21 +-
 .../admin/remote/VersionInfoResponse.java       |   21 +-
 .../admin/remote/VersionMismatchAlert.java      |   21 +-
 .../admin/statalerts/BaseDecoratorImpl.java     |   21 +-
 .../statalerts/DummyStatisticInfoImpl.java      |   21 +-
 .../admin/statalerts/FunctionDecoratorImpl.java |   21 +-
 .../admin/statalerts/FunctionHelper.java        |   20 +-
 .../statalerts/GaugeThresholdDecoratorImpl.java |   21 +-
 .../statalerts/MultiAttrDefinitionImpl.java     |   21 +-
 .../NumberThresholdDecoratorImpl.java           |   21 +-
 .../statalerts/SingleAttrDefinitionImpl.java    |   21 +-
 .../admin/statalerts/StatisticInfo.java         |   21 +-
 .../admin/statalerts/StatisticInfoImpl.java     |   21 +-
 .../cache/AbstractBucketRegionQueue.java        |   21 +-
 .../internal/cache/AbstractCacheServer.java     |   21 +-
 .../cache/AbstractDiskLRURegionEntry.java       |   21 +-
 .../internal/cache/AbstractDiskRegion.java      |   21 +-
 .../internal/cache/AbstractDiskRegionEntry.java |   21 +-
 .../internal/cache/AbstractLRURegionEntry.java  |   21 +-
 .../internal/cache/AbstractLRURegionMap.java    |   21 +-
 .../cache/AbstractOplogDiskRegionEntry.java     |   21 +-
 .../gemfire/internal/cache/AbstractRegion.java  |   46 +-
 .../internal/cache/AbstractRegionEntry.java     |   21 +-
 .../internal/cache/AbstractRegionMap.java       |   21 +-
 .../internal/cache/AbstractUpdateOperation.java |   21 +-
 .../gemfire/internal/cache/AcceptHelper.java    |   21 +-
 .../cache/AddCacheServerProfileMessage.java     |   21 +-
 .../gemfire/internal/cache/BackupLock.java      |   21 +-
 .../gemfire/internal/cache/BucketAdvisor.java   |   21 +-
 .../gemfire/internal/cache/BucketDump.java      |   21 +-
 .../internal/cache/BucketNotFoundException.java |   21 +-
 .../cache/BucketPersistenceAdvisor.java         |   21 +-
 .../gemfire/internal/cache/BucketRegion.java    |   21 +-
 .../internal/cache/BucketRegionEvictior.java    |   21 +-
 .../internal/cache/BucketRegionQueue.java       |   21 +-
 .../internal/cache/BucketServerLocation.java    |   20 +-
 .../internal/cache/BucketServerLocation66.java  |   20 +-
 .../cache/BytesAndBitsForCompactor.java         |   21 +-
 .../internal/cache/CacheClientStatus.java       |   21 +-
 .../gemfire/internal/cache/CacheConfig.java     |   21 +-
 .../cache/CacheDistributionAdvisee.java         |   21 +-
 .../cache/CacheDistributionAdvisor.java         |   21 +-
 .../internal/cache/CacheLifecycleListener.java  |   21 +-
 .../gemfire/internal/cache/CacheObserver.java   |   21 +-
 .../internal/cache/CacheObserverAdapter.java    |   21 +-
 .../internal/cache/CacheObserverHolder.java     |   21 +-
 .../gemfire/internal/cache/CachePerfStats.java  |   21 +-
 .../internal/cache/CacheServerAdvisor.java      |   21 +-
 .../gemfire/internal/cache/CacheServerImpl.java |   21 +-
 .../internal/cache/CacheServerLauncher.java     |   21 +-
 .../internal/cache/CacheStatisticsImpl.java     |   21 +-
 .../internal/cache/CachedDeserializable.java    |   21 +-
 .../cache/CachedDeserializableFactory.java      |   21 +-
 .../internal/cache/ClientRegionEventImpl.java   |   21 +-
 .../internal/cache/ClientServerObserver.java    |   21 +-
 .../cache/ClientServerObserverAdapter.java      |   21 +-
 .../cache/ClientServerObserverHolder.java       |   21 +-
 .../cache/ClientSubscriptionConfigImpl.java     |   21 +-
 .../internal/cache/CloseCacheMessage.java       |   21 +-
 .../cache/ClusterConfigurationLoader.java       |   16 +
 .../internal/cache/ColocationHelper.java        |   20 +-
 .../internal/cache/CommitReplyException.java    |   21 +-
 .../internal/cache/CompactableOplog.java        |   21 +-
 .../gemfire/internal/cache/Conflatable.java     |   21 +-
 .../internal/cache/ControllerAdvisor.java       |   21 +-
 .../internal/cache/CountingDataInputStream.java |   21 +-
 .../internal/cache/CreateRegionProcessor.java   |   21 +-
 .../internal/cache/CustomEntryExpiryTask.java   |   16 +
 .../cache/CustomEvictionAttributesImpl.java     |   21 +-
 .../internal/cache/DataLocationException.java   |   21 +-
 .../internal/cache/DestroyOperation.java        |   21 +-
 .../cache/DestroyPartitionedRegionMessage.java  |   21 +-
 .../internal/cache/DestroyRegionOperation.java  |   21 +-
 .../gemfire/internal/cache/DestroyedEntry.java  |   21 +-
 .../internal/cache/DirectReplyMessage.java      |   21 +-
 .../gemfire/internal/cache/DirectoryHolder.java |   21 +-
 .../internal/cache/DiskDirectoryStats.java      |   21 +-
 .../gemfire/internal/cache/DiskEntry.java       |   21 +-
 .../gemstone/gemfire/internal/cache/DiskId.java |   21 +-
 .../gemfire/internal/cache/DiskInitFile.java    |   21 +-
 .../gemfire/internal/cache/DiskRegion.java      |   21 +-
 .../gemfire/internal/cache/DiskRegionStats.java |   21 +-
 .../internal/cache/DiskStoreAttributes.java     |   21 +-
 .../gemfire/internal/cache/DiskStoreBackup.java |   21 +-
 .../internal/cache/DiskStoreFactoryImpl.java    |   21 +-
 .../gemfire/internal/cache/DiskStoreImpl.java   |   21 +-
 .../internal/cache/DiskStoreMonitor.java        |   21 +-
 .../internal/cache/DiskStoreObserver.java       |   21 +-
 .../gemfire/internal/cache/DiskStoreStats.java  |   21 +-
 .../gemfire/internal/cache/DiskStoreTask.java   |   21 +-
 .../internal/cache/DiskWriteAttributesImpl.java |   21 +-
 .../internal/cache/DistPeerTXStateStub.java     |   16 +
 .../cache/DistTXAdjunctCommitMessage.java       |   16 +
 .../internal/cache/DistTXCommitMessage.java     |   17 +-
 .../cache/DistTXCoordinatorInterface.java       |   21 +-
 .../internal/cache/DistTXPrecommitMessage.java  |   17 +-
 .../internal/cache/DistTXRollbackMessage.java   |   17 +-
 .../gemfire/internal/cache/DistTXState.java     |   16 +
 .../cache/DistTXStateOnCoordinator.java         |   16 +
 .../internal/cache/DistTXStateProxyImpl.java    |   16 +
 .../DistTXStateProxyImplOnCoordinator.java      |   18 +-
 .../cache/DistTXStateProxyImplOnDatanode.java   |   16 +
 .../cache/DistributedCacheOperation.java        |   20 +-
 .../cache/DistributedClearOperation.java        |   21 +-
 .../cache/DistributedPutAllOperation.java       |   21 +-
 .../internal/cache/DistributedRegion.java       |   21 +-
 ...stributedRegionFunctionStreamingMessage.java |   21 +-
 .../cache/DistributedRemoveAllOperation.java    |   21 +-
 .../cache/DistributedTombstoneOperation.java    |   21 +-
 .../internal/cache/DummyCachePerfStats.java     |   21 +-
 .../internal/cache/DynamicRegionAttributes.java |   21 +-
 .../cache/DynamicRegionFactoryImpl.java         |   21 +-
 .../gemfire/internal/cache/EntriesMap.java      |   21 +-
 .../gemfire/internal/cache/EntriesSet.java      |   21 +-
 .../gemfire/internal/cache/EntryBits.java       |   21 +-
 .../gemfire/internal/cache/EntryEventImpl.java  |   21 +-
 .../gemfire/internal/cache/EntryExpiryTask.java |   24 +-
 .../internal/cache/EntryOperationImpl.java      |   23 +-
 .../gemfire/internal/cache/EntrySnapshot.java   |   23 +-
 .../internal/cache/EnumListenerEvent.java       |   20 +-
 .../gemfire/internal/cache/EventID.java         |   21 +-
 .../internal/cache/EventStateHelper.java        |   21 +-
 .../gemfire/internal/cache/EventTracker.java    |   21 +-
 .../internal/cache/EvictionAttributesImpl.java  |   23 +-
 .../gemfire/internal/cache/EvictorService.java  |   21 +-
 .../internal/cache/ExpirationScheduler.java     |   21 +-
 .../gemfire/internal/cache/ExpiryTask.java      |   45 +-
 .../internal/cache/ExportDiskRegion.java        |   16 +
 .../gemfire/internal/cache/FilterProfile.java   |   21 +-
 .../internal/cache/FilterRoutingInfo.java       |   21 +-
 .../cache/FindDurableQueueProcessor.java        |   21 +-
 .../internal/cache/FindRemoteTXMessage.java     |   21 +-
 .../internal/cache/FindVersionTagOperation.java |   21 +-
 .../cache/FixedPartitionAttributesImpl.java     |   21 +-
 .../internal/cache/ForceReattemptException.java |   21 +-
 .../cache/ForceableLinkedBlockingQueue.java     |   21 +-
 .../FunctionStreamingOrderedReplyMessage.java   |   21 +-
 .../cache/FunctionStreamingReplyMessage.java    |   21 +-
 .../internal/cache/GatewayEventFilter.java      |   16 +
 .../internal/cache/GemFireCacheImpl.java        |   69 +-
 .../internal/cache/GemfireCacheHelper.java      |   23 +-
 .../gemfire/internal/cache/GridAdvisor.java     |   21 +-
 .../gemfire/internal/cache/HARegion.java        |   21 +-
 .../internal/cache/HDFSLRURegionMap.java        |   21 +-
 .../gemfire/internal/cache/HDFSRegionMap.java   |   16 +
 .../internal/cache/HDFSRegionMapDelegate.java   |   21 +-
 .../internal/cache/HDFSRegionMapImpl.java       |   21 +-
 .../internal/cache/HasCachePerfStats.java       |   16 +
 .../gemfire/internal/cache/ImageState.java      |   21 +-
 .../cache/InMemoryPersistentMemberView.java     |   21 +-
 .../internal/cache/IncomingGatewayStatus.java   |   21 +-
 .../internal/cache/InitialImageFlowControl.java |   21 +-
 .../internal/cache/InitialImageOperation.java   |   21 +-
 .../gemfire/internal/cache/InlineKeyHelper.java |   21 +-
 .../gemfire/internal/cache/InterestEvent.java   |   21 +-
 .../gemfire/internal/cache/InterestFilter.java  |   21 +-
 .../cache/InterestRegistrationEventImpl.java    |   21 +-
 .../gemfire/internal/cache/InternalCache.java   |   18 +-
 .../internal/cache/InternalCacheEvent.java      |   21 +-
 .../internal/cache/InternalDataView.java        |   21 +-
 .../internal/cache/InternalRegionArguments.java |   21 +-
 .../internal/cache/InvalidateOperation.java     |   21 +-
 .../InvalidatePartitionedRegionMessage.java     |   21 +-
 .../cache/InvalidateRegionOperation.java        |   21 +-
 .../cache/JtaAfterCompletionMessage.java        |   21 +-
 .../cache/JtaBeforeCompletionMessage.java       |   21 +-
 .../gemfire/internal/cache/KeyInfo.java         |   21 +-
 .../internal/cache/KeyWithRegionContext.java    |   21 +-
 .../gemfire/internal/cache/ListOfDeltas.java    |   21 +-
 .../internal/cache/LoaderHelperFactory.java     |   21 +-
 .../internal/cache/LoaderHelperImpl.java        |   21 +-
 .../gemfire/internal/cache/LocalDataSet.java    |   21 +-
 .../gemfire/internal/cache/LocalRegion.java     |   26 +-
 .../internal/cache/LocalRegionDataView.java     |   21 +-
 .../cache/MemberFunctionStreamingMessage.java   |   21 +-
 .../cache/MinimumSystemRequirements.java        |   21 +-
 .../cache/NetSearchExpirationCalculator.java    |   21 +-
 .../gemstone/gemfire/internal/cache/Node.java   |   20 +-
 .../internal/cache/NonLocalRegionEntry.java     |   21 +-
 .../cache/NonLocalRegionEntryWithStats.java     |   23 +-
 .../internal/cache/OffHeapRegionEntry.java      |   16 +
 .../cache/OfflineCompactionDiskRegion.java      |   21 +-
 .../gemstone/gemfire/internal/cache/OpType.java |   21 +-
 .../gemstone/gemfire/internal/cache/Oplog.java  |   22 +-
 .../gemfire/internal/cache/OplogSet.java        |   16 +
 .../internal/cache/OrderedTombstoneMap.java     |   21 +-
 .../gemfire/internal/cache/OverflowOplog.java   |   21 +-
 .../internal/cache/OverflowOplogSet.java        |   21 +-
 .../internal/cache/PRContainsValueFunction.java |   21 +-
 .../internal/cache/PRHARedundancyProvider.java  |   20 +-
 .../internal/cache/PRQueryProcessor.java        |   20 +-
 .../internal/cache/PRSystemPropertyGetter.java  |   21 +-
 .../internal/cache/PartitionAttributesImpl.java |   21 +-
 .../internal/cache/PartitionRegionConfig.java   |   21 +-
 .../cache/PartitionRegionConfigValidator.java   |   21 +-
 .../internal/cache/PartitionedRegion.java       |   47 +-
 .../PartitionedRegionBucketMgmtHelper.java      |   20 +-
 .../cache/PartitionedRegionDataStore.java       |   20 +-
 .../cache/PartitionedRegionDataView.java        |   21 +-
 .../cache/PartitionedRegionException.java       |   21 +-
 .../internal/cache/PartitionedRegionHelper.java |   22 +-
 .../cache/PartitionedRegionQueryEvaluator.java  |   20 +-
 .../internal/cache/PartitionedRegionStats.java  |   21 +-
 .../internal/cache/PartitionedRegionStatus.java |   21 +-
 .../gemfire/internal/cache/PeerTXStateStub.java |   21 +-
 .../internal/cache/PersistentOplogSet.java      |   21 +-
 .../internal/cache/PlaceHolderDiskRegion.java   |   23 +-
 .../gemfire/internal/cache/PoolFactoryImpl.java |   21 +-
 .../gemfire/internal/cache/PoolManagerImpl.java |   21 +-
 .../gemfire/internal/cache/PoolStats.java       |   21 +-
 .../cache/PreferBytesCachedDeserializable.java  |   21 +-
 .../internal/cache/PrimaryBucketException.java  |   21 +-
 .../cache/ProfileExchangeProcessor.java         |   21 +-
 .../internal/cache/ProxyBucketRegion.java       |   21 +-
 .../gemfire/internal/cache/ProxyRegionMap.java  |   21 +-
 .../cache/PutAllPartialResultException.java     |   21 +-
 .../gemfire/internal/cache/QueuedOperation.java |   21 +-
 .../internal/cache/RegionClearedException.java  |   21 +-
 .../gemfire/internal/cache/RegionEntry.java     |   21 +-
 .../internal/cache/RegionEntryContext.java      |   21 +-
 .../internal/cache/RegionEntryFactory.java      |   21 +-
 .../gemfire/internal/cache/RegionEventImpl.java |   21 +-
 .../internal/cache/RegionEvictorTask.java       |   21 +-
 .../internal/cache/RegionExpiryTask.java        |   24 +-
 .../internal/cache/RegionFactoryImpl.java       |   21 +-
 .../internal/cache/RegionIdleExpiryTask.java    |   21 +-
 .../gemfire/internal/cache/RegionMap.java       |   21 +-
 .../internal/cache/RegionMapFactory.java        |   21 +-
 .../gemfire/internal/cache/RegionQueue.java     |   21 +-
 .../internal/cache/RegionQueueException.java    |   21 +-
 .../gemfire/internal/cache/RegionStatus.java    |   21 +-
 .../internal/cache/RegionTTLExpiryTask.java     |   21 +-
 .../internal/cache/ReleaseClearLockMessage.java |   23 +-
 .../cache/ReliableDistributionData.java         |   21 +-
 .../internal/cache/ReliableMessageQueue.java    |   21 +-
 .../cache/ReliableMessageQueueFactory.java      |   21 +-
 .../cache/ReliableMessageQueueFactoryImpl.java  |   21 +-
 .../cache/RemoteContainsKeyValueMessage.java    |   20 +-
 .../internal/cache/RemoteDestroyMessage.java    |   21 +-
 .../internal/cache/RemoteFetchEntryMessage.java |   20 +-
 .../cache/RemoteFetchVersionMessage.java        |   20 +-
 .../internal/cache/RemoteGetMessage.java        |   21 +-
 .../internal/cache/RemoteInvalidateMessage.java |   20 +-
 .../cache/RemoteOperationException.java         |   21 +-
 .../internal/cache/RemoteOperationMessage.java  |   21 +-
 .../RemoteOperationMessageWithDirectReply.java  |   21 +-
 .../internal/cache/RemotePutAllMessage.java     |   21 +-
 .../internal/cache/RemotePutMessage.java        |   21 +-
 .../internal/cache/RemoteRegionOperation.java   |   20 +-
 .../internal/cache/RemoteRemoveAllMessage.java  |   21 +-
 .../gemfire/internal/cache/RoleEventImpl.java   |   21 +-
 .../cache/SearchLoadAndWriteProcessor.java      |   21 +-
 .../internal/cache/SendQueueOperation.java      |   21 +-
 .../internal/cache/SerializationHelper.java     |   16 +
 .../internal/cache/ServerPingMessage.java       |   16 +
 .../internal/cache/StateFlushOperation.java     |   21 +-
 .../cache/StoreAllCachedDeserializable.java     |   21 +-
 .../internal/cache/TXBucketRegionState.java     |   21 +-
 .../gemfire/internal/cache/TXCommitMessage.java |   21 +-
 .../gemfire/internal/cache/TXEntry.java         |   21 +-
 .../gemfire/internal/cache/TXEntryState.java    |   21 +-
 .../internal/cache/TXEntryStateFactory.java     |   21 +-
 .../internal/cache/TXEntryUserAttrState.java    |   21 +-
 .../gemfire/internal/cache/TXEvent.java         |   21 +-
 .../internal/cache/TXFarSideCMTracker.java      |   21 +-
 .../gemstone/gemfire/internal/cache/TXId.java   |   22 +-
 .../gemfire/internal/cache/TXLockRequest.java   |   21 +-
 .../gemfire/internal/cache/TXManagerImpl.java   |   21 +-
 .../gemfire/internal/cache/TXMessage.java       |   21 +-
 .../internal/cache/TXRegionLockRequestImpl.java |   21 +-
 .../gemfire/internal/cache/TXRegionState.java   |   21 +-
 .../internal/cache/TXRemoteCommitMessage.java   |   21 +-
 .../internal/cache/TXRemoteRollbackMessage.java |   21 +-
 .../internal/cache/TXReservationMgr.java        |   21 +-
 .../gemfire/internal/cache/TXRmtEvent.java      |   21 +-
 .../gemfire/internal/cache/TXState.java         |   21 +-
 .../internal/cache/TXStateInterface.java        |   21 +-
 .../gemfire/internal/cache/TXStateProxy.java    |   21 +-
 .../internal/cache/TXStateProxyImpl.java        |   21 +-
 .../gemfire/internal/cache/TXStateStub.java     |   21 +-
 .../cache/TXSynchronizationRunnable.java        |   21 +-
 .../cache/TestHeapThresholdObserver.java        |   21 +-
 .../cache/TimestampedEntryEventImpl.java        |   21 +-
 .../gemstone/gemfire/internal/cache/Token.java  |   21 +-
 .../internal/cache/TombstoneService.java        |   24 +-
 .../internal/cache/TransactionMessage.java      |   21 +-
 .../gemfire/internal/cache/TxEntryFactory.java  |   16 +
 .../internal/cache/UnsharedImageState.java      |   21 +-
 .../cache/UpdateAttributesProcessor.java        |   21 +-
 .../cache/UpdateEntryVersionOperation.java      |   22 +-
 .../gemfire/internal/cache/UpdateOperation.java |   20 +-
 .../cache/UserSpecifiedDiskStoreAttributes.java |   21 +-
 .../cache/UserSpecifiedRegionAttributes.java    |   21 +-
 .../internal/cache/VMCachedDeserializable.java  |   21 +-
 .../gemfire/internal/cache/VMLRURegionMap.java  |   21 +-
 .../gemfire/internal/cache/VMRegionMap.java     |   21 +-
 .../cache/VMStatsDiskLRURegionEntry.java        |   21 +-
 .../cache/VMStatsDiskLRURegionEntryHeap.java    |   21 +-
 .../VMStatsDiskLRURegionEntryHeapIntKey.java    |   21 +-
 .../VMStatsDiskLRURegionEntryHeapLongKey.java   |   21 +-
 .../VMStatsDiskLRURegionEntryHeapObjectKey.java |   21 +-
 ...VMStatsDiskLRURegionEntryHeapStringKey1.java |   21 +-
 ...VMStatsDiskLRURegionEntryHeapStringKey2.java |   21 +-
 .../VMStatsDiskLRURegionEntryHeapUUIDKey.java   |   21 +-
 .../cache/VMStatsDiskLRURegionEntryOffHeap.java |   21 +-
 .../VMStatsDiskLRURegionEntryOffHeapIntKey.java |   21 +-
 ...VMStatsDiskLRURegionEntryOffHeapLongKey.java |   21 +-
 ...StatsDiskLRURegionEntryOffHeapObjectKey.java |   21 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey1.java |   21 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey2.java |   21 +-
 ...VMStatsDiskLRURegionEntryOffHeapUUIDKey.java |   21 +-
 .../internal/cache/VMStatsDiskRegionEntry.java  |   21 +-
 .../cache/VMStatsDiskRegionEntryHeap.java       |   21 +-
 .../cache/VMStatsDiskRegionEntryHeapIntKey.java |   21 +-
 .../VMStatsDiskRegionEntryHeapLongKey.java      |   21 +-
 .../VMStatsDiskRegionEntryHeapObjectKey.java    |   21 +-
 .../VMStatsDiskRegionEntryHeapStringKey1.java   |   21 +-
 .../VMStatsDiskRegionEntryHeapStringKey2.java   |   21 +-
 .../VMStatsDiskRegionEntryHeapUUIDKey.java      |   21 +-
 .../cache/VMStatsDiskRegionEntryOffHeap.java    |   21 +-
 .../VMStatsDiskRegionEntryOffHeapIntKey.java    |   21 +-
 .../VMStatsDiskRegionEntryOffHeapLongKey.java   |   21 +-
 .../VMStatsDiskRegionEntryOffHeapObjectKey.java |   21 +-
 ...VMStatsDiskRegionEntryOffHeapStringKey1.java |   21 +-
 ...VMStatsDiskRegionEntryOffHeapStringKey2.java |   21 +-
 .../VMStatsDiskRegionEntryOffHeapUUIDKey.java   |   21 +-
 .../internal/cache/VMStatsLRURegionEntry.java   |   21 +-
 .../cache/VMStatsLRURegionEntryHeap.java        |   21 +-
 .../cache/VMStatsLRURegionEntryHeapIntKey.java  |   21 +-
 .../cache/VMStatsLRURegionEntryHeapLongKey.java |   21 +-
 .../VMStatsLRURegionEntryHeapObjectKey.java     |   21 +-
 .../VMStatsLRURegionEntryHeapStringKey1.java    |   21 +-
 .../VMStatsLRURegionEntryHeapStringKey2.java    |   21 +-
 .../cache/VMStatsLRURegionEntryHeapUUIDKey.java |   21 +-
 .../cache/VMStatsLRURegionEntryOffHeap.java     |   21 +-
 .../VMStatsLRURegionEntryOffHeapIntKey.java     |   21 +-
 .../VMStatsLRURegionEntryOffHeapLongKey.java    |   21 +-
 .../VMStatsLRURegionEntryOffHeapObjectKey.java  |   21 +-
 .../VMStatsLRURegionEntryOffHeapStringKey1.java |   21 +-
 .../VMStatsLRURegionEntryOffHeapStringKey2.java |   21 +-
 .../VMStatsLRURegionEntryOffHeapUUIDKey.java    |   21 +-
 .../internal/cache/VMStatsRegionEntry.java      |   21 +-
 .../internal/cache/VMStatsRegionEntryHeap.java  |   21 +-
 .../cache/VMStatsRegionEntryHeapIntKey.java     |   21 +-
 .../cache/VMStatsRegionEntryHeapLongKey.java    |   21 +-
 .../cache/VMStatsRegionEntryHeapObjectKey.java  |   21 +-
 .../cache/VMStatsRegionEntryHeapStringKey1.java |   21 +-
 .../cache/VMStatsRegionEntryHeapStringKey2.java |   21 +-
 .../cache/VMStatsRegionEntryHeapUUIDKey.java    |   21 +-
 .../cache/VMStatsRegionEntryOffHeap.java        |   21 +-
 .../cache/VMStatsRegionEntryOffHeapIntKey.java  |   21 +-
 .../cache/VMStatsRegionEntryOffHeapLongKey.java |   21 +-
 .../VMStatsRegionEntryOffHeapObjectKey.java     |   21 +-
 .../VMStatsRegionEntryOffHeapStringKey1.java    |   21 +-
 .../VMStatsRegionEntryOffHeapStringKey2.java    |   21 +-
 .../cache/VMStatsRegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VMThinDiskLRURegionEntry.java         |   21 +-
 .../cache/VMThinDiskLRURegionEntryHeap.java     |   21 +-
 .../VMThinDiskLRURegionEntryHeapIntKey.java     |   21 +-
 .../VMThinDiskLRURegionEntryHeapLongKey.java    |   21 +-
 .../VMThinDiskLRURegionEntryHeapObjectKey.java  |   21 +-
 .../VMThinDiskLRURegionEntryHeapStringKey1.java |   21 +-
 .../VMThinDiskLRURegionEntryHeapStringKey2.java |   21 +-
 .../VMThinDiskLRURegionEntryHeapUUIDKey.java    |   21 +-
 .../cache/VMThinDiskLRURegionEntryOffHeap.java  |   21 +-
 .../VMThinDiskLRURegionEntryOffHeapIntKey.java  |   21 +-
 .../VMThinDiskLRURegionEntryOffHeapLongKey.java |   21 +-
 ...MThinDiskLRURegionEntryOffHeapObjectKey.java |   21 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey1.java |   21 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey2.java |   21 +-
 .../VMThinDiskLRURegionEntryOffHeapUUIDKey.java |   21 +-
 .../internal/cache/VMThinDiskRegionEntry.java   |   21 +-
 .../cache/VMThinDiskRegionEntryHeap.java        |   21 +-
 .../cache/VMThinDiskRegionEntryHeapIntKey.java  |   21 +-
 .../cache/VMThinDiskRegionEntryHeapLongKey.java |   21 +-
 .../VMThinDiskRegionEntryHeapObjectKey.java     |   21 +-
 .../VMThinDiskRegionEntryHeapStringKey1.java    |   21 +-
 .../VMThinDiskRegionEntryHeapStringKey2.java    |   21 +-
 .../cache/VMThinDiskRegionEntryHeapUUIDKey.java |   21 +-
 .../cache/VMThinDiskRegionEntryOffHeap.java     |   21 +-
 .../VMThinDiskRegionEntryOffHeapIntKey.java     |   21 +-
 .../VMThinDiskRegionEntryOffHeapLongKey.java    |   21 +-
 .../VMThinDiskRegionEntryOffHeapObjectKey.java  |   21 +-
 .../VMThinDiskRegionEntryOffHeapStringKey1.java |   21 +-
 .../VMThinDiskRegionEntryOffHeapStringKey2.java |   21 +-
 .../VMThinDiskRegionEntryOffHeapUUIDKey.java    |   21 +-
 .../internal/cache/VMThinLRURegionEntry.java    |   21 +-
 .../cache/VMThinLRURegionEntryHeap.java         |   21 +-
 .../cache/VMThinLRURegionEntryHeapIntKey.java   |   21 +-
 .../cache/VMThinLRURegionEntryHeapLongKey.java  |   21 +-
 .../VMThinLRURegionEntryHeapObjectKey.java      |   21 +-
 .../VMThinLRURegionEntryHeapStringKey1.java     |   21 +-
 .../VMThinLRURegionEntryHeapStringKey2.java     |   21 +-
 .../cache/VMThinLRURegionEntryHeapUUIDKey.java  |   21 +-
 .../cache/VMThinLRURegionEntryOffHeap.java      |   21 +-
 .../VMThinLRURegionEntryOffHeapIntKey.java      |   21 +-
 .../VMThinLRURegionEntryOffHeapLongKey.java     |   21 +-
 .../VMThinLRURegionEntryOffHeapObjectKey.java   |   21 +-
 .../VMThinLRURegionEntryOffHeapStringKey1.java  |   21 +-
 .../VMThinLRURegionEntryOffHeapStringKey2.java  |   21 +-
 .../VMThinLRURegionEntryOffHeapUUIDKey.java     |   21 +-
 .../internal/cache/VMThinRegionEntry.java       |   21 +-
 .../internal/cache/VMThinRegionEntryHeap.java   |   21 +-
 .../cache/VMThinRegionEntryHeapIntKey.java      |   21 +-
 .../cache/VMThinRegionEntryHeapLongKey.java     |   21 +-
 .../cache/VMThinRegionEntryHeapObjectKey.java   |   21 +-
 .../cache/VMThinRegionEntryHeapStringKey1.java  |   21 +-
 .../cache/VMThinRegionEntryHeapStringKey2.java  |   21 +-
 .../cache/VMThinRegionEntryHeapUUIDKey.java     |   21 +-
 .../cache/VMThinRegionEntryOffHeap.java         |   16 +
 .../cache/VMThinRegionEntryOffHeapIntKey.java   |   21 +-
 .../cache/VMThinRegionEntryOffHeapLongKey.java  |   21 +-
 .../VMThinRegionEntryOffHeapObjectKey.java      |   21 +-
 .../VMThinRegionEntryOffHeapStringKey1.java     |   21 +-
 .../VMThinRegionEntryOffHeapStringKey2.java     |   21 +-
 .../cache/VMThinRegionEntryOffHeapUUIDKey.java  |   21 +-
 .../internal/cache/ValidatingDiskRegion.java    |   21 +-
 .../internal/cache/ValueByteWrapper.java        |   21 +-
 .../internal/cache/VersionTimestamp.java        |   21 +-
 .../cache/VersionedStatsDiskLRURegionEntry.java |   21 +-
 .../VersionedStatsDiskLRURegionEntryHeap.java   |   21 +-
 ...sionedStatsDiskLRURegionEntryHeapIntKey.java |   21 +-
 ...ionedStatsDiskLRURegionEntryHeapLongKey.java |   21 +-
 ...nedStatsDiskLRURegionEntryHeapObjectKey.java |   21 +-
 ...edStatsDiskLRURegionEntryHeapStringKey1.java |   21 +-
 ...edStatsDiskLRURegionEntryHeapStringKey2.java |   21 +-
 ...ionedStatsDiskLRURegionEntryHeapUUIDKey.java |   21 +-
 ...VersionedStatsDiskLRURegionEntryOffHeap.java |   21 +-
 ...nedStatsDiskLRURegionEntryOffHeapIntKey.java |   21 +-
 ...edStatsDiskLRURegionEntryOffHeapLongKey.java |   21 +-
 ...StatsDiskLRURegionEntryOffHeapObjectKey.java |   21 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey1.java |   21 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey2.java |   21 +-
 ...edStatsDiskLRURegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VersionedStatsDiskRegionEntry.java    |   21 +-
 .../VersionedStatsDiskRegionEntryHeap.java      |   21 +-
 ...VersionedStatsDiskRegionEntryHeapIntKey.java |   21 +-
 ...ersionedStatsDiskRegionEntryHeapLongKey.java |   21 +-
 ...sionedStatsDiskRegionEntryHeapObjectKey.java |   21 +-
 ...ionedStatsDiskRegionEntryHeapStringKey1.java |   21 +-
 ...ionedStatsDiskRegionEntryHeapStringKey2.java |   21 +-
 ...ersionedStatsDiskRegionEntryHeapUUIDKey.java |   21 +-
 .../VersionedStatsDiskRegionEntryOffHeap.java   |   21 +-
 ...sionedStatsDiskRegionEntryOffHeapIntKey.java |   21 +-
 ...ionedStatsDiskRegionEntryOffHeapLongKey.java |   21 +-
 ...nedStatsDiskRegionEntryOffHeapObjectKey.java |   21 +-
 ...edStatsDiskRegionEntryOffHeapStringKey1.java |   21 +-
 ...edStatsDiskRegionEntryOffHeapStringKey2.java |   21 +-
 ...ionedStatsDiskRegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VersionedStatsLRURegionEntry.java     |   21 +-
 .../cache/VersionedStatsLRURegionEntryHeap.java |   21 +-
 .../VersionedStatsLRURegionEntryHeapIntKey.java |   21 +-
 ...VersionedStatsLRURegionEntryHeapLongKey.java |   21 +-
 ...rsionedStatsLRURegionEntryHeapObjectKey.java |   21 +-
 ...sionedStatsLRURegionEntryHeapStringKey1.java |   21 +-
 ...sionedStatsLRURegionEntryHeapStringKey2.java |   21 +-
 ...VersionedStatsLRURegionEntryHeapUUIDKey.java |   21 +-
 .../VersionedStatsLRURegionEntryOffHeap.java    |   21 +-
 ...rsionedStatsLRURegionEntryOffHeapIntKey.java |   21 +-
 ...sionedStatsLRURegionEntryOffHeapLongKey.java |   21 +-
 ...onedStatsLRURegionEntryOffHeapObjectKey.java |   21 +-
 ...nedStatsLRURegionEntryOffHeapStringKey1.java |   21 +-
 ...nedStatsLRURegionEntryOffHeapStringKey2.java |   21 +-
 ...sionedStatsLRURegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VersionedStatsRegionEntry.java        |   21 +-
 .../cache/VersionedStatsRegionEntryHeap.java    |   21 +-
 .../VersionedStatsRegionEntryHeapIntKey.java    |   21 +-
 .../VersionedStatsRegionEntryHeapLongKey.java   |   21 +-
 .../VersionedStatsRegionEntryHeapObjectKey.java |   21 +-
 ...VersionedStatsRegionEntryHeapStringKey1.java |   21 +-
 ...VersionedStatsRegionEntryHeapStringKey2.java |   21 +-
 .../VersionedStatsRegionEntryHeapUUIDKey.java   |   21 +-
 .../cache/VersionedStatsRegionEntryOffHeap.java |   21 +-
 .../VersionedStatsRegionEntryOffHeapIntKey.java |   21 +-
 ...VersionedStatsRegionEntryOffHeapLongKey.java |   21 +-
 ...rsionedStatsRegionEntryOffHeapObjectKey.java |   21 +-
 ...sionedStatsRegionEntryOffHeapStringKey1.java |   21 +-
 ...sionedStatsRegionEntryOffHeapStringKey2.java |   21 +-
 ...VersionedStatsRegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VersionedThinDiskLRURegionEntry.java  |   21 +-
 .../VersionedThinDiskLRURegionEntryHeap.java    |   21 +-
 ...rsionedThinDiskLRURegionEntryHeapIntKey.java |   21 +-
 ...sionedThinDiskLRURegionEntryHeapLongKey.java |   21 +-
 ...onedThinDiskLRURegionEntryHeapObjectKey.java |   21 +-
 ...nedThinDiskLRURegionEntryHeapStringKey1.java |   21 +-
 ...nedThinDiskLRURegionEntryHeapStringKey2.java |   21 +-
 ...sionedThinDiskLRURegionEntryHeapUUIDKey.java |   21 +-
 .../VersionedThinDiskLRURegionEntryOffHeap.java |   21 +-
 ...onedThinDiskLRURegionEntryOffHeapIntKey.java |   21 +-
 ...nedThinDiskLRURegionEntryOffHeapLongKey.java |   21 +-
 ...dThinDiskLRURegionEntryOffHeapObjectKey.java |   21 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey1.java |   21 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey2.java |   21 +-
 ...nedThinDiskLRURegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VersionedThinDiskRegionEntry.java     |   21 +-
 .../cache/VersionedThinDiskRegionEntryHeap.java |   21 +-
 .../VersionedThinDiskRegionEntryHeapIntKey.java |   21 +-
 ...VersionedThinDiskRegionEntryHeapLongKey.java |   21 +-
 ...rsionedThinDiskRegionEntryHeapObjectKey.java |   21 +-
 ...sionedThinDiskRegionEntryHeapStringKey1.java |   21 +-
 ...sionedThinDiskRegionEntryHeapStringKey2.java |   21 +-
 ...VersionedThinDiskRegionEntryHeapUUIDKey.java |   21 +-
 .../VersionedThinDiskRegionEntryOffHeap.java    |   21 +-
 ...rsionedThinDiskRegionEntryOffHeapIntKey.java |   21 +-
 ...sionedThinDiskRegionEntryOffHeapLongKey.java |   21 +-
 ...onedThinDiskRegionEntryOffHeapObjectKey.java |   21 +-
 ...nedThinDiskRegionEntryOffHeapStringKey1.java |   21 +-
 ...nedThinDiskRegionEntryOffHeapStringKey2.java |   21 +-
 ...sionedThinDiskRegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VersionedThinLRURegionEntry.java      |   21 +-
 .../cache/VersionedThinLRURegionEntryHeap.java  |   21 +-
 .../VersionedThinLRURegionEntryHeapIntKey.java  |   21 +-
 .../VersionedThinLRURegionEntryHeapLongKey.java |   21 +-
 ...ersionedThinLRURegionEntryHeapObjectKey.java |   21 +-
 ...rsionedThinLRURegionEntryHeapStringKey1.java |   21 +-
 ...rsionedThinLRURegionEntryHeapStringKey2.java |   21 +-
 .../VersionedThinLRURegionEntryHeapUUIDKey.java |   21 +-
 .../VersionedThinLRURegionEntryOffHeap.java     |   21 +-
 ...ersionedThinLRURegionEntryOffHeapIntKey.java |   21 +-
 ...rsionedThinLRURegionEntryOffHeapLongKey.java |   21 +-
 ...ionedThinLRURegionEntryOffHeapObjectKey.java |   21 +-
 ...onedThinLRURegionEntryOffHeapStringKey1.java |   21 +-
 ...onedThinLRURegionEntryOffHeapStringKey2.java |   21 +-
 ...rsionedThinLRURegionEntryOffHeapUUIDKey.java |   21 +-
 .../cache/VersionedThinRegionEntry.java         |   21 +-
 .../cache/VersionedThinRegionEntryHeap.java     |   21 +-
 .../VersionedThinRegionEntryHeapIntKey.java     |   21 +-
 .../VersionedThinRegionEntryHeapLongKey.java    |   21 +-
 .../VersionedThinRegionEntryHeapObjectKey.java  |   21 +-
 .../VersionedThinRegionEntryHeapStringKey1.java |   21 +-
 .../VersionedThinRegionEntryHeapStringKey2.java |   21 +-
 .../VersionedThinRegionEntryHeapUUIDKey.java    |   21 +-
 .../cache/VersionedThinRegionEntryOffHeap.java  |   21 +-
 .../VersionedThinRegionEntryOffHeapIntKey.java  |   21 +-
 .../VersionedThinRegionEntryOffHeapLongKey.java |   21 +-
 ...ersionedThinRegionEntryOffHeapObjectKey.java |   21 +-
 ...rsionedThinRegionEntryOffHeapStringKey1.java |   21 +-
 ...rsionedThinRegionEntryOffHeapStringKey2.java |   21 +-
 .../VersionedThinRegionEntryOffHeapUUIDKey.java |   21 +-
 .../internal/cache/WrappedCallbackArgument.java |   21 +-
 .../cache/WrappedRegionMembershipListener.java  |   21 +-
 .../CompressedCachedDeserializable.java         |   23 +-
 .../SnappyCompressedCachedDeserializable.java   |   23 +-
 .../internal/cache/control/FilterByPath.java    |   21 +-
 .../cache/control/HeapMemoryMonitor.java        |   21 +-
 .../cache/control/InternalResourceManager.java  |   21 +-
 .../internal/cache/control/MemoryEvent.java     |   20 +-
 .../cache/control/MemoryThresholds.java         |   16 +
 .../cache/control/OffHeapMemoryMonitor.java     |  124 +-
 .../control/PartitionRebalanceDetailsImpl.java  |   21 +-
 .../cache/control/RebalanceOperationImpl.java   |   21 +-
 .../cache/control/RebalanceResultsImpl.java     |   21 +-
 .../internal/cache/control/RegionFilter.java    |   21 +-
 .../internal/cache/control/ResourceAdvisor.java |   21 +-
 .../internal/cache/control/ResourceEvent.java   |   20 +-
 .../cache/control/ResourceListener.java         |   21 +-
 .../cache/control/ResourceManagerStats.java     |   21 +-
 .../internal/cache/control/ResourceMonitor.java |   16 +
 .../gemfire/internal/cache/delta/Delta.java     |   21 +-
 .../cache/execute/AbstractExecution.java        |   21 +-
 .../cache/execute/BucketMovedException.java     |   21 +-
 .../cache/execute/DefaultResultCollector.java   |   20 +-
 .../DistributedRegionFunctionExecutor.java      |   20 +-
 .../DistributedRegionFunctionResultSender.java  |   21 +-
 .../DistributedRegionFunctionResultWaiter.java  |   21 +-
 .../cache/execute/FunctionContextImpl.java      |   21 +-
 .../execute/FunctionExecutionNodePruner.java    |   21 +-
 .../cache/execute/FunctionRemoteContext.java    |   21 +-
 .../cache/execute/FunctionServiceStats.java     |   24 +-
 .../internal/cache/execute/FunctionStats.java   |   21 +-
 .../FunctionStreamingResultCollector.java       |   21 +-
 .../cache/execute/InternalExecution.java        |   21 +-
 .../execute/InternalFunctionException.java      |   21 +-
 ...ternalFunctionInvocationTargetException.java |   21 +-
 .../cache/execute/InternalFunctionService.java  |   20 +-
 .../execute/InternalRegionFunctionContext.java  |   21 +-
 .../cache/execute/InternalResultSender.java     |   21 +-
 .../cache/execute/LocalResultCollector.java     |   20 +-
 .../cache/execute/LocalResultCollectorImpl.java |   21 +-
 .../cache/execute/MemberFunctionExecutor.java   |   21 +-
 .../execute/MemberFunctionResultSender.java     |   20 +-
 .../execute/MemberFunctionResultWaiter.java     |   21 +-
 .../cache/execute/MemberMappedArgument.java     |   20 +-
 .../execute/MultiRegionFunctionContext.java     |   21 +-
 .../execute/MultiRegionFunctionContextImpl.java |   21 +-
 .../execute/MultiRegionFunctionExecutor.java    |   21 +-
 .../MultiRegionFunctionResultWaiter.java        |   21 +-
 .../internal/cache/execute/NoResult.java        |   20 +-
 .../PartitionedRegionFunctionExecutor.java      |   21 +-
 .../PartitionedRegionFunctionResultSender.java  |   20 +-
 .../PartitionedRegionFunctionResultWaiter.java  |   21 +-
 .../execute/RegionFunctionContextImpl.java      |   21 +-
 .../cache/execute/ServerFunctionExecutor.java   |   21 +-
 .../execute/ServerRegionFunctionExecutor.java   |   23 +-
 .../ServerToClientFunctionResultSender.java     |   20 +-
 .../ServerToClientFunctionResultSender65.java   |   20 +-
 .../execute/StreamingFunctionOperation.java     |   21 +-
 .../execute/TransactionFunctionService.java     |   21 +-
 .../cache/execute/util/CommitFunction.java      |   21 +-
 .../util/FindRestEnabledServersFunction.java    |   23 +-
 .../execute/util/NestedTransactionFunction.java |   21 +-
 .../cache/execute/util/RollbackFunction.java    |   21 +-
 .../internal/cache/extension/Extensible.java    |   21 +-
 .../internal/cache/extension/Extension.java     |   21 +-
 .../cache/extension/ExtensionPoint.java         |   21 +-
 .../cache/extension/SimpleExtensionPoint.java   |   21 +-
 .../internal/cache/ha/HAContainerMap.java       |   21 +-
 .../internal/cache/ha/HAContainerRegion.java    |   21 +-
 .../internal/cache/ha/HAContainerWrapper.java   |   21 +-
 .../internal/cache/ha/HARegionQueue.java        |   20 +-
 .../cache/ha/HARegionQueueAttributes.java       |   21 +-
 .../internal/cache/ha/HARegionQueueStats.java   |   21 +-
 .../internal/cache/ha/QueueRemovalMessage.java  |   21 +-
 .../internal/cache/ha/ThreadIdentifier.java     |   21 +-
 .../locks/GFEAbstractQueuedSynchronizer.java    |   21 +-
 .../locks/ReentrantReadWriteWriteShareLock.java |   21 +-
 .../cache/locks/TXLessorDepartureHandler.java   |   21 +-
 .../internal/cache/locks/TXLockBatch.java       |   21 +-
 .../gemfire/internal/cache/locks/TXLockId.java  |   21 +-
 .../internal/cache/locks/TXLockIdImpl.java      |   21 +-
 .../internal/cache/locks/TXLockService.java     |   21 +-
 .../internal/cache/locks/TXLockServiceImpl.java |   21 +-
 .../internal/cache/locks/TXLockToken.java       |   21 +-
 .../locks/TXLockUpdateParticipantsMessage.java  |   21 +-
 .../locks/TXOriginatorRecoveryProcessor.java    |   21 +-
 .../locks/TXRecoverGrantorMessageProcessor.java |   21 +-
 .../cache/locks/TXRegionLockRequest.java        |   21 +-
 .../gemfire/internal/cache/lru/EnableLRU.java   |   21 +-
 .../gemfire/internal/cache/lru/HeapEvictor.java |   21 +-
 .../cache/lru/HeapLRUCapacityController.java    |   21 +-
 .../internal/cache/lru/HeapLRUStatistics.java   |   21 +-
 .../internal/cache/lru/LRUAlgorithm.java        |   21 +-
 .../cache/lru/LRUCapacityController.java        |   21 +-
 .../internal/cache/lru/LRUClockNode.java        |   21 +-
 .../gemfire/internal/cache/lru/LRUEntry.java    |   21 +-
 .../internal/cache/lru/LRUMapCallbacks.java     |   21 +-
 .../internal/cache/lru/LRUStatistics.java       |   21 +-
 .../cache/lru/MemLRUCapacityController.java     |   21 +-
 .../internal/cache/lru/NewLIFOClockHand.java    |   21 +-
 .../internal/cache/lru/NewLRUClockHand.java     |   21 +-
 .../internal/cache/lru/OffHeapEvictor.java      |   21 +-
 .../gemfire/internal/cache/lru/Sizeable.java    |   21 +-
 .../operations/ContainsKeyOperationContext.java |   21 +-
 .../AllBucketProfilesUpdateMessage.java         |   21 +-
 .../partitioned/BecomePrimaryBucketMessage.java |   21 +-
 .../internal/cache/partitioned/Bucket.java      |   21 +-
 .../cache/partitioned/BucketBackupMessage.java  |   20 +-
 .../partitioned/BucketProfileUpdateMessage.java |   21 +-
 .../cache/partitioned/BucketSizeMessage.java    |   21 +-
 .../partitioned/ContainsKeyValueMessage.java    |   20 +-
 .../cache/partitioned/CreateBucketMessage.java  |   21 +-
 .../partitioned/CreateMissingBucketsTask.java   |   23 +-
 .../partitioned/DeposePrimaryBucketMessage.java |   21 +-
 .../cache/partitioned/DestroyMessage.java       |   21 +-
 .../DestroyRegionOnDataStoreMessage.java        |   20 +-
 .../partitioned/DumpAllPRConfigMessage.java     |   20 +-
 .../cache/partitioned/DumpB2NRegion.java        |   20 +-
 .../cache/partitioned/DumpBucketsMessage.java   |   21 +-
 .../partitioned/EndBucketCreationMessage.java   |   21 +-
 .../partitioned/FetchBulkEntriesMessage.java    |   21 +-
 .../cache/partitioned/FetchEntriesMessage.java  |   21 +-
 .../cache/partitioned/FetchEntryMessage.java    |   20 +-
 .../cache/partitioned/FetchKeysMessage.java     |   21 +-
 .../FetchPartitionDetailsMessage.java           |   21 +-
 .../cache/partitioned/FlushMessage.java         |   21 +-
 .../internal/cache/partitioned/GetMessage.java  |   21 +-
 .../partitioned/IdentityRequestMessage.java     |   20 +-
 .../partitioned/IdentityUpdateMessage.java      |   21 +-
 .../cache/partitioned/IndexCreationMsg.java     |   21 +-
 .../cache/partitioned/InterestEventMessage.java |   21 +-
 .../cache/partitioned/InternalPRInfo.java       |   21 +-
 .../partitioned/InternalPartitionDetails.java   |   21 +-
 .../cache/partitioned/InvalidateMessage.java    |   20 +-
 .../internal/cache/partitioned/LoadProbe.java   |   21 +-
 .../internal/cache/partitioned/LockObject.java  |   21 +-
 .../partitioned/ManageBackupBucketMessage.java  |   21 +-
 .../cache/partitioned/ManageBucketMessage.java  |   21 +-
 .../cache/partitioned/MoveBucketMessage.java    |   21 +-
 .../cache/partitioned/OfflineMemberDetails.java |   23 +-
 .../partitioned/OfflineMemberDetailsImpl.java   |   21 +-
 .../cache/partitioned/PREntriesIterator.java    |   21 +-
 .../PRFunctionStreamingResultCollector.java     |   21 +-
 .../internal/cache/partitioned/PRLoad.java      |   21 +-
 .../PRLocallyDestroyedException.java            |   21 +-
 .../cache/partitioned/PRSanityCheckMessage.java |   21 +-
 .../cache/partitioned/PRTombstoneMessage.java   |   21 +-
 .../PRUpdateEntryVersionMessage.java            |   22 +-
 .../partitioned/PartitionMemberInfoImpl.java    |   21 +-
 .../cache/partitioned/PartitionMessage.java     |   21 +-
 .../PartitionMessageWithDirectReply.java        |   21 +-
 .../partitioned/PartitionRegionInfoImpl.java    |   21 +-
 ...rtitionedRegionFunctionStreamingMessage.java |   21 +-
 .../partitioned/PartitionedRegionObserver.java  |   21 +-
 .../PartitionedRegionObserverAdapter.java       |   21 +-
 .../PartitionedRegionObserverHolder.java        |   21 +-
 .../PartitionedRegionRebalanceOp.java           |   73 +-
 .../partitioned/PrimaryRequestMessage.java      |   21 +-
 .../cache/partitioned/PutAllPRMessage.java      |   21 +-
 .../internal/cache/partitioned/PutMessage.java  |   21 +-
 .../cache/partitioned/QueryMessage.java         |   21 +-
 .../cache/partitioned/RecoveryRunnable.java     |   23 +-
 .../RedundancyAlreadyMetException.java          |   21 +-
 .../cache/partitioned/RedundancyLogger.java     |   21 +-
 .../cache/partitioned/RegionAdvisor.java        |   20 +-
 .../partitioned/RemoteFetchKeysMessage.java     |   21 +-
 .../cache/partitioned/RemoteSizeMessage.java    |   21 +-
 .../cache/partitioned/RemoveAllPRMessage.java   |   21 +-
 .../cache/partitioned/RemoveBucketMessage.java  |   21 +-
 .../cache/partitioned/RemoveIndexesMessage.java |   21 +-
 .../internal/cache/partitioned/SizeMessage.java |   21 +-
 .../cache/partitioned/SizedBasedLoadProbe.java  |   21 +-
 .../StreamingPartitionOperation.java            |   24 +-
 .../partitioned/rebalance/BucketOperator.java   |   21 +-
 .../rebalance/CompositeDirector.java            |   21 +-
 .../rebalance/ExplicitMoveDirector.java         |   21 +-
 .../partitioned/rebalance/FPRDirector.java      |   21 +-
 .../partitioned/rebalance/MoveBuckets.java      |   21 +-
 .../partitioned/rebalance/MovePrimaries.java    |   21 +-
 .../partitioned/rebalance/MovePrimariesFPR.java |   21 +-
 .../rebalance/ParallelBucketOperator.java       |   16 +
 .../rebalance/PartitionedRegionLoadModel.java   |   21 +-
 .../rebalance/PercentageMoveDirector.java       |   21 +-
 .../rebalance/RebalanceDirector.java            |   21 +-
 .../rebalance/RebalanceDirectorAdapter.java     |   21 +-
 .../rebalance/RemoveOverRedundancy.java         |   21 +-
 .../rebalance/SatisfyRedundancy.java            |   21 +-
 .../rebalance/SatisfyRedundancyFPR.java         |   21 +-
 .../rebalance/SimulatedBucketOperator.java      |   21 +-
 .../cache/persistence/BackupInspector.java      |   21 +-
 .../cache/persistence/BackupManager.java        |   21 +-
 .../cache/persistence/BytesAndBits.java         |   21 +-
 .../cache/persistence/CanonicalIdHolder.java    |   21 +-
 .../CreatePersistentRegionProcessor.java        |   21 +-
 .../cache/persistence/DiskExceptionHandler.java |   21 +-
 .../persistence/DiskInitFileInterpreter.java    |   21 +-
 .../cache/persistence/DiskInitFileParser.java   |   21 +-
 .../cache/persistence/DiskRecoveryStore.java    |   23 +-
 .../cache/persistence/DiskRegionView.java       |   21 +-
 .../cache/persistence/DiskStoreFilter.java      |   23 +-
 .../internal/cache/persistence/DiskStoreID.java |   21 +-
 .../persistence/MembershipFlushRequest.java     |   21 +-
 .../persistence/MembershipViewRequest.java      |   21 +-
 .../internal/cache/persistence/OplogType.java   |   18 +-
 .../cache/persistence/PRPersistentConfig.java   |   21 +-
 .../cache/persistence/PersistenceAdvisor.java   |   21 +-
 .../persistence/PersistenceAdvisorImpl.java     |   21 +-
 .../persistence/PersistenceObserverHolder.java  |   21 +-
 .../cache/persistence/PersistentMemberID.java   |   21 +-
 .../persistence/PersistentMemberManager.java    |   21 +-
 .../persistence/PersistentMemberPattern.java    |   23 +-
 .../persistence/PersistentMemberState.java      |   21 +-
 .../cache/persistence/PersistentMemberView.java |   21 +-
 .../persistence/PersistentMembershipView.java   |   23 +-
 .../persistence/PersistentStateListener.java    |   23 +-
 .../PersistentStateQueryMessage.java            |   21 +-
 .../PersistentStateQueryResults.java            |   21 +-
 .../PrepareNewPersistentMemberMessage.java      |   21 +-
 .../RemovePersistentMemberMessage.java          |   21 +-
 .../cache/persistence/RestoreScript.java        |   21 +-
 .../persistence/UninterruptibleFileChannel.java |   18 +-
 .../UninterruptibleRandomAccessFile.java        |   16 +
 .../persistence/query/CloseableIterator.java    |   18 +-
 .../persistence/query/IdentityExtractor.java    |   16 +
 .../cache/persistence/query/IndexMap.java       |   21 +-
 .../cache/persistence/query/ResultBag.java      |   21 +-
 .../cache/persistence/query/ResultList.java     |   21 +-
 .../cache/persistence/query/ResultMap.java      |   21 +-
 .../cache/persistence/query/ResultSet.java      |   21 +-
 .../persistence/query/SortKeyExtractor.java     |   16 +
 .../query/TemporaryResultSetFactory.java        |   21 +-
 .../persistence/query/mock/ByteComparator.java  |   21 +-
 .../mock/CachedDeserializableComparator.java    |   23 +-
 .../persistence/query/mock/IndexMapImpl.java    |   21 +-
 .../persistence/query/mock/ItrAdapter.java      |   23 +-
 .../query/mock/NaturalComparator.java           |   16 +
 .../cache/persistence/query/mock/Pair.java      |   21 +-
 .../persistence/query/mock/PairComparator.java  |   21 +-
 .../persistence/query/mock/ResultListImpl.java  |   21 +-
 .../query/mock/ReverseComparator.java           |   21 +-
 .../query/mock/SortedResultBagImpl.java         |   21 +-
 .../query/mock/SortedResultMapImpl.java         |   21 +-
 .../query/mock/SortedResultSetImpl.java         |   21 +-
 .../persistence/soplog/AbstractCompactor.java   |   21 +-
 .../soplog/AbstractKeyValueIterator.java        |   21 +-
 .../soplog/AbstractSortedReader.java            |   21 +-
 .../soplog/ArraySerializedComparator.java       |   21 +-
 .../persistence/soplog/ByteComparator.java      |   21 +-
 .../cache/persistence/soplog/Compactor.java     |   21 +-
 .../soplog/CompositeSerializedComparator.java   |   21 +-
 .../persistence/soplog/CursorIterator.java      |   21 +-
 .../soplog/DelegatingSerializedComparator.java  |   21 +-
 .../soplog/HFileStoreStatistics.java            |   21 +-
 .../soplog/IndexSerializedComparator.java       |   21 +-
 .../persistence/soplog/KeyValueIterator.java    |   21 +-
 .../cache/persistence/soplog/LevelTracker.java  |   21 +-
 .../soplog/LexicographicalComparator.java       |   21 +-
 .../cache/persistence/soplog/NonCompactor.java  |   21 +-
 .../soplog/ReversingSerializedComparator.java   |   21 +-
 .../persistence/soplog/SizeTieredCompactor.java |   21 +-
 .../cache/persistence/soplog/SoplogToken.java   |   21 +-
 .../cache/persistence/soplog/SortedBuffer.java  |   21 +-
 .../cache/persistence/soplog/SortedOplog.java   |   21 +-
 .../persistence/soplog/SortedOplogFactory.java  |   21 +-
 .../persistence/soplog/SortedOplogSet.java      |   21 +-
 .../persistence/soplog/SortedOplogSetImpl.java  |   21 +-
 .../soplog/SortedOplogStatistics.java           |   21 +-
 .../cache/persistence/soplog/SortedReader.java  |   21 +-
 .../persistence/soplog/TrackedReference.java    |   21 +-
 .../soplog/hfile/BlockCacheHolder.java          |   21 +-
 .../soplog/hfile/HFileSortedOplog.java          |   21 +-
 .../soplog/hfile/HFileSortedOplogFactory.java   |   21 +-
 .../soplog/nofile/NoFileSortedOplog.java        |   21 +-
 .../soplog/nofile/NoFileSortedOplogFactory.java |   21 +-
 .../snapshot/CacheSnapshotServiceImpl.java      |   21 +-
 .../internal/cache/snapshot/ClientExporter.java |   21 +-
 .../cache/snapshot/ExportedRegistry.java        |   21 +-
 .../internal/cache/snapshot/FlowController.java |   21 +-
 .../internal/cache/snapshot/GFSnapshot.java     |   21 +-
 .../internal/cache/snapshot/LocalExporter.java  |   21 +-
 .../snapshot/RegionSnapshotServiceImpl.java     |   21 +-
 .../cache/snapshot/SnapshotFileMapper.java      |   21 +-
 .../cache/snapshot/SnapshotOptionsImpl.java     |   21 +-
 .../internal/cache/snapshot/SnapshotPacket.java |   21 +-
 .../cache/snapshot/WindowedExporter.java        |   21 +-
 .../gemfire/internal/cache/tier/Acceptor.java   |   21 +-
 .../internal/cache/tier/BatchException.java     |   21 +-
 .../internal/cache/tier/CachedRegionHelper.java |   21 +-
 .../internal/cache/tier/ClientHandShake.java    |   21 +-
 .../gemfire/internal/cache/tier/Command.java    |   21 +-
 .../internal/cache/tier/ConnectionProxy.java    |   21 +-
 .../internal/cache/tier/InterestType.java       |   21 +-
 .../cache/tier/InternalClientMembership.java    |   21 +-
 .../internal/cache/tier/MessageType.java        |   21 +-
 .../cache/tier/sockets/AcceptorImpl.java        |   57 +-
 .../cache/tier/sockets/BaseCommand.java         |   21 +-
 .../cache/tier/sockets/BaseCommandQuery.java    |   16 +
 .../cache/tier/sockets/CacheClientNotifier.java |   21 +-
 .../tier/sockets/CacheClientNotifierStats.java  |   21 +-
 .../cache/tier/sockets/CacheClientProxy.java    |   20 +-
 .../tier/sockets/CacheClientProxyStats.java     |   21 +-
 .../cache/tier/sockets/CacheClientUpdater.java  |   31 +-
 .../cache/tier/sockets/CacheServerHelper.java   |   21 +-
 .../cache/tier/sockets/CacheServerStats.java    |   21 +-
 .../cache/tier/sockets/ChunkedMessage.java      |   21 +-
 .../tier/sockets/ClientBlacklistProcessor.java  |   21 +-
 .../sockets/ClientDataSerializerMessage.java    |   21 +-
 .../cache/tier/sockets/ClientHealthMonitor.java |   21 +-
 .../tier/sockets/ClientInstantiatorMessage.java |   20 +-
 .../tier/sockets/ClientInterestMessageImpl.java |   21 +-
 .../tier/sockets/ClientMarkerMessageImpl.java   |   21 +-
 .../cache/tier/sockets/ClientMessage.java       |   21 +-
 .../tier/sockets/ClientPingMessageImpl.java     |   21 +-
 .../tier/sockets/ClientProxyMembershipID.java   |   21 +-
 .../tier/sockets/ClientTombstoneMessage.java    |   21 +-
 .../cache/tier/sockets/ClientUpdateMessage.java |   21 +-
 .../tier/sockets/ClientUpdateMessageImpl.java   |   21 +-
 .../cache/tier/sockets/ClientUserAuths.java     |   21 +-
 .../cache/tier/sockets/CommandInitializer.java  |   21 +-
 .../cache/tier/sockets/ConnectionListener.java  |   21 +-
 .../tier/sockets/ConnectionListenerAdapter.java |   21 +-
 .../cache/tier/sockets/HAEventWrapper.java      |   21 +-
 .../internal/cache/tier/sockets/HandShake.java  |   21 +-
 .../tier/sockets/InterestResultPolicyImpl.java  |   21 +-
 .../internal/cache/tier/sockets/Message.java    |   21 +-
 .../cache/tier/sockets/MessageStats.java        |   21 +-
 .../cache/tier/sockets/ObjectPartList.java      |   21 +-
 .../cache/tier/sockets/ObjectPartList651.java   |   21 +-
 .../internal/cache/tier/sockets/Part.java       |   21 +-
 .../RemoveClientFromBlacklistMessage.java       |   23 +-
 .../tier/sockets/SerializedObjectPartList.java  |   21 +-
 .../cache/tier/sockets/ServerConnection.java    |   21 +-
 .../tier/sockets/ServerHandShakeProcessor.java  |   21 +-
 .../cache/tier/sockets/ServerQueueStatus.java   |   21 +-
 .../tier/sockets/ServerResponseMatrix.java      |   20 +-
 .../tier/sockets/UnregisterAllInterest.java     |   21 +-
 .../cache/tier/sockets/UserAuthAttributes.java  |   21 +-
 .../cache/tier/sockets/VersionedObjectList.java |   21 +-
 .../cache/tier/sockets/command/AddPdxEnum.java  |   21 +-
 .../cache/tier/sockets/command/AddPdxType.java  |   21 +-
 .../cache/tier/sockets/command/ClearRegion.java |   21 +-
 .../cache/tier/sockets/command/ClientReady.java |   21 +-
 .../tier/sockets/command/CloseConnection.java   |   21 +-
 .../tier/sockets/command/CommitCommand.java     |   21 +-
 .../cache/tier/sockets/command/ContainsKey.java |   21 +-
 .../tier/sockets/command/ContainsKey66.java     |   21 +-
 .../tier/sockets/command/CreateRegion.java      |   21 +-
 .../cache/tier/sockets/command/Default.java     |   21 +-
 .../cache/tier/sockets/command/Destroy.java     |   21 +-
 .../cache/tier/sockets/command/Destroy65.java   |   21 +-
 .../cache/tier/sockets/command/Destroy70.java   |   23 +-
 .../tier/sockets/command/DestroyRegion.java     |   21 +-
 .../tier/sockets/command/ExecuteFunction.java   |   21 +-
 .../tier/sockets/command/ExecuteFunction65.java |   20 +-
 .../tier/sockets/command/ExecuteFunction66.java |   20 +-
 .../tier/sockets/command/ExecuteFunction70.java |   21 +-
 .../sockets/command/ExecuteRegionFunction.java  |   20 +-
 .../command/ExecuteRegionFunction61.java        |   20 +-
 .../command/ExecuteRegionFunction65.java        |   20 +-
 .../command/ExecuteRegionFunction66.java        |   20 +-
 .../command/ExecuteRegionFunctionSingleHop.java |   21 +-
 .../sockets/command/GatewayReceiverCommand.java |   21 +-
 .../cache/tier/sockets/command/Get70.java       |   21 +-
 .../cache/tier/sockets/command/GetAll.java      |   21 +-
 .../cache/tier/sockets/command/GetAll651.java   |   21 +-
 .../cache/tier/sockets/command/GetAll70.java    |   23 +-
 .../cache/tier/sockets/command/GetAllForRI.java |   21 +-
 .../sockets/command/GetAllWithCallback.java     |   21 +-
 .../command/GetClientPRMetadataCommand.java     |   20 +-
 .../command/GetClientPRMetadataCommand66.java   |   20 +-
 .../GetClientPartitionAttributesCommand.java    |   20 +-
 .../GetClientPartitionAttributesCommand66.java  |   20 +-
 .../cache/tier/sockets/command/GetEntry70.java  |   23 +-
 .../tier/sockets/command/GetEntryCommand.java   |   21 +-
 .../sockets/command/GetFunctionAttribute.java   |   21 +-
 .../tier/sockets/command/GetPDXEnumById.java    |   21 +-
 .../tier/sockets/command/GetPDXIdForEnum.java   |   21 +-
 .../tier/sockets/command/GetPDXIdForType.java   |   21 +-
 .../tier/sockets/command/GetPDXTypeById.java    |   21 +-
 .../tier/sockets/command/GetPdxEnums70.java     |   21 +-
 .../tier/sockets/command/GetPdxTypes70.java     |   21 +-
 .../cache/tier/sockets/command/Invalid.java     |   21 +-
 .../cache/tier/sockets/command/Invalidate.java  |   21 +-
 .../tier/sockets/command/Invalidate70.java      |   23 +-
 .../cache/tier/sockets/command/KeySet.java      |   21 +-
 .../cache/tier/sockets/command/MakePrimary.java |   21 +-
 .../tier/sockets/command/ManagementCommand.java |   21 +-
 .../cache/tier/sockets/command/PeriodicAck.java |   21 +-
 .../cache/tier/sockets/command/Ping.java        |   21 +-
 .../cache/tier/sockets/command/Put.java         |   21 +-
 .../cache/tier/sockets/command/Put61.java       |   21 +-
 .../cache/tier/sockets/command/Put65.java       |   21 +-
 .../cache/tier/sockets/command/Put70.java       |   21 +-
 .../cache/tier/sockets/command/PutAll.java      |   21 +-
 .../cache/tier/sockets/command/PutAll70.java    |   21 +-
 .../cache/tier/sockets/command/PutAll80.java    |   21 +-
 .../sockets/command/PutAllWithCallback.java     |   21 +-
 .../sockets/command/PutUserCredentials.java     |   21 +-
 .../cache/tier/sockets/command/Query.java       |   21 +-
 .../cache/tier/sockets/command/Query651.java    |   21 +-
 .../command/RegisterDataSerializers.java        |   21 +-
 .../sockets/command/RegisterInstantiators.java  |   21 +-
 .../tier/sockets/command/RegisterInterest.java  |   21 +-
 .../sockets/command/RegisterInterest61.java     |   21 +-
 .../sockets/command/RegisterInterestList.java   |   21 +-
 .../sockets/command/RegisterInterestList61.java |   21 +-
 .../sockets/command/RegisterInterestList66.java |   21 +-
 .../cache/tier/sockets/command/RemoveAll.java   |   21 +-
 .../tier/sockets/command/RemoveUserAuth.java    |   21 +-
 .../cache/tier/sockets/command/Request.java     |   21 +-
 .../tier/sockets/command/RequestEventValue.java |   20 +-
 .../tier/sockets/command/RollbackCommand.java   |   21 +-
 .../cache/tier/sockets/command/Size.java        |   21 +-
 .../tier/sockets/command/TXFailoverCommand.java |   21 +-
 .../command/TXSynchronizationCommand.java       |   21 +-
 .../sockets/command/UnregisterInterest.java     |   21 +-
 .../sockets/command/UnregisterInterestList.java |   21 +-
 .../command/UpdateClientNotification.java       |   21 +-
 .../cache/tx/AbstractPeerTXRegionStub.java      |   21 +-
 .../internal/cache/tx/ClientTXRegionStub.java   |   21 +-
 .../internal/cache/tx/ClientTXStateStub.java    |   21 +-
 .../cache/tx/DistClientTXStateStub.java         |   19 +-
 .../internal/cache/tx/DistTxEntryEvent.java     |   16 +
 .../internal/cache/tx/DistTxKeyInfo.java        |   18 +-
 .../cache/tx/DistributedTXRegionStub.java       |   21 +-
 .../cache/tx/PartitionedTXRegionStub.java       |   21 +-
 .../gemfire/internal/cache/tx/TXRegionStub.java |   21 +-
 .../cache/tx/TransactionalOperation.java        |   24 +-
 .../cache/versions/CompactVersionHolder.java    |   21 +-
 .../ConcurrentCacheModificationException.java   |   23 +-
 .../cache/versions/DiskRegionVersionVector.java |   21 +-
 .../internal/cache/versions/DiskVersionTag.java |   21 +-
 .../internal/cache/versions/RVVException.java   |   21 +-
 .../internal/cache/versions/RVVExceptionB.java  |   23 +-
 .../internal/cache/versions/RVVExceptionT.java  |   23 +-
 .../cache/versions/RegionVersionHolder.java     |   21 +-
 .../cache/versions/RegionVersionVector.java     |   21 +-
 .../cache/versions/VMRegionVersionVector.java   |   21 +-
 .../internal/cache/versions/VMVersionTag.java   |   21 +-
 .../internal/cache/versions/VersionHolder.java  |   21 +-
 .../internal/cache/versions/VersionSource.java  |   21 +-
 .../internal/cache/versions/VersionStamp.java   |   21 +-
 .../internal/cache/versions/VersionTag.java     |   21 +-
 .../internal/cache/vmotion/VMotionObserver.java |   20 +-
 .../cache/vmotion/VMotionObserverAdapter.java   |   20 +-
 .../cache/vmotion/VMotionObserverHolder.java    |   20 +-
 .../cache/wan/AbstractGatewaySender.java        |   20 +-
 .../AbstractGatewaySenderEventProcessor.java    |   21 +-
 .../AsyncEventQueueConfigurationException.java  |   21 +-
 .../internal/cache/wan/BatchException70.java    |   21 +-
 .../cache/wan/DistributedSystemListener.java    |   16 +
 .../cache/wan/GatewayEventFilterImpl.java       |   21 +-
 .../cache/wan/GatewayReceiverException.java     |   21 +-
 .../cache/wan/GatewayReceiverStats.java         |   21 +-
 .../cache/wan/GatewaySenderAdvisor.java         |   21 +-
 .../cache/wan/GatewaySenderAttributes.java      |   21 +-
 .../GatewaySenderConfigurationException.java    |   21 +-
 .../wan/GatewaySenderEventCallbackArgument.java |   20 +-
 .../GatewaySenderEventCallbackDispatcher.java   |   20 +-
 .../cache/wan/GatewaySenderEventDispatcher.java |   21 +-
 .../cache/wan/GatewaySenderEventImpl.java       |   20 +-
 .../cache/wan/GatewaySenderException.java       |   21 +-
 .../internal/cache/wan/GatewaySenderStats.java  |   21 +-
 .../cache/wan/InternalGatewaySenderFactory.java |   16 +
 .../cache/wan/TransportFilterServerSocket.java  |   21 +-
 .../cache/wan/TransportFilterSocket.java        |   21 +-
 .../cache/wan/TransportFilterSocketFactory.java |   21 +-
 .../internal/cache/wan/WANServiceProvider.java  |   16 +
 .../BucketRegionQueueUnavailableException.java  |   16 +
 ...rentParallelGatewaySenderEventProcessor.java |   21 +-
 .../ConcurrentParallelGatewaySenderQueue.java   |   21 +-
 .../ParallelGatewaySenderEventProcessor.java    |   21 +-
 .../parallel/ParallelGatewaySenderQueue.java    |   21 +-
 .../ParallelQueueBatchRemovalMessage.java       |   21 +-
 .../parallel/ParallelQueueRemovalMessage.java   |   21 +-
 .../cache/wan/parallel/RREventIDResolver.java   |   21 +-
 .../cache/wan/serial/BatchDestroyOperation.java |   21 +-
 ...urrentSerialGatewaySenderEventProcessor.java |   21 +-
 .../SerialGatewaySenderEventProcessor.java      |   20 +-
 .../wan/serial/SerialGatewaySenderQueue.java    |   21 +-
 .../serial/SerialSecondaryGatewayListener.java  |   21 +-
 .../internal/cache/wan/spi/WANFactory.java      |   16 +
 .../cache/xmlcache/AbstractXmlParser.java       |   21 +-
 .../cache/xmlcache/AsyncEventQueueCreation.java |   21 +-
 .../cache/xmlcache/BindingCreation.java         |   21 +-
 .../internal/cache/xmlcache/CacheCreation.java  |   32 +-
 .../cache/xmlcache/CacheServerCreation.java     |   45 +-
 .../CacheTransactionManagerCreation.java        |   21 +-
 .../internal/cache/xmlcache/CacheXml.java       |   21 +-
 .../cache/xmlcache/CacheXmlGenerator.java       |   25 +-
 .../internal/cache/xmlcache/CacheXmlParser.java |   27 +-
 .../xmlcache/CacheXmlPropertyResolver.java      |   21 +-
 .../CacheXmlPropertyResolverHelper.java         |   21 +-
 .../cache/xmlcache/CacheXmlVersion.java         |   17 +-
 .../cache/xmlcache/ClientCacheCreation.java     |   21 +-
 .../cache/xmlcache/ClientHaQueueCreation.java   |   21 +-
 .../internal/cache/xmlcache/Declarable2.java    |   21 +-
 .../cache/xmlcache/DefaultEntityResolver2.java  |   21 +-
 .../xmlcache/DiskStoreAttributesCreation.java   |   21 +-
 .../cache/xmlcache/FunctionServiceCreation.java |   21 +-
 .../cache/xmlcache/GatewayReceiverCreation.java |   21 +-
 .../cache/xmlcache/IndexCreationData.java       |   21 +-
 .../ParallelAsyncEventQueueCreation.java        |   21 +-
 .../xmlcache/ParallelGatewaySenderCreation.java |   21 +-
 .../cache/xmlcache/PivotalEntityResolver.java   |   21 +-
 .../cache/xmlcache/PropertyResolver.java        |   21 +-
 .../xmlcache/RegionAttributesCreation.java      |   21 +-
 .../internal/cache/xmlcache/RegionCreation.java |   21 +-
 .../cache/xmlcache/ResourceManagerCreation.java |   21 +-
 .../xmlcache/SerialAsyncEventQueueCreation.java |   21 +-
 .../xmlcache/SerialGatewaySenderCreation.java   |   21 +-
 .../cache/xmlcache/SerializerCreation.java      |   21 +-
 .../internal/cache/xmlcache/XmlGenerator.java   |   21 +-
 .../cache/xmlcache/XmlGeneratorUtils.java       |   21 +-
 .../internal/cache/xmlcache/XmlParser.java      |   21 +-
 .../gemfire/internal/concurrent/AL.java         |   21 +-
 .../internal/concurrent/AtomicLong5.java        |   21 +-
 .../gemfire/internal/concurrent/Atomics.java    |   21 +-
 .../concurrent/CompactConcurrentHashSet2.java   |   16 +
 .../internal/concurrent/ConcurrentHashSet.java  |   21 +-
 .../gemfire/internal/concurrent/LI.java         |   21 +-
 .../internal/concurrent/MapCallback.java        |   21 +-
 .../internal/concurrent/MapCallbackAdapter.java |   21 +-
 .../gemfire/internal/concurrent/MapResult.java  |   21 +-
 .../internal/datasource/AbstractDataSource.java |   21 +-
 .../internal/datasource/AbstractPoolCache.java  |   21 +-
 .../ClientConnectionFactoryWrapper.java         |   21 +-
 .../internal/datasource/ConfigProperty.java     |   21 +-
 .../ConfiguredDataSourceProperties.java         |   21 +-
 .../ConnectionEventListenerAdaptor.java         |   21 +-
 .../datasource/ConnectionPoolCache.java         |   21 +-
 .../datasource/ConnectionPoolCacheImpl.java     |   21 +-
 .../internal/datasource/ConnectionProvider.java |   21 +-
 .../datasource/ConnectionProviderException.java |   21 +-
 .../datasource/DataSourceCreateException.java   |   21 +-
 .../internal/datasource/DataSourceFactory.java  |   21 +-
 .../datasource/DataSourceResources.java         |   21 +-
 .../FacetsJCAConnectionManagerImpl.java         |   21 +-
 .../datasource/GemFireBasicDataSource.java      |   21 +-
 .../datasource/GemFireConnPooledDataSource.java |   21 +-
 .../GemFireConnectionPoolManager.java           |   21 +-
 .../GemFireTransactionDataSource.java           |   21 +-
 .../datasource/JCAConnectionManagerImpl.java    |   21 +-
 .../datasource/ManagedPoolCacheImpl.java        |   21 +-
 .../internal/datasource/PoolException.java      |   21 +-
 .../internal/datasource/TranxPoolCacheImpl.java |   21 +-
 .../i18n/AbstractStringIdResourceBundle.java    |   21 +-
 .../gemfire/internal/i18n/LocalizedStrings.java |   23 +-
 .../internal/i18n/ParentLocalizedStrings.java   |   21 +-
 .../internal/io/CompositeOutputStream.java      |   21 +-
 .../internal/io/CompositePrintStream.java       |   21 +-
 .../gemfire/internal/io/TeeOutputStream.java    |   21 +-
 .../gemfire/internal/io/TeePrintStream.java     |   21 +-
 .../gemfire/internal/jndi/ContextImpl.java      |   21 +-
 .../jndi/InitialContextFactoryImpl.java         |   21 +-
 .../gemfire/internal/jndi/JNDIInvoker.java      |   21 +-
 .../gemfire/internal/jndi/NameParserImpl.java   |   21 +-
 .../gemfire/internal/jta/GlobalTransaction.java |   21 +-
 .../gemfire/internal/jta/TransactionImpl.java   |   21 +-
 .../internal/jta/TransactionManagerImpl.java    |   21 +-
 .../gemfire/internal/jta/TransactionUtils.java  |   21 +-
 .../internal/jta/UserTransactionImpl.java       |   21 +-
 .../gemstone/gemfire/internal/jta/XidImpl.java  |   21 +-
 .../gemfire/internal/lang/ClassUtils.java       |   20 +-
 .../gemstone/gemfire/internal/lang/Filter.java  |   18 +-
 .../gemfire/internal/lang/InOutParameter.java   |   20 +-
 .../gemfire/internal/lang/Initable.java         |   20 +-
 .../gemfire/internal/lang/Initializer.java      |   21 +-
 .../internal/lang/MutableIdentifiable.java      |   24 +-
 .../gemfire/internal/lang/ObjectUtils.java      |   20 +-
 .../gemfire/internal/lang/Orderable.java        |   20 +-
 .../gemstone/gemfire/internal/lang/Ordered.java |   20 +-
 .../gemfire/internal/lang/StringUtils.java      |   20 +-
 .../gemfire/internal/lang/SystemUtils.java      |   20 +-
 .../gemfire/internal/lang/ThreadUtils.java      |   20 +-
 .../gemfire/internal/logging/DateFormatter.java |   16 +
 .../internal/logging/DebugLogWriter.java        |   21 +-
 .../internal/logging/GemFireFormatter.java      |   21 +-
 .../internal/logging/GemFireHandler.java        |   21 +-
 .../gemfire/internal/logging/GemFireLevel.java  |   21 +-
 .../internal/logging/InternalLogWriter.java     |   16 +
 .../internal/logging/LocalLogWriter.java        |   21 +-
 .../gemfire/internal/logging/LogConfig.java     |   16 +
 .../gemfire/internal/logging/LogFileParser.java |   21 +-
 .../gemfire/internal/logging/LogService.java    |  149 +-
 .../internal/logging/LogWriterFactory.java      |   16 +
 .../gemfire/internal/logging/LogWriterImpl.java |   21 +-
 .../internal/logging/LoggingThreadGroup.java    |   16 +
 .../internal/logging/ManagerLogWriter.java      |   21 +-
 .../gemfire/internal/logging/MergeLogFiles.java |   21 +-
 .../gemfire/internal/logging/PureLogWriter.java |   21 +-
 .../logging/SecurityLocalLogWriter.java         |   21 +-
 .../internal/logging/SecurityLogConfig.java     |   16 +
 .../internal/logging/SecurityLogWriter.java     |   21 +-
 .../logging/SecurityManagerLogWriter.java       |   21 +-
 .../gemfire/internal/logging/SortLogFile.java   |   21 +-
 .../internal/logging/StandardErrorPrinter.java  |   16 +
 .../internal/logging/StandardOutputPrinter.java |   16 +
 .../internal/logging/log4j/AlertAppender.java   |   16 +
 .../internal/logging/log4j/AppenderContext.java |   16 +
 .../internal/logging/log4j/ConfigLocator.java   |   16 +
 .../internal/logging/log4j/Configurator.java    |   21 +
 .../internal/logging/log4j/FastLogger.java      |   16 +
 .../internal/logging/log4j/GemFireLogger.java   |   16 +
 .../logging/log4j/LocalizedMessage.java         |   16 +
 .../internal/logging/log4j/LogMarker.java       |   16 +
 .../logging/log4j/LogWriterAppender.java        |   18 +-
 .../logging/log4j/LogWriterAppenders.java       |   16 +
 .../internal/logging/log4j/LogWriterLogger.java |   16 +
 .../logging/log4j/ThreadIdPatternConverter.java |   16 +
 .../gemfire/internal/memcached/Command.java     |   21 +-
 .../internal/memcached/CommandProcessor.java    |   21 +-
 .../internal/memcached/ConnectionHandler.java   |   21 +-
 .../gemfire/internal/memcached/KeyWrapper.java  |   21 +-
 .../gemfire/internal/memcached/Reply.java       |   21 +-
 .../internal/memcached/RequestReader.java       |   21 +-
 .../internal/memcached/ResponseStatus.java      |   21 +-
 .../internal/memcached/ValueWrapper.java        |   21 +-
 .../memcached/commands/AbstractCommand.java     |   21 +-
 .../internal/memcached/commands/AddCommand.java |   21 +-
 .../memcached/commands/AddQCommand.java         |   16 +
 .../memcached/commands/AppendCommand.java       |   21 +-
 .../memcached/commands/AppendQCommand.java      |   16 +
 .../internal/memcached/commands/CASCommand.java |   21 +-
 .../memcached/commands/ClientError.java         |   21 +-
 .../memcached/commands/DecrementCommand.java    |   21 +-
 .../memcached/commands/DecrementQCommand.java   |   16 +
 .../memcached/commands/DeleteCommand.java       |   21 +-
 .../memcached/commands/DeleteQCommand.java      |   16 +
 .../memcached/commands/FlushAllCommand.java     |   21 +-
 .../memcached/commands/FlushAllQCommand.java    |   16 +
 .../internal/memcached/commands/GATCommand.java |   16 +
 .../memcached/commands/GATQCommand.java         |   16 +
 .../internal/memcached/commands/GetCommand.java |   21 +-
 .../memcached/commands/GetKCommand.java         |   16 +
 .../memcached/commands/GetKQCommand.java        |   16 +
 .../memcached/commands/GetQCommand.java         |   21 +-
 .../memcached/commands/IncrementCommand.java    |   21 +-
 .../memcached/commands/IncrementQCommand.java   |   16 +
 .../memcached/commands/NoOpCommand.java         |   21 +-
 .../memcached/commands/NotSupportedCommand.java |   21 +-
 .../memcached/commands/PrependCommand.java      |   21 +-
 .../memcached/commands/PrependQCommand.java     |   16 +
 .../memcached/commands/QuitCommand.java         |   21 +-
 .../memcached/commands/QuitQCommand.java        |   16 +
 .../memcached/commands/ReplaceCommand.java      |   21 +-
 .../memcached/commands/ReplaceQCommand.java     |   16 +
 .../internal/memcached/commands/SetCommand.java |   21 +-
 .../memcached/commands/SetQCommand.java         |   16 +
 .../memcached/commands/StatsCommand.java        |   21 +-
 .../memcached/commands/StorageCommand.java      |   21 +-
 .../memcached/commands/TouchCommand.java        |   21 +-
 .../memcached/commands/VerbosityCommand.java    |   21 +-
 .../memcached/commands/VersionCommand.java      |   21 +-
 .../modules/util/RegionConfiguration.java       |   21 +-
 .../gemfire/internal/net/SocketUtils.java       |   20 +-
 .../internal/offheap/ByteArrayMemoryChunk.java  |   16 +
 .../internal/offheap/ByteBufferMemoryChunk.java |   16 +
 .../gemfire/internal/offheap/DataType.java      |   16 +
 .../internal/offheap/MemoryAllocator.java       |   16 +
 .../gemfire/internal/offheap/MemoryBlock.java   |   16 +
 .../gemfire/internal/offheap/MemoryChunk.java   |   16 +
 .../offheap/MemoryChunkWithRefCount.java        |   16 +
 .../internal/offheap/MemoryInspector.java       |   16 +
 .../internal/offheap/MemoryUsageListener.java   |   16 +
 .../offheap/OffHeapCachedDeserializable.java    |   16 +
 .../gemfire/internal/offheap/OffHeapHelper.java |   16 +
 .../internal/offheap/OffHeapMemoryStats.java    |   16 +
 .../internal/offheap/OffHeapReference.java      |   18 +-
 .../offheap/OffHeapRegionEntryHelper.java       |   16 +
 .../internal/offheap/OffHeapStorage.java        |   16 +
 .../offheap/OutOfOffHeapMemoryListener.java     |   16 +
 .../gemfire/internal/offheap/Releasable.java    |   16 +
 .../offheap/SimpleMemoryAllocatorImpl.java      |   18 +-
 .../gemfire/internal/offheap/StoredObject.java  |   16 +
 .../internal/offheap/UnsafeMemoryChunk.java     |   16 +
 .../offheap/annotations/OffHeapIdentifier.java  |   16 +
 .../internal/offheap/annotations/Released.java  |   16 +
 .../internal/offheap/annotations/Retained.java  |   16 +
 .../offheap/annotations/Unretained.java         |   16 +
 .../internal/process/AttachProcessUtils.java    |   16 +
 .../process/BlockingProcessStreamReader.java    |   16 +
 ...usterConfigurationNotAvailableException.java |   16 +
 .../process/ConnectionFailedException.java      |   21 +-
 .../internal/process/ControlFileWatchdog.java   |   16 +
 .../process/ControlNotificationHandler.java     |   16 +
 .../internal/process/ControllableProcess.java   |   16 +
 .../process/FileAlreadyExistsException.java     |   21 +-
 .../process/FileControllerParameters.java       |   16 +
 .../internal/process/FileProcessController.java |   16 +
 .../process/LocalProcessController.java         |   21 +-
 .../internal/process/LocalProcessLauncher.java  |   21 +-
 .../process/MBeanControllerParameters.java      |   16 +
 .../process/MBeanInvocationFailedException.java |   21 +-
 .../process/MBeanProcessController.java         |   16 +
 .../internal/process/NativeProcessUtils.java    |   16 +
 .../process/NonBlockingProcessStreamReader.java |   16 +
 .../gemfire/internal/process/PidFile.java       |   16 +
 .../process/PidUnavailableException.java        |   21 +-
 .../internal/process/ProcessController.java     |   16 +
 .../process/ProcessControllerFactory.java       |   16 +
 .../process/ProcessControllerParameters.java    |   16 +
 .../process/ProcessLauncherContext.java         |   21 +-
 .../internal/process/ProcessStreamReader.java   |   21 +-
 .../ProcessTerminatedAbnormallyException.java   |   20 +-
 .../gemfire/internal/process/ProcessType.java   |   16 +
 .../gemfire/internal/process/ProcessUtils.java  |   21 +-
 .../gemfire/internal/process/StartupStatus.java |   16 +
 .../internal/process/StartupStatusListener.java |   16 +
 .../UnableToControlProcessException.java        |   16 +
 .../AbstractSignalNotificationHandler.java      |   20 +-
 .../gemfire/internal/process/signal/Signal.java |   20 +-
 .../internal/process/signal/SignalEvent.java    |   20 +-
 .../internal/process/signal/SignalListener.java |   20 +-
 .../internal/process/signal/SignalType.java     |   20 +-
 .../internal/redis/ByteArrayWrapper.java        |   16 +
 .../internal/redis/ByteToCommandDecoder.java    |   16 +
 .../gemstone/gemfire/internal/redis/Coder.java  |   16 +
 .../gemfire/internal/redis/Command.java         |   16 +
 .../gemfire/internal/redis/DoubleWrapper.java   |   16 +
 .../internal/redis/ExecutionHandlerContext.java |   16 +
 .../gemfire/internal/redis/Executor.java        |   16 +
 .../gemfire/internal/redis/Extendable.java      |   16 +
 .../redis/RedisCommandParserException.java      |   16 +
 .../internal/redis/RedisCommandType.java        |   16 +
 .../gemfire/internal/redis/RedisConstants.java  |   16 +
 .../gemfire/internal/redis/RedisDataType.java   |   18 +-
 .../redis/RedisDataTypeMismatchException.java   |   16 +
 .../internal/redis/RegionCreationException.java |   16 +
 .../gemfire/internal/redis/RegionProvider.java  |   18 +-
 .../redis/executor/AbstractExecutor.java        |   16 +
 .../redis/executor/AbstractScanExecutor.java    |   16 +
 .../internal/redis/executor/AuthExecutor.java   |   16 +
 .../internal/redis/executor/DBSizeExecutor.java |   16 +
 .../internal/redis/executor/DelExecutor.java    |   16 +
 .../internal/redis/executor/EchoExecutor.java   |   16 +
 .../internal/redis/executor/ExistsExecutor.java |   16 +
 .../redis/executor/ExpirationExecutor.java      |   16 +
 .../redis/executor/ExpireAtExecutor.java        |   16 +
 .../internal/redis/executor/ExpireExecutor.java |   16 +
 .../redis/executor/FlushAllExecutor.java        |   16 +
 .../internal/redis/executor/KeysExecutor.java   |   16 +
 .../internal/redis/executor/ListQuery.java      |   16 +
 .../redis/executor/PExpireAtExecutor.java       |   16 +
 .../redis/executor/PExpireExecutor.java         |   16 +
 .../internal/redis/executor/PTTLExecutor.java   |   16 +
 .../redis/executor/PersistExecutor.java         |   16 +
 .../internal/redis/executor/PingExecutor.java   |   16 +
 .../internal/redis/executor/QuitExecutor.java   |   16 +
 .../internal/redis/executor/ScanExecutor.java   |   16 +
 .../redis/executor/ShutDownExecutor.java        |   16 +
 .../internal/redis/executor/SortedSetQuery.java |   16 +
 .../internal/redis/executor/TTLExecutor.java    |   16 +
 .../internal/redis/executor/TimeExecutor.java   |   16 +
 .../internal/redis/executor/TypeExecutor.java   |   16 +
 .../internal/redis/executor/UnkownExecutor.java |   16 +
 .../redis/executor/hash/HDelExecutor.java       |   16 +
 .../redis/executor/hash/HExistsExecutor.java    |   16 +
 .../redis/executor/hash/HGetAllExecutor.java    |   16 +
 .../redis/executor/hash/HGetExecutor.java       |   16 +
 .../redis/executor/hash/HIncrByExecutor.java    |   16 +
 .../executor/hash/HIncrByFloatExecutor.java     |   16 +
 .../redis/executor/hash/HKeysExecutor.java      |   16 +
 .../redis/executor/hash/HLenExecutor.java       |   16 +
 .../redis/executor/hash/HMGetExecutor.java      |   16 +
 .../redis/executor/hash/HMSetExecutor.java      |   16 +
 .../redis/executor/hash/HScanExecutor.java      |   16 +
 .../redis/executor/hash/HSetExecutor.java       |   16 +
 .../redis/executor/hash/HSetNXExecutor.java     |   16 +
 .../redis/executor/hash/HValsExecutor.java      |   16 +
 .../redis/executor/hash/HashExecutor.java       |   18 +-
 .../internal/redis/executor/hll/Bits.java       |   16 +
 .../executor/hll/CardinalityMergeException.java |   18 +-
 .../redis/executor/hll/HllExecutor.java         |   16 +
 .../redis/executor/hll/HyperLogLog.java         |   16 +
 .../redis/executor/hll/HyperLogLogPlus.java     |   18 +-
 .../internal/redis/executor/hll/IBuilder.java   |   18 +-
 .../redis/executor/hll/ICardinality.java        |   16 +
 .../internal/redis/executor/hll/MurmurHash.java |   18 +-
 .../redis/executor/hll/PFAddExecutor.java       |   16 +
 .../redis/executor/hll/PFCountExecutor.java     |   16 +
 .../redis/executor/hll/PFMergeExecutor.java     |   16 +
 .../redis/executor/hll/RegisterSet.java         |   18 +-
 .../internal/redis/executor/hll/Varint.java     |   18 +-
 .../redis/executor/list/LIndexExecutor.java     |   16 +
 .../redis/executor/list/LInsertExecutor.java    |   16 +
 .../redis/executor/list/LLenExecutor.java       |   16 +
 .../redis/executor/list/LPopExecutor.java       |   16 +
 .../redis/executor/list/LPushExecutor.java      |   16 +
 .../redis/executor/list/LPushXExecutor.java     |   16 +
 .../redis/executor/list/LRangeExecutor.java     |   16 +
 .../redis/executor/list/LRemExecutor.java       |   16 +
 .../redis/executor/list/LSetExecutor.java       |   16 +
 .../redis/executor/list/LTrimExecutor.java      |   16 +
 .../redis/executor/list/ListExecutor.java       |   16 +
 .../redis/executor/list/PopExecutor.java        |   16 +
 .../redis/executor/list/PushExecutor.java       |   16 +
 .../redis/executor/list/PushXExecutor.java      |   16 +
 .../redis/executor/list/RPopExecutor.java       |   16 +
 .../redis/executor/list/RPushExecutor.java      |   16 +
 .../redis/executor/list/RPushXExecutor.java     |   16 +
 .../redis/executor/set/SAddExecutor.java        |   16 +
 .../redis/executor/set/SCardExecutor.java       |   16 +
 .../redis/executor/set/SDiffExecutor.java       |   16 +
 .../redis/executor/set/SDiffStoreExecutor.java  |   16 +
 .../redis/executor/set/SInterExecutor.java      |   16 +
 .../redis/executor/set/SInterStoreExecutor.java |   16 +
 .../redis/executor/set/SIsMemberExecutor.java   |   16 +
 .../redis/executor/set/SMembersExecutor.java    |   16 +
 .../redis/executor/set/SMoveExecutor.java       |   16 +
 .../redis/executor/set/SPopExecutor.java        |   16 +
 .../redis/executor/set/SRandMemberExecutor.java |   16 +
 .../redis/executor/set/SRemExecutor.java        |   16 +
 .../redis/executor/set/SScanExecutor.java       |   16 +
 .../redis/executor/set/SUnionExecutor.java      |   16 +
 .../redis/executor/set/SUnionStoreExecutor.java |   16 +
 .../redis/executor/set/SetExecutor.java         |   16 +
 .../redis/executor/set/SetOpExecutor.java       |   16 +
 .../executor/sortedset/SortedSetExecutor.java   |   16 +
 .../redis/executor/sortedset/ZAddExecutor.java  |   16 +
 .../redis/executor/sortedset/ZCardExecutor.java |   16 +
 .../executor/sortedset/ZCountExecutor.java      |   16 +
 .../executor/sortedset/ZIncrByExecutor.java     |   16 +
 .../executor/sortedset/ZLexCountExecutor.java   |   16 +
 .../executor/sortedset/ZRangeByLexExecutor.java |   16 +
 .../sortedset/ZRangeByScoreExecutor.java        |   16 +
 .../executor/sortedset/ZRangeExecutor.java      |   16 +
 .../redis/executor/sortedset/ZRankExecutor.java |   16 +
 .../redis/executor/sortedset/ZRemExecutor.java  |   16 +
 .../sortedset/ZRemRangeByLexExecutor.java       |   16 +
 .../sortedset/ZRemRangeByRankExecutor.java      |   16 +
 .../sortedset/ZRemRangeByScoreExecutor.java     |   16 +
 .../sortedset/ZRevRangeByScoreExecutor.java     |   16 +
 .../executor/sortedset/ZRevRangeExecutor.java   |   16 +
 .../executor/sortedset/ZRevRankExecutor.java    |   16 +
 .../redis/executor/sortedset/ZScanExecutor.java |   16 +
 .../executor/sortedset/ZScoreExecutor.java      |   16 +
 .../redis/executor/string/AppendExecutor.java   |   16 +
 .../redis/executor/string/BitCountExecutor.java |   16 +
 .../redis/executor/string/BitOpExecutor.java    |   16 +
 .../redis/executor/string/BitPosExecutor.java   |   16 +
 .../redis/executor/string/DecrByExecutor.java   |   16 +
 .../redis/executor/string/DecrExecutor.java     |   16 +
 .../redis/executor/string/GetBitExecutor.java   |   16 +
 .../redis/executor/string/GetExecutor.java      |   16 +
 .../redis/executor/string/GetRangeExecutor.java |   16 +
 .../redis/executor/string/GetSetExecutor.java   |   16 +
 .../redis/executor/string/IncrByExecutor.java   |   16 +
 .../executor/string/IncrByFloatExecutor.java    |   16 +
 .../redis/executor/string/IncrExecutor.java     |   16 +
 .../redis/executor/string/MGetExecutor.java     |   16 +
 .../redis/executor/string/MSetExecutor.java     |   16 +
 .../redis/executor/string/MSetNXExecutor.java   |   16 +
 .../redis/executor/string/PSetEXExecutor.java   |   16 +
 .../redis/executor/string/SetBitExecutor.java   |   16 +
 .../redis/executor/string/SetEXExecutor.java    |   16 +
 .../redis/executor/string/SetExecutor.java      |   16 +
 .../redis/executor/string/SetNXExecutor.java    |   16 +
 .../redis/executor/string/SetRangeExecutor.java |   16 +
 .../redis/executor/string/StringExecutor.java   |   18 +-
 .../redis/executor/string/StrlenExecutor.java   |   16 +
 .../executor/transactions/DiscardExecutor.java  |   16 +
 .../executor/transactions/ExecExecutor.java     |   16 +
 .../executor/transactions/MultiExecutor.java    |   16 +
 .../transactions/TransactionExecutor.java       |   16 +
 .../executor/transactions/UnwatchExecutor.java  |   16 +
 .../executor/transactions/WatchExecutor.java    |   16 +
 .../internal/security/AuthorizeRequest.java     |   21 +-
 .../internal/security/AuthorizeRequestPP.java   |   21 +-
 .../security/FilterPostAuthorization.java       |   21 +-
 .../security/FilterPreAuthorization.java        |   21 +-
 .../internal/security/ObjectWithAuthz.java      |   21 +-
 .../internal/sequencelog/EntryLogger.java       |   23 +-
 .../gemfire/internal/sequencelog/GraphType.java |   21 +-
 .../internal/sequencelog/MembershipLogger.java  |   21 +-
 .../internal/sequencelog/MessageLogger.java     |   21 +-
 .../internal/sequencelog/RegionLogger.java      |   21 +-
 .../internal/sequencelog/SequenceLogger.java    |   21 +-
 .../sequencelog/SequenceLoggerImpl.java         |   21 +-
 .../internal/sequencelog/Transition.java        |   21 +-
 .../gemfire/internal/sequencelog/io/Filter.java |   21 +-
 .../sequencelog/io/GemfireLogConverter.java     |   21 +-
 .../internal/sequencelog/io/GraphReader.java    |   21 +-
 .../sequencelog/io/InputStreamReader.java       |   21 +-
 .../sequencelog/io/OutputStreamAppender.java    |   21 +-
 .../internal/sequencelog/model/Edge.java        |   23 +-
 .../internal/sequencelog/model/Graph.java       |   21 +-
 .../internal/sequencelog/model/GraphID.java     |   21 +-
 .../sequencelog/model/GraphReaderCallback.java  |   23 +-
 .../internal/sequencelog/model/GraphSet.java    |   21 +-
 .../internal/sequencelog/model/Vertex.java      |   21 +-
 .../visualization/text/TextDisplay.java         |   21 +-
 .../gemfire/internal/shared/NativeCalls.java    |   21 +-
 .../internal/shared/NativeCallsJNAImpl.java     |   21 +-
 .../internal/shared/NativeErrorException.java   |   21 +-
 .../gemfire/internal/shared/OSType.java         |   21 +-
 .../internal/shared/StringPrintWriter.java      |   21 +-
 .../internal/shared/TCPSocketOptions.java       |   21 +-
 .../internal/size/CachingSingleObjectSizer.java |   21 +-
 .../size/InstrumentationSingleObjectSizer.java  |   21 +-
 .../gemfire/internal/size/ObjectGraphSizer.java |   28 +-
 .../gemfire/internal/size/ObjectTraverser.java  |   28 +-
 .../internal/size/ReflectionObjectSizer.java    |   21 +-
 .../size/ReflectionSingleObjectSizer.java       |   21 +-
 .../internal/size/SingleObjectSizer.java        |   16 +
 .../internal/size/SizeClassOnceObjectSizer.java |   21 +-
 .../gemfire/internal/size/SizeOfUtil0.java      |   21 +-
 .../internal/size/WellKnownClassSizer.java      |   21 +-
 .../internal/statistics/CounterMonitor.java     |   21 +-
 .../internal/statistics/GaugeMonitor.java       |   21 +-
 .../statistics/IgnoreResourceException.java     |   21 +-
 .../MapBasedStatisticsNotification.java         |   21 +-
 .../internal/statistics/ResourceInstance.java   |   21 +-
 .../internal/statistics/ResourceType.java       |   21 +-
 .../internal/statistics/SampleCollector.java    |   21 +-
 .../internal/statistics/SampleHandler.java      |   21 +-
 .../internal/statistics/SimpleStatisticId.java  |   21 +-
 .../statistics/StatArchiveDescriptor.java       |   21 +-
 .../internal/statistics/StatArchiveHandler.java |   21 +-
 .../statistics/StatArchiveHandlerConfig.java    |   21 +-
 .../internal/statistics/StatMonitorHandler.java |   21 +-
 .../internal/statistics/StatisticId.java        |   21 +-
 .../statistics/StatisticNotFoundException.java  |   21 +-
 .../internal/statistics/StatisticsListener.java |   23 +-
 .../internal/statistics/StatisticsMonitor.java  |   21 +-
 .../statistics/StatisticsNotification.java      |   21 +-
 .../internal/statistics/StatisticsSampler.java  |   21 +-
 .../internal/statistics/ValueMonitor.java       |   21 +-
 .../stats50/Atomic50StatisticsImpl.java         |   21 +-
 .../gemfire/internal/stats50/VMStats50.java     |   21 +-
 .../gemfire/internal/tcp/BaseMsgStreamer.java   |   21 +-
 .../gemstone/gemfire/internal/tcp/Buffers.java  |   21 +-
 .../internal/tcp/ByteBufferInputStream.java     |   21 +-
 .../gemfire/internal/tcp/ConnectExceptions.java |   21 +-
 .../gemfire/internal/tcp/Connection.java        |   21 +-
 .../internal/tcp/ConnectionException.java       |   21 +-
 .../gemfire/internal/tcp/ConnectionTable.java   |   22 +-
 .../gemfire/internal/tcp/DirectReplySender.java |   21 +-
 .../tcp/ImmutableByteBufferInputStream.java     |   21 +-
 .../internal/tcp/MemberShunnedException.java    |   21 +-
 .../gemfire/internal/tcp/MsgDestreamer.java     |   21 +-
 .../gemfire/internal/tcp/MsgIdGenerator.java    |   21 +-
 .../gemfire/internal/tcp/MsgOutputStream.java   |   21 +-
 .../gemfire/internal/tcp/MsgReader.java         |   21 +-
 .../gemfire/internal/tcp/MsgStreamer.java       |   21 +-
 .../gemfire/internal/tcp/MsgStreamerList.java   |   21 +-
 .../gemfire/internal/tcp/NIOMsgReader.java      |   21 +-
 .../gemfire/internal/tcp/OioMsgReader.java      |   21 +-
 .../internal/tcp/ReenteredConnectException.java |   21 +-
 .../gemfire/internal/tcp/ServerDelegate.java    |   21 +-
 .../com/gemstone/gemfire/internal/tcp/Stub.java |   21 +-
 .../gemfire/internal/tcp/TCPConduit.java        |   21 +-
 .../tcp/VersionedByteBufferInputStream.java     |   21 +-
 .../internal/tcp/VersionedMsgStreamer.java      |   21 +-
 .../internal/util/AbortableTaskService.java     |   21 +-
 .../gemfire/internal/util/ArrayUtils.java       |   21 +-
 .../gemfire/internal/util/BlobHelper.java       |   21 +-
 .../gemfire/internal/util/Breadcrumbs.java      |   21 +-
 .../gemstone/gemfire/internal/util/Bytes.java   |   21 +-
 .../gemfire/internal/util/Callable.java         |   21 +-
 .../gemfire/internal/util/CollectionUtils.java  |   21 +-
 .../gemfire/internal/util/DebuggerSupport.java  |   21 +-
 .../gemfire/internal/util/DelayedAction.java    |   21 +-
 .../com/gemstone/gemfire/internal/util/Hex.java |   21 +-
 .../gemstone/gemfire/internal/util/IOUtils.java |   21 +-
 .../internal/util/JavaCommandBuilder.java       |   21 +-
 .../gemfire/internal/util/LogFileUtils.java     |   21 +-
 .../internal/util/ObjectIntProcedure.java       |   16 +
 .../gemfire/internal/util/ObjectProcedure.java  |   16 +
 .../gemfire/internal/util/PasswordUtil.java     |   20 +-
 .../gemfire/internal/util/PluckStacks.java      |   21 +-
 .../internal/util/SingletonCallable.java        |   16 +
 .../gemfire/internal/util/SingletonValue.java   |   18 +-
 .../internal/util/StackTraceCollector.java      |   21 +-
 .../gemfire/internal/util/StopWatch.java        |   21 +-
 .../internal/util/SunAPINotFoundException.java  |   20 +-
 .../gemfire/internal/util/TransformUtils.java   |   21 +-
 .../gemfire/internal/util/Transformer.java      |   21 +-
 .../gemfire/internal/util/Versionable.java      |   21 +-
 .../internal/util/VersionedArrayList.java       |   20 +-
 .../util/concurrent/CopyOnWriteHashMap.java     |   21 +-
 .../util/concurrent/CopyOnWriteWeakHashMap.java |   21 +-
 .../CustomEntryConcurrentHashMap.java           |   21 +-
 .../internal/util/concurrent/FutureResult.java  |   21 +-
 .../util/concurrent/ReentrantSemaphore.java     |   21 +-
 .../util/concurrent/SemaphoreReadWriteLock.java |   21 +-
 .../util/concurrent/StoppableCondition.java     |   21 +-
 .../concurrent/StoppableCountDownLatch.java     |   21 +-
 .../concurrent/StoppableCountDownOrUpLatch.java |   21 +-
 .../concurrent/StoppableNonReentrantLock.java   |   21 +-
 .../util/concurrent/StoppableReadWriteLock.java |   16 +
 .../util/concurrent/StoppableReentrantLock.java |   21 +-
 .../StoppableReentrantReadWriteLock.java        |   21 +-
 .../lang/AttachAPINotFoundException.java        |   20 +-
 .../com/gemstone/gemfire/lang/Identifiable.java |   20 +-
 .../management/AlreadyRunningException.java     |   21 +-
 .../management/AsyncEventQueueMXBean.java       |   20 +-
 .../gemfire/management/CacheServerMXBean.java   |   20 +-
 .../gemfire/management/ClientHealthStatus.java  |   20 +-
 .../gemfire/management/ClientQueueDetail.java   |   21 +-
 .../DependenciesNotFoundException.java          |   20 +-
 .../gemfire/management/DiskBackupResult.java    |   20 +-
 .../gemfire/management/DiskBackupStatus.java    |   20 +-
 .../gemfire/management/DiskMetrics.java         |   20 +-
 .../gemfire/management/DiskStoreMXBean.java     |   20 +-
 .../DistributedLockServiceMXBean.java           |   20 +-
 .../management/DistributedRegionMXBean.java     |   20 +-
 .../management/DistributedSystemMXBean.java     |   20 +-
 .../management/EvictionAttributesData.java      |   20 +-
 .../FixedPartitionAttributesData.java           |   21 +-
 .../management/GatewayReceiverMXBean.java       |   20 +-
 .../gemfire/management/GatewaySenderMXBean.java |   20 +-
 .../gemfire/management/GemFireProperties.java   |   20 +-
 .../gemfire/management/JMXNotificationType.java |   28 +-
 .../management/JMXNotificationUserData.java     |   28 +-
 .../gemstone/gemfire/management/JVMMetrics.java |   20 +-
 .../gemfire/management/LocatorMXBean.java       |   20 +-
 .../gemfire/management/LockServiceMXBean.java   |   20 +-
 .../gemfire/management/ManagementException.java |   20 +-
 .../gemfire/management/ManagementService.java   |   21 +-
 .../gemfire/management/ManagerMXBean.java       |   20 +-
 .../gemfire/management/MemberMXBean.java        |   20 +-
 .../management/MembershipAttributesData.java    |   20 +-
 .../gemfire/management/NetworkMetrics.java      |   20 +-
 .../gemstone/gemfire/management/OSMetrics.java  |   20 +-
 .../management/PartitionAttributesData.java     |   20 +-
 .../management/PersistentMemberDetails.java     |   20 +-
 .../management/RegionAttributesData.java        |   20 +-
 .../gemfire/management/RegionMXBean.java        |   20 +-
 .../gemfire/management/ServerLoadData.java      |   20 +-
 .../gemfire/management/cli/CliMetaData.java     |   20 +-
 .../cli/CommandProcessingException.java         |   20 +-
 .../gemfire/management/cli/CommandService.java  |   20 +-
 .../management/cli/CommandServiceException.java |   20 +-
 .../management/cli/CommandStatement.java        |   20 +-
 .../gemfire/management/cli/ConverterHint.java   |   21 +-
 .../gemstone/gemfire/management/cli/Result.java |   21 +-
 .../management/internal/AlertDetails.java       |   21 +-
 .../management/internal/ArrayConverter.java     |   20 +-
 .../internal/BaseManagementService.java         |   21 +-
 .../internal/CollectionConverter.java           |   22 +-
 .../management/internal/CompositeConverter.java |   20 +-
 .../management/internal/EnumConverter.java      |   20 +-
 .../management/internal/FederatingManager.java  |   21 +-
 .../internal/FederationComponent.java           |   20 +-
 .../management/internal/FilterChain.java        |   20 +-
 .../management/internal/FilterParam.java        |   22 +-
 .../management/internal/IdentityConverter.java  |   20 +-
 .../management/internal/JettyHelper.java        |   21 +-
 .../management/internal/JmxManagerAdvisee.java  |   21 +-
 .../management/internal/JmxManagerAdvisor.java  |   21 +-
 .../management/internal/JmxManagerLocator.java  |   21 +-
 .../internal/JmxManagerLocatorRequest.java      |   20 +-
 .../internal/JmxManagerLocatorResponse.java     |   20 +-
 .../management/internal/LocalFilterChain.java   |   20 +-
 .../management/internal/LocalManager.java       |   20 +-
 .../management/internal/MBeanJMXAdapter.java    |   20 +-
 .../management/internal/MBeanProxyFactory.java  |   22 +-
 .../internal/MBeanProxyInfoRepository.java      |   22 +-
 .../internal/MBeanProxyInvocationHandler.java   |   23 +-
 .../internal/MXBeanProxyInvocationHandler.java  |   20 +-
 .../management/internal/ManagementAgent.java    |   21 +-
 .../internal/ManagementCacheListener.java       |   22 +-
 .../internal/ManagementConstants.java           |   20 +-
 .../management/internal/ManagementFunction.java |   20 +-
 .../internal/ManagementMembershipListener.java  |   20 +-
 .../internal/ManagementResourceRepo.java        |   20 +-
 .../management/internal/ManagementStrings.java  |   20 +-
 .../gemfire/management/internal/Manager.java    |   21 +-
 .../internal/ManagerStartupMessage.java         |   21 +-
 .../management/internal/MemberMessenger.java    |   20 +-
 .../internal/MonitoringRegionCacheListener.java |   20 +-
 .../internal/NotificationBroadCasterProxy.java  |   20 +-
 .../internal/NotificationCacheListener.java     |   20 +-
 .../management/internal/NotificationHub.java    |   22 +-
 .../internal/NotificationHubClient.java         |   20 +-
 .../management/internal/NotificationKey.java    |   20 +-
 .../gemfire/management/internal/OpenMethod.java |   22 +-
 .../management/internal/OpenTypeConverter.java  |   20 +-
 .../management/internal/OpenTypeUtil.java       |   20 +-
 .../gemfire/management/internal/ProxyInfo.java  |   20 +-
 .../management/internal/ProxyInterface.java     |   20 +-
 .../management/internal/ProxyListener.java      |   20 +-
 .../management/internal/RemoteFilterChain.java  |   20 +-
 .../gemfire/management/internal/RestAgent.java  |   21 +-
 .../gemfire/management/internal/SSLUtil.java    |   16 +
 .../management/internal/StringBasedFilter.java  |   20 +-
 .../internal/SystemManagementService.java       |   21 +-
 .../management/internal/TableConverter.java     |   22 +-
 .../internal/beans/AggregateHandler.java        |   20 +-
 .../internal/beans/AsyncEventQueueMBean.java    |   20 +-
 .../beans/AsyncEventQueueMBeanBridge.java       |   20 +-
 .../internal/beans/BeanUtilFuncs.java           |   20 +-
 .../internal/beans/CacheServerBridge.java       |   20 +-
 .../internal/beans/CacheServerMBean.java        |   20 +-
 .../internal/beans/DiskRegionBridge.java        |   22 +-
 .../internal/beans/DiskStoreMBean.java          |   20 +-
 .../internal/beans/DiskStoreMBeanBridge.java    |   20 +-
 .../beans/DistributedLockServiceBridge.java     |   20 +-
 .../beans/DistributedLockServiceMBean.java      |   20 +-
 .../internal/beans/DistributedRegionBridge.java |   20 +-
 .../internal/beans/DistributedRegionMBean.java  |   20 +-
 .../internal/beans/DistributedSystemBridge.java |   20 +-
 .../internal/beans/DistributedSystemMBean.java  |   20 +-
 .../internal/beans/GatewayReceiverMBean.java    |   20 +-
 .../beans/GatewayReceiverMBeanBridge.java       |   20 +-
 .../internal/beans/GatewaySenderMBean.java      |   20 +-
 .../beans/GatewaySenderMBeanBridge.java         |   20 +-
 .../internal/beans/HDFSRegionBridge.java        |   20 +-
 .../management/internal/beans/LocatorMBean.java |   20 +-
 .../internal/beans/LocatorMBeanBridge.java      |   20 +-
 .../internal/beans/LockServiceMBean.java        |   20 +-
 .../internal/beans/LockServiceMBeanBridge.java  |   22 +-
 .../internal/beans/MBeanAggregator.java         |   20 +-
 .../internal/beans/ManagementAdapter.java       |   22 +-
 .../internal/beans/ManagementListener.java      |   20 +-
 .../management/internal/beans/ManagerMBean.java |   20 +-
 .../internal/beans/ManagerMBeanBridge.java      |   20 +-
 .../management/internal/beans/MemberMBean.java  |   20 +-
 .../internal/beans/MemberMBeanBridge.java       |   21 +-
 .../internal/beans/MetricsCalculator.java       |   20 +-
 .../internal/beans/PartitionedRegionBridge.java |   20 +-
 .../internal/beans/QueryDataFunction.java       |   20 +-
 .../management/internal/beans/RegionMBean.java  |   20 +-
 .../internal/beans/RegionMBeanBridge.java       |   20 +-
 .../beans/RegionMBeanCompositeDataFactory.java  |   20 +-
 .../internal/beans/SequenceNumber.java          |   20 +-
 .../management/internal/beans/ServerBridge.java |   21 +-
 .../stats/AggregateRegionStatsMonitor.java      |   20 +-
 .../internal/beans/stats/GCStatsMonitor.java    |   20 +-
 .../GatewayReceiverClusterStatsMonitor.java     |   20 +-
 .../stats/GatewaySenderClusterStatsMonitor.java |   20 +-
 .../stats/IntegerStatsDeltaAggregator.java      |   23 +-
 .../beans/stats/LongStatsDeltaAggregator.java   |   23 +-
 .../internal/beans/stats/MBeanStatsMonitor.java |   20 +-
 .../beans/stats/MemberClusterStatsMonitor.java  |   20 +-
 .../beans/stats/MemberLevelDiskMonitor.java     |   20 +-
 .../beans/stats/RegionClusterStatsMonitor.java  |   20 +-
 .../beans/stats/ServerClusterStatsMonitor.java  |   20 +-
 .../internal/beans/stats/StatType.java          |   20 +-
 .../internal/beans/stats/StatsAggregator.java   |   20 +-
 .../beans/stats/StatsAverageLatency.java        |   20 +-
 .../internal/beans/stats/StatsKey.java          |   20 +-
 .../internal/beans/stats/StatsLatency.java      |   20 +-
 .../internal/beans/stats/StatsRate.java         |   20 +-
 .../internal/beans/stats/VMStatsMonitor.java    |   20 +-
 .../cli/AbstractCliAroundInterceptor.java       |   20 +-
 .../internal/cli/CliAroundInterceptor.java      |   20 +-
 .../management/internal/cli/CliUtil.java        |   20 +-
 .../management/internal/cli/CommandManager.java |   20 +-
 .../management/internal/cli/CommandRequest.java |   21 +-
 .../internal/cli/CommandResponse.java           |   22 +-
 .../internal/cli/CommandResponseBuilder.java    |   20 +-
 .../internal/cli/CommandResponseWriter.java     |   20 +-
 .../internal/cli/GfshParseResult.java           |   20 +-
 .../management/internal/cli/GfshParser.java     |   20 +-
 .../management/internal/cli/Launcher.java       |   20 +-
 .../management/internal/cli/LogWrapper.java     |   20 +-
 .../internal/cli/MultipleValueAdapter.java      |   21 +-
 .../internal/cli/MultipleValueConverter.java    |   21 +-
 .../internal/cli/annotation/CliArgument.java    |   20 +-
 .../cli/commands/AbstractCommandsSupport.java   |   20 +-
 .../internal/cli/commands/ClientCommands.java   |   20 +-
 .../internal/cli/commands/ConfigCommands.java   |   20 +-
 .../CreateAlterDestroyRegionCommands.java       |   32 +-
 .../internal/cli/commands/DataCommands.java     |   20 +-
 .../internal/cli/commands/DeployCommands.java   |   20 +-
 .../cli/commands/DiskStoreCommands.java         |   41 +-
 .../cli/commands/DurableClientCommands.java     |   20 +-
 ...ExportImportSharedConfigurationCommands.java |   21 +-
 .../internal/cli/commands/FunctionCommands.java |   20 +-
 .../internal/cli/commands/GfshHelpCommands.java |   20 +-
 .../cli/commands/HDFSStoreCommands.java         |  695 -------
 .../internal/cli/commands/IndexCommands.java    |   20 +-
 .../cli/commands/LauncherLifecycleCommands.java |   20 +-
 .../internal/cli/commands/MemberCommands.java   |   20 +-
 .../cli/commands/MiscellaneousCommands.java     |   20 +-
 .../internal/cli/commands/PDXCommands.java      |   16 +
 .../internal/cli/commands/QueueCommands.java    |   20 +-
 .../internal/cli/commands/RegionCommands.java   |   20 +-
 .../internal/cli/commands/ShellCommands.java    |   27 +-
 .../internal/cli/commands/StatusCommands.java   |   21 +-
 .../internal/cli/commands/WanCommands.java      |   21 +-
 .../cli/commands/dto/RegionAttributesInfo.java  |   21 +-
 .../cli/commands/dto/RegionDetails.java         |   21 +-
 .../cli/commands/dto/RegionMemberDetails.java   |   21 +-
 .../cli/converters/BooleanConverter.java        |   22 +-
 .../ClusterMemberIdNameConverter.java           |   20 +-
 .../converters/ConnectionEndpointConverter.java |   21 +-
 .../internal/cli/converters/DirConverter.java   |   20 +-
 .../cli/converters/DirPathConverter.java        |   20 +-
 .../cli/converters/DiskStoreNameConverter.java  |   20 +-
 .../internal/cli/converters/EnumConverter.java  |   20 +-
 .../cli/converters/FilePathConverter.java       |   20 +-
 .../cli/converters/FilePathStringConverter.java |   20 +-
 .../converters/GatewayReceiverIdsConverter.java |   21 +-
 .../converters/GatewaySenderIdConverter.java    |   20 +-
 .../cli/converters/HdfsStoreNameConverter.java  |   88 -
 .../internal/cli/converters/HelpConverter.java  |   20 +-
 .../cli/converters/HintTopicConverter.java      |   20 +-
 .../cli/converters/IndexTypeConverter.java      |   21 +-
 .../LocatorDiscoveryConfigConverter.java        |   20 +-
 .../cli/converters/LocatorIdNameConverter.java  |   20 +-
 .../cli/converters/LogLevelConverter.java       |   20 +-
 .../cli/converters/MemberGroupConverter.java    |   20 +-
 .../cli/converters/MemberIdNameConverter.java   |   20 +-
 .../cli/converters/RegionPathConverter.java     |   20 +-
 .../cli/converters/StringArrayConverter.java    |   20 +-
 .../cli/converters/StringListConverter.java     |   20 +-
 .../cli/domain/AsyncEventQueueDetails.java      |   21 +-
 .../internal/cli/domain/CacheServerInfo.java    |   21 +-
 .../cli/domain/ConnectToLocatorResult.java      |   20 +-
 .../internal/cli/domain/DataCommandRequest.java |   21 +-
 .../internal/cli/domain/DataCommandResult.java  |   21 +-
 .../internal/cli/domain/DiskStoreDetails.java   |   18 +-
 .../cli/domain/DurableCqNamesResult.java        |   21 +-
 .../cli/domain/EvictionAttributesInfo.java      |   21 +-
 .../domain/FixedPartitionAttributesInfo.java    |   21 +-
 .../internal/cli/domain/IndexDetails.java       |   20 +-
 .../internal/cli/domain/IndexInfo.java          |   21 +-
 .../cli/domain/MemberConfigurationInfo.java     |   21 +-
 .../internal/cli/domain/MemberInformation.java  |   20 +-
 .../internal/cli/domain/MemberResult.java       |   21 +-
 .../cli/domain/PartitionAttributesInfo.java     |   21 +-
 .../cli/domain/RegionAttributesInfo.java        |   21 +-
 .../internal/cli/domain/RegionDescription.java  |   21 +-
 .../cli/domain/RegionDescriptionPerMember.java  |   21 +-
 .../internal/cli/domain/RegionInformation.java  |   20 +-
 .../cli/domain/StackTracesPerMember.java        |   21 +-
 .../cli/domain/SubscriptionQueueSizeResult.java |   21 +-
 .../cli/exceptions/CliCommandException.java     |   20 +-
 .../exceptions/CliCommandInvalidException.java  |   20 +-
 .../CliCommandMultiModeOptionException.java     |   16 +
 .../CliCommandNotAvailableException.java        |   20 +-
 .../exceptions/CliCommandOptionException.java   |   20 +-
 ...CommandOptionHasMultipleValuesException.java |   20 +-
 .../CliCommandOptionInvalidException.java       |   20 +-
 .../CliCommandOptionMissingException.java       |   20 +-
 .../CliCommandOptionNotApplicableException.java |   20 +-
 ...liCommandOptionValueConversionException.java |   20 +-
 .../CliCommandOptionValueException.java         |   20 +-
 .../CliCommandOptionValueMissingException.java  |   20 +-
 .../internal/cli/exceptions/CliException.java   |   20 +-
 .../exceptions/CreateSubregionException.java    |   20 +-
 .../cli/exceptions/ExceptionGenerator.java      |   20 +-
 .../cli/exceptions/ExceptionHandler.java        |   20 +-
 .../cli/exceptions/IndexNotFoundException.java  |   16 +
 .../cli/functions/AlterHDFSStoreFunction.java   |  228 ---
 .../functions/AlterRuntimeConfigFunction.java   |   21 +-
 .../cli/functions/ChangeLogLevelFunction.java   |   20 +-
 .../cli/functions/CliFunctionResult.java        |   21 +-
 .../functions/CloseDurableClientFunction.java   |   21 +-
 .../cli/functions/CloseDurableCqFunction.java   |   21 +-
 .../cli/functions/ContunuousQueryFunction.java  |   20 +-
 .../CreateAsyncEventQueueFunction.java          |   21 +-
 .../functions/CreateDefinedIndexesFunction.java |   16 +
 .../cli/functions/CreateDiskStoreFunction.java  |   21 +-
 .../cli/functions/CreateHDFSStoreFunction.java  |  124 --
 .../cli/functions/CreateIndexFunction.java      |   21 +-
 .../cli/functions/DataCommandFunction.java      |   21 +-
 .../internal/cli/functions/DeployFunction.java  |   21 +-
 .../functions/DescribeDiskStoreFunction.java    |   18 +-
 .../functions/DescribeHDFSStoreFunction.java    |   16 +
 .../cli/functions/DestroyDiskStoreFunction.java |   21 +-
 .../cli/functions/DestroyHDFSStoreFunction.java |  100 -
 .../cli/functions/DestroyIndexFunction.java     |   21 +-
 .../cli/functions/ExportConfigFunction.java     |   23 +-
 .../cli/functions/ExportDataFunction.java       |   21 +-
 .../ExportSharedConfigurationFunction.java      |   21 +-
 .../FetchRegionAttributesFunction.java          |   20 +-
 .../FetchSharedConfigurationStatusFunction.java |   21 +-
 .../functions/GarbageCollectionFunction.java    |   21 +-
 .../GatewayReceiverCreateFunction.java          |   21 +-
 .../functions/GatewayReceiverFunctionArgs.java  |   21 +-
 .../functions/GatewaySenderCreateFunction.java  |   21 +-
 .../functions/GatewaySenderFunctionArgs.java    |   21 +-
 .../GetMemberConfigInformationFunction.java     |   21 +-
 .../functions/GetMemberInformationFunction.java |   21 +-
 .../functions/GetRegionDescriptionFunction.java |   20 +-
 .../cli/functions/GetRegionsFunction.java       |   20 +-
 .../cli/functions/GetStackTracesFunction.java   |   21 +-
 .../GetSubscriptionQueueSizeFunction.java       |   21 +-
 .../cli/functions/ImportDataFunction.java       |   21 +-
 ...ortSharedConfigurationArtifactsFunction.java |   21 +-
 .../functions/ListAsyncEventQueuesFunction.java |   18 +-
 .../cli/functions/ListDeployedFunction.java     |   21 +-
 .../cli/functions/ListDiskStoresFunction.java   |   18 +-
 .../functions/ListDurableCqNamesFunction.java   |   20 +-
 .../cli/functions/ListFunctionFunction.java     |   21 +-
 .../cli/functions/ListHDFSStoresFunction.java   |  102 -
 .../cli/functions/ListIndexFunction.java        |   20 +-
 .../LoadSharedConfigurationFunction.java        |   21 +-
 .../internal/cli/functions/LogFileFunction.java |   23 +-
 .../cli/functions/MemberRegionFunction.java     |   23 +-
 .../cli/functions/MembersForRegionFunction.java |   20 +-
 .../internal/cli/functions/NetstatFunction.java |   20 +-
 .../cli/functions/RebalanceFunction.java        |   23 +-
 .../cli/functions/RegionAlterFunction.java      |   20 +-
 .../cli/functions/RegionCreateFunction.java     |   28 +-
 .../cli/functions/RegionDestroyFunction.java    |   20 +-
 .../cli/functions/RegionFunctionArgs.java       |   86 +-
 .../cli/functions/ShutDownFunction.java         |   23 +-
 .../cli/functions/UndeployFunction.java         |   21 +-
 .../cli/functions/UnregisterFunction.java       |   23 +-
 .../cli/functions/UserFunctionExecution.java    |   24 +-
 .../management/internal/cli/help/CliTopic.java  |   20 +-
 .../internal/cli/help/format/Block.java         |   20 +-
 .../internal/cli/help/format/DataNode.java      |   20 +-
 .../internal/cli/help/format/Help.java          |   20 +-
 .../internal/cli/help/format/NewHelp.java       |   20 +-
 .../internal/cli/help/format/Row.java           |   20 +-
 .../internal/cli/help/utils/FormatOutput.java   |   16 +
 .../internal/cli/help/utils/HelpUtils.java      |   20 +-
 .../internal/cli/i18n/CliStrings.java           |  134 +-
 .../internal/cli/json/GfJsonArray.java          |   20 +-
 .../internal/cli/json/GfJsonException.java      |   22 +-
 .../internal/cli/json/GfJsonObject.java         |   20 +-
 .../management/internal/cli/json/TypedJson.java |   20 +-
 .../internal/cli/modes/CommandModes.java        |   18 +-
 .../cli/multistep/CLIMultiStepHelper.java       |   21 +-
 .../internal/cli/multistep/CLIRemoteStep.java   |   16 +
 .../internal/cli/multistep/CLIStep.java         |   16 +
 .../cli/multistep/CLIStepExecption.java         |   21 +-
 .../cli/multistep/MultiStepCommand.java         |   16 +
 .../internal/cli/parser/Argument.java           |   20 +-
 .../internal/cli/parser/AvailabilityTarget.java |   20 +-
 .../internal/cli/parser/CommandTarget.java      |   22 +-
 .../internal/cli/parser/GfshMethodTarget.java   |   22 +-
 .../internal/cli/parser/GfshOptionParser.java   |   22 +-
 .../internal/cli/parser/MethodParameter.java    |   20 +-
 .../management/internal/cli/parser/Option.java  |   20 +-
 .../internal/cli/parser/OptionSet.java          |   20 +-
 .../internal/cli/parser/Parameter.java          |   20 +-
 .../internal/cli/parser/ParserUtils.java        |   20 +-
 .../internal/cli/parser/SyntaxConstants.java    |   22 +-
 .../cli/parser/jopt/JoptOptionParser.java       |   20 +-
 .../preprocessor/EnclosingCharacters.java       |   20 +-
 .../cli/parser/preprocessor/Preprocessor.java   |   20 +-
 .../parser/preprocessor/PreprocessorUtils.java  |   20 +-
 .../internal/cli/parser/preprocessor/Stack.java |   20 +-
 .../cli/parser/preprocessor/TrimmedInput.java   |   20 +-
 .../cli/remote/CommandExecutionContext.java     |   20 +-
 .../internal/cli/remote/CommandProcessor.java   |   20 +-
 .../cli/remote/CommandStatementImpl.java        |   20 +-
 .../cli/remote/MemberCommandService.java        |   20 +-
 .../cli/remote/RemoteExecutionStrategy.java     |   20 +-
 .../internal/cli/remote/WrapperThreadLocal.java |   20 +-
 .../internal/cli/result/AbstractResultData.java |   20 +-
 .../cli/result/CliJsonSerializable.java         |   20 +-
 .../cli/result/CliJsonSerializableFactory.java  |   21 +-
 .../cli/result/CliJsonSerializableIds.java      |   20 +-
 .../internal/cli/result/CommandResult.java      |   20 +-
 .../cli/result/CommandResultException.java      |   21 +-
 .../cli/result/CompositeResultData.java         |   20 +-
 .../internal/cli/result/ErrorResultData.java    |   20 +-
 .../internal/cli/result/FileResult.java         |   20 +-
 .../internal/cli/result/InfoResultData.java     |   20 +-
 .../internal/cli/result/ObjectResultData.java   |   20 +-
 .../internal/cli/result/ResultBuilder.java      |   20 +-
 .../internal/cli/result/ResultData.java         |   20 +-
 .../cli/result/ResultDataException.java         |   20 +-
 .../internal/cli/result/TableBuilder.java       |   20 +-
 .../internal/cli/result/TableBuilderHelper.java |   21 +-
 .../internal/cli/result/TabularResultData.java  |   20 +-
 .../management/internal/cli/shell/Gfsh.java     |   20 +-
 .../internal/cli/shell/GfshConfig.java          |   20 +-
 .../cli/shell/GfshExecutionStrategy.java        |   20 +-
 .../cli/shell/JMXConnectionException.java       |   20 +-
 .../cli/shell/JMXInvocationException.java       |   20 +-
 .../internal/cli/shell/JmxOperationInvoker.java |   20 +-
 .../internal/cli/shell/MultiCommandHelper.java  |   16 +
 .../internal/cli/shell/OperationInvoker.java    |   20 +-
 .../internal/cli/shell/jline/ANSIHandler.java   |   20 +-
 .../cli/shell/jline/CygwinMinttyTerminal.java   |   21 +-
 .../internal/cli/shell/jline/GfshHistory.java   |   20 +-
 .../shell/jline/GfshUnsupportedTerminal.java    |   20 +-
 .../cli/shell/unsafe/GfshSignalHandler.java     |   21 +-
 .../internal/cli/util/CLIConsoleBufferUtil.java |   21 +-
 .../internal/cli/util/CauseFinder.java          |   20 +-
 .../cli/util/ClasspathScanLoadHelper.java       |   20 +-
 .../internal/cli/util/CommandStringBuilder.java |   20 +-
 .../internal/cli/util/CommentSkipHelper.java    |   20 +-
 .../internal/cli/util/ConnectionEndpoint.java   |   21 +-
 .../internal/cli/util/DiskStoreCompacter.java   |   20 +-
 .../cli/util/DiskStoreNotFoundException.java    |   18 +-
 .../internal/cli/util/DiskStoreUpgrader.java    |   21 +-
 .../internal/cli/util/DiskStoreValidater.java   |   21 +-
 .../cli/util/EvictionAttributesInfo.java        |   21 +-
 .../cli/util/FixedPartitionAttributesInfo.java  |   21 +-
 .../internal/cli/util/GfshConsoleReader.java    |   22 +-
 .../cli/util/HDFSStoreNotFoundException.java    |   18 +-
 .../cli/util/JConsoleNotFoundException.java     |   20 +-
 .../management/internal/cli/util/JsonUtil.java  |   20 +-
 .../internal/cli/util/MemberInformation.java    |   20 +-
 .../cli/util/MemberNotFoundException.java       |   18 +-
 .../management/internal/cli/util/MergeLogs.java |   21 +-
 .../internal/cli/util/ReadWriteFile.java        |   21 +-
 .../cli/util/RegionAttributesDefault.java       |   21 +-
 .../cli/util/RegionAttributesNames.java         |   21 +-
 .../internal/cli/util/RegionPath.java           |   20 +-
 .../cli/util/VisualVmNotFoundException.java     |   20 +-
 .../internal/cli/util/spring/Assert.java        |   20 +-
 .../internal/cli/util/spring/ObjectUtils.java   |   21 +-
 .../cli/util/spring/ReflectionUtils.java        |   21 +-
 .../internal/cli/util/spring/StringUtils.java   |   21 +-
 .../SharedConfigurationWriter.java              |   21 +-
 .../callbacks/ConfigurationChangeListener.java  |   21 +-
 .../configuration/domain/CacheElement.java      |   21 +-
 .../configuration/domain/Configuration.java     |   21 +-
 .../domain/ConfigurationChangeResult.java       |   21 +-
 .../domain/SharedConfigurationStatus.java       |   16 +
 .../configuration/domain/XmlEntity.java         |   21 +-
 .../configuration/functions/AddJarFunction.java |   21 +-
 .../functions/AddXmlEntityFunction.java         |   21 +-
 .../functions/DeleteJarFunction.java            |   21 +-
 .../functions/DeleteXmlEntityFunction.java      |   21 +-
 .../functions/GetAllJarsFunction.java           |   21 +-
 .../functions/ModifyPropertiesFunction.java     |   21 +-
 .../handlers/ConfigurationRequestHandler.java   |   21 +-
 ...SharedConfigurationStatusRequestHandler.java |   21 +-
 .../messages/ConfigurationRequest.java          |   21 +-
 .../messages/ConfigurationResponse.java         |   21 +-
 .../SharedConfigurationStatusRequest.java       |   21 +-
 .../SharedConfigurationStatusResponse.java      |   21 +-
 .../configuration/utils/DtdResolver.java        |   16 +
 .../configuration/utils/XmlConstants.java       |   21 +-
 .../internal/configuration/utils/XmlUtils.java  |   21 +-
 .../internal/configuration/utils/ZipUtils.java  |   21 +-
 .../internal/messages/CompactRequest.java       |   20 +-
 .../internal/messages/CompactResponse.java      |   20 +-
 .../internal/security/AccessControl.java        |   16 +
 .../internal/security/AccessControlContext.java |   16 +
 .../internal/security/AccessControlMXBean.java  |   16 +
 .../internal/security/CLIOperationContext.java  |   16 +
 .../internal/security/JMXOperationContext.java  |   16 +
 .../internal/security/JSONAuthorization.java    |   16 +
 .../internal/security/MBeanServerWrapper.java   |   16 +
 .../security/ManagementInterceptor.java         |   16 +
 .../management/internal/security/Resource.java  |   16 +
 .../internal/security/ResourceConstants.java    |   16 +
 .../internal/security/ResourceOperation.java    |   16 +
 .../security/ResourceOperationContext.java      |   16 +
 .../unsafe/ReadOpFileAccessController.java      |   21 +-
 .../controllers/AbstractCommandsController.java |   28 +-
 .../AbstractMultiPartCommandsController.java    |   21 +-
 .../controllers/ClientCommandsController.java   |   21 +-
 .../controllers/ClusterCommandsController.java  |   21 +-
 .../controllers/ConfigCommandsController.java   |   21 +-
 .../web/controllers/DataCommandsController.java |   21 +-
 .../controllers/DeployCommandsController.java   |   21 +-
 .../DiskStoreCommandsController.java            |   21 +-
 .../DurableClientCommandsController.java        |   21 +-
 .../controllers/FunctionCommandsController.java |   21 +-
 .../HDFSStoreCommandsController.java            |  229 ---
 .../controllers/IndexCommandsController.java    |   21 +-
 .../LauncherLifecycleCommandsController.java    |   21 +-
 .../controllers/MemberCommandsController.java   |   21 +-
 .../MiscellaneousCommandsController.java        |   21 +-
 .../web/controllers/PdxCommandsController.java  |   16 +
 .../controllers/QueueCommandsController.java    |   21 +-
 .../controllers/RegionCommandsController.java   |   21 +-
 .../controllers/ShellCommandsController.java    |  225 +--
 .../web/controllers/WanCommandsController.java  |   21 +-
 .../EnvironmentVariablesHandlerInterceptor.java |   21 +-
 .../support/MemberMXBeanAdapter.java            |   21 +-
 .../management/internal/web/domain/Link.java    |   21 +-
 .../internal/web/domain/LinkIndex.java          |   21 +-
 .../web/domain/QueryParameterSource.java        |   21 +-
 .../internal/web/http/ClientHttpRequest.java    |   21 +-
 .../internal/web/http/HttpHeader.java           |   21 +-
 .../internal/web/http/HttpMethod.java           |   21 +-
 .../SerializableObjectHttpMessageConverter.java |   21 +-
 .../web/http/support/SimpleHttpRequester.java   |   21 +-
 .../internal/web/io/MultipartFileAdapter.java   |   21 +-
 .../web/io/MultipartFileResourceAdapter.java    |   21 +-
 .../web/shell/AbstractHttpOperationInvoker.java |   21 +-
 .../web/shell/HttpOperationInvoker.java         |   16 +
 .../web/shell/MBeanAccessException.java         |   21 +-
 .../RestApiCallForCommandNotFoundException.java |   21 +-
 .../web/shell/RestHttpOperationInvoker.java     |   21 +-
 .../web/shell/SimpleHttpOperationInvoker.java   |   21 +-
 .../shell/support/HttpInvocationHandler.java    |   21 +-
 .../shell/support/HttpMBeanProxyFactory.java    |   21 +-
 .../internal/web/util/ConvertUtils.java         |   21 +-
 .../management/internal/web/util/UriUtils.java  |   21 +-
 .../management/membership/ClientMembership.java |   21 +-
 .../membership/ClientMembershipEvent.java       |   21 +-
 .../membership/ClientMembershipListener.java    |   21 +-
 .../ClientMembershipListenerAdapter.java        |   21 +-
 .../management/membership/MembershipEvent.java  |   21 +-
 .../membership/MembershipListener.java          |   21 +-
 .../UniversalMembershipListenerAdapter.java     |   21 +-
 .../memcached/GemFireMemcachedServer.java       |   21 +-
 .../com/gemstone/gemfire/pdx/FieldType.java     |   21 +-
 .../com/gemstone/gemfire/pdx/JSONFormatter.java |   16 +
 .../gemfire/pdx/JSONFormatterException.java     |   23 +-
 .../gemfire/pdx/NonPortableClassException.java  |   16 +
 .../gemfire/pdx/PdxConfigurationException.java  |   21 +-
 .../pdx/PdxFieldAlreadyExistsException.java     |   21 +-
 .../pdx/PdxFieldDoesNotExistException.java      |   21 +-
 .../pdx/PdxFieldTypeMismatchException.java      |   21 +-
 .../gemfire/pdx/PdxInitializationException.java |   21 +-
 .../com/gemstone/gemfire/pdx/PdxInstance.java   |   21 +-
 .../gemfire/pdx/PdxInstanceFactory.java         |   21 +-
 .../com/gemstone/gemfire/pdx/PdxReader.java     |   21 +-
 .../pdx/PdxRegistryMismatchException.java       |   24 +-
 .../gemstone/gemfire/pdx/PdxSerializable.java   |   21 +-
 .../gemfire/pdx/PdxSerializationException.java  |   21 +-
 .../com/gemstone/gemfire/pdx/PdxSerializer.java |   21 +-
 .../gemstone/gemfire/pdx/PdxUnreadFields.java   |   21 +-
 .../com/gemstone/gemfire/pdx/PdxWriter.java     |   21 +-
 .../pdx/ReflectionBasedAutoSerializer.java      |   21 +-
 .../gemfire/pdx/WritablePdxInstance.java        |   21 +-
 .../pdx/internal/AutoSerializableManager.java   |   21 +-
 .../pdx/internal/CheckTypeRegistryState.java    |   21 +-
 .../pdx/internal/ClientTypeRegistration.java    |   21 +-
 .../gemfire/pdx/internal/ComparableEnum.java    |   16 +
 .../pdx/internal/ConvertableToBytes.java        |   16 +
 .../gemstone/gemfire/pdx/internal/DataSize.java |   21 +-
 .../gemfire/pdx/internal/DefaultPdxField.java   |   21 +-
 .../gemstone/gemfire/pdx/internal/EnumId.java   |   21 +-
 .../gemstone/gemfire/pdx/internal/EnumInfo.java |   21 +-
 .../pdx/internal/FieldNotFoundInPdxVersion.java |   16 +
 .../gemfire/pdx/internal/InternalPdxReader.java |   21 +-
 .../pdx/internal/LonerTypeRegistration.java     |   21 +-
 .../pdx/internal/NullTypeRegistration.java      |   21 +-
 .../gemstone/gemfire/pdx/internal/PdxField.java |   21 +-
 .../gemfire/pdx/internal/PdxInputStream.java    |   21 +-
 .../gemfire/pdx/internal/PdxInstanceEnum.java   |   21 +-
 .../pdx/internal/PdxInstanceFactoryImpl.java    |   21 +-
 .../gemfire/pdx/internal/PdxInstanceImpl.java   |   21 +-
 .../pdx/internal/PdxInstanceInputStream.java    |   21 +-
 .../gemfire/pdx/internal/PdxOutputStream.java   |   21 +-
 .../gemfire/pdx/internal/PdxReaderImpl.java     |   21 +-
 .../gemfire/pdx/internal/PdxString.java         |   23 +-
 .../gemstone/gemfire/pdx/internal/PdxType.java  |   21 +-
 .../gemfire/pdx/internal/PdxUnreadData.java     |   21 +-
 .../gemfire/pdx/internal/PdxWriterImpl.java     |   21 +-
 .../pdx/internal/PeerTypeRegistration.java      |   21 +-
 .../pdx/internal/TrackingPdxReaderImpl.java     |   21 +-
 .../gemfire/pdx/internal/TypeRegistration.java  |   21 +-
 .../gemfire/pdx/internal/TypeRegistry.java      |   21 +-
 .../gemfire/pdx/internal/UnreadPdxType.java     |   21 +-
 .../internal/WeakConcurrentIdentityHashMap.java |   21 +-
 .../pdx/internal/WritablePdxInstanceImpl.java   |   21 +-
 .../gemfire/pdx/internal/json/JsonHelper.java   |   21 +-
 .../pdx/internal/json/PdxInstanceHelper.java    |   23 +-
 .../pdx/internal/json/PdxListHelper.java        |   23 +-
 .../gemfire/pdx/internal/json/PdxToJSON.java    |   23 +-
 .../pdx/internal/unsafe/UnsafeWrapper.java      |   21 +-
 .../com/gemstone/gemfire/ra/GFConnection.java   |   16 +
 .../gemfire/ra/GFConnectionFactory.java         |   16 +
 .../gemfire/redis/GemFireRedisServer.java       |   18 +-
 .../gemfire/security/AccessControl.java         |   21 +-
 .../gemfire/security/AuthInitialize.java        |   21 +-
 .../security/AuthenticationFailedException.java |   21 +-
 .../AuthenticationRequiredException.java        |   21 +-
 .../gemfire/security/Authenticator.java         |   21 +-
 .../security/GemFireSecurityException.java      |   21 +-
 .../security/NotAuthorizedException.java        |   21 +-
 .../internal/logging/log4j/log4j2-cli.xml       |   17 -
 .../internal/logging/log4j/log4j2-default.xml   |   21 -
 gemfire-core/src/main/resources/log4j2-cli.xml  |   17 +
 gemfire-core/src/main/resources/log4j2.xml      |   22 +
 .../batterytest/greplogs/ExpectedStrings.java   |   21 +-
 .../java/batterytest/greplogs/LogConsumer.java  |   66 +-
 .../src/test/java/cacheRunner/Portfolio.java    |   16 +
 .../src/test/java/cacheRunner/Position.java     |   16 +
 .../src/test/java/com/company/app/Customer.java |   21 +-
 .../src/test/java/com/company/app/DBLoader.java |   21 +-
 .../com/company/app/OrdersCacheListener.java    |   21 +-
 .../java/com/company/data/DatabaseLoader.java   |   21 +-
 .../java/com/company/data/MyDeclarable.java     |   16 +
 .../src/test/java/com/company/data/MySizer.java |   21 +-
 .../com/company/data/MyTransactionListener.java |   21 +-
 .../src/test/java/com/examples/LinkNode.java    |   21 +-
 .../src/test/java/com/examples/SuperClass.java  |   21 +-
 .../src/test/java/com/examples/TestObject.java  |   21 +-
 .../src/test/java/com/examples/ds/Address.java  |   16 +
 .../src/test/java/com/examples/ds/Company.java  |   21 +-
 .../java/com/examples/ds/CompanySerializer.java |   21 +-
 .../src/test/java/com/examples/ds/Employee.java |   21 +-
 .../com/examples/ds/PutDataSerializables.java   |   21 +-
 .../src/test/java/com/examples/ds/User.java     |   21 +-
 .../com/examples/snapshot/MyDataSerializer.java |   21 +-
 .../java/com/examples/snapshot/MyObject.java    |   23 +-
 .../snapshot/MyObjectDataSerializable.java      |   23 +-
 .../java/com/examples/snapshot/MyObjectPdx.java |   16 +
 .../snapshot/MyObjectPdxSerializable.java       |   21 +-
 .../com/examples/snapshot/MyPdxSerializer.java  |   21 +-
 .../java/com/gemstone/gemfire/AppObject.java    |   18 +-
 .../test/java/com/gemstone/gemfire/BadTest.java |   21 +-
 .../com/gemstone/gemfire/CopyJUnitTest.java     |   21 +-
 .../com/gemstone/gemfire/DeltaTestImpl.java     |   21 +-
 .../gemfire/DiskInstantiatorsJUnitTest.java     |   21 +-
 .../com/gemstone/gemfire/GemFireTestCase.java   |   21 +-
 .../java/com/gemstone/gemfire/Invariant.java    |   22 +-
 .../com/gemstone/gemfire/InvariantResult.java   |   22 +-
 .../com/gemstone/gemfire/JUnitTestSetup.java    |   21 +-
 .../gemfire/JtaNoninvolvementJUnitTest.java     |   21 +-
 .../gemfire/LocalStatisticsJUnitTest.java       |   21 +-
 .../com/gemstone/gemfire/LonerDMJUnitTest.java  |   21 +-
 .../gemstone/gemfire/StatisticsTestCase.java    |   21 +-
 .../gemfire/StatisticsTypeJUnitTest.java        |   21 +-
 .../com/gemstone/gemfire/TXExpiryJUnitTest.java |   90 +-
 .../java/com/gemstone/gemfire/TXJUnitTest.java  |   21 +-
 .../com/gemstone/gemfire/TXWriterJUnitTest.java |   21 +-
 .../gemstone/gemfire/TXWriterOOMEJUnitTest.java |   21 +-
 .../com/gemstone/gemfire/TXWriterTestCase.java  |   16 +
 .../gemstone/gemfire/TestDataSerializer.java    |   21 +-
 .../com/gemstone/gemfire/TimingTestCase.java    |   22 +-
 .../com/gemstone/gemfire/UnitTestDoclet.java    |   21 +-
 .../gemstone/gemfire/admin/AdminTestHelper.java |   16 +
 .../BindDistributedSystemJUnitTest.java         |   21 +-
 .../internal/CacheHealthEvaluatorJUnitTest.java |   21 +-
 .../internal/DistributedSystemTestCase.java     |   21 +-
 .../admin/internal/HealthEvaluatorTestCase.java |   21 +-
 .../MemberHealthEvaluatorJUnitTest.java         |   21 +-
 .../cache/AttributesFactoryJUnitTest.java       |   21 +-
 .../gemfire/cache/Bug36619JUnitTest.java        |   21 +-
 .../gemfire/cache/Bug42039JUnitTest.java        |   21 +-
 .../gemfire/cache/Bug52289JUnitTest.java        |   24 +-
 .../gemfire/cache/CacheListenerJUnitTest.java   |   21 +-
 .../cache/CacheRegionClearStatsDUnitTest.java   |   21 +-
 .../gemstone/gemfire/cache/ClientHelper.java    |   21 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |   16 +
 .../cache/ConnectionPoolAndLoaderDUnitTest.java |   21 +-
 .../cache/ConnectionPoolFactoryJUnitTest.java   |   21 +-
 .../gemfire/cache/OperationJUnitTest.java       |   21 +-
 .../gemfire/cache/PoolManagerJUnitTest.java     |   21 +-
 .../gemstone/gemfire/cache/ProxyJUnitTest.java  |   21 +-
 .../gemfire/cache/RegionFactoryJUnitTest.java   |   21 +-
 .../gemfire/cache/RoleExceptionJUnitTest.java   |   21 +-
 .../client/ClientCacheFactoryJUnitTest.java     |   21 +-
 .../client/ClientRegionFactoryJUnitTest.java    |   21 +-
 .../ClientServerRegisterInterestsDUnitTest.java |   16 +
 .../internal/AutoConnectionSourceDUnitTest.java |   21 +-
 .../AutoConnectionSourceImplJUnitTest.java      |   21 +-
 .../AutoConnectionSourceWithUDPDUnitTest.java   |   21 +-
 .../internal/CacheServerSSLConnectionDUnit.java |  648 -------
 .../CacheServerSSLConnectionDUnitTest.java      |  426 +++++
 .../internal/ConnectionPoolImplJUnitTest.java   |   21 +-
 .../internal/LocatorLoadBalancingDUnitTest.java |   21 +-
 .../cache/client/internal/LocatorTestBase.java  |   21 +-
 .../internal/OpExecutorImplJUnitTest.java       |   21 +-
 .../client/internal/QueueManagerJUnitTest.java  |   21 +-
 .../internal/SSLNoClientAuthDUnitTest.java      |  280 +++
 .../internal/ServerBlackListJUnitTest.java      |   21 +-
 .../locator/LocatorStatusResponseJUnitTest.java |   20 +-
 .../pooling/ConnectionManagerJUnitTest.java     |   21 +-
 .../ColocatedRegionWithHDFSDUnitTest.java       |  189 --
 .../hdfs/internal/HDFSConfigJUnitTest.java      |  520 ------
 .../hdfs/internal/HDFSEntriesSetJUnitTest.java  |  227 ---
 .../internal/HdfsStoreMutatorJUnitTest.java     |  191 --
 .../hdfs/internal/RegionRecoveryDUnitTest.java  |  415 -----
 .../internal/RegionWithHDFSBasicDUnitTest.java  | 1594 ----------------
 .../RegionWithHDFSOffHeapBasicDUnitTest.java    |  114 --
 ...RegionWithHDFSPersistenceBasicDUnitTest.java |   77 -
 .../hdfs/internal/RegionWithHDFSTestBase.java   |  715 -------
 .../SignalledFlushObserverJUnitTest.java        |   23 +-
 .../SortedListForAsyncQueueJUnitTest.java       |   31 +-
 .../internal/hoplog/BaseHoplogTestCase.java     |  389 ----
 .../hoplog/CardinalityEstimatorJUnitTest.java   |  188 --
 .../hoplog/HDFSCacheLoaderJUnitTest.java        |  106 --
 .../hoplog/HDFSCompactionManagerJUnitTest.java  |  449 -----
 .../hoplog/HDFSRegionDirectorJUnitTest.java     |   97 -
 .../internal/hoplog/HDFSStatsJUnitTest.java     |  250 ---
 .../HDFSUnsortedHoplogOrganizerJUnitTest.java   |  297 ---
 .../HdfsSortedOplogOrganizerJUnitTest.java      | 1045 -----------
 .../hoplog/HfileSortedOplogJUnitTest.java       |  540 ------
 .../hoplog/SortedOplogListIterJUnitTest.java    |  178 --
 .../hoplog/TieredCompactionJUnitTest.java       |  904 ---------
 .../hoplog/mapreduce/GFKeyJUnitTest.java        |   50 -
 .../mapreduce/HDFSSplitIteratorJUnitTest.java   |  265 ---
 .../hoplog/mapreduce/HoplogUtilJUnitTest.java   |  305 ---
 .../management/MXMemoryPoolListenerExample.java |   21 +-
 .../management/MemoryThresholdsDUnitTest.java   |   31 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |  181 +-
 .../management/ResourceManagerDUnitTest.java    |   21 +-
 .../ExceptionHandlingJUnitTest.java             |   21 +-
 .../mapInterface/MapFunctionalJUnitTest.java    |   21 +-
 .../mapInterface/PutAllGlobalLockJUnitTest.java |   21 +-
 .../PutOperationContextJUnitTest.java           |   16 +
 .../GetOperationContextImplJUnitTest.java       |   16 +
 .../partition/PartitionManagerDUnitTest.java    |   21 +-
 .../PartitionRegionHelperDUnitTest.java         |   21 +-
 .../BaseLineAndCompareQueryPerfJUnitTest.java   |   21 +-
 .../query/Bug32947ValueConstraintJUnitTest.java |   21 +-
 .../gemfire/cache/query/BugJUnitTest.java       |   21 +-
 .../gemfire/cache/query/CacheUtils.java         |   21 +-
 .../cache/query/PdxStringQueryJUnitTest.java    |   21 +-
 .../gemstone/gemfire/cache/query/PerfQuery.java |   22 +-
 .../gemfire/cache/query/QueryJUnitTest.java     |   21 +-
 .../cache/query/QueryServiceJUnitTest.java      |   21 +-
 .../gemfire/cache/query/QueryTestUtils.java     |   21 +-
 .../cache/query/QueryTestUtilsJUnitTest.java    |   21 +-
 .../gemfire/cache/query/RegionJUnitTest.java    |   21 +-
 .../cache/query/TypedIteratorJUnitTest.java     |   21 +-
 .../com/gemstone/gemfire/cache/query/Utils.java |   21 +-
 .../query/cq/dunit/CqQueryTestListener.java     |   21 +-
 .../gemfire/cache/query/data/Address.java       |   21 +-
 .../gemstone/gemfire/cache/query/data/City.java |   22 +-
 .../cache/query/data/CollectionHolder.java      |   22 +-
 .../cache/query/data/ComparableWrapper.java     |   22 +-
 .../gemfire/cache/query/data/Country.java       |   21 +-
 .../gemstone/gemfire/cache/query/data/Data.java |   22 +-
 .../gemfire/cache/query/data/District.java      |   22 +-
 .../gemfire/cache/query/data/Employee.java      |   21 +-
 .../gemfire/cache/query/data/Inventory.java     |   21 +-
 .../gemfire/cache/query/data/Keywords.java      |   21 +-
 .../gemfire/cache/query/data/Manager.java       |   21 +-
 .../gemfire/cache/query/data/Numbers.java       |   21 +-
 .../gemfire/cache/query/data/PhoneNo.java       |   21 +-
 .../gemfire/cache/query/data/Portfolio.java     |   22 +-
 .../gemfire/cache/query/data/PortfolioData.java |   21 +-
 .../gemfire/cache/query/data/PortfolioNoDS.java |   16 +
 .../gemfire/cache/query/data/PortfolioPdx.java  |   22 +-
 .../gemfire/cache/query/data/Position.java      |   21 +-
 .../gemfire/cache/query/data/PositionNoDS.java  |   16 +
 .../gemfire/cache/query/data/PositionPdx.java   |   21 +-
 .../query/data/ProhibitedSecurityQuote.java     |   21 +-
 .../gemfire/cache/query/data/Quote.java         |   21 +-
 .../gemfire/cache/query/data/Restricted.java    |   21 +-
 .../cache/query/data/SecurityMaster.java        |   21 +-
 .../gemfire/cache/query/data/State.java         |   21 +-
 .../gemfire/cache/query/data/Street.java        |   21 +-
 .../gemfire/cache/query/data/Student.java       |   23 +-
 .../gemfire/cache/query/data/Vehicle.java       |   21 +-
 .../gemfire/cache/query/data/Village.java       |   21 +-
 .../query/dunit/CloseCacheAuthorization.java    |   16 +
 .../query/dunit/CompactRangeIndexDUnitTest.java |   21 +-
 .../cache/query/dunit/CqTimeTestListener.java   |   21 +-
 .../cache/query/dunit/GroupByDUnitImpl.java     |   16 +
 .../dunit/GroupByPartitionedQueryDUnitTest.java |   16 +
 .../query/dunit/GroupByQueryDUnitTest.java      |   16 +
 .../cache/query/dunit/HashIndexDUnitTest.java   |   21 +-
 .../cache/query/dunit/HelperTestCase.java       |   16 +
 .../dunit/NonDistinctOrderByDUnitImpl.java      |   16 +
 .../NonDistinctOrderByPartitionedDUnitTest.java |   16 +
 .../query/dunit/PdxStringQueryDUnitTest.java    |   21 +-
 .../dunit/QueryAPITestPartitionResolver.java    |   22 +-
 .../cache/query/dunit/QueryAuthorization.java   |   21 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java  |   24 +-
 .../dunit/QueryIndexUsingXMLDUnitTest.java      |   21 +-
 .../QueryParamsAuthorizationDUnitTest.java      |   21 +-
 .../QueryUsingFunctionContextDUnitTest.java     |   47 +-
 .../query/dunit/QueryUsingPoolDUnitTest.java    |   21 +-
 .../cache/query/dunit/RemoteQueryDUnitTest.java |   21 +-
 ...esourceManagerWithQueryMonitorDUnitTest.java |   21 +-
 .../query/dunit/SelectStarQueryDUnitTest.java   |   21 +-
 .../cache/query/facets/lang/Address.java        |   23 +-
 .../gemfire/cache/query/facets/lang/Course.java |   23 +-
 .../cache/query/facets/lang/Department.java     |   23 +-
 .../query/facets/lang/DerivedEmployee.java      |   22 +-
 .../cache/query/facets/lang/Employee.java       |   21 +-
 .../cache/query/facets/lang/Faculty.java        |   21 +-
 .../cache/query/facets/lang/G_Student.java      |   23 +-
 .../gemfire/cache/query/facets/lang/Person.java |   23 +-
 .../cache/query/facets/lang/Student.java        |   23 +-
 .../cache/query/facets/lang/UG_Student.java     |   23 +-
 .../gemfire/cache/query/facets/lang/Utils.java  |   20 +-
 .../ComparisonOperatorsJUnitTest.java           |   21 +-
 .../query/functional/ConstantsJUnitTest.java    |   21 +-
 .../query/functional/CountStarJUnitTest.java    |   21 +-
 .../CustomerOptimizationsJUnitTest.java         |   21 +-
 .../DistinctAndNonDistinctQueryJUnitTest.java   |   29 +-
 ...ctResultsWithDupValuesInRegionJUnitTest.java |   21 +-
 .../query/functional/FunctionJUnitTest.java     |   21 +-
 .../functional/GroupByPartitionedJUnitTest.java |   16 +
 .../functional/GroupByReplicatedJUnitTest.java  |   16 +
 .../cache/query/functional/GroupByTestImpl.java |   21 +-
 .../query/functional/GroupByTestInterface.java  |   16 +
 .../query/functional/INOperatorJUnitTest.java   |   21 +-
 .../functional/IUM6Bug32345ReJUnitTest.java     |   21 +-
 .../cache/query/functional/IUMJUnitTest.java    |   21 +-
 .../IUMRCompositeIteratorJUnitTest.java         |   21 +-
 .../IUMRMultiIndexesMultiRegionJUnitTest.java   |   21 +-
 .../IUMRShuffleIteratorsJUnitTest.java          |   21 +-
 .../functional/IUMRSingleRegionJUnitTest.java   |   21 +-
 ...ependentOperandsInWhereClause2JUnitTest.java |   21 +-
 .../IndexCreationDeadLockJUnitTest.java         |   21 +-
 .../functional/IndexCreationJUnitTest.java      |   21 +-
 .../IndexMaintenanceAsynchJUnitTest.java        |   21 +-
 .../functional/IndexOperatorJUnitTest.java      |   21 +-
 .../IndexPrimaryKeyUsageJUnitTest.java          |   21 +-
 .../IndexUsageInNestedQueryJUnitTest.java       |   21 +-
 .../IndexUsageWithAliasAsProjAtrbt.java         |   21 +-
 ...IndexUsageWithAliasAsProjAtrbtJUnitTest.java |   21 +-
 .../IndexUseMultFrmSnglCondJUnitTest.java       |   21 +-
 ...ndexWithSngleFrmAndMultCondQryJUnitTest.java |   21 +-
 .../functional/IteratorTypeDefEmpJUnitTest.java |   21 +-
 .../functional/IteratorTypeDefJUnitTest.java    |   21 +-
 .../IteratorTypeDefaultTypesJUnitTest.java      |   21 +-
 .../functional/IumMultConditionJUnitTest.java   |   21 +-
 .../functional/JavaSerializationJUnitTest.java  |   21 +-
 .../functional/LikePredicateJUnitTest.java      |   21 +-
 .../query/functional/LimitClauseJUnitTest.java  |   21 +-
 .../functional/LogicalOperatorsJUnitTest.java   |   21 +-
 .../cache/query/functional/MiscJUnitTest.java   |   21 +-
 .../functional/MultiIndexCreationJUnitTest.java |   16 +
 .../MultiRegionIndexUsageJUnitTest.java         |   21 +-
 .../functional/MultipleRegionsJUnitTest.java    |   21 +-
 .../NegativeNumberQueriesJUnitTest.java         |   21 +-
 .../query/functional/NestedQueryJUnitTest.java  |   21 +-
 .../NonDistinctOrderByPartitionedJUnitTest.java |   16 +
 .../NonDistinctOrderByReplicatedJUnitTest.java  |   16 +
 .../NonDistinctOrderByTestImplementation.java   |   21 +-
 .../query/functional/NumericQueryJUnitTest.java |   21 +-
 .../functional/OrderByPartitionedJUnitTest.java |   16 +
 .../functional/OrderByReplicatedJUnitTest.java  |   16 +
 .../functional/OrderByTestImplementation.java   |   21 +-
 .../functional/ParameterBindingJUnitTest.java   |   21 +-
 .../PdxGroupByPartitionedJUnitTest.java         |   16 +
 .../PdxGroupByReplicatedJUnitTest.java          |   16 +
 .../query/functional/PdxGroupByTestImpl.java    |   16 +
 .../query/functional/PdxOrderByJUnitTest.java   |   16 +
 .../functional/QRegionInterfaceJUnitTest.java   |   21 +-
 .../QueryREUpdateInProgressJUnitTest.java       |   21 +-
 .../functional/QueryUndefinedJUnitTest.java     |   21 +-
 .../functional/ReservedKeywordsJUnitTest.java   |   21 +-
 .../ResultsDataSerializabilityJUnitTest.java    |   21 +-
 .../query/functional/SelectToDateJUnitTest.java |   21 +-
 .../functional/StructMemberAccessJUnitTest.java |   21 +-
 .../query/functional/StructSetOrResultsSet.java |   25 +-
 .../query/functional/TestNewFunctionSSorRS.java |   21 +-
 .../CompiledAggregateFunctionJUnitTest.java     |   16 +
 .../CompiledGroupBySelectJUnitTest.java         |   16 +
 .../CompiledJunctionInternalsJUnitTest.java     |   21 +-
 .../internal/CopyOnReadQueryJUnitTest.java      |   21 +-
 .../internal/ExecutionContextJUnitTest.java     |   21 +-
 .../query/internal/IndexManagerJUnitTest.java   |   21 +-
 .../internal/NWayMergeResultsJUnitTest.java     |   16 +
 .../internal/OrderByComparatorJUnitTest.java    |   16 +
 .../internal/ProjectionAttributeJUnitTest.java  |   21 +-
 .../query/internal/QCompilerJUnitTest.java      |   21 +-
 ...ueryFromClauseCanonicalizationJUnitTest.java |   21 +-
 .../QueryObjectSerializationJUnitTest.java      |   21 +-
 .../QueryObserverCallbackJUnitTest.java         |   21 +-
 .../query/internal/QueryTraceJUnitTest.java     |   21 +-
 .../query/internal/QueryUtilsJUnitTest.java     |   21 +-
 .../query/internal/ResultsBagJUnitTest.java     |   21 +-
 .../ResultsBagLimitBehaviourJUnitTest.java      |   21 +-
 .../ResultsCollectionWrapperLimitJUnitTest.java |   21 +-
 .../SelectResultsComparatorJUnitTest.java       |   21 +-
 .../StructBagLimitBehaviourJUnitTest.java       |   21 +-
 .../query/internal/StructSetJUnitTest.java      |   21 +-
 .../internal/aggregate/AggregatorJUnitTest.java |   16 +
 ...syncIndexUpdaterThreadShutdownJUnitTest.java |   21 +-
 .../index/AsynchIndexMaintenanceJUnitTest.java  |   21 +-
 .../CompactRangeIndexIndexMapJUnitTest.java     |   21 +-
 .../index/CompactRangeIndexJUnitTest.java       |   21 +-
 ...rrentIndexInitOnOverflowRegionDUnitTest.java |   21 +-
 ...ndexOperationsOnOverflowRegionDUnitTest.java |   21 +-
 ...pdateWithInplaceObjectModFalseDUnitTest.java |   21 +-
 ...ConcurrentIndexUpdateWithoutWLDUnitTest.java |   21 +-
 .../index/CopyOnReadIndexDUnitTest.java         |   95 +-
 .../index/CopyOnReadIndexJUnitTest.java         |   21 +-
 .../DeclarativeIndexCreationJUnitTest.java      |   21 +-
 .../internal/index/HashIndexJUnitTest.java      |   21 +-
 .../index/IndexCreationInternalsJUnitTest.java  |   21 +-
 .../internal/index/IndexElemArrayJUnitTest.java |   21 +-
 .../internal/index/IndexHintJUnitTest.java      |   16 +
 .../query/internal/index/IndexJUnitTest.java    |   21 +-
 .../index/IndexMaintainceJUnitTest.java         |   21 +-
 .../index/IndexMaintenanceJUnitTest.java        |   21 +-
 .../index/IndexStatisticsJUnitTest.java         |   21 +-
 .../IndexTrackingQueryObserverDUnitTest.java    |   21 +-
 .../IndexTrackingQueryObserverJUnitTest.java    |   21 +-
 .../query/internal/index/IndexUseJUnitTest.java |   21 +-
 .../IndexedMergeEquiJoinScenariosJUnitTest.java |   21 +-
 ...itializeIndexEntryDestroyQueryDUnitTest.java |   21 +-
 .../internal/index/MapIndexStoreJUnitTest.java  |   21 +-
 .../MapRangeIndexMaintenanceJUnitTest.java      |   21 +-
 .../index/MultiIndexCreationDUnitTest.java      |   16 +
 .../NewDeclarativeIndexCreationJUnitTest.java   |   21 +-
 .../index/PdxCopyOnReadQueryJUnitTest.java      |   16 +
 ...gRegionCreationIndexUpdateTypeJUnitTest.java |   21 +-
 .../PutAllWithIndexPerfDUnitDisabledTest.java   |   21 +-
 .../internal/index/RangeIndexAPIJUnitTest.java  |   23 +-
 .../PRBasicIndexCreationDUnitTest.java          |   20 +-
 .../PRBasicIndexCreationDeadlockDUnitTest.java  |   20 +-
 .../PRBasicMultiIndexCreationDUnitTest.java     |   20 +-
 .../partitioned/PRBasicQueryDUnitTest.java      |   20 +-
 .../PRBasicRemoveIndexDUnitTest.java            |   21 +-
 .../PRColocatedEquiJoinDUnitTest.java           |   21 +-
 .../partitioned/PRIndexStatisticsJUnitTest.java |   21 +-
 .../partitioned/PRInvalidQueryDUnitTest.java    |   20 +-
 .../partitioned/PRInvalidQueryJUnitTest.java    |   21 +-
 .../partitioned/PRQueryCacheCloseDUnitTest.java |   20 +-
 .../PRQueryCacheClosedJUnitTest.java            |   21 +-
 .../query/partitioned/PRQueryDUnitHelper.java   |   20 +-
 .../query/partitioned/PRQueryDUnitTest.java     |   20 +-
 .../query/partitioned/PRQueryJUnitTest.java     |   21 +-
 .../partitioned/PRQueryNumThreadsJUnitTest.java |   21 +-
 .../query/partitioned/PRQueryPerfDUnitTest.java |   20 +-
 .../PRQueryRegionCloseDUnitTest.java            |   20 +-
 .../PRQueryRegionClosedJUnitTest.java           |   21 +-
 .../PRQueryRegionDestroyedDUnitTest.java        |   20 +-
 .../PRQueryRegionDestroyedJUnitTest.java        |   21 +-
 .../PRQueryRemoteNodeExceptionDUnitTest.java    |   21 +-
 .../gemfire/cache/query/transaction/Person.java |   21 +-
 .../query/transaction/QueryAndJtaJUnitTest.java |   21 +-
 .../internal/ConnectionCountProbeJUnitTest.java |   21 +-
 .../cache/snapshot/CacheSnapshotJUnitTest.java  |   21 +-
 .../snapshot/ParallelSnapshotDUnitTest.java     |   21 +-
 .../gemfire/cache/snapshot/RegionGenerator.java |   21 +-
 .../cache/snapshot/RegionSnapshotJUnitTest.java |   21 +-
 .../snapshot/SnapshotByteArrayDUnitTest.java    |   21 +-
 .../cache/snapshot/SnapshotDUnitTest.java       |   21 +-
 .../snapshot/SnapshotPerformanceDUnitTest.java  |   21 +-
 .../cache/snapshot/SnapshotTestCase.java        |   21 +-
 .../cache/snapshot/WanSnapshotJUnitTest.java    |   21 +-
 .../cache/util/PasswordUtilJUnitTest.java       |   21 +-
 .../gemfire/cache30/Bug34387DUnitTest.java      |   21 +-
 .../gemfire/cache30/Bug34948DUnitTest.java      |   21 +-
 .../gemfire/cache30/Bug35214DUnitTest.java      |   21 +-
 .../gemfire/cache30/Bug38013DUnitTest.java      |   21 +-
 .../gemfire/cache30/Bug38741DUnitTest.java      |   21 +-
 .../cache30/Bug40255JUnitDisabledTest.java      |   22 +-
 .../cache30/Bug40662JUnitDisabledTest.java      |   21 +-
 .../gemfire/cache30/Bug44418JUnitTest.java      |   21 +-
 .../gemfire/cache30/CacheCloseDUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheListenerTestCase.java  |   21 +-
 .../gemfire/cache30/CacheLoaderTestCase.java    |   21 +-
 .../gemfire/cache30/CacheLogRollDUnitTest.java  |   21 +-
 .../gemfire/cache30/CacheMapTxnDUnitTest.java   |   22 +-
 ...cheRegionsReliablityStatsCheckDUnitTest.java |   21 +-
 .../cache30/CacheSerializableRunnable.java      |   21 +-
 .../cache30/CacheStatisticsDUnitTest.java       |   21 +-
 .../gemstone/gemfire/cache30/CacheTestCase.java |   67 +-
 .../gemfire/cache30/CacheWriterTestCase.java    |   21 +-
 .../cache30/CacheXMLPartitionResolver.java      |   21 +-
 .../gemfire/cache30/CacheXml30DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml40DUnitTest.java    |   37 +-
 .../gemfire/cache30/CacheXml41DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml45DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml51DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml55DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml57DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml58DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml60DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml61DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml65DUnitTest.java    |   22 +-
 .../gemfire/cache30/CacheXml66DUnitTest.java    |   21 +-
 .../gemfire/cache30/CacheXml70DUnitTest.java    |   22 +-
 .../gemfire/cache30/CacheXml80DUnitTest.java    |   22 +-
 .../gemfire/cache30/CacheXml81DUnitTest.java    |   22 +-
 .../gemfire/cache30/CacheXml90DUnitTest.java    |   22 +-
 .../gemfire/cache30/CacheXmlTestCase.java       |   16 +
 .../cache30/CachedAllEventsDUnitTest.java       |   21 +-
 .../gemfire/cache30/CallbackArgDUnitTest.java   |   21 +-
 .../cache30/CertifiableTestCacheListener.java   |   24 +-
 .../cache30/ClearMultiVmCallBkDUnitTest.java    |   22 +-
 .../gemfire/cache30/ClearMultiVmDUnitTest.java  |   22 +-
 .../cache30/ClientMembershipDUnitTest.java      |   21 +-
 .../ClientMembershipSelectorDUnitTest.java      |   16 +
 .../ClientRegisterInterestDUnitTest.java        |   21 +-
 ...ClientRegisterInterestSelectorDUnitTest.java |   16 +
 .../cache30/ClientServerCCEDUnitTest.java       |   21 +-
 .../gemfire/cache30/ClientServerTestCase.java   |   21 +-
 .../ConcurrentLeaveDuringGIIDUnitTest.java      |   21 +-
 ...ibutedNoAckAsyncOverflowRegionDUnitTest.java |   22 +-
 ...iskDistributedNoAckAsyncRegionDUnitTest.java |   22 +-
 .../DiskDistributedNoAckRegionTestCase.java     |   22 +-
 ...ributedNoAckSyncOverflowRegionDUnitTest.java |   22 +-
 .../gemfire/cache30/DiskRegionDUnitTest.java    |   21 +-
 .../gemfire/cache30/DiskRegionTestImpl.java     |   22 +-
 .../cache30/DistAckMapMethodsDUnitTest.java     |   22 +-
 ...ckOverflowRegionCCECompressionDUnitTest.java |   21 +-
 ...istributedAckOverflowRegionCCEDUnitTest.java |   21 +-
 ...tedAckOverflowRegionCCEOffHeapDUnitTest.java |   16 +
 ...PersistentRegionCCECompressionDUnitTest.java |   21 +-
 ...tributedAckPersistentRegionCCEDUnitTest.java |   22 +-
 ...dAckPersistentRegionCCEOffHeapDUnitTest.java |   16 +
 .../DistributedAckRegionCCEDUnitTest.java       |   22 +-
 ...DistributedAckRegionCCEOffHeapDUnitTest.java |   16 +
 ...istributedAckRegionCompressionDUnitTest.java |   21 +-
 .../cache30/DistributedAckRegionDUnitTest.java  |   21 +-
 .../DistributedAckRegionOffHeapDUnitTest.java   |   16 +
 .../DistributedNoAckRegionCCEDUnitTest.java     |   23 +-
 ...stributedNoAckRegionCCEOffHeapDUnitTest.java |   16 +
 ...tributedNoAckRegionCompressionDUnitTest.java |   21 +-
 .../DistributedNoAckRegionDUnitTest.java        |   21 +-
 .../DistributedNoAckRegionOffHeapDUnitTest.java |   16 +
 .../gemfire/cache30/DynamicRegionDUnitTest.java |   21 +-
 .../gemfire/cache30/GlobalLockingDUnitTest.java |   21 +-
 .../cache30/GlobalRegionCCEDUnitTest.java       |   22 +-
 .../GlobalRegionCCEOffHeapDUnitTest.java        |   16 +
 .../GlobalRegionCompressionDUnitTest.java       |   21 +-
 .../gemfire/cache30/GlobalRegionDUnitTest.java  |   21 +-
 .../cache30/GlobalRegionOffHeapDUnitTest.java   |   16 +
 .../cache30/LRUEvictionControllerDUnitTest.java |   21 +-
 .../gemfire/cache30/LocalRegionDUnitTest.java   |   21 +-
 .../MemLRUEvictionControllerDUnitTest.java      |   21 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  |  120 +-
 .../gemfire/cache30/MyGatewayEventFilter1.java  |   21 +-
 .../gemfire/cache30/MyGatewayEventFilter2.java  |   23 +-
 .../cache30/MyGatewayTransportFilter1.java      |   21 +-
 .../cache30/MyGatewayTransportFilter2.java      |   21 +-
 .../OffHeapLRUEvictionControllerDUnitTest.java  |   21 +-
 .../PRBucketSynchronizationDUnitTest.java       |   21 +-
 .../PartitionedRegionCompressionDUnitTest.java  |   21 +-
 .../cache30/PartitionedRegionDUnitTest.java     |   21 +-
 ...tionedRegionMembershipListenerDUnitTest.java |   22 +-
 .../PartitionedRegionOffHeapDUnitTest.java      |   16 +
 .../cache30/PreloadedRegionTestCase.java        |   21 +-
 .../gemfire/cache30/ProxyDUnitTest.java         |   21 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java  |   22 +-
 .../cache30/PutAllCallBkSingleVMDUnitTest.java  |   22 +-
 .../gemfire/cache30/PutAllMultiVmDUnitTest.java |   22 +-
 .../gemfire/cache30/QueueMsgDUnitTest.java      |   21 +-
 .../cache30/RRSynchronizationDUnitTest.java     |   21 +-
 .../gemfire/cache30/ReconnectDUnitTest.java     |   21 +-
 .../ReconnectedCacheServerDUnitTest.java        |   21 +-
 .../cache30/RegionAttributesTestCase.java       |   21 +-
 .../cache30/RegionExpirationDUnitTest.java      |   21 +-
 .../RegionMembershipListenerDUnitTest.java      |   21 +-
 .../RegionReliabilityDistAckDUnitTest.java      |   21 +-
 .../RegionReliabilityDistNoAckDUnitTest.java    |   21 +-
 .../RegionReliabilityGlobalDUnitTest.java       |   21 +-
 .../RegionReliabilityListenerDUnitTest.java     |   21 +-
 .../cache30/RegionReliabilityTestCase.java      |  105 +-
 .../gemfire/cache30/RegionTestCase.java         |   51 +-
 .../gemfire/cache30/ReliabilityTestCase.java    |   21 +-
 .../cache30/RemoveAllMultiVmDUnitTest.java      |   22 +-
 .../gemfire/cache30/RequiredRolesDUnitTest.java |   21 +-
 .../cache30/RolePerformanceDUnitTest.java       |   21 +-
 .../gemfire/cache30/SearchAndLoadDUnitTest.java |   21 +-
 .../cache30/SlowRecDUnitDisabledTest.java       |   21 +-
 .../gemfire/cache30/TXDistributedDUnitTest.java |   21 +-
 .../gemfire/cache30/TXOrderDUnitTest.java       |   21 +-
 .../cache30/TXRestrictionsDUnitTest.java        |   21 +-
 .../gemfire/cache30/TestCacheCallback.java      |   21 +-
 .../gemfire/cache30/TestCacheListener.java      |   21 +-
 .../gemfire/cache30/TestCacheLoader.java        |   21 +-
 .../gemfire/cache30/TestCacheWriter.java        |   21 +-
 .../gemfire/cache30/TestDiskRegion.java         |   21 +-
 .../gemstone/gemfire/cache30/TestHeapLRU.java   |   21 +-
 .../gemfire/cache30/TestPdxSerializer.java      |   21 +-
 .../cache30/TestTransactionListener.java        |   21 +-
 .../gemfire/cache30/TestTransactionWriter.java  |   21 +-
 .../AnalyzeSerializablesJUnitTest.java          |   47 +-
 .../codeAnalysis/ClassAndMethodDetails.java     |   23 +-
 .../gemfire/codeAnalysis/ClassAndMethods.java   |   23 +-
 .../codeAnalysis/ClassAndVariableDetails.java   |   23 +-
 .../gemfire/codeAnalysis/ClassAndVariables.java |   23 +-
 .../codeAnalysis/CompiledClassUtils.java        |   23 +-
 .../codeAnalysis/decode/CompiledAttribute.java  |   21 +-
 .../codeAnalysis/decode/CompiledClass.java      |   21 +-
 .../codeAnalysis/decode/CompiledCode.java       |   21 +-
 .../codeAnalysis/decode/CompiledField.java      |   21 +-
 .../codeAnalysis/decode/CompiledMethod.java     |   21 +-
 .../gemfire/codeAnalysis/decode/cp/Cp.java      |   21 +-
 .../gemfire/codeAnalysis/decode/cp/CpClass.java |   21 +-
 .../codeAnalysis/decode/cp/CpDouble.java        |   21 +-
 .../codeAnalysis/decode/cp/CpFieldref.java      |   18 +-
 .../gemfire/codeAnalysis/decode/cp/CpFloat.java |   18 +-
 .../codeAnalysis/decode/cp/CpInteger.java       |   18 +-
 .../decode/cp/CpInterfaceMethodref.java         |   18 +-
 .../gemfire/codeAnalysis/decode/cp/CpLong.java  |   21 +-
 .../codeAnalysis/decode/cp/CpMethodref.java     |   18 +-
 .../codeAnalysis/decode/cp/CpNameAndType.java   |   18 +-
 .../codeAnalysis/decode/cp/CpString.java        |   18 +-
 .../gemfire/codeAnalysis/decode/cp/CpUtf8.java  |   21 +-
 .../distributed/AbstractLauncherJUnitTest.java  |   20 +-
 .../AbstractLauncherJUnitTestCase.java          |   16 +
 .../AbstractLauncherServiceStatusJUnitTest.java |   21 +-
 .../AbstractLocatorLauncherJUnitTestCase.java   |   16 +
 .../AbstractServerLauncherJUnitTestCase.java    |   16 +
 .../gemfire/distributed/AuthInitializer.java    |   23 +-
 .../distributed/CommonLauncherTestSuite.java    |   20 +-
 .../distributed/DistributedMemberDUnitTest.java |   21 +-
 .../DistributedSystemConnectPerf.java           |   21 +-
 .../distributed/DistributedSystemDUnitTest.java |   21 +-
 .../distributed/DistributedTestSuite.java       |   16 +
 .../distributed/HostedLocatorsDUnitTest.java    |   16 +
 .../gemfire/distributed/JGroupsJUnitTest.java   |   21 +-
 .../LauncherMemberMXBeanJUnitTest.java          |   16 +
 .../gemfire/distributed/LauncherTestSuite.java  |   16 +
 .../gemfire/distributed/LocatorDUnitTest.java   |   21 +-
 .../gemfire/distributed/LocatorJUnitTest.java   |   21 +-
 .../distributed/LocatorLauncherJUnitTest.java   |   45 +-
 .../LocatorLauncherLocalFileJUnitTest.java      |   16 +
 .../LocatorLauncherLocalJUnitTest.java          |  108 +-
 .../LocatorLauncherRemoteFileJUnitTest.java     |   20 +-
 .../LocatorLauncherRemoteJUnitTest.java         |   20 +-
 .../gemfire/distributed/MyAuthenticator.java    |   23 +-
 .../gemfire/distributed/MyPrincipal.java        |   18 +-
 .../gemfire/distributed/RoleDUnitTest.java      |   21 +-
 .../distributed/ServerLauncherJUnitTest.java    |   78 +-
 .../ServerLauncherLocalFileJUnitTest.java       |   20 +-
 .../ServerLauncherLocalJUnitTest.java           |  136 +-
 .../ServerLauncherRemoteFileJUnitTest.java      |   16 +
 .../ServerLauncherRemoteJUnitTest.java          |   32 +-
 .../ServerLauncherWithSpringJUnitTest.java      |   16 +
 .../distributed/SystemAdminDUnitTest.java       |   21 +-
 .../AtomicLongWithTerminalStateJUnitTest.java   |   21 +-
 .../distributed/internal/Bug40751DUnitTest.java |   21 +-
 .../ConsoleDistributionManagerDUnitTest.java    |   21 +-
 .../distributed/internal/DateMessage.java       |   21 +-
 .../internal/DistributionAdvisorDUnitTest.java  |   21 +-
 .../internal/DistributionManagerDUnitTest.java  |   21 +-
 ...istributionManagerTimeDUnitDisabledTest.java |   21 +-
 .../GemFireTimeSyncServiceDUnitTest.java        |   21 +-
 .../InternalDistributedSystemJUnitTest.java     |   45 +-
 .../gemfire/distributed/internal/LDM.java       |   21 +-
 .../internal/LocalDistributionManagerTest.java  |   21 +-
 .../internal/LocatorLoadSnapshotJUnitTest.java  |   21 +-
 .../internal/ProduceDateMessages.java           |   21 +-
 .../internal/ProductUseLogDUnitTest.java        |   21 +-
 .../internal/ProductUseLogJUnitTest.java        |   21 +-
 .../internal/ServerLocatorJUnitTest.java        |   20 +-
 .../internal/SharedConfigurationJUnitTest.java  |   21 +-
 .../internal/StartupMessageDataJUnitTest.java   |   21 +-
 .../deadlock/DeadlockDetectorJUnitTest.java     |   21 +-
 .../deadlock/DependencyGraphJUnitTest.java      |   21 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |   70 +-
 .../deadlock/UnsafeThreadLocalJUnitTest.java    |   21 +-
 .../locks/CollaborationJUnitDisabledTest.java   |   21 +-
 .../internal/locks/DLockGrantorHelper.java      |   21 +-
 ...entrantReadWriteWriteShareLockJUnitTest.java |   21 +-
 .../membership/MembershipJUnitTest.java         |   21 +-
 .../jgroup/MembershipManagerHelper.java         |   21 +-
 .../StreamingOperationManyDUnitTest.java        |   29 +-
 .../StreamingOperationOneDUnitTest.java         |   29 +-
 .../tcpserver/LocatorVersioningJUnitTest.java   |   17 +-
 ...cpServerBackwardCompatDUnitDisabledTest.java |   17 +-
 .../tcpserver/TcpServerJUnitDisabledTest.java   |   16 +
 .../support/DistributedSystemAdapter.java       |   21 +-
 .../gemfire/disttx/CacheMapDistTXDUnitTest.java |   16 +
 .../gemfire/disttx/DistTXDebugDUnitTest.java    |   29 +-
 .../disttx/DistTXDistributedTestSuite.java      |   16 +
 .../gemfire/disttx/DistTXExpiryJUnitTest.java   |   16 +
 .../gemfire/disttx/DistTXJUnitTest.java         |   16 +
 .../disttx/DistTXManagerImplJUnitTest.java      |   16 +
 .../gemfire/disttx/DistTXOrderDUnitTest.java    |   16 +
 .../disttx/DistTXPersistentDebugDUnitTest.java  |   19 +-
 .../DistTXReleasesOffHeapOnCloseJUnitTest.java  |   16 +
 .../disttx/DistTXRestrictionsDUnitTest.java     |   16 +
 .../disttx/DistTXWithDeltaDUnitTest.java        |   16 +
 .../gemfire/disttx/DistTXWriterJUnitTest.java   |   16 +
 .../disttx/DistTXWriterOOMEJUnitTest.java       |   16 +
 .../disttx/DistributedTransactionDUnitTest.java |   18 +-
 .../gemfire/disttx/PRDistTXDUnitTest.java       |   16 +
 .../gemfire/disttx/PRDistTXJUnitTest.java       |   16 +
 .../disttx/PRDistTXWithVersionsDUnitTest.java   |   16 +
 ...entPartitionedRegionWithDistTXDUnitTest.java |   16 +
 .../gemfire/internal/ArrayEqualsJUnitTest.java  |   21 +-
 .../gemfire/internal/AvailablePortHelper.java   |   21 +-
 .../internal/AvailablePortJUnitTest.java        |   21 +-
 ...wardCompatibilitySerializationJUnitTest.java |   21 +-
 .../gemfire/internal/Bug49856JUnitTest.java     |   21 +-
 .../gemfire/internal/Bug51616JUnitTest.java     |   16 +
 .../gemfire/internal/ByteArrayData.java         |   21 +-
 .../gemstone/gemfire/internal/ClassBuilder.java |   21 +-
 .../ClassNotFoundExceptionDUnitTest.java        |   21 +-
 .../internal/ClassPathLoaderJUnitTest.java      |   21 +-
 .../internal/CopyOnWriteHashSetJUnitTest.java   |   21 +-
 .../internal/DataSerializableJUnitTest.java     |   21 +-
 .../gemstone/gemfire/internal/FDDUnitTest.java  |   23 +-
 .../gemfire/internal/FileUtilJUnitTest.java     |   21 +-
 .../internal/GemFireStatSamplerJUnitTest.java   |   21 +-
 .../GemFireVersionIntegrationJUnitTest.java     |   21 +-
 .../internal/GemFireVersionJUnitTest.java       |   21 +-
 .../internal/HeapDataOutputStreamJUnitTest.java |   21 +-
 .../gemfire/internal/InlineKeyJUnitTest.java    |   21 +-
 .../gemfire/internal/JSSESocketJUnitTest.java   |   21 +-
 .../internal/JarClassLoaderJUnitTest.java       |   22 +-
 .../gemfire/internal/JarDeployerDUnitTest.java  |   22 +-
 .../com/gemstone/gemfire/internal/JavaExec.java |   21 +-
 .../gemfire/internal/LineWrapUnitJUnitTest.java |   21 +-
 .../gemstone/gemfire/internal/LongBuffer.java   |   21 +-
 .../gemfire/internal/NanoTimerJUnitTest.java    |   21 +-
 .../gemfire/internal/ObjIdMapJUnitTest.java     |   21 +-
 .../internal/OneTaskOnlyDecoratorJUnitTest.java |   21 +-
 .../internal/PdxDeleteFieldDUnitTest.java       |   16 +
 .../internal/PdxDeleteFieldJUnitTest.java       |   16 +
 .../gemfire/internal/PdxRenameDUnitTest.java    |   16 +
 .../gemfire/internal/PdxRenameJUnitTest.java    |   16 +
 .../PutAllOperationContextJUnitTest.java        |   21 +-
 .../internal/SSLConfigIntegrationJUnitTest.java |   16 +
 .../gemfire/internal/SSLConfigJUnitTest.java    |   20 +-
 ...hreadPoolExecutorWithKeepAliveJUnitTest.java |   21 +-
 .../internal/SimpleStatSamplerJUnitTest.java    |   21 +-
 .../gemfire/internal/SocketCloserJUnitTest.java |   16 +
 .../internal/SocketCloserWithWaitJUnitTest.java |   16 +
 .../StatArchiveWriterReaderJUnitTest.java       |   21 +-
 .../gemfire/internal/StatSamplerJUnitTest.java  |   21 +-
 .../gemfire/internal/StatSamplerTestCase.java   |   21 +-
 .../internal/UniqueIdGeneratorJUnitTest.java    |   21 +-
 .../internal/cache/AbstractRegionJUnitTest.java |   21 +-
 .../gemfire/internal/cache/BackupDUnitTest.java |   21 +-
 .../gemfire/internal/cache/BackupJUnitTest.java |   21 +-
 .../internal/cache/Bug33359DUnitTest.java       |   21 +-
 .../internal/cache/Bug33726DUnitTest.java       |   21 +-
 .../internal/cache/Bug33726JUnitTest.java       |   21 +-
 .../Bug34179TooManyFilesOpenJUnitTest.java      |   21 +-
 .../internal/cache/Bug34583JUnitTest.java       |   21 +-
 .../internal/cache/Bug37241DUnitTest.java       |   21 +-
 .../internal/cache/Bug37244JUnitTest.java       |   21 +-
 .../internal/cache/Bug37377DUnitTest.java       |   21 +-
 .../internal/cache/Bug37500JUnitTest.java       |   21 +-
 .../internal/cache/Bug39079DUnitTest.java       |   21 +-
 .../internal/cache/Bug40299DUnitTest.java       |   21 +-
 .../internal/cache/Bug40632DUnitTest.java       |   21 +-
 .../internal/cache/Bug41091DUnitTest.java       |   21 +-
 .../internal/cache/Bug41733DUnitTest.java       |   21 +-
 .../internal/cache/Bug41957DUnitTest.java       |   21 +-
 .../internal/cache/Bug42010StatsDUnitTest.java  |   21 +-
 .../internal/cache/Bug42055DUnitTest.java       |   21 +-
 .../internal/cache/Bug45164DUnitTest.java       |   21 +-
 .../internal/cache/Bug45934DUnitTest.java       |   21 +-
 .../internal/cache/Bug47667DUnitTest.java       |   21 +-
 .../internal/cache/Bug48182JUnitTest.java       |   16 +
 .../internal/cache/CacheAdvisorDUnitTest.java   |   21 +-
 .../cache/CacheLifecycleListenerJUnitTest.java  |   21 +-
 .../cache/ChunkValueWrapperJUnitTest.java       |   16 +
 .../internal/cache/ClearDAckDUnitTest.java      |   21 +-
 .../internal/cache/ClearGlobalDUnitTest.java    |   21 +-
 ...ssagesRegionCreationAndDestroyJUnitTest.java |   21 +-
 .../cache/ClientServerGetAllDUnitTest.java      |   21 +-
 ...ServerInvalidAndDestroyedEntryDUnitTest.java |   21 +-
 .../ClientServerTransactionCCEDUnitTest.java    |   21 +-
 .../cache/ClientServerTransactionDUnitTest.java |   43 +-
 .../cache/ComplexDiskRegionJUnitTest.java       |   21 +-
 .../ConcurrentDestroySubRegionDUnitTest.java    |   21 +-
 ...entFlushingAndRegionOperationsJUnitTest.java |   21 +-
 .../cache/ConcurrentMapLocalJUnitTest.java      |   21 +-
 .../cache/ConcurrentMapOpsDUnitTest.java        |   21 +-
 .../ConcurrentRegionOperationsJUnitTest.java    |   21 +-
 ...rentRollingAndRegionOperationsJUnitTest.java |   21 +-
 .../internal/cache/ConflationJUnitTest.java     |   21 +-
 .../cache/ConnectDisconnectDUnitTest.java       |   16 +
 .../cache/CustomerIDPartitionResolver.java      |   21 +-
 .../internal/cache/DeltaFaultInDUnitTest.java   |   21 +-
 .../cache/DeltaPropagationDUnitTest.java        |   21 +-
 .../cache/DeltaPropagationStatsDUnitTest.java   |   21 +-
 .../internal/cache/DeltaSizingDUnitTest.java    |   21 +-
 .../gemfire/internal/cache/DiskIFJUnitTest.java |   21 +-
 .../gemfire/internal/cache/DiskIdJUnitTest.java |   21 +-
 .../internal/cache/DiskInitFileJUnitTest.java   |   21 +-
 .../cache/DiskOfflineCompactionJUnitTest.java   |   21 +-
 .../internal/cache/DiskOldAPIsJUnitTest.java    |   21 +-
 ...iskRandomOperationsAndRecoveryJUnitTest.java |   21 +-
 .../cache/DiskRegByteArrayDUnitTest.java        |   21 +-
 .../cache/DiskRegCacheXmlJUnitTest.java         |   21 +-
 .../DiskRegCachexmlGeneratorJUnitTest.java      |   21 +-
 .../internal/cache/DiskRegCbkChkJUnitTest.java  |   21 +-
 .../DiskRegOplogSwtchingAndRollerJUnitTest.java |   21 +-
 .../cache/DiskRegRecoveryJUnitTest.java         |   21 +-
 .../cache/DiskRegionAsyncRecoveryJUnitTest.java |   21 +-
 ...RegionChangingRegionAttributesJUnitTest.java |   21 +-
 .../cache/DiskRegionClearJUnitTest.java         |   21 +-
 .../internal/cache/DiskRegionHelperFactory.java |   21 +-
 .../DiskRegionIllegalArguementsJUnitTest.java   |   21 +-
 ...iskRegionIllegalCacheXMLvaluesJUnitTest.java |   21 +-
 .../internal/cache/DiskRegionJUnitTest.java     |   21 +-
 .../internal/cache/DiskRegionProperties.java    |   21 +-
 .../internal/cache/DiskRegionTestingBase.java   |   21 +-
 .../cache/DiskStoreFactoryJUnitTest.java        |   21 +-
 .../cache/DiskWriteAttributesJUnitTest.java     |   21 +-
 ...DistrbutedRegionProfileOffHeapDUnitTest.java |   16 +
 .../cache/DistributedCacheTestCase.java         |   21 +-
 .../cache/EnumListenerEventJUnitTest.java       |   21 +-
 .../internal/cache/EventTrackerDUnitTest.java   |   21 +-
 .../cache/EvictionDUnitDisabledTest.java        |   21 +-
 .../cache/EvictionObjectSizerDUnitTest.java     |   21 +-
 .../internal/cache/EvictionStatsDUnitTest.java  |   21 +-
 .../internal/cache/EvictionTestBase.java        |   21 +-
 .../internal/cache/FaultingInJUnitTest.java     |   21 +-
 .../cache/FixedPRSinglehopDUnitTest.java        |   21 +-
 .../internal/cache/GIIDeltaDUnitTest.java       |   23 +-
 .../internal/cache/GIIFlowControlDUnitTest.java |   21 +-
 .../internal/cache/GridAdvisorDUnitTest.java    |   21 +-
 .../internal/cache/HABug36773DUnitTest.java     |   21 +-
 .../HAOverflowMemObjectSizerDUnitTest.java      |   21 +-
 .../HDFSQueueRegionOperationsJUnitTest.java     |   33 -
 ...FSQueueRegionOperationsOffHeapJUnitTest.java |   54 -
 .../cache/HDFSRegionOperationsJUnitTest.java    |  542 ------
 .../HDFSRegionOperationsOffHeapJUnitTest.java   |   78 -
 .../cache/IncrementalBackupDUnitTest.java       |   21 +-
 .../cache/InterruptClientServerDUnitTest.java   |   21 +-
 .../internal/cache/InterruptDiskJUnitTest.java  |   21 +-
 ...InterruptsConserveSocketsFalseDUnitTest.java |   16 +
 .../internal/cache/InterruptsDUnitTest.java     |   21 +-
 .../internal/cache/IteratorDUnitTest.java       |   21 +-
 .../LIFOEvictionAlgoEnabledRegionJUnitTest.java |   21 +-
 ...victionAlgoMemoryEnabledRegionJUnitTest.java |   21 +-
 .../internal/cache/MapClearGIIDUnitTest.java    |   21 +-
 .../internal/cache/MapInterface2JUnitTest.java  |   21 +-
 .../internal/cache/MapInterfaceJUnitTest.java   |   21 +-
 .../MultipleOplogsRollingFeatureJUnitTest.java  |   21 +-
 .../cache/NetSearchMessagingDUnitTest.java      |   51 +-
 .../cache/OffHeapEvictionDUnitTest.java         |   23 +-
 .../cache/OffHeapEvictionStatsDUnitTest.java    |   21 +-
 .../gemfire/internal/cache/OffHeapTestUtil.java |   21 +-
 .../cache/OfflineSnapshotJUnitTest.java         |   21 +-
 .../gemfire/internal/cache/OldVLJUnitTest.java  |   21 +-
 .../cache/OldValueImporterTestBase.java         |   16 +
 .../cache/OplogEntryIdMapJUnitTest.java         |   21 +-
 .../cache/OplogEntryIdSetJUnitTest.java         |   21 +-
 .../gemfire/internal/cache/OplogJUnitTest.java  |   67 +-
 .../internal/cache/OplogRVVJUnitTest.java       |   21 +-
 .../cache/OrderedTombstoneMapJUnitTest.java     |   21 +-
 .../cache/P2PDeltaPropagationDUnitTest.java     |   21 +-
 .../internal/cache/PRBadToDataDUnitTest.java    |   21 +-
 .../cache/PRConcurrentMapOpsJUnitTest.java      |   21 +-
 .../cache/PRDataStoreMemoryJUnitTest.java       |   21 +-
 .../PRDataStoreMemoryOffHeapJUnitTest.java      |   16 +
 .../gemfire/internal/cache/PRTXJUnitTest.java   |   21 +-
 .../cache/PartitionAttributesImplJUnitTest.java |   16 +
 .../cache/PartitionListenerDUnitTest.java       |   21 +-
 ...dRegionAPIConserveSocketsFalseDUnitTest.java |   21 +-
 .../cache/PartitionedRegionAPIDUnitTest.java    |   20 +-
 .../PartitionedRegionAsSubRegionDUnitTest.java  |   20 +-
 ...gionBucketCreationDistributionDUnitTest.java |   20 +-
 .../PartitionedRegionCacheCloseDUnitTest.java   |   20 +-
 ...rtitionedRegionCacheLoaderForRootRegion.java |   21 +-
 ...artitionedRegionCacheLoaderForSubRegion.java |   21 +-
 ...rtitionedRegionCacheXMLExampleDUnitTest.java |   21 +-
 .../PartitionedRegionCreationDUnitTest.java     |   20 +-
 .../PartitionedRegionCreationJUnitTest.java     |   20 +-
 .../cache/PartitionedRegionDUnitTestCase.java   |   20 +-
 .../PartitionedRegionDataStoreJUnitTest.java    |   20 +-
 ...rtitionedRegionDelayedRecoveryDUnitTest.java |   21 +-
 .../PartitionedRegionDestroyDUnitTest.java      |   20 +-
 .../PartitionedRegionEntryCountDUnitTest.java   |   21 +-
 .../PartitionedRegionEvictionDUnitTest.java     |   21 +-
 .../cache/PartitionedRegionHADUnitTest.java     |   20 +-
 ...onedRegionHAFailureAndRecoveryDUnitTest.java |   20 +-
 .../cache/PartitionedRegionHelperJUnitTest.java |   21 +-
 .../PartitionedRegionInvalidateDUnitTest.java   |   21 +-
 ...artitionedRegionLocalMaxMemoryDUnitTest.java |   20 +-
 ...nedRegionLocalMaxMemoryOffHeapDUnitTest.java |   16 +
 .../PartitionedRegionMultipleDUnitTest.java     |   20 +-
 ...rtitionedRegionOffHeapEvictionDUnitTest.java |   22 +-
 .../cache/PartitionedRegionPRIDDUnitTest.java   |   21 +-
 .../cache/PartitionedRegionQueryDUnitTest.java  |   21 +-
 ...artitionedRegionQueryEvaluatorJUnitTest.java |   21 +-
 ...artitionedRegionRedundancyZoneDUnitTest.java |   25 +-
 ...tionedRegionSerializableObjectJUnitTest.java |   21 +-
 .../PartitionedRegionSingleHopDUnitTest.java    |   80 +-
 ...RegionSingleHopWithServerGroupDUnitTest.java |   21 +-
 ...onedRegionSingleNodeOperationsJUnitTest.java |   20 +-
 .../cache/PartitionedRegionSizeDUnitTest.java   |   20 +-
 .../cache/PartitionedRegionStatsDUnitTest.java  |   20 +-
 .../cache/PartitionedRegionStatsJUnitTest.java  |   21 +-
 .../cache/PartitionedRegionTestHelper.java      |   20 +-
 .../PartitionedRegionTestUtilsDUnitTest.java    |   20 +-
 .../PartitionedRegionWithSameNameDUnitTest.java |   21 +-
 .../PersistentPartitionedRegionJUnitTest.java   |   16 +
 .../internal/cache/PutAllDAckDUnitTest.java     |   21 +-
 .../internal/cache/PutAllGlobalDUnitTest.java   |   21 +-
 .../cache/RegionEntryFlagsJUnitTest.java        |   21 +-
 .../cache/RemotePutReplyMessageJUnitTest.java   |   16 +
 .../cache/RemoteTransactionCCEDUnitTest.java    |   16 +
 .../cache/RemoteTransactionDUnitTest.java       |   27 +-
 .../internal/cache/RemoveAllDAckDUnitTest.java  |   21 +-
 .../internal/cache/RemoveDAckDUnitTest.java     |   21 +-
 .../internal/cache/RemoveGlobalDUnitTest.java   |   21 +-
 .../internal/cache/RunCacheInOldGemfire.java    |   21 +-
 .../cache/SimpleDiskRegionJUnitTest.java        |   21 +-
 .../internal/cache/SizingFlagDUnitTest.java     |   21 +-
 .../internal/cache/SnapshotTestUtil.java        |   16 +
 .../internal/cache/SystemFailureDUnitTest.java  |   21 +-
 .../internal/cache/TXManagerImplJUnitTest.java  |   21 +-
 .../cache/TXReservationMgrJUnitTest.java        |   21 +-
 .../gemfire/internal/cache/TestDelta.java       |   21 +-
 .../internal/cache/TestHelperForHydraTests.java |   16 +
 .../internal/cache/TestNonSizerObject.java      |   21 +-
 .../internal/cache/TestObjectSizerImpl.java     |   21 +-
 .../gemfire/internal/cache/TestUtils.java       |   21 +-
 .../cache/TombstoneCreationJUnitTest.java       |   21 +-
 .../cache/TransactionsWithDeltaDUnitTest.java   |   21 +-
 .../internal/cache/UnitTestValueHolder.java     |   18 +-
 .../gemfire/internal/cache/UnzipUtil.java       |   21 +-
 .../internal/cache/UpdateVersionJUnitTest.java  |   21 +-
 .../gemfire/internal/cache/VLJUnitTest.java     |   21 +-
 .../cache/control/FilterByPathJUnitTest.java    |   21 +-
 .../cache/control/MemoryMonitorJUnitTest.java   |   21 +-
 .../control/MemoryMonitorOffHeapJUnitTest.java  |   23 +-
 .../control/MemoryThresholdsJUnitTest.java      |   16 +
 .../control/RebalanceOperationDUnitTest.java    |   58 +-
 .../control/TestMemoryThresholdListener.java    |   21 +-
 ...skRegOverflowAsyncGetInMemPerfJUnitTest.java |   21 +-
 ...iskRegOverflowAsyncJUnitPerformanceTest.java |   21 +-
 ...lowSyncGetInMemPerfJUnitPerformanceTest.java |   21 +-
 ...DiskRegOverflowSyncJUnitPerformanceTest.java |   21 +-
 ...egionOverflowAsyncRollingOpLogJUnitTest.java |   21 +-
 ...RegionOverflowSyncRollingOpLogJUnitTest.java |   21 +-
 .../DiskRegionPerfJUnitPerformanceTest.java     |   21 +-
 .../DiskRegionPersistOnlySyncJUnitTest.java     |   21 +-
 ...DiskRegionRollOpLogJUnitPerformanceTest.java |   21 +-
 ...ltiThreadedOplogPerJUnitPerformanceTest.java |   21 +-
 .../cache/execute/Bug51193DUnitTest.java        |   16 +
 .../ClientServerFunctionExecutionDUnitTest.java |   21 +-
 .../execute/ColocationFailoverDUnitTest.java    |   21 +-
 .../cache/execute/CustomResultCollector.java    |   21 +-
 .../execute/CustomerIDPartitionResolver.java    |   21 +-
 ...ributedRegionFunctionExecutionDUnitTest.java |   21 +-
 .../FunctionExecution_ExceptionDUnitTest.java   |   21 +-
 .../execute/FunctionServiceStatsDUnitTest.java  |   64 +-
 .../cache/execute/LocalDataSetDUnitTest.java    |   21 +-
 .../cache/execute/LocalDataSetFunction.java     |   21 +-
 .../execute/LocalDataSetIndexingDUnitTest.java  |   21 +-
 .../LocalFunctionExecutionDUnitTest.java        |   21 +-
 .../MemberFunctionExecutionDUnitTest.java       |   21 +-
 .../MultiRegionFunctionExecutionDUnitTest.java  |   21 +-
 .../execute/MyFunctionExecutionException.java   |   21 +-
 .../cache/execute/MyTransactionFunction.java    |   21 +-
 .../OnGroupsFunctionExecutionDUnitTest.java     |   51 +-
 ...ntServerFunctionExecutionNoAckDUnitTest.java |   21 +-
 ...tServerRegionFunctionExecutionDUnitTest.java |   21 +-
 ...egionFunctionExecutionFailoverDUnitTest.java |   21 +-
 ...onFunctionExecutionNoSingleHopDUnitTest.java |   21 +-
 ...onExecutionSelectorNoSingleHopDUnitTest.java |   21 +-
 ...gionFunctionExecutionSingleHopDUnitTest.java |   23 +-
 .../cache/execute/PRClientServerTestBase.java   |   21 +-
 .../cache/execute/PRColocationDUnitTest.java    |   21 +-
 .../execute/PRCustomPartitioningDUnitTest.java  |   21 +-
 .../execute/PRFunctionExecutionDUnitTest.java   |   21 +-
 .../PRFunctionExecutionTimeOutDUnitTest.java    |   21 +-
 ...ctionExecutionWithResultSenderDUnitTest.java |   21 +-
 .../execute/PRPerformanceTestDUnitTest.java     |   21 +-
 .../cache/execute/PRTransactionDUnitTest.java   |   21 +-
 .../PRTransactionWithVersionsDUnitTest.java     |   16 +
 .../internal/cache/execute/PerfFunction.java    |   21 +-
 .../internal/cache/execute/PerfTxFunction.java  |   21 +-
 .../cache/execute/PerformanceTestFunction.java  |   21 +-
 .../execute/SingleHopGetAllPutAllDUnitTest.java |   21 +-
 .../internal/cache/execute/TestFunction.java    |   21 +-
 .../internal/cache/execute/data/CustId.java     |   21 +-
 .../internal/cache/execute/data/Customer.java   |   21 +-
 .../internal/cache/execute/data/Order.java      |   21 +-
 .../internal/cache/execute/data/OrderId.java    |   21 +-
 .../internal/cache/execute/data/Shipment.java   |   21 +-
 .../internal/cache/execute/data/ShipmentId.java |   21 +-
 .../SimpleExtensionPointJUnitTest.java          |   21 +-
 .../extension/mock/AbstractMockExtension.java   |   21 +-
 .../mock/AbstractMockExtensionXmlGenerator.java |   21 +-
 .../mock/AlterMockCacheExtensionFunction.java   |   21 +-
 .../mock/AlterMockRegionExtensionFunction.java  |   21 +-
 .../mock/CreateMockCacheExtensionFunction.java  |   21 +-
 .../mock/CreateMockRegionExtensionFunction.java |   21 +-
 .../mock/DestroyMockCacheExtensionFunction.java |   21 +-
 .../DestroyMockRegionExtensionFunction.java     |   21 +-
 .../extension/mock/MockCacheExtension.java      |   21 +-
 .../mock/MockCacheExtensionXmlGenerator.java    |   21 +-
 .../extension/mock/MockExtensionCommands.java   |   21 +-
 .../extension/mock/MockExtensionXmlParser.java  |   21 +-
 .../extension/mock/MockRegionExtension.java     |   21 +-
 .../mock/MockRegionExtensionXmlGenerator.java   |   21 +-
 ...gionFunctionFunctionInvocationException.java |   21 +-
 .../functions/DistributedRegionFunction.java    |   21 +-
 .../cache/functions/LocalDataSetFunction.java   |   21 +-
 .../internal/cache/functions/TestFunction.java  |   21 +-
 .../ha/BlockingHARQAddOperationJUnitTest.java   |   21 +-
 .../cache/ha/BlockingHARQStatsJUnitTest.java    |   21 +-
 .../cache/ha/BlockingHARegionJUnitTest.java     |   21 +-
 .../ha/BlockingHARegionQueueJUnitTest.java      |   21 +-
 .../cache/ha/Bug36853EventsExpiryDUnitTest.java |   21 +-
 .../internal/cache/ha/Bug48571DUnitTest.java    |   21 +-
 .../internal/cache/ha/Bug48879DUnitTest.java    |   16 +
 .../internal/cache/ha/ConflatableObject.java    |   21 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java  |   21 +-
 .../cache/ha/EventIdOptimizationJUnitTest.java  |   20 +-
 .../internal/cache/ha/FailoverDUnitTest.java    |   21 +-
 .../internal/cache/ha/HABugInPutDUnitTest.java  |   21 +-
 .../internal/cache/ha/HAClearDUnitTest.java     |   21 +-
 .../cache/ha/HAConflationDUnitTest.java         |   21 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |   21 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |   21 +-
 .../internal/cache/ha/HAExpiryDUnitTest.java    |   21 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |   21 +-
 .../internal/cache/ha/HAGIIDUnitTest.java       |   25 +-
 .../gemfire/internal/cache/ha/HAHelper.java     |   21 +-
 .../cache/ha/HARQAddOperationJUnitTest.java     |   21 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |   21 +-
 .../internal/cache/ha/HARegionDUnitTest.java    |   21 +-
 .../internal/cache/ha/HARegionJUnitTest.java    |   20 +-
 .../cache/ha/HARegionQueueDUnitTest.java        |   21 +-
 .../cache/ha/HARegionQueueJUnitTest.java        |   20 +-
 ...HARegionQueueStartStopJUnitDisabledTest.java |   21 +-
 .../ha/HARegionQueueStartStopJUnitTest.java     |   21 +-
 .../cache/ha/HARegionQueueStatsJUnitTest.java   |   20 +-
 .../cache/ha/HASlowReceiverDUnitTest.java       |   21 +-
 .../ha/OperationsPropagationDUnitTest.java      |   21 +-
 .../internal/cache/ha/PutAllDUnitTest.java      |   21 +-
 .../cache/ha/StatsBugDUnitDisabledTest.java     |   21 +-
 .../cache/ha/TestBlockingHARegionQueue.java     |   21 +-
 .../cache/ha/ThreadIdentifierJUnitTest.java     |   21 +-
 .../cache/locks/TXLockServiceDUnitTest.java     |   21 +-
 .../internal/cache/lru/LRUClockJUnitTest.java   |   21 +-
 .../cache/partitioned/Bug39356DUnitTest.java    |   21 +-
 .../cache/partitioned/Bug43684DUnitTest.java    |   21 +-
 .../cache/partitioned/Bug47388DUnitTest.java    |   21 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |   21 +-
 .../partitioned/ElidedPutAllDUnitTest.java      |   21 +-
 .../OfflineMembersDetailsJUnitTest.java         |   21 +-
 .../partitioned/PartitionResolverDUnitTest.java |   21 +-
 .../PartitionedRegionLoadModelJUnitTest.java    |   21 +-
 .../PartitionedRegionLoaderWriterDUnitTest.java |   21 +-
 ...rtitionedRegionMetaDataCleanupDUnitTest.java |   21 +-
 .../partitioned/PersistPRKRFDUnitTest.java      |   21 +-
 ...tentColocatedPartitionedRegionDUnitTest.java |   21 +-
 .../PersistentPartitionedRegionDUnitTest.java   |   27 +-
 ...tentPartitionedRegionOldConfigDUnitTest.java |   21 +-
 .../PersistentPartitionedRegionTestBase.java    |   21 +-
 ...rtitionedRegionWithTransactionDUnitTest.java |   21 +-
 .../PutPutReplyMessageJUnitTest.java            |   16 +
 .../cache/partitioned/ShutdownAllDUnitTest.java |   21 +-
 ...treamingPartitionOperationManyDUnitTest.java |   28 +-
 ...StreamingPartitionOperationOneDUnitTest.java |   29 +-
 .../fixed/CustomerFixedPartitionResolver.java   |   21 +-
 .../fixed/FixedPartitioningDUnitTest.java       |   21 +-
 .../fixed/FixedPartitioningTestBase.java        |   21 +-
 ...ngWithColocationAndPersistenceDUnitTest.java |   21 +-
 .../cache/partitioned/fixed/MyDate1.java        |   21 +-
 .../cache/partitioned/fixed/MyDate2.java        |   21 +-
 .../cache/partitioned/fixed/MyDate3.java        |   21 +-
 .../fixed/QuarterPartitionResolver.java         |   21 +-
 .../SingleHopQuarterPartitionResolver.java      |   21 +-
 .../persistence/BackupInspectorJUnitTest.java   |   21 +-
 .../PersistentRVVRecoveryDUnitTest.java         |   21 +-
 .../PersistentRecoveryOrderDUnitTest.java       |   21 +-
 ...rsistentRecoveryOrderOldConfigDUnitTest.java |   21 +-
 .../PersistentReplicatedTestBase.java           |   21 +-
 .../TemporaryResultSetFactoryJUnitTest.java     |   21 +-
 .../cache/persistence/soplog/AppendLog.java     |   21 +-
 .../ArraySerializedComparatorJUnitTest.java     |   21 +-
 .../CompactionSortedOplogSetTestCase.java       |   21 +-
 .../persistence/soplog/CompactionTestCase.java  |   21 +-
 .../persistence/soplog/ComparisonTestCase.java  |   21 +-
 .../soplog/IndexComparatorJUnitTest.java        |   21 +-
 .../LexicographicalComparatorJUnitTest.java     |   21 +-
 .../soplog/RecoverableSortedOplogSet.java       |   21 +-
 .../soplog/SizeTieredCompactorJUnitTest.java    |   21 +-
 .../SizeTieredSortedOplogSetJUnitTest.java      |   16 +
 .../soplog/SortedBufferJUnitTest.java           |   16 +
 .../soplog/SortedOplogSetJUnitTest.java         |   21 +-
 .../soplog/SortedReaderTestCase.java            |   21 +-
 .../nofile/NoFileSortedOplogJUnitTest.java      |   21 +-
 .../GFSnapshotJUnitPerformanceTest.java         |   21 +-
 .../internal/cache/tier/Bug40396DUnitTest.java  |   21 +-
 .../tier/sockets/AcceptorImplJUnitTest.java     |   21 +-
 ...mpatibilityHigherVersionClientDUnitTest.java |   21 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java   |   21 +-
 .../cache/tier/sockets/Bug36457DUnitTest.java   |   21 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java   |   21 +-
 .../cache/tier/sockets/Bug36829DUnitTest.java   |   21 +-
 .../cache/tier/sockets/Bug36995DUnitTest.java   |   23 +-
 .../cache/tier/sockets/Bug37210DUnitTest.java   |   43 +-
 .../cache/tier/sockets/Bug37805DUnitTest.java   |   21 +-
 .../CacheServerMaxConnectionsJUnitTest.java     |   21 +-
 ...heServerSelectorMaxConnectionsJUnitTest.java |   16 +
 .../cache/tier/sockets/CacheServerTestUtil.java |   21 +-
 .../CacheServerTransactionsDUnitTest.java       |   21 +-
 ...acheServerTransactionsSelectorDUnitTest.java |   16 +
 .../tier/sockets/ClearPropagationDUnitTest.java |   21 +-
 .../tier/sockets/ClientConflationDUnitTest.java |   21 +-
 .../sockets/ClientHealthMonitorJUnitTest.java   |   21 +-
 .../ClientHealthMonitorSelectorJUnitTest.java   |   16 +
 .../sockets/ClientInterestNotifyDUnitTest.java  |   21 +-
 .../tier/sockets/ClientServerMiscDUnitTest.java |   23 +-
 .../ClientServerMiscSelectorDUnitTest.java      |   21 +-
 .../cache/tier/sockets/ConflationDUnitTest.java |   21 +-
 .../tier/sockets/ConnectionProxyJUnitTest.java  |   21 +-
 .../DataSerializerPropogationDUnitTest.java     |   21 +-
 .../cache/tier/sockets/DeltaEOFException.java   |   21 +-
 .../DestroyEntryPropagationDUnitTest.java       |   21 +-
 .../sockets/DurableClientBug39997DUnitTest.java |   21 +-
 .../DurableClientQueueSizeDUnitTest.java        |   17 +-
 .../DurableClientReconnectAutoDUnitTest.java    |   21 +-
 .../DurableClientReconnectDUnitTest.java        |   21 +-
 .../sockets/DurableClientStatsDUnitTest.java    |   21 +-
 .../sockets/DurableRegistrationDUnitTest.java   |   21 +-
 .../sockets/DurableResponseMatrixDUnitTest.java |   21 +-
 .../sockets/EventIDVerificationDUnitTest.java   |   21 +-
 .../EventIDVerificationInP2PDUnitTest.java      |   20 +-
 .../cache/tier/sockets/FaultyDelta.java         |   21 +-
 .../tier/sockets/FilterProfileJUnitTest.java    |   21 +-
 .../ForceInvalidateEvictionDUnitTest.java       |   21 +-
 ...ForceInvalidateOffHeapEvictionDUnitTest.java |   21 +-
 .../cache/tier/sockets/HABug36738DUnitTest.java |   21 +-
 .../cache/tier/sockets/HAInterestBaseTest.java  |   21 +-
 .../sockets/HAInterestDistributedTestCase.java  |   16 +
 .../tier/sockets/HAInterestPart1DUnitTest.java  |   22 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |   45 +-
 .../sockets/HAStartupAndFailoverDUnitTest.java  |   21 +-
 .../internal/cache/tier/sockets/HaHelper.java   |   16 +
 .../tier/sockets/InterestListDUnitTest.java     |   21 +-
 .../sockets/InterestListEndpointDUnitTest.java  |   21 +-
 .../InterestListEndpointPRDUnitTest.java        |   21 +-
 .../InterestListEndpointSelectorDUnitTest.java  |   16 +
 .../sockets/InterestListFailoverDUnitTest.java  |   21 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |   21 +-
 .../sockets/InterestRegrListenerDUnitTest.java  |   21 +-
 .../sockets/InterestResultPolicyDUnitTest.java  |   21 +-
 .../sockets/NewRegionAttributesDUnitTest.java   |   21 +-
 .../tier/sockets/ObjectPartListJUnitTest.java   |   21 +-
 .../tier/sockets/RedundancyLevelJUnitTest.java  |   20 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  |   21 +-
 .../sockets/RedundancyLevelPart2DUnitTest.java  |   21 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java  |   21 +-
 .../tier/sockets/RedundancyLevelTestBase.java   |   21 +-
 .../tier/sockets/RegionCloseDUnitTest.java      |   21 +-
 ...erInterestBeforeRegionCreationDUnitTest.java |   21 +-
 .../sockets/RegisterInterestKeysDUnitTest.java  |   21 +-
 .../RegisterInterestKeysPRDUnitTest.java        |   21 +-
 .../sockets/ReliableMessagingDUnitTest.java     |   21 +-
 .../sockets/UnregisterInterestDUnitTest.java    |   21 +-
 .../sockets/UpdatePropagationDUnitTest.java     |   21 +-
 .../sockets/UpdatePropagationPRDUnitTest.java   |   21 +-
 .../VerifyEventIDGenerationInP2PDUnitTest.java  |   20 +-
 ...UpdatesFromNonInterestEndPointDUnitTest.java |   21 +-
 .../cache/versions/RVVExceptionJUnitTest.java   |   21 +-
 .../versions/RegionVersionHolderJUnitTest.java  |   21 +-
 .../RegionVersionHolderRandomJUnitTest.java     |   21 +-
 ...RegionVersionHolderSmallBitSetJUnitTest.java |   21 +-
 .../versions/RegionVersionVectorJUnitTest.java  |   21 +-
 .../cache/wan/CompressionConstants.java         |   21 +-
 .../cache/wan/CompressionInputStream.java       |   21 +-
 .../cache/wan/CompressionOutputStream.java      |   21 +-
 .../cache/wan/CustomAsyncEventListener.java     |   21 +-
 .../gemfire/internal/cache/wan/Filter70.java    |   21 +-
 .../cache/wan/MyAsyncEventListener.java         |   21 +-
 .../cache/wan/MyAsyncEventListener2.java        |   21 +-
 .../cache/wan/MyDistributedSystemListener.java  |   21 +-
 .../cache/wan/MyGatewaySenderEventListener.java |   21 +-
 .../wan/MyGatewaySenderEventListener2.java      |   21 +-
 .../cache/wan/MyGatewayTransportFilter1.java    |   21 +-
 .../cache/wan/MyGatewayTransportFilter2.java    |   21 +-
 .../cache/wan/MyGatewayTransportFilter3.java    |   21 +-
 .../cache/wan/MyGatewayTransportFilter4.java    |   21 +-
 .../internal/cache/wan/QueueListener.java       |   21 +-
 .../AsyncEventQueueValidationsJUnitTest.java    |   21 +-
 .../xmlcache/AbstractXmlParserJUnitTest.java    |   21 +-
 .../cache/xmlcache/CacheXmlParserJUnitTest.java |   21 +-
 .../xmlcache/CacheXmlVersionJUnitTest.java      |   17 +-
 .../PivotalEntityResolverJUnitTest.java         |   21 +-
 .../cache/xmlcache/RegionCreationJUnitTest.java |   21 +-
 .../xmlcache/XmlGeneratorUtilsJUnitTest.java    |   21 +-
 .../classpathloaderjunittest/DoesExist.java     |   16 +
 .../CompressionCacheConfigDUnitTest.java        |   21 +-
 .../CompressionCacheListenerDUnitTest.java      |   21 +-
 ...ompressionCacheListenerOffHeapDUnitTest.java |   16 +
 .../CompressionRegionConfigDUnitTest.java       |   22 +-
 .../CompressionRegionFactoryDUnitTest.java      |   21 +-
 .../CompressionRegionOperationsDUnitTest.java   |   21 +-
 ...ressionRegionOperationsOffHeapDUnitTest.java |   16 +
 .../compression/CompressionStatsDUnitTest.java  |   21 +-
 .../compression/SnappyCompressorJUnitTest.java  |   23 +-
 .../datasource/AbstractPoolCacheJUnitTest.java  |   21 +-
 .../internal/datasource/CleanUpJUnitTest.java   |   21 +-
 .../ConnectionPoolCacheImplJUnitTest.java       |   21 +-
 .../datasource/ConnectionPoolingJUnitTest.java  |   21 +-
 .../datasource/DataSourceFactoryJUnitTest.java  |   21 +-
 .../internal/datasource/RestartJUnitTest.java   |   21 +-
 .../internal/i18n/BasicI18nJUnitTest.java       |   21 +-
 .../io/CompositeOutputStreamJUnitTest.java      |   21 +-
 .../gemfire/internal/jndi/ContextJUnitTest.java |   21 +-
 .../internal/jta/BlockingTimeOutJUnitTest.java  |   21 +-
 .../gemfire/internal/jta/CacheUtils.java        |   21 +-
 .../internal/jta/DataSourceJTAJUnitTest.java    |   21 +-
 .../internal/jta/ExceptionJUnitTest.java        |   21 +-
 .../jta/GlobalTransactionJUnitTest.java         |   21 +-
 .../gemstone/gemfire/internal/jta/JTAUtils.java |   21 +-
 .../internal/jta/JtaIntegrationJUnitTest.java   |   16 +
 .../gemstone/gemfire/internal/jta/SyncImpl.java |   21 +-
 .../internal/jta/TransactionImplJUnitTest.java  |   21 +-
 .../jta/TransactionManagerImplJUnitTest.java    |   21 +-
 .../jta/TransactionTimeOutJUnitTest.java        |   21 +-
 .../jta/UserTransactionImplJUnitTest.java       |   21 +-
 .../internal/jta/dunit/CommitThread.java        |   21 +-
 .../internal/jta/dunit/ExceptionsDUnitTest.java |   21 +-
 .../jta/dunit/IdleTimeOutDUnitTest.java         |   21 +-
 .../jta/dunit/LoginTimeOutDUnitTest.java        |   21 +-
 .../jta/dunit/MaxPoolSizeDUnitTest.java         |   21 +-
 .../internal/jta/dunit/RollbackThread.java      |   21 +-
 .../jta/dunit/TransactionTimeOutDUnitTest.java  |   21 +-
 .../dunit/TxnManagerMultiThreadDUnitTest.java   |   21 +-
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java |   21 +-
 .../internal/jta/functional/CacheJUnitTest.java |   21 +-
 .../jta/functional/TestXACacheLoader.java       |   21 +-
 .../internal/lang/ClassUtilsJUnitTest.java      |   21 +-
 .../internal/lang/InOutParameterJUnitTest.java  |   21 +-
 .../internal/lang/InitializerJUnitTest.java     |   21 +-
 .../internal/lang/ObjectUtilsJUnitTest.java     |   21 +-
 .../internal/lang/StringUtilsJUnitTest.java     |   21 +-
 .../internal/lang/SystemUtilsJUnitTest.java     |   21 +-
 .../internal/lang/ThreadUtilsJUnitTest.java     |   58 +-
 .../DistributedSystemLogFileJUnitTest.java      |   16 +
 .../logging/LocatorLogFileJUnitTest.java        |   16 +
 .../logging/LogServiceIntegrationJUnitTest.java |  114 +-
 .../LogServiceIntegrationTestSupport.java       |   16 +
 .../internal/logging/LogServiceJUnitTest.java   |   74 +-
 .../LogServiceUserDirIntegrationJUnitTest.java  |   70 -
 .../LogWriterDisabledPerformanceTest.java       |   16 +
 .../logging/LogWriterImplJUnitTest.java         |   16 +
 .../logging/LogWriterPerformanceTest.java       |   16 +
 .../logging/LoggingIntegrationTestSuite.java    |   22 +-
 .../logging/LoggingPerformanceTestCase.java     |   16 +
 .../internal/logging/LoggingUnitTestSuite.java  |   31 +-
 .../logging/MergeLogFilesJUnitTest.java         |   25 +-
 .../gemfire/internal/logging/NullLogWriter.java |   16 +
 .../internal/logging/SortLogFileJUnitTest.java  |   21 +-
 .../internal/logging/TestLogWriterFactory.java  |   16 +
 .../logging/log4j/AlertAppenderJUnitTest.java   |   16 +
 .../logging/log4j/ConfigLocatorJUnitTest.java   |   16 +
 .../log4j/FastLoggerIntegrationJUnitTest.java   |   20 +-
 .../logging/log4j/FastLoggerJUnitTest.java      |   16 +
 .../FastLoggerWithDefaultConfigJUnitTest.java   |   20 +-
 .../log4j/LocalizedMessageJUnitTest.java        |   16 +
 .../log4j/Log4J2DisabledPerformanceTest.java    |   16 +
 .../logging/log4j/Log4J2PerformanceTest.java    |   16 +
 .../log4j/Log4jIntegrationTestSuite.java        |   16 +
 .../logging/log4j/Log4jUnitTestSuite.java       |   16 +
 .../log4j/LogWriterAppenderJUnitTest.java       |   16 +
 .../LogWriterLoggerDisabledPerformanceTest.java |   16 +
 .../log4j/LogWriterLoggerPerformanceTest.java   |   16 +
 .../internal/net/SocketUtilsJUnitTest.java      |   21 +-
 .../offheap/ByteArrayMemoryChunkJUnitTest.java  |   16 +
 .../offheap/ConcurrentBagJUnitTest.java         |   16 +
 .../internal/offheap/DataTypeJUnitTest.java     |   16 +
 .../DirectByteBufferMemoryChunkJUnitTest.java   |   16 +
 .../offheap/FreeListOffHeapRegionJUnitTest.java |   16 +
 .../HeapByteBufferMemoryChunkJUnitTest.java     |   16 +
 .../internal/offheap/InlineKeyJUnitTest.java    |   16 +
 .../offheap/MemoryChunkJUnitTestBase.java       |   16 +
 .../offheap/NullOffHeapMemoryStats.java         |   16 +
 .../offheap/NullOutOfOffHeapMemoryListener.java |   16 +
 .../internal/offheap/OffHeapIndexJUnitTest.java |   16 +
 .../internal/offheap/OffHeapRegionBase.java     |   16 +
 .../offheap/OffHeapStorageJUnitTest.java        |   16 +
 .../offheap/OffHeapValidationJUnitTest.java     |   16 +
 .../OffHeapWriteObjectAsByteArrayJUnitTest.java |   16 +
 .../OldFreeListOffHeapRegionJUnitTest.java      |   16 +
 .../offheap/OutOfOffHeapMemoryDUnitTest.java    |   43 +-
 ...mpleMemoryAllocatorFillPatternJUnitTest.java |   16 +
 .../offheap/SimpleMemoryAllocatorJUnitTest.java |   16 +
 ...moryAllocatorLifecycleListenerJUnitTest.java |   16 +
 .../TxReleasesOffHeapOnCloseJUnitTest.java      |   16 +
 .../offheap/UnsafeMemoryChunkJUnitTest.java     |   16 +
 .../BlockingProcessStreamReaderJUnitTest.java   |   16 +
 .../LocalProcessControllerJUnitTest.java        |   21 +-
 .../process/LocalProcessLauncherDUnitTest.java  |   21 +-
 .../process/LocalProcessLauncherJUnitTest.java  |   21 +-
 ...NonBlockingProcessStreamReaderJUnitTest.java |   16 +
 .../internal/process/PidFileJUnitTest.java      |   16 +
 .../ProcessControllerFactoryJUnitTest.java      |   16 +
 .../process/ProcessStreamReaderTestCase.java    |   22 +-
 .../gemfire/internal/process/mbean/Process.java |   16 +
 .../internal/process/mbean/ProcessMBean.java    |   16 +
 ...tractSignalNotificationHandlerJUnitTest.java |   21 +-
 .../internal/size/ObjectSizerJUnitTest.java     |   21 +-
 .../internal/size/ObjectTraverserJUnitTest.java |   21 +-
 .../internal/size/ObjectTraverserPerf.java      |   21 +-
 .../size/SizeClassOnceObjectSizerJUnitTest.java |   21 +-
 .../gemfire/internal/size/SizeTestUtil.java     |   16 +
 .../size/WellKnownClassSizerJUnitTest.java      |   21 +-
 .../internal/statistics/DummyStatistics.java    |   21 +-
 .../statistics/SampleCollectorJUnitTest.java    |   21 +-
 .../statistics/StatMonitorHandlerJUnitTest.java |   21 +-
 .../statistics/StatisticsDUnitTest.java         |   21 +-
 .../statistics/StatisticsMonitorJUnitTest.java  |   21 +-
 .../internal/statistics/TestSampleHandler.java  |   21 +-
 .../statistics/TestStatArchiveWriter.java       |   21 +-
 .../statistics/TestStatisticsManager.java       |   21 +-
 .../statistics/TestStatisticsSampler.java       |   21 +-
 .../statistics/ValueMonitorJUnitTest.java       |   21 +-
 .../internal/stats50/AtomicStatsJUnitTest.java  |   21 +-
 .../util/AbortableTaskServiceJUnitTest.java     |   21 +-
 .../internal/util/ArrayUtilsJUnitTest.java      |   18 +-
 .../gemfire/internal/util/BytesJUnitTest.java   |   21 +-
 .../internal/util/CollectionUtilsJUnitTest.java |   18 +-
 .../internal/util/DelayedActionJUnitTest.java   |   21 +-
 .../gemfire/internal/util/IOUtilsJUnitTest.java |   21 +-
 .../gemfire/internal/util/SerializableImpl.java |   21 +-
 .../util/SerializableImplWithValue.java         |   21 +-
 .../gemfire/internal/util/Valuable.java         |   21 +-
 .../CompactConcurrentHashSetJUnitTest.java      |   16 +
 .../ConcurrentHashMapIteratorJUnitTest.java     |   21 +-
 .../concurrent/ReentrantSemaphoreJUnitTest.java |   21 +-
 .../SemaphoreReadWriteLockJUnitTest.java        |   21 +-
 .../cm/ConcurrentHashMapJUnitTest.java          |   21 +-
 .../concurrent/cm/CountedMapLoopsJUnitTest.java |   21 +-
 .../concurrent/cm/IntMapCheckJUnitTest.java     |   21 +-
 .../util/concurrent/cm/LoopHelpers.java         |   21 +-
 .../util/concurrent/cm/MapCheckJUnitTest.java   |   21 +-
 .../util/concurrent/cm/MapLoopsJUnitTest.java   |   21 +-
 .../util/concurrent/cm/RLJBarJUnitTest.java     |   21 +-
 .../concurrent/cm/StringMapLoopsJUnitTest.java  |   21 +-
 .../management/CacheManagementDUnitTest.java    |   22 +-
 .../management/ClientHealthStatsDUnitTest.java  |   22 +-
 .../gemfire/management/CompositeStats.java      |   21 +-
 .../gemfire/management/CompositeTestMBean.java  |   21 +-
 .../gemfire/management/CompositeTestMXBean.java |   16 +
 .../management/CompositeTypeTestDUnitTest.java  |   21 +-
 .../gemfire/management/CustomMBean.java         |   22 +-
 .../gemfire/management/CustomMXBean.java        |   20 +-
 .../management/DLockManagementDUnitTest.java    |   20 +-
 .../DataBrowserJSONValidationJUnitTest.java     |   21 +-
 .../management/DiskManagementDUnitTest.java     |   20 +-
 .../management/DistributedSystemDUnitTest.java  |   20 +-
 .../management/LocatorManagementDUnitTest.java  |   21 +-
 .../gemstone/gemfire/management/MBeanUtil.java  |   20 +-
 .../gemfire/management/ManagementTestBase.java  |   21 +-
 .../MemberMBeanAttributesDUnitTest.java         |   20 +-
 .../management/OffHeapManagementDUnitTest.java  |   32 +-
 .../gemfire/management/QueryDataDUnitTest.java  |   21 +-
 .../management/RegionManagementDUnitTest.java   |   20 +-
 .../gemfire/management/TypedJsonJUnitTest.java  |   21 +-
 ...ersalMembershipListenerAdapterDUnitTest.java |   21 +-
 .../stats/AsyncEventQueueStatsJUnitTest.java    |   21 +-
 .../bean/stats/CacheServerStatsJUnitTest.java   |   21 +-
 .../bean/stats/DiskStatsJUnitTest.java          |   21 +-
 .../stats/DistributedSystemStatsDUnitTest.java  |   21 +-
 .../stats/DistributedSystemStatsJUnitTest.java  |   21 +-
 .../stats/GatewayReceiverStatsJUnitTest.java    |   21 +-
 .../bean/stats/GatewaySenderStatsJUnitTest.java |   21 +-
 .../HDFSRegionMBeanAttributeJUnitTest.java      |  169 --
 .../bean/stats/MBeanStatsTestCase.java          |   21 +-
 .../bean/stats/MemberLevelStatsJUnitTest.java   |   21 +-
 .../bean/stats/RegionStatsJUnitTest.java        |   21 +-
 .../bean/stats/StatsRateJUnitTest.java          |   21 +-
 .../internal/JettyHelperJUnitTest.java          |   21 +-
 .../cli/ClasspathScanLoadHelperJUnitTest.java   |   21 +-
 .../internal/cli/CliUtilDUnitTest.java          |   21 +-
 .../internal/cli/CommandManagerJUnitTest.java   |   21 +-
 .../cli/CommandSeparatorEscapeJUnitTest.java    |   16 +
 .../internal/cli/DataCommandJsonJUnitTest.java  |   16 +
 .../internal/cli/GfshParserJUnitTest.java       |   21 +-
 .../cli/annotations/CliArgumentJUnitTest.java   |   21 +-
 .../AbstractCommandsSupportJUnitTest.java       |   21 +-
 .../commands/DiskStoreCommandsJUnitTest.java    |   21 +-
 .../commands/HDFSStoreCommandsJUnitTest.java    |  838 ---------
 .../HTTPServiceSSLSupportJUnitTest.java         |   20 +-
 .../cli/commands/IndexCommandsJUnitTest.java    |   21 +-
 .../RegionPathConverterJUnitTest.java           |   21 +-
 .../internal/cli/domain/AbstractImpl.java       |   16 +
 .../management/internal/cli/domain/Impl1.java   |   16 +
 .../management/internal/cli/domain/Impl12.java  |   16 +
 .../internal/cli/domain/Interface1.java         |   16 +
 .../internal/cli/domain/Interface2.java         |   16 +
 .../management/internal/cli/domain/Stock.java   |   21 +-
 .../management/internal/cli/dto/Car.java        |   16 +
 .../management/internal/cli/dto/Key1.java       |   21 +-
 .../management/internal/cli/dto/Key2.java       |   21 +-
 .../internal/cli/dto/ObjectWithCharAttr.java    |   21 +-
 .../management/internal/cli/dto/Value1.java     |   21 +-
 .../management/internal/cli/dto/Value2.java     |   21 +-
 .../AlterHDFSStoreFunctionJUnitTest.java        |  324 ----
 .../CreateHDFSStoreFunctionJUnitTest.java       |  307 ---
 .../DescribeDiskStoreFunctionJUnitTest.java     |   21 +-
 .../DescribeHDFSStoreFunctionJUnitTest.java     |  364 ----
 .../DestroyHDFSStoreFunctionJUnitTest.java      |  305 ---
 .../ListDiskStoresFunctionJUnitTest.java        |   21 +-
 .../ListHDFSStoresFunctionJUnitTest.java        |  319 ----
 .../functions/ListIndexFunctionJUnitTest.java   |   21 +-
 .../cli/parser/ParserUtilsJUnitTest.java        |   21 +-
 .../preprocessor/PreprocessorJUnitTest.java     |   21 +-
 .../PreprocessorUtilsJUnitTest.java             |   21 +-
 .../cli/shell/GfshConfigInitFileJUnitTest.java  |   16 +
 .../shell/GfshExecutionStrategyJUnitTest.java   |   21 +-
 .../cli/shell/GfshInitFileJUnitTest.java        |   16 +
 .../SharedConfigurationDUnitTest.java           |   21 +-
 .../configuration/ZipUtilsJUnitTest.java        |   21 +-
 .../domain/CacheElementJUnitTest.java           |   21 +-
 .../utils/XmlUtilsAddNewNodeJUnitTest.java      |   21 +-
 .../configuration/utils/XmlUtilsJUnitTest.java  |   21 +-
 .../internal/pulse/TestClientIdsDUnitTest.java  |   22 +-
 .../internal/pulse/TestFunctionsDUnitTest.java  |   22 +-
 .../internal/pulse/TestHeapDUnitTest.java       |   23 +-
 .../internal/pulse/TestLocatorsDUnitTest.java   |   22 +-
 .../pulse/TestSubscriptionsDUnitTest.java       |   20 +-
 .../internal/security/JSONAuthCodeTest.java     |   16 +
 .../security/JSONAuthorizationTest.java         |   16 +
 .../security/ResourceOperationJUnit.java        |   16 +
 .../ReadOpFileAccessControllerJUnitTest.java    |   21 +-
 .../WanCommandsControllerJUnitTest.java         |   16 +
 .../gemfire/management/model/EmptyObject.java   |   21 +-
 .../gemstone/gemfire/management/model/Item.java |   21 +-
 .../gemfire/management/model/Order.java         |   21 +-
 .../gemfire/management/model/SubOrder.java      |   21 +-
 .../DomainObjectsAsValuesJUnitTest.java         |   21 +-
 .../GemcachedBinaryClientJUnitTest.java         |   21 +-
 .../GemcachedDevelopmentJUnitTest.java          |   21 +-
 .../gemfire/memcached/IntegrationJUnitTest.java |   21 +-
 .../gemfire/pdx/AutoSerializableJUnitTest.java  |   21 +-
 .../gemfire/pdx/ByteSourceJUnitTest.java        |   16 +
 .../ClientsWithVersioningRetryDUnitTest.java    |   21 +-
 .../com/gemstone/gemfire/pdx/DSInsidePdx.java   |   23 +-
 .../pdx/DistributedSystemIdDUnitTest.java       |   21 +-
 .../com/gemstone/gemfire/pdx/DomainObject.java  |   21 +-
 .../gemstone/gemfire/pdx/DomainObjectBad.java   |   16 +
 .../gemfire/pdx/DomainObjectClassLoadable.java  |   16 +
 .../gemfire/pdx/DomainObjectPdxAuto.java        |   21 +-
 ...DomainObjectPdxAutoNoDefaultConstructor.java |   21 +-
 .../java/com/gemstone/gemfire/pdx/Employee.java |   23 +-
 .../pdx/JSONPdxClientServerDUnitTest.java       |   23 +-
 .../com/gemstone/gemfire/pdx/NestedPdx.java     |   21 +-
 .../gemfire/pdx/NonDelegatingLoader.java        |   23 +-
 .../OffHeapByteBufferByteSourceJUnitTest.java   |   16 +
 .../gemfire/pdx/OffHeapByteSourceJUnitTest.java |   16 +
 .../pdx/PDXAsyncEventQueueDUnitTest.java        |   22 +-
 .../gemfire/pdx/PdxAttributesJUnitTest.java     |   21 +-
 .../gemfire/pdx/PdxClientServerDUnitTest.java   |   21 +-
 .../pdx/PdxDeserializationDUnitTest.java        |   21 +-
 .../pdx/PdxFormatterPutGetJUnitTest.java        |   21 +-
 .../com/gemstone/gemfire/pdx/PdxInsideDS.java   |   23 +-
 .../pdx/PdxInstanceFactoryJUnitTest.java        |   21 +-
 .../gemfire/pdx/PdxInstanceJUnitTest.java       |   21 +-
 .../gemfire/pdx/PdxSerializableDUnitTest.java   |   21 +-
 .../gemfire/pdx/PdxSerializableJUnitTest.java   |   21 +-
 .../gemfire/pdx/PdxStringJUnitTest.java         |   21 +-
 .../gemfire/pdx/PdxTypeExportDUnitTest.java     |   21 +-
 .../gemfire/pdx/SeparateClassloaderPdx.java     |   23 +-
 .../com/gemstone/gemfire/pdx/SimpleClass.java   |   23 +-
 .../com/gemstone/gemfire/pdx/SimpleClass1.java  |   21 +-
 .../com/gemstone/gemfire/pdx/SimpleClass2.java  |   21 +-
 .../gemfire/pdx/TestObjectForPdxFormatter.java  |   21 +-
 .../gemfire/pdx/VersionClassLoader.java         |   22 +-
 .../gemstone/gemfire/redis/AuthJUnitTest.java   |   18 +-
 .../gemfire/redis/ConcurrentStartTest.java      |   16 +
 .../gemstone/gemfire/redis/HashesJUnitTest.java |   16 +
 .../gemstone/gemfire/redis/ListsJUnitTest.java  |   16 +
 .../gemfire/redis/RedisDistDUnitTest.java       |   16 +
 .../gemstone/gemfire/redis/SetsJUnitTest.java   |   16 +
 .../gemfire/redis/SortedSetsJUnitTest.java      |   20 +-
 .../gemfire/redis/StringsJunitTest.java         |   16 +
 .../web/controllers/AddFreeItemToOrders.java    |   21 +-
 .../rest/internal/web/controllers/Customer.java |   21 +-
 .../internal/web/controllers/DateTimeUtils.java |   16 +
 .../rest/internal/web/controllers/Gender.java   |   16 +
 .../internal/web/controllers/GetAllEntries.java |   21 +-
 .../web/controllers/GetDeliveredOrders.java     |   21 +-
 .../internal/web/controllers/GetRegions.java    |   21 +-
 .../web/controllers/GetValueForKey.java         |   21 +-
 .../rest/internal/web/controllers/Item.java     |   21 +-
 .../rest/internal/web/controllers/Order.java    |   21 +-
 .../rest/internal/web/controllers/Person.java   |   21 +-
 .../web/controllers/PutKeyFunction.java         |   21 +-
 .../web/controllers/RestAPITestBase.java        |   16 +
 .../internal/web/controllers/RestTestUtils.java |   21 +-
 .../gemfire/test/golden/ExecutableProcess.java  |   16 +
 .../gemfire/test/golden/FailOutputTestCase.java |   16 +
 .../golden/FailWithErrorInOutputJUnitTest.java  |   16 +
 .../FailWithExtraLineInOutputJUnitTest.java     |   16 +
 ...WithLineMissingFromEndOfOutputJUnitTest.java |   16 +
 ...hLineMissingFromMiddleOfOutputJUnitTest.java |   16 +
 .../FailWithLoggerErrorInOutputJUnitTest.java   |   16 +
 .../FailWithLoggerFatalInOutputJUnitTest.java   |   16 +
 .../FailWithLoggerWarnInOutputJUnitTest.java    |   16 +
 .../golden/FailWithProblemInOutputTestCase.java |   16 +
 .../golden/FailWithSevereInOutputJUnitTest.java |   16 +
 ...hTimeoutOfWaitForOutputToMatchJUnitTest.java |   16 +
 .../FailWithWarningInOutputJUnitTest.java       |   16 +
 .../gemfire/test/golden/GoldenComparator.java   |   16 +
 .../test/golden/GoldenStringComparator.java     |   16 +
 .../gemfire/test/golden/GoldenTestCase.java     |   16 +
 .../golden/GoldenTestFrameworkTestSuite.java    |   16 +
 .../gemfire/test/golden/PassJUnitTest.java      |   16 +
 .../golden/PassWithExpectedErrorJUnitTest.java  |   16 +
 .../golden/PassWithExpectedProblemTestCase.java |   16 +
 .../golden/PassWithExpectedSevereJUnitTest.java |   16 +
 .../PassWithExpectedWarningJUnitTest.java       |   16 +
 .../test/golden/RegexGoldenComparator.java      |   16 +
 .../test/golden/StringGoldenComparator.java     |   16 +
 .../gemfire/test/process/MainLauncher.java      |   16 +
 .../test/process/MainLauncherJUnitTest.java     |   16 +
 .../gemfire/test/process/OutputFormatter.java   |   16 +
 .../test/process/ProcessOutputReader.java       |   16 +
 .../test/process/ProcessStreamReader.java       |   16 +
 .../process/ProcessTestFrameworkTestSuite.java  |   16 +
 .../gemfire/test/process/ProcessWrapper.java    |   16 +
 .../test/process/ProcessWrapperJUnitTest.java   |   16 +
 .../gemstone/gemfire/util/JSR166TestCase.java   |   22 +-
 .../gemstone/gemfire/util/test/TestUtil.java    |   16 +
 .../protocols/CacheTimeSlowDownDUnitTest.java   |   17 +-
 .../GemFireTimeSyncProtocolDUnitTest.java       |   17 +-
 .../JGroupsFailureDetectionJUnitTest.java       |   16 +
 .../protocols/JGroupsVersioningJUnitTest.java   |   21 +-
 .../com/gemstone/persistence/admin/Logger.java  |   21 +-
 .../gemstone/persistence/logging/Formatter.java |   21 +-
 .../gemstone/persistence/logging/Handler.java   |   21 +-
 .../com/gemstone/persistence/logging/Level.java |   21 +-
 .../gemstone/persistence/logging/LogRecord.java |   21 +-
 .../gemstone/persistence/logging/Logger.java    |   21 +-
 .../persistence/logging/SimpleFormatter.java    |   21 +-
 .../persistence/logging/StreamHandler.java      |   21 +-
 .../test/java/com/gemstone/sequence/Arrow.java  |   21 +-
 .../java/com/gemstone/sequence/Lifeline.java    |   21 +-
 .../com/gemstone/sequence/LifelineState.java    |   21 +-
 .../java/com/gemstone/sequence/LineMapper.java  |   21 +-
 .../com/gemstone/sequence/SequenceDiagram.java  |   21 +-
 .../com/gemstone/sequence/SequencePanel.java    |   21 +-
 .../com/gemstone/sequence/StateColorMap.java    |   21 +-
 .../java/com/gemstone/sequence/TimeAxis.java    |   21 +-
 .../com/gemstone/sequence/ZoomingPanel.java     |   21 +-
 .../sequence/gemfire/DefaultLineMapper.java     |   21 +-
 .../gemfire/GemfireSequenceDisplay.java         |   21 +-
 .../sequence/gemfire/HydraLineMapper.java       |   21 +-
 .../sequence/gemfire/SelectGraphDialog.java     |   21 +-
 .../com/main/MyDistributedSystemListener.java   |   21 +-
 .../com/main/WANBootStrapping_Site1_Add.java    |   21 +-
 .../com/main/WANBootStrapping_Site1_Remove.java |   21 +-
 .../com/main/WANBootStrapping_Site2_Add.java    |   21 +-
 .../com/main/WANBootStrapping_Site2_Remove.java |   21 +-
 .../src/test/java/dunit/AsyncInvocation.java    |   21 +-
 .../src/test/java/dunit/BounceResult.java       |   16 +
 gemfire-core/src/test/java/dunit/DUnitEnv.java  |   21 +-
 .../test/java/dunit/DistributedTestCase.java    |   21 +-
 gemfire-core/src/test/java/dunit/Host.java      |   21 +-
 .../src/test/java/dunit/RMIException.java       |   21 +-
 .../src/test/java/dunit/RemoteDUnitVMIF.java    |   16 +
 .../src/test/java/dunit/RepeatableRunnable.java |   16 +
 .../test/java/dunit/SerializableCallable.java   |   21 +-
 .../test/java/dunit/SerializableRunnable.java   |   21 +-
 gemfire-core/src/test/java/dunit/VM.java        |   21 +-
 .../src/test/java/dunit/standalone/ChildVM.java |   25 +-
 .../java/dunit/standalone/DUnitLauncher.java    |   25 +-
 .../java/dunit/standalone/ProcessManager.java   |   36 +-
 .../java/dunit/standalone/RemoteDUnitVM.java    |   21 +-
 .../dunit/standalone/StandAloneDUnitEnv.java    |   21 +-
 .../test/java/dunit/tests/BasicDUnitTest.java   |   21 +-
 .../src/test/java/dunit/tests/TestFailure.java  |   21 +-
 .../src/test/java/dunit/tests/VMDUnitTest.java  |   21 +-
 gemfire-core/src/test/java/hydra/GsRandom.java  |   21 +-
 .../test/java/hydra/HydraRuntimeException.java  |   21 +-
 gemfire-core/src/test/java/hydra/Log.java       |   21 +-
 .../src/test/java/hydra/LogVersionHelper.java   |   21 +-
 .../src/test/java/hydra/MethExecutor.java       |   21 +-
 .../src/test/java/hydra/MethExecutorResult.java |   21 +-
 .../src/test/java/hydra/SchedulingOrder.java    |   21 +-
 .../src/test/java/hydra/log/AnyLogWriter.java   |   21 +-
 .../java/hydra/log/CircularOutputStream.java    |   21 +-
 .../parReg/query/unittest/NewPortfolio.java     |   21 +-
 .../java/parReg/query/unittest/Position.java    |   22 +-
 .../src/test/java/perffmwk/Formatter.java       |   22 +-
 .../templates/security/DummyAuthenticator.java  |   21 +-
 .../templates/security/DummyAuthorization.java  |   21 +-
 .../security/FunctionSecurityPrmsHolder.java    |   21 +-
 .../security/LdapUserAuthenticator.java         |   21 +-
 .../java/templates/security/PKCSAuthInit.java   |   21 +-
 .../templates/security/PKCSAuthenticator.java   |   21 +-
 .../java/templates/security/PKCSPrincipal.java  |   21 +-
 .../security/UserPasswordAuthInit.java          |   21 +-
 .../templates/security/UsernamePrincipal.java   |   21 +-
 .../templates/security/XmlAuthorization.java    |   21 +-
 .../templates/security/XmlErrorHandler.java     |   21 +-
 .../src/test/java/util/TestException.java       |   21 +-
 .../cache/client/internal/cacheserver.cer       |  Bin 0 -> 782 bytes
 .../cache/client/internal/cacheserver.keystore  |  Bin 0 -> 1253 bytes
 .../client/internal/cacheserver.truststore      |  Bin 0 -> 844 bytes
 .../gemfire/cache/client/internal/client.cer    |  Bin 0 -> 782 bytes
 .../cache/client/internal/client.keystore       |  Bin 0 -> 1251 bytes
 .../cache/client/internal/client.truststore     |  Bin 0 -> 846 bytes
 .../cache/client/internal/default.keystore      |  Bin 0 -> 1115 bytes
 .../cache/client/internal/trusted.keystore      |  Bin 0 -> 1078 bytes
 .../sanctionedDataSerializables.txt             | 1755 ++++++++----------
 .../codeAnalysis/sanctionedSerializables.txt    |   27 +-
 gemfire-jgroups/build.gradle                    |    8 +-
 .../org/jgroups/ShunnedAddressException.java    |   16 +
 .../com/gemstone/org/jgroups/SuspectMember.java |   16 +-
 .../org/jgroups/debug/JChannelTestHook.java     |   16 +
 .../gemstone/org/jgroups/protocols/AUTH.java    |   16 +
 .../gemstone/org/jgroups/protocols/FRAG3.java   |   17 +-
 .../org/jgroups/spi/GFBasicAdapter.java         |   16 +
 .../gemstone/org/jgroups/spi/GFPeerAdapter.java |   16 +
 .../org/jgroups/stack/BoundedLinkedHashMap.java |   21 +-
 .../org/jgroups/stack/GFBasicAdapterImpl.java   |   16 +
 .../org/jgroups/stack/GFPeerAdapterImpl.java    |   16 +
 .../org/jgroups/stack/GossipClient.java         |    6 +-
 .../org/jgroups/stack/SockCreatorImpl.java      |   21 +-
 .../org/jgroups/util/ConnectionWatcher.java     |   16 +
 .../org/jgroups/util/ExternalStrings.java       |   21 +-
 .../gemstone/org/jgroups/util/GFLogWriter.java  |   16 +
 .../org/jgroups/util/GFStringIdImpl.java        |   16 +
 .../gemstone/org/jgroups/util/SockCreator.java  |   24 +-
 .../org/jgroups/util/StreamableFixedID.java     |   16 +
 .../com/gemstone/org/jgroups/util/StringId.java |   21 +-
 .../org/jgroups/util/VersionedStreamable.java   |   16 +
 .../gemstone/org/jgroups/JChannelJUnitTest.java |   16 +
 .../test/junit/categories/DistributedTest.java  |   16 +
 .../categories/DistributedTransactionsTest.java |   16 +
 .../test/junit/categories/HoplogTest.java       |    7 -
 .../test/junit/categories/IntegrationTest.java  |   16 +
 .../test/junit/categories/PerformanceTest.java  |   16 +
 .../gemfire/test/junit/categories/UnitTest.java |   16 +
 .../gemfire/test/junit/categories/WanTest.java  |   16 +
 .../test/junit/rules/ExpectedTimeout.java       |   16 +
 .../junit/rules/ExpectedTimeoutJUnitTest.java   |   16 +
 .../gemfire/cache/lucene/LuceneIndex.java       |   21 +-
 .../gemfire/cache/lucene/LuceneQuery.java       |   16 +
 .../cache/lucene/LuceneQueryFactory.java        |   16 +
 .../cache/lucene/LuceneResultStruct.java        |   16 +
 .../gemfire/cache/lucene/LuceneService.java     |   16 +
 gemfire-rebalancer/build.gradle                 |   11 +-
 .../gemfire/cache/util/AutoBalancer.java        |  190 +-
 .../util/AutoBalancerIntegrationJUnitTest.java  |  190 ++
 .../cache/util/AutoBalancerJUnitTest.java       |  410 ++--
 gemfire-spark-connector/doc/1_building.md       |    2 +
 .../connector/internal/RegionMetadata.java      |   16 +
 .../gemfirefunctions/QueryFunction.java         |   18 +-
 .../RetrieveRegionFunction.java                 |   16 +
 .../RetrieveRegionMetadataFunction.java         |   16 +
 .../StructStreamingResultSender.java            |   16 +
 .../gemfire/spark/connector/Employee.java       |   16 +
 .../spark/connector/JavaApiIntegrationTest.java |   16 +
 .../gemfire/spark/connector/Portfolio.java      |   16 +
 .../gemfire/spark/connector/Position.java       |   16 +
 .../spark/connector/BasicIntegrationTest.scala  |   16 +
 .../RDDJoinRegionIntegrationTest.scala          |   16 +
 .../RetrieveRegionIntegrationTest.scala         |   16 +
 .../gemfire/spark/connector/package.scala       |   16 +
 .../connector/testkit/GemFireCluster.scala      |   16 +
 .../spark/connector/testkit/GemFireRunner.scala |   16 +
 .../spark/connector/testkit/IOUtils.scala       |   16 +
 .../spark/streaming/ManualClockHelper.scala     |   16 +
 .../spark/streaming/TestInputDStream.scala      |   16 +
 .../javaapi/GemFireJavaDStreamFunctions.java    |   16 +
 .../GemFireJavaPairDStreamFunctions.java        |   16 +
 .../javaapi/GemFireJavaPairRDDFunctions.java    |   16 +
 .../javaapi/GemFireJavaRDDFunctions.java        |   16 +
 .../javaapi/GemFireJavaSQLContextFunctions.java |   16 +
 .../GemFireJavaSparkContextFunctions.java       |   16 +
 .../connector/javaapi/GemFireJavaUtil.java      |   16 +
 .../spark/connector/GemFireConnection.scala     |   16 +
 .../spark/connector/GemFireConnectionConf.scala |   16 +
 .../connector/GemFireConnectionManager.scala    |   16 +
 .../connector/GemFireFunctionDeployer.scala     |   16 +
 .../connector/GemFireKryoRegistrator.scala      |   16 +
 .../connector/GemFirePairRDDFunctions.scala     |   16 +
 .../spark/connector/GemFireRDDFunctions.scala   |   16 +
 .../connector/GemFireSQLContextFunctions.scala  |   16 +
 .../GemFireSparkContextFunctions.scala          |   16 +
 .../internal/DefaultGemFireConnection.scala     |   16 +
 .../DefaultGemFireConnectionManager.scala       |   16 +
 .../connector/internal/LocatorHelper.scala      |   16 +
 .../StructStreamingResultCollector.scala        |   16 +
 .../connector/internal/oql/QueryParser.scala    |   16 +
 .../spark/connector/internal/oql/QueryRDD.scala |   18 +-
 .../internal/oql/QueryResultCollector.scala     |   18 +-
 .../connector/internal/oql/RDDConverter.scala   |   18 +-
 .../connector/internal/oql/RowBuilder.scala     |   16 +
 .../connector/internal/oql/SchemaBuilder.scala  |   16 +
 .../internal/oql/UndefinedSerializer.scala      |   16 +
 .../connector/internal/rdd/GemFireJoinRDD.scala |   16 +
 .../internal/rdd/GemFireOuterJoinRDD.scala      |   16 +
 .../internal/rdd/GemFireRDDPartition.scala      |   16 +
 .../internal/rdd/GemFireRDDPartitioner.scala    |   16 +
 .../rdd/GemFireRDDPartitionerImpl.scala         |   16 +
 .../internal/rdd/GemFireRDDWriter.scala         |   16 +
 .../internal/rdd/GemFireRegionRDD.scala         |   16 +
 .../javaapi/GemFireJavaRegionRDD.scala          |   16 +
 .../spark/connector/javaapi/JavaAPIHelper.scala |   16 +
 .../gemfire/spark/connector/package.scala       |   16 +
 .../streaming/GemFireDStreamFunctions.scala     |   18 +-
 .../spark/connector/streaming/package.scala     |   16 +
 .../gemfire/spark/connector/JavaAPITest.java    |   18 +-
 .../connector/GemFireFunctionDeployerTest.scala |   16 +
 .../DefaultGemFireConnectionManagerTest.scala   |   16 +
 ...tStreamingResultSenderAndCollectorTest.scala |   16 +
 .../internal/oql/QueryParserTest.scala          |   18 +-
 .../connector/ConnectorImplicitsTest.scala      |   16 +
 .../connector/GemFireConnectionConfTest.scala   |   16 +
 .../connector/GemFireDStreamFunctionsTest.scala |   16 +
 .../connector/GemFireRDDFunctionsTest.scala     |   16 +
 .../spark/connector/LocatorHelperTest.scala     |   16 +
 .../rdd/GemFireRDDPartitionerTest.scala         |   16 +
 .../connector/rdd/GemFireRegionRDDTest.scala    |   16 +
 .../basic-demos/src/main/java/demo/Emp.java     |   16 +
 .../src/main/java/demo/OQLJavaDemo.java         |   16 +
 .../src/main/java/demo/PairRDDSaveJavaDemo.java |   16 +
 .../src/main/java/demo/RDDSaveJavaDemo.java     |   16 +
 .../src/main/java/demo/RegionToRDDJavaDemo.java |   16 +
 .../src/main/scala/demo/NetworkWordCount.scala  |   16 +
 .../project/Dependencies.scala                  |   16 +
 .../project/GemFireSparkBuild.scala             |   16 +
 gemfire-spark-connector/project/Settings.scala  |   16 +
 gemfire-web-api/build.gradle                    |   46 +-
 .../web/controllers/AbstractBaseController.java |   21 +-
 .../web/controllers/BaseControllerAdvice.java   |   21 +-
 .../web/controllers/CommonCrudController.java   |   21 +-
 .../controllers/FunctionAccessController.java   |   21 +-
 .../web/controllers/PdxBasedCrudController.java |   21 +-
 .../web/controllers/QueryAccessController.java  |   21 +-
 .../web/controllers/support/JSONTypes.java      |   16 +
 .../controllers/support/QueryResultTypes.java   |   21 +-
 .../web/controllers/support/RegionData.java     |   21 +-
 .../controllers/support/RegionEntryData.java    |   21 +-
 .../support/RestServersResultCollector.java     |   16 +
 .../web/controllers/support/UpdateOp.java       |   21 +-
 .../DataTypeNotSupportedException.java          |   21 +-
 .../web/exception/GemfireRestException.java     |   21 +-
 .../web/exception/MalformedJsonException.java   |   21 +-
 .../web/exception/RegionNotFoundException.java  |   21 +-
 .../exception/ResourceNotFoundException.java    |   21 +-
 ...stomMappingJackson2HttpMessageConverter.java |   16 +
 .../web/swagger/config/RestApiPathProvider.java |   16 +
 .../web/swagger/config/SwaggerConfig.java       |   16 +
 .../rest/internal/web/util/ArrayUtils.java      |   21 +-
 .../rest/internal/web/util/DateTimeUtils.java   |   21 +-
 .../internal/web/util/IdentifiableUtils.java    |   21 +-
 .../rest/internal/web/util/JSONUtils.java       |   21 +-
 .../rest/internal/web/util/JsonWriter.java      |   21 +-
 .../rest/internal/web/util/NumberUtils.java     |   21 +-
 .../rest/internal/web/util/ValidationUtils.java |   21 +-
 gemfire-web/build.gradle                        |   32 +-
 .../internal/web/AbstractWebTestCase.java       |   21 +-
 .../ShellCommandsControllerJUnitTest.java       |   68 +-
 ...entVariablesHandlerInterceptorJUnitTest.java |   21 +-
 .../internal/web/domain/LinkIndexJUnitTest.java |   21 +-
 .../internal/web/domain/LinkJUnitTest.java      |   21 +-
 .../domain/QueryParameterSourceJUnitTest.java   |   21 +-
 .../web/http/ClientHttpRequestJUnitTest.java    |   21 +-
 ...ableObjectHttpMessageConverterJUnitTest.java |   21 +-
 .../RestHttpOperationInvokerJUnitTest.java      |   21 +-
 .../SimpleHttpOperationInvokerJUnitTest.java    |   21 +-
 .../web/util/ConvertUtilsJUnitTest.java         |   21 +-
 .../internal/web/util/UriUtilsJUnitTest.java    |   21 +-
 gradle/dependency-versions.properties           |   64 +
 gradle/wrapper/gradle-wrapper.jar               |  Bin 51018 -> 53637 bytes
 gradle/wrapper/gradle-wrapper.properties        |    4 +-
 gradlew                                         |   12 +-
 settings.gradle                                 |    1 +
 5014 files changed, 78666 insertions(+), 43006 deletions(-)
----------------------------------------------------------------------



[36/50] [abbrv] incubator-geode git commit: GEODE-545: fix race in testCustomEntryIdleReset

Posted by bs...@apache.org.
GEODE-545: fix race in testCustomEntryIdleReset


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

Branch: refs/heads/feature/GEODE-77
Commit: 355a2d35df846b675e25f05d797f9787bd77042a
Parents: 8b04c3d
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Thu Nov 12 16:07:56 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Nov 12 16:13:23 2015 -0800

----------------------------------------------------------------------
 .../gemfire/cache30/RegionTestCase.java         | 54 +++++++-------------
 1 file changed, 18 insertions(+), 36 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/355a2d35/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
index 35be2d0..0bc0ec0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
@@ -3457,7 +3457,7 @@ public abstract class RegionTestCase extends CacheTestCase {
   public void testCustomEntryIdleReset() {
 
     final String name = this.getUniqueName();
-    final int timeout = 200; // ms
+    final int timeout = 200*1000; // ms
     final String key1 = "KEY1";
     final String value = "VALUE";
     
@@ -3475,55 +3475,37 @@ public abstract class RegionTestCase extends CacheTestCase {
     factory.addCacheListener(list);
     RegionAttributes attrs = factory.create();
     
-    Region region = null;
     System.setProperty(LocalRegion.EXPIRY_MS_PROPERTY, "true");
     try {
-      region = createRegion(name, attrs);
+      LocalRegion region = (LocalRegion) createRegion(name, attrs);
 
     // DebuggerSupport.waitForJavaDebugger(getLogWriter(), "Set breakpoint in invalidate");
     ExpiryTask.suspendExpiration();
-    Region.Entry entry = null;
-    long tilt;
     try {
       region.create(key1, value);
-      tilt = System.currentTimeMillis() + timeout;
       assertTrue(list.waitForInvocation(5000));
-      entry = region.getEntry(key1);
+      Region.Entry entry = region.getEntry(key1);
       assertNotNull(entry.getValue());
-    } 
-    finally {
-      ExpiryTask.permitExpiration();
-    }
-    
-    pause(timeout / 2);
-    long now = System.currentTimeMillis();
-    if (entry.getValue() == null && now < tilt) {
-      fail("Entry invalidated " + (tilt - now) + " ms prematurely");
-    }
-    region.get(key1); // touch again
-    
-    waitForInvalidate(entry, tilt);
-
-    // Do it again with a put (I guess)
-    ExpiryTask.suspendExpiration();
-    try {
+      EntryExpiryTask eet = region.getEntryExpiryTask(key1);
+      final long createExpiryTime = eet.getExpirationTime();
+      waitForExpiryClockToChange(region);
+      region.get(key1);
+      assertSame(eet, region.getEntryExpiryTask(key1));
+      final long getExpiryTime = eet.getExpirationTime();
+      if (getExpiryTime - createExpiryTime <= 0L) {
+        fail("get did not reset the expiration time. createExpiryTime=" + createExpiryTime + " getExpiryTime=" + getExpiryTime);
+      }
+      waitForExpiryClockToChange(region);
       region.put(key1, value);
-      tilt = System.currentTimeMillis() + timeout;
-      entry = region.getEntry(key1);
-      assertNotNull(entry.getValue());
+      assertSame(eet, region.getEntryExpiryTask(key1));
+      final long putExpiryTime = eet.getExpirationTime();
+      if (putExpiryTime - getExpiryTime <= 0L) {
+        fail("put did not reset the expiration time. getExpiryTime=" + getExpiryTime + " putExpiryTime=" + putExpiryTime);
+      }
     } 
     finally {
       ExpiryTask.permitExpiration();
     }
-    
-    pause(timeout / 2);
-    now = System.currentTimeMillis();
-    if (entry.getValue() == null && now < tilt) {
-      fail("entry invalidated " + (tilt - now) + " ms prematurely");
-    }
-    region.put(key1, value); // touch
-    
-    waitForInvalidate(entry, tilt);
     } 
     finally {
       System.getProperties().remove(LocalRegion.EXPIRY_MS_PROPERTY);


[50/50] [abbrv] incubator-geode git commit: merge of develop to feature/GEODE-77

Posted by bs...@apache.org.
merge of develop to feature/GEODE-77

Merge remote-tracking branch 'origin/develop' into feature/GEODE-77

Conflicts:
	gemfire-core/build.gradle
	gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
	gemfire-jgroups/build.gradle


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

Branch: refs/heads/feature/GEODE-77
Commit: 766dfd05b378abc981b83a5372551c6df01bcda4
Parents: fd98f62 3fc2992
Author: Bruce Schuchardt <bs...@pivotal.io>
Authored: Tue Nov 17 12:44:50 2015 -0800
Committer: Bruce Schuchardt <bs...@pivotal.io>
Committed: Tue Nov 17 12:44:50 2015 -0800

----------------------------------------------------------------------
 build.gradle                                    |  63 +-
 gemfire-assembly/build.gradle                   |   2 +-
 gemfire-core/build.gradle                       | 186 ++---
 .../gemstone/gemfire/cache/GemFireCache.java    |   7 -
 .../internal/AsyncEventQueueFactoryImpl.java    |   9 +-
 .../internal/AsyncEventQueueImpl.java           |   3 +
 .../client/internal/EndpointManagerImpl.java    |   2 -
 .../internal/pooling/ConnectionManagerImpl.java |   5 +
 .../gemfire/cache/lucene/LuceneIndex.java       |  59 --
 .../gemfire/cache/lucene/LuceneQuery.java       |  53 --
 .../cache/lucene/LuceneQueryFactory.java        | 137 ----
 .../cache/lucene/LuceneQueryResults.java        |  45 --
 .../cache/lucene/LuceneResultStruct.java        |  75 --
 .../gemfire/cache/lucene/LuceneService.java     | 119 ---
 .../cache/lucene/LuceneServiceFactory.java      |  30 -
 .../cache/lucene/LuceneServiceProvider.java     |  52 --
 .../cache/lucene/internal/LuceneIndexImpl.java  |  70 --
 .../lucene/internal/LuceneQueryFactoryImpl.java | 104 ---
 .../cache/lucene/internal/LuceneQueryImpl.java  |  78 --
 .../lucene/internal/LuceneQueryResultsImpl.java |  82 --
 .../lucene/internal/LuceneResultStructImpl.java |  61 --
 .../internal/LuceneServiceFactoryImpl.java      |  32 -
 .../lucene/internal/LuceneServiceImpl.java      | 106 ---
 .../cache/partition/PartitionManager.java       |   2 +-
 .../internal/DistributionManager.java           | 322 ++------
 .../internal/DataSerializableFixedID.java       |   9 +
 .../com/gemstone/gemfire/internal/Version.java  |   5 +
 .../gemfire/internal/cache/BucketRegion.java    |   2 +-
 .../gemfire/internal/cache/CacheService.java    |  26 +
 .../gemfire/internal/cache/EntryEventImpl.java  |   1 -
 .../internal/cache/GemFireCacheImpl.java        |  79 +-
 .../gemfire/internal/cache/InternalCache.java   |   5 +-
 .../gemfire/internal/cache/LocalRegion.java     |   8 +-
 .../cache/MemberFunctionStreamingMessage.java   |   9 +-
 .../gemstone/gemfire/internal/cache/Oplog.java  |   1 -
 .../cache/PartitionedRegionDataStore.java       |   2 +-
 .../gemfire/internal/cache/RegionListener.java  |  30 +
 .../cache/control/OffHeapMemoryMonitor.java     |  34 +-
 .../cache/execute/ServerFunctionExecutor.java   |  18 -
 .../execute/TransactionFunctionService.java     | 193 -----
 .../cache/execute/util/CommitFunction.java      |   1 -
 .../cache/execute/util/RollbackFunction.java    |   1 -
 .../cache/extension/SimpleExtensionPoint.java   |   2 +-
 .../persistence/soplog/AbstractCompactor.java   | 533 -------------
 .../soplog/AbstractKeyValueIterator.java        |  76 --
 .../soplog/AbstractSortedReader.java            | 135 ----
 .../soplog/ArraySerializedComparator.java       | 144 ----
 .../cache/persistence/soplog/Compactor.java     | 174 -----
 .../soplog/CompositeSerializedComparator.java   |  57 --
 .../soplog/IndexSerializedComparator.java       | 127 ---
 .../cache/persistence/soplog/LevelTracker.java  | 120 ---
 .../soplog/LexicographicalComparator.java       | 460 -----------
 .../cache/persistence/soplog/NonCompactor.java  | 110 ---
 .../soplog/ReversingSerializedComparator.java   |  67 --
 .../persistence/soplog/SizeTieredCompactor.java | 198 -----
 .../cache/persistence/soplog/SoplogToken.java   | 116 ---
 .../cache/persistence/soplog/SortedBuffer.java  | 367 ---------
 .../cache/persistence/soplog/SortedOplog.java   | 158 ----
 .../persistence/soplog/SortedOplogFactory.java  | 278 -------
 .../persistence/soplog/SortedOplogSet.java      | 118 ---
 .../persistence/soplog/SortedOplogSetImpl.java  | 780 -------------------
 .../soplog/hfile/BlockCacheHolder.java          |  39 -
 .../soplog/hfile/HFileSortedOplog.java          | 694 -----------------
 .../soplog/hfile/HFileSortedOplogFactory.java   |  80 --
 .../soplog/nofile/NoFileSortedOplog.java        | 244 ------
 .../soplog/nofile/NoFileSortedOplogFactory.java |  41 -
 .../cache/tier/sockets/CommandInitializer.java  |   4 +
 .../tier/sockets/command/CommitCommand.java     |   4 +-
 .../tier/sockets/command/ExecuteFunction66.java |   2 +-
 .../command/ExecuteRegionFunction66.java        |   2 +-
 .../command/ExecuteRegionFunctionSingleHop.java |   2 +-
 .../cache/wan/AbstractGatewaySender.java        |  10 +
 .../cache/wan/GatewaySenderAttributes.java      |   5 +
 .../internal/cache/xmlcache/CacheCreation.java  |  14 +-
 .../cache/xmlcache/DefaultEntityResolver2.java  |   2 +-
 .../cache/xmlcache/GeodeEntityResolver.java     |  49 ++
 .../cache/xmlcache/PivotalEntityResolver.java   |   2 +-
 .../gemfire/internal/offheap/OffHeapHelper.java |   4 +-
 .../internal/offheap/OffHeapReference.java      |  72 --
 .../offheap/SimpleMemoryAllocatorImpl.java      |  28 +-
 .../gemfire/internal/offheap/StoredObject.java  |  42 +-
 .../util/concurrent/CopyOnWriteHashMap.java     |  46 +-
 .../util/concurrent/CopyOnWriteWeakHashMap.java |  12 +
 .../services/org.xml.sax.ext.EntityResolver2    |   1 +
 .../SerialAsyncEventQueueImplJUnitTest.java     |  46 ++
 .../management/MemoryThresholdsDUnitTest.java   |  46 +-
 .../partition/PartitionManagerDUnitTest.java    |  75 --
 .../gemfire/cache30/RegionTestCase.java         |  54 +-
 .../internal/ProductUseLogDUnitTest.java        |   3 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |   2 +-
 .../gemfire/internal/JSSESocketJUnitTest.java   |   2 +-
 .../internal/cache/CacheServiceJUnitTest.java   |  43 +
 .../cache/ClientServerTransactionDUnitTest.java |  31 +-
 .../internal/cache/MockCacheService.java        |   8 +
 .../internal/cache/MockCacheServiceImpl.java    |  23 +
 .../gemfire/internal/cache/OplogJUnitTest.java  |  46 +-
 .../internal/cache/RegionListenerJUnitTest.java |  47 ++
 .../control/TestMemoryThresholdListener.java    |  13 +
 .../MemberFunctionExecutionDUnitTest.java       |  49 ++
 .../mock/DestroyMockCacheExtensionFunction.java |   2 +-
 .../cache/persistence/soplog/AppendLog.java     |  65 --
 .../ArraySerializedComparatorJUnitTest.java     |  95 ---
 .../CompactionSortedOplogSetTestCase.java       | 134 ----
 .../persistence/soplog/CompactionTestCase.java  | 206 -----
 .../persistence/soplog/ComparisonTestCase.java  |  77 --
 .../soplog/IndexComparatorJUnitTest.java        |  79 --
 .../LexicographicalComparatorJUnitTest.java     | 204 -----
 .../soplog/RecoverableSortedOplogSet.java       | 221 ------
 .../soplog/SizeTieredCompactorJUnitTest.java    | 110 ---
 .../SizeTieredSortedOplogSetJUnitTest.java      |  43 -
 .../soplog/SortedBufferJUnitTest.java           |  39 -
 .../soplog/SortedOplogSetJUnitTest.java         | 273 -------
 .../soplog/SortedReaderTestCase.java            | 295 -------
 .../nofile/NoFileSortedOplogJUnitTest.java      |  48 --
 .../tier/sockets/command/CommitCommandTest.java |  39 +
 .../internal/i18n/BasicI18nJUnitTest.java       |  12 -
 .../concurrent/CopyOnWriteHashMapJUnitTest.java | 496 ++++++++++++
 .../management/DistributedSystemDUnitTest.java  |  12 +-
 ...gemstone.gemfire.internal.cache.CacheService |   1 +
 .../codeAnalysis/sanctionedSerializables.txt    |   2 +-
 .../src/main/java/org/json/JSONObject.java      |   2 +
 gemfire-lucene/build.gradle                     |  29 +
 .../gemfire/cache/lucene/LuceneIndex.java       |  60 ++
 .../gemfire/cache/lucene/LuceneQuery.java       |  48 ++
 .../cache/lucene/LuceneQueryFactory.java        | 101 +++
 .../cache/lucene/LuceneQueryProvider.java       |  45 ++
 .../cache/lucene/LuceneQueryResults.java        |  58 ++
 .../cache/lucene/LuceneResultStruct.java        |  62 ++
 .../gemfire/cache/lucene/LuceneService.java     | 125 +++
 .../cache/lucene/LuceneServiceProvider.java     |  46 ++
 .../lucene/internal/InternalLuceneIndex.java    |  29 +
 .../lucene/internal/InternalLuceneService.java  |  29 +
 .../lucene/internal/LuceneEventListener.java    |  99 +++
 .../LuceneIndexForPartitionedRegion.java        | 136 ++++
 .../LuceneIndexForReplicatedRegion.java         |  48 ++
 .../cache/lucene/internal/LuceneIndexImpl.java  | 107 +++
 .../lucene/internal/LuceneQueryFactoryImpl.java |  67 ++
 .../cache/lucene/internal/LuceneQueryImpl.java  |  87 +++
 .../lucene/internal/LuceneQueryResultsImpl.java | 120 +++
 .../lucene/internal/LuceneResultStructImpl.java |  94 +++
 .../lucene/internal/LuceneServiceImpl.java      | 273 +++++++
 .../internal/PartitionedRepositoryManager.java  | 163 ++++
 .../lucene/internal/StringQueryProvider.java    | 106 +++
 .../internal/directory/FileIndexInput.java      | 131 ++++
 .../internal/directory/RegionDirectory.java     | 119 +++
 .../internal/distributed/CollectorManager.java  |  55 ++
 .../lucene/internal/distributed/EntryScore.java |  82 ++
 .../internal/distributed/LuceneFunction.java    | 137 ++++
 .../distributed/LuceneFunctionContext.java      | 115 +++
 .../lucene/internal/distributed/TopEntries.java | 133 ++++
 .../distributed/TopEntriesCollector.java        | 102 +++
 .../distributed/TopEntriesCollectorManager.java | 178 +++++
 .../TopEntriesFunctionCollector.java            | 163 ++++
 .../lucene/internal/filesystem/ChunkKey.java    | 123 +++
 .../cache/lucene/internal/filesystem/File.java  | 155 ++++
 .../internal/filesystem/FileInputStream.java    | 166 ++++
 .../internal/filesystem/FileOutputStream.java   | 103 +++
 .../lucene/internal/filesystem/FileSystem.java  | 156 ++++
 .../filesystem/SeekableInputStream.java         |  43 +
 .../internal/repository/IndexRepository.java    |  74 ++
 .../repository/IndexRepositoryImpl.java         | 113 +++
 .../repository/IndexResultCollector.java        |  47 ++
 .../internal/repository/RepositoryManager.java  |  45 ++
 .../HeterogenousLuceneSerializer.java           |  83 ++
 .../repository/serializer/LuceneSerializer.java |  35 +
 .../serializer/PdxLuceneSerializer.java         |  47 ++
 .../serializer/ReflectionLuceneSerializer.java  |  74 ++
 .../repository/serializer/SerializerUtil.java   | 168 ++++
 .../internal/xml/LuceneIndexCreation.java       | 111 +++
 .../internal/xml/LuceneIndexXmlGenerator.java   |  65 ++
 .../internal/xml/LuceneServiceXmlGenerator.java |  39 +
 .../lucene/internal/xml/LuceneXmlConstants.java |  31 +
 .../lucene/internal/xml/LuceneXmlParser.java    |  97 +++
 .../lucene/lucene-1.0.xsd                       |  42 +
 ...gemstone.gemfire.internal.cache.CacheService |   1 +
 ...ne.gemfire.internal.cache.xmlcache.XmlParser |   1 +
 .../internal/LuceneEventListenerJUnitTest.java  | 109 +++
 .../LuceneIndexRecoveryHAJUnitTest.java         | 201 +++++
 .../LuceneQueryFactoryImplJUnitTest.java        |  50 ++
 .../internal/LuceneQueryImplJUnitTest.java      | 123 +++
 .../LuceneQueryResultsImplJUnitTest.java        | 126 +++
 .../LuceneResultStructImpJUnitTest.java         |  51 ++
 .../internal/LuceneServiceImplJUnitTest.java    | 226 ++++++
 .../PartitionedRepositoryManagerJUnitTest.java  | 230 ++++++
 .../internal/StringQueryProviderJUnitTest.java  |  90 +++
 .../directory/RegionDirectoryJUnitTest.java     |  56 ++
 .../DistributedScoringJUnitTest.java            | 155 ++++
 .../distributed/EntryScoreJUnitTest.java        |  40 +
 .../LuceneFunctionContextJUnitTest.java         |  64 ++
 .../distributed/LuceneFunctionJUnitTest.java    | 423 ++++++++++
 .../LuceneFunctionReadPathDUnitTest.java        | 241 ++++++
 .../TopEntriesCollectorJUnitTest.java           | 139 ++++
 .../TopEntriesFunctionCollectorJUnitTest.java   | 323 ++++++++
 .../distributed/TopEntriesJUnitTest.java        | 146 ++++
 .../internal/filesystem/ChunkKeyJUnitTest.java  |  48 ++
 .../internal/filesystem/FileJUnitTest.java      |  53 ++
 .../filesystem/FileSystemJUnitTest.java         | 578 ++++++++++++++
 ...IndexRepositoryImplJUnitPerformanceTest.java | 437 +++++++++++
 .../IndexRepositoryImplJUnitTest.java           | 208 +++++
 .../HeterogenousLuceneSerializerJUnitTest.java  |  90 +++
 .../serializer/PdxFieldMapperJUnitTest.java     |  85 ++
 .../ReflectionFieldMapperJUnitTest.java         |  85 ++
 .../internal/repository/serializer/Type1.java   |  48 ++
 .../internal/repository/serializer/Type2.java   |  34 +
 ...neIndexXmlGeneratorIntegrationJUnitTest.java |  78 ++
 .../xml/LuceneIndexXmlGeneratorJUnitTest.java   |  80 ++
 ...uceneIndexXmlParserIntegrationJUnitTest.java | 107 +++
 .../xml/LuceneIndexXmlParserJUnitTest.java      |  72 ++
 ...erIntegrationJUnitTest.createIndex.cache.xml |  24 +
 ...serIntegrationJUnitTest.parseIndex.cache.xml |  24 +
 gemfire-rebalancer/build.gradle                 |  10 +-
 gemfire-web-api/build.gradle                    |  46 +-
 gemfire-web/build.gradle                        |  12 +-
 gradle/dependency-versions.properties           |  64 ++
 settings.gradle                                 |   1 +
 215 files changed, 11345 insertions(+), 9088 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/build.gradle
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-assembly/build.gradle
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/build.gradle
----------------------------------------------------------------------
diff --cc gemfire-core/build.gradle
index d44a649,f03066f..aa143b1
--- a/gemfire-core/build.gradle
+++ b/gemfire-core/build.gradle
@@@ -11,79 -11,77 +11,78 @@@ configurations 
  }
  
  dependencies {
+    // Source Dependencies
+   // External 
    provided files("${System.getProperty('java.home')}/../lib/tools.jar")
 +  compile 'org.jgroups:jgroups:3.6.6.Final'
-   compile 'antlr:antlr:2.7.7'
-   compile 'com.fasterxml.jackson.core:jackson-annotations:2.2.0'
-   compile 'com.fasterxml.jackson.core:jackson-core:2.2.0'
-   compile 'com.fasterxml.jackson.core:jackson-databind:2.2.0'
-   compile 'com.google.code.findbugs:annotations:3.0.0'
-   compile 'commons-io:commons-io:2.3'
-   compile 'commons-logging:commons-logging:1.1.1'
-   compile 'commons-modeler:commons-modeler:2.0'
-   compile 'org.apache.lucene:lucene-analyzers-common:5.0.0'
-   compile 'org.apache.lucene:lucene-core:5.0.0'
-   compile 'org.apache.lucene:lucene-queries:5.0.0'
-   compile 'org.apache.lucene:lucene-queryparser:5.0.0'
-   compile 'it.unimi.dsi:fastutil:7.0.2'
-   compile 'javax.activation:activation:1.1.1'
-   compile 'javax.mail:javax.mail-api:1.4.5'
-   compile 'javax.resource:javax.resource-api:1.7'
-   compile 'javax.servlet:javax.servlet-api:3.1.0'
-   compile 'javax.transaction:javax.transaction-api:1.2'
-   compile 'mx4j:mx4j:3.0.1'
-   compile 'mx4j:mx4j-remote:3.0.1'
-   compile 'mx4j:mx4j-tools:3.0.1'
-   compile 'net.java.dev.jna:jna:4.0.0'
-   compile 'net.sourceforge.jline:jline:1.0.S2-B'
-   compile 'org.eclipse.jetty:jetty-http:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-io:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-security:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-server:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-servlet:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-util:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-webapp:9.2.3.v20140905'
-   compile 'org.eclipse.jetty:jetty-xml:9.2.3.v20140905'
-   compile 'org.fusesource.jansi:jansi:1.8'
-   compile 'org.apache.logging.log4j:log4j-api:2.1'
-   compile 'org.apache.logging.log4j:log4j-core:2.1'
-   runtime 'org.apache.logging.log4j:log4j-slf4j-impl:2.1'
-   runtime 'org.apache.logging.log4j:log4j-jcl:2.1'
-   runtime 'org.apache.logging.log4j:log4j-jul:2.1'
-   compile 'org.slf4j:slf4j-api:1.7.7'
-   compile 'org.springframework.data:spring-data-commons:1.9.1.RELEASE'
-   provided 'org.springframework.data:spring-data-gemfire:1.5.1.RELEASE'
-   compile 'org.springframework:spring-tx:3.2.12.RELEASE'
-   compile 'org.springframework.shell:spring-shell:1.0.0.RELEASE'
-   compile 'org.xerial.snappy:snappy-java:1.1.1.6'
-   provided 'org.apache.hadoop:hadoop-common:2.4.1'
-   provided 'org.apache.hadoop:hadoop-annotations:2.4.1'
-   provided 'org.apache.hadoop:hadoop-hdfs:2.4.1'
-   provided 'org.apache.hadoop:hadoop-mapreduce-client-core:2.4.1'
-   compile 'org.apache.hbase:hbase:0.94.27'
-   provided 'commons-lang:commons-lang:2.5'
-   provided 'com.google.guava:guava:11.0.2'
-   compile 'io.netty:netty-all:4.0.4.Final'
- 
-   testRuntime 'org.apache.hadoop:hadoop-auth:2.4.1'
-   testRuntime 'commons-collections:commons-collections:3.2.1'
-   testRuntime 'commons-configuration:commons-configuration:1.6'
-   testRuntime 'commons-io:commons-io:2.1'
-   testRuntime 'log4j:log4j:1.2.17'
-   
+   compile 'antlr:antlr:' + project.'antlr.version'
+   compile 'com.fasterxml.jackson.core:jackson-annotations:' + project.'jackson.version'
+   compile 'com.fasterxml.jackson.core:jackson-core:' + project.'jackson.version'
+   compile 'com.fasterxml.jackson.core:jackson-databind:' + project.'jackson.version'
+   compile 'com.google.code.findbugs:annotations:' + project.'annotations.version'
+   provided 'com.google.guava:guava:' + project.'guava.version'
+   compile 'commons-io:commons-io:' + project.'commons-io.version'
+   provided 'commons-lang:commons-lang:' + project.'commons-lang.version'
+   compile 'commons-logging:commons-logging:' + project.'commons-logging.version'
+   compile 'commons-modeler:commons-modeler:' + project.'commons-modeler.version'
+   compile 'io.netty:netty-all:' + project.'netty-all.version'
+   compile 'it.unimi.dsi:fastutil:' + project.'fastutil.version'
+   compile 'javax.activation:activation:' + project.'activation.version'
+   compile 'javax.mail:javax.mail-api:' + project.'javax.mail-api.version'
+   compile 'javax.resource:javax.resource-api:' + project.'javax.resource-api.version'
+   compile 'javax.servlet:javax.servlet-api:' + project.'javax.servlet-api.version'
+   compile 'javax.transaction:javax.transaction-api:' + project.'javax.transaction-api.version'
+   compile 'mx4j:mx4j:' + project.'mx4j.version'
+   compile 'mx4j:mx4j-remote:' + project.'mx4j.version'
+   compile 'mx4j:mx4j-tools:' + project.'mx4j.version'
+   compile 'net.java.dev.jna:jna:' + project.'jna.version'
+   compile 'net.sourceforge.jline:jline:' + project.'jline.version'
+   provided 'org.apache.hadoop:hadoop-common:' + project.'hadoop.version'
+   provided 'org.apache.hadoop:hadoop-annotations:' + project.'hadoop.version'
+   provided 'org.apache.hadoop:hadoop-hdfs:' + project.'hadoop.version'
+   provided 'org.apache.hadoop:hadoop-mapreduce-client-core:' + project.'hadoop.version'
+   compile 'org.apache.hbase:hbase:' + project.'hbase.version'
+   compile 'org.apache.logging.log4j:log4j-api:' + project.'log4j.version'
+   compile 'org.apache.logging.log4j:log4j-core:' + project.'log4j.version'
+   runtime 'org.apache.logging.log4j:log4j-slf4j-impl:' + project.'log4j.version'
+   runtime 'org.apache.logging.log4j:log4j-jcl:' + project.'log4j.version'
+   runtime 'org.apache.logging.log4j:log4j-jul:' + project.'log4j.version'
+   compile 'org.eclipse.jetty:jetty-http:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-io:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-security:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-server:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-servlet:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-util:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-webapp:' + project.'jetty.version'
+   compile 'org.eclipse.jetty:jetty-xml:' + project.'jetty.version'
+   compile 'org.fusesource.jansi:jansi:' + project.'jansi.version'
+   compile 'org.slf4j:slf4j-api:' + project.'slf4j-api.version'
+   compile 'org.springframework.data:spring-data-commons:' + project.'spring-data-commons.version'
+   provided 'org.springframework.data:spring-data-gemfire:' + project.'spring-data-gemfire.version'
+   compile 'org.springframework:spring-tx:' + project.'springframework.version'
+   compile 'org.springframework.shell:spring-shell:' + project.'spring-shell.version'
+   compile 'org.xerial.snappy:snappy-java:' + project.'snappy-java.version'
+   compile 'org.apache.hbase:hbase:' + project.'hbase.version'
+  
    compile project(':gemfire-common')
 -  compile project(':gemfire-jgroups')
    compile project(':gemfire-joptsimple')
    compile project(':gemfire-json')
    
    jcaCompile sourceSets.main.output
  
    provided project(path: ':gemfire-junit', configuration: 'testOutput')
+ 
+   // Test Dependencies
+   // External
+   testCompile 'org.apache.bcel:bcel:' + project.'bcel.version'
+   testRuntime 'org.apache.derby:derby:' + project.'derby.version'
+   testRuntime 'org.apache.hadoop:hadoop-auth:' + project.'hadoop.version'
++  testCompile 'org.mockito:mockito-core:' + project.'mockito-core.version'
+   testRuntime 'commons-collections:commons-collections:' + project.'commons-collections.version'
+   testRuntime 'commons-configuration:commons-configuration:' + project.'commons-configuration.version'
+   testRuntime 'commons-io:commons-io:' + project.'commons-io.version'
+   testCompile 'net.spy:spymemcached:' + project.'spymemcached.version'
+   testCompile 'redis.clients:jedis:' + project.'jedis.version'
  }
  
  def generatedResources = "$buildDir/generated-resources/main"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
----------------------------------------------------------------------
diff --cc gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
index cb09643,83e4878..d31ff3c
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
@@@ -41,8 -41,9 +41,9 @@@ import com.gemstone.gemfire.internal.lo
  import com.gemstone.gemfire.internal.logging.LogService;
  import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
  import com.gemstone.gemfire.security.GemFireSecurityException;
 -import com.gemstone.org.jgroups.util.StringId;
 +import com.gemstone.gemfire.i18n.StringId;
  
+ import java.net.SocketException;
  import java.util.ArrayList;
  import java.util.Collections;
  import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
----------------------------------------------------------------------
diff --cc gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
index 882358e,9c06fa1..247775d
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionManager.java
@@@ -4800,13 -4688,9 +4606,9 @@@ public class DistributionManage
        this.view = view;
      }
      public long getViewId() {
 -      return view.getViewNumber();
 +      return view.getViewId();
      }
      @Override
-     public int eventType() {
-       return VIEW_INSTALLED;
-     }
-     @Override
      public String toString() {
        return "view installed: " + this.view;
      }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/main/java/com/gemstone/gemfire/internal/Version.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
----------------------------------------------------------------------
diff --cc gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
index 5232dc9,1900297..c17caa2
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
@@@ -214,8 -213,7 +213,7 @@@ import com.gemstone.gemfire.internal.se
  import com.gemstone.gemfire.internal.util.concurrent.FutureResult;
  import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
  import com.gemstone.gemfire.internal.util.concurrent.StoppableReadWriteLock;
- import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock.StoppableWriteLock;
 -import com.gemstone.org.jgroups.util.StringId;
 +import com.gemstone.gemfire.i18n.StringId;
  
  /**
   * Implementation of a local scoped-region. Note that this class has a different

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataStore.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
----------------------------------------------------------------------
diff --cc gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
index b2adc64,4edab28..2f8f7c0
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
@@@ -402,10 -402,10 +402,10 @@@ public class MemoryThresholdsDUnitTest 
      final String regionName = "testEventDelivery";
  
      ServerPorts ports1 = startCacheServer(server1, 0f, 0f, regionName, false/*createPR*/, false/*notifyBySubscription*/, 0);
 -    ServerPorts ports2 = startCacheServer(server2, ports1.getMcastPort(), 80f, 90f,
 +    ServerPorts ports2 = startCacheServer(server2, 80f, 90f,
          regionName, false/*createPR*/, false/*notifyBySubscription*/, 0);
  
-     registerTestMemoryThresholdListener(server1);
+     registerLoggingTestMemoryThresholdListener(server1);
      registerTestMemoryThresholdListener(server2);
  
      //NORMAL -> CRITICAL

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
----------------------------------------------------------------------
diff --cc gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
index fcae123,28934b3..3e1efd8
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/i18n/BasicI18nJUnitTest.java
@@@ -205,21 -206,9 +205,9 @@@ public class BasicI18nJUnitTest extend
    @Override
    public void tearDown() {
      //reset to the original
 -    StringIdImpl.setLocale(DEFAULT_LOCALE);
 +    StringId.setLocale(DEFAULT_LOCALE);
    }
  
-   public void testDefaults() {
-     Locale l = getCurrentLocale();
-     AbstractStringIdResourceBundle r = getActiveResourceBundle();
-     assertNotNull(l);
-     assertNotNull(r);
-     final String currentLang = l.getLanguage();
-     final String expectedLang = new Locale("en", "", "").getLanguage();
-     final String frenchLang = new Locale("fr", "", "").getLanguage();
-     // TODO this will fail if run under a locale with a language other than french or english
-     assertTrue(currentLang.equals(expectedLang) || currentLang.equals(frenchLang));
-   }
- 
    public void testSetLocale() {
      //Verify we are starting in a known state
      assertTrue(DEFAULT_LOCALE.equals(getCurrentLocale()));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/gemfire-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/766dfd05/settings.gradle
----------------------------------------------------------------------


[02/50] [abbrv] incubator-geode git commit: GEODE-11: Add dunits for various partition regions

Posted by bs...@apache.org.
GEODE-11: Add dunits for various partition regions


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

Branch: refs/heads/feature/GEODE-77
Commit: 28a0eb81740076278d9471872ced68c1f01183d7
Parents: 1f597bb
Author: Ashvin Agrawal <as...@apache.org>
Authored: Fri Oct 16 15:45:06 2015 -0700
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Fri Oct 16 15:49:06 2015 -0700

----------------------------------------------------------------------
 .../LuceneFunctionReadPathDUnitTest.java        | 170 ++++++++++++-------
 1 file changed, 104 insertions(+), 66 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/28a0eb81/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
index 0bf1842..b3460b7 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
@@ -1,6 +1,5 @@
 package com.gemstone.gemfire.cache.lucene.internal.distributed;
 
-import java.io.IOException;
 import java.io.Serializable;
 import java.util.HashMap;
 import java.util.List;
@@ -11,6 +10,8 @@ import org.junit.Assert;
 import org.junit.experimental.categories.Category;
 
 import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.EvictionAction;
+import com.gemstone.gemfire.cache.EvictionAlgorithm;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionFactory;
 import com.gemstone.gemfire.cache.RegionShortcut;
@@ -21,10 +22,10 @@ import com.gemstone.gemfire.cache.lucene.LuceneQueryResults;
 import com.gemstone.gemfire.cache.lucene.LuceneResultStruct;
 import com.gemstone.gemfire.cache.lucene.LuceneService;
 import com.gemstone.gemfire.cache.lucene.LuceneServiceProvider;
-import com.gemstone.gemfire.cache.lucene.internal.InternalLuceneIndex;
 import com.gemstone.gemfire.cache.lucene.internal.LuceneServiceImpl;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-import com.gemstone.gemfire.internal.cache.BucketNotFoundException;
+import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
+import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
 import dunit.Host;
@@ -34,7 +35,6 @@ import dunit.VM;
 @Category(DistributedTest.class)
 public class LuceneFunctionReadPathDUnitTest extends CacheTestCase {
   private static final String INDEX_NAME = "index";
-  private static final String REGION_NAME = "indexedRegion";
 
   private static final long serialVersionUID = 1L;
 
@@ -54,101 +54,140 @@ public class LuceneFunctionReadPathDUnitTest extends CacheTestCase {
   }
 
   public void testEnd2EndFunctionExecution() {
-    SerializableCallable createPartitionRegion = new SerializableCallable("createRegion") {
+    e2eTextSearchForRegionType(RegionShortcut.PARTITION);
+    e2eTextSearchForRegionType(RegionShortcut.PARTITION_PERSISTENT);
+    e2eTextSearchForRegionType(RegionShortcut.PARTITION_OVERFLOW);
+    e2eTextSearchForRegionType(RegionShortcut.PARTITION_PERSISTENT_OVERFLOW);
+  }
+
+  private void e2eTextSearchForRegionType(RegionShortcut type) {
+    final String regionName = type.toString();
+    createPartitionRegionAndIndex(server1, regionName, type);
+    putDataInRegion(server1, regionName);
+    createPartitionRegionAndIndex(server2, regionName, type);
+    // Make sure we can search from both members
+    executeTextSearch(server1, regionName);
+    executeTextSearch(server2, regionName);
+
+    rebalanceRegion(server1);
+    // Make sure the search still works
+    executeTextSearch(server1, regionName);
+    executeTextSearch(server2, regionName);
+    destroyRegion(server2, regionName);
+  }
+
+  private void rebalanceRegion(VM vm) {
+    // Do a rebalance
+    vm.invoke(new SerializableCallable<Object>() {
+      private static final long serialVersionUID = 1L;
+
+      @Override
+      public Object call() throws CancellationException, InterruptedException {
+        RebalanceOperation op = getCache().getResourceManager().createRebalanceFactory().start();
+        RebalanceResults results = op.getResults();
+        assertTrue(1 < results.getTotalBucketTransfersCompleted());
+        return null;
+      }
+    });
+  }
+
+  private void executeTextSearch(VM vm, final String regionName) {
+    SerializableCallable<Object> executeSearch = new SerializableCallable<Object>("executeSearch") {
       private static final long serialVersionUID = 1L;
 
       public Object call() throws Exception {
-        final Cache cache = getCache();
+        Cache cache = getCache();
         assertNotNull(cache);
+        Region<Object, Object> region = cache.getRegion(regionName);
+        Assert.assertNotNull(region);
+
         LuceneService service = LuceneServiceProvider.get(cache);
-        service.createIndex(INDEX_NAME, REGION_NAME, "text");
-        RegionFactory<Object, Object> regionFactory = cache.createRegionFactory(RegionShortcut.PARTITION);
-        Region<Object, Object> region = regionFactory.
-            create(REGION_NAME);
+        LuceneQuery<Integer, TestObject> query;
+        query = service.createLuceneQueryFactory().create(INDEX_NAME, regionName, "text:world");
+        LuceneQueryResults<Integer, TestObject> results = query.search();
+        assertEquals(3, results.size());
+        List<LuceneResultStruct<Integer, TestObject>> page = results.getNextPage();
+
+        Map<Integer, TestObject> data = new HashMap<Integer, TestObject>();
+        for (LuceneResultStruct<Integer, TestObject> row : page) {
+          data.put(row.getKey(), row.getValue());
+        }
+
+        assertEquals(data, region);
         return null;
       }
     };
-        
-    server1.invoke(createPartitionRegion);
-    
 
-    SerializableCallable createSomeData = new SerializableCallable("createRegion") {
+    vm.invoke(executeSearch);
+  }
+
+  private void putDataInRegion(VM vm, final String regionName) {
+    SerializableCallable<Object> createSomeData = new SerializableCallable<Object>("putDataInRegion") {
       private static final long serialVersionUID = 1L;
 
       public Object call() throws Exception {
         final Cache cache = getCache();
-        Region<Object, Object> region = cache.getRegion(REGION_NAME);
-        
-        putInRegion(region, 1, new TestObject("hello world"));
-        putInRegion(region, 113, new TestObject("hi world"));
-        putInRegion(region, 2, new TestObject("goodbye world"));
-        
+        Region<Object, Object> region = cache.getRegion(regionName);
+        assertNotNull(region);
+        region.put(1, new TestObject("hello world"));
+        region.put(113, new TestObject("hi world"));
+        region.put(2, new TestObject("goodbye world"));
+
         return null;
       }
     };
 
-    server1.invoke(createSomeData);
-    server2.invoke(createPartitionRegion);
+    vm.invoke(createSomeData);
+  }
 
-    SerializableCallable executeSearch = new SerializableCallable("executeSearch") {
+  private void createPartitionRegionAndIndex(VM vm, final String regionName, final RegionShortcut type) {
+    SerializableCallable<Object> createPartitionRegion = new SerializableCallable<Object>("createRegionAndIndex") {
       private static final long serialVersionUID = 1L;
 
       public Object call() throws Exception {
-        Cache cache = getCache();
+        final Cache cache = getCache();
         assertNotNull(cache);
-        Region<Object, Object> region = cache.getRegion(REGION_NAME);
-        Assert.assertNotNull(region);
-
         LuceneService service = LuceneServiceProvider.get(cache);
-        LuceneQuery<Integer, TestObject> query = service.createLuceneQueryFactory().create(INDEX_NAME, REGION_NAME, "text:world");
-        LuceneQueryResults<Integer, TestObject> results = query.search();
-        assertEquals(3, results.size());
-        List<LuceneResultStruct<Integer, TestObject>> page = results.getNextPage();
-        
-        Map<Integer, TestObject> data = new HashMap<Integer, TestObject>();
-        for(LuceneResultStruct<Integer, TestObject> row : page) {
-          data.put(row.getKey(), row.getValue());
+        service.createIndex(INDEX_NAME, regionName, "text");
+        RegionFactory<Object, Object> regionFactory = cache.createRegionFactory(type);
+        if (regionName.contains("OVERFLOW")) {
+          System.out.println("yello");
+          EvictionAttributesImpl evicAttr = new EvictionAttributesImpl().setAction(EvictionAction.OVERFLOW_TO_DISK);
+          evicAttr.setAlgorithm(EvictionAlgorithm.LRU_ENTRY).setMaximum(1);
+          regionFactory.setEvictionAttributes(evicAttr);
         }
-        
-        assertEquals(data, region);
-        
+        regionFactory.create(regionName);
         return null;
       }
     };
+    vm.invoke(createPartitionRegion);
+  }
 
-    //Make sure we can search from both members
-    server1.invoke(executeSearch);
-    server2.invoke(executeSearch);
+  private void destroyRegion(VM vm, final String regionName) {
+    SerializableCallable<Object> createPartitionRegion = new SerializableCallable<Object>("destroyRegion") {
+      private static final long serialVersionUID = 1L;
 
-    //Do a rebalance
-    server1.invoke(new SerializableCallable() {
-      @Override
-      public Object call() throws CancellationException, InterruptedException {
-        RebalanceOperation op = getCache().getResourceManager().createRebalanceFactory().start();
-        RebalanceResults results = op.getResults();
-        assertTrue(1 < results.getTotalBucketTransfersCompleted());
+      public Object call() throws Exception {
+        final Cache cache = getCache();
+        assertNotNull(cache);
+        String aeqId = LuceneServiceImpl.getUniqueIndexName(INDEX_NAME, regionName);
+        PartitionedRegion chunkRegion = (PartitionedRegion) cache.getRegion(aeqId + ".chunks");
+        assertNotNull(chunkRegion);
+        chunkRegion.destroyRegion();
+        PartitionedRegion fileRegion = (PartitionedRegion) cache.getRegion(aeqId + ".files");
+        assertNotNull(fileRegion);
+        fileRegion.destroyRegion();
+        Region<Object, Object> region = cache.getRegion(regionName);
+        assertNotNull(region);
+        region.destroyRegion();
         return null;
       }
-    });
-    
-    //Make sure the search still works
-    server1.invoke(executeSearch);
-    server2.invoke(executeSearch);
-  }
-  
-  private static void putInRegion(Region<Object, Object> region, Object key, Object value) throws BucketNotFoundException, IOException {
-    region.put(key, value);
-    
-    //TODO - the async event queue hasn't been hooked up, so we'll fake out
-    //writing the entry to the repository.
-//    LuceneService service = LuceneServiceProvider.get(region.getCache());
-//    InternalLuceneIndex index = (InternalLuceneIndex) service.getIndex(INDEX_NAME, REGION_NAME);
-//    IndexRepository repository1 = index.getRepositoryManager().getRepository(region, 1, null);
-//    repository1.create(key, value);
-//    repository1.commit();
+    };
+    vm.invoke(createPartitionRegion);
   }
 
   private static class TestObject implements Serializable {
+    private static final long serialVersionUID = 1L;
     private String text;
 
     public TestObject(String text) {
@@ -180,5 +219,4 @@ public class LuceneFunctionReadPathDUnitTest extends CacheTestCase {
       return true;
     }
   }
-
 }


[04/50] [abbrv] incubator-geode git commit: GEODE-485: Logging at debug level on a SocketException while closing the connection

Posted by bs...@apache.org.
GEODE-485: Logging at debug level on a SocketException while closing the connection

This avoids any suspect strings written to logs.


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

Branch: refs/heads/feature/GEODE-77
Commit: 59de5551e77fbcc1b37227520807834ce45da6da
Parents: fc4bbfc
Author: Sai Boorlagadda <sb...@pivotal.io>
Authored: Wed Oct 28 11:37:49 2015 -0700
Committer: Sai Boorlagadda <sb...@pivotal.io>
Committed: Fri Oct 30 11:59:56 2015 -0700

----------------------------------------------------------------------
 .../cache/client/internal/pooling/ConnectionManagerImpl.java    | 5 +++++
 1 file changed, 5 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/59de5551/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
index 5f6dc25..83e4878 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerImpl.java
@@ -43,6 +43,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
 import com.gemstone.gemfire.security.GemFireSecurityException;
 import com.gemstone.org.jgroups.util.StringId;
 
+import java.net.SocketException;
 import java.util.ArrayList;
 import java.util.Collections;
 import java.util.HashMap;
@@ -1171,6 +1172,10 @@ public class ConnectionManagerImpl implements ConnectionManager {
         if (!pc.isDestroyed()) {
           try {
             pc.internalClose(keepAlive);
+          } catch(SocketException se) {
+              logger.info(LocalizedMessage.create(
+                      LocalizedStrings.ConnectionManagerImpl_ERROR_CLOSING_CONNECTION_TO_SERVER_0,
+                      pc.getServer()), se);
           } catch(Exception e) {
             logger.warn(LocalizedMessage.create(
                 LocalizedStrings.ConnectionManagerImpl_ERROR_CLOSING_CONNECTION_TO_SERVER_0, 


[07/50] [abbrv] incubator-geode git commit: Merge branch 'feature/GEODE-409' into develop

Posted by bs...@apache.org.
Merge branch 'feature/GEODE-409' into develop


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

Branch: refs/heads/feature/GEODE-77
Commit: b2b2de8b2945c6f1778c2b20b10448cc6e638538
Parents: af3199e eced0c5
Author: Ashvin Agrawal <as...@apache.org>
Authored: Thu Nov 5 14:31:35 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Thu Nov 5 14:31:35 2015 -0800

----------------------------------------------------------------------
 .../gemstone/gemfire/internal/cache/Oplog.java  |  1 -
 .../gemfire/internal/cache/OplogJUnitTest.java  | 46 +++++++++++---------
 2 files changed, 26 insertions(+), 21 deletions(-)
----------------------------------------------------------------------



[43/50] [abbrv] incubator-geode git commit: GEODE-546: Resetting stats when AbstractGatewaySender is stopped

Posted by bs...@apache.org.
GEODE-546: Resetting stats when AbstractGatewaySender is stopped


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

Branch: refs/heads/feature/GEODE-77
Commit: 5a0d43e3f1b96b6360fc7d35e211923598cc37b4
Parents: 8703abc
Author: Dan Smith <up...@apache.org>
Authored: Thu Nov 12 13:50:11 2015 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Fri Nov 13 13:14:12 2015 -0800

----------------------------------------------------------------------
 .../cache/wan/AbstractGatewaySender.java        |  3 ++
 .../SerialAsyncEventQueueImplJUnitTest.java     | 46 ++++++++++++++++++++
 2 files changed, 49 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5a0d43e3/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
index ae1b523..bd19a71 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
@@ -1100,6 +1100,9 @@ public abstract class AbstractGatewaySender implements GatewaySender,
       }
       this.enqueuedAllTempQueueEvents = false;
     }
+    
+    statistics.setQueueSize(0);
+    statistics.setTempQueueSize(0);
   }
   
   public Object getSubstituteValue(EntryEventImpl clonedEvent, EnumListenerEvent operation) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5a0d43e3/gemfire-core/src/test/java/com/gemstone/gemfire/cache/asyncqueue/internal/SerialAsyncEventQueueImplJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/asyncqueue/internal/SerialAsyncEventQueueImplJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/asyncqueue/internal/SerialAsyncEventQueueImplJUnitTest.java
new file mode 100644
index 0000000..594a98f
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/asyncqueue/internal/SerialAsyncEventQueueImplJUnitTest.java
@@ -0,0 +1,46 @@
+package com.gemstone.gemfire.cache.asyncqueue.internal;
+
+import static org.junit.Assert.*;
+
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.internal.cache.wan.GatewaySenderAttributes;
+import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+
+@Category(IntegrationTest.class)
+public class SerialAsyncEventQueueImplJUnitTest {
+
+  private Cache cache;
+  @Before
+  public void setUp() {
+    CacheFactory cf = new CacheFactory().set("mcast-port", "0");
+    cache = cf.create();
+  }
+  
+  @After
+  public void tearDown() {
+    cache.close();
+  }
+  @Test
+  public void testStopClearsStats() {
+    GatewaySenderAttributes attrs = new GatewaySenderAttributes();
+    attrs.id = AsyncEventQueueImpl.ASYNC_EVENT_QUEUE_PREFIX + "id";
+    SerialAsyncEventQueueImpl queue = new SerialAsyncEventQueueImpl(cache, attrs);
+    queue.getStatistics().incQueueSize(5);
+    queue.getStatistics().incTempQueueSize(10);
+    
+    assertEquals(5, queue.getStatistics().getEventQueueSize());
+    assertEquals(10, queue.getStatistics().getTempEventQueueSize());
+   
+    queue.stop();
+    
+    assertEquals(0, queue.getStatistics().getEventQueueSize());
+    assertEquals(0, queue.getStatistics().getTempEventQueueSize());
+  }
+
+}


[16/50] [abbrv] incubator-geode git commit: GEODE-516: increase the trylock timeout to make sure the deadlock would happen.

Posted by bs...@apache.org.
GEODE-516: increase the trylock timeout to make sure the deadlock would happen.


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

Branch: refs/heads/feature/GEODE-77
Commit: 4103c1eb1e130a47da840e0be632b74cca47a8ad
Parents: 8fe2910
Author: Jinmei Liao <ji...@pivotal.io>
Authored: Fri Nov 6 09:34:07 2015 -0800
Committer: Jinmei Liao <ji...@pivotal.io>
Committed: Fri Nov 6 09:35:22 2015 -0800

----------------------------------------------------------------------
 .../internal/deadlock/GemFireDeadlockDetectorDUnitTest.java        | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4103c1eb/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
index a477361..be80150 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
@@ -205,7 +205,7 @@ public class GemFireDeadlockDetectorDUnitTest extends CacheTestCase {
   
   private static class TestFunction implements Function {
     
-    private static final int LOCK_WAIT_TIME = 5;
+    private static final int LOCK_WAIT_TIME = 1000;
 
     public boolean hasResult() {
       return true;


[37/50] [abbrv] incubator-geode git commit: GEODE-427: add more test logging

Posted by bs...@apache.org.
GEODE-427: add more test logging


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

Branch: refs/heads/feature/GEODE-77
Commit: 5118ad08ea5882c46fd2238aa08183db84c6f880
Parents: 355a2d3
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Thu Nov 12 16:18:06 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Nov 12 16:18:06 2015 -0800

----------------------------------------------------------------------
 .../cache/management/MemoryThresholdsDUnitTest.java     | 12 ++++++------
 1 file changed, 6 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/5118ad08/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
index 1d1ada3..4edab28 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
@@ -409,7 +409,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     registerTestMemoryThresholdListener(server2);
 
     //NORMAL -> CRITICAL
-    server2.invoke(new SerializableCallable() {
+    server2.invoke(new SerializableCallable("NORMAL->CRITICAL") {
       public Object call() throws Exception {
         GemFireCacheImpl gfCache = (GemFireCacheImpl)getCache();
         getCache().getLoggerI18n().fine(addExpectedExString);
@@ -428,7 +428,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     verifyListenerValue(server1, MemoryState.NORMAL, 0, true);;
 
     //CRITICAL -> EVICTION
-    server2.invoke(new SerializableCallable() {
+    server2.invoke(new SerializableCallable("CRITICAL->EVICTION") {
       public Object call() throws Exception {
         GemFireCacheImpl gfCache = (GemFireCacheImpl)getCache();
         getCache().getLoggerI18n().fine(addExpectedBelow);
@@ -445,7 +445,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     verifyListenerValue(server1, MemoryState.NORMAL, 0, true);;
     
     //EVICTION -> EVICTION
-    server2.invoke(new SerializableCallable() {
+    server2.invoke(new SerializableCallable("EVICTION->EVICTION") {
       public Object call() throws Exception {
         GemFireCacheImpl gfCache = (GemFireCacheImpl)getCache();
         gfCache.getResourceManager().getHeapMonitor().updateStateAndSendEvent(840);
@@ -460,7 +460,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     verifyListenerValue(server1, MemoryState.NORMAL, 0, true);
 
     //EVICTION -> NORMAL
-    server2.invoke(new SerializableCallable() {
+    server2.invoke(new SerializableCallable("EVICTION->NORMAL") {
       public Object call() throws Exception {
         GemFireCacheImpl gfCache = (GemFireCacheImpl)getCache();
         gfCache.getResourceManager().getHeapMonitor().updateStateAndSendEvent(750);
@@ -477,7 +477,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     
     this.getLogWriter().info("before NORMAL->CRITICAL->NORMAL");
     //NORMAL -> EVICTION -> NORMAL
-    server2.invoke(new SerializableCallable() {
+    server2.invoke(new SerializableCallable("NORMAL->CRITICAL->NORMAL") {
       public Object call() throws Exception {
         GemFireCacheImpl gfCache = (GemFireCacheImpl)getCache();
         gfCache.getResourceManager().getHeapMonitor().updateStateAndSendEvent(950);
@@ -495,7 +495,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     verifyListenerValue(server1, MemoryState.NORMAL, 2, true);
     
     //NORMAL -> EVICTION
-    server2.invoke(new SerializableCallable() {
+    server2.invoke(new SerializableCallable("NORMAL->EVICTION") {
       public Object call() throws Exception {
         GemFireCacheImpl gfCache = (GemFireCacheImpl)getCache();
         gfCache.getResourceManager().getHeapMonitor().updateStateAndSendEvent(850);


[29/50] [abbrv] incubator-geode git commit: Merge branch 'feature/GEODE-537' into develop

Posted by bs...@apache.org.
Merge branch 'feature/GEODE-537' into develop

This closes #32


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

Branch: refs/heads/feature/GEODE-77
Commit: 7cbaadc78de6a4ff72b4f89df675a6efdb184d8f
Parents: e1eb74e 0f72d36
Author: Swapnil Bawaskar <sb...@pivotal.io>
Authored: Tue Nov 10 12:22:36 2015 -0800
Committer: Swapnil Bawaskar <sb...@pivotal.io>
Committed: Tue Nov 10 12:22:36 2015 -0800

----------------------------------------------------------------------
 .../tier/sockets/command/CommitCommand.java     |  4 +-
 .../tier/sockets/command/CommitCommandTest.java | 39 ++++++++++++++++++++
 2 files changed, 42 insertions(+), 1 deletion(-)
----------------------------------------------------------------------



[39/50] [abbrv] incubator-geode git commit: GEODE-544: Removes soplog code and tests

Posted by bs...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplog.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplog.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplog.java
deleted file mode 100644
index 8995f66..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplog.java
+++ /dev/null
@@ -1,244 +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.persistence.soplog.nofile;
-
-import java.io.File;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.Collections;
-import java.util.EnumMap;
-import java.util.NavigableMap;
-import java.util.concurrent.ConcurrentSkipListMap;
-import java.util.concurrent.atomic.AtomicReference;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.AbstractSortedReader;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedBuffer.BufferIterator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.Metadata;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedStatistics;
-
-public class NoFileSortedOplog implements SortedOplog {
-  private final SortedOplogConfiguration config;
-  
-  private final AtomicReference<NavigableMap<byte[], byte[]>> data;
-  private final EnumMap<Metadata, byte[]> metadata;
-  private final NoFileStatistics stats;
-  
-  public NoFileSortedOplog(SortedOplogConfiguration config) {
-    this.config = config;
-    
-    data = new AtomicReference<NavigableMap<byte[],byte[]>>();
-    metadata = new EnumMap<Metadata, byte[]>(Metadata.class);
-    stats = new NoFileStatistics();
-  }
-  
-  @Override
-  public SortedOplogReader createReader() throws IOException {
-    return new NoFileReader();
-  }
-
-  @Override
-  public SortedOplogWriter createWriter() throws IOException {
-    synchronized (metadata) {
-      metadata.clear();
-    }
-    data.set(new ConcurrentSkipListMap<byte[], byte[]>(config.getComparator()));
-    
-    return new NoFileWriter();
-  }
-  
-  private class NoFileWriter implements SortedOplogWriter {
-    @Override
-    public void append(byte[] key, byte[] value) throws IOException {
-      if (data.get().put(key, value) == null) {
-        stats.add(key.length, value.length);
-      }
-    }
-
-    @Override
-    public void append(ByteBuffer key, ByteBuffer value) throws IOException {
-      byte[] k = new byte[key.remaining()];
-      byte[] v = new byte[value.remaining()];
-      
-      key.get(k);
-      value.get(v);
-      
-      append(k, v);
-    }
-
-    @Override
-    public void close(EnumMap<Metadata, byte[]> meta) throws IOException {
-      if (meta != null) {
-        synchronized (metadata) {
-          metadata.putAll(meta);
-        }
-      }
-    }
-
-    @Override
-    public void closeAndDelete() throws IOException {
-      data.get().clear();
-      data.set(null);
-    }
-  }
-  
-  private class NoFileReader extends AbstractSortedReader implements SortedOplogReader {
-    private final BloomFilter bloom;
-    private volatile boolean closed;
-    
-    public NoFileReader() {
-      closed = false;
-      bloom = new BloomFilter() {
-        @Override
-        public boolean mightContain(byte[] key) {
-          return data.get().containsKey(key);
-        }
-      };
-    }
-    
-    @Override
-    public boolean mightContain(byte[] key) throws IOException {
-      return bloom.mightContain(key);
-    }
-
-    @Override
-    public ByteBuffer read(byte[] key) throws IOException {
-      return ByteBuffer.wrap(data.get().get(key));
-    }
-
-    @Override
-    public SortedIterator<ByteBuffer> scan(
-        byte[] from, boolean fromInclusive, 
-        byte[] to, boolean toInclusive,
-        boolean ascending,
-        MetadataFilter filter) {
-
-      if (filter == null || filter.accept(metadata.get(filter.getName()))) {
-        NavigableMap<byte[],byte[]> subset = ascending ? data.get() : data.get().descendingMap();
-        if (from == null && to == null) {
-          // we're good
-        } else if (from == null) {
-          subset = subset.headMap(to, toInclusive);
-        } else if (to == null) {
-          subset = subset.tailMap(from, fromInclusive);
-        } else {
-          subset = subset.subMap(from, fromInclusive, to, toInclusive);
-        }
-        return new BufferIterator(subset.entrySet().iterator());
-      }
-      return new BufferIterator(Collections.<byte[], byte[]>emptyMap().entrySet().iterator());
-    }
-
-    @Override
-    public SerializedComparator getComparator() {
-      return (SerializedComparator) data.get().comparator();
-    }
-
-    @Override
-    public SortedStatistics getStatistics() {
-      return stats;
-    }
-
-    @Override
-    public boolean isClosed() {
-      return closed;
-    }
-    
-    @Override
-    public void close() throws IOException {
-      closed = true;
-    }
-
-    @Override
-    public BloomFilter getBloomFilter() {
-      return bloom;
-    }
-
-    @Override
-    public byte[] getMetadata(Metadata name) {
-      synchronized (metadata) {
-        return metadata.get(name);
-      }
-    }
-
-    @Override
-    public File getFile() {
-      return new File(".");
-    }
-    
-    @Override
-    public String getFileName() {
-      return "name";
-    }
-   
-    @Override
-    public long getModificationTimeStamp() throws IOException {
-      return 0;
-    }
-    
-    @Override
-    public void rename(String name) throws IOException {
-    }
-    
-    @Override
-    public void delete() throws IOException {
-    }
-  }
-  
-  private class NoFileStatistics implements SortedStatistics {
-    private long keys;
-    private double avgKeySize;
-    private double avgValueSize;
-    
-    private synchronized void add(int keyLength, int valueLength) {
-      avgKeySize = (keyLength + keys * avgKeySize) / (keys + 1);
-      avgValueSize = (keyLength + keys * avgValueSize) / (keys + 1);
-      
-      keys++;
-    }
-    
-    @Override
-    public synchronized long keyCount() {
-      return keys;
-    }
-
-    @Override
-    public byte[] firstKey() {
-      return data.get().firstKey();
-    }
-
-    @Override
-    public byte[] lastKey() {
-      return data.get().lastKey();
-    }
-
-    @Override
-    public synchronized double avgKeySize() {
-      return avgKeySize;
-    }
-    
-    @Override
-    public synchronized double avgValueSize() {
-      return avgValueSize;
-    }
-    
-    @Override
-    public void close() {
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogFactory.java
deleted file mode 100644
index 365d796..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogFactory.java
+++ /dev/null
@@ -1,41 +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.persistence.soplog.nofile;
-
-import java.io.File;
-import java.io.IOException;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory;
-
-public class NoFileSortedOplogFactory implements SortedOplogFactory {
-  private final SortedOplogConfiguration config;
-  
-  public NoFileSortedOplogFactory(String name) {
-    config = new SortedOplogConfiguration(name);
-  }
-  
-  @Override
-  public SortedOplog createSortedOplog(File name) throws IOException {
-    return new NoFileSortedOplog(config);
-  }
-
-  @Override
-  public SortedOplogConfiguration getConfiguration() {
-    return config;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AppendLog.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AppendLog.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AppendLog.java
deleted file mode 100644
index e0e696a..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/AppendLog.java
+++ /dev/null
@@ -1,65 +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.persistence.soplog;
-
-import java.io.BufferedOutputStream;
-import java.io.Closeable;
-import java.io.DataOutputStream;
-import java.io.File;
-import java.io.FileOutputStream;
-import java.io.IOException;
-
-public class AppendLog {
-
-  public static AppendLogReader recover(File f) throws IOException {
-    throw new RuntimeException("Not implemented");
-  }
-  
-  public static AppendLogWriter create(File f) throws IOException {
-    DataOutputStream dos = new DataOutputStream(new BufferedOutputStream(new FileOutputStream(f)));
-    return new AppendLogWriter(f, dos);
-  }
-  
-  public static class AppendLogReader {
-  }
-  
-  public static class AppendLogWriter implements Closeable {
-    private final File file;
-    private final DataOutputStream out;
-    
-    private AppendLogWriter(File f, DataOutputStream out) {
-      this.file = f;
-      this.out = out;
-    }
-    
-    public synchronized void append(byte[] key, byte[] value) throws IOException {
-      out.writeInt(key.length);
-      out.writeInt(value.length);
-      out.write(key);
-      out.write(value);
-    }
-
-    @Override
-    public void close() throws IOException {
-      out.close();
-    }
-    
-    public File getFile() {
-      return file;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparatorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparatorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparatorJUnitTest.java
deleted file mode 100644
index 3689255..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ArraySerializedComparatorJUnitTest.java
+++ /dev/null
@@ -1,95 +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.persistence.soplog;
-
-import java.io.IOException;
-import java.nio.ByteBuffer;
-
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class ArraySerializedComparatorJUnitTest extends ComparisonTestCase {
-  protected ArraySerializedComparator comp;
-  
-  public void testSearch() throws IOException {
-    byte[] k1 = comp.createCompositeKey(convert("aaaa"), convert(1), convert(true));
-    byte[] k2 = comp.createCompositeKey(convert("bbbb"), convert(2), convert(false));
-    byte[] k3 = comp.createCompositeKey(convert("bbbb"), convert(3), convert(true));
-    byte[] k4 = comp.createCompositeKey(convert("cccc"), convert(1), convert(false));
-
-    byte[] s1 = comp.createCompositeKey(convert("aaaa"), 
-        new byte[] {SoplogToken.WILDCARD.toByte()}, new byte[] {SoplogToken.WILDCARD.toByte()});
-    
-    
-    byte[] s2 = comp.createCompositeKey(convert("bbbb"), 
-        new byte[] {SoplogToken.WILDCARD.toByte()}, new byte[] {SoplogToken.WILDCARD.toByte()});
-    
-    byte[] s3 = comp.createCompositeKey(new byte[] {SoplogToken.WILDCARD.toByte()}, convert(1), 
-        new byte[] {SoplogToken.WILDCARD.toByte()});
-    
-    compareAsIs(comp, k1, s1, Comparison.EQ);
-    compareAsIs(comp, k2, s1, Comparison.GT);
-    compareAsIs(comp, k1, s2, Comparison.LT);
-    compareAsIs(comp, k2, s2, Comparison.EQ);
-    compareAsIs(comp, k3, s2, Comparison.EQ);
-    compareAsIs(comp, k4, s2, Comparison.GT);
-    compareAsIs(comp, s3, k4, Comparison.EQ);
-  }
-  
-  public void testCompositeKey() throws IOException {
-    byte[] k1 = comp.createCompositeKey(convert("aaaa"), convert(1), convert(true));
-    byte[] k2 = comp.createCompositeKey(convert("bbbb"), convert(2), convert(false));
-    byte[] k3 = comp.createCompositeKey(convert("bbbb"), convert(3), convert(true));
-    byte[] k4 = comp.createCompositeKey(convert("cccc"), convert(1), convert(false));
-    byte[] k5 = comp.createCompositeKey(convert(null),   convert(1), convert(false));
-    byte[] k6 = comp.createCompositeKey(convert(null),   convert(1), convert(true));
-    
-    compareAsIs(comp, k1, k1, Comparison.EQ);
-    compareAsIs(comp, k1, k2, Comparison.LT);
-    compareAsIs(comp, k2, k1, Comparison.GT);
-    compareAsIs(comp, k2, k3, Comparison.LT);
-    compareAsIs(comp, k3, k4, Comparison.LT);
-    
-    compareAsIs(comp, k4, k5, Comparison.LT);
-    compareAsIs(comp, k5, k1, Comparison.GT);
-    compareAsIs(comp, k5, k6, Comparison.LT);
-  }
-  
-  public void testGetKey() throws Exception {
-    Object[] vals = new Object[] { "aaaa", 1, true };
-    
-    byte[][] composite = new byte[][] { convert(vals[0]), convert(vals[1]), convert(vals[2]) };
-    ByteBuffer key = ByteBuffer.wrap(comp.createCompositeKey(composite));
-    
-    for (int i = 0; i < 3; i++) {
-      ByteBuffer subkey = comp.getKey(key, i);
-      assertEquals(vals[i], recover(subkey.array(), subkey.arrayOffset(), subkey.remaining()));
-    }
-  }
-
-  public void setUp() {
-    comp = new ArraySerializedComparator();
-    comp.setComparators(new SerializedComparator[] {
-        new LexicographicalComparator(), // string
-        new LexicographicalComparator(), // int
-        new LexicographicalComparator()  // boolean
-    });
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionSortedOplogSetTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionSortedOplogSetTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionSortedOplogSetTestCase.java
deleted file mode 100644
index bca52a9..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionSortedOplogSetTestCase.java
+++ /dev/null
@@ -1,134 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.concurrent.Executors;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.CompactionTestCase.FileTracker;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.CompactionTestCase.WaitingHandler;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedIterator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.nofile.NoFileSortedOplogFactory;
-
-public abstract class CompactionSortedOplogSetTestCase extends SortedOplogSetJUnitTest {
-  public void testWithCompaction() throws IOException, InterruptedException {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogSet sos = createSoplogSet("compact");
-    
-    for (int i = 0; i < 1000; i++) {
-      sos.put(wrapInt(i), wrapInt(i));
-      if (i % 100 == 0) {
-        sos.flush(null, handler);
-      }
-    }
-    
-    flushAndWait(handler, sos);
-    
-    compactAndWait(sos, false);
-    validate(sos, 1000);
-    sos.close();
-  }
-  
-  public void testTombstone() throws Exception {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogFactory factory = new NoFileSortedOplogFactory("tombstone");
-    Compactor compactor = new SizeTieredCompactor(factory, 
-        NonCompactor.createFileset("tombstone", new File(".")), 
-        new FileTracker(), 
-        Executors.newSingleThreadExecutor(), 
-        2, 2);
-    
-    SortedOplogSet sos = new SortedOplogSetImpl(factory, Executors.newSingleThreadExecutor(), compactor);
-    
-    for (int i = 0; i < 1000; i++) {
-      sos.put(wrapInt(i), wrapInt(i));
-    }
-    sos.flush(null, handler);
-    
-    for (int i = 900; i < 1000; i++) {
-      sos.put(wrapInt(i), new byte[] {SoplogToken.TOMBSTONE.toByte()});
-    }
-    flushAndWait(handler, sos);
-    compactAndWait(sos, true);
-
-    validate(sos, 900);
-    sos.close();
-    
-  }
-  
-  public void testInUse() throws Exception {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogSet sos = createSoplogSet("inuse");
-    
-    for (int i = 0; i < 1000; i++) {
-      sos.put(wrapInt(i), wrapInt(i));
-    }
-    
-    flushAndWait(handler, sos);
-    
-    // start iterating over soplog
-    SortedIterator<ByteBuffer> range = sos.scan();
-    assertEquals(0, ((SizeTieredCompactor) sos.getCompactor()).countInactiveReaders());
-
-    for (int i = 1000; i < 5000; i++) {
-      sos.put(wrapInt(i), wrapInt(i));
-      if (i % 100 == 0) {
-        sos.flush(null, handler);
-      }
-    }
-
-    flushAndWait(handler, sos);
-    compactAndWait(sos, false);
-    assertEquals(1, ((SizeTieredCompactor) sos.getCompactor()).countInactiveReaders());
-
-    range.close();
-    compactAndWait(sos, false);
-    assertEquals(0, ((SizeTieredCompactor) sos.getCompactor()).countInactiveReaders());
-
-    validate(sos, 5000);
-    sos.close();
-  }
-
-  @Override
-  protected SortedOplogSetImpl createSoplogSet(String name) throws IOException {
-    SortedOplogFactory factory = new NoFileSortedOplogFactory(name);
-    Compactor compactor = createCompactor(factory);
-    
-    return new SortedOplogSetImpl(factory,  Executors.newSingleThreadExecutor(), compactor);
-  }
-  
-  protected abstract AbstractCompactor<?> createCompactor(SortedOplogFactory factory) throws IOException;
-  
-  private void validate(SortedReader<ByteBuffer> range, int count) throws IOException {
-    int i = 0;
-    for (SortedIterator<ByteBuffer> iter = range.scan(); iter.hasNext(); i++) {
-      iter.next();
-      assertEquals(i, iter.key().getInt());
-    }
-    assertEquals(count, i);
-    range.close();
-  }
-
-  private void compactAndWait(SortedOplogSet sos, boolean force) throws InterruptedException {
-    WaitingHandler wh = new WaitingHandler();
-    sos.getCompactor().compact(force, wh);
-    wh.waitForCompletion();
-    assertNull(wh.getError());
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionTestCase.java
deleted file mode 100644
index 7577b53..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/CompactionTestCase.java
+++ /dev/null
@@ -1,206 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.atomic.AtomicReference;
-
-import org.apache.logging.log4j.Logger;
-
-import junit.framework.TestCase;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.Compactor.CompactionHandler;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.Compactor.CompactionTracker;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogWriter;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.nofile.NoFileSortedOplogFactory;
-import com.gemstone.gemfire.internal.logging.LogService;
-
-public abstract class CompactionTestCase<T extends Comparable<T>> extends TestCase {
-  private static final Logger logger = LogService.getLogger();
-  protected SortedOplogFactory factory;
-  protected AbstractCompactor<T> compactor;
-  
-  public void testMaxCompaction() throws Exception {
-    for (int i = 0; i < 100; i += 2) {
-      compactor.add(createSoplog(0, 100, i));
-      compactor.add(createSoplog(100, 100, i+1));
-
-      WaitingHandler wh = new WaitingHandler();
-      compactor.compact(false, wh);
-      wh.waitForCompletion();
-    }
-    
-    WaitingHandler wh = new WaitingHandler();
-    compactor.compact(true, wh);
-    wh.waitForCompletion();
-  }
-  
-  public void testClear() throws IOException {
-    compactor.add(createSoplog(0, 100, 0));
-    compactor.add(createSoplog(100, 100, 1));
-    compactor.clear();
-    
-    assertEquals(0, compactor.getActiveReaders(null, null).size());
-    assertFalse(compactor.getLevel(0).needsCompaction());
-  }
-  
-  public void testInterruptedCompaction() throws IOException {
-    compactor.add(createSoplog(0, 100, 0));
-    compactor.add(createSoplog(100, 100, 1));
-    
-    compactor.testAbortDuringCompaction = true;
-    boolean compacted = compactor.compact();
-    
-    assertFalse(compacted);
-    assertEquals(2, compactor.getActiveReaders(null, null).size());
-    assertTrue(compactor.getLevel(0).needsCompaction());
-  }
-  
-  public void testClearDuringCompaction() throws Exception {
-    compactor.add(createSoplog(0, 100, 0));
-    compactor.add(createSoplog(100, 100, 1));
-    
-    compactor.testDelayDuringCompaction = new CountDownLatch(1);
-    WaitingHandler wh = new WaitingHandler();
-    
-    logger.debug("Invoking compact");
-    compactor.compact(false, wh);
-    
-    logger.debug("Invoking clear");
-    compactor.clear();
-    
-    boolean compacted = wh.waitForCompletion();
-    
-    assertFalse(compacted);
-    assertEquals(0, compactor.getActiveReaders(null, null).size());
-  }
-  
-  public void testClearRepeat() throws Exception {
-    int i = 0;
-    do {
-      testClearDuringCompaction();
-      logger.debug("Test {} is complete", i);
-      tearDown();
-      setUp();
-    } while (i++ < 100);
-  }
-
-  public void testCloseRepeat() throws Exception {
-    int i = 0;
-    do {
-      testCloseDuringCompaction();
-      logger.debug("Test {} is complete", i);
-      tearDown();
-      setUp();
-    } while (i++ < 100);
-  }
-
-  public void testCloseDuringCompaction() throws Exception {
-    compactor.add(createSoplog(0, 100, 0));
-    compactor.add(createSoplog(100, 100, 1));
-    
-    compactor.testDelayDuringCompaction = new CountDownLatch(1);
-    WaitingHandler wh = new WaitingHandler();
-    
-    compactor.compact(false, wh);
-    compactor.close();
-    
-    boolean compacted = wh.waitForCompletion();
-    
-    assertFalse(compacted);
-    assertEquals(0, compactor.getActiveReaders(null, null).size());
-  }
-
-  public void setUp() throws IOException {
-    factory = new NoFileSortedOplogFactory("test");
-    compactor = createCompactor(factory);
-  }
-  
-  public void tearDown() throws Exception {
-    compactor.close();
-    for (File f : SortedReaderTestCase.getSoplogsToDelete()) {
-      f.delete();
-    }
-  }
-  
-  protected SortedOplog createSoplog(int start, int count, int id) throws IOException {
-    SortedOplog soplog = factory.createSortedOplog(new File("test-" + id + ".soplog"));
-    SortedOplogWriter wtr = soplog.createWriter();
-    try {
-      for (int i = start; i < start + count; i++) {
-        wtr.append(SortedReaderTestCase.wrapInt(i), SortedReaderTestCase.wrapInt(i));
-      }
-    } finally {
-      wtr.close(null);
-    }
-    return soplog;
-  }
-
-  protected abstract AbstractCompactor<T> createCompactor(SortedOplogFactory factory) throws IOException;
-  
-  static class WaitingHandler implements CompactionHandler {
-    private final CountDownLatch latch;
-    private final AtomicReference<Throwable> err;
-    private volatile boolean compacted;
-    
-    public WaitingHandler() {
-      latch = new CountDownLatch(1);
-      err = new AtomicReference<Throwable>();
-    }
-    
-    public boolean waitForCompletion() throws InterruptedException {
-      logger.debug("Waiting for compaction to complete");
-      latch.await();
-      logger.debug("Done waiting!");
-      
-      return compacted;
-    }
-    
-    public Throwable getError() {
-      return err.get();
-    }
-    
-    @Override
-    public void complete(boolean compacted) {
-      logger.debug("Compaction completed with {}", compacted);
-      this.compacted = compacted;
-      latch.countDown();
-    }
-
-    @Override
-    public void failed(Throwable ex) {
-      err.set(ex);
-      latch.countDown();
-    }
-  }
-  
-  static class FileTracker implements CompactionTracker<Integer> {
-    @Override
-    public void fileDeleted(File f) {
-    }
-
-    @Override
-    public void fileAdded(File f, Integer attach) {
-    }
-
-    @Override
-    public void fileRemoved(File f, Integer attach) {
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ComparisonTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ComparisonTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ComparisonTestCase.java
deleted file mode 100644
index cb9e909..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/ComparisonTestCase.java
+++ /dev/null
@@ -1,77 +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.persistence.soplog;
-
-import java.io.ByteArrayInputStream;
-import java.io.ByteArrayOutputStream;
-import java.io.DataInputStream;
-import java.io.DataOutputStream;
-import java.io.IOException;
-
-import junit.framework.TestCase;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-
-public abstract class ComparisonTestCase extends TestCase {
-  public enum Comparison {
-    EQ(0.0),
-    LT(-1.0),
-    GT(1.0);
-    
-    private final double sgn;
-    
-    private Comparison(double sgn) {
-      this.sgn = sgn;
-    }
-    
-    public double signum() {
-      return sgn;
-    }
-    
-    public Comparison opposite() {
-      switch (this) {
-      case LT: return GT;
-      case GT : return LT;
-      default : return EQ;
-      }
-    }
-  }
-  
-  public void compare(SerializedComparator sc, Object o1, Object o2, Comparison result) throws IOException {
-    double diff = sc.compare(convert(o1), convert(o2));
-    assertEquals(String.format("%s ? %s", o1, o2), result.signum(), Math.signum(diff));
-  }
-  
-  public void compareAsIs(SerializedComparator sc, byte[] b1, byte[] b2, Comparison result) throws IOException {
-    double diff = sc.compare(b1, b2);
-    assertEquals(result.signum(), Math.signum(diff));
-  }
-  
-  public static byte[] convert(Object o) throws IOException {
-    ByteArrayOutputStream b = new ByteArrayOutputStream();
-    DataOutputStream d = new DataOutputStream(b);
-    DataSerializer.writeObject(o, d);
-    
-    return b.toByteArray();
-  }
-  
-  public static Object recover(byte[] obj, int off, int len) throws ClassNotFoundException, IOException {
-    DataInputStream in = new DataInputStream(new ByteArrayInputStream(obj, off, len));
-    return DataSerializer.readObject(in);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexComparatorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexComparatorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexComparatorJUnitTest.java
deleted file mode 100644
index 27202ec..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/IndexComparatorJUnitTest.java
+++ /dev/null
@@ -1,79 +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.persistence.soplog;
-
-import java.io.IOException;
-import java.nio.ByteBuffer;
-
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class IndexComparatorJUnitTest extends ComparisonTestCase {
-  protected IndexSerializedComparator comp;
-  
-  public void testSearch() throws IOException {
-    byte[] k1 = comp.createCompositeKey(convert("aaaa"), convert(1));
-    byte[] k2 = comp.createCompositeKey(convert("bbbb"), convert(2));
-    byte[] k3 = comp.createCompositeKey(convert("bbbb"), convert(3));
-    byte[] k4 = comp.createCompositeKey(convert(null), convert(1));
-
-    byte[] s1 = comp.createCompositeKey(convert("aaaa"), new byte[] {SoplogToken.WILDCARD.toByte()});
-    byte[] s2 = comp.createCompositeKey(convert("bbbb"), new byte[] {SoplogToken.WILDCARD.toByte()});
-    byte[] s3 = comp.createCompositeKey(new byte[] {SoplogToken.WILDCARD.toByte()}, convert(1));
-    
-    compareAsIs(comp, k1, s1, Comparison.EQ);
-    compareAsIs(comp, k2, s1, Comparison.GT);
-    compareAsIs(comp, k1, s2, Comparison.LT);
-    compareAsIs(comp, k2, s2, Comparison.EQ);
-    compareAsIs(comp, k3, s2, Comparison.EQ);
-    compareAsIs(comp, k4, s2, Comparison.GT);
-    compareAsIs(comp, s3, k4, Comparison.EQ);
-  }
-  
-  public void testCompositeKey() throws IOException {
-    byte[] k1 = comp.createCompositeKey(convert("aaaa"), convert(1));
-    byte[] k2 = comp.createCompositeKey(convert("bbbb"), convert(2));
-    byte[] k3 = comp.createCompositeKey(convert("bbbb"), convert(3));
-    byte[] k4 = comp.createCompositeKey(convert("cccc"), convert(1));
-    byte[] k5 = comp.createCompositeKey(convert(null), convert(1));
-    
-    compareAsIs(comp, k1, k1, Comparison.EQ);
-    compareAsIs(comp, k1, k2, Comparison.LT);
-    compareAsIs(comp, k2, k1, Comparison.GT);
-    compareAsIs(comp, k2, k3, Comparison.LT);
-    compareAsIs(comp, k3, k4, Comparison.LT);
-    
-    compareAsIs(comp, k4, k5, Comparison.LT);
-    compareAsIs(comp, k5, k1, Comparison.GT);
-  }
-  
-  public void testGetKey() throws Exception {
-    ByteBuffer key = ByteBuffer.wrap(comp.createCompositeKey(convert("aaaa"), convert(1)));
-    
-    ByteBuffer k1 = comp.getKey(key, 0);
-    assertEquals("aaaa", recover(k1.array(), k1.arrayOffset(), k1.remaining()));
-    
-    ByteBuffer k2 = comp.getKey(key, 1);
-    assertEquals(1, recover(k2.array(), k2.arrayOffset(), k2.remaining()));
-  }
-  
-  public void setUp() {
-    comp = new IndexSerializedComparator();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparatorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparatorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparatorJUnitTest.java
deleted file mode 100644
index 0c0e93e..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/LexicographicalComparatorJUnitTest.java
+++ /dev/null
@@ -1,204 +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.persistence.soplog;
-
-import java.math.BigInteger;
-import java.nio.ByteBuffer;
-
-import org.apache.hadoop.hbase.util.Bytes;
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class LexicographicalComparatorJUnitTest extends ComparisonTestCase {
-  private LexicographicalComparator lc;
-
-  public void testMixedNumeric() throws Exception {
-    compare(lc, (byte) 1,  (short) 2,    Comparison.LT);
-    compare(lc, (byte) 1,  (int)   2,    Comparison.LT);
-    compare(lc, (byte) 1,  (long)  2,    Comparison.LT);
-    compare(lc, (byte) 1,          2.1f, Comparison.LT);
-    compare(lc, (byte) 1,          2.1d, Comparison.LT);
-    
-    compare(lc, (short) 1, (byte) 2,    Comparison.LT);
-    compare(lc, (short) 1, (int)  2,    Comparison.LT);
-    compare(lc, (short) 1, (long) 2,    Comparison.LT);
-    compare(lc, (short) 1,        2.1f, Comparison.LT);
-    compare(lc, (short) 1,        2.1d, Comparison.LT);
-    
-    compare(lc, (int) 1,  (byte)  2,    Comparison.LT);
-    compare(lc, (int) 1,  (short) 2,    Comparison.LT);
-    compare(lc, (int) 1,  (long)  2,    Comparison.LT);
-    compare(lc, (int) 1,          2.1f, Comparison.LT);
-    compare(lc, (int) 1,          2.1d, Comparison.LT);
-
-    compare(lc, (long) 1,  (byte)  2,    Comparison.LT);
-    compare(lc, (long) 1,  (short) 2,    Comparison.LT);
-    compare(lc, (long) 1,  (int)   2,    Comparison.LT);
-    compare(lc, (long) 1,          2.1f, Comparison.LT);
-    compare(lc, (long) 1,          2.1d, Comparison.LT);
-
-    compare(lc, 1.1f,  (byte)  2,    Comparison.LT);
-    compare(lc, 1.1f,  (short) 2,    Comparison.LT);
-    compare(lc, 1.1f,  (int)   2,    Comparison.LT);
-    compare(lc, 1.1f,  (long)  2,    Comparison.LT);
-    compare(lc, 1.1f,          2.1d, Comparison.LT);
-
-    compare(lc, 1.1d,  (byte)  2,    Comparison.LT);
-    compare(lc, 1.1d,  (short) 2,    Comparison.LT);
-    compare(lc, 1.1d,  (int)   2,    Comparison.LT);
-    compare(lc, 1.1d,  (long)  2,    Comparison.LT);
-    compare(lc, 1.1d,          2.1f, Comparison.LT);
-  }
-  
-  public void testBoolean() throws Exception {
-    compare(lc, Boolean.TRUE,  Boolean.TRUE,  Comparison.EQ);
-    compare(lc, Boolean.FALSE, Boolean.FALSE, Comparison.EQ);
-    compare(lc, Boolean.TRUE,  Boolean.FALSE, Comparison.GT);
-    compare(lc, Boolean.FALSE, Boolean.TRUE,  Comparison.LT);
-  }
-  
-  public void testByte() throws Exception {
-    compare(lc, (byte)  0, (byte)  0, Comparison.EQ);
-    compare(lc, (byte)  0, (byte)  1, Comparison.LT);
-    compare(lc, (byte) -1, (byte)  1, Comparison.LT);
-    compare(lc, (byte)  1, (byte) -1, Comparison.GT);
-    compare(lc, (byte) -2, (byte) -1, Comparison.LT);
-    compare(lc, (byte)  1, (byte)  2, Comparison.LT);
-    compare(lc, (byte)  2, (byte)  1, Comparison.GT);
-  }
-  
-  public void testShort() throws Exception {
-    compare(lc, (short)  0, (short)  0, Comparison.EQ);
-    compare(lc, (short)  0, (short)  1, Comparison.LT);
-    compare(lc, (short) -1, (short)  1, Comparison.LT);
-    compare(lc, (short)  1, (short) -1, Comparison.GT);
-    compare(lc, (short) -2, (short) -1, Comparison.LT);
-    compare(lc, (short)  1, (short)  2, Comparison.LT);
-    compare(lc, (short)  2, (short)  1, Comparison.GT);
-  }
-
-  public void testInt() throws Exception {
-    compare(lc, (int)  0, (int)  0, Comparison.EQ);
-    compare(lc, (int)  0, (int)  1, Comparison.LT);
-    compare(lc, (int) -1, (int)  1, Comparison.LT);
-    compare(lc, (int)  1, (int) -1, Comparison.GT);
-    compare(lc, (int) -2, (int) -1, Comparison.LT);
-    compare(lc, (int)  1, (int)  2, Comparison.LT);
-    compare(lc, (int)  2, (int)  1, Comparison.GT);
-  }
-
-  public void testLong() throws Exception {
-    compare(lc, (long)  0, (long)  0, Comparison.EQ);
-    compare(lc, (long)  0, (long)  1, Comparison.LT);
-    compare(lc, (long) -1, (long)  1, Comparison.LT);
-    compare(lc, (long)  1, (long) -1, Comparison.GT);
-    compare(lc, (long) -2, (long) -1, Comparison.LT);
-    compare(lc, (long)  1, (long)  2, Comparison.LT);
-    compare(lc, (long)  2, (long)  1, Comparison.GT);
-  }
-
-  public void testFloat() throws Exception {
-    compare(lc,  0.0f,  0.0f, Comparison.EQ);
-    compare(lc,  0.0f,  1.0f, Comparison.LT);
-    compare(lc, -1.0f,  1.0f, Comparison.LT);
-    compare(lc,  1.0f, -1.0f, Comparison.GT);
-    compare(lc, -2.0f, -1.0f, Comparison.LT);
-    compare(lc,  1.0f,  2.0f, Comparison.LT);
-    compare(lc,  2.0f,  1.0f, Comparison.GT);
-    compare(lc,  2.1f,  0.9f, Comparison.GT);
-  }
-
-  public void testDouble() throws Exception {
-    compare(lc,  0.0d,  0.0d, Comparison.EQ);
-    compare(lc,  0.0d,  1.0d, Comparison.LT);
-    compare(lc, -1.0d,  1.0d, Comparison.LT);
-    compare(lc,  1.0d, -1.0d, Comparison.GT);
-    compare(lc, -2.0d, -1.0d, Comparison.LT);
-    compare(lc,  1.0d,  2.0d, Comparison.LT);
-    compare(lc,  2.0d,  1.0d, Comparison.GT);
-    compare(lc,  2.1d,  0.9d, Comparison.GT);
-  }
-
-  public void testString() throws Exception {
-    compare(lc, "",        "",         Comparison.EQ);
-    compare(lc, "aa",      "a",        Comparison.GT);
-    compare(lc, "a",       "b",        Comparison.LT);
-    compare(lc, "b",       "a",        Comparison.GT);
-    compare(lc, "baah",    "aardvark", Comparison.GT);
-    compare(lc, "Chloé",   "Réal",     Comparison.LT);
-    compare(lc, "chowder", "Réal",     Comparison.GT);
-    compare(lc, "Réal",    "chowder",  Comparison.LT);
-    compare(lc, "Réal",    "Réa",      Comparison.GT);
-    compare(lc, "Réal",    "Réa",      Comparison.GT);
-    compare(lc, "\u0061\u00a2\u0f00", "\u0061\u00a2\u0f00\u0061", Comparison.LT);
-  }
-  
-  public void testChar() throws Exception {
-    compare(lc, 'a', 'a', Comparison.EQ);
-    compare(lc, 'a', 'b', Comparison.LT);
-    compare(lc, 'b', 'a', Comparison.GT);
-  }
-  
-  public void testNull() throws Exception {
-    compare(lc, null,     null,     Comparison.EQ);
-    compare(lc, null,     "hi mom", Comparison.GT);
-    compare(lc, "hi mom", null,     Comparison.LT);
-  }
-
-  public void testObject() throws Exception {
-    compare(lc, new BigInteger("1"),  new BigInteger("1"), Comparison.EQ);
-    compare(lc, new BigInteger("1"),  new BigInteger("0"), Comparison.GT);
-    compare(lc, new BigInteger("-1"), new BigInteger("0"), Comparison.LT);
-  }
-
-  public void testIntPerformance() throws Exception {
-    ByteBuffer b1 = ByteBuffer.allocate(5).put(0, DSCODE.INTEGER);
-    ByteBuffer b2 = ByteBuffer.allocate(5).put(0, DSCODE.INTEGER);
-    
-    for (int n = 0; n < 5; n++) {
-    long diff = 0;
-      int count = 10000000;
-      long start = System.nanoTime();
-      for (int i = 0; i < count; i++) {
-        b1.putInt(1, i);
-        b2.putInt(1, i + 1);
-        diff += lc.compare(b1.array(), b1.arrayOffset(), b1.capacity(), b2.array(), b2.arrayOffset(), b2.capacity());
-      }
-      long nanos = System.nanoTime() - start;
-      
-      System.out.printf("(%d) %f int comparisons / ms\n", diff, 1000000.0 * count / nanos);
-  
-      diff = 0;
-      start = System.nanoTime();
-      for (int i = 0; i < count; i++) {
-        b1.putInt(1, i);
-        b2.putInt(1, i + 1);
-        diff += Bytes.compareTo(b1.array(), b1.arrayOffset(), b1.capacity(), b2.array(), b2.arrayOffset(), b2.capacity());
-      }
-      nanos = System.nanoTime() - start;
-      
-      System.out.printf("(%d) %f byte comparisons / ms\n\n", diff, 1000000.0 * count / nanos);
-    }
-  }
-
-  protected void setUp() {
-    lc = new LexicographicalComparator();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/RecoverableSortedOplogSet.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/RecoverableSortedOplogSet.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/RecoverableSortedOplogSet.java
deleted file mode 100644
index 0b3e1f5..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/RecoverableSortedOplogSet.java
+++ /dev/null
@@ -1,221 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.lang.management.ManagementFactory;
-import java.nio.ByteBuffer;
-import java.util.EnumMap;
-import java.util.UUID;
-import java.util.concurrent.atomic.AtomicReference;
-import java.util.concurrent.locks.Lock;
-import java.util.concurrent.locks.ReentrantLock;
-
-import org.apache.logging.log4j.Logger;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.AppendLog.AppendLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-
-public class RecoverableSortedOplogSet extends AbstractSortedReader implements SortedOplogSet {
-  private static final Logger logger = LogService.getLogger();
-  
-  private final SortedOplogSet sos;
-  private final long bufferSize;
-  
-  private final long maxBufferMemory;
-  
-  private final Lock rollLock;
-  private AtomicReference<AppendLogWriter> writer;
-  
-  private final String logPrefix;
-  
-  public RecoverableSortedOplogSet(SortedOplogSet sos, long bufferSize, double memLimit) throws IOException {
-    this.sos = sos;
-    this.bufferSize = bufferSize;
-    
-    this.logPrefix = "<" + sos.getFactory().getConfiguration().getName() + "> ";
-    
-    rollLock = new ReentrantLock();
-    writer = new AtomicReference<AppendLogWriter>(AppendLog.create(nextLogFile()));
-    
-    maxBufferMemory = Math.round(memLimit * ManagementFactory.getMemoryMXBean().getHeapMemoryUsage().getMax());
-  }
-  
-  @Override
-  public boolean mightContain(byte[] key) throws IOException {
-    return sos.mightContain(key);
-  }
-
-  @Override
-  public ByteBuffer read(byte[] key) throws IOException {
-    return sos.read(key);
-  }
-
-  @Override
-  public SortedIterator<ByteBuffer> scan(byte[] from, boolean fromInclusive, byte[] to, boolean toInclusive) throws IOException {
-    return sos.scan(from, fromInclusive, to, toInclusive);
-  }
-
-  @Override
-  public SortedIterator<ByteBuffer> scan(
-      byte[] from,
-      boolean fromInclusive,
-      byte[] to,
-      boolean toInclusive,
-      boolean ascending,
-      MetadataFilter filter) throws IOException {
-    return sos.scan(from, fromInclusive, to, toInclusive, ascending, filter);
-  }
-
-  @Override
-  public SerializedComparator getComparator() {
-    return sos.getComparator();
-  }
-
-  @Override
-  public SortedOplogFactory getFactory() {
-    return sos.getFactory();
-  }
-  
-  @Override
-  public SortedStatistics getStatistics() throws IOException {
-    return sos.getStatistics();
-  }
-
-  @Override
-  public void close() throws IOException {
-    rollLock.lock();
-    try {
-      writer.get().close();
-      writer.set(null);
-      sos.close();
-    } finally {
-      rollLock.unlock();
-    }
-  }
-
-  @Override
-  public void put(byte[] key, byte[] value) throws IOException {
-    throttle();
-    if (sos.bufferSize() > bufferSize) {
-      roll(false);
-    }
-
-    writer.get().append(key, value);
-    sos.put(key, value);
-  }
-
-  @Override
-  public long bufferSize() {
-    return sos.bufferSize();
-  }
-
-  @Override
-  public long unflushedSize() {
-    return sos.unflushedSize();
-  }
-
-  @Override
-  public void flush(EnumMap<Metadata, byte[]> metadata, FlushHandler handler) throws IOException {
-    roll(true);
-  }
-
-  @Override
-  public void flushAndClose(EnumMap<Metadata, byte[]> metadata) throws IOException {
-    throw new RuntimeException("Not implemented");
-  }
-
-  @Override
-  public Compactor getCompactor() {
-    return sos.getCompactor();
-  }
-
-  @Override
-  public void clear() throws IOException {
-    rollLock.lock();
-    try {
-      roll(true);
-      sos.clear();
-    } finally {
-      rollLock.unlock();
-    }
-  }
-
-  @Override
-  public void destroy() throws IOException {
-    roll(true);
-    sos.destroy();
-  }
-
-  @Override
-  public boolean isClosed() {
-    return sos.isClosed();
-  }
-  
-  private void throttle() {
-    int n = 0;
-    while (sos.bufferSize() + sos.unflushedSize() > maxBufferMemory) {
-      try {
-        Thread.sleep(1 << n++);
-        
-      } catch (InterruptedException e) {
-        Thread.currentThread().interrupt();
-        break;
-      }
-    }
-  }
-
-  private void roll(boolean wait) throws IOException {
-    boolean locked = true;
-    if (wait) {
-      rollLock.lock();
-    } else {
-      locked = rollLock.tryLock();
-    }
-    
-    if (locked) {
-      try {
-        AppendLogWriter next = AppendLog.create(nextLogFile());
-        final AppendLogWriter old = writer.getAndSet(next);
-        old.close();
-
-        if (logger.isDebugEnabled()) {
-          logger.debug("{}Rolling from {} to {}", this.logPrefix, old.getFile(), next.getFile());
-        }
-
-        sos.flush(null, new FlushHandler() {
-          @Override
-          public void complete() {
-            old.getFile().delete();
-          }
-
-          @Override
-          public void error(Throwable t) {
-          }
-        });
-      } finally {
-        rollLock.unlock();
-      }
-    }
-  }
-
-  private File nextLogFile() {
-    return new File(sos.getFactory().getConfiguration().getName() 
-        + "-" + UUID.randomUUID().toString() + ".aolog");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactorJUnitTest.java
deleted file mode 100644
index ee76c55..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredCompactorJUnitTest.java
+++ /dev/null
@@ -1,110 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.concurrent.Executors;
-
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogReader;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedIterator;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class SizeTieredCompactorJUnitTest extends CompactionTestCase<Integer> {
-  public void testBasic() throws Exception {
-    compactor.add(createSoplog(0, 100, 0));
-    
-    assertEquals(1, compactor.getActiveReaders(null, null).size());
-    assertEquals(1, compactor.getLevel(0).getSnapshot().size());
-    assertFalse(compactor.getLevel(0).needsCompaction());
-    
-    WaitingHandler wh = new WaitingHandler();
-    compactor.compact(false, wh);
-    wh.waitForCompletion();
-
-    assertEquals(1, compactor.getActiveReaders(null, null).size());
-    assertEquals(1, compactor.getLevel(0).getSnapshot().size());
-    assertFalse(compactor.getLevel(0).needsCompaction());
-  }
-
-  public void testCompactionLevel0() throws Exception {
-    compactor.add(createSoplog(0, 100, 0));
-    compactor.add(createSoplog(100, 100, 1));
-    
-    assertEquals(2, compactor.getActiveReaders(null, null).size());
-    assertEquals(2, compactor.getLevel(0).getSnapshot().size());
-    assertTrue(compactor.getLevel(0).needsCompaction());
-
-    WaitingHandler wh = new WaitingHandler();
-    compactor.compact(false, wh);
-    wh.waitForCompletion();
-
-    assertEquals(1, compactor.getActiveReaders(null, null).size());
-    assertEquals(0, compactor.getLevel(0).getSnapshot().size());
-    assertEquals(1, compactor.getLevel(1).getSnapshot().size());
-    assertFalse(compactor.getLevel(0).needsCompaction());
-    assertFalse(compactor.getLevel(1).needsCompaction());
-    
-    validate(compactor.getActiveReaders(null, null).iterator().next().get(), 0, 200);
-  }
-  
-  public void testMultilevelCompaction() throws Exception {
-    for (int i = 0; i < 8; i += 2) {
-      compactor.add(createSoplog(0, 100, i));
-      compactor.add(createSoplog(100, 100, i+1));
-
-      WaitingHandler wh = new WaitingHandler();
-      compactor.compact(false, wh);
-      wh.waitForCompletion();
-    }
-    
-    assertEquals(1, compactor.getActiveReaders(null, null).size());
-    validate(compactor.getActiveReaders(null, null).iterator().next().get(), 0, 200);
-  }
-  
-  public void testForceCompaction() throws Exception {
-    compactor.add(createSoplog(0, 100, 0));
-    compactor.add(createSoplog(100, 100, 1));
-    boolean compacted = compactor.compact();
-    
-    assertTrue(compacted);
-    validate(compactor.getActiveReaders(null, null).iterator().next().get(), 0, 200);
-  }
-
-  @Override
-  protected AbstractCompactor<Integer> createCompactor(SortedOplogFactory factory) throws IOException {
-    return new SizeTieredCompactor(factory, 
-        NonCompactor.createFileset("test", new File(".")), 
-        new FileTracker(), 
-        Executors.newSingleThreadExecutor(),
-        2, 4);
-  }
-
-  private void validate(SortedOplogReader soplog, int start, int count) throws IOException {
-    int i = 0;
-    for (SortedIterator<ByteBuffer> iter = soplog.scan(); iter.hasNext(); i++) {
-      iter.next();
-      assertEquals(i, iter.key().getInt());
-      assertEquals(i, iter.value().getInt());
-    }
-    assertEquals(count, i);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredSortedOplogSetJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredSortedOplogSetJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredSortedOplogSetJUnitTest.java
deleted file mode 100644
index cf1de00..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SizeTieredSortedOplogSetJUnitTest.java
+++ /dev/null
@@ -1,43 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.concurrent.Executors;
-
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.CompactionTestCase.FileTracker;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class SizeTieredSortedOplogSetJUnitTest extends CompactionSortedOplogSetTestCase {
-  @Override
-  protected AbstractCompactor<?> createCompactor(SortedOplogFactory factory) throws IOException {
-    return new SizeTieredCompactor(factory, 
-        NonCompactor.createFileset("test", new File(".")), 
-        new FileTracker(), 
-        Executors.newSingleThreadExecutor(),
-        2, 4);
-  }
-  @Override
-  public void testStatistics() throws IOException {
-    // remove this noop override when bug 52249 is fixed
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBufferJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBufferJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBufferJUnitTest.java
deleted file mode 100644
index 1d79059..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBufferJUnitTest.java
+++ /dev/null
@@ -1,39 +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.persistence.soplog;
-
-import java.nio.ByteBuffer;
-import java.util.Map.Entry;
-import java.util.NavigableMap;
-
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class SortedBufferJUnitTest extends SortedReaderTestCase {
-  @Override
-  protected SortedReader<ByteBuffer> createReader(NavigableMap<byte[], byte[]> data) {
-    SortedOplogConfiguration config = new SortedOplogConfiguration("test");
-    SortedBuffer<Integer> sb = new SortedBuffer<Integer>(config, 0);
-    for (Entry<byte[], byte[]> entry : data.entrySet()) {
-      sb.put(entry.getKey(), entry.getValue());
-    }
-    return sb;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetJUnitTest.java
deleted file mode 100644
index bb0a198..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetJUnitTest.java
+++ /dev/null
@@ -1,273 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Map.Entry;
-import java.util.NavigableMap;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.Executors;
-import java.util.concurrent.atomic.AtomicBoolean;
-import java.util.concurrent.atomic.AtomicInteger;
-
-import org.apache.logging.log4j.Logger;
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogSet.FlushHandler;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedIterator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.nofile.NoFileSortedOplogFactory;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class SortedOplogSetJUnitTest extends SortedReaderTestCase {
-  private static final Logger logger = LogService.getLogger();
-  private SortedOplogSet set;
-  
-  public void testMergedIterator() throws IOException {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogSet sos = createSoplogSet("merge");
-    
-    // #1
-    sos.put(wrapInt(1), wrapInt(1));
-    sos.put(wrapInt(2), wrapInt(1));
-    sos.put(wrapInt(3), wrapInt(1));
-    sos.put(wrapInt(4), wrapInt(1));
-    sos.flush(null, handler);
-    
-    // #2
-    sos.put(wrapInt(2), wrapInt(1));
-    sos.put(wrapInt(4), wrapInt(1));
-    sos.put(wrapInt(6), wrapInt(1));
-    sos.put(wrapInt(8), wrapInt(1));
-    sos.flush(null, handler);
-    
-    // #3
-    sos.put(wrapInt(1), wrapInt(1));
-    sos.put(wrapInt(3), wrapInt(1));
-    sos.put(wrapInt(5), wrapInt(1));
-    sos.put(wrapInt(7), wrapInt(1));
-    sos.put(wrapInt(9), wrapInt(1));
-    sos.flush(null, handler);
-    
-    // #4
-    sos.put(wrapInt(0), wrapInt(1));
-    sos.put(wrapInt(1), wrapInt(1));
-    sos.put(wrapInt(4), wrapInt(1));
-    sos.put(wrapInt(5), wrapInt(1));
-
-    while (!handler.flushes.compareAndSet(3, 0));
-    
-    // the iteration pattern for this test should be 0-9:
-    // 0 1 4 5   sbuffer #4
-    // 1 3 5 7 9 soplog #3
-    // 2 4 6 8   soplog #2
-    // 1 2 3 4   soplog #1
-    List<Integer> result = new ArrayList<Integer>();
-    SortedIterator<ByteBuffer> iter = sos.scan();
-    try {
-      while (iter.hasNext()) {
-        ByteBuffer key = iter.next();
-        ByteBuffer val = iter.value();
-        assertEquals(wrapInt(1), val);
-        
-        result.add(key.getInt());
-      }
-    } finally {
-      iter.close();
-    }
-
-    sos.close();
-    
-    assertEquals(10, result.size());
-    for (int i = 0; i < 10; i++) {
-      assertEquals(i, result.get(i).intValue());
-    }
-  }
-
-  @Override
-  protected SortedReader<ByteBuffer> createReader(NavigableMap<byte[], byte[]> data) 
-      throws IOException {
-    set = createSoplogSet("test");
-    
-    int i = 0;
-    int flushes = 0;
-    FlushCounter fc = new FlushCounter();
-    
-    for (Entry<byte[], byte[]> entry : data.entrySet()) {
-      set.put(entry.getKey(), entry.getValue());
-      if (i++ % 13 == 0) {
-        flushes++;
-        set.flush(null, fc);
-      }
-    }
-    
-    while (!fc.flushes.compareAndSet(flushes, 0));
-    return set;
-  }
-  
-  public void testClear() throws IOException {
-    set.clear();
-    validateEmpty(set);
-  }
-  
-  public void testDestroy() throws IOException {
-    set.destroy();
-    assertTrue(((SortedOplogSetImpl) set).isClosed());
-    try {
-      set.scan();
-      fail();
-    } catch (IllegalStateException e) { }
-  }
-  
-  public void testClearInterruptsFlush() throws Exception {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogSetImpl sos = prepSoplogSet("clearDuringFlush");
-    
-    sos.testDelayDuringFlush = new CountDownLatch(1);
-    sos.flush(null, handler);
-    sos.clear();
-    
-    flushAndWait(handler, sos);
-    validateEmpty(sos);
-    assertEquals(2, handler.flushes.get());
-  }
-  
-  public void testClearRepeat() throws Exception {
-    int i = 0;
-    do {
-      testClearInterruptsFlush();
-      logger.debug("Test {} is complete", i);
-      tearDown();
-      setUp();
-    } while (i++ < 100);
- }
-  
-  public void testCloseInterruptsFlush() throws Exception {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogSetImpl sos = prepSoplogSet("closeDuringFlush");
-    
-    sos.testDelayDuringFlush = new CountDownLatch(1);
-    sos.flush(null, handler);
-    sos.close();
-    
-    assertTrue(sos.isClosed());
-    assertEquals(1, handler.flushes.get());
-  }
-
-  public void testDestroyInterruptsFlush() throws Exception {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogSetImpl sos = prepSoplogSet("destroyDuringFlush");
-    
-    sos.testDelayDuringFlush = new CountDownLatch(1);
-    sos.flush(null, handler);
-    sos.destroy();
-    
-    assertTrue(sos.isClosed());
-    assertEquals(1, handler.flushes.get());
-  }
-
-  public void testScanAfterClear() throws IOException {
-    SortedIterator<ByteBuffer> iter = set.scan();
-    set.clear();
-    assertFalse(iter.hasNext());
-  }
-
-  public void testScanAfterClose() throws IOException {
-    SortedIterator<ByteBuffer> iter = set.scan();
-    set.close();
-    assertFalse(iter.hasNext());
-  }
-  
-  public void testEmptyFlush() throws Exception {
-    FlushCounter handler = new FlushCounter();
-    SortedOplogSet sos = prepSoplogSet("empty");
-    
-    flushAndWait(handler, sos);
-    flushAndWait(handler, sos);
-  }
-  
-  public void testErrorDuringFlush() throws Exception {
-    FlushCounter handler = new FlushCounter();
-    handler.error.set(true);
-    
-    SortedOplogSetImpl sos = prepSoplogSet("err");
-    sos.testErrorDuringFlush = true;
-    
-    flushAndWait(handler, sos);
-  }
-  
-  protected void validateEmpty(SortedOplogSet sos) throws IOException {
-    assertEquals(0, sos.bufferSize());
-    assertEquals(0, sos.unflushedSize());
-    
-    SortedIterator<ByteBuffer> iter = sos.scan();
-    assertFalse(iter.hasNext());
-    iter.close();
-    sos.close();
-  }
-  
-  protected SortedOplogSetImpl prepSoplogSet(String name) throws IOException {
-    SortedOplogSetImpl sos = createSoplogSet(name);
-
-    sos.put(wrapInt(1), wrapInt(1));
-    sos.put(wrapInt(2), wrapInt(1));
-    sos.put(wrapInt(3), wrapInt(1));
-    sos.put(wrapInt(4), wrapInt(1));
-    
-    return sos;
-  }
-  
-  protected SortedOplogSetImpl createSoplogSet(String name) throws IOException {
-    SortedOplogFactory factory = new NoFileSortedOplogFactory(name);
-    Compactor compactor = new NonCompactor(name, new File("."));
-    
-    return new SortedOplogSetImpl(factory, Executors.newSingleThreadExecutor(), compactor);
-  }
-
-  protected void flushAndWait(FlushCounter handler, SortedOplogSet sos)
-      throws InterruptedException, IOException {
-    sos.flush(null, handler);
-    while (sos.unflushedSize() > 0) {
-      Thread.sleep(1000);
-    }
-  }
-
-  protected static class FlushCounter implements FlushHandler {
-    private final AtomicInteger flushes = new AtomicInteger(0);
-    private final AtomicBoolean error = new AtomicBoolean(false);
-    
-    @Override 
-    public void complete() {
-      logger.debug("Flush complete! {}", this);
-      assertFalse(error.get());
-      flushes.incrementAndGet();
-    }
-    
-    @Override 
-    public void error(Throwable t) {
-      if (!error.get()) {
-        t.printStackTrace();
-        fail(t.getMessage());
-      }
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedReaderTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedReaderTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedReaderTestCase.java
deleted file mode 100644
index b41e6ba..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedReaderTestCase.java
+++ /dev/null
@@ -1,295 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.FilenameFilter;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map.Entry;
-import java.util.NavigableMap;
-import java.util.TreeMap;
-import java.util.concurrent.Callable;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-import java.util.concurrent.Future;
-
-import junit.framework.TestCase;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedIterator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedStatistics;
-
-public abstract class SortedReaderTestCase extends TestCase {
-  private NavigableMap<byte[], byte[]> data;
-  protected SortedReader<ByteBuffer> reader;
-
-  public static void assertEquals(byte[] expected, ByteBuffer actual) {
-    assertEquals(expected.length, actual.remaining());
-    for (int i = 0; i < expected.length; i++) {
-      assertEquals(expected[i], actual.get(actual.position() + i));
-    }
-  }
-  
-  public void testComparator() {
-    assertNotNull(reader.getComparator());
-  }
-  
-  public void testStatistics() throws IOException {
-    SortedStatistics stats = reader.getStatistics();
-    try {
-      assertEquals(data.size(), stats.keyCount());
-      assertTrue(Arrays.equals(data.firstKey(), stats.firstKey()));
-      assertTrue(Arrays.equals(data.lastKey(), stats.lastKey()));
-      
-      int keySize = 0;
-      int valSize = 0;
-      for (Entry<byte[], byte[]> entry : data.entrySet()) {
-        keySize += entry.getKey().length;
-        valSize += entry.getValue().length;
-      }
-
-      double avgKey = keySize / data.size();
-      double avgVal = valSize / data.size();
-          
-      assertEquals(avgVal, stats.avgValueSize());
-      assertEquals(avgKey, stats.avgKeySize());
-      
-    } finally {
-      stats.close();
-    }
-  }
-
-  public void testMightContain() throws IOException {
-    for (byte[] key : data.keySet()) {
-      assertTrue(reader.mightContain(key));
-    }
-  }
-
-  public void testRead() throws IOException {
-    for (byte[] key : data.keySet()) {
-      assertEquals(data.get(key), reader.read(key));
-    }
-  }
-
-  public void testScan() throws IOException {
-    SortedIterator<ByteBuffer> scan = reader.scan();
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.entrySet().iterator();
-      doIter(scan, iter);
-      
-    } finally {
-      scan.close();
-    }
-  }
-  
-  public void testMultithreadScan() throws Exception {
-    int threads = 10;
-    ExecutorService exec = Executors.newFixedThreadPool(threads);
-    List<Callable<Boolean>> tasks = new ArrayList<Callable<Boolean>>();
-    for (int i = 0; i < threads; i++) {
-      tasks.add(new Callable<Boolean>() {
-        @Override
-        public Boolean call() throws Exception {
-          testScan();
-          return true;
-        }
-      });
-    }
-
-    int i = 0;
-    while (i++ < 1000) {
-      for (Future<Boolean> ft : exec.invokeAll(tasks)) {
-        assertTrue(ft.get());
-      }
-    }
-  }
-  
-  public void testScanReverse() throws IOException {
-    SortedIterator<ByteBuffer> scan = reader.withAscending(false).scan();
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.descendingMap().entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  }
-  
-  public void testHead() throws IOException {
-    byte[] split = wrapInt(50);
-    SortedIterator<ByteBuffer> scan = reader.head(split, true);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.headMap(split, true).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-    
-    scan = reader.head(split, false);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.headMap(split, false).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  }
-  
-  public void testTail() throws IOException {
-    byte[] split = wrapInt(50);
-    SortedIterator<ByteBuffer> scan = reader.tail(split, true);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.tailMap(split, true).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-    
-    scan = reader.tail(split, false);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.tailMap(split, false).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  }
-  
-  public void testScanWithBounds() throws IOException {
-    byte[] lhs = wrapInt(10);
-    byte[] rhs = wrapInt(90);
-
-    // [lhs,rhs)
-    SortedIterator<ByteBuffer> scan = reader.scan(lhs, rhs);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.subMap(lhs, rhs).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-    
-    // (lhs,rhs)
-    scan = reader.scan(lhs, false, rhs, false);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.subMap(lhs, false, rhs, false).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  
-    // [lhs,rhs]
-    scan = reader.scan(lhs, true, rhs, true);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.subMap(lhs, true, rhs, true).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  }
-  
-  public void testReverseScanWithBounds() throws IOException {
-    data = data.descendingMap();
-    byte[] rhs = wrapInt(10);
-    byte[] lhs = wrapInt(90);
-
-    SortedReader<ByteBuffer> rev = reader.withAscending(false);
-    
-    // [rhs,lhs)
-    SortedIterator<ByteBuffer> scan = rev.scan(lhs, rhs);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.subMap(lhs, rhs).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-      
-    // (rhs,lhs)
-    scan = rev.scan(lhs, false, rhs, false);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.subMap(lhs, false, rhs, false).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  
-    // [rhs,lhs]
-    scan = rev.scan(lhs, true, rhs, true);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.subMap(lhs, true, rhs, true).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  }
-  
-  public void testScanEquality() throws IOException {
-    byte[] val = wrapInt(10);
-    
-    // [val,val]
-    SortedIterator<ByteBuffer> scan = reader.scan(val);
-    try {
-      Iterator<Entry<byte[], byte[]>> iter = data.subMap(val, true, val, true).entrySet().iterator();
-      doIter(scan, iter);
-    } finally {
-      scan.close();
-    }
-  }
-  
-  public static byte[] wrapInt(int n) {
-    ByteBuffer buf = (ByteBuffer) ByteBuffer.allocate(4).putInt(n).flip();
-    return buf.array();
-  }
-  
-  public static File[] getSoplogsToDelete() {
-    return new File(".").listFiles(new FilenameFilter() {
-      @Override
-      public boolean accept(File dir, String name) {
-        return name.endsWith("soplog") || name.endsWith("crc");
-      }
-    });
-  }
-
-  private void doIter(SortedIterator<ByteBuffer> scan, Iterator<Entry<byte[], byte[]>> iter) {
-    while (scan.hasNext() || iter.hasNext()) {
-      Entry<byte[], byte[]> expected = iter.next();
-      assertEquals(expected.getKey(), scan.next());
-      assertEquals(expected.getValue(), scan.value());
-    }
-  }
-
-  @Override
-  protected final void setUp() throws IOException {
-    data = new TreeMap<byte[], byte[]>(new ByteComparator());
-    
-    for (int i = 0; i < 100; i++) {
-      data.put(wrapInt(i), wrapInt(i));
-    }
-    reader = createReader(data);
-  }
-  
-  @Override 
-  protected void tearDown() throws IOException {
-    reader.close();
-    for (File f : getSoplogsToDelete()) {
-      f.delete();
-    }
-  }
-  
-  protected abstract SortedReader<ByteBuffer> createReader(NavigableMap<byte[], byte[]> data) 
-      throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogJUnitTest.java
deleted file mode 100644
index b6813d7..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/soplog/nofile/NoFileSortedOplogJUnitTest.java
+++ /dev/null
@@ -1,48 +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.persistence.soplog.nofile;
-
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.Map.Entry;
-import java.util.NavigableMap;
-
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogWriter;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReaderTestCase;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
-
-@Category(UnitTest.class)
-public class NoFileSortedOplogJUnitTest extends SortedReaderTestCase {
-  private NoFileSortedOplog mfile;
-
-  @Override
-  protected SortedReader<ByteBuffer> createReader(NavigableMap<byte[], byte[]> data) throws IOException {
-    mfile = new NoFileSortedOplog(new SortedOplogConfiguration("nofile"));
-
-    SortedOplogWriter wtr = mfile.createWriter();
-    for (Entry<byte[], byte[]> entry : data.entrySet()) {
-      wtr.append(entry.getKey(), entry.getValue());
-    }
-    wtr.close(null);
-
-    return mfile.createReader();
-  }
-}


[14/50] [abbrv] incubator-geode git commit: GEODE-533: GFSH query swaps row values when they are null

Posted by bs...@apache.org.
GEODE-533: GFSH query swaps row values when they are null


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

Branch: refs/heads/feature/GEODE-77
Commit: 1b8a35734a7808623f0247ad5f82de92aea70c14
Parents: dc5d343
Author: Jens Deppe <jd...@pivotal.io>
Authored: Fri Nov 6 08:53:25 2015 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Fri Nov 6 08:53:25 2015 -0800

----------------------------------------------------------------------
 gemfire-json/src/main/java/org/json/JSONObject.java | 2 ++
 1 file changed, 2 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/1b8a3573/gemfire-json/src/main/java/org/json/JSONObject.java
----------------------------------------------------------------------
diff --git a/gemfire-json/src/main/java/org/json/JSONObject.java b/gemfire-json/src/main/java/org/json/JSONObject.java
index 63676cc..6c478db 100755
--- a/gemfire-json/src/main/java/org/json/JSONObject.java
+++ b/gemfire-json/src/main/java/org/json/JSONObject.java
@@ -999,6 +999,8 @@ public class JSONObject {
                         Object result = method.invoke(bean, (Object[])null);
                         if (result != null) {
                             this.map.put(key, wrap(result));
+                        } else if (!method.getReturnType().isArray()) {
+                            this.map.put(key, JSONObject.NULL);
                         }
                     }
                 }


[26/50] [abbrv] incubator-geode git commit: GEODE-494: remove failing test

Posted by bs...@apache.org.
GEODE-494: remove failing test

This test fails very intermittently but doesn't reflect any real-world
use case so I'm deleting it.

While debugging, found a logic error in PartitionManager but it seems
that the code path is never exercised (used only in tests).


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

Branch: refs/heads/feature/GEODE-77
Commit: e96c960d658044018be864ccfc81a7cf91e189b2
Parents: cfbeaf2
Author: Jens Deppe <jd...@pivotal.io>
Authored: Mon Nov 9 15:42:42 2015 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Mon Nov 9 15:42:42 2015 -0800

----------------------------------------------------------------------
 .../cache/partition/PartitionManager.java       |  2 +-
 .../partition/PartitionManagerDUnitTest.java    | 75 --------------------
 2 files changed, 1 insertion(+), 76 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e96c960d/gemfire-core/src/main/java/com/gemstone/gemfire/cache/partition/PartitionManager.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/partition/PartitionManager.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/partition/PartitionManager.java
index ceff534..8454d2c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/partition/PartitionManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/partition/PartitionManager.java
@@ -191,7 +191,7 @@ public final class PartitionManager {
             logger.debug("createPrimaryBucket: {} bucket {} already primary, destroying local primary", pr, bucketId);
           }
           if (dumpBucket(self, region, bucketId)) {
-            createdBucket = createBucket(self, region, bucketId, destroyExistingRemote);
+            createdBucket = createBucket(self, region, bucketId, destroyExistingLocal);
           }
         } else {
           if (logger.isDebugEnabled()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e96c960d/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionManagerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionManagerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionManagerDUnitTest.java
index e061053..a7696c3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionManagerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionManagerDUnitTest.java
@@ -440,79 +440,4 @@ public class PartitionManagerDUnitTest extends CacheTestCase {
     });
     
   }
-  
-public void testConcurrentWithPuts() throws Throwable {
-    
-    Host host = Host.getHost(0);
-    VM vm0 = host.getVM(0);
-    VM vm1 = host.getVM(1);
-
-    SerializableRunnable createPrRegion = new SerializableRunnable("createRegion") {
-      public void run()
-      {
-        Cache cache = getCache();
-        AttributesFactory attr = new AttributesFactory();
-        PartitionAttributesFactory paf = new PartitionAttributesFactory();
-        paf.setRedundantCopies(0);
-        paf.setRecoveryDelay(-1);
-        paf.setStartupRecoveryDelay(-1);
-        PartitionAttributes prAttr = paf.create();
-        attr.setPartitionAttributes(prAttr);
-        cache.createRegion("region1", attr.create());
-      }
-    };
-    
-    vm0.invoke(createPrRegion);
-    vm1.invoke(createPrRegion);
-    
-    SerializableRunnable lotsOfPuts= new SerializableRunnable("A bunch of puts") {
-      public void run()
-      {
-        Cache cache = getCache();
-        PartitionedRegion region = (PartitionedRegion) cache.getRegion("region1");
-        
-        long start = System.nanoTime();
-        
-        while(TimeUnit.NANOSECONDS.toSeconds(System.nanoTime() - start) < CONCURRENT_TIME) {
-          //Do a put which might trigger bucket creation
-          region.put(BUCKET_ID, "B");
-          try {
-            Thread.sleep(10);
-          } catch (InterruptedException e) {
-            fail("", e);
-          }
-        }
-      }
-    };
-    AsyncInvocation async0_2 = vm0.invokeAsync(lotsOfPuts);
-    AsyncInvocation async1_2 = vm1.invokeAsync(lotsOfPuts);
-    
-    
-    long start = System.nanoTime();
-    
-    while(TimeUnit.NANOSECONDS.toSeconds(System.nanoTime() - start) < CONCURRENT_TIME) {
-      createPrimaryBucket(vm0, true, false);
-      createPrimaryBucket(vm1, true, false);
-    }
-    
-    async0_2.getResult(MAX_WAIT);
-    async1_2.getResult(MAX_WAIT);
-
-    vm0.invoke(new SerializableRunnable("Check the number of owners") {
-      public void run()
-      {
-        Cache cache = getCache();
-        PartitionedRegion region = (PartitionedRegion) cache.getRegion("region1");
-        List owners;
-        try {
-          owners = region.getBucketOwnersForValidation(BUCKET_ID);
-          assertEquals(1, owners.size());
-        } catch (ForceReattemptException e) {
-          fail("shouldn't have seen force reattempt", e);
-        }
-      }
-    });
-    
-  }
-
 }


[18/50] [abbrv] incubator-geode git commit: GEODE-427: add test logging and assertions

Posted by bs...@apache.org.
GEODE-427: add test logging and assertions

This test refuses to reproduce the failure and
code review has not revealed the cause.
I've added additional test logging and assertions
to give more info the next time the test fails.


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

Branch: refs/heads/feature/GEODE-77
Commit: 06509f34f81cf7afa3de062c7ca342f309849e05
Parents: 2933ccd
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Fri Nov 6 13:40:35 2015 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Fri Nov 6 13:40:35 2015 -0800

----------------------------------------------------------------------
 .../management/MemoryThresholdsDUnitTest.java   | 34 +++++++++++++++++++-
 .../control/TestMemoryThresholdListener.java    | 13 ++++++++
 2 files changed, 46 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/06509f34/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
index 50654f6..1d1ada3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
@@ -405,7 +405,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     ServerPorts ports2 = startCacheServer(server2, ports1.getMcastPort(), 80f, 90f,
         regionName, false/*createPR*/, false/*notifyBySubscription*/, 0);
 
-    registerTestMemoryThresholdListener(server1);
+    registerLoggingTestMemoryThresholdListener(server1);
     registerTestMemoryThresholdListener(server2);
 
     //NORMAL -> CRITICAL
@@ -418,6 +418,9 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
         return null;
       }
     });
+    verifyListenerValue(server2, MemoryState.CRITICAL, 1, true);
+    verifyListenerValue(server2, MemoryState.EVICTION, 1, true);
+    verifyListenerValue(server2, MemoryState.NORMAL, 0, true);
 
     //make sure we get two events on remote server
     verifyListenerValue(server1, MemoryState.CRITICAL, 1, true);
@@ -434,6 +437,9 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
         return null;
       }
     });
+    verifyListenerValue(server2, MemoryState.CRITICAL, 1, true);
+    verifyListenerValue(server2, MemoryState.EVICTION, 2, true);
+    verifyListenerValue(server2, MemoryState.NORMAL, 0, true);
     verifyListenerValue(server1, MemoryState.CRITICAL, 1, true);
     verifyListenerValue(server1, MemoryState.EVICTION, 2, true);
     verifyListenerValue(server1, MemoryState.NORMAL, 0, true);;
@@ -446,6 +452,9 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
         return null;
       }
     });
+    verifyListenerValue(server2, MemoryState.CRITICAL, 1, true);
+    verifyListenerValue(server2, MemoryState.EVICTION, 2, true);
+    verifyListenerValue(server2, MemoryState.NORMAL, 0, true);
     verifyListenerValue(server1, MemoryState.CRITICAL, 1, true);
     verifyListenerValue(server1, MemoryState.EVICTION, 2, true);
     verifyListenerValue(server1, MemoryState.NORMAL, 0, true);
@@ -459,10 +468,14 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
       }
     });
 
+    verifyListenerValue(server2, MemoryState.CRITICAL, 1, true);
+    verifyListenerValue(server2, MemoryState.EVICTION, 2, true);
+    verifyListenerValue(server2, MemoryState.NORMAL, 1, true);
     verifyListenerValue(server1, MemoryState.CRITICAL, 1, true);
     verifyListenerValue(server1, MemoryState.EVICTION, 2, true);
     verifyListenerValue(server1, MemoryState.NORMAL, 1, true);
     
+    this.getLogWriter().info("before NORMAL->CRITICAL->NORMAL");
     //NORMAL -> EVICTION -> NORMAL
     server2.invoke(new SerializableCallable() {
       public Object call() throws Exception {
@@ -472,7 +485,11 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
         return null;
       }
     });
+    this.getLogWriter().info("after NORMAL->CRITICAL->NORMAL");
 
+    verifyListenerValue(server2, MemoryState.CRITICAL, 2, true);
+    verifyListenerValue(server2, MemoryState.EVICTION, 3, true);
+    verifyListenerValue(server2, MemoryState.NORMAL, 2, true);
     verifyListenerValue(server1, MemoryState.CRITICAL, 2, true);
     verifyListenerValue(server1, MemoryState.EVICTION, 3, true);
     verifyListenerValue(server1, MemoryState.NORMAL, 2, true);
@@ -486,6 +503,9 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
       }
     });
 
+    verifyListenerValue(server2, MemoryState.CRITICAL, 2, true);
+    verifyListenerValue(server2, MemoryState.EVICTION, 4, true);
+    verifyListenerValue(server2, MemoryState.NORMAL, 2, true);
     verifyListenerValue(server1, MemoryState.CRITICAL, 2, true);
     verifyListenerValue(server1, MemoryState.EVICTION, 4, true);
     verifyListenerValue(server1, MemoryState.NORMAL, 2, true);
@@ -1452,6 +1472,18 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
     });
   }
 
+  private void registerLoggingTestMemoryThresholdListener(VM vm) {
+    vm.invoke(new SerializableCallable() {
+      public Object call() throws Exception {
+        TestMemoryThresholdListener listener = new TestMemoryThresholdListener(true);
+        InternalResourceManager irm = ((GemFireCacheImpl)getCache()).getResourceManager();
+        irm.addResourceListener(ResourceType.HEAP_MEMORY, listener);
+        assertTrue(irm.getResourceListeners(ResourceType.HEAP_MEMORY).contains(listener));
+        return null;
+      }
+    });
+  }
+
   /**
    * Verifies that the test listener value on the given vm is what is expected
    * Note that for remote events useWaitCriterion must be true

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/06509f34/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/TestMemoryThresholdListener.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/TestMemoryThresholdListener.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/TestMemoryThresholdListener.java
index ba1feb6..7dd596c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/TestMemoryThresholdListener.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/TestMemoryThresholdListener.java
@@ -16,6 +16,8 @@
  */
 package com.gemstone.gemfire.internal.cache.control;
 
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+
 
 public class TestMemoryThresholdListener implements ResourceListener<MemoryEvent>{
   private int normalCalls = 0;
@@ -26,6 +28,14 @@ public class TestMemoryThresholdListener implements ResourceListener<MemoryEvent
   private long bytesFromThreshold = 0;
   private int currentHeapPercentage = 0;
   private int allCalls = 0;
+  private final boolean logOnEventCalls;
+  
+  public TestMemoryThresholdListener() {
+    this(false);
+  }
+  public TestMemoryThresholdListener(boolean log) {
+    this.logOnEventCalls = log;
+  }
 
   public  long getBytesFromThreshold() {
     synchronized (this) {
@@ -100,6 +110,9 @@ public class TestMemoryThresholdListener implements ResourceListener<MemoryEvent
    */
   @Override
   public void onEvent(MemoryEvent event) {
+    if (this.logOnEventCalls) {
+      InternalDistributedSystem.getAnyInstance().getLogWriter().info("TestMemoryThresholdListener onEvent " + event);
+    }
     synchronized (this) {
       if (event.getState().isNormal()) {
         this.normalCalls++;


[25/50] [abbrv] incubator-geode git commit: GEODE-537 Fix NPE in JTA AFTER_COMPLETION during rollback

Posted by bs...@apache.org.
GEODE-537 Fix NPE in JTA AFTER_COMPLETION during rollback

A fix for NullPointerException thrown on the server side and propagated to the Gemfire client in case when active JTA transaction gets rolled back.


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

Branch: refs/heads/feature/GEODE-77
Commit: 0f72d363bae43a11f0c6d132076b99aedd8d834a
Parents: cfbeaf2
Author: sshcherbakov <ss...@gopivotal.com>
Authored: Mon Nov 9 23:21:54 2015 +0100
Committer: sshcherbakov <ss...@gopivotal.com>
Committed: Mon Nov 9 23:30:22 2015 +0100

----------------------------------------------------------------------
 .../tier/sockets/command/CommitCommand.java     |  4 +-
 .../tier/sockets/command/CommitCommandTest.java | 39 ++++++++++++++++++++
 2 files changed, 42 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0f72d363/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommand.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommand.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommand.java
index 8d77874..6caf89a 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommand.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommand.java
@@ -119,7 +119,9 @@ public class CommitCommand extends BaseCommand {
     responseMsg.setMessageType(MessageType.RESPONSE);
     responseMsg.setTransactionId(origMsg.getTransactionId());
     responseMsg.setNumberOfParts(1);
-    response.setClientVersion(servConn.getClientVersion());
+    if( response != null ) {
+    	response.setClientVersion(servConn.getClientVersion());
+    }
     responseMsg.addObjPart(response, zipValues);
     servConn.getCache().getCancelCriterion().checkCancelInProgress(null);
     if (logger.isDebugEnabled()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0f72d363/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommandTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommandTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommandTest.java
new file mode 100644
index 0000000..1f9ce54
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/command/CommitCommandTest.java
@@ -0,0 +1,39 @@
+package com.gemstone.gemfire.internal.cache.tier.sockets.command;
+
+import static org.mockito.Mockito.mock;
+import static org.mockito.Mockito.when;
+
+import java.io.IOException;
+
+import org.junit.Test;
+
+import com.gemstone.gemfire.CancelCriterion;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
+
+public class CommitCommandTest {
+
+	/**
+	 * Test for GEODE-537
+	 * No NPE should be thrown from the {@link CommitCommand.writeCommitResponse()}
+	 * if the response message is null as it is the case when JTA
+	 * transaction is rolled back with TX_SYNCHRONIZATION AFTER_COMPLETION STATUS_ROLLEDBACK 
+	 * @throws IOException 
+	 * 
+	 */
+	@Test
+	public void testWriteNullResponse() throws IOException {
+		
+		Cache cache = mock(Cache.class);
+		Message origMsg = mock(Message.class);
+		ServerConnection servConn = mock(ServerConnection.class);
+		when(servConn.getResponseMessage()).thenReturn(mock(Message.class));
+		when(servConn.getCache()).thenReturn(cache);
+		when(cache.getCancelCriterion()).thenReturn(mock(CancelCriterion.class));
+		
+		CommitCommand.writeCommitResponse(null, origMsg, servConn);
+		
+	}
+	
+}


[40/50] [abbrv] incubator-geode git commit: GEODE-544: Removes soplog code and tests

Posted by bs...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SoplogToken.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SoplogToken.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SoplogToken.java
deleted file mode 100644
index 73175e7..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SoplogToken.java
+++ /dev/null
@@ -1,116 +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.persistence.soplog;
-
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.internal.cache.EntryBits;
-
-/**
- * Defines serialized tokens for soplogs. 
- */
-public enum SoplogToken {
-  
-  /** indicates the serialized value is a wildcard compares equal to any other key */
-  WILDCARD( DSCODE.WILDCARD ),
-  
-  /** indicates the serialized value is a tombstone of a deleted key */ 
-  TOMBSTONE( EntryBits.setTombstone((byte)0, true) ),
-
-  /** indicates the serialized value is a invalid token*/
-  INVALID( EntryBits.setInvalid((byte)0, true) ),
-
-  /** indicates the serialized tombstone has been garbage collected*/
-  REMOVED_PHASE2( EntryBits.setLocalInvalid((byte)0, true) ),
-  
-  /** indicates the value is serialized */
-  SERIALIZED( EntryBits.setSerialized((byte)0, true) );
-
-  /** the serialized form of the token */
-  private final byte val;
-  
-  private SoplogToken(byte val) {
-    this.val = val;
-  }
-  
-  @Override
-  public String toString() {
-    return super.toString()+" byte:"+val;
-  }
-
-  /**
-   * Returns the serialized form of the token.
-   * @return the byte
-   */
-  public byte toByte() {
-    return val;
-  }
-  
-  /**
-   * Returns true if either of the serialized objects is a wildcard.
-   * 
-   * @param b1 the first object
-   * @param off1 the first offset
-   * @param b2 the second object
-   * @param off2 the second object
-   * @return true if a wildcard
-   */
-  public static boolean isWildcard(byte[] b1, int off1, byte[] b2, int off2) {
-    return b1[off1] == DSCODE.WILDCARD || b2[off2] == DSCODE.WILDCARD;
-  }
-  
-  /**
-   * Returns true if the serialized object is a tombstone.
-   * 
-   * @param b the magic entry type byte
-   * @return true if a tombstone
-   */
-  public static boolean isTombstone(byte b) {
-    return EntryBits.isTombstone(b);
-  }
-
-  /**
-   * Returns true if the serialized object is an invalid token.
-   * 
-   * @param b the magic entry type byte
-   * @return true if invalid
-   */
-  public static boolean isInvalid(byte b) {
-    return EntryBits.isInvalid(b);
-  }
-
-  /**
-   * Returns true if the serialized tombstone was garbage collected
-   * 
-   * @param b the magic entry type byte
-   * @return true if RemovedPhase2
-   */
-  public static boolean isRemovedPhase2(byte b) {
-    return EntryBits.isLocalInvalid(b);
-  }
-
-  /**
-   * Returns true if the serialized object is not any token
-   * 
-   *@param b the magic entry type byte
-   * @return true if not any token
-   */
-  public static boolean isSerialized(byte b) {
-    return EntryBits.isSerialized(b);
-  }
-}
-
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBuffer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBuffer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBuffer.java
deleted file mode 100644
index b301ac5..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedBuffer.java
+++ /dev/null
@@ -1,367 +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.persistence.soplog;
-
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.Collections;
-import java.util.EnumMap;
-import java.util.Iterator;
-import java.util.Map.Entry;
-import java.util.NavigableMap;
-import java.util.concurrent.ConcurrentSkipListMap;
-
-import org.apache.logging.log4j.Logger;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration;
-import com.gemstone.gemfire.internal.logging.LogService;
-
-/**
- * Provides an in-memory buffer to temporarily hold key/value pairs until they
- * can be flushed to disk.  Each buffer instance can be optionally associated
- * with a user-specified tag for identification purposes.
- * 
- * @param <T> the tag type
- * @author bakera
- */
-public class SortedBuffer<T> extends AbstractSortedReader {
-  private static final Logger logger = LogService.getLogger();
-  
-  /** the tag */
-  private final T tag;
-  
-  /** in-memory sorted key/vaue buffer */
-  private final NavigableMap<byte[], byte[]> buffer;
-
-  /** the stats */
-  private final BufferStats stats;
-  
-  /** the metadata, set during flush */
-  private final EnumMap<Metadata, byte[]> metadata;
-  
-  /** the command to run (or defer) when the flush is complete */
-  private Runnable flushAction;
-  
-  private final String logPrefix;
-  
-  public SortedBuffer(SortedOplogConfiguration config, T tag) {
-    assert config != null;
-    assert tag != null;
-    
-    this.tag = tag;
-    
-    buffer = new ConcurrentSkipListMap<byte[], byte[]>(config.getComparator());
-    stats = new BufferStats();
-    metadata = new EnumMap<Metadata, byte[]>(Metadata.class);
-    
-    this.logPrefix = "<" + config.getName() + "#" + tag + "> ";
-  }
-  
-  /**
-   * Returns the tag associated with the buffer.
-   * @return the tag
-   */
-  public T getTag() {
-    return tag;
-  }
-  
-  @Override
-  public String toString() {
-    return logger.getName() + this.logPrefix;
-  }
-  
-  /**
-   * Adds a new value to the buffer.
-   * @param key the key
-   * @param value the value
-   */
-  public void put(byte[] key, byte[] value) {
-    if (buffer.put(key, value) == null) {
-      // ASSUMPTION: updates don't significantly change the value length
-      // this lets us optimize statistics calculations
-      stats.add(key.length, value.length);
-    }
-  }
-  
-  /**
-   * Allows sorted iteration over the buffer contents.
-   * @return the buffer entries
-   */
-  public Iterable<Entry<byte[], byte[]>> entries() {
-    return buffer.entrySet();
-  }
-  
-  /**
-   * Returns the number of entries in the buffer.
-   * @return the count
-   */
-  public int count() {
-    return buffer.size();
-  }
-  
-  /**
-   * Returns the size of the data in bytes.
-   * @return the data size
-   */
-  public long dataSize() {
-    return stats.totalSize();
-  }
-  
-  /**
-   * Clears the buffer of all entries.
-   */
-  public void clear() {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Clearing buffer", this.logPrefix);
-    }
-    
-    buffer.clear();
-    stats.clear();
-    metadata.clear();
-    
-    synchronized (this) {
-      flushAction = null;
-    }
-  }
-  
-  /**
-   * Returns true if the flush completion has been deferred.
-   * @return true if deferred
-   */
-  public synchronized boolean isDeferred() {
-    return flushAction != null;
-  }
-  
-  /**
-   * Defers the flush completion to a later time.  This is used to ensure correct
-   * ordering of soplogs during parallel flushes.
-   * 
-   * @param action the action to perform when ready
-   */
-  public synchronized void defer(Runnable action) {
-    assert flushAction == null;
-    
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Deferring flush completion", this.logPrefix);
-    }
-    flushAction = action;
-  }
-  
-  /**
-   * Completes the deferred flush operation.
-   */
-  public synchronized void complete() {
-    assert flushAction != null;
-
-    try {
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Completing deferred flush operation", this.logPrefix);
-      }
-      flushAction.run();
-      
-    } finally {
-      flushAction = null;
-    }
-  }
-  
-  /**
-   * Returns the buffer metadata.
-   * @return the metadata
-   */
-  public synchronized EnumMap<Metadata, byte[]> getMetadata() {
-    return metadata;
-  }
-  
-  /**
-   * Returns the metadata value for the given key.
-   * 
-   * @param name the metadata name
-   * @return the requested metadata
-   */
-  public synchronized byte[] getMetadata(Metadata name) {
-    return metadata.get(name);
-  }
-  
-  /**
-   * Sets the metadata for the buffer.  This is not available until the buffer
-   * is about to be flushed.
-   * 
-   * @param metadata the metadata
-   */
-  public synchronized void setMetadata(EnumMap<Metadata, byte[]> metadata) {
-    if (metadata != null) {
-      this.metadata.putAll(metadata);
-    }
-  }
-  
-  @Override
-  public boolean mightContain(byte[] key) {
-    return true;
-  }
-
-  @Override
-  public ByteBuffer read(byte[] key) throws IOException {
-    byte[] val = buffer.get(key);
-    if (val != null) {
-      return ByteBuffer.wrap(val);
-    }
-    return null;
-  }
-
-  @Override
-  public SortedIterator<ByteBuffer> scan(
-      byte[] from, boolean fromInclusive, 
-      byte[] to, boolean toInclusive,
-      boolean ascending,
-      MetadataFilter filter) {
-
-    if (filter == null || filter.accept(metadata.get(filter.getName()))) {
-      NavigableMap<byte[],byte[]> subset = ascending ? buffer : buffer.descendingMap();
-      if (from == null && to == null) {
-        // we're good
-      } else if (from == null) {
-        subset = subset.headMap(to, toInclusive);
-      } else if (to == null) {
-        subset = subset.tailMap(from, fromInclusive);
-      } else {
-        subset = subset.subMap(from, fromInclusive, to, toInclusive);
-      }
-      return new BufferIterator(subset.entrySet().iterator());
-    }
-    return new BufferIterator(Collections.<byte[], byte[]>emptyMap().entrySet().iterator());
-  }
-
-  @Override
-  public SerializedComparator getComparator() {
-    return (SerializedComparator) buffer.comparator();
-  }
-
-  @Override
-  public SortedStatistics getStatistics() {
-    return stats;
-  }
-  
-  @Override
-  public void close() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Closing buffer", this.logPrefix);
-    }
-    
-    synchronized (this) {
-      flushAction = null;
-    }
-  }
-  
-  /**
-   * Allows sorted iteration over the buffer contents.
-   */
-  public static class BufferIterator 
-    extends AbstractKeyValueIterator<ByteBuffer, ByteBuffer>
-    implements SortedIterator<ByteBuffer>
-  {
-    /** the backing iterator */
-    private final Iterator<Entry<byte[], byte[]>> entries;
-    
-    /** the iteration cursor */
-    private Entry<byte[], byte[]> current;
-    
-    public BufferIterator(Iterator<Entry<byte[], byte[]>> iterator) {
-      this.entries = iterator;
-    }
-    
-    @Override
-    public ByteBuffer key() {
-      return ByteBuffer.wrap(current.getKey());
-    }
-
-    @Override
-    public ByteBuffer value() {
-      return ByteBuffer.wrap(current.getValue());
-    }
-
-    @Override
-    public void close() {
-    }
-
-    @Override
-    protected boolean step() {
-      return (current = entries.hasNext() ? entries.next() : null) != null;
-    }
-  }
-  
-  private class BufferStats implements SortedStatistics {
-    /** data size */
-    private long totalSize;
-    
-    /** key count */
-    private long keys;
-    
-    /** avg key size */
-    private double avgKeySize;
-    
-    /** avg value size */
-    private double avgValueSize;
-    
-    private synchronized void clear() {
-      totalSize = 0;
-      keys = 0;
-      avgKeySize = 0;
-      avgValueSize = 0;
-    }
-    
-    private synchronized void add(int keyLength, int valueLength) {
-      totalSize += keyLength + valueLength;
-      avgKeySize = (keyLength + keys * avgKeySize) / (keys + 1);
-      avgValueSize = (keyLength + keys * avgValueSize) / (keys + 1);
-      
-      keys++;
-    }
-    
-    @Override
-    public synchronized long keyCount() {
-      return keys;
-    }
-
-    @Override
-    public byte[] firstKey() {
-      return buffer.firstKey();
-    }
-
-    @Override
-    public byte[] lastKey() {
-      return buffer.lastKey();
-    }
-
-    @Override
-    public synchronized double avgKeySize() {
-      return avgKeySize;
-    }
-    
-    @Override
-    public synchronized double avgValueSize() {
-      return avgValueSize;
-    }
-    
-    @Override
-    public void close() {
-    }
-
-    public synchronized long totalSize() {
-      return totalSize;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplog.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplog.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplog.java
deleted file mode 100644
index 95fb411..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplog.java
+++ /dev/null
@@ -1,158 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.EnumMap;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.Metadata;
-
-/**
- * Defines the API for reading and writing sorted key/value pairs.  The keys
- * are expected to be lexicographically comparable {@code byte[]} arrays.
- * 
- * @author bakera
- */
-public interface SortedOplog {
-  /**
-   * Checks if a key may be present in a set.
-   */
-  public interface BloomFilter {
-    /**
-     * Returns true if the bloom filter might contain the supplied key.  The 
-     * nature of the bloom filter is such that false positives are allowed, but
-     * false negatives cannot occur.
-     * 
-     * @param key the key to test
-     * @return true if the key might be present
-     */
-    boolean mightContain(byte[] key);
-  }
-  
-  /**
-   * Reads key/value pairs from the sorted file.
-   */
-  public interface SortedOplogReader extends SortedReader<ByteBuffer> {
-    /**
-     * Returns the bloom filter associated with this reader.
-     * @return the bloom filter
-     */
-    BloomFilter getBloomFilter();
-    
-    /**
-     * Returns the metadata value for the given key.
-     * 
-     * @param name the metadata name
-     * @return the requested metadata
-     * @throws IOException error reading metadata
-     */
-    byte[] getMetadata(Metadata name) throws IOException;
-    
-    /**
-     * Returns the file used to persist the soplog contents.
-     * @return the file
-     */
-    File getFile();
-    
-    /**
-     * @return file name
-     */
-    String getFileName();
-    
-    /**
-     * renames the file to the input name
-     * 
-     * @throws IOException
-     */
-    void rename(String name) throws IOException;
-    
-    /**
-     * @return the modification timestamp of the file
-     * @throws IOException 
-     */
-    long getModificationTimeStamp() throws IOException;
-    
-    /**
-     * Deletes the sorted oplog file
-     */
-    public void delete() throws IOException;
-
-    /**
-     * Returns true if the reader is closed.
-     * @return true if closed
-     */
-    boolean isClosed();
-  }
-  
-  /**
-   * Writes key/value pairs in a sorted manner.  Each entry that is appended
-   * must have a key that is greater than or equal to the previous key.
-   */
-  public interface SortedOplogWriter {
-    /**
-     * Appends another key and value.  The key is expected to be greater than
-     * or equal to the last key that was appended.
-     * 
-     * @param key the key
-     * @param value the value
-     * @throws IOException write error
-     */
-    void append(ByteBuffer key, ByteBuffer value) throws IOException;
-
-    /**
-     * Appends another key and value.  The key is expected to be greater than
-     * or equal to the last key that was appended.
-     * 
-     * @param key the key
-     * @param value the value
-     * @throws IOException write error
-     */
-    void append(byte[] key, byte[] value) throws IOException;
-
-    /**
-     * Closes the file, first writing optional user and system metadata. 
-     * 
-     * @param metadata the metadata to include
-     * @throws IOException unable to close file
-     */
-    void close(EnumMap<Metadata, byte[]> metadata) throws IOException;
-    
-    /**
-     * Invoked to close and remove the file to clean up after an error.
-     * @throws IOException error closing
-     */
-    void closeAndDelete() throws IOException;
-  }
-  
-  /**
-   * Creates a new sorted reader.
-   * 
-   * @return the reader
-   * @throws IOException error creating reader
-   */
-  SortedOplogReader createReader() throws IOException;
-  
-  /**
-   * Creates a new sorted writer.
-   * 
-   * @return the writer
-   * @throws IOException error creating writer
-   */
-  SortedOplogWriter createWriter() throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogFactory.java
deleted file mode 100644
index a470d7e..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogFactory.java
+++ /dev/null
@@ -1,278 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.EnumMap;
-
-import org.apache.hadoop.hbase.io.hfile.BlockCache;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.Compactor.MetadataCompactor;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.Metadata;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-
-/**
- * Provides a means to construct a soplog.
- */
-public interface SortedOplogFactory {
-  /**
-   * Configures a <code>SortedOplog</code>.
-   * 
-   * @author bakera
-   */
-  public class SortedOplogConfiguration {
-    /** the default metadata compactor */
-    public static MetadataCompactor DEFAULT_METADATA_COMPACTOR = new MetadataCompactor() {
-      @Override
-      public byte[] compact(byte[] metadata1, byte[] metadata2) {
-        return metadata1;
-      }
-    };
-    
-    /**
-     * Defines the available checksum algorithms.
-     */
-    public enum Checksum {
-      NONE,
-      CRC32
-    }
-    
-    /**
-     * Defines the available compression algorithms.
-     */
-    public enum Compression { 
-      NONE, 
-    }
-    
-    /**
-     * Defines the available key encodings.
-     */
-    public enum KeyEncoding { 
-      NONE, 
-    }
-
-    /** the soplog name */
-    private final String name;
-    
-    /** the statistics */
-    private final SortedOplogStatistics stats;
-    
-    private final HFileStoreStatistics storeStats;
-    
-    /** true if bloom filters are enabled */
-    private boolean bloom;
-    
-    /** the soplog block size */
-    private int blockSize;
-    
-    /** the number of bytes for each checksum */
-    private int bytesPerChecksum;
-    
-    /** the checksum type */
-    private Checksum checksum;
-    
-    /** the compression type */
-    private Compression compression;
-    
-    /** the key encoding type */
-    private KeyEncoding keyEncoding;
-    
-    /** the comparator */
-    private SerializedComparator comparator;
-
-    /** metadata comparers */
-    private EnumMap<Metadata, MetadataCompactor> metaCompactors;
-
-    private BlockCache blockCache;
-
-    private boolean cacheDataBlocksOnRead;
-    
-    public SortedOplogConfiguration(String name) {
-      this(name, null, new SortedOplogStatistics("GridDBRegionStatistics", name), new HFileStoreStatistics("GridDBStoreStatistics", name));
-    }
-    
-    public SortedOplogConfiguration(String name, BlockCache blockCache, SortedOplogStatistics stats, HFileStoreStatistics storeStats) {
-      this.name = name;
-      this.stats = stats;
-      
-      // defaults
-      bloom = true;
-      blockSize = 1 << 16;
-      bytesPerChecksum = 1 << 14;
-      checksum = Checksum.NONE;
-      compression = Compression.NONE;
-      keyEncoding = KeyEncoding.NONE;
-      comparator = new ByteComparator();
-      this.cacheDataBlocksOnRead = true;
-      this.storeStats = storeStats;
-      this.blockCache = blockCache;
-    }
-    
-    public SortedOplogConfiguration setBloomFilterEnabled(boolean enabled) {
-      this.bloom = enabled;
-      return this;
-    }
-    
-    public SortedOplogConfiguration setBlockSize(int size) {
-      this.blockSize = size;
-      return this;
-    }
-    
-    public SortedOplogConfiguration setBytesPerChecksum(int bytes) {
-      this.bytesPerChecksum = bytes;
-      return this;
-    }
-    
-    public SortedOplogConfiguration setChecksum(Checksum type) {
-      this.checksum = type;
-      return this;
-    }
-    
-    public SortedOplogConfiguration setCompression(Compression type) {
-      this.compression = type;
-      return this;
-    }
-    
-    public SortedOplogConfiguration setKeyEncoding(KeyEncoding type) {
-      this.keyEncoding = type;
-      return this;
-    }
-    
-    public SortedOplogConfiguration setComparator(SerializedComparator comp) {
-      this.comparator = comp;
-      return this;
-    }
-    
-    public SortedOplogConfiguration addMetadataCompactor(Metadata name, MetadataCompactor compactor) {
-      metaCompactors.put(name, compactor);
-      return this;
-    }
-    
-    /**
-     * Returns the soplog name.
-     * @return the name
-     */
-    public String getName() {
-      return name;
-    }
-
-    /**
-     * Returns the statistics.
-     * @return the statistics
-     */
-    public SortedOplogStatistics getStatistics() {
-      return stats;
-    }
-    
-    public HFileStoreStatistics getStoreStatistics() {
-      return storeStats;
-    }
-    
-    /**
-     * Returns true if the bloom filter is enabled.
-     * @return true if enabled
-     */
-    public boolean isBloomFilterEnabled() {
-      return bloom;
-    }
-
-    /**
-     * Returns the block size in bytes.
-     * @return the block size
-     */
-    public int getBlockSize() {
-      return blockSize;
-    }
-
-    /**
-     * Returns the number of bytes per checksum.
-     * @return the bytes
-     */
-    public int getBytesPerChecksum() {
-      return bytesPerChecksum;
-    }
-
-    /**
-     * Returns the checksum type.
-     * @return the checksum
-     */
-    public Checksum getChecksum() {
-      return checksum;
-    }
-
-    /**
-     * Returns the compression type.
-     * @return the compression
-     */
-    public Compression getCompression() {
-      return compression;
-    }
-
-    /**
-     * Returns the key encoding type.
-     * @return the key encoding
-     */
-    public KeyEncoding getKeyEncoding() {
-      return keyEncoding;
-    }
-
-    /**
-     * Returns the comparator.
-     * @return the comparator
-     */
-    public SerializedComparator getComparator() {
-      return comparator;
-    }
-    
-    /**
-     * Returns the metadata compactor for the given name. 
-     * @param name the metadata name
-     * @return the compactor
-     */
-    public MetadataCompactor getMetadataCompactor(Metadata name) {
-      MetadataCompactor mc = metaCompactors.get(name);
-      if (mc != null) {
-        return mc;
-      }
-      return DEFAULT_METADATA_COMPACTOR;
-    }
-
-    public BlockCache getBlockCache() {
-      return this.blockCache;
-    }
-
-    public boolean getCacheDataBlocksOnRead() {
-      return cacheDataBlocksOnRead ;
-    }
-  }
-  
-  /**
-   * Returns the configuration.
-   * @return the configuration
-   */
-  SortedOplogConfiguration getConfiguration();
-  
-  /**
-   * Creates a new soplog.
-   * 
-   * @param name the filename
-   * @return the soplog
-   * @throws IOException error creating soplog
-   */
-  SortedOplog createSortedOplog(File name) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSet.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSet.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSet.java
deleted file mode 100644
index 2900229..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSet.java
+++ /dev/null
@@ -1,118 +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.persistence.soplog;
-
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.EnumMap;
-
-/**
- * Provides a unified view of the current SBuffer, the unflushed SBuffers, and
- * the existing soplogs.
- * 
- * @author bakera
- */
-public interface SortedOplogSet extends SortedReader<ByteBuffer> {
-  /**
-   * Defines a callback handler for asynchronous operations.
-   */
-  public interface FlushHandler {
-    /**
-     * Invoked when the operation completed successfully.
-     */
-    void complete();
-    
-    /**
-     * Invoked when the operation completed with an error.
-     * @param t the error
-     */
-    void error(Throwable t);
-  }
-
-  /**
-   * Inserts or updates an entry in the current buffer.  This invocation may
-   * block if the current buffer is full and there are too many outstanding
-   * write requests.
-   * 
-   * @param key the key
-   * @param value the value
-   * @throws IOException 
-   */
-  void put(byte[] key, byte[] value) throws IOException;
-  
-  /**
-   * Returns the size of the current buffer in bytes.
-   * @return the buffer size
-   */
-  long bufferSize();
-  
-  /**
-   * Returns the size of the unflushed buffers in bytes.
-   * @return the unflushed size
-   */
-  long unflushedSize();
-  
-  /**
-   * Requests that the current buffer be flushed to disk.  This invocation may
-   * block if there are too many outstanding write requests.
-   * 
-   * @param metadata supplemental data to be included in the soplog
-   * @param handler the flush completion callback
-   * @throws IOException error preparing flush
-   */
-  void flush(EnumMap<Metadata, byte[]> metadata, FlushHandler handler) throws IOException;
-
-  /**
-   * Flushes the current buffer and closes the soplog set.  Blocks until the flush
-   * is completed.
-   * 
-   * @param metadata supplemental data to be included in the soplog
-   * @throws IOException error during flush
-   */
-  void flushAndClose(EnumMap<Metadata, byte[]> metadata) throws IOException;
-
-  /**
-   * Returns the configured compaction strategy.
-   * @return the compactor
-   */
-  Compactor getCompactor();
-
-  /**
-   * Clears the current buffer, any existing buffers, and all active soplogs.
-   * 
-   * @throws IOException unable to clear
-   */
-  void clear() throws IOException;
-  
-  /**
-   * Clears existing and closes the soplog set.
-   * @throws IOException unable to destroy
-   */
-  void destroy() throws IOException;
-  
-  /**
-   * Returns true if the set is closed.
-   * @return true if closed
-   */
-  boolean isClosed();
-
-  /**
-   * Returns the soplog factory.
-   * @return the factory
-   */
-  SortedOplogFactory getFactory();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetImpl.java
deleted file mode 100644
index 2cf1191..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/SortedOplogSetImpl.java
+++ /dev/null
@@ -1,780 +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.persistence.soplog;
-
-import java.io.File;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.ArrayDeque;
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Deque;
-import java.util.EnumMap;
-import java.util.List;
-import java.util.Map.Entry;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.Executor;
-import java.util.concurrent.TimeUnit;
-import java.util.concurrent.atomic.AtomicBoolean;
-import java.util.concurrent.atomic.AtomicInteger;
-import java.util.concurrent.atomic.AtomicReference;
-import java.util.concurrent.locks.ReadWriteLock;
-import java.util.concurrent.locks.ReentrantReadWriteLock;
-
-import org.apache.logging.log4j.Logger;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogReader;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog.SortedOplogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.util.AbortableTaskService;
-import com.gemstone.gemfire.internal.util.AbortableTaskService.AbortableTask;
-
-/**
- * Provides a unifies view across a set of sbuffers and soplogs.  Updates are 
- * made into the current sbuffer.  When requested, the current sbuffer will be
- * flushed and subsequent updates will flow into a new sbuffer.  All flushes are
- * done on a background thread.
- * 
- * @author bakera
- */
-public class SortedOplogSetImpl extends AbstractSortedReader implements SortedOplogSet {
-  private static final Logger logger = LogService.getLogger();
-  
-  /** creates new soplogs */
-  private final SortedOplogFactory factory;
-  
-  /** the background flush thread pool */
-  private final AbortableTaskService flusher;
-  
-  /** the compactor */
-  private final Compactor compactor;
-  
-  /** the current sbuffer */
-  private final AtomicReference<SortedBuffer<Integer>> current;
-  
-  /** the buffer count */
-  private final AtomicInteger bufferCount;
-  
-  /** the unflushed sbuffers */
-  private final Deque<SortedBuffer<Integer>> unflushed;
-  
-  /** the lock for access to unflushed and soplogs */
-  private final ReadWriteLock rwlock;
-  
-  /** test hook for clear/close/destroy during flush */
-  volatile CountDownLatch testDelayDuringFlush;
-  
-  /** test hook to cause IOException during flush */
-  volatile boolean testErrorDuringFlush;
-  
-  private final String logPrefix;
-  
-  public SortedOplogSetImpl(final SortedOplogFactory factory, Executor exec, Compactor ctor) throws IOException {
-    this.factory = factory;
-    this.flusher = new AbortableTaskService(exec);
-    this.compactor = ctor;
-    
-    rwlock = new ReentrantReadWriteLock();
-    bufferCount = new AtomicInteger(0);
-    unflushed = new ArrayDeque<SortedBuffer<Integer>>();
-    current = new AtomicReference<SortedBuffer<Integer>>(
-        new SortedBuffer<Integer>(factory.getConfiguration(), 0));
-    
-    this.logPrefix = "<" + factory.getConfiguration().getName() + "> ";
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Creating soplog set", this.logPrefix);
-    }
-  }
-  
-  @Override
-  public boolean mightContain(byte[] key) throws IOException {
-    // loops through the following readers:
-    //   current sbuffer
-    //   unflushed sbuffers
-    //   soplogs
-    //
-    // The loop has been unrolled for efficiency.
-    //
-    if (getCurrent().mightContain(key)) {
-      return true;
-    }
-
-    // snapshot the sbuffers and soplogs for stable iteration
-    List<SortedReader<ByteBuffer>> readers;
-    Collection<TrackedReference<SortedOplogReader>> soplogs;
-    rwlock.readLock().lock();
-    try {
-      readers = new ArrayList<SortedReader<ByteBuffer>>(unflushed);
-      soplogs = compactor.getActiveReaders(key, key);
-      for (TrackedReference<SortedOplogReader> tr : soplogs) {
-        readers.add(tr.get());
-      }
-    } finally {
-      rwlock.readLock().unlock();
-    }
-
-    try {
-      for (SortedReader<ByteBuffer> rdr : readers) {
-        if (rdr.mightContain(key)) {
-          return true;
-        }
-      }
-      return false;
-    } finally {
-      TrackedReference.decrementAll(soplogs);
-    }
-  }
-
-  @Override
-  public ByteBuffer read(byte[] key) throws IOException {
-    // loops through the following readers:
-    //   current sbuffer
-    //   unflushed sbuffers
-    //   soplogs
-    //
-    // The loop has been slightly unrolled for efficiency.
-    //
-    ByteBuffer val = getCurrent().read(key);
-    if (val != null) {
-      return val;
-    }
-
-    // snapshot the sbuffers and soplogs for stable iteration
-    List<SortedReader<ByteBuffer>> readers;
-    Collection<TrackedReference<SortedOplogReader>> soplogs;
-    rwlock.readLock().lock();
-    try {
-      readers = new ArrayList<SortedReader<ByteBuffer>>(unflushed);
-      soplogs = compactor.getActiveReaders(key, key);
-      for (TrackedReference<SortedOplogReader> tr : soplogs) {
-        readers.add(tr.get());
-      }
-    } finally {
-      rwlock.readLock().unlock();
-    }
-    
-    try {
-      for (SortedReader<ByteBuffer> rdr : readers) {
-        if (rdr.mightContain(key)) {
-          val = rdr.read(key);
-          if (val != null) {
-            return val;
-          }
-        }
-      }
-      return null;
-    } finally {
-      TrackedReference.decrementAll(soplogs);
-    }
-  }
-
-  @Override
-  public SortedIterator<ByteBuffer> scan(
-      byte[] from, boolean fromInclusive, 
-      byte[] to, boolean toInclusive,
-      boolean ascending,
-      MetadataFilter filter) throws IOException {
-
-    SerializedComparator sc = factory.getConfiguration().getComparator();
-    sc = ascending ? sc : ReversingSerializedComparator.reverse(sc);
-
-    List<SortedIterator<ByteBuffer>> scans = new ArrayList<SortedIterator<ByteBuffer>>();
-    Collection<TrackedReference<SortedOplogReader>> soplogs;
-    rwlock.readLock().lock();
-    try {
-      scans.add(getCurrent().scan(from, fromInclusive, to, toInclusive, ascending, filter));
-      for (SortedBuffer<Integer> sb : unflushed) {
-        scans.add(sb.scan(from, fromInclusive, to, toInclusive, ascending, filter));
-      }
-      soplogs = compactor.getActiveReaders(from, to);
-    } finally {
-      rwlock.readLock().unlock();
-    }
-
-    for (TrackedReference<SortedOplogReader> tr : soplogs) {
-      scans.add(tr.get().scan(from, fromInclusive, to, toInclusive, ascending, filter));
-    }
-    return new MergedIterator(sc, soplogs, scans);
-  }
-
-  @Override
-  public void put(byte[] key, byte[] value) {
-    assert key != null;
-    assert value != null;
-    
-    long start = factory.getConfiguration().getStatistics().getPut().begin();
-    getCurrent().put(key, value);
-    factory.getConfiguration().getStatistics().getPut().end(value.length, start);
-  }
-
-  @Override
-  public long bufferSize() {
-    return getCurrent().dataSize();
-  }
-
-  @Override
-  public long unflushedSize() {
-    long size = 0;
-    rwlock.readLock().lock();
-    try {
-      for (SortedBuffer<Integer> sb : unflushed) {
-        size += sb.dataSize();
-      }
-    } finally {
-      rwlock.readLock().unlock();
-    }
-    return size;
-  }
-  
-  @Override
-  public void flushAndClose(EnumMap<Metadata, byte[]> metadata) throws IOException {
-    final AtomicReference<Throwable> err = new AtomicReference<Throwable>(null);
-    flush(metadata, new FlushHandler() {
-      @Override public void complete() { }
-      @Override public void error(Throwable t) { err.set(t); }
-    });
-    
-    // waits for flush completion
-    close();
-    
-    Throwable t = err.get();
-    if (t != null) {
-      throw new IOException(t);
-    }
-  }
-  
-  @Override
-  public void flush(EnumMap<Metadata, byte[]> metadata, FlushHandler handler) {
-    assert handler != null;
-    
-    long start = factory.getConfiguration().getStatistics().getFlush().begin();
-    
-    // flip to a new buffer
-    final SortedBuffer<Integer> sb;
-    rwlock.writeLock().lock();
-    try {
-      if (isClosed()) {
-        handler.complete();
-        factory.getConfiguration().getStatistics().getFlush().end(0, start);
-        
-        return;
-      }
-      
-      sb = flipBuffer();
-      if (sb.count() == 0) {
-        if (logger.isDebugEnabled()) {
-          logger.debug("{}Skipping flush of empty buffer {}", this.logPrefix, sb);
-        }
-        handler.complete();
-        return;
-      }
-      
-      sb.setMetadata(metadata);
-      unflushed.addFirst(sb);
-    
-      // Note: this is queued while holding the lock to ensure correct ordering
-      // on the executor queue.  Don't use a bounded queue here or we will block
-      // the flush invoker.
-      flusher.execute(new FlushTask(handler, sb, start));
-      
-    } finally {
-      rwlock.writeLock().unlock();
-    }
-  }
-
-  @Override
-  public void clear() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Clearing soplog set", this.logPrefix);
-    }
-
-    long start = factory.getConfiguration().getStatistics().getClear().begin();
-
-    // acquire lock to ensure consistency with flushes
-    rwlock.writeLock().lock();
-    try {
-      SortedBuffer<Integer> tmp = current.get();
-      if (tmp != null) {
-        tmp.clear();
-      }
-
-      flusher.abortAll();
-      for (SortedBuffer<Integer> sb : unflushed) {
-        sb.clear();
-      }
-      
-      unflushed.clear();
-      compactor.clear();
-
-      releaseTestDelay();
-      flusher.waitForCompletion();
-      factory.getConfiguration().getStatistics().getClear().end(start);
-      
-    } catch (IOException e) {
-      factory.getConfiguration().getStatistics().getClear().error(start);
-      throw (IOException) e.fillInStackTrace();
-      
-    } finally {
-      rwlock.writeLock().unlock();
-    }
-  }
-  
-  @Override
-  public void destroy() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Destroying soplog set", this.logPrefix);
-    }
-
-    long start = factory.getConfiguration().getStatistics().getDestroy().begin();
-    try {
-      unsetCurrent();
-      clear();
-      close();
-      
-      factory.getConfiguration().getStatistics().getDestroy().end(start);
-      
-    } catch (IOException e) {
-      factory.getConfiguration().getStatistics().getDestroy().error(start);
-      throw (IOException) e.fillInStackTrace();
-    }
-  }
-  
-  @Override
-  public void close() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Closing soplog set", this.logPrefix);
-    }
-
-    unsetCurrent();
-    releaseTestDelay();
-
-    flusher.waitForCompletion();
-    compactor.close();
-  }
-
-  @Override
-  public SerializedComparator getComparator() {
-    return factory.getConfiguration().getComparator();
-  }
-
-  @Override
-  public SortedStatistics getStatistics() throws IOException {
-    List<SortedStatistics> stats = new ArrayList<SortedStatistics>();
-    Collection<TrackedReference<SortedOplogReader>> soplogs;
-    
-    // snapshot, this is expensive
-    rwlock.readLock().lock();
-    try {
-      stats.add(getCurrent().getStatistics());
-      for (SortedBuffer<Integer> sb : unflushed) {
-        stats.add(sb.getStatistics());
-      }
-      soplogs = compactor.getActiveReaders(null, null);
-    } finally {
-      rwlock.readLock().unlock();
-    }
-    
-    for (TrackedReference<SortedOplogReader> tr : soplogs) {
-      stats.add(tr.get().getStatistics());
-    }
-    return new MergedStatistics(stats, soplogs);
-  }
-
-  @Override
-  public Compactor getCompactor() {
-    return compactor;
-  }
-  
-  @Override
-  public boolean isClosed() {
-    return current.get() == null;
-  }
-  
-  @Override
-  public SortedOplogFactory getFactory() {
-    return factory;
-  }
-  
-  private SortedBuffer<Integer> flipBuffer() {
-    final SortedBuffer<Integer> sb;
-    sb = getCurrent();
-    SortedBuffer<Integer> next = new SortedBuffer<Integer>(
-        factory.getConfiguration(), 
-        bufferCount.incrementAndGet());
-  
-    current.set(next);
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Switching from buffer {} to {}", this.logPrefix, sb, next);
-    }
-    return sb;
-  }
-
-  private SortedBuffer<Integer> getCurrent() {
-    SortedBuffer<Integer> tmp = current.get();
-    if (tmp == null) {
-      throw new IllegalStateException("Closed");
-    }
-    return tmp;
-  }
-  
-  private void unsetCurrent() {
-    rwlock.writeLock().lock();
-    try {
-      SortedBuffer<Integer> tmp = current.getAndSet(null);
-      if (tmp != null) {
-        tmp.clear();
-      }
-    } finally {
-      rwlock.writeLock().unlock();
-    }
-  }
-  
-  private void releaseTestDelay() {
-    if (testDelayDuringFlush != null) {
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Releasing testDelayDuringFlush", this.logPrefix);
-      }
-      testDelayDuringFlush.countDown();
-    }
-  }
-
-  private class FlushTask implements AbortableTask {
-    private final FlushHandler handler;
-    private final SortedBuffer<Integer> buffer;
-    private final long start;
-    
-    public FlushTask(FlushHandler handler, SortedBuffer<Integer> buffer, long start) {
-      this.handler = handler;
-      this.buffer = buffer;
-      this.start = start;
-    }
-    
-    @Override
-    public void runOrAbort(final AtomicBoolean aborted) {
-      try {
-        // First transfer the contents of the buffer to a new soplog.
-        final SortedOplog soplog = writeBuffer(buffer, aborted);
-        
-        // If we are aborted, someone else will cleanup the unflushed queue
-        if (soplog == null || !lockOrAbort(aborted)) {
-          handler.complete();
-          return;
-        }
-
-        try {
-          Runnable action = new Runnable() {
-            @Override
-            public void run() {
-              try {
-                compactor.add(soplog);
-                compactor.compact(false, null);
-
-                unflushed.removeFirstOccurrence(buffer);
-                
-                // TODO need to invoke this while NOT holding write lock
-                handler.complete();
-                factory.getConfiguration().getStatistics().getFlush().end(buffer.dataSize(), start);
-                
-              } catch (Exception e) {
-                handleError(e, aborted);
-                return;
-              }
-            }
-          };
-          
-          // Enforce flush ordering for consistency.  If the previous buffer flush
-          // is incomplete, we defer completion and release the thread to avoid
-          // deadlocks.
-          if (buffer == unflushed.peekLast()) {
-            action.run();
-            
-            SortedBuffer<Integer> tail = unflushed.peekLast();
-            while (tail != null && tail.isDeferred() && !aborted.get()) {
-              // TODO need to invoke this while NOT holding write lock
-              tail.complete();
-              tail = unflushed.peekLast();
-            }
-          } else {
-            buffer.defer(action);
-          }
-        } finally {
-          rwlock.writeLock().unlock();
-        }
-      } catch (Exception e) {
-        handleError(e, aborted);
-      }
-    }
-    
-    @Override
-    public void abortBeforeRun() {
-      handler.complete();
-      factory.getConfiguration().getStatistics().getFlush().end(start);
-    }
-    
-    private void handleError(Exception e, AtomicBoolean aborted) {
-      if (lockOrAbort(aborted)) {
-        try {
-          unflushed.removeFirstOccurrence(buffer);
-        } finally {
-          rwlock.writeLock().unlock();
-        }
-      }  
-
-      handler.error(e);
-      factory.getConfiguration().getStatistics().getFlush().error(start);
-    }
-    
-    private SortedOplog writeBuffer(SortedBuffer<Integer> sb, AtomicBoolean aborted) 
-        throws IOException {
-      File f = compactor.getFileset().getNextFilename();
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Flushing buffer {} to {}", SortedOplogSetImpl.this.logPrefix, sb, f);
-      }
-
-      SortedOplog so = factory.createSortedOplog(f);
-      SortedOplogWriter writer = so.createWriter();
-      try {
-        if (testErrorDuringFlush) {
-          throw new IOException("Flush error due to testErrorDuringFlush=true");
-        }
-        
-        for (Entry<byte[], byte[]> entry : sb.entries()) {
-          if (aborted.get()) {
-            writer.closeAndDelete();
-            return null;
-          }
-          writer.append(entry.getKey(), entry.getValue());
-        }
-   
-        checkTestDelay();
-        
-        writer.close(buffer.getMetadata());
-        return so;
-   
-      } catch (IOException e) {
-        if (logger.isDebugEnabled()) {
-          logger.debug("{}Encountered error while flushing buffer {}", SortedOplogSetImpl.this.logPrefix, sb, e);
-        }
-        
-        writer.closeAndDelete();
-        throw e;
-      }
-    }
-
-    private void checkTestDelay() {
-      if (testDelayDuringFlush != null) {
-        try {
-          if (logger.isDebugEnabled()) {
-            logger.debug("{}Waiting for testDelayDuringFlush", SortedOplogSetImpl.this.logPrefix);
-          }
-          testDelayDuringFlush.await();
-          
-        } catch (InterruptedException e) {
-          Thread.currentThread().interrupt();
-        }
-      }
-    }
-
-    private boolean lockOrAbort(AtomicBoolean abort) {
-      try {
-        while (!abort.get()) {
-          if (rwlock.writeLock().tryLock(10, TimeUnit.MILLISECONDS)) {
-            return true;
-          }
-        }
-      } catch (InterruptedException e) {
-        Thread.currentThread().interrupt();
-      }
-      return false;
-    }
-  }
-  
-  private class MergedStatistics implements SortedStatistics {
-    private final List<SortedStatistics> stats;
-    private final Collection<TrackedReference<SortedOplogReader>> soplogs;
-
-    public MergedStatistics(List<SortedStatistics> stats, Collection<TrackedReference<SortedOplogReader>> soplogs) {
-      this.stats = stats;
-      this.soplogs = soplogs;
-    }
-    
-    @Override
-    public long keyCount() {
-      // TODO we have no way of determining the overall key population
-      // just assume no overlap for now
-      long keys = 0;
-      for (SortedStatistics ss : stats) {
-        keys += ss.keyCount();
-      }
-      return keys;
-    }
-
-    @Override
-    public byte[] firstKey() {
-      byte[] first = stats.get(0).firstKey();
-      for (int i = 1; i < stats.size(); i++) {
-        byte[] tmp = stats.get(i).firstKey();
-        if (getComparator().compare(first, tmp) > 0) {
-          first = tmp;
-        }
-      }
-      return first;
-    }
-
-    @Override
-    public byte[] lastKey() {
-      byte[] last = stats.get(0).lastKey();
-      for (int i = 1; i < stats.size(); i++) {
-        byte[] tmp = stats.get(i).lastKey();
-        if (getComparator().compare(last, tmp) < 0) {
-          last = tmp;
-        }
-      }
-      return last;
-    }
-
-    @Override
-    public double avgKeySize() {
-      double avg = 0;
-      for (SortedStatistics ss : stats) {
-        avg += ss.avgKeySize();
-      }
-      return avg / stats.size();
-    }
-
-    @Override
-    public double avgValueSize() {
-      double avg = 0;
-      for (SortedStatistics ss : stats) {
-        avg += ss.avgValueSize();
-      }
-      return avg / stats.size();
-    }
-
-    @Override
-    public void close() {
-      TrackedReference.decrementAll(soplogs);
-    }
-  }
-  
-  /**
-   * Provides ordered iteration across a set of sorted data sets. 
-   */
-  public static class MergedIterator 
-    extends AbstractKeyValueIterator<ByteBuffer, ByteBuffer> 
-    implements SortedIterator<ByteBuffer>
-  {
-    /** the comparison operator */
-    private final SerializedComparator comparator;
-    
-    /** the reference counted soplogs */
-    private final Collection<TrackedReference<SortedOplogReader>> soplogs;
-
-    /** the backing iterators */
-    private final List<SortedIterator<ByteBuffer>> iters;
-    
-    /** the current key */
-    private ByteBuffer key;
-    
-    /** the current value */
-    private ByteBuffer value;
-    
-    public MergedIterator(SerializedComparator comparator, 
-        Collection<TrackedReference<SortedOplogReader>> soplogs, 
-        List<SortedIterator<ByteBuffer>> iters) {
-      this.comparator = comparator;
-      this.soplogs = soplogs;
-      this.iters = iters;
-      
-      // initialize iteration positions
-      int i = 0;
-      while (i < iters.size()) {
-        i = advance(i);
-      }
-    }
-    
-    @Override
-    public ByteBuffer key() {
-      return key;
-    }
-
-    @Override
-    public ByteBuffer value() {
-      return value;
-    }
-
-    @Override
-    protected boolean step() {
-      if (iters.isEmpty() || readerIsClosed()) {
-        return false;
-      }
-      
-      int cursor = 0;
-      key = iters.get(cursor).key();
-      
-      int i = 1;
-      while (i < iters.size()) {
-        ByteBuffer tmp = iters.get(i).key();
-        
-        int diff = comparator.compare(tmp.array(), tmp.arrayOffset(), tmp.remaining(), 
-            key.array(), key.arrayOffset(), key.remaining());
-        if (diff < 0) {
-          cursor = i++;
-          key = tmp;
-          
-        } else if (diff == 0) {
-          i = advance(i);
-          
-        } else {
-          i++;
-        }
-      }
-      
-      value = iters.get(cursor).value();
-      advance(cursor);
-      
-      return true;
-    }
-    
-    @Override
-    public void close() {
-      for (SortedIterator<ByteBuffer> iter : iters) {
-        iter.close();
-      }
-      TrackedReference.decrementAll(soplogs);
-    }
-
-    private int advance(int idx) {
-      // either advance the cursor or remove the iterator
-      if (!iters.get(idx).hasNext()) {
-        iters.remove(idx).close();
-        return idx;
-      }
-      iters.get(idx).next();
-      return idx + 1;
-    }
-    
-    private boolean readerIsClosed() {
-      for (TrackedReference<SortedOplogReader> tr : soplogs) {
-        if (tr.get().isClosed()) {
-          return true;
-        }
-      }
-      return false;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/BlockCacheHolder.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/BlockCacheHolder.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/BlockCacheHolder.java
deleted file mode 100644
index eb5154c..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/BlockCacheHolder.java
+++ /dev/null
@@ -1,39 +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.persistence.soplog.hfile;
-
-import org.apache.hadoop.hbase.io.hfile.BlockCache;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.HFileStoreStatistics;
-
-public class BlockCacheHolder {
-  private BlockCache cache;
-  private HFileStoreStatistics stats;
-  
-  public BlockCacheHolder(HFileStoreStatistics stats, BlockCache cache) {
-    this.stats = stats;
-    this.cache = cache;
-  }
-
-  public synchronized BlockCache getBlockCache() {
-    return cache;
-  }
-  
-  public synchronized HFileStoreStatistics getHFileStoreStats() {
-    return stats;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplog.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplog.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplog.java
deleted file mode 100644
index 56c6960..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplog.java
+++ /dev/null
@@ -1,694 +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.persistence.soplog.hfile;
-
-import java.io.ByteArrayInputStream;
-import java.io.DataInput;
-import java.io.DataInputStream;
-import java.io.File;
-import java.io.IOException;
-import java.nio.ByteBuffer;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.EnumMap;
-import java.util.Map.Entry;
-import java.util.NoSuchElementException;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.fs.FileStatus;
-import org.apache.hadoop.fs.FileSystem;
-import org.apache.hadoop.fs.Path;
-
-import com.gemstone.gemfire.cache.hdfs.HDFSIOException;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.AbstractSortedReader;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.DelegatingSerializedComparator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.ReversingSerializedComparator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedBuffer.BufferIterator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.Metadata;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SerializedComparator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedIterator;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedReader.SortedStatistics;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.util.Bytes;
-import com.gemstone.gemfire.internal.util.Hex;
-import org.apache.hadoop.hbase.io.hfile.CacheConfig;
-import org.apache.hadoop.hbase.io.hfile.HFile;
-import org.apache.hadoop.hbase.io.hfile.HFile.Reader;
-import org.apache.hadoop.hbase.io.hfile.HFile.Writer;
-import org.apache.hadoop.hbase.io.hfile.HFileScanner;
-import org.apache.hadoop.hbase.regionserver.StoreFile.BloomType;
-import org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics;
-import org.apache.hadoop.hbase.util.BloomFilterFactory;
-import org.apache.hadoop.hbase.util.BloomFilterWriter;
-import org.apache.hadoop.hbase.util.FSUtils;
-import org.apache.logging.log4j.Logger;
-import com.gemstone.gemfire.internal.logging.LogService;
-
-/**
- * Provides a soplog backed by an HFile.
- * 
- * @author bakera
- */
-public class HFileSortedOplog implements SortedOplog {
-  public static final byte[] MAGIC          = new byte[] { 0x53, 0x4F, 0x50 };
-  public static final byte[] VERSION_1      = new byte[] { 0x1 };
-  
-  // FileInfo is not visible
-  private static final byte[] AVG_KEY_LEN   = "hfile.AVG_KEY_LEN".getBytes();
-  private static final byte[] AVG_VALUE_LEN = "hfile.AVG_VALUE_LEN".getBytes();
-  
-  /** a default bloom filter */
-  private static final BloomFilter DUMMY_BLOOM = new BloomFilter() {
-    @Override
-    public boolean mightContain(byte[] key) {
-      return true;
-    }
-  };
-
-  static final Configuration hconf;
-  private static final FileSystem fs;
-
-  static {
-    // Leave these HBase properties set to defaults for now
-    //
-    // hfile.block.cache.size (25% of heap)
-    // hbase.hash.type (murmur)
-    // hfile.block.index.cacheonwrite (false)
-    // hfile.index.block.max.size (128k)
-    // hfile.format.version (2)
-    // io.storefile.bloom.block.size (128k)
-    // hfile.block.bloom.cacheonwrite (false)
-    // hbase.rs.cacheblocksonwrite (false)
-    // hbase.offheapcache.minblocksize (64k)
-    // hbase.offheapcache.percentage (0)
-    hconf = new Configuration();
-
-    hconf.setBoolean("hbase.metrics.showTableName", true);
-    SchemaMetrics.configureGlobally(hconf);
-
-    try {
-      fs = FileSystem.get(hconf);
-    } catch (IOException e) {
-      throw new IllegalStateException(e);
-    }
-  }
-
-  private static enum InternalMetadata {
-    /** identifies the soplog as a gemfire file, required */
-    GEMFIRE_MAGIC,
-    
-    /** identifies the soplog version, required */
-    VERSION,
-    
-    /** identifies the statistics data */
-    STATISTICS,
-
-    /** identifies the names of embedded comparators */
-    COMPARATORS;
-
-    public byte[] bytes() {
-      return ("gemfire." + name()).getBytes();
-    }
-  }
-  
-  //logger instance
-  private static final Logger logger = LogService.getLogger();
-  protected final String logPrefix;
-  
-  /** the configuration */
-  private final SortedOplogConfiguration sopConfig;
-  
-  /** the hfile cache config */
-  private final CacheConfig hcache;
-  
-  /** the hfile location */
-  private Path path;
-  
-  public HFileSortedOplog(File hfile, SortedOplogConfiguration sopConfig) throws IOException {
-    assert hfile != null;
-    assert sopConfig != null;
-    
-    this.sopConfig = sopConfig;
-    path = fs.makeQualified(new Path(hfile.toString()));
-    
-//    hcache = new CacheConfig(hconf, sopConfig.getCacheDataBlocksOnRead(), sopConfig.getBlockCache(), 
-//        HFileSortedOplogFactory.convertStatistics(sopConfig.getStatistics(), sopConfig.getStoreStatistics()));
-    hcache = new CacheConfig(hconf);
-    this.logPrefix = "<" + sopConfig.getName() + "> ";
-  }
-
-  @Override
-  public SortedOplogReader createReader() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Creating an HFile reader on " + path, logPrefix);
-    }
-    
-    return new HFileSortedOplogReader();
-  }
-
-  @Override
-  public SortedOplogWriter createWriter() throws IOException {
-    if (logger.isDebugEnabled()) {
-      logger.debug("{}Creating an HFile writer on " + path, logPrefix);
-    }
-
-    return new HFileSortedOplogWriter();  
-  }
-  
-  SortedOplogConfiguration getConfiguration() {
-    return sopConfig;
-  }
-  
-  private class HFileSortedOplogReader extends AbstractSortedReader implements SortedOplogReader {
-    private final Reader reader;
-    private final BloomFilter bloom;
-    private final SortedStatistics stats;
-    private volatile boolean closed;
-    
-    public HFileSortedOplogReader() throws IOException {
-      reader = HFile.createReader(fs, path, hcache);
-      validate();
-      
-      stats = new HFileSortedStatistics(reader);
-      closed = false;
-      
-      if (reader.getComparator() instanceof DelegatingSerializedComparator) {
-        loadComparators((DelegatingSerializedComparator) reader.getComparator());
-      }
-
-      DataInput bin = reader.getGeneralBloomFilterMetadata();
-      if (bin != null) {
-        final org.apache.hadoop.hbase.util.BloomFilter hbloom = BloomFilterFactory.createFromMeta(bin, reader);
-        if (reader.getComparator() instanceof DelegatingSerializedComparator) {
-          loadComparators((DelegatingSerializedComparator) hbloom.getComparator());
-        }
-
-        bloom = new BloomFilter() {
-          @Override
-          public boolean mightContain(byte[] key) {
-            assert key != null;
-            
-            long start = sopConfig.getStatistics().getBloom().begin();
-            boolean foundKey = hbloom.contains(key, 0, key.length, null);
-            sopConfig.getStatistics().getBloom().end(start);
-            
-            if (logger.isTraceEnabled()) {
-              logger.trace(String.format("{}Bloom check on %s for key %s: %b", 
-                  path, Hex.toHex(key), foundKey), logPrefix);
-            }
-            return foundKey;
-          }
-        };
-        
-      } else {
-        bloom = DUMMY_BLOOM;
-      }
-    }
-    
-    @Override
-    public boolean mightContain(byte[] key) {
-      return getBloomFilter().mightContain(key);
-    }
-
-    @Override
-    public ByteBuffer read(byte[] key) throws IOException {
-      assert key != null;
-      
-      if (logger.isTraceEnabled()) {
-        logger.trace(String.format("{}Reading key %s from %s", Hex.toHex(key), path), logPrefix);
-      }
-
-      long start = sopConfig.getStatistics().getRead().begin();
-      try {
-        HFileScanner seek = reader.getScanner(true, true);
-        if (seek.seekTo(key) == 0) {
-          ByteBuffer val = seek.getValue();
-          sopConfig.getStatistics().getRead().end(val.remaining(), start);
-          
-          return val;
-        }
-        
-        sopConfig.getStatistics().getRead().end(start);
-        sopConfig.getStatistics().getBloom().falsePositive();
-        return null;
-        
-      } catch (IOException e) {
-        sopConfig.getStatistics().getRead().error(start);
-        throw (IOException) e.fillInStackTrace();
-      }
-    }
-
-    @Override
-    public SortedIterator<ByteBuffer> scan(
-        byte[] from, boolean fromInclusive, 
-        byte[] to, boolean toInclusive,
-        boolean ascending,
-        MetadataFilter filter) throws IOException {
-      if (filter == null || filter.accept(getMetadata(filter.getName()))) {
-        SerializedComparator tmp = (SerializedComparator) reader.getComparator();
-        tmp = ascending ? tmp : ReversingSerializedComparator.reverse(tmp); 
-  
-//        HFileScanner scan = reader.getScanner(true, false, ascending, false);
-        HFileScanner scan = reader.getScanner(true, false, false);
-        return new HFileSortedIterator(scan, tmp, from, fromInclusive, to, toInclusive);
-      }
-      return new BufferIterator(Collections.<byte[], byte[]>emptyMap().entrySet().iterator());
-    }
-
-    @Override
-    public SerializedComparator getComparator() {
-      return (SerializedComparator) reader.getComparator();
-    }
-
-    @Override
-    public SortedStatistics getStatistics() {
-      return stats;
-    }
-
-    @Override
-    public boolean isClosed() {
-      return closed;
-    }
-    
-    @Override
-    public void close() throws IOException {
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Closing reader on " + path, logPrefix);
-      }
-      reader.close();
-      closed = true;
-    }
-
-    @Override
-    public BloomFilter getBloomFilter() {
-      return bloom;
-    }
-
-    @Override
-    public byte[] getMetadata(Metadata name) throws IOException {
-      assert name != null;
-      
-      return reader.loadFileInfo().get(name.bytes());
-    }
-    
-    @Override
-    public File getFile() {
-      return new File(path.toUri());
-    }
-    
-    @Override
-    public String getFileName() {
-      return path.getName();
-    }
-   
-    @Override
-    public long getModificationTimeStamp() throws IOException {
-      FileStatus[] stats = FSUtils.listStatus(fs, path, null);
-      if (stats != null && stats.length == 1) {
-        return stats[0].getModificationTime();
-      } else {
-        return 0;
-      }
-    }
-    
-    @Override
-    public void rename(String name) throws IOException {
-      Path parent = path.getParent();
-      Path newPath = new Path(parent, name);
-      fs.rename(path, newPath);
-      // update path to point to the new path
-      path = newPath;
-    }
-    
-    @Override
-    public void delete() throws IOException {
-      fs.delete(path, false);
-    }
-    
-    @Override
-    public String toString() {
-      return path.toString();
-    }
-    
-    private byte[] getMetadata(InternalMetadata name) throws IOException {
-      return reader.loadFileInfo().get(name.bytes());
-    }
-    
-    private void validate() throws IOException {
-      // check magic
-      byte[] magic = getMetadata(InternalMetadata.GEMFIRE_MAGIC);
-      if (!Arrays.equals(magic, MAGIC)) {
-        throw new IOException(LocalizedStrings.Soplog_INVALID_MAGIC.toLocalizedString(Hex.toHex(magic)));
-      }
-      
-      // check version compatibility
-      byte[] ver = getMetadata(InternalMetadata.VERSION);
-      if (logger.isDebugEnabled()) {
-        logger.debug("{}Soplog version is " + Hex.toHex(ver), logPrefix);
-      }
-      
-      if (!Arrays.equals(ver, VERSION_1)) {
-        throw new IOException(LocalizedStrings.Soplog_UNRECOGNIZED_VERSION.toLocalizedString(Hex.toHex(ver)));
-      }
-    }
-    
-    private void loadComparators(DelegatingSerializedComparator comparator) throws IOException {
-      byte[] raw = reader.loadFileInfo().get(InternalMetadata.COMPARATORS.bytes());
-      assert raw != null;
-
-      DataInput in = new DataInputStream(new ByteArrayInputStream(raw));
-      comparator.setComparators(readComparators(in));
-    }
-    
-    private SerializedComparator[] readComparators(DataInput in) throws IOException {
-      try {
-        SerializedComparator[] comps = new SerializedComparator[in.readInt()];
-        assert comps.length > 0;
-        
-        for (int i = 0; i < comps.length; i++) {
-          comps[i] = (SerializedComparator) Class.forName(in.readUTF()).newInstance();
-          if (comps[i] instanceof DelegatingSerializedComparator) {
-            ((DelegatingSerializedComparator) comps[i]).setComparators(readComparators(in));
-          }
-        }
-        return comps;
-        
-      } catch (Exception e) {
-        throw new IOException(e);
-      }
-    }
-  }
-  
-  private class HFileSortedOplogWriter implements SortedOplogWriter {
-    private final Writer writer;
-    private final BloomFilterWriter bfw;
-    
-    public HFileSortedOplogWriter() throws IOException {
-      writer = HFile.getWriterFactory(hconf, hcache)
-          .withPath(fs, path)
-          .withBlockSize(sopConfig.getBlockSize())
-          .withBytesPerChecksum(sopConfig.getBytesPerChecksum())
-          .withChecksumType(HFileSortedOplogFactory.convertChecksum(sopConfig.getChecksum()))
-//          .withComparator(sopConfig.getComparator())
-          .withCompression(HFileSortedOplogFactory.convertCompression(sopConfig.getCompression()))
-          .withDataBlockEncoder(HFileSortedOplogFactory.convertEncoding(sopConfig.getKeyEncoding()))
-          .create();
-      
-      bfw = sopConfig.isBloomFilterEnabled() ?
-//          BloomFilterFactory.createGeneralBloomAtWrite(hconf, hcache, BloomType.ROW, 
-//              0, writer, sopConfig.getComparator())
-          BloomFilterFactory.createGeneralBloomAtWrite(hconf, hcache, BloomType.ROW, 
-              0, writer)
-          : null;
-    }
-    
-    @Override
-    public void append(byte[] key, byte[] value) throws IOException {
-      assert key != null;
-      assert value != null;
-
-      if (logger.isTraceEnabled()) {
-        logger.trace(String.format("{}Appending key %s to %s", Hex.toHex(key), path), logPrefix);
-      }
-
-      try {
-        writer.append(key, value);
-        if (bfw != null) {
-          bfw.add(key, 0, key.length);
-        }
-      } catch (IOException e) {
-        throw (IOException) e.fillInStackTrace();
-      }
-    }
-
-    @Override
-    public void append(ByteBuffer key, ByteBuffer value) throws IOException {
-      assert key != null;
-      assert value != null;
-
-      if (logger.isTraceEnabled()) {
-        logger.trace(String.format("{}Appending key %s to %s", 
-            Hex.toHex(key.array(), key.arrayOffset(), key.remaining()), path), logPrefix);
-      }
-
-      try {
-        byte[] keyBytes = new byte[key.remaining()];
-        key.duplicate().get(keyBytes);
-        byte[] valueBytes = new byte[value.remaining()];
-        value.duplicate().get(valueBytes);
-        writer.append(keyBytes, valueBytes);
-        if (bfw != null) {
-          bfw.add(key.array(), key.arrayOffset(), key.remaining());
-        }
-      } catch (IOException e) {
-        throw (IOException) e.fillInStackTrace();
-      }
-    }
-    
-    @Override
-    public void close(EnumMap<Metadata, byte[]> metadata) throws IOException {
-      if (logger.isTraceEnabled()) {
-        logger.debug("{}Finalizing and closing writer on " + path, logPrefix);
-      }
-
-      if (bfw != null) {
-        bfw.compactBloom();
-        writer.addGeneralBloomFilter(bfw);
-      }
-      
-      // append system metadata
-      writer.appendFileInfo(InternalMetadata.GEMFIRE_MAGIC.bytes(), MAGIC);
-      writer.appendFileInfo(InternalMetadata.VERSION.bytes(), VERSION_1);
-      
-      // append comparator info
-//      if (writer.getComparator() instanceof DelegatingSerializedComparator) {
-//        ByteArrayOutputStream bos = new ByteArrayOutputStream();
-//        DataOutput out = new DataOutputStream(bos);
-//        
-//        writeComparatorInfo(out, ((DelegatingSerializedComparator) writer.getComparator()).getComparators());
-//        writer.appendFileInfo(InternalMetadata.COMPARATORS.bytes(), bos.toByteArray());
-//      }
-      
-      // TODO write statistics data to soplog
-      // writer.appendFileInfo(Meta.STATISTICS.toBytes(), null);
-
-      // append user metadata
-      if (metadata != null) {
-        for (Entry<Metadata, byte[]> entry : metadata.entrySet()) {
-          writer.appendFileInfo(entry.getKey().name().getBytes(), entry.getValue());
-        }
-      }
-      
-      writer.close();
-    }
-    
-    @Override
-    public void closeAndDelete() throws IOException {
-      if (logger.isTraceEnabled()) {
-        logger.debug("{}Closing writer and deleting " + path, logPrefix);
-      }
-
-      writer.close();
-      new File(writer.getPath().toUri()).delete();
-    }
-    
-//    private void writeComparatorInfo(DataOutput out, SerializedComparator[] comparators) throws IOException {
-//      out.writeInt(comparators.length);
-//      for (SerializedComparator sc : comparators) {
-//        out.writeUTF(sc.getClass().getName());
-//        if (sc instanceof DelegatingSerializedComparator) {
-//          writeComparatorInfo(out, ((DelegatingSerializedComparator) sc).getComparators());
-//        }
-//      }
-//    }
-  }
-  
-  private class HFileSortedIterator implements SortedIterator<ByteBuffer> {
-    private final HFileScanner scan;
-    private final SerializedComparator comparator;
-    
-    private final byte[] from;
-    private final boolean fromInclusive;
-
-    private final byte[] to;
-    private final boolean toInclusive;
-    
-    private final long start;
-    private long bytes;
-    
-    private boolean foundNext;
-    
-    private ByteBuffer key;
-    private ByteBuffer value;
-    
-    public HFileSortedIterator(HFileScanner scan, SerializedComparator comparator, 
-        byte[] from, boolean fromInclusive, 
-        byte[] to, boolean toInclusive) throws IOException {
-      this.scan = scan;
-      this.comparator = comparator;
-      this.from = from;
-      this.fromInclusive = fromInclusive;
-      this.to = to;
-      this.toInclusive = toInclusive;
-      
-      assert from == null 
-          || to == null 
-          || comparator.compare(from, 0, from.length, to, 0, to.length) <= 0;
-      
-      start = sopConfig.getStatistics().getScan().begin();
-      foundNext = evalFrom();
-    }
-    
-    @Override
-    public ByteBuffer key() {
-      return key;
-    }
-    
-    @Override 
-    public ByteBuffer value() {
-      return value;
-    }
-
-    @Override
-    public boolean hasNext() {
-      if (!foundNext) {
-        foundNext = step();
-      }
-      return foundNext;
-    }
-    
-    @Override
-    public ByteBuffer next() {
-      long startNext = sopConfig.getStatistics().getScan().beginIteration();
-      
-      if (!hasNext()) {
-        throw new NoSuchElementException();
-      }
-      
-      foundNext = false;
-      key = scan.getKey();
-      value = scan.getValue();
-      
-      int len = key.remaining() + value.remaining(); 
-      bytes += len;
-      sopConfig.getStatistics().getScan().endIteration(len, startNext);
-      
-      return key;
-    }
-    
-    @Override
-    public void remove() {
-      throw new UnsupportedOperationException();
-    }
-
-    @Override
-    public void close() {
-      sopConfig.getStatistics().getScan().end(bytes, start);
-    }
-
-    private boolean step() {
-      try {
-        if (!scan.isSeeked()) {
-          return false;
-          
-        } else  if (scan.next() && evalTo()) {
-          return true;
-        }
-      } catch (IOException e) {
-        throw new HDFSIOException("Error from HDFS during iteration", e);
-      }
-      return false;
-    }
-    
-    private boolean evalFrom() throws IOException {
-      if (from == null) {
-        return scan.seekTo() && evalTo();
-        
-      } else {
-        int compare = scan.seekTo(from);
-        if (compare < 0) {
-          return scan.seekTo() && evalTo();
-          
-        } else if (compare == 0 && fromInclusive) {
-          return true;
-          
-        } else {
-          return step();
-        }
-      }
-    }
-    
-    private boolean evalTo() throws IOException {
-      int compare = -1;
-      if (to != null) {
-        ByteBuffer key = scan.getKey();
-        compare = comparator.compare(
-            key.array(), key.arrayOffset(), key.remaining(), 
-            to, 0, to.length);
-      }
-
-      return compare < 0 || (compare == 0 && toInclusive);
-    }
-  }
-  
-  private static class HFileSortedStatistics implements SortedStatistics {
-    private final Reader reader;
-    private final int keySize;
-    private final int valueSize;
-    
-    public HFileSortedStatistics(Reader reader) throws IOException {
-      this.reader = reader;
-
-      byte[] sz = reader.loadFileInfo().get(AVG_KEY_LEN);
-      keySize = Bytes.toInt(sz[0], sz[1], sz[2], sz[3]);
-
-      sz = reader.loadFileInfo().get(AVG_VALUE_LEN);
-      valueSize = Bytes.toInt(sz[0], sz[1], sz[2], sz[3]);
-    }
-
-    @Override
-    public long keyCount() {
-      return reader.getEntries();
-    }
-
-    @Override
-    public byte[] firstKey() {
-      return reader.getFirstKey();
-    }
-
-    @Override
-    public byte[] lastKey() {
-      return reader.getLastKey();
-    }
-
-    @Override
-    public double avgKeySize() {
-      return keySize;
-    }
-    
-    @Override
-    public double avgValueSize() {
-      return valueSize;
-    }
-    
-    @Override
-    public void close() {
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/9438c8b1/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplogFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplogFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplogFactory.java
deleted file mode 100644
index 9546fd3..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/soplog/hfile/HFileSortedOplogFactory.java
+++ /dev/null
@@ -1,80 +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.persistence.soplog.hfile;
-
-import java.io.File;
-import java.io.IOException;
-
-import org.apache.hadoop.hbase.io.hfile.BlockCache;
-import org.apache.hadoop.hbase.io.hfile.Compression.Algorithm;
-import org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder;
-import org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder;
-import org.apache.hadoop.hbase.util.ChecksumType;
-
-import com.gemstone.gemfire.internal.cache.persistence.soplog.HFileStoreStatistics;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplog;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration.Checksum;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration.Compression;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogFactory.SortedOplogConfiguration.KeyEncoding;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogStatistics;
-
-/**
- * Creates HFile soplogs.
- * 
- * @author bakera
- */
-public class HFileSortedOplogFactory implements SortedOplogFactory {
-  private final SortedOplogConfiguration config;
-  
-  public HFileSortedOplogFactory(String name, BlockCache blockCache, SortedOplogStatistics stats, HFileStoreStatistics storeStats) {
-    config = new SortedOplogConfiguration(name, blockCache, stats, storeStats);
-  }
-  
-  @Override
-  public SortedOplogConfiguration getConfiguration() {
-    return config;
-  }
-
-  @Override
-  public SortedOplog createSortedOplog(File name) throws IOException {
-    return new HFileSortedOplog(name, config);
-  }
-  
-  public static ChecksumType convertChecksum(Checksum type) {
-    switch (type) {
-    case NONE:  return ChecksumType.NULL;
-    
-    default:
-    case CRC32: return ChecksumType.CRC32;
-    }
-  }
-
-  public static Algorithm convertCompression(Compression type) {
-    switch (type) {
-    default:
-    case NONE: return Algorithm.NONE;
-    }
-  }
-  
-  public static HFileDataBlockEncoder convertEncoding(KeyEncoding type) {
-    switch (type) {
-    default:
-    case NONE: return NoOpDataBlockEncoder.INSTANCE;
-    }
-  }
-}


[08/50] [abbrv] incubator-geode git commit: Merge commit 'refs/pull/26/head' of https://github.com/apache/incubator-geode into develop

Posted by bs...@apache.org.
Merge commit 'refs/pull/26/head' of https://github.com/apache/incubator-geode into develop

Merging pull request 26. This closes #26.


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

Branch: refs/heads/feature/GEODE-77
Commit: c67a08fcd4bb8fafb2f7ba7d28f564d140be6992
Parents: b2b2de8 59de555
Author: Dan Smith <up...@apache.org>
Authored: Thu Nov 5 16:21:51 2015 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Thu Nov 5 16:23:50 2015 -0800

----------------------------------------------------------------------
 .../cache/client/internal/pooling/ConnectionManagerImpl.java    | 5 +++++
 1 file changed, 5 insertions(+)
----------------------------------------------------------------------



[20/50] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-11

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


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

Branch: refs/heads/feature/GEODE-77
Commit: afa0a6e9c1d45ea0d5c19b01b3ab3380706fdd5b
Parents: f189ff5 cfbeaf2
Author: Ashvin Agrawal <as...@apache.org>
Authored: Sun Nov 8 20:17:30 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Sun Nov 8 20:17:30 2015 -0800

----------------------------------------------------------------------
 .../management/MemoryThresholdsDUnitTest.java   | 34 +++++++++++++++++++-
 .../internal/ProductUseLogDUnitTest.java        |  3 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |  2 +-
 .../gemfire/internal/JSSESocketJUnitTest.java   |  2 +-
 .../control/TestMemoryThresholdListener.java    | 13 ++++++++
 .../internal/i18n/BasicI18nJUnitTest.java       | 12 -------
 .../src/main/java/org/json/JSONObject.java      |  2 ++
 7 files changed, 52 insertions(+), 16 deletions(-)
----------------------------------------------------------------------



[06/50] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-409

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


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

Branch: refs/heads/feature/GEODE-77
Commit: eced0c5b1ad2fc4c64242bba459b1ec7b2ada714
Parents: 066c11e af3199e
Author: Ashvin Agrawal <as...@apache.org>
Authored: Thu Nov 5 14:29:10 2015 -0800
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Thu Nov 5 14:29:10 2015 -0800

----------------------------------------------------------------------
 gemfire-assembly/build.gradle                   |   8 +-
 gemfire-common/build.gradle                     |   3 +
 .../gemfire/annotations/Experimental.java       |  40 ++++
 .../annotations/ExperimentalJUnitTest.java      | 183 +++++++++++++++++++
 .../ClassInExperimentalPackage.java             |  11 ++
 .../experimentalpackage/package-info.java       |  11 ++
 .../ClassInNonExperimentalPackage.java          |  11 ++
 .../nonexperimentalpackage/package-info.java    |   8 +
 gemfire-core/build.gradle                       |   1 +
 .../asyncqueue/AsyncEventQueueFactory.java      |   2 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |  12 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |  24 ++-
 gemfire-rebalancer/build.gradle                 |   1 +
 gemfire-spark-connector/doc/1_building.md       |   2 +
 gemfire-web/build.gradle                        |  18 +-
 settings.gradle                                 |   1 +
 16 files changed, 322 insertions(+), 14 deletions(-)
----------------------------------------------------------------------



[27/50] [abbrv] incubator-geode git commit: GEODE-416: Fixed synchronization issue when receiving notifications

Posted by bs...@apache.org.
GEODE-416: Fixed synchronization issue when receiving notifications


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

Branch: refs/heads/feature/GEODE-77
Commit: b313362961809758a27c3c402adc64543610e5ee
Parents: e96c960
Author: Jens Deppe <jd...@pivotal.io>
Authored: Tue Nov 10 06:43:09 2015 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Tue Nov 10 06:43:09 2015 -0800

----------------------------------------------------------------------
 .../gemfire/management/DistributedSystemDUnitTest.java  | 12 ++++--------
 1 file changed, 4 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b3133629/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
index 3cf3a6e..193dd12 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
@@ -17,6 +17,7 @@
 package com.gemstone.gemfire.management;
 
 import java.util.ArrayList;
+import java.util.Collections;
 import java.util.HashMap;
 import java.util.Iterator;
 import java.util.List;
@@ -94,7 +95,7 @@ public class DistributedSystemDUnitTest extends ManagementTestBase {
   
   private static MBeanServer mbeanServer = MBeanJMXAdapter.mbeanServer;
   
-  static List<Notification> notifList = new ArrayList<Notification>();
+  static List<Notification> notifList = new ArrayList<>();
   
   static Map<ObjectName , NotificationListener> notificationListenerMap = new HashMap<ObjectName , NotificationListener>();
   
@@ -154,8 +155,8 @@ public class DistributedSystemDUnitTest extends ManagementTestBase {
       createCache(vm);
       warnLevelAlert(vm);
       severeLevelAlert(vm);
-      
     }
+
     VM managingNode = getManagingNode();
     createManagementCache(managingNode);
     startManagingNode(managingNode);
@@ -266,9 +267,8 @@ public class DistributedSystemDUnitTest extends ManagementTestBase {
 
     class NotificationHubTestListener implements NotificationListener {
       @Override
-      public void handleNotification(Notification notification, Object handback) {
+      public synchronized void handleNotification(Notification notification, Object handback) {
         notifList.add(notification);
-
       }
     }
 
@@ -291,9 +291,7 @@ public class DistributedSystemDUnitTest extends ManagementTestBase {
                 } else {
                   return false;
                 }
-
               }
-
             }, MAX_WAIT, 500, true);
             for (ObjectName objectName : bean.listMemberObjectNames()) {
               NotificationHubTestListener listener = new NotificationHubTestListener();
@@ -369,9 +367,7 @@ public class DistributedSystemDUnitTest extends ManagementTestBase {
             } else {
               return false;
             }
-
           }
-
         }, MAX_WAIT, 500, true);
 
         notifList.clear();


[48/50] [abbrv] incubator-geode git commit: Revert "GEODE-543: upgrade the Jline and Spring Shell libraries and fix the compilation erros"

Posted by bs...@apache.org.
Revert "GEODE-543: upgrade the Jline and Spring Shell libraries and fix the compilation erros"

This reverts commit 058aad3663cb00de3ac83f76b9c9b72a32952ca3.


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

Branch: refs/heads/feature/GEODE-77
Commit: e8ddd3398d90818f552dcec00eff29d01bc93795
Parents: 058aad3
Author: Jens Deppe <jd...@pivotal.io>
Authored: Mon Nov 16 16:07:39 2015 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Mon Nov 16 16:07:39 2015 -0800

----------------------------------------------------------------------
 gemfire-core/build.gradle                       |   2 +-
 .../management/internal/cli/CliUtil.java        |   2 +-
 .../management/internal/cli/Launcher.java       |   4 +-
 .../internal/cli/commands/ShellCommands.java    |   4 +-
 .../management/internal/cli/shell/Gfsh.java     |  15 +-
 .../internal/cli/shell/jline/ANSIBuffer.java    | 433 -------------------
 .../internal/cli/shell/jline/ANSIHandler.java   |   5 +-
 .../cli/shell/jline/CygwinMinttyTerminal.java   | 137 +++++-
 .../internal/cli/shell/jline/GfshHistory.java   |  13 +-
 .../shell/jline/GfshUnsupportedTerminal.java    |   2 +-
 .../internal/cli/util/CLIConsoleBufferUtil.java |   8 +-
 .../PersistentPartitionedRegionTestBase.java    |   2 +-
 gradle/dependency-versions.properties           |   4 +-
 13 files changed, 163 insertions(+), 468 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-core/build.gradle b/gemfire-core/build.gradle
index aa83bb9..f03066f 100755
--- a/gemfire-core/build.gradle
+++ b/gemfire-core/build.gradle
@@ -35,7 +35,7 @@ dependencies {
   compile 'mx4j:mx4j-remote:' + project.'mx4j.version'
   compile 'mx4j:mx4j-tools:' + project.'mx4j.version'
   compile 'net.java.dev.jna:jna:' + project.'jna.version'
-  compile 'jline:jline:' + project.'jline.version'
+  compile 'net.sourceforge.jline:jline:' + project.'jline.version'
   provided 'org.apache.hadoop:hadoop-common:' + project.'hadoop.version'
   provided 'org.apache.hadoop:hadoop-annotations:' + project.'hadoop.version'
   provided 'org.apache.hadoop:hadoop-hdfs:' + project.'hadoop.version'

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
index 09f8bd8..bc1f7b7 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/CliUtil.java
@@ -105,7 +105,7 @@ public class CliUtil {
 
     if (includeGfshDependencies) {
       // ConsoleReader from jline
-      jarProductName = checkLibraryByLoadingClass("jline.console.ConsoleReader", "JLine");
+      jarProductName = checkLibraryByLoadingClass("jline.ConsoleReader", "JLine");
       if (jarProductName != null) {
         return jarProductName;
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
index 12e2c50..8bf1ce1 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/Launcher.java
@@ -166,7 +166,7 @@ public final class Launcher {
           System.err.println(CliStrings.format(MSG_INVALID_COMMAND_OR_OPTION, CliUtil.arrayToString(args)));
           exitRequest = ExitShellRequest.FATAL_EXIT;
         } else {
-          if (!gfsh.executeScriptLine(commandLineCommand)) {
+          if (!gfsh.executeCommand(commandLineCommand)) {
               if (gfsh.getLastExecutionStatus() != 0) 
                 exitRequest = ExitShellRequest.FATAL_EXIT;
           } else if (gfsh.getLastExecutionStatus() != 0) {
@@ -224,7 +224,7 @@ public final class Launcher {
             String command = commandsToExecute.get(i);
             System.out.println(GfshParser.LINE_SEPARATOR + "(" + (i + 1) + ") Executing - " + command
                 + GfshParser.LINE_SEPARATOR);
-            if (!gfsh.executeScriptLine(command) || gfsh.getLastExecutionStatus() != 0) {
+            if (!gfsh.executeCommand(command) || gfsh.getLastExecutionStatus() != 0) {
               exitRequest = ExitShellRequest.FATAL_EXIT;
             }
           }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
index 1bd7692..edab207 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/commands/ShellCommands.java
@@ -853,8 +853,8 @@ private void configureHttpsURLConnection(Map<String, String> sslConfigProps) thr
       int historySizeWordLength = historySizeString.length();
 
       GfshHistory gfshHistory = gfsh.getGfshHistory();
-      //List<?> gfshHistoryList = gfshHistory.getHistoryList();
-      Iterator<?> it = gfshHistory.entries();
+      List<?> gfshHistoryList = gfshHistory.getHistoryList();
+      Iterator<?> it = gfshHistoryList.iterator();
       boolean flagForLineNumbers = (saveHistoryTo != null && saveHistoryTo
           .length() > 0) ? false : true;
       long lineNumber = 0;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
index 67a8ccb..1d14c5b 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/Gfsh.java
@@ -36,9 +36,9 @@ import java.util.logging.Level;
 import java.util.logging.LogManager;
 import java.util.logging.Logger;
 
+import jline.ConsoleReader;
 import jline.Terminal;
 
-import jline.console.ConsoleReader;
 import org.springframework.shell.core.AbstractShell;
 import org.springframework.shell.core.CommandMarker;
 import org.springframework.shell.core.Converter;
@@ -380,6 +380,7 @@ public class Gfsh extends JLineShell {
   /**
    * See findResources in {@link AbstractShell}
    */
+  @Override
   protected Collection<URL> findResources(String resourceName) {
 //    return Collections.singleton(ClassPathLoader.getLatest().getResource(resourceName));
     return null;
@@ -419,7 +420,7 @@ public class Gfsh extends JLineShell {
    * @return true if execution is successful; false otherwise
    */
   @Override
-  public boolean executeScriptLine(final String line) {
+  public boolean executeCommand(final String line) {
     boolean success = false;
     String withPropsExpanded = line;
 
@@ -439,7 +440,7 @@ public class Gfsh extends JLineShell {
       if (gfshFileLogger.fineEnabled()) {
         gfshFileLogger.fine(logMessage + withPropsExpanded);
       }
-      success = super.executeScriptLine(withPropsExpanded);
+      success = super.executeCommand(withPropsExpanded);
     } catch (Exception e) {
       //TODO: should there be a way to differentiate error in shell & error on
       //server. May be by exception type.
@@ -632,12 +633,12 @@ public class Gfsh extends JLineShell {
   ///////////////////// JLineShell Class Methods End  //////////////////////////
 
   public int getTerminalHeight() {
-    return terminal != null ? terminal.getHeight() : DEFAULT_HEIGHT;
+    return terminal != null ? terminal.getTerminalHeight() : DEFAULT_HEIGHT;
   }
 
   public int getTerminalWidth() {
     if (terminal != null) {
-      return terminal.getWidth();
+      return terminal.getTerminalWidth();
     }
 
     Map<String, String> env = System.getenv();
@@ -804,7 +805,7 @@ public class Gfsh extends JLineShell {
                 ++commandSrNum;
                 Gfsh.println(commandSrNum+". Executing - " + cmdLet);                
                 Gfsh.println();
-                boolean executeSuccess = executeScriptLine(cmdLet);
+                boolean executeSuccess = executeCommand(cmdLet);
                 if (!executeSuccess) {
                   setLastExecutionStatus(-1);
                 }
@@ -921,7 +922,7 @@ public class Gfsh extends JLineShell {
       readLine = reader.readLine(prompt);
     } catch (IndexOutOfBoundsException e) {
       if (earlierLine.length() == 0) {
-        reader.println();
+        reader.printNewline();
         readLine = LINE_SEPARATOR;
         reader.getCursorBuffer().cursor = 0;
       } else {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java
deleted file mode 100644
index 572f899..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIBuffer.java
+++ /dev/null
@@ -1,433 +0,0 @@
-/*
- * Copyright (c) 2002-2007, Marc Prud'hommeaux. All rights reserved.
- *
- * This software is distributable under the BSD license. See the terms of the
- * BSD license in the documentation provided with this software.
- */
-package com.gemstone.gemfire.management.internal.cli.shell.jline;
-
-import org.springframework.shell.support.util.OsUtils;
-
-import java.io.BufferedReader;
-import java.io.InputStreamReader;
-
-/**
- *  A buffer that can contain ANSI text.
- *
- *  @author  <a href="mailto:mwp1@cornell.edu">Marc Prud'hommeaux</a>
- */
-public class ANSIBuffer {
-    private boolean ansiEnabled = true;
-    private final StringBuffer ansiBuffer = new StringBuffer();
-    private final StringBuffer plainBuffer = new StringBuffer();
-
-    public ANSIBuffer() {
-    }
-
-    public ANSIBuffer(final String str) {
-        append(str);
-    }
-
-    public void setAnsiEnabled(final boolean ansi) {
-        this.ansiEnabled = ansi;
-    }
-
-    public boolean getAnsiEnabled() {
-        return this.ansiEnabled;
-    }
-
-    public String getAnsiBuffer() {
-        return ansiBuffer.toString();
-    }
-
-    public String getPlainBuffer() {
-        return plainBuffer.toString();
-    }
-
-    public String toString(final boolean ansi) {
-        return ansi ? getAnsiBuffer() : getPlainBuffer();
-    }
-
-    public String toString() {
-        return toString(ansiEnabled);
-    }
-
-    public ANSIBuffer append(final String str) {
-        ansiBuffer.append(str);
-        plainBuffer.append(str);
-
-        return this;
-    }
-
-    public ANSIBuffer attrib(final String str, final int code) {
-        ansiBuffer.append(ANSICodes.attrib(code)).append(str)
-                  .append(ANSICodes.attrib(ANSICodes.OFF));
-        plainBuffer.append(str);
-
-        return this;
-    }
-
-    public ANSIBuffer red(final String str) {
-        return attrib(str, ANSICodes.FG_RED);
-    }
-
-    public ANSIBuffer blue(final String str) {
-        return attrib(str, ANSICodes.FG_BLUE);
-    }
-
-    public ANSIBuffer green(final String str) {
-        return attrib(str, ANSICodes.FG_GREEN);
-    }
-
-    public ANSIBuffer black(final String str) {
-        return attrib(str, ANSICodes.FG_BLACK);
-    }
-
-    public ANSIBuffer yellow(final String str) {
-        return attrib(str, ANSICodes.FG_YELLOW);
-    }
-
-    public ANSIBuffer magenta(final String str) {
-        return attrib(str, ANSICodes.FG_MAGENTA);
-    }
-
-    public ANSIBuffer cyan(final String str) {
-        return attrib(str, ANSICodes.FG_CYAN);
-    }
-
-    public ANSIBuffer bold(final String str) {
-        return attrib(str, ANSICodes.BOLD);
-    }
-
-    public ANSIBuffer underscore(final String str) {
-        return attrib(str, ANSICodes.UNDERSCORE);
-    }
-
-    public ANSIBuffer blink(final String str) {
-        return attrib(str, ANSICodes.BLINK);
-    }
-
-    public ANSIBuffer reverse(final String str) {
-        return attrib(str, ANSICodes.REVERSE);
-    }
-
-    public static class ANSICodes {
-        static final int OFF = 0;
-        static final int BOLD = 1;
-        static final int UNDERSCORE = 4;
-        static final int BLINK = 5;
-        static final int REVERSE = 7;
-        static final int CONCEALED = 8;
-        static final int FG_BLACK = 30;
-        static final int FG_RED = 31;
-        static final int FG_GREEN = 32;
-        static final int FG_YELLOW = 33;
-        static final int FG_BLUE = 34;
-        static final int FG_MAGENTA = 35;
-        static final int FG_CYAN = 36;
-        static final int FG_WHITE = 37;
-        static final char ESC = 27;
-
-        /**
-         *  Constructor is private since this is a utility class.
-         */
-        private ANSICodes() {
-        }
-
-        /**
-          * Sets the screen mode. The mode will be one of the following values:
-          * <pre>
-          * mode     description
-          * ----------------------------------------
-          *   0      40 x 148 x 25 monochrome (text)
-          *   1      40 x 148 x 25 color (text)
-          *   2      80 x 148 x 25 monochrome (text)
-          *   3      80 x 148 x 25 color (text)
-          *   4      320 x 148 x 200 4-color (graphics)
-          *   5      320 x 148 x 200 monochrome (graphics)
-          *   6      640 x 148 x 200 monochrome (graphics)
-          *   7      Enables line wrapping
-          *  13      320 x 148 x 200 color (graphics)
-          *  14      640 x 148 x 200 color (16-color graphics)
-          *  15      640 x 148 x 350 monochrome (2-color graphics)
-          *  16      640 x 148 x 350 color (16-color graphics)
-          *  17      640 x 148 x 480 monochrome (2-color graphics)
-          *  18      640 x 148 x 480 color (16-color graphics)
-          *  19      320 x 148 x 200 color (256-color graphics)
-          * </pre>
-          */
-        public static String setmode(final int mode) {
-            return ESC + "[=" + mode + "h";
-        }
-
-        /**
-          * Same as setmode () except for mode = 7, which disables line
-          * wrapping (useful for writing the right-most column without
-          * scrolling to the next line).
-          */
-        public static String resetmode(final int mode) {
-            return ESC + "[=" + mode + "l";
-        }
-
-        /**
-          * Clears the screen and moves the cursor to the home postition.
-          */
-        public static String clrscr() {
-            return ESC + "[2J";
-        }
-
-        /**
-          * Removes all characters from the current cursor position until
-          * the end of the line.
-          */
-        public static String clreol() {
-            return ESC + "[K";
-        }
-
-        /**
-          * Moves the cursor n positions to the left. If n is greater or
-          * equal to the current cursor column, the cursor is moved to the
-          * first column.
-          */
-        public static String left(final int n) {
-            return ESC + "[" + n + "D";
-        }
-
-        /**
-          * Moves the cursor n positions to the right. If n plus the current
-          * cursor column is greater than the rightmost column, the cursor
-          * is moved to the rightmost column.
-          */
-        public static String right(final int n) {
-            return ESC + "[" + n + "C";
-        }
-
-        /**
-          * Moves the cursor n rows up without changing the current column.
-          * If n is greater than or equal to the current row, the cursor is
-          * placed in the first row.
-          */
-        public static String up(final int n) {
-            return ESC + "[" + n + "A";
-        }
-
-        /**
-          * Moves the cursor n rows down. If n plus the current row is greater
-          * than the bottom row, the cursor is moved to the bottom row.
-          */
-        public static String down(final int n) {
-            return ESC + "[" + n + "B";
-        }
-
-        /*
-          * Moves the cursor to the given row and column. (1,1) represents
-          * the upper left corner. The lower right corner of a usual DOS
-          * screen is (25, 80).
-          */
-        public static String gotoxy(final int row, final int column) {
-            return ESC + "[" + row + ";" + column + "H";
-        }
-
-        /**
-          * Saves the current cursor position.
-          */
-        public static String save() {
-            return ESC + "[s";
-        }
-
-        /**
-          * Restores the saved cursor position.
-          */
-        public static String restore() {
-            return ESC + "[u";
-        }
-
-        /**
-          * Sets the character attribute. It will be
-         * one of the following character attributes:
-          *
-          * <pre>
-          * Text attributes
-          *    0    All attributes off
-          *    1    Bold on
-          *    4    Underscore (on monochrome display adapter only)
-          *    5    Blink on
-          *    7    Reverse video on
-          *    8    Concealed on
-          *
-          *   Foreground colors
-          *    30    Black
-          *    31    Red
-          *    32    Green
-          *    33    Yellow
-          *    34    Blue
-          *    35    Magenta
-          *    36    Cyan
-          *    37    White
-          *
-          *   Background colors
-          *    40    Black
-          *    41    Red
-          *    42    Green
-          *    43    Yellow
-          *    44    Blue
-          *    45    Magenta
-          *    46    Cyan
-          *    47    White
-          * </pre>
-          *
-          * The attributes remain in effect until the next attribute command
-          * is sent.
-          */
-        public static String attrib(final int attr) {
-            return ESC + "[" + attr + "m";
-        }
-
-        /**
-          * Sets the key with the given code to the given value. code must be
-          * derived from the following table, value must
-         * be any semicolon-separated
-          * combination of String (enclosed in double quotes) and numeric values.
-          * For example, to set F1 to the String "Hello F1", followed by a CRLF
-          * sequence, one can use: ANSI.setkey ("0;59", "\"Hello F1\";13;10").
-          * Heres's the table of key values:
-          * <pre>
-          * Key                       Code      SHIFT+code  CTRL+code  ALT+code
-          * ---------------------------------------------------------------
-          * F1                        0;59      0;84        0;94       0;104
-          * F2                        0;60      0;85        0;95       0;105
-          * F3                        0;61      0;86        0;96       0;106
-          * F4                        0;62      0;87        0;97       0;107
-          * F5                        0;63      0;88        0;98       0;108
-          * F6                        0;64      0;89        0;99       0;109
-          * F7                        0;65      0;90        0;100      0;110
-          * F8                        0;66      0;91        0;101      0;111
-          * F9                        0;67      0;92        0;102      0;112
-          * F10                       0;68      0;93        0;103      0;113
-          * F11                       0;133     0;135       0;137      0;139
-          * F12                       0;134     0;136       0;138      0;140
-          * HOME (num keypad)         0;71      55          0;119      --
-          * UP ARROW (num keypad)     0;72      56          (0;141)    --
-          * PAGE UP (num keypad)      0;73      57          0;132      --
-          * LEFT ARROW (num keypad)   0;75      52          0;115      --
-          * RIGHT ARROW (num keypad)  0;77      54          0;116      --
-          * END (num keypad)          0;79      49          0;117      --
-          * DOWN ARROW (num keypad)   0;80      50          (0;145)    --
-          * PAGE DOWN (num keypad)    0;81      51          0;118      --
-          * INSERT (num keypad)       0;82      48          (0;146)    --
-          * DELETE  (num keypad)      0;83      46          (0;147)    --
-          * HOME                      (224;71)  (224;71)    (224;119)  (224;151)
-          * UP ARROW                  (224;72)  (224;72)    (224;141)  (224;152)
-          * PAGE UP                   (224;73)  (224;73)    (224;132)  (224;153)
-          * LEFT ARROW                (224;75)  (224;75)    (224;115)  (224;155)
-          * RIGHT ARROW               (224;77)  (224;77)    (224;116)  (224;157)
-          * END                       (224;79)  (224;79)    (224;117)  (224;159)
-          * DOWN ARROW                (224;80)  (224;80)    (224;145)  (224;154)
-          * PAGE DOWN                 (224;81)  (224;81)    (224;118)  (224;161)
-          * INSERT                    (224;82)  (224;82)    (224;146)  (224;162)
-          * DELETE                    (224;83)  (224;83)    (224;147)  (224;163)
-          * PRINT SCREEN              --        --          0;114      --
-          * PAUSE/BREAK               --        --          0;0        --
-          * BACKSPACE                 8         8           127        (0)
-          * ENTER                     13        --          10         (0
-          * TAB                       9         0;15        (0;148)    (0;165)
-          * NULL                      0;3       --          --         --
-          * A                         97        65          1          0;30
-          * B                         98        66          2          0;48
-          * C                         99        66          3          0;46
-          * D                         100       68          4          0;32
-          * E                         101       69          5          0;18
-          * F                         102       70          6          0;33
-          * G                         103       71          7          0;34
-          * H                         104       72          8          0;35
-          * I                         105       73          9          0;23
-          * J                         106       74          10         0;36
-          * K                         107       75          11         0;37
-          * L                         108       76          12         0;38
-          * M                         109       77          13         0;50
-          * N                         110       78          14         0;49
-          * O                         111       79          15         0;24
-          * P                         112       80          16         0;25
-          * Q                         113       81          17         0;16
-          * R                         114       82          18         0;19
-          * S                         115       83          19         0;31
-          * T                         116       84          20         0;20
-          * U                         117       85          21         0;22
-          * V                         118       86          22         0;47
-          * W                         119       87          23         0;17
-          * X                         120       88          24         0;45
-          * Y                         121       89          25         0;21
-          * Z                         122       90          26         0;44
-          * 1                         49        33          --         0;120
-          * 2                         50        64          0          0;121
-          * 3                         51        35          --         0;122
-          * 4                         52        36          --         0;123
-          * 5                         53        37          --         0;124
-          * 6                         54        94          30         0;125
-          * 7                         55        38          --         0;126
-          * 8                         56        42          --         0;126
-          * 9                         57        40          --         0;127
-          * 0                         48        41          --         0;129
-          * -                         45        95          31         0;130
-          * =                         61        43          ---        0;131
-          * [                         91        123         27         0;26
-          * ]                         93        125         29         0;27
-          *                           92        124         28         0;43
-          * ;                         59        58          --         0;39
-          * '                         39        34          --         0;40
-          * ,                         44        60          --         0;51
-          * .                         46        62          --         0;52
-          * /                         47        63          --         0;53
-          * `                         96        126         --         (0;41)
-          * ENTER (keypad)            13        --          10         (0;166)
-          * / (keypad)                47        47          (0;142)    (0;74)
-          * * (keypad)                42        (0;144)     (0;78)     --
-          * - (keypad)                45        45          (0;149)    (0;164)
-          * + (keypad)                43        43          (0;150)    (0;55)
-          * 5 (keypad)                (0;76)    53          (0;143)    --
-          */
-        public static String setkey(final String code, final String value) {
-            return ESC + "[" + code + ";" + value + "p";
-        }
-    }
-
-    public static void main(final String[] args) throws Exception {
-        // sequence, one can use: ANSI.setkey ("0;59", "\"Hello F1\";13;10").
-        BufferedReader reader =
-            new BufferedReader(new InputStreamReader(System.in));
-        System.out.print(ANSICodes.setkey("97", "97;98;99;13")
-                         + ANSICodes.attrib(ANSICodes.OFF));
-        System.out.flush();
-
-        String line;
-
-        while ((line = reader.readLine()) != null) {
-            System.out.println("GOT: " + line);
-        }
-    }
-
-    private static final boolean ROO_BRIGHT_COLORS = Boolean.getBoolean("roo.bright");
-    private static final boolean SHELL_BRIGHT_COLORS = Boolean.getBoolean("spring.shell.bright");
-    private static final boolean BRIGHT_COLORS = ROO_BRIGHT_COLORS || SHELL_BRIGHT_COLORS;
-
-    public static ANSIBuffer getANSIBuffer() {
-        final char esc = (char) 27;
-        return new ANSIBuffer() {
-            @Override
-            public ANSIBuffer reverse(final String str) {
-                if (OsUtils.isWindows()) {
-                    return super.reverse(str).append(ANSICodes.attrib(esc));
-                }
-                return super.reverse(str);
-            };
-            @Override
-            public ANSIBuffer attrib(final String str, final int code) {
-                if (BRIGHT_COLORS && 30 <= code && code <= 37) {
-                    // This is a color code: add a 'bright' code
-                    return append(esc + "[" + code + ";1m").append(str).append(ANSICodes.attrib(0));
-                }
-                return super.attrib(str, code);
-            }
-        };
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
index c8102ae..ccd9864 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/ANSIHandler.java
@@ -18,6 +18,8 @@ package com.gemstone.gemfire.management.internal.cli.shell.jline;
 
 import org.springframework.shell.core.JLineLogHandler;
 
+import jline.ANSIBuffer;
+
 /**
  * Overrides jline.History to add History without newline characters.
  * 
@@ -48,8 +50,7 @@ public class ANSIHandler {
     String decoratedInput = input;
     
     if (isAnsiEnabled()) {
-      ANSIBuffer ansiBuffer = ANSIBuffer.getANSIBuffer();
-
+      ANSIBuffer ansiBuffer = JLineLogHandler.getANSIBuffer();
 
       for (ANSIStyle ansiStyle : styles) {
         switch (ansiStyle) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
index f486774..d84bbe7 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/CygwinMinttyTerminal.java
@@ -39,18 +39,147 @@ public class CygwinMinttyTerminal extends UnixTerminal {
   
   
   String encoding = System.getProperty("input.encoding", "UTF-8");
+  ReplayPrefixOneCharInputStream replayStream = new ReplayPrefixOneCharInputStream(encoding);
   InputStreamReader replayReader;
 
-  public CygwinMinttyTerminal() throws Exception{
+  public CygwinMinttyTerminal() {
+      try {
+          replayReader = new InputStreamReader(replayStream, encoding);
+      } catch (Exception e) {
+          throw new RuntimeException(e);
+      }
   }
 
   @Override
-  public void init() throws Exception{
+  public void initializeTerminal() throws IOException, InterruptedException {
 
   }
 
   @Override
-  public void restore() throws Exception {
-    reset();
+  public void restoreTerminal() throws Exception {
+    resetTerminal();
   }
+
+  @Override
+  public int readVirtualKey(InputStream in) throws IOException {
+    int c = readCharacter(in);
+
+    //if (backspaceDeleteSwitched)
+        if (c == DELETE)
+            c = BACKSPACE;
+        else if (c == BACKSPACE)
+            c = DELETE;
+
+    // in Unix terminals, arrow keys are represented by
+    // a sequence of 3 characters. E.g., the up arrow
+    // key yields 27, 91, 68
+    if (c == ARROW_START && in.available() > 0) {
+        // Escape key is also 27, so we use InputStream.available()
+        // to distinguish those. If 27 represents an arrow, there
+        // should be two more chars immediately available.
+        while (c == ARROW_START) {
+            c = readCharacter(in);
+        }
+        if (c == ARROW_PREFIX || c == O_PREFIX) {
+            c = readCharacter(in);
+            if (c == ARROW_UP) {
+                return CTRL_P;
+            } else if (c == ARROW_DOWN) {
+                return CTRL_N;
+            } else if (c == ARROW_LEFT) {
+                return CTRL_B;
+            } else if (c == ARROW_RIGHT) {
+                return CTRL_F;
+            } else if (c == HOME_CODE) {
+                return CTRL_A;
+            } else if (c == END_CODE) {
+                return CTRL_E;
+            } else if (c == DEL_THIRD) {
+                c = readCharacter(in); // read 4th
+                return DELETE;
+            }
+        } 
+    } 
+    // handle unicode characters, thanks for a patch from amyi@inf.ed.ac.uk
+    if (c > 128) {      
+      // handle unicode characters longer than 2 bytes,
+      // thanks to Marc.Herbert@continuent.com        
+        replayStream.setInput(c, in);
+//      replayReader = new InputStreamReader(replayStream, encoding);
+        c = replayReader.read();
+        
+    }
+    return c;
+  }
+  
+  /**
+   * This is awkward and inefficient, but probably the minimal way to add
+   * UTF-8 support to JLine
+   *
+   * @author <a href="mailto:Marc.Herbert@continuent.com">Marc Herbert</a>
+   */
+  static class ReplayPrefixOneCharInputStream extends InputStream {
+      byte firstByte;
+      int byteLength;
+      InputStream wrappedStream;
+      int byteRead;
+
+      final String encoding;
+      
+      public ReplayPrefixOneCharInputStream(String encoding) {
+          this.encoding = encoding;
+      }
+      
+      public void setInput(int recorded, InputStream wrapped) throws IOException {
+          this.byteRead = 0;
+          this.firstByte = (byte) recorded;
+          this.wrappedStream = wrapped;
+
+          byteLength = 1;
+          if (encoding.equalsIgnoreCase("UTF-8"))
+              setInputUTF8(recorded, wrapped);
+          else if (encoding.equalsIgnoreCase("UTF-16"))
+              byteLength = 2;
+          else if (encoding.equalsIgnoreCase("UTF-32"))
+              byteLength = 4;
+      }
+          
+          
+      public void setInputUTF8(int recorded, InputStream wrapped) throws IOException {
+          // 110yyyyy 10zzzzzz
+          if ((firstByte & (byte) 0xE0) == (byte) 0xC0)
+              this.byteLength = 2;
+          // 1110xxxx 10yyyyyy 10zzzzzz
+          else if ((firstByte & (byte) 0xF0) == (byte) 0xE0)
+              this.byteLength = 3;
+          // 11110www 10xxxxxx 10yyyyyy 10zzzzzz
+          else if ((firstByte & (byte) 0xF8) == (byte) 0xF0)
+              this.byteLength = 4;
+          else
+              throw new IOException("invalid UTF-8 first byte: " + firstByte);
+      }
+
+      public int read() throws IOException {
+          if (available() == 0)
+              return -1;
+
+          byteRead++;
+
+          if (byteRead == 1)
+              return firstByte;
+
+          return wrappedStream.read();
+      }
+
+      /**
+      * InputStreamReader is greedy and will try to read bytes in advance. We
+      * do NOT want this to happen since we use a temporary/"losing bytes"
+      * InputStreamReader above, that's why we hide the real
+      * wrappedStream.available() here.
+      */
+      public int available() {
+          return byteLength - byteRead;
+      }
+  }
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
index dc3fbe1..9f18cae 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshHistory.java
@@ -18,10 +18,7 @@ package com.gemstone.gemfire.management.internal.cli.shell.jline;
 
 import com.gemstone.gemfire.management.internal.cli.parser.preprocessor.PreprocessorUtils;
 
-import jline.console.history.MemoryHistory;
-
-import java.io.File;
-import java.io.IOException;
+import jline.History;
 
 /**
  * Overrides jline.History to add History without newline characters.
@@ -29,14 +26,14 @@ import java.io.IOException;
  * @author Abhishek Chaudhari
  * @since 7.0
  */
-public class GfshHistory extends MemoryHistory {
-
+public class GfshHistory extends History {
   // let the history from history file get added initially
   private boolean autoFlush = true;
-
+  
+  @Override
   public void addToHistory(String buffer) {
     if (isAutoFlush()) {
-      super.add(toHistoryLoggable(buffer));
+      super.addToHistory(toHistoryLoggable(buffer));
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
index 3bc839e..59609ba 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/shell/jline/GfshUnsupportedTerminal.java
@@ -27,7 +27,7 @@ import jline.UnsupportedTerminal;
  */
 public class GfshUnsupportedTerminal extends UnsupportedTerminal {
   @Override
-  public synchronized boolean isAnsiSupported() {
+  public boolean isANSISupported() {
     return false;
   }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
index 9d1bdbe..70a00a1 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/cli/util/CLIConsoleBufferUtil.java
@@ -16,7 +16,7 @@
  */
 package com.gemstone.gemfire.management.internal.cli.util;
 
-import jline.console.ConsoleReader;
+import jline.ConsoleReader;
 import com.gemstone.gemfire.management.internal.cli.shell.Gfsh;
 
 public class CLIConsoleBufferUtil {
@@ -24,9 +24,9 @@ public class CLIConsoleBufferUtil {
     
     ConsoleReader reader = Gfsh.getConsoleReader();    
     if (reader != null) {
-      int bufferLength = reader.getCursorBuffer().length();
-      if(bufferLength > messege.length()){
-        int appendSpaces = bufferLength - messege.length();
+      StringBuffer buffer = reader.getCursorBuffer().getBuffer();    
+      if(buffer.length() > messege.length()){
+        int appendSpaces = buffer.length() - messege.length();
         for(int i = 0; i < appendSpaces; i++){
           messege = messege + " ";
         }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
index 057be81..6ce1a13 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
@@ -172,7 +172,7 @@ public abstract class PersistentPartitionedRegionTestBase extends CacheTestCase
           public void run() {
             Cache cache = getCache();
             Region region = cache.getRegion(regionName);
-
+            
             for(int i =startKey; i < endKey; i++) {
               assertEquals("For key " + i, value, region.get(i));
             }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/e8ddd339/gradle/dependency-versions.properties
----------------------------------------------------------------------
diff --git a/gradle/dependency-versions.properties b/gradle/dependency-versions.properties
index 9c47763..c86d45d 100644
--- a/gradle/dependency-versions.properties
+++ b/gradle/dependency-versions.properties
@@ -33,7 +33,7 @@ javax.servlet-api.version = 3.1.0
 javax.transaction-api.version = 1.2
 jedis.version = 2.7.2
 jetty.version = 9.2.3.v20140905
-jline.version = 2.12
+jline.version = 1.0.S2-B
 jmock.version = 2.8.1
 jna.version = 4.0.0
 json4s.version = 3.2.4
@@ -56,7 +56,7 @@ snappy-java.version = 1.1.1.6
 spring-data-commons.version = 1.9.1.RELEASE
 spring-data-gemfire.version = 1.5.1.RELEASE
 spring-hateos.version = 0.16.0.RELEASE
-spring-shell.version = 1.1.0.RELEASE
+spring-shell.version = 1.0.0.RELEASE
 springframework.version = 3.2.12.RELEASE
 spymemcached.version = 2.9.0
 swagger.version = 1.3.2