You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@solr.apache.org by ep...@apache.org on 2022/07/01 14:00:33 UTC

[solr] branch main updated: SOLR-16270: address dangling javadocs (#918)

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

epugh pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/solr.git


The following commit(s) were added to refs/heads/main by this push:
     new dcb415ff2f8 SOLR-16270: address dangling javadocs (#918)
dcb415ff2f8 is described below

commit dcb415ff2f84e249090dba3829bb2440f50f3041
Author: Eric Pugh <ep...@opensourceconnections.com>
AuthorDate: Fri Jul 1 10:00:28 2022 -0400

    SOLR-16270: address dangling javadocs (#918)
    
    * remove dangling javadocs
    
    * fix returns to return
    
    * spotless
---
 solr/core/src/test/org/apache/solr/CursorPagingTest.java          | 4 ++--
 solr/core/src/test/org/apache/solr/DisMaxRequestHandlerTest.java  | 2 +-
 solr/core/src/test/org/apache/solr/TestGroupingSearch.java        | 2 +-
 solr/core/src/test/org/apache/solr/TestRandomDVFaceting.java      | 2 +-
 solr/core/src/test/org/apache/solr/TestRandomFaceting.java        | 2 +-
 .../src/test/org/apache/solr/cloud/DistribCursorPagingTest.java   | 4 ++--
 .../src/test/org/apache/solr/cloud/RestartWhileUpdatingTest.java  | 4 ++--
 .../test/org/apache/solr/cloud/TestQueryingOnDownCollection.java  | 2 +-
 .../core/src/test/org/apache/solr/cloud/TestRandomFlRTGCloud.java | 2 +-
 .../org/apache/solr/cluster/events/ClusterEventProducerTest.java  | 1 -
 .../test/org/apache/solr/handler/admin/ThreadDumpHandlerTest.java | 4 ++--
 .../org/apache/solr/handler/component/TermsComponentTest.java     | 2 +-
 .../org/apache/solr/search/TestComplexPhraseQParserPlugin.java    | 8 ++++----
 .../test/org/apache/solr/search/join/TestScoreJoinQPNoScore.java  | 4 ++--
 .../test/org/apache/solr/update/TestInPlaceUpdatesStandalone.java | 2 +-
 solr/core/src/test/org/apache/solr/update/UpdateLogTest.java      | 2 +-
 16 files changed, 23 insertions(+), 24 deletions(-)

diff --git a/solr/core/src/test/org/apache/solr/CursorPagingTest.java b/solr/core/src/test/org/apache/solr/CursorPagingTest.java
index 67e9e58cf61..b9553667f4b 100644
--- a/solr/core/src/test/org/apache/solr/CursorPagingTest.java
+++ b/solr/core/src/test/org/apache/solr/CursorPagingTest.java
@@ -909,7 +909,7 @@ public class CursorPagingTest extends SolrTestCaseJ4 {
    * once, or if an id is encountered which is not expected, or if an id is <code>[elevated]
    * </code> and comes "after" any ids which were not <code>[elevated]</code>
    *
-   * @returns set of all elevated ids encountered in the walk
+   * @return set of all elevated ids encountered in the walk
    * @see #assertFullWalkNoDups(SolrParams,Consumer)
    */
   public SentinelIntSet assertFullWalkNoDupsElevated(
@@ -947,7 +947,7 @@ public class CursorPagingTest extends SolrTestCaseJ4 {
    * positive ints) encountered and throws an assertion failure if any id is encountered more than
    * once, or if the set grows above maxSize
    *
-   * @returns set of all ids encountered in the walk
+   * @return set of all ids encountered in the walk
    * @see #assertFullWalkNoDups(SolrParams,Consumer)
    */
   public SentinelIntSet assertFullWalkNoDups(int maxSize, SolrParams params) throws Exception {
diff --git a/solr/core/src/test/org/apache/solr/DisMaxRequestHandlerTest.java b/solr/core/src/test/org/apache/solr/DisMaxRequestHandlerTest.java
index 15b5045749a..c5da6805c22 100644
--- a/solr/core/src/test/org/apache/solr/DisMaxRequestHandlerTest.java
+++ b/solr/core/src/test/org/apache/solr/DisMaxRequestHandlerTest.java
@@ -29,7 +29,7 @@ public class DisMaxRequestHandlerTest extends SolrTestCaseJ4 {
     lrf =
         h.getRequestFactory(
             "/dismax", 0, 20, CommonParams.VERSION, "2.2", "facet", "true", "facet.field", "t_s");
-    /** Add some documents to the index */
+    // Add some documents to the index
     assertNull(
         h.validateUpdate(
             adoc(
diff --git a/solr/core/src/test/org/apache/solr/TestGroupingSearch.java b/solr/core/src/test/org/apache/solr/TestGroupingSearch.java
index 2cc1e24052b..68074ae41b1 100644
--- a/solr/core/src/test/org/apache/solr/TestGroupingSearch.java
+++ b/solr/core/src/test/org/apache/solr/TestGroupingSearch.java
@@ -1574,7 +1574,7 @@ public class TestGroupingSearch extends SolrTestCaseJ4 {
 
   @Test
   public void testRandomGrouping() throws Exception {
-    /**
+    /*
      * updateJ("{\"add\":{\"doc\":{\"id\":\"77\"}}}", params("commit","true"));
      * assertJQ(req("q","id:77"), "/response/numFound==1");
      *
diff --git a/solr/core/src/test/org/apache/solr/TestRandomDVFaceting.java b/solr/core/src/test/org/apache/solr/TestRandomDVFaceting.java
index 2b66a4488d3..100c1c0a6d6 100644
--- a/solr/core/src/test/org/apache/solr/TestRandomDVFaceting.java
+++ b/solr/core/src/test/org/apache/solr/TestRandomDVFaceting.java
@@ -298,7 +298,7 @@ public class TestRandomDVFaceting extends SolrTestCaseJ4 {
         responses.add(strResponse);
       }
 
-      /**
+      /*
        * String strResponse = h.query(req(params)); Object realResponse =
        * ObjectBuilder.fromJSON(strResponse);
        */
diff --git a/solr/core/src/test/org/apache/solr/TestRandomFaceting.java b/solr/core/src/test/org/apache/solr/TestRandomFaceting.java
index 408f41c63ac..fae236b08c2 100644
--- a/solr/core/src/test/org/apache/solr/TestRandomFaceting.java
+++ b/solr/core/src/test/org/apache/solr/TestRandomFaceting.java
@@ -318,7 +318,7 @@ public class TestRandomFaceting extends SolrTestCaseJ4 {
         }
       }
 
-      /**
+      /*
        * String strResponse = h.query(req(params)); Object realResponse =
        * ObjectBuilder.fromJSON(strResponse);
        */
diff --git a/solr/core/src/test/org/apache/solr/cloud/DistribCursorPagingTest.java b/solr/core/src/test/org/apache/solr/cloud/DistribCursorPagingTest.java
index a53ca1b623b..b05127cd22d 100644
--- a/solr/core/src/test/org/apache/solr/cloud/DistribCursorPagingTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/DistribCursorPagingTest.java
@@ -776,7 +776,7 @@ public class DistribCursorPagingTest extends AbstractFullDistribZkTestBase {
    * than once, or if an id is encountered which is not expected, or if an id is <code>[elevated]
    * </code> and comes "after" any ids which were not <code>[elevated]</code>
    *
-   * @returns set of all elevated ids encountered in the walk
+   * @return set of all elevated ids encountered in the walk
    * @see #assertFullWalkNoDups(SolrParams,Consumer)
    */
   public SentinelIntSet assertFullWalkNoDupsElevated(
@@ -838,7 +838,7 @@ public class DistribCursorPagingTest extends AbstractFullDistribZkTestBase {
    * the sorting in some cases and cause false negatives in the response comparisons (even if we
    * don't include "score" in the "fl")
    *
-   * @returns set of all ids encountered in the walk
+   * @return set of all ids encountered in the walk
    * @see #assertFullWalkNoDups(SolrParams,Consumer)
    */
   public SentinelIntSet assertFullWalkNoDups(int maxSize, SolrParams params) throws Exception {
diff --git a/solr/core/src/test/org/apache/solr/cloud/RestartWhileUpdatingTest.java b/solr/core/src/test/org/apache/solr/cloud/RestartWhileUpdatingTest.java
index 41ba9e00d1d..3b2279849ef 100644
--- a/solr/core/src/test/org/apache/solr/cloud/RestartWhileUpdatingTest.java
+++ b/solr/core/src/test/org/apache/solr/cloud/RestartWhileUpdatingTest.java
@@ -20,12 +20,12 @@ import org.apache.lucene.tests.util.LuceneTestCase.Nightly;
 import org.apache.lucene.tests.util.LuceneTestCase.Slow;
 import org.junit.Test;
 
-@Slow
-@Nightly
 /**
  * Implementation moved to AbstractRestartWhileUpdatingTestBase because it is used by HDFS contrib
  * module tests
  */
+@Slow
+@Nightly
 public class RestartWhileUpdatingTest extends AbstractRestartWhileUpdatingTestBase {
 
   public RestartWhileUpdatingTest() throws Exception {
diff --git a/solr/core/src/test/org/apache/solr/cloud/TestQueryingOnDownCollection.java b/solr/core/src/test/org/apache/solr/cloud/TestQueryingOnDownCollection.java
index 87e0dc4bc9c..8b583db50a8 100644
--- a/solr/core/src/test/org/apache/solr/cloud/TestQueryingOnDownCollection.java
+++ b/solr/core/src/test/org/apache/solr/cloud/TestQueryingOnDownCollection.java
@@ -51,11 +51,11 @@ public class TestQueryingOnDownCollection extends SolrCloudTestCase {
         .configure();
   }
 
-  @Test
   /**
    * Assert that requests to "down collection", i.e. a collection which has all replicas in down
    * state (but are hosted on nodes that are live), fail fast and throw meaningful exceptions
    */
+  @Test
   public void testQueryToDownCollectionShouldFailFast() throws Exception {
 
     CollectionAdminRequest.createCollection(COLLECTION_NAME, "conf", 2, 1)
diff --git a/solr/core/src/test/org/apache/solr/cloud/TestRandomFlRTGCloud.java b/solr/core/src/test/org/apache/solr/cloud/TestRandomFlRTGCloud.java
index 3832550f26d..4ba5b5466ce 100644
--- a/solr/core/src/test/org/apache/solr/cloud/TestRandomFlRTGCloud.java
+++ b/solr/core/src/test/org/apache/solr/cloud/TestRandomFlRTGCloud.java
@@ -265,7 +265,7 @@ public class TestRandomFlRTGCloud extends SolrCloudTestCase {
    * Randomly chooses to do a commit, where the probability of doing so increases the longer it's
    * been since a commit was done.
    *
-   * @returns <code>0</code> if a commit was done, else <code>itersSinceLastCommit + 1</code>
+   * @return <code>0</code> if a commit was done, else <code>itersSinceLastCommit + 1</code>
    */
   private static int maybeCommit(
       final Random rand, final int itersSinceLastCommit, final int numIters)
diff --git a/solr/core/src/test/org/apache/solr/cluster/events/ClusterEventProducerTest.java b/solr/core/src/test/org/apache/solr/cluster/events/ClusterEventProducerTest.java
index 7a1dbc07fe2..25035bffd91 100644
--- a/solr/core/src/test/org/apache/solr/cluster/events/ClusterEventProducerTest.java
+++ b/solr/core/src/test/org/apache/solr/cluster/events/ClusterEventProducerTest.java
@@ -52,7 +52,6 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 @ThreadLeakLingering(linger = 0)
-/** */
 @LogLevel("org.apache.solr.cluster.events=DEBUG")
 public class ClusterEventProducerTest extends SolrCloudTestCase {
   private AllEventsListener eventsListener;
diff --git a/solr/core/src/test/org/apache/solr/handler/admin/ThreadDumpHandlerTest.java b/solr/core/src/test/org/apache/solr/handler/admin/ThreadDumpHandlerTest.java
index 32c4efdf6b9..7d4787ce8f0 100644
--- a/solr/core/src/test/org/apache/solr/handler/admin/ThreadDumpHandlerTest.java
+++ b/solr/core/src/test/org/apache/solr/handler/admin/ThreadDumpHandlerTest.java
@@ -65,7 +65,7 @@ public class ThreadDumpHandlerTest extends SolrTestCaseJ4 {
         "monitor checking not supported on this JVM",
         ManagementFactory.getThreadMXBean().isObjectMonitorUsageSupported());
 
-    /** unique class name to show up as a lock class name in output */
+    // unique class name to show up as a lock class name in output
     final class TestMonitorStruct {
       /* empty */
     }
@@ -190,7 +190,7 @@ public class ThreadDumpHandlerTest extends SolrTestCaseJ4 {
         "ownable sync checking not supported on this JVM",
         ManagementFactory.getThreadMXBean().isSynchronizerUsageSupported());
 
-    /** unique class name to show up as a lock class name in output */
+    // unique class name to show up as a lock class name in output
     final class TestReentrantLockStruct extends ReentrantLock {
       /* empty */
     }
diff --git a/solr/core/src/test/org/apache/solr/handler/component/TermsComponentTest.java b/solr/core/src/test/org/apache/solr/handler/component/TermsComponentTest.java
index 1d509ac8a7e..51d7cbeec39 100644
--- a/solr/core/src/test/org/apache/solr/handler/component/TermsComponentTest.java
+++ b/solr/core/src/test/org/apache/solr/handler/component/TermsComponentTest.java
@@ -697,7 +697,7 @@ public class TermsComponentTest extends SolrTestCaseJ4 {
     try {
       SchemaField sf = req.getSchema().getField("foo_pi");
 
-      /**
+      /*
        * LeafReader r = req.getSearcher().getIndexReader().leaves().get(0).reader(); PointValues pv
        * = r.getPointValues("foo_pi"); System.out.println("pv=" + pv); if (pv instanceof
        * AssertingLeafReader.AssertingPointValues) { pv =
diff --git a/solr/core/src/test/org/apache/solr/search/TestComplexPhraseQParserPlugin.java b/solr/core/src/test/org/apache/solr/search/TestComplexPhraseQParserPlugin.java
index d1617031101..90f89b539dd 100644
--- a/solr/core/src/test/org/apache/solr/search/TestComplexPhraseQParserPlugin.java
+++ b/solr/core/src/test/org/apache/solr/search/TestComplexPhraseQParserPlugin.java
@@ -289,7 +289,7 @@ public class TestComplexPhraseQParserPlugin extends SolrTestCaseJ4 {
     assertU(commit());
     assertU(optimize());
 
-    /** ordered phrase query return only fist document */
+    // ordered phrase query return only fist document
     assertQ(
         req("q", "{!complexphrase} \"protein digest\""),
         "//result[@numFound='1']",
@@ -310,7 +310,7 @@ public class TestComplexPhraseQParserPlugin extends SolrTestCaseJ4 {
         "//result[@numFound='1']",
         "//doc[./str[@name='id']='3']");
 
-    /** unordered phrase query returns two documents. */
+    // unordered phrase query returns two documents.
     assertQ(
         req("q", "{!complexphrase inOrder=false} \"digest protein\""),
         "//result[@numFound='2']",
@@ -335,7 +335,7 @@ public class TestComplexPhraseQParserPlugin extends SolrTestCaseJ4 {
         "//doc[./str[@name='id']='3']",
         "//doc[./str[@name='id']='4']");
 
-    /** inOrder parameter can be defined with local params syntax. */
+    // inOrder parameter can be defined with local params syntax.
     assertQ(
         req("q", "{!complexphrase inOrder=false} \"di* pro*\""),
         "//result[@numFound='2']",
@@ -344,7 +344,7 @@ public class TestComplexPhraseQParserPlugin extends SolrTestCaseJ4 {
 
     assertQ(req("q", "{!complexphrase inOrder=true} \"di* pro*\""), "//result[@numFound='1']");
 
-    /** inOrder and df parameters can be defined with local params syntax. */
+    // inOrder and df parameters can be defined with local params syntax.
     assertQ(
         req("q", "{!complexphrase inOrder=false df=name} \"di* pro*\""),
         "//result[@numFound='2']",
diff --git a/solr/core/src/test/org/apache/solr/search/join/TestScoreJoinQPNoScore.java b/solr/core/src/test/org/apache/solr/search/join/TestScoreJoinQPNoScore.java
index 420cd5d3b0b..f507dbfb2f2 100644
--- a/solr/core/src/test/org/apache/solr/search/join/TestScoreJoinQPNoScore.java
+++ b/solr/core/src/test/org/apache/solr/search/join/TestScoreJoinQPNoScore.java
@@ -269,7 +269,7 @@ public class TestScoreJoinQPNoScore extends SolrTestCaseJ4 {
 
       List<FldType> types = new ArrayList<FldType>();
       types.add(new FldType("id", ONE_ONE, new SVal('A', 'Z', 4, 4)));
-      /**
+      /*
        * no numeric fields so far LUCENE-5868 types.add(new FldType("score_f_dv",ONE_ONE, new
        * FVal(1,100))); // field used to score
        */
@@ -280,7 +280,7 @@ public class TestScoreJoinQPNoScore extends SolrTestCaseJ4 {
       types.add(
           new FldType("small2_ss_dv", ZERO_TWO, new SVal('a', (char) ('c' + indexSize / 3), 1, 1)));
       types.add(new FldType("small3_ss_dv", new IRange(0, 25), new SVal('A', 'z', 1, 1)));
-      /**
+      /*
        * no numeric fields so far LUCENE-5868 types.add(new FldType("small_i_dv",ZERO_ONE, new
        * IRange(0,5+indexSize/3))); types.add(new FldType("small2_i_dv",ZERO_ONE, new
        * IRange(0,5+indexSize/3))); types.add(new FldType("small2_is_dv",ZERO_TWO, new
diff --git a/solr/core/src/test/org/apache/solr/update/TestInPlaceUpdatesStandalone.java b/solr/core/src/test/org/apache/solr/update/TestInPlaceUpdatesStandalone.java
index 6ca4908ccb9..0b2431037c7 100644
--- a/solr/core/src/test/org/apache/solr/update/TestInPlaceUpdatesStandalone.java
+++ b/solr/core/src/test/org/apache/solr/update/TestInPlaceUpdatesStandalone.java
@@ -1501,11 +1501,11 @@ public class TestInPlaceUpdatesStandalone extends SolrTestCaseJ4 {
     assertTrue(inPlaceUpdatedFields.isEmpty());
   }
 
-  @Test
   /**
    * Test the @see {@link AtomicUpdateDocumentMerger#doInPlaceUpdateMerge(AddUpdateCommand,Set)}
    * method is working fine
    */
+  @Test
   public void testDoInPlaceUpdateMerge() throws Exception {
     long version1 = addAndGetVersion(sdoc("id", "1", "title_s", "first"), null);
     long version2 = addAndGetVersion(sdoc("id", "2", "title_s", "second"), null);
diff --git a/solr/core/src/test/org/apache/solr/update/UpdateLogTest.java b/solr/core/src/test/org/apache/solr/update/UpdateLogTest.java
index fe223f885fd..6a35c3df32c 100644
--- a/solr/core/src/test/org/apache/solr/update/UpdateLogTest.java
+++ b/solr/core/src/test/org/apache/solr/update/UpdateLogTest.java
@@ -56,10 +56,10 @@ public class UpdateLogTest extends SolrTestCaseJ4 {
     ulog = null;
   }
 
-  @Test
   /**
    * @see org.apache.solr.update.UpdateLog#applyPartialUpdates
    */
+  @Test
   public void testApplyPartialUpdatesOnMultipleInPlaceUpdatesInSequence() {
     // Add a full update, two in-place updates and verify applying partial updates is working
     ulogAdd(