You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@solr.apache.org by ge...@apache.org on 2024/01/19 17:03:34 UTC

(solr) branch branch_9x updated: SOLR-17066: Replace 'data store' term in code and docs (#2201)

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

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


The following commit(s) were added to refs/heads/branch_9x by this push:
     new d0616dc5c91 SOLR-17066: Replace 'data store' term in code and docs (#2201)
d0616dc5c91 is described below

commit d0616dc5c917ff06f3ff63ac6672dba37eebd51a
Author: Jason Gerlowski <ge...@apache.org>
AuthorDate: Fri Jan 19 11:01:26 2024 -0500

    SOLR-17066: Replace 'data store' term in code and docs (#2201)
    
    "Data store" as a term, was introduced a few weeks back as a way to
    refer generically to something that could be either a collection or a
    core.  As its use expanded though, it turned out to not be very well
    liked in practice.
    
    This commit replaces all usage of the term with either "collection" or
    "index type", depending on the specific usage.
---
 solr/CHANGES.txt                                             |  5 ++---
 .../org/apache/solr/client/api/endpoint/GetSchemaApi.java    |  4 ++--
 .../java/org/apache/solr/client/api/endpoint/SelectApi.java  |  4 ++--
 .../solr/client/api/model/{StoreType.java => IndexType.java} |  4 ++--
 .../src/java/org/apache/solr/client/api/util/Constants.java  |  8 ++++----
 .../org/apache/solr/client/api/util/StoreApiParameters.java  | 12 ++++++------
 .../src/java/org/apache/solr/cloud/RecoveryStrategy.java     |  2 +-
 .../solr/cloud/api/collections/CollectionHandlingUtils.java  |  2 +-
 .../solr/cloud/api/collections/ReindexCollectionCmd.java     |  2 +-
 .../src/java/org/apache/solr/handler/SolrConfigHandler.java  |  6 +++---
 .../solr/handler/component/IterativeMergeStrategy.java       |  2 +-
 .../src/java/org/apache/solr/schema/ManagedIndexSchema.java  |  8 ++++----
 .../src/java/org/apache/solr/update/PeerSyncWithLeader.java  |  2 +-
 .../java/org/apache/solr/update/StreamingSolrClients.java    |  2 +-
 .../modules/getting-started/pages/solr-glossary.adoc         |  3 ++-
 .../src/java/org/apache/solr/client/solrj/SolrRequest.java   | 12 ++++++------
 .../apache/solr/client/solrj/impl/CloudLegacySolrClient.java | 12 +-----------
 .../client/solrj/impl/ConcurrentUpdateHttp2SolrClient.java   | 12 ++++++------
 .../solr/client/solrj/impl/ConcurrentUpdateSolrClient.java   |  4 ++--
 .../org/apache/solr/client/solrj/impl/Http2SolrClient.java   | 12 ++++++------
 .../org/apache/solr/client/solrj/impl/HttpSolrClient.java    |  4 ++--
 .../org/apache/solr/client/solrj/impl/LBHttp2SolrClient.java | 10 +++++-----
 .../org/apache/solr/client/solrj/impl/LBHttpSolrClient.java  |  4 ++--
 .../java/org/apache/solr/client/solrj/impl/LBSolrClient.java |  2 +-
 .../org/apache/solr/client/solrj/impl/SolrClientBuilder.java |  8 ++++----
 .../solr/client/solrj/request/AbstractUpdateRequest.java     |  2 +-
 ...eSolrRequest.java => CollectionRequiringSolrRequest.java} |  8 +++++---
 .../apache/solr/client/solrj/request/DirectXmlRequest.java   |  2 +-
 .../solr/client/solrj/request/DocumentAnalysisRequest.java   |  3 ++-
 .../solr/client/solrj/request/FieldAnalysisRequest.java      |  2 +-
 .../org/apache/solr/client/solrj/request/LukeRequest.java    |  2 +-
 .../org/apache/solr/client/solrj/request/QueryRequest.java   |  2 +-
 .../java/org/apache/solr/client/solrj/request/SolrPing.java  |  2 +-
 .../client/solrj/request/schema/AbstractSchemaRequest.java   |  4 ++--
 .../java/org/apache/solr/client/solrj/util/ClientUtils.java  |  4 ++--
 .../solrj/impl/ConcurrentUpdateSolrClientBuilderTest.java    |  2 +-
 .../solr/client/solrj/impl/HttpSolrClientBuilderTest.java    |  2 +-
 .../solr/client/solrj/impl/LBHttpSolrClientBuilderTest.java  |  2 +-
 .../solr/client/solrj/response/TestSuggesterResponse.java    |  2 +-
 .../org/apache/solr/client/solrj/util/ClientUtilsTest.java   |  8 ++++----
 .../src/java/org/apache/solr/SolrTestCaseJ4.java             |  2 +-
 .../src/java/org/apache/solr/cloud/ConfigRequest.java        |  4 ++--
 42 files changed, 96 insertions(+), 103 deletions(-)

diff --git a/solr/CHANGES.txt b/solr/CHANGES.txt
index 4637f6ef64a..274e8f99179 100644
--- a/solr/CHANGES.txt
+++ b/solr/CHANGES.txt
@@ -56,9 +56,8 @@ Improvements
 * SOLR-17063: Do not retain log param references in LogWatcher (Michael Gibney)
 
 * SOLR-17066: SolrClient builders now allow users to specify a "default" collection or core
-  using the `withDefaultDataStore` method  ("Cloud" client builders retain the more specific
-  `withDefaultCollection`).  Use of the Builder methods is preferable to including the
-  collection in the base URL accepted by certain client implementations. (Jason Gerlowski)
+  using the `withDefaultCollection` method.  Use of the Builder methods is preferable to including
+  the collection in the base URL accepted by certain client implementations. (Jason Gerlowski)
 
 * SOLR-15960: Unified use of system properties and environment variables (janhoy)
 
diff --git a/solr/api/src/java/org/apache/solr/client/api/endpoint/GetSchemaApi.java b/solr/api/src/java/org/apache/solr/client/api/endpoint/GetSchemaApi.java
index c0102a26c4b..d745ba59a05 100644
--- a/solr/api/src/java/org/apache/solr/client/api/endpoint/GetSchemaApi.java
+++ b/solr/api/src/java/org/apache/solr/client/api/endpoint/GetSchemaApi.java
@@ -16,7 +16,7 @@
  */
 package org.apache.solr.client.api.endpoint;
 
-import static org.apache.solr.client.api.util.Constants.STORE_PATH_PREFIX;
+import static org.apache.solr.client.api.util.Constants.INDEX_PATH_PREFIX;
 
 import io.swagger.v3.oas.annotations.Operation;
 import javax.ws.rs.DefaultValue;
@@ -31,7 +31,7 @@ import org.apache.solr.client.api.model.SchemaVersionResponse;
 import org.apache.solr.client.api.model.SchemaZkVersionResponse;
 import org.apache.solr.client.api.util.StoreApiParameters;
 
-@Path(STORE_PATH_PREFIX + "/schema")
+@Path(INDEX_PATH_PREFIX + "/schema")
 public interface GetSchemaApi {
 
   @GET
diff --git a/solr/api/src/java/org/apache/solr/client/api/endpoint/SelectApi.java b/solr/api/src/java/org/apache/solr/client/api/endpoint/SelectApi.java
index 94a7e3fb590..e04aa344c91 100644
--- a/solr/api/src/java/org/apache/solr/client/api/endpoint/SelectApi.java
+++ b/solr/api/src/java/org/apache/solr/client/api/endpoint/SelectApi.java
@@ -17,7 +17,7 @@
 package org.apache.solr.client.api.endpoint;
 
 import static org.apache.solr.client.api.util.Constants.GENERIC_ENTITY_PROPERTY;
-import static org.apache.solr.client.api.util.Constants.STORE_PATH_PREFIX;
+import static org.apache.solr.client.api.util.Constants.INDEX_PATH_PREFIX;
 
 import io.swagger.v3.oas.annotations.Operation;
 import io.swagger.v3.oas.annotations.Parameter;
@@ -42,7 +42,7 @@ import org.apache.solr.client.api.util.StoreApiParameters;
  * Solr's OAS (and the clients generated from that) an approximate view of the endpoint until its
  * inputs and outputs can be understood more fully.
  */
-@Path(STORE_PATH_PREFIX + "/select")
+@Path(INDEX_PATH_PREFIX + "/select")
 public interface SelectApi {
   @GET
   @StoreApiParameters
diff --git a/solr/api/src/java/org/apache/solr/client/api/model/StoreType.java b/solr/api/src/java/org/apache/solr/client/api/model/IndexType.java
similarity index 94%
rename from solr/api/src/java/org/apache/solr/client/api/model/StoreType.java
rename to solr/api/src/java/org/apache/solr/client/api/model/IndexType.java
index d6ba2002f4c..aee0a077593 100644
--- a/solr/api/src/java/org/apache/solr/client/api/model/StoreType.java
+++ b/solr/api/src/java/org/apache/solr/client/api/model/IndexType.java
@@ -16,13 +16,13 @@
  */
 package org.apache.solr.client.api.model;
 
-public enum StoreType {
+public enum IndexType {
   COLLECTION("collections"),
   CORE("cores");
 
   private final String pathString;
 
-  StoreType(String pathString) {
+  IndexType(String pathString) {
     this.pathString = pathString;
   }
 
diff --git a/solr/api/src/java/org/apache/solr/client/api/util/Constants.java b/solr/api/src/java/org/apache/solr/client/api/util/Constants.java
index cacc7a50090..560ce77af97 100644
--- a/solr/api/src/java/org/apache/solr/client/api/util/Constants.java
+++ b/solr/api/src/java/org/apache/solr/client/api/util/Constants.java
@@ -22,10 +22,10 @@ public class Constants {
     /* Private ctor prevents instantiation */
   }
 
-  public static final String STORE_TYPE_PATH_PARAMETER = "storeType";
-  public static final String STORE_NAME_PATH_PARAMETER = "storeName";
-  public static final String STORE_PATH_PREFIX =
-      "/{" + STORE_TYPE_PATH_PARAMETER + ":cores|collections}/{" + STORE_NAME_PATH_PARAMETER + "}";
+  public static final String INDEX_TYPE_PATH_PARAMETER = "indexType";
+  public static final String INDEX_NAME_PATH_PARAMETER = "indexName";
+  public static final String INDEX_PATH_PREFIX =
+      "/{" + INDEX_TYPE_PATH_PARAMETER + ":cores|collections}/{" + INDEX_NAME_PATH_PARAMETER + "}";
 
   public static final String GENERIC_ENTITY_PROPERTY = "genericEntity";
 
diff --git a/solr/api/src/java/org/apache/solr/client/api/util/StoreApiParameters.java b/solr/api/src/java/org/apache/solr/client/api/util/StoreApiParameters.java
index f13a639e356..b82f4cd107a 100644
--- a/solr/api/src/java/org/apache/solr/client/api/util/StoreApiParameters.java
+++ b/solr/api/src/java/org/apache/solr/client/api/util/StoreApiParameters.java
@@ -16,8 +16,8 @@
  */
 package org.apache.solr.client.api.util;
 
-import static org.apache.solr.client.api.util.Constants.STORE_NAME_PATH_PARAMETER;
-import static org.apache.solr.client.api.util.Constants.STORE_TYPE_PATH_PARAMETER;
+import static org.apache.solr.client.api.util.Constants.INDEX_NAME_PATH_PARAMETER;
+import static org.apache.solr.client.api.util.Constants.INDEX_TYPE_PATH_PARAMETER;
 
 import io.swagger.v3.oas.annotations.Parameter;
 import io.swagger.v3.oas.annotations.enums.ParameterIn;
@@ -26,7 +26,7 @@ import java.lang.annotation.ElementType;
 import java.lang.annotation.Retention;
 import java.lang.annotation.RetentionPolicy;
 import java.lang.annotation.Target;
-import org.apache.solr.client.api.model.StoreType;
+import org.apache.solr.client.api.model.IndexType;
 
 /**
  * Concisely collects the parameters shared by APIs that interact with contents of a specific
@@ -38,8 +38,8 @@ import org.apache.solr.client.api.model.StoreType;
 @Target({ElementType.METHOD, ElementType.TYPE, ElementType.PARAMETER, ElementType.FIELD})
 @Retention(RetentionPolicy.RUNTIME)
 @Parameter(
-    name = STORE_TYPE_PATH_PARAMETER,
+    name = INDEX_TYPE_PATH_PARAMETER,
     in = ParameterIn.PATH,
-    schema = @Schema(implementation = StoreType.class, enumAsRef = true))
-@Parameter(name = STORE_NAME_PATH_PARAMETER, in = ParameterIn.PATH)
+    schema = @Schema(implementation = IndexType.class, enumAsRef = true))
+@Parameter(name = INDEX_NAME_PATH_PARAMETER, in = ParameterIn.PATH)
 public @interface StoreApiParameters {}
diff --git a/solr/core/src/java/org/apache/solr/cloud/RecoveryStrategy.java b/solr/core/src/java/org/apache/solr/cloud/RecoveryStrategy.java
index b5504699942..f3387effc33 100644
--- a/solr/core/src/java/org/apache/solr/cloud/RecoveryStrategy.java
+++ b/solr/core/src/java/org/apache/solr/cloud/RecoveryStrategy.java
@@ -181,7 +181,7 @@ public class RecoveryStrategy implements Runnable, Closeable {
     // (even though getRecoveryOnlyHttpClient() already has them set)
     final UpdateShardHandlerConfig cfg = cc.getConfig().getUpdateShardHandlerConfig();
     return (new HttpSolrClient.Builder(baseUrl)
-        .withDefaultDataStore(leaderCoreName)
+        .withDefaultCollection(leaderCoreName)
         .withConnectionTimeout(cfg.getDistributedConnectionTimeout(), TimeUnit.MILLISECONDS)
         .withSocketTimeout(cfg.getDistributedSocketTimeout(), TimeUnit.MILLISECONDS)
         .withHttpClient(cc.getUpdateShardHandler().getRecoveryOnlyHttpClient()));
diff --git a/solr/core/src/java/org/apache/solr/cloud/api/collections/CollectionHandlingUtils.java b/solr/core/src/java/org/apache/solr/cloud/api/collections/CollectionHandlingUtils.java
index c08b1a3b754..98845b840c3 100644
--- a/solr/core/src/java/org/apache/solr/cloud/api/collections/CollectionHandlingUtils.java
+++ b/solr/core/src/java/org/apache/solr/cloud/api/collections/CollectionHandlingUtils.java
@@ -240,7 +240,7 @@ public class CollectionHandlingUtils {
 
     try (SolrClient client =
         new HttpSolrClient.Builder(baseUrl)
-            .withDefaultDataStore(coreName)
+            .withDefaultCollection(coreName)
             .withConnectionTimeout(30000, TimeUnit.MILLISECONDS)
             .withSocketTimeout(120000, TimeUnit.MILLISECONDS)
             .build()) {
diff --git a/solr/core/src/java/org/apache/solr/cloud/api/collections/ReindexCollectionCmd.java b/solr/core/src/java/org/apache/solr/cloud/api/collections/ReindexCollectionCmd.java
index fd2081be1de..5ff49538971 100644
--- a/solr/core/src/java/org/apache/solr/cloud/api/collections/ReindexCollectionCmd.java
+++ b/solr/core/src/java/org/apache/solr/cloud/api/collections/ReindexCollectionCmd.java
@@ -806,7 +806,7 @@ public class ReindexCollectionCmd implements CollApiCmds.CollectionApiCommand {
     try (SolrClient solrClient =
         new HttpSolrClient.Builder()
             .withHttpClient(client)
-            .withDefaultDataStore(daemonReplica.getCoreName())
+            .withDefaultCollection(daemonReplica.getCoreName())
             .withBaseSolrUrl(daemonReplica.getBaseUrl())
             .build()) {
       ModifiableSolrParams q = new ModifiableSolrParams();
diff --git a/solr/core/src/java/org/apache/solr/handler/SolrConfigHandler.java b/solr/core/src/java/org/apache/solr/handler/SolrConfigHandler.java
index 9746cb8cdad..8a8a0da4425 100644
--- a/solr/core/src/java/org/apache/solr/handler/SolrConfigHandler.java
+++ b/solr/core/src/java/org/apache/solr/handler/SolrConfigHandler.java
@@ -59,7 +59,7 @@ import org.apache.solr.client.solrj.SolrRequest;
 import org.apache.solr.client.solrj.SolrResponse;
 import org.apache.solr.client.solrj.impl.HttpSolrClient;
 import org.apache.solr.client.solrj.io.stream.expr.Expressible;
-import org.apache.solr.client.solrj.request.DataStoreSolrRequest;
+import org.apache.solr.client.solrj.request.CollectionRequiringSolrRequest;
 import org.apache.solr.cloud.ZkController;
 import org.apache.solr.cloud.ZkSolrResourceLoader;
 import org.apache.solr.common.MapSerializable;
@@ -960,7 +960,7 @@ public class SolrConfigHandler extends RequestHandlerBase
     }
   }
 
-  private static class PerReplicaCallable extends DataStoreSolrRequest<SolrResponse>
+  private static class PerReplicaCallable extends CollectionRequiringSolrRequest<SolrResponse>
       implements Callable<Boolean> {
     Replica replica;
     String prop;
@@ -989,7 +989,7 @@ public class SolrConfigHandler extends RequestHandlerBase
       int attempts = 0;
       try (HttpSolrClient solr =
           new HttpSolrClient.Builder(replica.getBaseUrl())
-              .withDefaultDataStore(replica.getCoreName())
+              .withDefaultCollection(replica.getCoreName())
               .build()) {
         // eventually, this loop will get killed by the ExecutorService's timeout
         while (true) {
diff --git a/solr/core/src/java/org/apache/solr/handler/component/IterativeMergeStrategy.java b/solr/core/src/java/org/apache/solr/handler/component/IterativeMergeStrategy.java
index 350d60174e8..41df454d7b6 100644
--- a/solr/core/src/java/org/apache/solr/handler/component/IterativeMergeStrategy.java
+++ b/solr/core/src/java/org/apache/solr/handler/component/IterativeMergeStrategy.java
@@ -96,7 +96,7 @@ public abstract class IterativeMergeStrategy implements MergeStrategy {
           URLUtil.extractCoreFromCoreUrl(originalShardResponse.getShardAddress());
       this.solrClient =
           new Builder(shardBaseUrl)
-              .withDefaultDataStore(shardCoreName)
+              .withDefaultCollection(shardCoreName)
               .withHttpClient(httpClient)
               .build();
       this.req = req;
diff --git a/solr/core/src/java/org/apache/solr/schema/ManagedIndexSchema.java b/solr/core/src/java/org/apache/solr/schema/ManagedIndexSchema.java
index 3ca6e7b8389..d3da65fb5ce 100644
--- a/solr/core/src/java/org/apache/solr/schema/ManagedIndexSchema.java
+++ b/solr/core/src/java/org/apache/solr/schema/ManagedIndexSchema.java
@@ -44,7 +44,7 @@ import org.apache.solr.client.solrj.SolrClient;
 import org.apache.solr.client.solrj.SolrRequest;
 import org.apache.solr.client.solrj.SolrResponse;
 import org.apache.solr.client.solrj.impl.HttpSolrClient;
-import org.apache.solr.client.solrj.request.DataStoreSolrRequest;
+import org.apache.solr.client.solrj.request.CollectionRequiringSolrRequest;
 import org.apache.solr.cloud.ZkController;
 import org.apache.solr.cloud.ZkSolrResourceLoader;
 import org.apache.solr.common.SolrException;
@@ -347,8 +347,8 @@ public final class ManagedIndexSchema extends IndexSchema {
     return activeReplicas;
   }
 
-  private static class GetZkSchemaVersionCallable extends DataStoreSolrRequest<SolrResponse>
-      implements Callable<Integer> {
+  private static class GetZkSchemaVersionCallable
+      extends CollectionRequiringSolrRequest<SolrResponse> implements Callable<Integer> {
 
     private final ZkController zkController;
     private String baseUrl;
@@ -375,7 +375,7 @@ public final class ManagedIndexSchema extends IndexSchema {
     public Integer call() throws Exception {
       int remoteVersion = -1;
       try (HttpSolrClient solr =
-          new HttpSolrClient.Builder(baseUrl).withDefaultDataStore(coreName).build()) {
+          new HttpSolrClient.Builder(baseUrl).withDefaultCollection(coreName).build()) {
         // eventually, this loop will get killed by the ExecutorService's timeout
         while (remoteVersion == -1
             || (remoteVersion < expectedZkVersion
diff --git a/solr/core/src/java/org/apache/solr/update/PeerSyncWithLeader.java b/solr/core/src/java/org/apache/solr/update/PeerSyncWithLeader.java
index 883f179b528..c2d98d41ac0 100644
--- a/solr/core/src/java/org/apache/solr/update/PeerSyncWithLeader.java
+++ b/solr/core/src/java/org/apache/solr/update/PeerSyncWithLeader.java
@@ -85,7 +85,7 @@ public class PeerSyncWithLeader implements SolrMetricProducer {
     final var coreName = URLUtil.extractCoreFromCoreUrl(leaderUrl);
     this.clientToLeader =
         new HttpSolrClient.Builder(leaderBaseUrl)
-            .withDefaultDataStore(coreName)
+            .withDefaultCollection(coreName)
             .withHttpClient(httpClient)
             .build();
 
diff --git a/solr/core/src/java/org/apache/solr/update/StreamingSolrClients.java b/solr/core/src/java/org/apache/solr/update/StreamingSolrClients.java
index 2bdb512d0fc..e53797ee21f 100644
--- a/solr/core/src/java/org/apache/solr/update/StreamingSolrClients.java
+++ b/solr/core/src/java/org/apache/solr/update/StreamingSolrClients.java
@@ -76,7 +76,7 @@ public class StreamingSolrClients {
       client =
           new ErrorReportingConcurrentUpdateSolrClient.Builder(
                   req.node.getBaseUrl(), httpClient, req, errors)
-              .withDefaultDataStore(defaultCore)
+              .withDefaultCollection(defaultCore)
               .withQueueSize(100)
               .withThreadCount(runnerCount)
               .withExecutorService(updateExecutor)
diff --git a/solr/solr-ref-guide/modules/getting-started/pages/solr-glossary.adoc b/solr/solr-ref-guide/modules/getting-started/pages/solr-glossary.adoc
index 456d17e7a0e..9c5986f70d0 100644
--- a/solr/solr-ref-guide/modules/getting-started/pages/solr-glossary.adoc
+++ b/solr/solr-ref-guide/modules/getting-started/pages/solr-glossary.adoc
@@ -55,7 +55,8 @@ In Solr, one or more <<document,Documents>> grouped together in a single logical
 In <<solrclouddef,SolrCloud>> a collection may be divided up into multiple logical shards, which may in turn be distributed across many nodes.
 +
 Single-node installations and user-managed clusters use instead the concept of a <<core,Core>>.
-
+"Collection" is most frequently used in the SolrCloud context, but as it represents a "logical index", the term may be used to refer to individual cores in a user-managed cluster as well.
++
 [[defcommit]]Commit::
 To make document changes permanent in the index.
 In the case of added documents, they would be searchable after a _commit_.
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/SolrRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/SolrRequest.java
index bf5f195d88a..eb6fe33626a 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/SolrRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/SolrRequest.java
@@ -202,15 +202,15 @@ public abstract class SolrRequest<T extends SolrResponse> implements Serializabl
   public abstract SolrParams getParams();
 
   /**
-   * Determines whether this request should use or ignore any specified data stores (esp. {@link
+   * Determines whether this request should use or ignore any specified collections (esp. {@link
    * SolrClient#defaultCollection})
    *
-   * <p>Many Solr requests target a particular data store (i.e. core or collection). But not all of
-   * them - many Solr APIs (e.g. security or other admin APIs) are agnostic of data stores entirely.
-   * This method gives these requests a way to opt out of using {@link SolrClient#defaultCollection}
-   * or other specified data stores.
+   * <p>Many Solr requests target a particular core or collection. But not all of them - many Solr
+   * APIs (e.g. security or other admin APIs) are agnostic of collections entirely. This method
+   * gives these requests a way to opt out of using {@link SolrClient#defaultCollection} or other
+   * specified collections.
    */
-  public boolean requiresDataStore() {
+  public boolean requiresCollection() {
     return false;
   }
 
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/CloudLegacySolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/CloudLegacySolrClient.java
index e3c493f1a61..e1f3840cfbd 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/CloudLegacySolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/CloudLegacySolrClient.java
@@ -64,7 +64,7 @@ public class CloudLegacySolrClient extends CloudSolrClient {
     super(builder.shardLeadersOnly, builder.parallelUpdates, builder.directUpdatesToLeadersOnly);
     this.stateProvider = builder.stateProvider;
     this.retryExpiryTimeNano = builder.retryExpiryTimeNano;
-    this.defaultCollection = builder.defaultDataStore;
+    this.defaultCollection = builder.defaultCollection;
     this.collectionStateCache.timeToLiveMs =
         TimeUnit.MILLISECONDS.convert(builder.timeToLiveSeconds, TimeUnit.SECONDS);
     this.clientIsInternal = builder.httpClient == null;
@@ -238,16 +238,6 @@ public class CloudLegacySolrClient extends CloudSolrClient {
       return this;
     }
 
-    /**
-     * Sets a default collection for all collection-based requests.
-     *
-     * <p>Identical to {@link #withDefaultDataStore(String)} for this builder
-     */
-    public Builder withDefaultCollection(String defaultCollection) {
-      this.defaultDataStore = defaultCollection;
-      return this;
-    }
-
     /** Provides a {@link HttpClient} for the builder to use when creating clients. */
     public Builder withLBHttpSolrClientBuilder(LBHttpSolrClient.Builder lbHttpSolrClientBuilder) {
       this.lbClientBuilder = lbHttpSolrClientBuilder;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateHttp2SolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateHttp2SolrClient.java
index 350d8c17a5c..d000933b41f 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateHttp2SolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateHttp2SolrClient.java
@@ -150,7 +150,7 @@ public class ConcurrentUpdateHttp2SolrClient extends SolrClient {
     this.runners = new ArrayDeque<>();
     this.streamDeletes = builder.streamDeletes;
     this.basePath = builder.baseSolrUrl;
-    this.defaultCollection = builder.defaultDataStore;
+    this.defaultCollection = builder.defaultCollection;
     this.pollQueueTimeMillis = builder.pollQueueTimeMillis;
     this.stallTimeMillis = Integer.getInteger("solr.cloud.client.stallTime", 15000);
 
@@ -369,7 +369,7 @@ public class ConcurrentUpdateHttp2SolrClient extends SolrClient {
   @Override
   public NamedList<Object> request(final SolrRequest<?> request, String collection)
       throws SolrServerException, IOException {
-    if (ClientUtils.shouldApplyDefaultDataStore(collection, request))
+    if (ClientUtils.shouldApplyDefaultCollection(collection, request))
       collection = defaultCollection;
     if (!(request instanceof UpdateRequest)) {
       request.setBasePath(basePath);
@@ -725,7 +725,7 @@ public class ConcurrentUpdateHttp2SolrClient extends SolrClient {
   public static class Builder {
     protected Http2SolrClient client;
     protected String baseSolrUrl;
-    protected String defaultDataStore;
+    protected String defaultCollection;
     protected int queueSize = 10;
     protected int threadCount;
     protected ExecutorService executorService;
@@ -816,9 +816,9 @@ public class ConcurrentUpdateHttp2SolrClient extends SolrClient {
       return this;
     }
 
-    /** Sets a default data store for core- or collection-based requests. */
-    public Builder withDefaultDataStore(String defaultCoreOrCollection) {
-      this.defaultDataStore = defaultCoreOrCollection;
+    /** Sets a default for core or collection based requests. */
+    public Builder withDefaultCollection(String defaultCoreOrCollection) {
+      this.defaultCollection = defaultCoreOrCollection;
       return this;
     }
 
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClient.java
index 6a6858f851f..2341ea3d4e2 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClient.java
@@ -119,7 +119,7 @@ public class ConcurrentUpdateSolrClient extends SolrClient {
 
     this.pollQueueTimeMillis = builder.pollQueueTime;
     this.stallTimeMillis = Integer.getInteger("solr.cloud.client.stallTime", 15000);
-    this.defaultCollection = builder.defaultDataStore;
+    this.defaultCollection = builder.defaultCollection;
 
     // make sure the stall time is larger than the polling time
     // to give a chance for the queue to change
@@ -488,7 +488,7 @@ public class ConcurrentUpdateSolrClient extends SolrClient {
   @Override
   public NamedList<Object> request(final SolrRequest<?> request, String collection)
       throws SolrServerException, IOException {
-    if (ClientUtils.shouldApplyDefaultDataStore(collection, request))
+    if (ClientUtils.shouldApplyDefaultCollection(collection, request))
       collection = defaultCollection;
     if (!(request instanceof UpdateRequest)) {
       return client.request(request, collection);
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/Http2SolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/Http2SolrClient.java
index 6d15ba258f9..374b7a704d9 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/Http2SolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/Http2SolrClient.java
@@ -192,7 +192,7 @@ public class Http2SolrClient extends SolrClient {
       this.parser = builder.responseParser;
     }
     updateDefaultMimeTypeForParser();
-    this.defaultCollection = builder.defaultDataStore;
+    this.defaultCollection = builder.defaultCollection;
     if (builder.requestTimeoutMillis != null) {
       this.requestTimeoutMillis = builder.requestTimeoutMillis;
     } else {
@@ -557,7 +557,7 @@ public class Http2SolrClient extends SolrClient {
       throws SolrServerException, IOException {
 
     solrRequest = unwrapV2Request(solrRequest);
-    if (ClientUtils.shouldApplyDefaultDataStore(collection, solrRequest))
+    if (ClientUtils.shouldApplyDefaultCollection(collection, solrRequest))
       collection = defaultCollection;
     String url = getRequestPath(solrRequest, collection);
     Throwable abortCause = null;
@@ -1113,7 +1113,7 @@ public class Http2SolrClient extends SolrClient {
     private ExecutorService executor;
     protected RequestWriter requestWriter;
     protected ResponseParser responseParser;
-    protected String defaultDataStore;
+    protected String defaultCollection;
     private Set<String> urlParamNames;
     private CookieStore cookieStore = getDefaultCookieStore();
     private String proxyHost;
@@ -1238,9 +1238,9 @@ public class Http2SolrClient extends SolrClient {
       return this;
     }
 
-    /** Sets a default data store for core- or collection-based requests. */
-    public Builder withDefaultDataStore(String defaultCoreOrCollection) {
-      this.defaultDataStore = defaultCoreOrCollection;
+    /** Sets a default for core or collection based requests. */
+    public Builder withDefaultCollection(String defaultCoreOrCollection) {
+      this.defaultCollection = defaultCoreOrCollection;
       return this;
     }
 
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/HttpSolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/HttpSolrClient.java
index fa56929efb3..48e5b2deead 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/HttpSolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/HttpSolrClient.java
@@ -191,7 +191,7 @@ public class HttpSolrClient extends BaseHttpSolrClient {
     this.soTimeout = builder.socketTimeoutMillis;
     this.useMultiPartPost = builder.useMultiPartPost;
     this.urlParamNames = builder.urlParamNames;
-    this.defaultCollection = builder.defaultDataStore;
+    this.defaultCollection = builder.defaultCollection;
   }
 
   /**
@@ -254,7 +254,7 @@ public class HttpSolrClient extends BaseHttpSolrClient {
   public NamedList<Object> request(
       final SolrRequest<?> request, final ResponseParser processor, String collection)
       throws SolrServerException, IOException {
-    if (ClientUtils.shouldApplyDefaultDataStore(collection, request))
+    if (ClientUtils.shouldApplyDefaultCollection(collection, request))
       collection = defaultCollection;
     HttpRequestBase method = createMethod(request, collection);
     setBasicAuthHeader(request, method);
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttp2SolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttp2SolrClient.java
index cf3cc486960..b756b02f772 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttp2SolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttp2SolrClient.java
@@ -98,7 +98,7 @@ public class LBHttp2SolrClient extends LBSolrClient {
     super(Arrays.asList(builder.baseSolrUrls));
     this.solrClient = builder.http2SolrClient;
     this.aliveCheckIntervalMillis = builder.aliveCheckIntervalMillis;
-    this.defaultCollection = builder.defaultDataStore;
+    this.defaultCollection = builder.defaultCollection;
   }
 
   @Override
@@ -320,7 +320,7 @@ public class LBHttp2SolrClient extends LBSolrClient {
     private final String[] baseSolrUrls;
     private long aliveCheckIntervalMillis =
         TimeUnit.MILLISECONDS.convert(60, TimeUnit.SECONDS); // 1 minute between checks
-    protected String defaultDataStore;
+    protected String defaultCollection;
 
     public Builder(Http2SolrClient http2Client, String... baseSolrUrls) {
       this.http2SolrClient = http2Client;
@@ -342,9 +342,9 @@ public class LBHttp2SolrClient extends LBSolrClient {
       return this;
     }
 
-    /** Sets a default data store for core- or collection-based requests. */
-    public LBHttp2SolrClient.Builder withDefaultDataStore(String defaultCoreOrCollection) {
-      this.defaultDataStore = defaultCoreOrCollection;
+    /** Sets a default for core or collection based requests. */
+    public LBHttp2SolrClient.Builder withDefaultCollection(String defaultCoreOrCollection) {
+      this.defaultCollection = defaultCoreOrCollection;
       return this;
     }
 
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttpSolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttpSolrClient.java
index e5864e2eff3..12aaf0c86ef 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttpSolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBHttpSolrClient.java
@@ -93,9 +93,9 @@ public class LBHttpSolrClient extends LBSolrClient {
         builder.httpClient == null
             ? constructClient(builder.baseSolrUrls.toArray(new String[0]))
             : builder.httpClient;
-    this.defaultCollection = builder.defaultDataStore;
+    this.defaultCollection = builder.defaultCollection;
     if (httpSolrClientBuilder != null && this.defaultCollection != null) {
-      httpSolrClientBuilder.defaultDataStore = this.defaultCollection;
+      httpSolrClientBuilder.defaultCollection = this.defaultCollection;
     }
     this.connectionTimeoutMillis = builder.connectionTimeoutMillis;
     this.soTimeoutMillis = builder.socketTimeoutMillis;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBSolrClient.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBSolrClient.java
index bbad09bf6f9..9202768bcf6 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBSolrClient.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/LBSolrClient.java
@@ -617,7 +617,7 @@ public abstract class LBSolrClient extends SolrClient {
     final int maxTries = (numServersToTry == null ? serverList.length : numServersToTry.intValue());
     int numServersTried = 0;
     Map<String, ServerWrapper> justFailed = null;
-    if (ClientUtils.shouldApplyDefaultDataStore(collection, request))
+    if (ClientUtils.shouldApplyDefaultCollection(collection, request))
       collection = defaultCollection;
 
     boolean timeAllowedExceeded = false;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/SolrClientBuilder.java b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/SolrClientBuilder.java
index c08fa9ed734..94657ab7b9d 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/impl/SolrClientBuilder.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/impl/SolrClientBuilder.java
@@ -41,7 +41,7 @@ public abstract class SolrClientBuilder<B extends SolrClientBuilder<B>> {
   protected int socketTimeoutMillis = 120000; // 120 seconds
   private boolean socketTimeoutMillisUpdate = false;
   protected boolean followRedirects = false;
-  protected String defaultDataStore;
+  protected String defaultCollection;
   protected Set<String> urlParamNames;
 
   /** The solution for the unchecked cast warning. */
@@ -98,9 +98,9 @@ public abstract class SolrClientBuilder<B extends SolrClientBuilder<B>> {
     return getThis();
   }
 
-  /** Sets a default data store for core- or collection-based requests. */
-  public B withDefaultDataStore(String defaultCoreOrCollection) {
-    this.defaultDataStore = defaultCoreOrCollection;
+  /** Sets a default for core or collection based requests. */
+  public B withDefaultCollection(String defaultCoreOrCollection) {
+    this.defaultCollection = defaultCoreOrCollection;
     return getThis();
   }
 
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/AbstractUpdateRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/AbstractUpdateRequest.java
index bbdba067ea4..2df8e8c5af9 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/AbstractUpdateRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/AbstractUpdateRequest.java
@@ -22,7 +22,7 @@ import org.apache.solr.common.params.ModifiableSolrParams;
 import org.apache.solr.common.params.UpdateParams;
 
 /** */
-public abstract class AbstractUpdateRequest extends DataStoreSolrRequest<UpdateResponse>
+public abstract class AbstractUpdateRequest extends CollectionRequiringSolrRequest<UpdateResponse>
     implements IsUpdateRequest {
   protected ModifiableSolrParams params;
   protected int commitWithin = -1;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/DataStoreSolrRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/CollectionRequiringSolrRequest.java
similarity index 77%
rename from solr/solrj/src/java/org/apache/solr/client/solrj/request/DataStoreSolrRequest.java
rename to solr/solrj/src/java/org/apache/solr/client/solrj/request/CollectionRequiringSolrRequest.java
index 2972e99913b..d5ebff84821 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/DataStoreSolrRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/CollectionRequiringSolrRequest.java
@@ -19,13 +19,15 @@ package org.apache.solr.client.solrj.request;
 import org.apache.solr.client.solrj.SolrRequest;
 import org.apache.solr.client.solrj.SolrResponse;
 
-public abstract class DataStoreSolrRequest<T extends SolrResponse> extends SolrRequest<T> {
-  public DataStoreSolrRequest(METHOD m, String path) {
+/** Parent {@link SolrRequest} class that requires a target collection or core. */
+public abstract class CollectionRequiringSolrRequest<T extends SolrResponse>
+    extends SolrRequest<T> {
+  public CollectionRequiringSolrRequest(METHOD m, String path) {
     super(m, path);
   }
 
   @Override
-  public boolean requiresDataStore() {
+  public boolean requiresCollection() {
     return true;
   }
 }
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/DirectXmlRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/DirectXmlRequest.java
index 8b2c09dbdd5..4fbe8b08158 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/DirectXmlRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/DirectXmlRequest.java
@@ -27,7 +27,7 @@ import org.apache.solr.common.params.SolrParams;
  *
  * @since solr 1.3
  */
-public class DirectXmlRequest extends DataStoreSolrRequest<UpdateResponse>
+public class DirectXmlRequest extends CollectionRequiringSolrRequest<UpdateResponse>
     implements IsUpdateRequest {
 
   final String xml;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/DocumentAnalysisRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/DocumentAnalysisRequest.java
index 494b1e518ee..912ba039756 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/DocumentAnalysisRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/DocumentAnalysisRequest.java
@@ -37,7 +37,8 @@ import org.apache.solr.common.params.ModifiableSolrParams;
  *
  * @since solr 1.4
  */
-public class DocumentAnalysisRequest extends DataStoreSolrRequest<DocumentAnalysisResponse> {
+public class DocumentAnalysisRequest
+    extends CollectionRequiringSolrRequest<DocumentAnalysisResponse> {
 
   private List<SolrInputDocument> documents = new ArrayList<>();
   private String query;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/FieldAnalysisRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/FieldAnalysisRequest.java
index 5458ac99dde..8dda80d22f4 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/FieldAnalysisRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/FieldAnalysisRequest.java
@@ -29,7 +29,7 @@ import org.apache.solr.common.params.SolrParams;
  *
  * @since solr.14
  */
-public class FieldAnalysisRequest extends DataStoreSolrRequest<FieldAnalysisResponse> {
+public class FieldAnalysisRequest extends CollectionRequiringSolrRequest<FieldAnalysisResponse> {
 
   private String fieldValue;
   private String query;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/LukeRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/LukeRequest.java
index a3b3a9d265b..a3225c4fc87 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/LukeRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/LukeRequest.java
@@ -27,7 +27,7 @@ import org.apache.solr.common.params.SolrParams;
 /**
  * @since solr 1.3
  */
-public class LukeRequest extends DataStoreSolrRequest<LukeResponse> {
+public class LukeRequest extends CollectionRequiringSolrRequest<LukeResponse> {
 
   private List<String> fields;
   private int numTerms = -1;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/QueryRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/QueryRequest.java
index cb01201842d..082b88cd101 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/QueryRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/QueryRequest.java
@@ -24,7 +24,7 @@ import org.apache.solr.common.params.SolrParams;
 /**
  * @since solr 1.3
  */
-public class QueryRequest extends DataStoreSolrRequest<QueryResponse> {
+public class QueryRequest extends CollectionRequiringSolrRequest<QueryResponse> {
 
   private SolrParams query;
 
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/SolrPing.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/SolrPing.java
index ee1e89cbb89..49fcd3015ea 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/SolrPing.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/SolrPing.java
@@ -28,7 +28,7 @@ import org.apache.solr.common.params.ModifiableSolrParams;
  *
  * @since solr 1.3
  */
-public class SolrPing extends DataStoreSolrRequest<SolrPingResponse> {
+public class SolrPing extends CollectionRequiringSolrRequest<SolrPingResponse> {
 
   /** serialVersionUID. */
   private static final long serialVersionUID = 5828246236669090017L;
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/request/schema/AbstractSchemaRequest.java b/solr/solrj/src/java/org/apache/solr/client/solrj/request/schema/AbstractSchemaRequest.java
index db6ef157c55..57edce799ba 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/request/schema/AbstractSchemaRequest.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/request/schema/AbstractSchemaRequest.java
@@ -17,11 +17,11 @@
 package org.apache.solr.client.solrj.request.schema;
 
 import org.apache.solr.client.solrj.SolrResponse;
-import org.apache.solr.client.solrj.request.DataStoreSolrRequest;
+import org.apache.solr.client.solrj.request.CollectionRequiringSolrRequest;
 import org.apache.solr.common.params.SolrParams;
 
 public abstract class AbstractSchemaRequest<T extends SolrResponse>
-    extends DataStoreSolrRequest<T> {
+    extends CollectionRequiringSolrRequest<T> {
   private SolrParams params = null;
 
   public AbstractSchemaRequest(METHOD m, String path) {
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/util/ClientUtils.java b/solr/solrj/src/java/org/apache/solr/client/solrj/util/ClientUtils.java
index fa83c1ddb71..be6b02977ea 100644
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/util/ClientUtils.java
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/util/ClientUtils.java
@@ -249,8 +249,8 @@ public class ClientUtils {
    *     through {@link org.apache.solr.client.solrj.SolrClient#request(SolrRequest, String)}
    * @param request the {@link SolrRequest} being executed
    */
-  public static boolean shouldApplyDefaultDataStore(
+  public static boolean shouldApplyDefaultCollection(
       String providedCollection, SolrRequest<? extends SolrResponse> request) {
-    return providedCollection == null && request.requiresDataStore();
+    return providedCollection == null && request.requiresCollection();
   }
 }
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClientBuilderTest.java b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClientBuilderTest.java
index c311b99a32b..c6cd4779f96 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClientBuilderTest.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/ConcurrentUpdateSolrClientBuilderTest.java
@@ -77,7 +77,7 @@ public class ConcurrentUpdateSolrClientBuilderTest extends SolrTestCase {
   public void testDefaultCollectionPassedFromBuilderToClient() throws IOException {
     try (SolrClient createdClient =
         new ConcurrentUpdateSolrClient.Builder("someurl")
-            .withDefaultDataStore("aCollection")
+            .withDefaultCollection("aCollection")
             .build()) {
       assertEquals("aCollection", createdClient.getDefaultCollection());
     }
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientBuilderTest.java b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientBuilderTest.java
index 65e113a0a11..6aba55d47bf 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientBuilderTest.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/HttpSolrClientBuilderTest.java
@@ -88,7 +88,7 @@ public class HttpSolrClientBuilderTest extends SolrTestCase {
   @Test
   public void testDefaultCollectionPassedFromBuilderToClient() throws IOException {
     try (final SolrClient createdClient =
-        new Builder(ANY_BASE_SOLR_URL).withDefaultDataStore("aCollection").build()) {
+        new Builder(ANY_BASE_SOLR_URL).withDefaultCollection("aCollection").build()) {
       assertEquals("aCollection", createdClient.getDefaultCollection());
     }
   }
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/LBHttpSolrClientBuilderTest.java b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/LBHttpSolrClientBuilderTest.java
index 2aa7e9b756b..6db869cf96b 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/impl/LBHttpSolrClientBuilderTest.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/impl/LBHttpSolrClientBuilderTest.java
@@ -83,7 +83,7 @@ public class LBHttpSolrClientBuilderTest extends SolrTestCase {
     try (LBHttpSolrClient createdClient =
         new LBHttpSolrClient.Builder()
             .withBaseSolrUrl(ANY_BASE_SOLR_URL)
-            .withDefaultDataStore("aCollection")
+            .withDefaultCollection("aCollection")
             .build()) {
       assertEquals("aCollection", createdClient.getDefaultCollection());
     }
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/response/TestSuggesterResponse.java b/solr/solrj/src/test/org/apache/solr/client/solrj/response/TestSuggesterResponse.java
index b595b23fd61..65d2c966257 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/response/TestSuggesterResponse.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/response/TestSuggesterResponse.java
@@ -144,7 +144,7 @@ public class TestSuggesterResponse extends SolrJettyTestBase {
         random().nextBoolean() ? new BinaryResponseParser() : new XMLResponseParser();
     return new HttpSolrClient.Builder()
         .withBaseSolrUrl(getBaseUrl())
-        .withDefaultDataStore(DEFAULT_TEST_CORENAME)
+        .withDefaultCollection(DEFAULT_TEST_CORENAME)
         .withResponseParser(randomParser)
         .build();
   }
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/util/ClientUtilsTest.java b/solr/solrj/src/test/org/apache/solr/client/solrj/util/ClientUtilsTest.java
index d62c88e539d..0d078eeec4b 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/util/ClientUtilsTest.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/util/ClientUtilsTest.java
@@ -35,18 +35,18 @@ public class ClientUtilsTest extends SolrTestCase {
   }
 
   @Test
-  public void testDeterminesWhenToUseDefaultDataStore() {
+  public void testDeterminesWhenToUseDefaultCollection() {
     final var noDefaultNeededRequest = new CollectionAdminRequest.List();
     final var defaultNeededRequest = new UpdateRequest();
 
     assertFalse(
         "Expected default-coll to be skipped for collection-agnostic request",
-        ClientUtils.shouldApplyDefaultDataStore(null, noDefaultNeededRequest));
+        ClientUtils.shouldApplyDefaultCollection(null, noDefaultNeededRequest));
     assertTrue(
         "Expected default-coll to be used for collection-based request",
-        ClientUtils.shouldApplyDefaultDataStore(null, defaultNeededRequest));
+        ClientUtils.shouldApplyDefaultCollection(null, defaultNeededRequest));
     assertFalse(
         "Expected default-coll to be skipped when a collection is explicitly provided",
-        ClientUtils.shouldApplyDefaultDataStore("someCollection", defaultNeededRequest));
+        ClientUtils.shouldApplyDefaultCollection("someCollection", defaultNeededRequest));
   }
 }
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 abda996858f..1a30c07f403 100644
--- a/solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java
+++ b/solr/test-framework/src/java/org/apache/solr/SolrTestCaseJ4.java
@@ -2702,7 +2702,7 @@ public abstract class SolrTestCaseJ4 extends SolrTestCase {
    * should use the {@link org.apache.solr.client.solrj.impl.Http2SolrClient.Builder} class directly
    */
   public static HttpSolrClient getHttpSolrClient(String url, String defaultCoreName) {
-    return new HttpSolrClient.Builder(url).withDefaultDataStore(defaultCoreName).build();
+    return new HttpSolrClient.Builder(url).withDefaultCollection(defaultCoreName).build();
   }
 
   /**
diff --git a/solr/test-framework/src/java/org/apache/solr/cloud/ConfigRequest.java b/solr/test-framework/src/java/org/apache/solr/cloud/ConfigRequest.java
index e4dbffe202e..9a805141d79 100644
--- a/solr/test-framework/src/java/org/apache/solr/cloud/ConfigRequest.java
+++ b/solr/test-framework/src/java/org/apache/solr/cloud/ConfigRequest.java
@@ -19,7 +19,7 @@ package org.apache.solr.cloud;
 import org.apache.solr.client.solrj.SolrClient;
 import org.apache.solr.client.solrj.SolrRequest;
 import org.apache.solr.client.solrj.SolrResponse;
-import org.apache.solr.client.solrj.request.DataStoreSolrRequest;
+import org.apache.solr.client.solrj.request.CollectionRequiringSolrRequest;
 import org.apache.solr.client.solrj.request.RequestWriter;
 import org.apache.solr.client.solrj.response.SolrResponseBase;
 import org.apache.solr.common.params.CommonParams;
@@ -30,7 +30,7 @@ import org.apache.solr.common.params.SolrParams;
  * components, handlers, parsers, etc. to an otherwise generic configset.
  */
 @SuppressWarnings({"rawtypes"})
-public class ConfigRequest extends DataStoreSolrRequest {
+public class ConfigRequest extends CollectionRequiringSolrRequest {
 
   protected final String message;