You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by ud...@apache.org on 2018/03/19 18:48:59 UTC

[geode] branch feature/GEODE-3926_2 updated: WIP2

This is an automated email from the ASF dual-hosted git repository.

udo pushed a commit to branch feature/GEODE-3926_2
in repository https://gitbox.apache.org/repos/asf/geode.git


The following commit(s) were added to refs/heads/feature/GEODE-3926_2 by this push:
     new 5253e2a  WIP2
5253e2a is described below

commit 5253e2ae63d3328b48be761d819694b6c5bc9b70
Author: Udo <uk...@pivotal.io>
AuthorDate: Mon Mar 19 11:48:48 2018 -0700

    WIP2
---
 .../internal/LuceneIndexForPartitionedRegion.java  | 31 +++----
 .../cache/lucene/internal/LuceneIndexImpl.java     | 41 ++++-----
 .../lucene/internal/LuceneIndexImplFactory.java    |  4 -
 .../cache/lucene/internal/LuceneRawIndex.java      | 13 +--
 .../lucene/internal/LuceneRawIndexFactory.java     |  8 +-
 .../lucene/internal/LuceneIndexFactorySpy.java     |  2 +-
 .../LuceneIndexForPartitionedRegionTest.java       | 99 ++++++++++++++--------
 .../lucene/internal/LuceneIndexImplJUnitTest.java  | 47 ----------
 8 files changed, 99 insertions(+), 146 deletions(-)

diff --git a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegion.java b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegion.java
index b338595..58e270b 100644
--- a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegion.java
+++ b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegion.java
@@ -76,28 +76,22 @@ public class LuceneIndexForPartitionedRegion extends LuceneIndexImpl {
 
   private ExecutorService waitingThreadPool;
 
-
-  public LuceneIndexForPartitionedRegion(String indexName, String regionPath, InternalCache cache) {
-    super(indexName, regionPath, cache);
-
-    final String statsName = indexName + "-" + regionPath;
-    this.fileSystemStats = new FileSystemStats(cache.getDistributedSystem(), statsName);
-  }
-
   public LuceneIndexForPartitionedRegion(String indexName, String regionPath, InternalCache cache,
                                          Analyzer analyzer, Map<String, Analyzer> fieldAnalyzers,
                                          LuceneSerializer serializer,
                                          RegionAttributes attributes, String aeqId, String[] fields,
                                          ExecutorService waitingThreadPool) {
-    this(indexName, regionPath, cache);
+    super(indexName, regionPath, cache, serializer, fieldAnalyzers);
+    final String statsName = indexName + "-" + regionPath;
+    this.fileSystemStats = new FileSystemStats(cache.getDistributedSystem(), statsName);
     this.waitingThreadPool = waitingThreadPool;
     this.setSearchableFields(fields);
     this.setAnalyzer(analyzer);
-    this.setFieldAnalyzers(fieldAnalyzers);
-    this.setLuceneSerializer(serializer);
-    this.setupRepositoryManager(serializer);
-    System.out.println(this+".LuceneIndexForPartitionedRegion construct  " + this.repositoryManager);
-    this.createAEQ(attributes, aeqId);
+    if (aeqId == null) {
+      this.createAEQ(attributes);
+    } else {
+      this.createAEQ(attributes, aeqId);
+    }
   }
 
   protected RepositoryManager createRepositoryManager(LuceneSerializer luceneSerializer) {
@@ -112,7 +106,8 @@ public class LuceneIndexForPartitionedRegion extends LuceneIndexImpl {
 
   protected void createLuceneListenersAndFileChunkRegions(
       PartitionedRepositoryManager partitionedRepositoryManager) {
-    partitionedRepositoryManager.setUserRegionForRepositoryManager((PartitionedRegion) dataRegion);
+    partitionedRepositoryManager
+        .setUserRegionForRepositoryManager((PartitionedRegion) dataRegion);
     RegionShortcut regionShortCut;
     final boolean withPersistence = withPersistence();
     RegionAttributes regionAttributes = dataRegion.getAttributes();
@@ -258,7 +253,8 @@ public class LuceneIndexForPartitionedRegion extends LuceneIndexImpl {
   public boolean isIndexAvailable(int id) {
     PartitionedRegion fileAndChunkRegion = getFileAndChunkRegion();
     if (fileAndChunkRegion != null) {
-      return fileAndChunkRegion.get(IndexRepositoryFactory.APACHE_GEODE_INDEX_COMPLETE, id) != null;
+      return fileAndChunkRegion.get(IndexRepositoryFactory.APACHE_GEODE_INDEX_COMPLETE, id)
+          != null;
     }
     return false;
   }
@@ -292,7 +288,8 @@ public class LuceneIndexForPartitionedRegion extends LuceneIndexImpl {
     }
   }
 
-  public IndexRepository computeIndexRepository(final Integer bucketId, LuceneSerializer serializer,
+  public IndexRepository computeIndexRepository(final Integer bucketId, LuceneSerializer
+      serializer,
                                                 PartitionedRegion userRegion,
                                                 final IndexRepository oldRepository)
       throws IOException {
diff --git a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImpl.java b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImpl.java
index 45ecc78..d6b608d 100644
--- a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImpl.java
+++ b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImpl.java
@@ -48,20 +48,25 @@ public abstract class LuceneIndexImpl implements InternalLuceneIndex {
   protected final InternalCache cache;
   protected final LuceneIndexStats indexStats;
 
-  protected Map<String, Analyzer> fieldAnalyzers;
+  protected final Map<String, Analyzer> fieldAnalyzers;
   protected String[] searchableFieldNames;
-  protected RepositoryManager repositoryManager;
+  protected final RepositoryManager repositoryManager;
   protected Analyzer analyzer;
   protected LuceneSerializer luceneSerializer;
   protected LocalRegion dataRegion;
 
-  protected LuceneIndexImpl(String indexName, String regionPath, InternalCache cache) {
+  protected LuceneIndexImpl(String indexName, String regionPath, InternalCache cache,
+                            LuceneSerializer serializer, Map<String, Analyzer> fieldAnalyzers) {
     this.indexName = indexName;
     this.regionPath = regionPath;
     this.cache = cache;
 
     final String statsName = indexName + "-" + regionPath;
     this.indexStats = new LuceneIndexStats(cache.getDistributedSystem(), statsName);
+    luceneSerializer = serializer;
+    repositoryManager = createRepositoryManager(luceneSerializer);
+    this.fieldAnalyzers = fieldAnalyzers;
+
   }
 
   @Override
@@ -123,19 +128,10 @@ public abstract class LuceneIndexImpl implements InternalLuceneIndex {
     return this.luceneSerializer;
   }
 
-  public void setLuceneSerializer(LuceneSerializer serializer) {
-    this.luceneSerializer = serializer;
-  }
-
   public Cache getCache() {
     return this.cache;
   }
 
-  public void setFieldAnalyzers(Map<String, Analyzer> fieldAnalyzers) {
-    this.fieldAnalyzers =
-        fieldAnalyzers == null ? null : Collections.unmodifiableMap(fieldAnalyzers);
-  }
-
   public LuceneIndexStats getIndexStats() {
     return indexStats;
   }
@@ -143,36 +139,33 @@ public abstract class LuceneIndexImpl implements InternalLuceneIndex {
   public void initialize() {
     /* create index region */
     dataRegion = assignDataRegion();
-    System.err.println(this+".initialize  DataRegion: "+dataRegion+"  repositoryManager: "+repositoryManager);
+    System.err.println(this + ".initialize  DataRegion: " + dataRegion + "  repositoryManager: "
+        + repositoryManager);
     createLuceneListenersAndFileChunkRegions((PartitionedRepositoryManager) repositoryManager);
     addExtension(dataRegion);
   }
 
-  protected void setupRepositoryManager(LuceneSerializer luceneSerializer) {
-    repositoryManager = createRepositoryManager(luceneSerializer);
-  }
-
   protected abstract RepositoryManager createRepositoryManager(LuceneSerializer luceneSerializer);
 
   protected abstract void createLuceneListenersAndFileChunkRegions(
       PartitionedRepositoryManager partitionedRepositoryManager);
 
-  protected AsyncEventQueue createAEQ(Region dataRegion) {
-    String aeqId = LuceneServiceImpl.getUniqueIndexName(getName(), regionPath);
-    return createAEQ(createAEQFactory(dataRegion.getAttributes()), aeqId);
+  protected AsyncEventQueue createAEQ(RegionAttributes attributes) {
+    return createAEQ(attributes, LuceneServiceImpl.getUniqueIndexName(getName(), regionPath));
   }
 
   protected AsyncEventQueue createAEQ(RegionAttributes attributes, String aeqId) {
-    if (attributes.getPartitionAttributes() != null) {
+    if (attributes != null && attributes.getPartitionAttributes() != null) {
       if (attributes.getPartitionAttributes().getLocalMaxMemory() == 0) {
         // accessor will not create AEQ
         return null;
       }
+      return createAEQ(createAEQFactory(attributes), aeqId);
     }
-    return createAEQ(createAEQFactory(attributes), aeqId);
+    return null;
   }
+
   private AsyncEventQueue createAEQ(AsyncEventQueueFactoryImpl factory, String aeqId) {
-    System.err.println(this+".createAEQ RepositoryManager: "+repositoryManager);
     LuceneEventListener listener = new LuceneEventListener(cache, repositoryManager);
     factory.setGatewayEventSubstitutionListener(new LuceneEventSubstitutionFilter());
     AsyncEventQueue indexQueue = factory.create(aeqId, listener);
@@ -255,7 +248,7 @@ public abstract class LuceneIndexImpl implements InternalLuceneIndex {
   }
 
   protected <K, V> Region<K, V> createRegion(final String regionName,
-      final RegionAttributes<K, V> attributes) {
+                                             final RegionAttributes<K, V> attributes) {
     // Create InternalRegionArguments to set isUsedForMetaRegion true to suppress xml generation
     // (among other things)
     InternalRegionArguments ira =
diff --git a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImplFactory.java b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImplFactory.java
index aeb6054..94819e5 100755
--- a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImplFactory.java
+++ b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneIndexImplFactory.java
@@ -27,10 +27,6 @@ public class LuceneIndexImplFactory {
 
   public LuceneIndexImplFactory() {}
 
-  public LuceneIndexImpl create(String indexName, String regionPath, InternalCache cache) {
-    return new LuceneIndexForPartitionedRegion(indexName, regionPath, cache);
-  }
-
   public LuceneIndexImpl create(String indexName, String regionPath, InternalCache cache,
       Analyzer analyzer, Map<String, Analyzer> fieldAnalyzers, LuceneSerializer serializer,
       RegionAttributes attributes, String aeqId, String[] fields,
diff --git a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndex.java b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndex.java
index 54f16e9..a074bd6 100755
--- a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndex.java
+++ b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndex.java
@@ -27,25 +27,14 @@ import org.apache.geode.internal.cache.InternalCache;
 import org.apache.geode.internal.cache.PartitionedRegion;
 
 public class LuceneRawIndex extends LuceneIndexImpl {
-
-  private ExecutorService waitingThreadPool;
-
-  protected LuceneRawIndex(String indexName, String regionPath, InternalCache cache) {
-    super(indexName, regionPath, cache);
-  }
-
   public LuceneRawIndex(String indexName, String regionPath, InternalCache cache, Analyzer analyzer,
                         Map<String, Analyzer> fieldAnalyzers,
                         LuceneSerializer serializer, RegionAttributes attributes, String aeqId,
                         String[] fields,
                         ExecutorService waitingThreadPool) {
-    super(indexName, regionPath, cache);
-    this.waitingThreadPool = waitingThreadPool;
+    super(indexName, regionPath, cache, serializer, fieldAnalyzers);
     this.setSearchableFields(fields);
     this.setAnalyzer(analyzer);
-    this.setFieldAnalyzers(fieldAnalyzers);
-    this.setLuceneSerializer(serializer);
-    this.setupRepositoryManager(serializer);
     this.createAEQ(attributes, aeqId);
   }
 
diff --git a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndexFactory.java b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndexFactory.java
index e319fb9..a84b846 100755
--- a/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndexFactory.java
+++ b/geode-lucene/src/main/java/org/apache/geode/cache/lucene/internal/LuceneRawIndexFactory.java
@@ -24,13 +24,9 @@ import org.apache.geode.cache.lucene.LuceneSerializer;
 import org.apache.geode.internal.cache.InternalCache;
 
 public class LuceneRawIndexFactory extends LuceneIndexImplFactory {
-  @Override
-  public LuceneIndexImpl create(String indexName, String regionPath, InternalCache cache) {
-    return new LuceneRawIndex(indexName, regionPath, cache);
-  }
-
   public LuceneIndexImpl create(String indexName, String regionPath, InternalCache cache,
-                                Analyzer analyzer, Map<String, Analyzer> fieldAnalyzers, LuceneSerializer serializer,
+                                Analyzer analyzer, Map<String, Analyzer> fieldAnalyzers,
+                                LuceneSerializer serializer,
                                 RegionAttributes attributes, String aeqId, String[] fields,
                                 ExecutorService waitingThreadPool) {
     return new LuceneRawIndex(indexName, regionPath, cache, analyzer,
diff --git a/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexFactorySpy.java b/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexFactorySpy.java
index e063223..6625515 100644
--- a/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexFactorySpy.java
+++ b/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexFactorySpy.java
@@ -50,7 +50,7 @@ public class LuceneIndexFactorySpy extends LuceneIndexImplFactory {
     LuceneIndexForPartitionedRegion index =
         Mockito.spy(new ExtendedLuceneIndexForPartitionedRegion(indexName, regionPath, cache, analyzer, fieldAnalyzers, serializer, attributes, aeqId,
             fields, waitingThreadPool));
-    System.err.println("LuceneIndexFactorySpy.create  "+index);
+    System.err.println(this+".create  "+index);
     return index;
   }
 
diff --git a/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegionTest.java b/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegionTest.java
index 9ebde2c..ee25162 100644
--- a/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegionTest.java
+++ b/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexForPartitionedRegionTest.java
@@ -18,7 +18,12 @@ import static org.junit.Assert.*;
 import static org.mockito.Mockito.*;
 
 import java.util.Properties;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
 
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Ignore;
 import org.junit.Rule;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
@@ -37,11 +42,13 @@ import org.apache.geode.cache.Region;
 import org.apache.geode.cache.RegionAttributes;
 import org.apache.geode.cache.RegionShortcut;
 import org.apache.geode.cache.asyncqueue.AsyncEventQueue;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueueFactory;
 import org.apache.geode.cache.asyncqueue.internal.AsyncEventQueueFactoryImpl;
 import org.apache.geode.cache.execute.FunctionService;
 import org.apache.geode.cache.execute.ResultCollector;
 import org.apache.geode.cache.lucene.LuceneSerializer;
 import org.apache.geode.cache.lucene.internal.directory.DumpDirectoryFiles;
+import org.apache.geode.cache.lucene.internal.repository.RepositoryManager;
 import org.apache.geode.internal.cache.GemFireCacheImpl;
 import org.apache.geode.internal.cache.InternalCache;
 import org.apache.geode.internal.cache.PartitionedRegion;
@@ -55,6 +62,17 @@ public class LuceneIndexForPartitionedRegionTest {
 
   @Rule
   public ExpectedException expectedExceptions = ExpectedException.none();
+  private ExecutorService executorService;
+
+  @Before
+  public void setup() {
+    executorService = Executors.newSingleThreadExecutor();
+  }
+
+  @After
+  public void teardown() {
+    executorService.shutdownNow();
+  }
 
   @Test
   public void getIndexNameReturnsCorrectName() {
@@ -62,7 +80,8 @@ public class LuceneIndexForPartitionedRegionTest {
     String regionPath = "regionName";
     InternalCache cache = Fakes.cache();
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            null, null, null, executorService);
     assertEquals(name, index.getName());
   }
 
@@ -72,7 +91,8 @@ public class LuceneIndexForPartitionedRegionTest {
     String regionPath = "regionName";
     InternalCache cache = Fakes.cache();
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            null, null, null, executorService);
     assertEquals(regionPath, index.getRegionPath());
   }
 
@@ -83,7 +103,8 @@ public class LuceneIndexForPartitionedRegionTest {
     InternalCache cache = Fakes.cache();
     PartitionedRegion region = mock(PartitionedRegion.class);
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            region.getAttributes(), null, null, executorService);
     String fileRegionName = index.createFileRegionName();
     when(cache.getRegion(fileRegionName)).thenReturn(region);
 
@@ -96,7 +117,8 @@ public class LuceneIndexForPartitionedRegionTest {
     String regionPath = "regionName";
     InternalCache cache = Fakes.cache();
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            null, null, null, executorService);
     String fileRegionName = index.createFileRegionName();
     when(cache.getRegion(fileRegionName)).thenReturn(null);
 
@@ -104,6 +126,7 @@ public class LuceneIndexForPartitionedRegionTest {
   }
 
   @Test
+  @Ignore("Not sure this makes sense anymore since these calls are handled by the constructor")
   public void createAEQWithPersistenceCallsCreateOnAEQFactory() {
     String name = "indexName";
     String regionPath = "regionName";
@@ -115,27 +138,28 @@ public class LuceneIndexForPartitionedRegionTest {
     when(cache.createAsyncEventQueueFactory()).thenReturn(aeqFactory);
 
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
-    index.createAEQ(region);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            region.getAttributes(), null, null, executorService);
 
     verify(aeqFactory).setPersistent(eq(true));
     verify(aeqFactory).create(any(), any());
   }
 
   @Test
+  @Ignore("Not sure this makes sense anymore since these calls are handled by the constructor")
   public void createRepositoryManagerWithNotNullSerializer() {
     String name = "indexName";
     String regionPath = "regionName";
     InternalCache cache = Fakes.cache();
     LuceneSerializer serializer = mock(LuceneSerializer.class);
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
-    index = spy(index);
-    index.setupRepositoryManager(serializer);
+        spy(new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, serializer,
+            null, null, null, executorService));
     verify(index).createRepositoryManager(eq(serializer));
   }
 
   @Test
+  @Ignore("Not sure this makes sense anymore since these calls are handled by the constructor")
   public void createRepositoryManagerWithNullSerializer() {
     String name = "indexName";
     String regionPath = "regionName";
@@ -144,16 +168,16 @@ public class LuceneIndexForPartitionedRegionTest {
     ArgumentCaptor<LuceneSerializer> serializerCaptor =
         ArgumentCaptor.forClass(LuceneSerializer.class);
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            null, null, fields, executorService);
     index = spy(index);
-    when(index.getFieldNames()).thenReturn(fields);
-    index.setupRepositoryManager(null);
     verify(index).createRepositoryManager(serializerCaptor.capture());
     LuceneSerializer serializer = serializerCaptor.getValue();
     assertNull(serializer);
   }
 
   @Test
+  @Ignore("Not sure this makes sense anymore since these calls are handled by the constructor")
   public void createAEQCallsCreateOnAEQFactory() {
     String name = "indexName";
     String regionPath = "regionName";
@@ -163,21 +187,21 @@ public class LuceneIndexForPartitionedRegionTest {
     when(cache.createAsyncEventQueueFactory()).thenReturn(aeqFactory);
 
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
-    index.createAEQ(region);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            region.getAttributes(), null, null, executorService);
 
     verify(aeqFactory, never()).setPersistent(eq(true));
     verify(aeqFactory).create(any(), any());
   }
 
   private Region initializeScenario(final boolean withPersistence, final String regionPath,
-      final Cache cache) {
+                                    final Cache cache) {
     int defaultLocalMemory = 100;
     return initializeScenario(withPersistence, regionPath, cache, defaultLocalMemory);
   }
 
   private RegionAttributes createRegionAttributes(final boolean withPersistence,
-      PartitionAttributes partitionAttributes) {
+                                                  PartitionAttributes partitionAttributes) {
     AttributesFactory factory = new AttributesFactory();
     if (withPersistence) {
       factory.setDataPolicy(DataPolicy.PERSISTENT_PARTITION);
@@ -190,7 +214,7 @@ public class LuceneIndexForPartitionedRegionTest {
   }
 
   private Region initializeScenario(final boolean withPersistence, final String regionPath,
-      final Cache cache, int localMaxMemory) {
+                                    final Cache cache, int localMaxMemory) {
     PartitionedRegion region = mock(PartitionedRegion.class);
     PartitionAttributes partitionAttributes = new PartitionAttributesFactory()
         .setLocalMaxMemory(localMaxMemory).setTotalNumBuckets(103).create();
@@ -228,8 +252,11 @@ public class LuceneIndexForPartitionedRegionTest {
     String regionPath = "regionName";
     InternalCache cache = Fakes.cache();
     Region region = initializeScenario(withPersistence, regionPath, cache, 0);
+
+    RegionAttributes regionAttributes = region.getAttributes();
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            regionAttributes, "aeq", null, executorService);
     LuceneIndexForPartitionedRegion spy = setupSpy(region, index, "aeq");
     spy.initialize();
   }
@@ -240,23 +267,22 @@ public class LuceneIndexForPartitionedRegionTest {
     String name = "indexName";
     String regionPath = "regionName";
     InternalCache cache = Fakes.cache();
+    when(cache.createAsyncEventQueueFactory()).thenReturn(mock(AsyncEventQueueFactoryImpl.class));
     Region region = initializeScenario(withPersistence, regionPath, cache);
 
+    RegionAttributes regionAttributes = region.getAttributes();
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
-    LuceneIndexForPartitionedRegion spy = setupSpy(region, index, "aeq");
-
-    verify(spy).createAEQ(eq(region.getAttributes()), eq("aeq"));
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            regionAttributes, "aeq", null, executorService);
   }
 
   protected LuceneIndexForPartitionedRegion setupSpy(final Region region,
-      final LuceneIndexForPartitionedRegion index, final String aeq) {
-    index.setSearchableFields(new String[] {"field"});
+                                                     final LuceneIndexForPartitionedRegion index,
+                                                     final String aeq) {
+    index.setSearchableFields(new String[]{"field"});
     LuceneIndexForPartitionedRegion spy = spy(index);
     doReturn(null).when(spy).createRegion(any(), any(), any(), any(), any(), any());
     doReturn(null).when(spy).createAEQ(any(), any());
-    spy.setupRepositoryManager(null);
-    spy.createAEQ(region.getAttributes(), aeq);
     spy.initialize();
     return spy;
   }
@@ -268,9 +294,11 @@ public class LuceneIndexForPartitionedRegionTest {
     String regionPath = "regionName";
     InternalCache cache = Fakes.cache();
     Region region = initializeScenario(withPersistence, regionPath, cache);
-
+    AsyncEventQueueFactoryImpl aeqFactory = mock(AsyncEventQueueFactoryImpl.class);
+    when(cache.createAsyncEventQueueFactory()).thenReturn(aeqFactory);
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            region.getAttributes(), "aeq", null, executorService);
     LuceneIndexForPartitionedRegion spy = setupSpy(region, index, "aeq");
 
     verify(spy).createRegion(eq(index.createFileRegionName()), eq(RegionShortcut.PARTITION), any(),
@@ -287,7 +315,8 @@ public class LuceneIndexForPartitionedRegionTest {
     when(regionAttributes.getDataPolicy()).thenReturn(DataPolicy.PARTITION);
     PartitionAttributes partitionAttributes = initializeAttributes(cache);
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            regionAttributes, null, null, executorService);
     LuceneIndexForPartitionedRegion indexSpy = spy(index);
     indexSpy.createRegion(index.createFileRegionName(), RegionShortcut.PARTITION, regionPath,
         partitionAttributes, regionAttributes, null);
@@ -306,12 +335,12 @@ public class LuceneIndexForPartitionedRegionTest {
     initializeScenario(withPersistence, regionPath, cache);
 
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
-    index.setSearchableFields(new String[] {"field"});
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            null, null, null, executorService);
+    index.setSearchableFields(new String[]{"field"});
     LuceneIndexForPartitionedRegion spy = spy(index);
     doReturn(null).when(spy).createRegion(any(), any(), any(), any(), any(), any());
     doReturn(null).when(spy).createAEQ((RegionAttributes) any(), any());
-    spy.setupRepositoryManager(null);
     spy.createAEQ(any(), any());
     spy.initialize();
 
@@ -324,7 +353,7 @@ public class LuceneIndexForPartitionedRegionTest {
     boolean withPersistence = false;
     String name = "indexName";
     String regionPath = "regionName";
-    String[] fields = new String[] {"field1", "field2"};
+    String[] fields = new String[]{"field1", "field2"};
     InternalCache cache = Fakes.cache();
     initializeScenario(withPersistence, regionPath, cache);
 
@@ -332,11 +361,11 @@ public class LuceneIndexForPartitionedRegionTest {
     DumpDirectoryFiles function = new DumpDirectoryFiles();
     FunctionService.registerFunction(function);
     LuceneIndexForPartitionedRegion index =
-        new LuceneIndexForPartitionedRegion(name, regionPath, cache);
+        new LuceneIndexForPartitionedRegion(name, regionPath, cache, null, null, null,
+            null, null, null, executorService);
     index = spy(index);
     when(index.getFieldNames()).thenReturn(fields);
     doReturn(aeq).when(index).createAEQ(any(), any());
-    index.setupRepositoryManager(null);
     index.createAEQ(cache.getRegionAttributes(regionPath), aeq.getId());
     index.initialize();
     PartitionedRegion region = (PartitionedRegion) cache.getRegion(regionPath);
diff --git a/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexImplJUnitTest.java b/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexImplJUnitTest.java
deleted file mode 100644
index 5286bae..0000000
--- a/geode-lucene/src/test/java/org/apache/geode/cache/lucene/internal/LuceneIndexImplJUnitTest.java
+++ /dev/null
@@ -1,47 +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 org.apache.geode.cache.lucene.internal;
-
-import org.junit.Before;
-import org.junit.Rule;
-import org.junit.experimental.categories.Category;
-import org.junit.rules.ExpectedException;
-
-import org.apache.geode.cache.lucene.LuceneIndex;
-import org.apache.geode.internal.cache.InternalCache;
-import org.apache.geode.test.fake.Fakes;
-import org.apache.geode.test.junit.categories.LuceneTest;
-import org.apache.geode.test.junit.categories.UnitTest;
-
-@Category({UnitTest.class, LuceneTest.class})
-public class LuceneIndexImplJUnitTest {
-
-  public static final String REGION = "region";
-  public static final String INDEX = "index";
-  public static final int MAX_WAIT = 30000;
-
-  private InternalCache cache;
-  private LuceneIndex index;
-
-  @Rule
-  public ExpectedException thrown = ExpectedException.none();
-
-  @Before
-  public void createLuceneIndex() {
-    cache = Fakes.cache();
-    index = new LuceneIndexForPartitionedRegion(INDEX, REGION, cache);
-  }
-
-}

-- 
To stop receiving notification emails like this one, please contact
udo@apache.org.