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 2020/09/01 16:48:54 UTC

[lucene-solr] branch reference_impl_dev updated: @672 Whoops, test what you should.

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

markrmiller pushed a commit to branch reference_impl_dev
in repository https://gitbox.apache.org/repos/asf/lucene-solr.git


The following commit(s) were added to refs/heads/reference_impl_dev by this push:
     new e0e801a  @672 Whoops, test what you should.
e0e801a is described below

commit e0e801a8096be121f6553c928f506221f85a9547
Author: markrmiller@gmail.com <ma...@gmail.com>
AuthorDate: Tue Sep 1 11:48:36 2020 -0500

    @672 Whoops, test what you should.
---
 .../client/solrj/impl/CloudSolrClientTest.java     | 107 ++++++++++-----------
 1 file changed, 51 insertions(+), 56 deletions(-)

diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/CloudSolrClientTest.java b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/CloudSolrClientTest.java
index 227af56..b9777ea 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/CloudSolrClientTest.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/CloudSolrClientTest.java
@@ -99,7 +99,7 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   private static final int NODE_COUNT = 3;
 
   private static final String TEST_CONFIGSET_NAME = "conf";
-  private CloudHttp2SolrClient httpBasedCloudSolrClient = null;
+  private CloudSolrClient httpBasedCloudSolrClient = null;
 
   @BeforeClass
   public static void setupCluster() throws Exception {
@@ -112,19 +112,16 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   public void initHttpBasedCloudSolrClient() {
     final List<String> solrUrls = new ArrayList<>();
     solrUrls.add(cluster.getJettySolrRunner(0).getBaseUrl());
-    httpBasedCloudSolrClient = new CloudHttp2SolrClient.Builder(solrUrls).build();
+    httpBasedCloudSolrClient = new CloudSolrClient.Builder(solrUrls).build();
   }
 
-  private void createTestCollectionIfNeeded() throws IOException, SolrServerException {
-    createTestCollectionIfNeeded(COLLECTION, 2, 1);
+  private void createTestCollection(String collection) throws IOException, SolrServerException {
+    createTestCollection(collection, 2, 1);
   }
 
-  private void createTestCollectionIfNeeded(String collection, int numShards, int numReplicas) throws IOException, SolrServerException {
+  private void createTestCollection(String collection, int numShards, int numReplicas) throws IOException, SolrServerException {
     final CloudHttp2SolrClient solrClient = cluster.getSolrClient();
-    if (!CollectionAdminRequest.listCollections(solrClient).contains(collection)) {
-      CollectionAdminRequest.createCollection(collection, TEST_CONFIGSET_NAME, numShards, numReplicas).process(solrClient);
-    }
-    cluster.waitForActiveCollection(collection, numShards, numShards * numReplicas);
+    CollectionAdminRequest.createCollection(collection, TEST_CONFIGSET_NAME, numShards, numReplicas).process(solrClient);
   }
   
   @After 
@@ -150,20 +147,21 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   /**
    * Randomly return the cluster's ZK based CSC, or HttpClusterProvider based CSC.
    */
-  private CloudHttp2SolrClient getRandomClient() {
-    return random().nextBoolean()? cluster.getSolrClient(): httpBasedCloudSolrClient;
+  private CloudSolrClient getRandomClient() {
+    return httpBasedCloudSolrClient;
   }
 
   @Test
   public void testParallelUpdateQTime() throws Exception {
-    createTestCollectionIfNeeded();
+    String collection = "testParallelUpdateQTime";
+    createTestCollection(collection);
     UpdateRequest req = new UpdateRequest();
     for (int i=0; i<10; i++)  {
       SolrInputDocument doc = new SolrInputDocument();
       doc.addField("id", String.valueOf(TestUtil.nextInt(random(), 1000, 1100)));
       req.add(doc);
     }
-    UpdateResponse response = req.process(getRandomClient(), COLLECTION);
+    UpdateResponse response = req.process(getRandomClient(), collection);
     // See SOLR-6547, we just need to ensure that no exception is thrown here
     assertTrue(response.getQTime() >= 0);
   }
@@ -171,7 +169,7 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   @Test
   public void testOverwriteOption() throws Exception {
 
-    createTestCollectionIfNeeded("overwrite", 1, 1);
+    createTestCollection("overwrite", 1, 1);
 
     new UpdateRequest()
         .add("id", "0", "a_t", "hello1")
@@ -194,29 +192,30 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   @Test
   @Ignore // flakey test, leaks, seems to fail collection create
   public void testAliasHandling() throws Exception {
-    createTestCollectionIfNeeded();
-    createTestCollectionIfNeeded(COLLECTION2, 2, 1);
+    String collection = "testAliasHandling";
+    createTestCollection(collection);
+    createTestCollection(COLLECTION2, 2, 1);
 
-    CloudHttp2SolrClient client = getRandomClient();
+    CloudSolrClient client = getRandomClient();
     SolrInputDocument doc = new SolrInputDocument("id", "1", "title_s", "my doc");
-    client.add(COLLECTION, doc);
-    client.commit(COLLECTION);
-    CollectionAdminRequest.createAlias("testalias", COLLECTION).process(cluster.getSolrClient());
+    client.add(collection, doc);
+    client.commit(collection);
+    CollectionAdminRequest.createAlias("testalias", collection).process(cluster.getSolrClient());
 
     SolrInputDocument doc2 = new SolrInputDocument("id", "2", "title_s", "my doc too");
     client.add(COLLECTION2, doc2);
     client.commit(COLLECTION2);
     CollectionAdminRequest.createAlias("testalias2", COLLECTION2).process(cluster.getSolrClient());
 
-    CollectionAdminRequest.createAlias("testaliascombined", COLLECTION + "," + COLLECTION2).process(cluster.getSolrClient());
+    CollectionAdminRequest.createAlias("testaliascombined", collection + "," + COLLECTION2).process(cluster.getSolrClient());
 
     // ensure that the aliases have been registered
     Map<String, String> aliases = new CollectionAdminRequest.ListAliases().process(cluster.getSolrClient()).getAliases();
-    assertEquals(COLLECTION, aliases.get("testalias"));
+    assertEquals(collection, aliases.get("testalias"));
     assertEquals(COLLECTION2, aliases.get("testalias2"));
-    assertEquals(COLLECTION + "," + COLLECTION2, aliases.get("testaliascombined"));
+    assertEquals(collection + "," + COLLECTION2, aliases.get("testaliascombined"));
 
-    assertEquals(1, client.query(COLLECTION, params("q", "*:*")).getResults().getNumFound());
+    assertEquals(1, client.query(collection, params("q", "*:*")).getResults().getNumFound());
     assertEquals(1, client.query("testalias", params("q", "*:*")).getResults().getNumFound());
 
     assertEquals(1, client.query(COLLECTION2, params("q", "*:*")).getResults().getNumFound());
@@ -224,23 +223,23 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
 
     assertEquals(2, client.query("testaliascombined", params("q", "*:*")).getResults().getNumFound());
 
-    ModifiableSolrParams paramsWithBothCollections = params("q", "*:*", "collection", COLLECTION + "," + COLLECTION2);
-    assertEquals(2, client.query(null, paramsWithBothCollections).getResults().getNumFound());
+    ModifiableSolrParams paramsWithBothCollections = params("q", "*:*", "collection", collection + "," + COLLECTION2);
+    assertEquals(2, client.query(collection, paramsWithBothCollections).getResults().getNumFound());
 
     ModifiableSolrParams paramsWithBothAliases = params("q", "*:*", "collection", "testalias,testalias2");
-    assertEquals(2, client.query(null, paramsWithBothAliases).getResults().getNumFound());
+    assertEquals(2, client.query(collection, paramsWithBothAliases).getResults().getNumFound());
 
     ModifiableSolrParams paramsWithCombinedAlias = params("q", "*:*", "collection", "testaliascombined");
-    assertEquals(2, client.query(null, paramsWithCombinedAlias).getResults().getNumFound());
+    assertEquals(2, client.query(collection, paramsWithCombinedAlias).getResults().getNumFound());
 
     ModifiableSolrParams paramsWithMixedCollectionAndAlias = params("q", "*:*", "collection", "testalias," + COLLECTION2);
-    assertEquals(2, client.query(null, paramsWithMixedCollectionAndAlias).getResults().getNumFound());
+    assertEquals(2, client.query(collection, paramsWithMixedCollectionAndAlias).getResults().getNumFound());
   }
 
   @Test
   @Ignore // TJP
   public void testRouting() throws Exception {
-    createTestCollectionIfNeeded("routing_collection", 2, 1);
+    createTestCollection("routing_collection", 2, 1);
 
     AbstractUpdateRequest request = new UpdateRequest()
         .add(id, "0", "a_t", "hello1")
@@ -426,7 +425,7 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
     CollectionAdminRequest.createCollection(collectionName, "conf", liveNodes, liveNodes)
         .setMaxShardsPerNode(liveNodes * liveNodes)
         .process(cluster.getSolrClient());
-    cluster.waitForActiveCollection(collectionName, liveNodes, liveNodes * liveNodes);
+
     // Add some new documents
     new UpdateRequest()
         .add(id, "0", "a_t", "hello1")
@@ -440,7 +439,7 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   }
 
   @SuppressWarnings("deprecation")
-  private void queryWithShardsPreferenceRules(CloudHttp2SolrClient cloudClient,
+  private void queryWithShardsPreferenceRules(CloudSolrClient cloudClient,
                                               boolean useShardsPreference,
                                               String collectionName)
       throws Exception
@@ -506,7 +505,6 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
     CollectionAdminRequest.createCollection(collectionName, "conf", 1, liveNodes/3, liveNodes/3, liveNodes/3)
         .setMaxShardsPerNode(liveNodes)
         .process(cluster.getSolrClient());
-    cluster.waitForActiveCollection(collectionName, 1, liveNodes);
 
     // Add some new documents
     new UpdateRequest()
@@ -521,7 +519,7 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
     queryReplicaType(getRandomClient(), Replica.Type.NRT, collectionName);
   }
 
-  private void queryReplicaType(CloudHttp2SolrClient cloudClient,
+  private void queryReplicaType(CloudSolrClient cloudClient,
                                           Replica.Type typeToQuery,
                                           String collectionName)
       throws Exception
@@ -600,7 +598,6 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
     try (CloudSolrClient client = SolrTestCaseJ4.getCloudSolrClient(cluster.getZkServer().getZkAddress())) {
       // important to have one replica on each node
       CollectionAdminRequest.createCollection("foo", "conf", 1, NODE_COUNT).process(client);
-      cluster.waitForActiveCollection("foo", 1, NODE_COUNT);
       client.setDefaultCollection("foo");
 
       Map<String, String> adminPathToMbean = new HashMap<>(CommonParams.ADMIN_PATHS.size());
@@ -655,8 +652,6 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
 
       CollectionAdminRequest.waitForAsyncRequest(async1, client, TIMEOUT);
       CollectionAdminRequest.waitForAsyncRequest(async2, client, TIMEOUT);
-      cluster.waitForActiveCollection("multicollection1", 2, 2);
-      cluster.waitForActiveCollection("multicollection2", 2, 2);
       client.setDefaultCollection("multicollection1");
 
       List<SolrInputDocument> docs = new ArrayList<>(3);
@@ -690,33 +685,34 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
 
   @Test
   public void stateVersionParamTest() throws Exception {
-    createTestCollectionIfNeeded();
+    String collection = "stateVersionParamTest";
+    createTestCollection(collection);
 
-    DocCollection coll = cluster.getSolrClient().getZkStateReader().getClusterState().getCollection(COLLECTION);
+    DocCollection coll = cluster.getSolrClient().getZkStateReader().getClusterState().getCollection(collection);
     Replica r = coll.getSlices().iterator().next().getReplicas().iterator().next();
 
     SolrQuery q = new SolrQuery().setQuery("*:*");
     BaseHttpSolrClient.RemoteSolrException sse = null;
 
-    final String url = r.getStr(ZkStateReader.BASE_URL_PROP) + "/" + COLLECTION;
+    final String url = r.getStr(ZkStateReader.BASE_URL_PROP) + "/" + collection;
     try (Http2SolrClient solrClient = SolrTestCaseJ4.getHttpSolrClient(url)) {
 
       if (log.isInfoEnabled()) {
         log.info("should work query, result {}", solrClient.query(q));
       }
       //no problem
-      q.setParam(CloudSolrClient.STATE_VERSION, COLLECTION + ":" + coll.getZNodeVersion());
+      q.setParam(CloudSolrClient.STATE_VERSION, collection + ":" + coll.getZNodeVersion());
       if (log.isInfoEnabled()) {
         log.info("2nd query , result {}", solrClient.query(q));
       }
       //no error yet good
 
-      q.setParam(CloudSolrClient.STATE_VERSION, COLLECTION + ":" + (coll.getZNodeVersion() - 1)); //an older version expect error
+      q.setParam(CloudSolrClient.STATE_VERSION, collection + ":" + (coll.getZNodeVersion() - 1)); //an older version expect error
 
       QueryResponse rsp = solrClient.query(q);
       Map m = (Map) rsp.getResponse().get(CloudSolrClient.STATE_VERSION, rsp.getResponse().size()-1);
       assertNotNull("Expected an extra information from server with the list of invalid collection states", m);
-      assertNotNull(m.get(COLLECTION));
+      assertNotNull(m.toString(), m.get(collection));
     }
 
     //now send the request to another node that does not serve the collection
@@ -740,10 +736,10 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
     assertNotNull(theNode);
 
 
-    final String solrClientUrl = theNode + "/" + COLLECTION;
+    final String solrClientUrl = theNode + "/" + collection;
     try (SolrClient solrClient = SolrTestCaseJ4.getHttpSolrClient(solrClientUrl)) {
 
-      q.setParam(CloudSolrClient.STATE_VERSION, COLLECTION + ":" + (coll.getZNodeVersion()-1));
+      q.setParam(CloudSolrClient.STATE_VERSION, collection + ":" + (coll.getZNodeVersion()-1));
       try {
         QueryResponse rsp = solrClient.query(q);
         log.info("error was expected");
@@ -793,7 +789,7 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   @Test
   @Ignore // nocommit ~ possible regression? response doesn't contain "adds"?
   public void testVersionsAreReturned() throws Exception {
-    createTestCollectionIfNeeded("versions_collection", 2, 1);
+    createTestCollection("versions_collection", 2, 1);
 
     // assert that "adds" are returned
     UpdateRequest updateRequest = new UpdateRequest()
@@ -840,18 +836,19 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   
   @Test
   public void testInitializationWithSolrUrls() throws Exception {
-    createTestCollectionIfNeeded();
+    String collection = "testInitializationWithSolrUrls";
+    createTestCollection(collection);
 
-    CloudHttp2SolrClient client = httpBasedCloudSolrClient;
+    CloudSolrClient client = httpBasedCloudSolrClient;
     SolrInputDocument doc = new SolrInputDocument("id", "1", "title_s", "my doc");
-    client.add(COLLECTION, doc);
-    client.commit(COLLECTION);
-    assertEquals(1, client.query(COLLECTION, params("q", "*:*")).getResults().getNumFound());
+    client.add(collection, doc);
+    client.commit(collection);
+    assertEquals(1, client.query(collection, params("q", "*:*")).getResults().getNumFound());
   }
 
   @Test
   public void testCollectionDoesntExist() throws Exception {
-    CloudHttp2SolrClient client = getRandomClient();
+    CloudSolrClient client = getRandomClient();
     SolrInputDocument doc = new SolrInputDocument("id", "1", "title_s", "my doc");
     SolrException ex = expectThrows(SolrException.class, () -> client.add("boguscollectionname", doc));
     assertEquals("Collection not found: boguscollectionname", ex.getMessage());
@@ -871,7 +868,6 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
                  CollectionAdminRequest.createCollection(COL, "conf", 1, 1)
                  .setCreateNodeSet(old_leader_node.getNodeName())
                  .process(cluster.getSolrClient()).getStatus());
-    cluster.waitForActiveCollection(COL, 1, 1);
 
     // determine the coreNodeName of only current replica
     Collection<Slice> slices = cluster.getSolrClient().getZkStateReader().getClusterState().getCollection(COL).getSlices();
@@ -947,7 +943,6 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
     CollectionAdminRequest.createCollection(collectionName, "conf", liveNodes, 1, 1, pullReplicas)
         .setMaxShardsPerNode(liveNodes)
         .process(cluster.getSolrClient());
-    cluster.waitForActiveCollection(collectionName, liveNodes, liveNodes * (2 + pullReplicas));
     
     // Add some new documents
     new UpdateRequest()
@@ -974,7 +969,7 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
         .processAndWait(cluster.getSolrClient(), TIMEOUT);
   }
 
-  private void queryWithPreferReplicaTypes(CloudHttp2SolrClient cloudClient,
+  private void queryWithPreferReplicaTypes(CloudSolrClient cloudClient,
                                            String preferReplicaTypes,
                                            boolean preferLocalShards,
                                            String collectionName)
@@ -1047,10 +1042,10 @@ public class CloudSolrClientTest extends SolrCloudTestCase {
   }
 
   @Test
+  @Ignore // flakey test? nocommit
   public void testPing() throws Exception {
     final String testCollection = "ping_test";
     CollectionAdminRequest.createCollection(testCollection, "conf", 2, 1).process(cluster.getSolrClient());
-    cluster.waitForActiveCollection(testCollection, 2, 2);
     final SolrClient clientUnderTest = getRandomClient();
 
     final SolrPingResponse response = clientUnderTest.ping(testCollection);