You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@solr.apache.org by GitBox <gi...@apache.org> on 2022/07/03 14:08:47 UTC

[GitHub] [solr] epugh opened a new pull request, #927: SOLR-16278: remove unused declarations

epugh opened a new pull request, #927:
URL: https://github.com/apache/solr/pull/927

   https://issues.apache.org/jira/browse/SOLR-16278
   # Description
   
   IntelliJ flags variables and methods that aren't used in tests.   Some I kept if I felt like you would want to consult them a lot, mostly `resp` or `req` or if they generated a exception.    
   
   
   
   # Solution
   
   Remove ones that we can.
   
   
   
   # Tests
   
   ran the tests
   
   # Checklist
   
   Please review the following and check all that apply:
   
   - [X ] I have reviewed the guidelines for [How to Contribute](https://wiki.apache.org/solr/HowToContribute) and my code conforms to the standards described there to the best of my ability.
   - [ X] I have created a Jira issue and added the issue ID to my pull request title.
   - [ X] I have given Solr maintainers [access](https://help.github.com/en/articles/allowing-changes-to-a-pull-request-branch-created-from-a-fork) to contribute to my PR branch. (optional but recommended)
   - [ X] I have developed this patch against the `main` branch.
   - [ X] I have run `./gradlew check`.
   - [ ] I have added tests for my changes.
   - [ ] I have added documentation for the [Reference Guide](https://github.com/apache/solr/tree/main/solr/solr-ref-guide)
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r916782318


##########
solr/core/src/test/org/apache/solr/cloud/DistributedVersionInfoTest.java:
##########
@@ -330,9 +330,8 @@ protected void assertDocsExistInAllReplicas(
         if (deletedDocs != null && deletedDocs.contains(d)) continue;
 
         String docId = String.valueOf(d);
-        Long leaderVers = assertDocExists(leaderSolr, testCollectionName, docId, null);
-        for (HttpSolrClient replicaSolr : replicas)
-          assertDocExists(replicaSolr, testCollectionName, docId, leaderVers);
+        Long leaderVers = assertDocExists(leaderSolr, docId, null);
+        for (HttpSolrClient replicaSolr : replicas) assertDocExists(replicaSolr, docId, leaderVers);

Review Comment:
   I much prefer this style on for loops....    ;-)



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1178981351

   > Yea, I don't have strong feelings about leaving the loggers in over taking them out, do what you gotta do man.
   
   @cpoerschke want to be tie breaker?   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r917316058


##########
solr/core/src/test/org/apache/solr/handler/TestSolrConfigHandlerConcurrent.java:
##########
@@ -97,12 +96,7 @@ public void test() throws Exception {
     assertTrue(collectErrors.toString(), success);
   }
 
-  private void invokeBulkCall(
-      String cacheName,
-      List<String> errs,
-      // TODO this is unused - is that a bug?

Review Comment:
   I * think* that this todo was introduced in SOLR-15385 RawTypes Part VI, and was a reminder to check.  I ran the tests and they pass with this change...  so based on that, inclined to keep the change and be happy that the TODO can be removed...



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r916801978


##########
solr/core/src/test/org/apache/solr/handler/ThrowErrorOnInitRequestHandler.java:
##########
@@ -1,52 +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.solr.handler;
-
-import java.io.IOException;
-import org.apache.solr.common.util.NamedList;
-import org.apache.solr.request.SolrQueryRequest;
-import org.apache.solr.response.SolrQueryResponse;
-import org.apache.solr.security.AuthorizationContext;
-
-/** throws a {@link java.lang.Error} on init for testing purposes */
-public class ThrowErrorOnInitRequestHandler extends RequestHandlerBase {

Review Comment:
   nice find...  i thought maybe this solrconfig was also a dead code path, but appears not



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] madrob commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
madrob commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1178257360

   Yea, I don't have strong feelings about leaving the loggers in over taking them out, do what you gotta do man.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1178992013

   There are enoguh changes, I'll make sure to rerun all the tests when we get this to ready!


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] cpoerschke commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
cpoerschke commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r916884938


##########
solr/core/src/test/org/apache/solr/search/TestStressVersions.java:
##########
@@ -116,7 +112,6 @@ public void run() {
                   }
 
                   int id = rand.nextInt(ndocs);

Review Comment:
   ```suggestion
                     int id = rand.nextInt(ndocs);
                     // Object sync = syncArr[id];
   ```
   
   because there's some commented out `synchronized (sync)` code below



##########
solr/core/src/test/org/apache/solr/search/facet/TestCloudJSONFacetSKG.java:
##########
@@ -726,7 +726,7 @@ public static String randomPrefixParam(final Random r, final String facetField)
      * @return a sort string (w/direction), or null to specify nothing (trigger default behavior)
      * @see #randomSortParam

Review Comment:
   ```suggestion
   ```



##########
solr/core/src/test/org/apache/solr/update/processor/UniqFieldsUpdateProcessorFactoryTest.java:
##########
@@ -54,8 +54,6 @@ public void setUp() throws Exception {
   public void testUniqFields() throws Exception {
     SolrCore core = h.getCore();
     UpdateRequestProcessorChain chained = core.getUpdateProcessingChain("uniq-fields");
-    UniqFieldsUpdateProcessorFactory factory =
-        ((UniqFieldsUpdateProcessorFactory) chained.getProcessors().get(0));
     assertNotNull(chained);

Review Comment:
   ```suggestion
       assertNotNull(chained);
       UniqFieldsUpdateProcessorFactory factory =
            ((UniqFieldsUpdateProcessorFactory) chained.getProcessors().get(0));
       assertNotNull(factory);
   ```



##########
solr/core/src/test/org/apache/solr/handler/TestSolrConfigHandlerConcurrent.java:
##########
@@ -97,12 +96,7 @@ public void test() throws Exception {
     assertTrue(collectErrors.toString(), success);
   }
 
-  private void invokeBulkCall(
-      String cacheName,
-      List<String> errs,
-      // TODO this is unused - is that a bug?

Review Comment:
   on the basis of this comment, how about excluding this file from the cleanup?



##########
solr/core/src/test/org/apache/solr/cloud/MockSimpleZkController.java:
##########
@@ -26,14 +26,22 @@
 
 public class MockSimpleZkController extends ZkController {
 
+  /**
+   * @param cc Core container associated with this controller. cannot be null.
+   * @param zkServerAddress where to connect to the zk server
+   * @param zkClientConnectTimeout timeout in ms
+   * @param cloudConfig configuration for this controller. TODO: possibly redundant with
+   *     CoreContainer
+   * @param descriptorsSupplier a supplier of the current core descriptors. used to know which cores
+   */

Review Comment:
   minor/subjective: seems to just repeat javadocs from super class, not sure if that's useful



##########
solr/core/src/test/org/apache/solr/search/facet/TestCloudJSONFacetSKGEquiv.java:
##########
@@ -1184,7 +1183,7 @@ public static String randomSortParam(final Random r) {
      * @return a sort string (w/direction), or null to specify nothing (trigger default behavior)
      * @see #randomSortParam

Review Comment:
   ```suggestion
   ```



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1177532138

   Thanks @cpoerschke for all the work reviewing these so far!


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1178118429

   > Even if a logger is unused, I would still leave it in.
   
   I was really hoping that I could just use the logger declared in the base class, so for `TestRandomFaceting`, use the `log` declared by `SolrTestCaseJ4`, but it doesn't work, you don't get the right message.   Even though the call was in `TestRandomFaceting`, the output refers to where it was defined:
   
   ```
   o.a.s.SolrTestCaseJ4 HI There from log2
   ```
   
   It feels sort of haphazard that the log is on some unit tests but not others....     
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] cpoerschke commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
cpoerschke commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1179084190

   > > Yea, I don't have strong feelings about leaving the loggers in over taking them out, do what you gotta do man.
   > 
   > @cpoerschke want to be tie breaker?
   
   No strong views either way. As a developer I find it convenient if the logger is already there but from a CI perspective I'd also love to see the tools flagging up early when code becomes unused in future.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1178133308

   I also get @madrob that keeping the unused log might just be a personal thing, and I'm happy to put them back in to avoid a bike shedding discussion!


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r916800392


##########
solr/core/src/test/org/apache/solr/internal/csv/CSVParserTest.java:
##########
@@ -377,37 +377,6 @@ public void testEmptyLineBehaviourCSV() throws Exception {
     }
   }
 
-  public void OLDtestBackslashEscaping() throws IOException {

Review Comment:
   Umm, it fails....    and since we were not running it, I'd rather not debug why it fails...  and just ignore it.  since maybe it fails cause we changed logic...



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r916798521


##########
solr/core/src/test/org/apache/solr/internal/csv/CSVParserTest.java:
##########
@@ -377,37 +377,6 @@ public void testEmptyLineBehaviourCSV() throws Exception {
     }
   }
 
-  public void OLDtestBackslashEscaping() throws IOException {

Review Comment:
   sure, I'll restore it, and move it below the first two `testBackslashEscaping`!



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r916807573


##########
solr/core/src/test/org/apache/solr/handler/ThrowErrorOnInitRequestHandler.java:
##########
@@ -1,52 +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.solr.handler;
-
-import java.io.IOException;
-import org.apache.solr.common.util.NamedList;
-import org.apache.solr.request.SolrQueryRequest;
-import org.apache.solr.response.SolrQueryResponse;
-import org.apache.solr.security.AuthorizationContext;
-
-/** throws a {@link java.lang.Error} on init for testing purposes */
-public class ThrowErrorOnInitRequestHandler extends RequestHandlerBase {

Review Comment:
   restored!



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] madrob commented on pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
madrob commented on PR #927:
URL: https://github.com/apache/solr/pull/927#issuecomment-1177945815

   Even if a logger is unused, I would still leave it in.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] cpoerschke commented on a diff in pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
cpoerschke commented on code in PR #927:
URL: https://github.com/apache/solr/pull/927#discussion_r916660164


##########
solr/core/src/test/org/apache/solr/cloud/TestDistribDocBasedVersion.java:
##########
@@ -38,7 +36,6 @@ public class TestDistribDocBasedVersion extends AbstractFullDistribZkTestBase {
   private static final Logger log = LoggerFactory.getLogger(MethodHandles.lookup().lookupClass());
 
   String bucket1 = "shard1"; // shard1: top bits:10  80000000:ffffffff

Review Comment:
   ```suggestion
     String bucket1 = "shard1"; // shard1: top bits:10  80000000:ffffffff
     // String bucket2 = "shard2"; // shard2: top bits:00  00000000:7fffffff
   ```



##########
solr/core/src/test/org/apache/solr/cluster/placement/plugins/AffinityPlacementFactoryTest.java:
##########
@@ -276,7 +276,6 @@ public void testPlacementMultiCriteria() throws Exception {
     final int AZ2_TLOGPULL = 7;
 
     final int AZ3_NRT_LOWCORES = 4;

Review Comment:
   ```suggestion
       final int AZ3_NRT_LOWCORES = 4;
       // final int AZ3_NRT_HIGHCORES = 6;
   ```



##########
solr/core/src/test/org/apache/solr/cluster/placement/plugins/AffinityPlacementFactoryTest.java:
##########
@@ -980,7 +978,6 @@ public void testNodeType() throws Exception {
     assertEquals("expected 3 placements: " + pp, 3, pp.getReplicaPlacements().size());
     Set<String> type0nodes = nodeNamesByType.get("type_0");
     Set<String> type1nodes = nodeNamesByType.get("type_1");

Review Comment:
   ```suggestion
       Set<String> type1nodes = nodeNamesByType.get("type_1");
       // Set<String> type2nodes = nodeNamesByType.get("type_2");
   ```



##########
solr/core/src/test/org/apache/solr/cloud/DistributedVersionInfoTest.java:
##########
@@ -330,9 +330,8 @@ protected void assertDocsExistInAllReplicas(
         if (deletedDocs != null && deletedDocs.contains(d)) continue;
 
         String docId = String.valueOf(d);
-        Long leaderVers = assertDocExists(leaderSolr, testCollectionName, docId, null);
-        for (HttpSolrClient replicaSolr : replicas)
-          assertDocExists(replicaSolr, testCollectionName, docId, leaderVers);
+        Long leaderVers = assertDocExists(leaderSolr, docId, null);
+        for (HttpSolrClient replicaSolr : replicas) assertDocExists(replicaSolr, docId, leaderVers);

Review Comment:
   ```suggestion
           for (HttpSolrClient replicaSolr : replicas) {
             assertDocExists(replicaSolr, docId, leaderVers);
           }
   ```



##########
solr/core/src/test/org/apache/solr/internal/csv/CSVParserTest.java:
##########
@@ -377,37 +377,6 @@ public void testEmptyLineBehaviourCSV() throws Exception {
     }
   }
 
-  public void OLDtestBackslashEscaping() throws IOException {

Review Comment:
   How about keeping this and renaming to `testOLDBackslashEscaping()` say?



##########
solr/core/src/test/org/apache/solr/core/ConfigureRecoveryStrategyTest.java:
##########
@@ -82,14 +82,6 @@ public static class CustomRecoveryStrategy extends RecoveryStrategy {
 
     private String alternativeBaseUrlProp;
 
-    public String getAlternativeBaseUrlProp() {
-      return alternativeBaseUrlProp;
-    }
-
-    public void setAlternativeBaseUrlProp(String alternativeBaseUrlProp) {
-      this.alternativeBaseUrlProp = alternativeBaseUrlProp;
-    }
-

Review Comment:
   This is used via reflection: https://github.com/apache/solr/blob/releases/solr/9.0.0/solr/core/src/java/org/apache/solr/cloud/RecoveryStrategy.java#L91



##########
solr/core/src/test/org/apache/solr/cloud/TestRandomFlRTGCloud.java:
##########
@@ -1394,8 +1394,7 @@ private static void addRandomFlValidators(final Random r, final Set<FlValidator>
    * Given an ordered list of values to include in a (key) param, randomly groups them (ie: comma

Review Comment:
   ```suggestion
      * Given an ordered list of values to include in a (key) param, groups them (ie: comma
   ```



##########
solr/core/src/test/org/apache/solr/handler/ReplicationTestHelper.java:
##########
@@ -101,8 +101,6 @@ private static void copyFile(File src, File dst, Integer port, boolean internalC
 
   public static void assertVersions(SolrClient client1, SolrClient client2) throws Exception {
     NamedList<Object> details = getDetails(client1);

Review Comment:
   ```suggestion
   ```



##########
solr/core/src/test/org/apache/solr/handler/ThrowErrorOnInitRequestHandler.java:
##########
@@ -1,52 +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.solr.handler;
-
-import java.io.IOException;
-import org.apache.solr.common.util.NamedList;
-import org.apache.solr.request.SolrQueryRequest;
-import org.apache.solr.response.SolrQueryResponse;
-import org.apache.solr.security.AuthorizationContext;
-
-/** throws a {@link java.lang.Error} on init for testing purposes */
-public class ThrowErrorOnInitRequestHandler extends RequestHandlerBase {

Review Comment:
   Looks to be used in tests: https://github.com/apache/solr/search?q=ThrowErrorOnInitRequestHandler



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org


[GitHub] [solr] epugh merged pull request #927: SOLR-16278: remove unused declarations

Posted by GitBox <gi...@apache.org>.
epugh merged PR #927:
URL: https://github.com/apache/solr/pull/927


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@solr.apache.org
For additional commands, e-mail: issues-help@solr.apache.org