You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucene.apache.org by ma...@apache.org on 2018/12/10 00:31:59 UTC

[01/16] lucene-solr:master: SOLR-12801: Raise timeout in CollectionsAPIAsyncDistributedZkTest.

Repository: lucene-solr
Updated Branches:
  refs/heads/master 54ca26abe -> 1d5ae9857


SOLR-12801: Raise timeout in CollectionsAPIAsyncDistributedZkTest.


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/1d5ae985
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/1d5ae985
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/1d5ae985

Branch: refs/heads/master
Commit: 1d5ae9857fc3bb267dcbfee7d7de1d2f3f1c117e
Parents: 5d52980
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 18:05:23 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../api/collections/CollectionsAPIAsyncDistributedZkTest.java      | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/1d5ae985/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIAsyncDistributedZkTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIAsyncDistributedZkTest.java b/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIAsyncDistributedZkTest.java
index b81b956..953fad0 100644
--- a/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIAsyncDistributedZkTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIAsyncDistributedZkTest.java
@@ -55,7 +55,7 @@ import org.slf4j.LoggerFactory;
 @Slow
 public class CollectionsAPIAsyncDistributedZkTest extends SolrCloudTestCase {
 
-  private static final int MAX_TIMEOUT_SECONDS = 60;
+  private static final int MAX_TIMEOUT_SECONDS = 90;
   
   private static final Logger log = LoggerFactory.getLogger(MethodHandles.lookup().lookupClass());
 


[15/16] lucene-solr:master: SOLR-12801: harden DocValuesNotIndexedTest

Posted by ma...@apache.org.
SOLR-12801: harden DocValuesNotIndexedTest


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/5d529802
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/5d529802
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/5d529802

Branch: refs/heads/master
Commit: 5d529802c45cc5651ad1c09aafbff00e35ddecd6
Parents: 0824f7b
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 17:10:16 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../solr/cloud/DocValuesNotIndexedTest.java     | 29 ++++++++------------
 1 file changed, 12 insertions(+), 17 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/5d529802/solr/core/src/test/org/apache/solr/cloud/DocValuesNotIndexedTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/DocValuesNotIndexedTest.java b/solr/core/src/test/org/apache/solr/cloud/DocValuesNotIndexedTest.java
index 8e5482e..f396a5d 100644
--- a/solr/core/src/test/org/apache/solr/cloud/DocValuesNotIndexedTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/DocValuesNotIndexedTest.java
@@ -71,10 +71,10 @@ public class DocValuesNotIndexedTest extends SolrCloudTestCase {
   static final String COLLECTION = "dv_coll";
 
 
-  static List<FieldProps> fieldsToTestSingle = null;
-  static List<FieldProps> fieldsToTestMulti = null;
-  static List<FieldProps> fieldsToTestGroupSortFirst = null;
-  static List<FieldProps> fieldsToTestGroupSortLast = null;
+  volatile static List<FieldProps> fieldsToTestSingle = null;
+  volatile static List<FieldProps> fieldsToTestMulti = null;
+  volatile static List<FieldProps> fieldsToTestGroupSortFirst = null;
+  volatile static List<FieldProps> fieldsToTestGroupSortLast = null;
 
   @Before
   public void createCluster() throws Exception {
@@ -168,20 +168,12 @@ public class DocValuesNotIndexedTest extends SolrCloudTestCase {
   public void after() throws Exception {
     shutdownCluster();
     
-    resetFieldBases(fieldsToTestSingle);
-    resetFieldBases(fieldsToTestMulti);
-    resetFieldBases(fieldsToTestGroupSortFirst);
-    resetFieldBases(fieldsToTestGroupSortLast);
+    fieldsToTestSingle = null;
+    fieldsToTestMulti = null;
+    fieldsToTestGroupSortFirst = null;
+    fieldsToTestGroupSortLast = null;
   }
 
-  private void resetFieldBases(List<FieldProps> props) {
-    // OK, it's not bad with the int and string fields, but every time a new test counts on docs being
-    // indexed so they sort in a particular order, then particularly the boolean and string fields need to be
-    // reset to a known state.
-    for (FieldProps prop : props) {
-      prop.resetBase();
-    }
-  }
   @Test
   public void testDistribFaceting() throws IOException, SolrServerException {
     // For this test, I want to insure that there are shards that do _not_ have a doc with any of the DV_only 
@@ -229,7 +221,7 @@ public class DocValuesNotIndexedTest extends SolrCloudTestCase {
 
   // We should be able to sort thing with missing first/last and that are _NOT_ present at all on one server.
   @Test
-  // 12-Jun-2018 @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 26-Mar-2018
+  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-12028")
   public void testGroupingSorting() throws IOException, SolrServerException {
     CloudSolrClient client = cluster.getSolrClient();
 
@@ -349,6 +341,9 @@ public class DocValuesNotIndexedTest extends SolrCloudTestCase {
       // Special handling until SOLR-9802 is fixed
       if (prop.getName().startsWith("date")) continue;
       // SOLR-9802 to here
+      
+      // TODO: gsf fails this
+      if (prop.getName().endsWith("GSF") ) continue;
 
       final SolrQuery solrQuery = new SolrQuery(
           "q", "*:*",


[11/16] lucene-solr:master: SOLR-12801: raise jetty idle socket timeout

Posted by ma...@apache.org.
SOLR-12801: raise jetty idle socket timeout


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/a9a5cdc3
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/a9a5cdc3
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/a9a5cdc3

Branch: refs/heads/master
Commit: a9a5cdc34dc2333455401510b9518767534c56b8
Parents: 40432cd
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 10:29:18 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../org/apache/solr/client/solrj/embedded/JettySolrRunner.java     | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a9a5cdc3/solr/core/src/java/org/apache/solr/client/solrj/embedded/JettySolrRunner.java
----------------------------------------------------------------------
diff --git a/solr/core/src/java/org/apache/solr/client/solrj/embedded/JettySolrRunner.java b/solr/core/src/java/org/apache/solr/client/solrj/embedded/JettySolrRunner.java
index 24caec8..32a9bcc 100644
--- a/solr/core/src/java/org/apache/solr/client/solrj/embedded/JettySolrRunner.java
+++ b/solr/core/src/java/org/apache/solr/client/solrj/embedded/JettySolrRunner.java
@@ -85,7 +85,7 @@ public class JettySolrRunner {
 
   private static final int THREAD_POOL_MAX_THREADS = 10000;
   // NOTE: needs to be larger than SolrHttpClient.threadPoolSweeperMaxIdleTime
-  private static final int THREAD_POOL_MAX_IDLE_TIME_MS = 160000;
+  private static final int THREAD_POOL_MAX_IDLE_TIME_MS = 260000;
   
   Server server;
 


[06/16] lucene-solr:master: SOLR-13037: Add @AwaitsFix annotation to TestSimGenericDistributedQueue.

Posted by ma...@apache.org.
SOLR-13037: Add @AwaitsFix annotation to TestSimGenericDistributedQueue.


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/e25d6850
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/e25d6850
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/e25d6850

Branch: refs/heads/master
Commit: e25d6850c4a90a053c2c34ccd7478afb508a479a
Parents: 54ca26a
Author: markrmiller <ma...@apache.org>
Authored: Sat Dec 8 11:34:02 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../cloud/autoscaling/sim/TestSimGenericDistributedQueue.java    | 4 +++-
 1 file changed, 3 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/e25d6850/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimGenericDistributedQueue.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimGenericDistributedQueue.java b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimGenericDistributedQueue.java
index 89f3366..68c37a4 100644
--- a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimGenericDistributedQueue.java
+++ b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimGenericDistributedQueue.java
@@ -16,13 +16,15 @@
  */
 package org.apache.solr.cloud.autoscaling.sim;
 
+import org.apache.lucene.util.LuceneTestCase.AwaitsFix;
+
 import org.apache.solr.client.solrj.cloud.DistributedQueue;
 import org.apache.solr.client.solrj.cloud.DistribStateManager;
 
 /**
  *
  */
-// commented 4-Sep-2018 @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 2018-02-26
+@AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-13037")
 public class TestSimGenericDistributedQueue extends TestSimDistributedQueue {
   DistribStateManager stateManager = new SimDistribStateManager();
 


[10/16] lucene-solr:master: SOLR-12801: tweak shard count specificiation

Posted by ma...@apache.org.
SOLR-12801: tweak shard count specificiation


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/40432cdf
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/40432cdf
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/40432cdf

Branch: refs/heads/master
Commit: 40432cdfbcfba7e94a7de1eaf28e30e42bd6d4be
Parents: eac3f58
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 10:29:05 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/40432cdf/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java b/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
index d43e1dc..d69b47b 100644
--- a/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
@@ -55,12 +55,13 @@ public class MultiThreadedOCPTest extends AbstractFullDistribZkTestBase {
 
   public MultiThreadedOCPTest() {
     sliceCount = 2;
+    
+    fixShardCount(3);
   }
 
   @Test
 // commented 20-July-2018   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
 //commented 20-Sep-2018 @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // added 17-Aug-2018
-  @ShardsFixed(num = 3)
   public void test() throws Exception {
     testParallelCollectionAPICalls();
     testTaskExclusivity();


[05/16] lucene-solr:master: SOLR-12923: Harden AutoScalingHandlerTest.

Posted by ma...@apache.org.
SOLR-12923: Harden AutoScalingHandlerTest.


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/1184fbed
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/1184fbed
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/1184fbed

Branch: refs/heads/master
Commit: 1184fbed63bbb4053f00a77d51bce45221c216aa
Parents: b94911b
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 00:15:44 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../org/apache/solr/cloud/autoscaling/AutoScalingHandlerTest.java   | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/1184fbed/solr/core/src/test/org/apache/solr/cloud/autoscaling/AutoScalingHandlerTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/autoscaling/AutoScalingHandlerTest.java b/solr/core/src/test/org/apache/solr/cloud/autoscaling/AutoScalingHandlerTest.java
index d8219ab..fd3f563 100644
--- a/solr/core/src/test/org/apache/solr/cloud/autoscaling/AutoScalingHandlerTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/autoscaling/AutoScalingHandlerTest.java
@@ -792,6 +792,7 @@ public class AutoScalingHandlerTest extends SolrCloudTestCase {
     CollectionAdminRequest.Create create = CollectionAdminRequest.Create.createCollection("readApiTestViolations", CONFIGSET_NAME, 1, 6)
         .setMaxShardsPerNode(3);
     CollectionAdminResponse adminResponse = create.process(solrClient);
+    cluster.waitForActiveCollection("readApiTestViolations", 1, 6);
     assertTrue(adminResponse.isSuccess());
 
     // reset the original cluster policy


[08/16] lucene-solr:master: SOLR-12801: harden CollectionsAPIDistributedZkTest

Posted by ma...@apache.org.
SOLR-12801: harden CollectionsAPIDistributedZkTest


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/906e32af
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/906e32af
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/906e32af

Branch: refs/heads/master
Commit: 906e32af1384fe5ece66beb57e8f8619afd1807b
Parents: 65bfb16
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 00:28:15 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../CollectionsAPIDistributedZkTest.java            | 16 ++++++++--------
 1 file changed, 8 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/906e32af/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIDistributedZkTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIDistributedZkTest.java b/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIDistributedZkTest.java
index d019dd8..42a2e40 100644
--- a/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIDistributedZkTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/api/collections/CollectionsAPIDistributedZkTest.java
@@ -474,20 +474,20 @@ public class CollectionsAPIDistributedZkTest extends SolrCloudTestCase {
         .add("id", "7")
         .add("id", "8")
         .commit(cluster.getSolrClient(), collectionName);
+    long numFound = 0;
     TimeOut timeOut = new TimeOut(10, TimeUnit.SECONDS, TimeSource.NANO_TIME);
     while (!timeOut.hasTimedOut()) {
-      try {
-        long numFound = cluster.getSolrClient().query(collectionName, new SolrQuery("*:*")).getResults().getNumFound();
-        assertEquals(3, numFound);
+
+      numFound = cluster.getSolrClient().query(collectionName, new SolrQuery("*:*")).getResults().getNumFound();
+      if (numFound == 3) {
         break;
-      } catch (Exception e) {
-        // Query node can have stale clusterstate
-        log.info("Error when query " + collectionName, e);
-        Thread.sleep(500);
       }
+
+      Thread.sleep(500);
     }
+    
     if (timeOut.hasTimedOut()) {
-      fail("Timeout on query " + collectionName);
+      fail("Timeout waiting to see 3 found, instead saw " + numFound + " for collection " + collectionName);
     }
 
     checkNoTwoShardsUseTheSameIndexDir();


[07/16] lucene-solr:master: SOLR-12801: harden CollectionsAPISolrJTest

Posted by ma...@apache.org.
SOLR-12801: harden CollectionsAPISolrJTest


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/65bfb163
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/65bfb163
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/65bfb163

Branch: refs/heads/master
Commit: 65bfb1639ce1b9f19b052953e453cf36fbf07b58
Parents: 1184fbe
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 00:21:28 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../src/test/org/apache/solr/cloud/CollectionsAPISolrJTest.java    | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/65bfb163/solr/core/src/test/org/apache/solr/cloud/CollectionsAPISolrJTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/CollectionsAPISolrJTest.java b/solr/core/src/test/org/apache/solr/cloud/CollectionsAPISolrJTest.java
index ef19728..0925eee 100644
--- a/solr/core/src/test/org/apache/solr/cloud/CollectionsAPISolrJTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/CollectionsAPISolrJTest.java
@@ -130,7 +130,7 @@ public class CollectionsAPISolrJTest extends SolrCloudTestCase {
           .build()
           .process(cluster.getSolrClient());
 
-      for (int i = 0; i < 10; i++) {
+      for (int i = 0; i < 30; i++) {
         Map m = cluster.getSolrClient().getZkStateReader().getClusterProperty(COLLECTION_DEF, null);
         if (m != null) break;
         Thread.sleep(10);


[12/16] lucene-solr:master: SOLR-12988: Disable SSL on Java 11/12 for now.

Posted by ma...@apache.org.
SOLR-12988: Disable SSL on Java 11/12 for now.


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/3eb2612e
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/3eb2612e
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/3eb2612e

Branch: refs/heads/master
Commit: 3eb2612e675c5b85452e78123745e68475f7dd40
Parents: 0aef561
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 14:45:35 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 lucene/core/src/java/org/apache/lucene/util/Constants.java  | 1 +
 .../org/apache/solr/client/solrj/embedded/SSLConfig.java    | 9 ++++++++-
 .../org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java  | 2 ++
 .../test/org/apache/solr/cloud/TestSSLRandomization.java    | 2 ++
 .../client/solrj/impl/HttpSolrClientSSLAuthConPoolTest.java | 4 ++++
 .../src/java/org/apache/solr/util/SSLTestConfig.java        | 3 ++-
 6 files changed, 19 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/3eb2612e/lucene/core/src/java/org/apache/lucene/util/Constants.java
----------------------------------------------------------------------
diff --git a/lucene/core/src/java/org/apache/lucene/util/Constants.java b/lucene/core/src/java/org/apache/lucene/util/Constants.java
index 007ef85..653c1e3 100644
--- a/lucene/core/src/java/org/apache/lucene/util/Constants.java
+++ b/lucene/core/src/java/org/apache/lucene/util/Constants.java
@@ -87,6 +87,7 @@ public final class Constants {
 
   public static final boolean JRE_IS_MINIMUM_JAVA8 = JVM_MAJOR_VERSION > 1 || (JVM_MAJOR_VERSION == 1 && JVM_MINOR_VERSION >= 8);
   public static final boolean JRE_IS_MINIMUM_JAVA9 = JVM_MAJOR_VERSION > 1 || (JVM_MAJOR_VERSION == 1 && JVM_MINOR_VERSION >= 9);
+  public static final boolean JRE_IS_MINIMUM_JAVA11 = JVM_MAJOR_VERSION > 1 || (JVM_MAJOR_VERSION == 1 && JVM_MINOR_VERSION >= 11);
 
   /**
    * This is the internal Lucene version, including bugfix versions, recorded into each segment.

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/3eb2612e/solr/core/src/java/org/apache/solr/client/solrj/embedded/SSLConfig.java
----------------------------------------------------------------------
diff --git a/solr/core/src/java/org/apache/solr/client/solrj/embedded/SSLConfig.java b/solr/core/src/java/org/apache/solr/client/solrj/embedded/SSLConfig.java
index 62c9024..e641816 100644
--- a/solr/core/src/java/org/apache/solr/client/solrj/embedded/SSLConfig.java
+++ b/solr/core/src/java/org/apache/solr/client/solrj/embedded/SSLConfig.java
@@ -16,6 +16,7 @@
  */
 package org.apache.solr.client.solrj.embedded;
 
+import org.apache.lucene.util.Constants;
 import org.eclipse.jetty.util.ssl.SslContextFactory;
 
 /** 
@@ -34,7 +35,13 @@ public class SSLConfig {
 
   /** NOTE: all other settings are ignored if useSSL is false; trustStore settings are ignored if clientAuth is false */
   public SSLConfig(boolean useSSL, boolean clientAuth, String keyStore, String keyStorePassword, String trustStore, String trustStorePassword) {
-    this.useSsl = useSSL;
+    // @AwaitsFix: SOLR-12988 - ssl issues on Java 11/12
+    if (Constants.JRE_IS_MINIMUM_JAVA11) {
+      this.useSsl = false;
+    } else {
+      this.useSsl = useSSL;
+    }
+
     this.clientAuth = clientAuth;
     this.keyStore = keyStore;
     this.keyStorePassword = keyStorePassword;

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/3eb2612e/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java b/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
index 97a2de0..37080e1 100644
--- a/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
+++ b/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
@@ -85,6 +85,8 @@ public class TestMiniSolrCloudClusterSSL extends SolrTestCaseJ4 {
   
   @Before
   public void before() {
+    assumeFalse("@AwaitsFix: SOLR-12988 - ssl issues on Java 11/12", Constants.JRE_IS_MINIMUM_JAVA11);
+    
     // undo the randomization of our super class
     log.info("NOTE: This Test ignores the randomized SSL & clientAuth settings selected by base class");
     HttpClientUtil.resetHttpClientBuilder(); // also resets SchemaRegistryProvider

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/3eb2612e/solr/core/src/test/org/apache/solr/cloud/TestSSLRandomization.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/TestSSLRandomization.java b/solr/core/src/test/org/apache/solr/cloud/TestSSLRandomization.java
index e846f73..1241189 100644
--- a/solr/core/src/test/org/apache/solr/cloud/TestSSLRandomization.java
+++ b/solr/core/src/test/org/apache/solr/cloud/TestSSLRandomization.java
@@ -19,6 +19,7 @@ package org.apache.solr.cloud;
 import java.lang.invoke.MethodHandles;
 import java.util.Arrays;
 
+import org.apache.lucene.util.Constants;
 import org.apache.solr.SolrTestCaseJ4;
 import org.apache.solr.util.SSLTestConfig;
 import org.apache.solr.util.RandomizeSSL;
@@ -43,6 +44,7 @@ public class TestSSLRandomization extends SolrCloudTestCase {
 
   @BeforeClass
   public static void createMiniSolrCloudCluster() throws Exception {
+    assumeFalse("@AwaitsFix: SOLR-12988 - ssl issues on Java 11/12", Constants.JRE_IS_MINIMUM_JAVA11);
     configureCluster(TestMiniSolrCloudClusterSSL.NUM_SERVERS).configure();
   }
   

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/3eb2612e/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientSSLAuthConPoolTest.java
----------------------------------------------------------------------
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientSSLAuthConPoolTest.java b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientSSLAuthConPoolTest.java
index 3a39c67..3b59049 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientSSLAuthConPoolTest.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientSSLAuthConPoolTest.java
@@ -20,14 +20,18 @@ package org.apache.solr.client.solrj.impl;
 import java.net.URL;
 import java.util.Arrays;
 
+import org.apache.lucene.util.Constants;
 import org.apache.solr.util.RandomizeSSL;
 import org.junit.BeforeClass;
 
 @RandomizeSSL(1.0)
+
 public class HttpSolrClientSSLAuthConPoolTest extends HttpSolrClientConPoolTest {
 
     @BeforeClass
     public static void checkUrls() throws Exception {
+      assumeFalse("@AwaitsFix: SOLR-12988 - ssl issues on Java 11/12", Constants.JRE_IS_MINIMUM_JAVA11);
+      
       URL[] urls = new URL[] {
           jetty.getBaseUrl(), yetty.getBaseUrl() 
       };

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/3eb2612e/solr/test-framework/src/java/org/apache/solr/util/SSLTestConfig.java
----------------------------------------------------------------------
diff --git a/solr/test-framework/src/java/org/apache/solr/util/SSLTestConfig.java b/solr/test-framework/src/java/org/apache/solr/util/SSLTestConfig.java
index 3b03f6e..307f547 100644
--- a/solr/test-framework/src/java/org/apache/solr/util/SSLTestConfig.java
+++ b/solr/test-framework/src/java/org/apache/solr/util/SSLTestConfig.java
@@ -98,8 +98,9 @@ public class SSLTestConfig extends SSLConfig {
    */
   public SSLTestConfig(boolean useSSL, boolean clientAuth, boolean checkPeerName) {
     super(useSSL, clientAuth, null, TEST_KEYSTORE_PASSWORD, null, TEST_KEYSTORE_PASSWORD);
+
     this.checkPeerName = checkPeerName;
-    
+
     final String resourceName = checkPeerName
       ? TEST_KEYSTORE_LOCALHOST_RESOURCE : TEST_KEYSTORE_BOGUSHOST_RESOURCE;
     trustStore = keyStore = Resource.newClassPathResource(resourceName);


[09/16] lucene-solr:master: SOLR-12801: wait 60 seconds instead of 30 for cores to close

Posted by ma...@apache.org.
SOLR-12801: wait 60 seconds instead of 30 for cores to close


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/eac3f58c
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/eac3f58c
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/eac3f58c

Branch: refs/heads/master
Commit: eac3f58c4395534dd739fe645850e9f120f51323
Parents: 906e32a
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 01:08:33 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/eac3f58c/solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java
----------------------------------------------------------------------
diff --git a/solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java b/solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java
index 13d7f22..9a7fef1 100644
--- a/solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java
+++ b/solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java
@@ -313,7 +313,7 @@ public abstract class SolrTestCaseJ4 extends LuceneTestCase {
 
       if (suiteFailureMarker.wasSuccessful()) {
         // if the tests passed, make sure everything was closed / released
-        String orr = clearObjectTrackerAndCheckEmpty(30, false);
+        String orr = clearObjectTrackerAndCheckEmpty(60, false);
         assertNull(orr, orr);
       } else {
         ObjectReleaseTracker.tryClose();


[02/16] lucene-solr:master: SOLR-12801: use waitForActiveCollection call

Posted by ma...@apache.org.
SOLR-12801: use waitForActiveCollection call


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/0824f7b0
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/0824f7b0
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/0824f7b0

Branch: refs/heads/master
Commit: 0824f7b045f4f9b1376de7f6707ae37bf7a48d74
Parents: f6063a1
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 15:51:17 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../org/apache/solr/cloud/AssignBackwardCompatibilityTest.java  | 5 +++--
 .../src/test/org/apache/solr/cloud/TestCloudConsistency.java    | 2 ++
 .../test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java | 3 +--
 .../apache/solr/cloud/api/collections/CustomCollectionTest.java | 2 ++
 4 files changed, 8 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0824f7b0/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java b/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java
index 8700e14..c1ba972 100644
--- a/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java
@@ -53,6 +53,7 @@ public class AssignBackwardCompatibilityTest extends SolrCloudTestCase {
     CollectionAdminRequest.createCollection(COLLECTION, 1, 4)
         .setMaxShardsPerNode(1000)
         .process(cluster.getSolrClient());
+    cluster.waitForActiveCollection(COLLECTION, 1, 4);
   }
 
   @Test
@@ -75,7 +76,7 @@ public class AssignBackwardCompatibilityTest extends SolrCloudTestCase {
         clearedCounter = true;
       }
       if (deleteReplica) {
-        waitForState("Expected " + numLiveReplicas + " active replicas", COLLECTION, clusterShape(1, numLiveReplicas));
+        cluster.waitForActiveCollection(COLLECTION, 1, numLiveReplicas);
         DocCollection dc = getCollectionState(COLLECTION);
         Replica replica = getRandomReplica(dc.getSlice("shard1"), (r) -> r.getState() == Replica.State.ACTIVE);
         CollectionAdminRequest.deleteReplica(COLLECTION, "shard1", replica.getName()).process(cluster.getSolrClient());
@@ -90,7 +91,7 @@ public class AssignBackwardCompatibilityTest extends SolrCloudTestCase {
         assertFalse("Core name is not unique coreName=" + coreName + " " + coreNames, coreNames.contains(coreName));
         coreNames.add(coreName);
         numLiveReplicas++;
-        waitForState("Expected " + numLiveReplicas + " active replicas", COLLECTION, clusterShape(1, numLiveReplicas));
+        cluster.waitForActiveCollection(COLLECTION, 1, numLiveReplicas);
 
         Replica newReplica = getCollectionState(COLLECTION).getReplicas().stream()
             .filter(r -> r.getCoreName().equals(coreName))

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0824f7b0/solr/core/src/test/org/apache/solr/cloud/TestCloudConsistency.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/TestCloudConsistency.java b/solr/core/src/test/org/apache/solr/cloud/TestCloudConsistency.java
index db558c5b..9b27522 100644
--- a/solr/core/src/test/org/apache/solr/cloud/TestCloudConsistency.java
+++ b/solr/core/src/test/org/apache/solr/cloud/TestCloudConsistency.java
@@ -229,6 +229,8 @@ public class TestCloudConsistency extends SolrCloudTestCase {
       return newLeader != null && newLeader.getName().equals(leader.getName());
     });
     waitForState("Timeout waiting for active collection", collection, clusterShape(1, 3));
+    
+    cluster.waitForActiveCollection(collection, 1, 3);
   }
 
   private void addDocs(String collection, int numDocs, int startId) throws SolrServerException, IOException {

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0824f7b0/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java b/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
index 37080e1..7cb82c5 100644
--- a/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
+++ b/solr/core/src/test/org/apache/solr/cloud/TestMiniSolrCloudClusterSSL.java
@@ -263,8 +263,7 @@ public class TestMiniSolrCloudClusterSSL extends SolrTestCaseJ4 {
     CollectionAdminRequest.createCollection(collection, CONF_NAME, NUM_SERVERS, 1)
         .withProperty("config", "solrconfig-tlog.xml")
         .process(cloudClient);
-    ZkStateReader zkStateReader = cloudClient.getZkStateReader();
-    AbstractDistribZkTestBase.waitForRecoveriesToFinish(collection, zkStateReader, true, true, 330);
+    cluster.waitForActiveCollection(collection, NUM_SERVERS, NUM_SERVERS);
     assertEquals("sanity query", 0, cloudClient.query(collection, params("q","*:*")).getStatus());
   }
   

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0824f7b0/solr/core/src/test/org/apache/solr/cloud/api/collections/CustomCollectionTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/api/collections/CustomCollectionTest.java b/solr/core/src/test/org/apache/solr/cloud/api/collections/CustomCollectionTest.java
index 5a14a23..d4f3783 100644
--- a/solr/core/src/test/org/apache/solr/cloud/api/collections/CustomCollectionTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/api/collections/CustomCollectionTest.java
@@ -161,6 +161,8 @@ public class CustomCollectionTest extends SolrCloudTestCase {
         .setMaxShardsPerNode(maxShardsPerNode)
         .setRouterField(shard_fld)
         .process(cluster.getSolrClient());
+    
+    cluster.waitForActiveCollection(collectionName, numShards, numShards * replicationFactor);
 
     new UpdateRequest()
         .add("id", "6", shard_fld, "a")


[16/16] lucene-solr:master: SOLR-12801: boost wait to try and harden

Posted by ma...@apache.org.
SOLR-12801: boost wait to try and harden


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/f6063a14
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/f6063a14
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/f6063a14

Branch: refs/heads/master
Commit: f6063a14611da106aae4fe218cd0943c7d61af29
Parents: 4133ce4
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 15:12:42 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../src/test/org/apache/solr/cloud/cdcr/CdcrBootstrapTest.java     | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f6063a14/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrBootstrapTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrBootstrapTest.java b/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrBootstrapTest.java
index 383b3ef..cc3f6ed 100644
--- a/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrBootstrapTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrBootstrapTest.java
@@ -114,7 +114,7 @@ public class CdcrBootstrapTest extends SolrTestCaseJ4 {
         target.waitForActiveCollection("cdcr-target", 1, 2);
         CloudSolrClient targetSolrClient = target.getSolrClient();
         targetSolrClient.setDefaultCollection("cdcr-target");
-        Thread.sleep(1000);
+        Thread.sleep(3000);
 
         CdcrTestsUtil.cdcrStart(targetSolrClient);
         CdcrTestsUtil.cdcrStart(sourceSolrClient);


[14/16] lucene-solr:master: SOLR-12923: Harden TestSimTriggerIntegration.testNodeMarkersRegistration.

Posted by ma...@apache.org.
SOLR-12923: Harden TestSimTriggerIntegration.testNodeMarkersRegistration.


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/4133ce4c
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/4133ce4c
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/4133ce4c

Branch: refs/heads/master
Commit: 4133ce4cc167a80ed20f7763de4b4a8ab5d0316f
Parents: 3eb2612
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 15:10:12 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../autoscaling/sim/TestSimTriggerIntegration.java    | 14 ++++++++++++++
 1 file changed, 14 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/4133ce4c/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimTriggerIntegration.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimTriggerIntegration.java b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimTriggerIntegration.java
index 1b177f9..8f37ddb 100644
--- a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimTriggerIntegration.java
+++ b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimTriggerIntegration.java
@@ -20,6 +20,7 @@ package org.apache.solr.cloud.autoscaling.sim;
 import static org.apache.solr.cloud.autoscaling.AutoScalingHandlerTest.createAutoScalingRequest;
 import static org.apache.solr.cloud.autoscaling.ScheduledTriggers.DEFAULT_SCHEDULED_TRIGGER_DELAY_SECONDS;
 
+import java.io.IOException;
 import java.lang.invoke.MethodHandles;
 import java.util.ArrayList;
 import java.util.Collections;
@@ -66,6 +67,7 @@ import org.apache.solr.common.util.TimeSource;
 import org.apache.solr.core.SolrResourceLoader;
 import org.apache.solr.util.LogLevel;
 import org.apache.solr.util.TimeOut;
+import org.apache.zookeeper.KeeperException;
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
@@ -848,7 +850,19 @@ public class TestSimTriggerIntegration extends SimSolrCloudTestCase {
     cluster.getTimeSource().sleep(5000);
     // verify that a znode does NOT exist - there's no nodeLost trigger,
     // so the new overseer cleaned up existing nodeLost markers
+    
     String pathLost = ZkStateReader.SOLR_AUTOSCALING_NODE_LOST_PATH + "/" + overseerLeader;
+    
+    TimeOut timeout = new TimeOut(30, TimeUnit.SECONDS, TimeSource.NANO_TIME);
+    timeout.waitFor("Path " + pathLost + " exists", () -> {
+      try {
+        return !cluster.getDistribStateManager().hasData(pathLost);
+      } catch (IOException | KeeperException | InterruptedException e) {
+        e.printStackTrace();
+        throw new RuntimeException(e);
+      }
+    });
+
     assertFalse("Path " + pathLost + " exists", cluster.getDistribStateManager().hasData(pathLost));
 
     listener.reset();


[03/16] lucene-solr:master: SOLR-12923: Harden TestSimNodeLostTrigger#testTrigger.

Posted by ma...@apache.org.
SOLR-12923: Harden TestSimNodeLostTrigger#testTrigger.


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/0aef5612
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/0aef5612
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/0aef5612

Branch: refs/heads/master
Commit: 0aef56124529f866da56eec2cc3ade2bf702fbaf
Parents: 3f1b75a
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 11:59:41 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../apache/solr/cloud/autoscaling/sim/TestSimNodeLostTrigger.java  | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0aef5612/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimNodeLostTrigger.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimNodeLostTrigger.java b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimNodeLostTrigger.java
index c1c5f4c..0a9bd19 100644
--- a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimNodeLostTrigger.java
+++ b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimNodeLostTrigger.java
@@ -109,7 +109,7 @@ public class TestSimNodeLostTrigger extends SimSolrCloudTestCase {
       do {
         trigger.run();
         timeSource.sleep(1000);
-        if (counter++ > 10) {
+        if (counter++ > 20) {
           fail("Lost node was not discovered by trigger even after 10 seconds");
         }
       } while (!fired.get());


[13/16] lucene-solr:master: SOLR-12801: harden MultiThreadedOCPTest

Posted by ma...@apache.org.
SOLR-12801: harden MultiThreadedOCPTest


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/3f1b75ab
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/3f1b75ab
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/3f1b75ab

Branch: refs/heads/master
Commit: 3f1b75ab82b1924ab124f0e19be4603a7975d70b
Parents: a9a5cdc
Author: markrmiller <ma...@apache.org>
Authored: Sun Dec 9 11:17:24 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java | 8 ++++----
 1 file changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/3f1b75ab/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java b/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
index d69b47b..a688897 100644
--- a/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/MultiThreadedOCPTest.java
@@ -75,7 +75,7 @@ public class MultiThreadedOCPTest extends AbstractFullDistribZkTestBase {
       DistributedQueue distributedQueue = new ZkDistributedQueue(cloudClient.getZkStateReader().getZkClient(),
           "/overseer/collection-queue-work", new Stats());
       //fill the work queue with blocked tasks by adding more than the no:of parallel tasks
-      for (int i = 0; i < MAX_PARALLEL_TASKS+5; i++) {
+      for (int i = 0; i < MAX_PARALLEL_TASKS + 15; i++) {
         distributedQueue.offer(Utils.toJSON(Utils.makeMap(
             "collection", "A_COLL",
             QUEUE_OPERATION, MOCK_COLL_TASK.toLower(),
@@ -87,7 +87,7 @@ public class MultiThreadedOCPTest extends AbstractFullDistribZkTestBase {
         log.info("MOCK task added {}", i);
 
       }
-      Thread.sleep(10);//wait and post the next message
+      Thread.sleep(100);//wait and post the next message
 
       //this is not going to be blocked because it operates on another collection
       distributedQueue.offer(Utils.toJSON(Utils.makeMap(
@@ -99,7 +99,7 @@ public class MultiThreadedOCPTest extends AbstractFullDistribZkTestBase {
 
 
       Long acoll = null, bcoll = null;
-      for (int i = 0; i < 100; i++) {
+      for (int i = 0; i < 500; i++) {
         if (bcoll == null) {
           CollectionAdminResponse statusResponse = getStatusResponse("200", client);
           bcoll = (Long) statusResponse.getResponse().get("MOCK_FINISHED");
@@ -112,7 +112,7 @@ public class MultiThreadedOCPTest extends AbstractFullDistribZkTestBase {
         Thread.sleep(100);
       }
       assertTrue(acoll != null && bcoll != null);
-      assertTrue(acoll > bcoll);
+      assertTrue("acoll: " + acoll + " bcoll: " + bcoll, acoll > bcoll);
     }
 
   }


[04/16] lucene-solr:master: SOLR-12801: don't do single index check here on windows.

Posted by ma...@apache.org.
SOLR-12801: don't do single index check here on windows.


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/b94911b2
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/b94911b2
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/b94911b2

Branch: refs/heads/master
Commit: b94911b260d8411cde755e2aa2c18694b3f9a825
Parents: e25d685
Author: markrmiller <ma...@apache.org>
Authored: Sat Dec 8 11:40:00 2018 -0600
Committer: markrmiller <ma...@apache.org>
Committed: Sun Dec 9 18:31:28 2018 -0600

----------------------------------------------------------------------
 .../test/org/apache/solr/handler/TestReplicationHandler.java   | 6 +++++-
 1 file changed, 5 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/b94911b2/solr/core/src/test/org/apache/solr/handler/TestReplicationHandler.java
----------------------------------------------------------------------
diff --git a/solr/core/src/test/org/apache/solr/handler/TestReplicationHandler.java b/solr/core/src/test/org/apache/solr/handler/TestReplicationHandler.java
index e3a9377..f1a9a86 100644
--- a/solr/core/src/test/org/apache/solr/handler/TestReplicationHandler.java
+++ b/solr/core/src/test/org/apache/solr/handler/TestReplicationHandler.java
@@ -42,6 +42,7 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.lucene.store.Directory;
 import org.apache.lucene.store.FSDirectory;
+import org.apache.lucene.util.Constants;
 import org.apache.lucene.util.LuceneTestCase;
 import org.apache.lucene.util.LuceneTestCase.Slow;
 import org.apache.lucene.util.TestUtil;
@@ -899,7 +900,10 @@ public class TestReplicationHandler extends SolrTestCaseJ4 {
         assertVersions(masterClient, slaveClient);
         
         checkForSingleIndex(masterJetty);
-        checkForSingleIndex(slaveJetty);
+        
+        if (!Constants.WINDOWS) {
+          checkForSingleIndex(slaveJetty);
+        }
         
         if (random().nextBoolean()) {
           // move the slave ahead