A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages

A

a - Variable in class org.apache.solr.search.function.DualDoubleFunction
 
ABORT - org.apache.solr.cloud.api.collections.ReindexCollectionCmd.Cmd
 
ABORTED - org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
 
abortErrorMessage - Variable in class org.apache.solr.servlet.SolrDispatchFilter
 
abortFetch() - Method in class org.apache.solr.handler.ReplicationHandler
 
absComparator - Static variable in class org.apache.solr.update.PeerSync
 
AbstractDefaultValueUpdateProcessorFactory - Class in org.apache.solr.update.processor
Base class that can be extended by any UpdateRequestProcessorFactory designed to add a default value to the document in an AddUpdateCommand when that field is not already specified.
AbstractDefaultValueUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.AbstractDefaultValueUpdateProcessorFactory
 
AbstractEnumField - Class in org.apache.solr.schema
Abstract Field type for support of string values with custom sort order.
AbstractEnumField() - Constructor for class org.apache.solr.schema.AbstractEnumField
 
AbstractEnumField.EnumMapping - Class in org.apache.solr.schema
Models all the info contained in an enums config XML file
AbstractLuceneSpellChecker - Class in org.apache.solr.spelling
Abstract base class for all Lucene-based spell checking implementations.
AbstractLuceneSpellChecker() - Constructor for class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
AbstractPluginLoader<T> - Class in org.apache.solr.util.plugin
An abstract super class that manages standard solr-style plugin configuration.
AbstractPluginLoader(String, Class<T>) - Constructor for class org.apache.solr.util.plugin.AbstractPluginLoader
 
AbstractPluginLoader(String, Class<T>, boolean, boolean) - Constructor for class org.apache.solr.util.plugin.AbstractPluginLoader
 
AbstractReRankQuery - Class in org.apache.solr.search
 
AbstractReRankQuery(Query, int, Rescorer) - Constructor for class org.apache.solr.search.AbstractReRankQuery
 
AbstractReRankQuery(Query, int, Rescorer, ReRankScaler, ReRankOperator) - Constructor for class org.apache.solr.search.AbstractReRankQuery
 
AbstractSolrEventListener - Class in org.apache.solr.core
 
AbstractSolrEventListener(SolrCore) - Constructor for class org.apache.solr.core.AbstractSolrEventListener
 
AbstractSpatialFieldType<T extends org.apache.lucene.spatial.SpatialStrategy> - Class in org.apache.solr.schema
Abstract base class for Solr FieldTypes based on a Lucene 4 SpatialStrategy.
AbstractSpatialFieldType() - Constructor for class org.apache.solr.schema.AbstractSpatialFieldType
 
AbstractSpatialFieldType(Set<String>) - Constructor for class org.apache.solr.schema.AbstractSpatialFieldType
 
AbstractSpatialPrefixTreeFieldType<T extends org.apache.lucene.spatial.prefix.PrefixTreeStrategy> - Class in org.apache.solr.schema
 
AbstractSpatialPrefixTreeFieldType() - Constructor for class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
AbstractSSLCredentialProvider - Class in org.apache.solr.util.configuration.providers
Abstract provider with default implementation
AbstractSSLCredentialProvider() - Constructor for class org.apache.solr.util.configuration.providers.AbstractSSLCredentialProvider
 
AbstractSubTypeFieldType - Class in org.apache.solr.schema
An abstract base class for FieldTypes that delegate work to another FieldType.
AbstractSubTypeFieldType() - Constructor for class org.apache.solr.schema.AbstractSubTypeFieldType
 
accept(float) - Method in interface org.apache.solr.util.FloatConsumer
Performs this operation on the given argument.
accept(File) - Method in class org.apache.solr.util.RegexFileFilter
 
ACCEPT_VERSIONS - Static variable in class org.apache.solr.security.PKIAuthenticationPlugin
 
accumulate(int) - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
accumulate(int) - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
accumulate(int) - Method in interface org.apache.solr.handler.component.StatsValues
Accumulate the value associated with docID.
accumulate(BytesRef, int) - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
accumulate(BytesRef, int) - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
accumulate(BytesRef, int) - Method in interface org.apache.solr.handler.component.StatsValues
Accumulate the values based on the given value
accumulate(NamedList<?>) - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
accumulate(NamedList<?>) - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
accumulate(NamedList<?>) - Method in interface org.apache.solr.handler.component.StatsValues
Accumulate the values based on those in the given NamedList
accumulateMissing() - Method in class org.apache.solr.handler.component.FieldFacetStats
 
accumulateTermNum(int, BytesRef) - Method in class org.apache.solr.handler.component.FieldFacetStats
 
accuracy - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
accuracy - Variable in class org.apache.solr.spelling.SpellingOptions
Optionally restrict the results to have a minimum accuracy level.
ACCURACY - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
ACCURACY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
acquire() - Method in class org.apache.solr.util.AdjustableSemaphore
 
action - Variable in class org.apache.solr.servlet.HttpSolrCall
 
Action(RoutedAlias, RoutedAlias.ActionType, String) - Constructor for class org.apache.solr.cloud.api.collections.RoutedAlias.Action
 
ActionThrottle - Class in org.apache.solr.cloud
 
ActionThrottle(String, long) - Constructor for class org.apache.solr.cloud.ActionThrottle
 
ActionThrottle(String, long, long) - Constructor for class org.apache.solr.cloud.ActionThrottle
 
ActionThrottle(String, long, long, TimeSource) - Constructor for class org.apache.solr.cloud.ActionThrottle
 
ActionThrottle(String, long, TimeSource) - Constructor for class org.apache.solr.cloud.ActionThrottle
 
ACTIVE - org.apache.solr.cluster.Replica.ReplicaState
 
ACTIVE - org.apache.solr.cluster.Shard.ShardState
 
ACTIVE - org.apache.solr.update.UpdateLog.State
 
ActiveReplicaWatcher - Class in org.apache.solr.cloud
Watch for replicas to become Replica.State.ACTIVE.
ActiveReplicaWatcher(String, List<String>, List<String>, SolrCloseableLatch) - Constructor for class org.apache.solr.cloud.ActiveReplicaWatcher
Construct the watcher.
ActiveTasksListComponent - Class in org.apache.solr.handler.component
List the active tasks that can be cancelled
ActiveTasksListComponent() - Constructor for class org.apache.solr.handler.component.ActiveTasksListComponent
 
ActiveTasksListHandler - Class in org.apache.solr.handler.component
Handles request for listing all active cancellable tasks
ActiveTasksListHandler() - Constructor for class org.apache.solr.handler.component.ActiveTasksListHandler
 
actualShards - Variable in class org.apache.solr.handler.component.ShardRequest
actual shards to send the request to, filled out by framework
adaptExistingFieldToData(SchemaField, List<Object>, ManagedIndexSchema) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
adaptExistingFieldToData(SchemaField, List<Object>, ManagedIndexSchema) - Method in interface org.apache.solr.handler.designer.SchemaSuggester
 
add(int) - Method in class org.apache.solr.search.DocSetBuilder
 
add(int, int) - Method in class org.apache.solr.search.DocSetCollector.ExpandingIntArray
 
add(long) - Method in class org.apache.solr.util.LongPriorityQueue
Adds an object to a PriorityQueue in log(size) time.
add(long) - Method in class org.apache.solr.util.LongSet
Adds an additional value to the set, returns true if the set did not already contain the value.
add(E) - Method in class org.apache.solr.util.BoundedTreeSet
 
add(E, long) - Method in class org.apache.solr.logging.LogWatcher
 
add(CharSequence, Object) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
Adds a new node if key already exists, otherwise replaces its value.
add(String) - Method in class org.apache.solr.update.processor.Lookup3Signature
 
add(String) - Method in class org.apache.solr.update.processor.MD5Signature
 
add(String) - Method in class org.apache.solr.update.processor.Signature
 
add(String) - Method in class org.apache.solr.update.processor.TextProfileSignature
 
add(String, Object) - Method in class org.apache.solr.index.MergePolicyFactoryArgs
 
add(String, Object) - Method in class org.apache.solr.response.SolrQueryResponse
Appends a named value to the list of named values to be returned.
add(String, String, List<Lookup.LookupResult>) - Method in class org.apache.solr.spelling.suggest.SuggesterResult
Add suggestion results for token
add(TermsEnum, int) - Method in class org.apache.solr.search.DocSetBuilder
Returns the number of terms visited
add(DocIdSetIterator, int) - Method in class org.apache.solr.search.DocSetBuilder
 
add(FixedBitSet, DocIdSetIterator, int) - Static method in class org.apache.solr.search.DocSetBuilder
 
add(Api) - Method in class org.apache.solr.api.V2HttpCall.CompositeApi
 
add(PayloadObj<PackagePayload.AddVersion>) - Method in class org.apache.solr.pkg.PackageAPI.Edit
 
add(PayloadObj<PluginMeta>) - Method in class org.apache.solr.handler.admin.ContainerPluginsApi.Edit
 
add(ShardBackupMetadata) - Method in class org.apache.solr.core.backup.AggregateBackupStats
 
add(PivotFacetValue) - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Adds a PivotFacetValue to this collection -- callers must not use this method if a PivotFacetValue with the same value already exists in this collection
add(Grouping.Command<?>) - Method in class org.apache.solr.search.Grouping
 
add(CollectionStats) - Method in class org.apache.solr.search.stats.CollectionStats
 
add(TermStats) - Method in class org.apache.solr.search.stats.TermStats
 
add(Token, String, int) - Method in class org.apache.solr.spelling.SpellingResult
Suggestions must be added with the best suggestion first.
add(Token, List<String>) - Method in class org.apache.solr.spelling.SpellingResult
Adds a whole bunch of suggestions, and does not worry about frequency.
add(AddUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
 
add(AddUpdateCommand, boolean) - Method in class org.apache.solr.update.UpdateLog
 
add(ConcurrentLRUCache.Stats) - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
add(T) - Method in class org.apache.solr.logging.CircularList
 
ADD - org.apache.solr.search.ReRankOperator
 
ADD - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
ADD - Static variable in class org.apache.solr.update.UpdateLog
 
ADD_COPY_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
ADD_DYNAMIC_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
ADD_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
ADD_FIELD_TYPE - org.apache.solr.schema.SchemaManager.OpType
 
addAlias(String, float, Map<String, Float>) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
Add an alias to this query parser.
addAlias(String, float, Map<String, Float>) - Method in class org.apache.solr.util.SolrPluginUtils.DisjunctionMaxQueryParser
Add an alias to this query parser.
addAll(Collection<? extends E>) - Method in class org.apache.solr.util.BoundedTreeSet
 
addAllTo(FixedBitSet) - Method in class org.apache.solr.search.BitDocSet
 
addAllTo(FixedBitSet) - Method in class org.apache.solr.search.DocSet
Adds all the docs from this set to the target.
addAllTo(FixedBitSet) - Method in class org.apache.solr.search.SortedIntDocSet
 
addBackedFile(String, String, Checksum) - Method in class org.apache.solr.core.backup.ShardBackupMetadata
 
addBackedFile(ShardBackupMetadata.BackedFile) - Method in class org.apache.solr.core.backup.ShardBackupMetadata
 
addBoostFunctions(BooleanQuery.Builder, SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
 
addBoostQuery(BooleanQuery.Builder, SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
 
addChecker(SolrSpellChecker) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
addChild(FacetDebugInfo) - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
addClause(List<BooleanClause>, int, int, Query) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
addCloseHook(Closeable) - Method in class org.apache.solr.request.SolrRequestInfo
 
addCloseHook(Closeable) - Method in class org.apache.solr.search.QueryContext
 
addCloseHook(CloseHook) - Method in class org.apache.solr.core.SolrCore
Add a close callback hook
addCloseListener(Directory, CachingDirectoryFactory.CloseListener) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
addCloseListener(Directory, CachingDirectoryFactory.CloseListener) - Method in class org.apache.solr.core.DirectoryFactory
Adds a close listener for a Directory.
addCollationsToResponse(SolrParams, SpellingResult, ResponseBuilder, String, NamedList<Object>, boolean) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
addCollectionParamIfNeeded(List<String>) - Method in class org.apache.solr.servlet.HttpSolrCall
Sets the "collection" parameter on the request to the list of alias-resolved collections for this request.
addCommandField(Command<?>) - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
 
addConfListener(Runnable) - Method in class org.apache.solr.core.SolrCore
Register to notify for any file change in the conf directory.
addCopyFields(String, Collection<String>, int) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema and adds the new copy fields to the copy.
addCopyFields(String, Collection<String>, int) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
addCopyFields(Map<String, Collection<String>>, boolean) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema and adds the new copy fields to the copy Requires synchronizing on the object returned by IndexSchema.getSchemaUpdateLock().
addCopyFields(Map<String, Collection<String>>, boolean) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
addCore(String, SolrCore) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Adds the newly-opened core to the list of open cores.
addCore(String, SolrCore) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
addCoreDescriptor(CoreDescriptor) - Method in class org.apache.solr.core.SolrCores
 
addCoreDescriptor(CoreDescriptor) - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
addDebug(Object, String...) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
addDebugInfo(String, Object) - Method in class org.apache.solr.handler.component.ResponseBuilder
Utility function to add debugging info.
addDebugInfo(NamedList<Object>) - Method in class org.apache.solr.search.DisMaxQParser
 
addDebugInfo(NamedList<Object>) - Method in class org.apache.solr.search.ExtendedDismaxQParser
 
addDebugInfo(NamedList<Object>) - Method in class org.apache.solr.search.QParser
 
addDeprecatedWarning() - Method in class org.apache.solr.rest.BaseSolrResource
 
addDeprecatedWarning() - Method in class org.apache.solr.rest.RestManager.ManagedEndpoint
 
addDoc(int, String[]) - Method in class org.apache.solr.handler.loader.CSVLoaderBase
called for each line of values (document)
addDoc(AddUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
addDoc(AddUpdateCommand) - Method in class org.apache.solr.update.UpdateHandler
 
addDocList(NamedList<? super DocList>, GroupDocs<?>) - Method in class org.apache.solr.search.Grouping.Command
 
addDynamicFields(Collection<SchemaField>, Map<String, Collection<String>>, boolean) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, adds the given dynamic fields to the copy, Requires synchronizing on the object returned by IndexSchema.getSchemaUpdateLock().
addDynamicFields(Collection<SchemaField>, Map<String, Collection<String>>, boolean) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
added(ContainerPluginsRegistry.ApiInfo) - Method in interface org.apache.solr.api.ContainerPluginsRegistry.PluginRegistryListener
Called when a new plugin is added.
ADDED - org.apache.solr.api.ContainerPluginsRegistry.Diff
 
addedDocument(int) - Method in class org.apache.solr.update.CommitTracker
Indicate that documents have been added
addedDocument(int, LongSupplier) - Method in class org.apache.solr.update.CommitTracker
Indicate that documents have been added
addElevatedIds(List<String>) - Method in class org.apache.solr.handler.component.QueryElevationComponent.ElevationBuilder
 
addErrorToResponse(String, SolrException, Map<Object, Throwable>, Map<String, Object>, String) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
addEscapes(String) - Static method in error org.apache.solr.parser.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addEventParms(SolrIndexSearcher, NamedList<Object>) - Method in class org.apache.solr.core.AbstractSolrEventListener
Add the EventParams.EVENT with either the EventParams.NEW_SEARCHER or EventParams.FIRST_SEARCHER values depending on the value of currentSearcher.
addExceptionToNamedList(Object, Exception, NamedList<Object>) - Static method in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
Creates a SimpleOrderedMap with the exception details and adds it to the results
addExcludedIds(Collection<String>) - Method in class org.apache.solr.handler.component.QueryElevationComponent.ElevationBuilder
 
addExperimentalFormatWarning(SolrQueryResponse) - Static method in class org.apache.solr.handler.RequestHandlerUtils
A common way to mark the response format as experimental
addExpressiblePlugins(StreamFactory, SolrCore) - Static method in class org.apache.solr.handler.StreamHandler
 
addFacet(String, Map<String, StatsValues>) - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
addFacet(String, Map<String, StatsValues>) - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
addFacet(String, Map<String, StatsValues>) - Method in interface org.apache.solr.handler.component.StatsValues
Adds the facet statistics for the facet with the given name
addField(SchemaField) - Method in class org.apache.solr.schema.IndexSchema
 
addField(SchemaField, boolean) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, adds the given field to the copy Requires synchronizing on the object returned by IndexSchema.getSchemaUpdateLock().
addField(SchemaField, Collection<String>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, adds the given field to the copy Requires synchronizing on the object returned by IndexSchema.getSchemaUpdateLock().
addFieldCommand(String, SolrQueryRequest) - Method in class org.apache.solr.search.Grouping
Adds a field command based on the specified field.
addFieldFacet(String) - Method in class org.apache.solr.search.facet.LegacyFacet
 
addFields(Collection<SchemaField>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, adds the given fields to the copy.
addFields(Collection<SchemaField>, Map<String, Collection<String>>, boolean) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, adds the given fields to the copy Requires synchronizing on the object returned by IndexSchema.getSchemaUpdateLock().
addFields(Collection<SchemaField>, Map<String, Collection<String>>, boolean) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
addFieldTypes(List<FieldType>, boolean) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, adds the given field type to the copy, Requires synchronizing on the object returned by IndexSchema.getSchemaUpdateLock().
addFieldTypes(List<FieldType>, boolean) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
addFL(StringBuilder, String, boolean) - Method in class org.apache.solr.handler.component.QueryComponent
 
addFrequency(Token, int) - Method in class org.apache.solr.spelling.SpellingResult
Adds an original token with its document frequency
addFunctionCommand(String, SolrQueryRequest) - Method in class org.apache.solr.search.Grouping
 
addGlobalStrings(Collection<String>) - Method in class org.apache.solr.update.TransactionLog
 
addHighlights(Object[], Object, Map<Object, ShardDoc>) - Method in class org.apache.solr.handler.component.HighlightComponent
 
addHttpHeader(String, String) - Method in class org.apache.solr.response.SolrQueryResponse
Adds a response header with the given name and value.
addKey(byte[], String) - Method in class org.apache.solr.packagemanager.RepositoryManager
 
addListener(PackageListeners.Listener) - Method in class org.apache.solr.pkg.PackageListeners
 
addListener(PackageListeners.Listener, boolean) - Method in class org.apache.solr.pkg.PackageListeners
 
addMainQuery(BooleanQuery.Builder, SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
Adds the main query to the query argument.
addManagedResource(String, Class<? extends ManagedResource>) - Method in class org.apache.solr.rest.RestManager
If not already registered, registers the given ManagedResource subclass at the given resourceId, creates an instance.
addMergeStrategy(MergeStrategy) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
addMetric(ReplicaMetric<?>, Object) - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ReplicaMetricsBuilder
Add unconverted (raw) values here, this method internally calls Metric.convert(Object).
addMetrics(NamedList<Object>, Timer) - Static method in class org.apache.solr.util.stats.MetricUtils
Adds metrics from a Timer to a NamedList, using well-known back-compat names.
addMissing(int) - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
addMissing(int) - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
addMissing(int) - Method in interface org.apache.solr.handler.component.StatsValues
Updates the statistics when multiple documents are missing a value
addMultiTermClause(List<BooleanClause>, Query) - Method in class org.apache.solr.parser.SolrQueryParserBase
Called from QueryParser's MultiTerm rule.
addMultiTermClause(List<BooleanClause>, Query) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
addMXBeanMetrics(T, Class<? extends T>, String, BiConsumer<String, Metric>) - Static method in class org.apache.solr.util.stats.MetricUtils
Creates a set of metrics (gauges) that correspond to available bean properties for the provided MXBean.
addMXBeanMetrics(T, String[], String, BiConsumer<String, Metric>) - Static method in class org.apache.solr.util.stats.MetricUtils
Creates a set of metrics (gauges) that correspond to available bean properties for the provided MXBean.
addNamedPlugin(Map<String, Object>, String) - Method in class org.apache.solr.core.ConfigOverlay
 
addNoCheck(long) - Method in class org.apache.solr.util.LongPriorityQueue
Adds an object to a PriorityQueue in log(size) time.
addNumberElement(Number) - Method in class org.apache.solr.util.vector.ByteDenseVectorParser
 
addNumberElement(Number) - Method in class org.apache.solr.util.vector.DenseVectorParser
 
addNumberElement(Number) - Method in class org.apache.solr.util.vector.FloatDenseVectorParser
 
addOldLog(TransactionLog, boolean) - Method in class org.apache.solr.update.UpdateLog
 
addOnReconnectListener(OnReconnect) - Method in class org.apache.solr.cloud.ZkController
Add a listener to be notified once there is a new session created after a ZooKeeper session expiration occurs; in most cases, listeners will be components that have watchers that need to be re-created.
addParamToDistributedRequestWhitelist(SolrQueryRequest, String...) - Static method in class org.apache.solr.update.processor.DistributedUpdateProcessorFactory
By default, the DistributedUpdateProcessor is extremely conservative in the list of request params that will be copied/included when updates are forwarded to other nodes.
addPath(String) - Method in class org.apache.solr.core.SolrPaths.AllowPathBuilder
Adds an allowed path.
addPath(Path) - Method in class org.apache.solr.core.SolrPaths.AllowPathBuilder
Adds an allowed path.
addPhraseFieldQueries(BooleanQuery.Builder, List<ExtendedDismaxQParser.Clause>, ExtendedDismaxQParser.ExtendedDismaxConfiguration) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Adds shingled phrase queries to all the fields specified in the pf, pf2 anf pf3 parameters
addPivotQueriesAndRanges(NamedList<Object>, SolrParams, DocSet, List<FacetComponent.FacetBase>, List<RangeFacetRequest>) - Method in class org.apache.solr.handler.component.PivotFacetProcessor
Add facet.queries and facet.ranges to the pivot response if needed
addProjectedReplicaWeights(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
Add the weights for the given replica to this node
addQueryCommand(String, SolrQueryRequest) - Method in class org.apache.solr.search.Grouping
 
addQueryFacet(String) - Method in class org.apache.solr.search.facet.LegacyFacet
 
addRange(int, int, int) - Method in class org.apache.solr.legacy.LegacyNumericUtils.IntRangeBuilder
Deprecated.
Overwrite this method, if you like to receive the raw int range bounds.
addRange(long, long, int) - Method in class org.apache.solr.legacy.LegacyNumericUtils.LongRangeBuilder
Deprecated.
Overwrite this method, if you like to receive the raw long range bounds.
addRange(BytesRef, BytesRef) - Method in class org.apache.solr.legacy.LegacyNumericUtils.IntRangeBuilder
Deprecated.
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRange(BytesRef, BytesRef) - Method in class org.apache.solr.legacy.LegacyNumericUtils.LongRangeBuilder
Deprecated.
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRangeFacet(String) - Method in class org.apache.solr.search.facet.LegacyFacet
 
addRaw(long) - Method in class org.apache.solr.util.hll.HLL
Adds rawValue directly to the HLL.
addRefinement(int, PivotFacetValue) - Method in class org.apache.solr.handler.component.PivotFacet
Tracks that the specified shard needs to be asked to refine the specified PivotFacetValue
addRejectedModification(String, String) - Method in exception org.apache.solr.cluster.placement.PlacementModificationException
Add information about the modification that cause this exception.
addRemoteMessageProperties(Map<String, Object>, String) - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.CategoryRoutedAliasProperties
 
addRemoteMessageProperties(Map<String, Object>, String) - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.RoutedAliasProperties
 
addRemoteMessageProperties(Map<String, Object>, String) - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
addReplica(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
addReplica(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.SliceMutator
 
ADDREPLICA_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
AddReplicaCmd - Class in org.apache.solr.cloud.api.collections
 
AddReplicaCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.AddReplicaCmd
 
AddReplicaCmd.CreateReplica - Class in org.apache.solr.cloud.api.collections
A data structure to keep all information required to create a new replica in one place.
ADDREPLICAPROP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
AddReplicaPropCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.AddReplicaPropCmd
 
addReplicaProperty(String, String, String, String, AddReplicaPropertyRequestBody) - Method in class org.apache.solr.handler.admin.api.AddReplicaProperty
 
addReplicaProperty(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.ReplicaMutator
 
AddReplicaProperty - Class in org.apache.solr.handler.admin.api
V2 API for adding a property to a collection replica
AddReplicaProperty(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.AddReplicaProperty
 
addRepository(String, String) - Method in class org.apache.solr.packagemanager.RepositoryManager
Add a repository to Solr
addRequest(SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
addResponse(Object) - Method in class org.apache.solr.response.SolrQueryResponse
Set response
addResponseHeader(NamedList<Object>) - Method in class org.apache.solr.response.SolrQueryResponse
Set response header
AddressUtils - Class in org.apache.solr.util
Simple utilities for working Hostname/IP Addresses
AddressUtils() - Constructor for class org.apache.solr.util.AddressUtils
 
addRole(PayloadObj<ClusterAPI.RoleInfo>) - Method in class org.apache.solr.handler.ClusterAPI.Commands
 
ADDROLE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
addRoutingRule(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.SliceMutator
 
ADDROUTINGRULE - org.apache.solr.cloud.overseer.OverseerAction
 
adds - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
 
AddSchemaFieldsUpdateProcessorFactory - Class in org.apache.solr.update.processor
This processor will dynamically add fields to the schema if an input document contains one or more fields that don't match any field or dynamic field in the schema.
AddSchemaFieldsUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.AddSchemaFieldsUpdateProcessorFactory
 
addSchemaObject(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
addSettingsToResponse(SchemaDesignerSettings, Map<String, Object>) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
addShardLevelActiveQuery(String, CancellableCollector) - Method in class org.apache.solr.core.CancellableQueryTracker
 
addShingledPhraseQueries(BooleanQuery.Builder, List<ExtendedDismaxQParser.Clause>, Collection<FieldParams>, int, float, int) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Modifies the main query by adding a new optional Query consisting of shingled phrase queries across the specified clauses using the specified field => boost mappings.
addStat(String, AggValueSource) - Method in class org.apache.solr.search.facet.FacetRequest
 
addStringElement(String) - Method in class org.apache.solr.util.vector.ByteDenseVectorParser
 
addStringElement(String) - Method in class org.apache.solr.util.vector.DenseVectorParser
 
addStringElement(String) - Method in class org.apache.solr.util.vector.FloatDenseVectorParser
 
addSubFacet(String, FacetRequest) - Method in class org.apache.solr.search.facet.FacetRequest
 
addSubset(Collection<E>, M) - Method in class org.apache.solr.handler.component.QueryElevationComponent.TrieSubsetMatcher.Builder
Adds a subset.
addTargetCollection(ClusterState, NamedList<Object>, String, ZkStateReader.AliasesManager, Map<String, String>, RoutedAlias.Action) - Method in class org.apache.solr.cloud.api.collections.MaintainRoutedAliasCmd
 
addToCoreAware(T) - Method in class org.apache.solr.core.SolrResourceLoader
the inform() callback should be invoked on the listener.
addToGlobalColStats(SolrQueryRequest, Map.Entry<String, CollectionStats>) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
addToGlobalColStats(SolrQueryRequest, Map.Entry<String, CollectionStats>) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
addToGlobalColStats(SolrQueryRequest, Map.Entry<String, CollectionStats>) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
addToGlobalTermStats(SolrQueryRequest, Map.Entry<String, TermStats>) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
addToGlobalTermStats(SolrQueryRequest, Map.Entry<String, TermStats>) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
addToGlobalTermStats(SolrQueryRequest, Map.Entry<String, TermStats>) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
addToInfoBeans(T) - Method in class org.apache.solr.core.SolrResourceLoader
 
addToLog(String, Object) - Method in class org.apache.solr.response.SolrQueryResponse
Add a value to be logged.
addToPerShardColStats(SolrQueryRequest, String, Map<String, CollectionStats>) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
addToPerShardColStats(SolrQueryRequest, String, Map<String, CollectionStats>) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
addToPerShardColStats(SolrQueryRequest, String, Map<String, CollectionStats>) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
addToPerShardTermStats(SolrQueryRequest, String, String) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
addToPerShardTermStats(SolrQueryRequest, String, String) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
addToPerShardTermStats(SolrQueryRequest, String, String) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
addToRemoteMessageWithPrefix(CreateCollectionRequestBody, Map<String, Object>, String) - Static method in class org.apache.solr.handler.admin.api.CreateCollection
 
addToResourceLoaderAware(T) - Method in class org.apache.solr.core.SolrResourceLoader
 
addTransformer(DocTransformer) - Method in class org.apache.solr.response.transform.DocTransformers
 
addTransformerFactory(String, TransformerFactory) - Method in class org.apache.solr.core.SolrCore
 
addTransientDescriptor(String, CoreDescriptor) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Adds a new CoreDescriptor.
addTransientDescriptor(String, CoreDescriptor) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
addUnits(String, double, double) - Static method in class org.apache.solr.util.DistanceUnits
Custom distance units can be supplied using this method.
AddUpdateCommand - Class in org.apache.solr.update
An UpdateCommand for adding or updating one document.
AddUpdateCommand(SolrQueryRequest) - Constructor for class org.apache.solr.update.AddUpdateCommand
 
AdjustableSemaphore - Class in org.apache.solr.util
 
AdjustableSemaphore(int) - Constructor for class org.apache.solr.util.AdjustableSemaphore
 
adjustMetrics(long, long, long) - Method in class org.apache.solr.search.CaffeineCache
 
ADMIN - org.apache.solr.core.SolrInfoBean.Category
 
ADMIN - org.apache.solr.security.AuditEvent.RequestType
 
ADMIN - org.apache.solr.security.AuthorizationContext.RequestType
 
ADMIN - org.apache.solr.servlet.SolrDispatchFilter.Action
 
ADMIN_OR_REMOTEQUERY - org.apache.solr.servlet.SolrDispatchFilter.Action
 
AdminAPIBase - Class in org.apache.solr.handler.admin.api
A common parent for "admin" (i.e.
AdminAPIBase(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.AdminAPIBase
 
AdminHandlersProxy - Class in org.apache.solr.handler.admin
Static methods to proxy calls to an Admin (GET) API to other nodes in the cluster and return a combined response
AdminHandlersProxy() - Constructor for class org.apache.solr.handler.admin.AdminHandlersProxy
 
advance(int) - Method in class org.apache.solr.search.BitsFilteredPostingsEnum
 
advance(int) - Method in class org.apache.solr.search.facet.FieldUtil.OrdValues
 
advance(int) - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
advanceExact(int) - Method in class org.apache.solr.search.facet.DocValuesAcc
Wrapper to org.apache.lucene.index.DocValuesIterator#advanceExact(int) returns whether or not given doc has value
advanceExact(int) - Method in class org.apache.solr.search.facet.FieldUtil.DVOrdValues
 
advanceExact(int) - Method in class org.apache.solr.search.facet.FieldUtil.FCOrdValues
 
advanceExact(int) - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
advanceToMapKey(JSONParser, String, boolean) - Static method in class org.apache.solr.request.json.JSONUtil
 
AffinityPlacementConfig - Class in org.apache.solr.cluster.placement.plugins
Configuration bean for AffinityPlacementFactory.
AffinityPlacementConfig() - Constructor for class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Zero-arguments public constructor required for deserialization - don't use.
AffinityPlacementConfig(long, long) - Constructor for class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Configuration for the AffinityPlacementFactory.
AffinityPlacementConfig(long, long, Map<String, String>, Map<String, String>) - Constructor for class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
 
AffinityPlacementConfig(long, long, Map<String, String>, Map<String, String>, Map<String, String>) - Constructor for class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Configuration for the AffinityPlacementFactory.
AffinityPlacementFactory - Class in org.apache.solr.cluster.placement.plugins
This factory is instantiated by config from its class name.
AffinityPlacementFactory() - Constructor for class org.apache.solr.cluster.placement.plugins.AffinityPlacementFactory
Empty public constructor is used to instantiate this factory.
AffinityPlacementFactory.AffinityPlacementPlugin - Class in org.apache.solr.cluster.placement.plugins
See AffinityPlacementFactory for instructions on how to configure a cluster to use this plugin and details on what the plugin does.
afterCoreRename() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Make sure that metrics already collected that correspond to the old core name are carried over and will be used under the new core name.
AggregateBackupStats - Class in org.apache.solr.core.backup
Aggregate stats from multiple ShardBackupMetadata
AggregateBackupStats() - Constructor for class org.apache.solr.core.backup.AggregateBackupStats
 
AggregateMetric - Class in org.apache.solr.metrics
This class is used for keeping several partial named values and providing useful statistics over them.
AggregateMetric() - Constructor for class org.apache.solr.metrics.AggregateMetric
 
AggregateMetric.Update - Class in org.apache.solr.metrics
Simple class to represent current value and how many times it was set.
aggregateNodeLevelMetricsEnabled - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
aggregateNodeLevelMetricsEnabled - Variable in class org.apache.solr.handler.RequestHandlerBase
 
AggUtil - Class in org.apache.solr.search.facet
 
AggValueSource - Class in org.apache.solr.search.facet
 
AggValueSource(String) - Constructor for class org.apache.solr.search.facet.AggValueSource
 
alias - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileMetaData
 
Alias() - Constructor for class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias
 
Alias() - Constructor for class org.apache.solr.util.SolrPluginUtils.DisjunctionMaxQueryParser.Alias
 
ALIAS - Static variable in class org.apache.solr.handler.ReplicationHandler
 
aliases - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
Where we store a map from field name we expect to see in our query string, to Alias object containing the fields to use in our DisjunctionMaxQuery and the tiebreaker to use.
aliases - Variable in class org.apache.solr.util.SolrPluginUtils.DisjunctionMaxQueryParser
Where we store a map from field name we expect to see in our query string, to Alias object containing the fields to use in our DisjunctionMaxQuery and the tiebreaker to use.
ALIASPROP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
Change properties for an alias (use CREATEALIAS_OP to change the actual value of the alias)
AliasProperty - Class in org.apache.solr.handler.admin.api
V2 APIs for managing and inspecting properties for collection aliases
AliasProperty(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.AliasProperty
 
ALL - org.apache.solr.security.PermissionNameProvider.Name
 
ALL - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
ALL - Static variable in interface org.apache.solr.handler.tagger.TagClusterReducer
 
ALL_EVENT_TYPES - Static variable in class org.apache.solr.cluster.events.NoOpProducer
 
ALL_FROM_DV - org.apache.solr.search.SolrReturnFields.FIELD_SOURCES
 
ALL_FROM_STORED - org.apache.solr.search.SolrReturnFields.FIELD_SOURCES
 
ALL_PATH - Static variable in class org.apache.solr.core.SolrPaths
Special path which means to accept all paths.
ALL_PROPERTIES - Static variable in class org.apache.solr.util.stats.MetricUtils
 
ALL_SHARDS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
ALL_TERMS_REQUIRED - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
Boolean clause matching option for multiple terms Default is true - all terms required.
AllCoresStatusAPI - Class in org.apache.solr.handler.admin.api
V2 API for retrieving status information for all cores on the receiving node.
AllCoresStatusAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.AllCoresStatusAPI
 
ALLOW_ALL - Static variable in class org.apache.solr.security.AllowListUrlChecker
Singleton checker which allows all URLs.
allowedRequests - Variable in class org.apache.solr.core.RateLimiterConfig
 
AllowListUrlChecker - Class in org.apache.solr.security
Validates URLs based on an allow list or a ClusterState in SolrCloud.
AllowListUrlChecker(List<String>) - Constructor for class org.apache.solr.security.AllowListUrlChecker
 
allowOverseerPendingTasksToComplete() - Method in class org.apache.solr.cloud.OverseerTaskQueue
 
AllowPathBuilder() - Constructor for class org.apache.solr.core.SolrPaths.AllowPathBuilder
 
allowSlotBorrowing() - Method in class org.apache.solr.servlet.RequestRateLimiter
Whether to allow another request type to borrow a slot from this request rate limiter.
allPhraseFields - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
allPhrases - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
AllValuesOrNoneFieldMutatingUpdateProcessor - Class in org.apache.solr.update.processor
Abstract subclass of FieldMutatingUpdateProcessor for implementing UpdateProcessors that will mutate all individual values of a selected field independently.
AllValuesOrNoneFieldMutatingUpdateProcessor(FieldMutatingUpdateProcessor.FieldNameSelector, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.AllValuesOrNoneFieldMutatingUpdateProcessor
 
allVersions() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage
 
ALREADY_IN_SYNC - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
pre-defined results
AltBufferPoolMetricSet - Class in org.apache.solr.metrics
This is an alternative implementation of BufferPoolMetricSet that doesn't need an MBean server.
AltBufferPoolMetricSet() - Constructor for class org.apache.solr.metrics.AltBufferPoolMetricSet
 
alternateField(SolrDocument, int, String, DefaultSolrHighlighter.FvhContainer, Query, IndexReader, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Returns the alternate highlight object for this field -- a String[] by default.
alternativeTermCount - Variable in class org.apache.solr.spelling.SpellingOptions
 
altQ - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
altUserQuery - Variable in class org.apache.solr.search.DisMaxQParser
 
amILeader() - Method in class org.apache.solr.cloud.OverseerTaskProcessor
 
amISubShardLeader(DocCollection, Slice, String, SolrInputDocument) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
For CollectionParams.CollectionAction.SPLITSHARD
ANALYSIS_ERROR - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
AnalysisContext(String, FieldType, Analyzer) - Constructor for class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
Constructs an AnalysisContext with a given field name, field type and analyzer.
AnalysisContext(String, FieldType, Analyzer, Set<BytesRef>) - Constructor for class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
Constructs a new AnalysisContext with a given field tpe, analyzer and termsToMatch.
AnalysisContext(FieldType, Analyzer, Set<BytesRef>) - Constructor for class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
Constructs a new AnalysisContext with a given field tpe, analyzer and termsToMatch.
analysisField - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
AnalysisRequestHandlerBase - Class in org.apache.solr.handler
A base class for all analysis request handlers.
AnalysisRequestHandlerBase() - Constructor for class org.apache.solr.handler.AnalysisRequestHandlerBase
 
AnalysisRequestHandlerBase.AnalysisContext - Class in org.apache.solr.handler
Serves as the context of an analysis process.
AnalysisRequestHandlerBase.ListBasedTokenStream - Class in org.apache.solr.handler
TokenStream that iterates over a list of pre-existing Tokens
AnalysisRequestHandlerBase.TokenTrackingAttribute - Interface in org.apache.solr.handler
This is an Attribute used to track the positions of tokens in the analysis chain.
AnalysisRequestHandlerBase.TokenTrackingAttributeImpl - Class in org.apache.solr.handler
AnalyticsQuery - Class in org.apache.solr.search
Note: This API is experimental and may change in non backward-compatible ways in the future
AnalyticsQuery() - Constructor for class org.apache.solr.search.AnalyticsQuery
Use this constructor for single node analytics.
AnalyticsQuery(MergeStrategy) - Constructor for class org.apache.solr.search.AnalyticsQuery
Use this constructor for distributed analytics.
analyze(Collection<Token>, String, int, int) - Method in class org.apache.solr.spelling.SpellingQueryConverter
 
analyze(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
AnalyzeEvaluator - Class in org.apache.solr.handler
 
AnalyzeEvaluator(String, String) - Constructor for class org.apache.solr.handler.AnalyzeEvaluator
 
AnalyzeEvaluator(StreamExpression, StreamFactory) - Constructor for class org.apache.solr.handler.AnalyzeEvaluator
 
analyzeIfMultitermTermText(String, String, FieldType) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
analyzeInputDocs(Map<String, List<Object>>, ManagedIndexSchema, List<String>) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
analyzeMultiTerm(String, String, Analyzer) - Static method in class org.apache.solr.schema.TextField
Analyzes a text part using the provided Analyzer for a multi-term query.
analyzeQuery(String) - Method in class org.apache.solr.handler.component.QueryElevationComponent
Analyzes the provided query string and returns a concatenation of the analyzed tokens.
analyzeQuery(String, Consumer<CharSequence>) - Method in class org.apache.solr.handler.component.QueryElevationComponent
Analyzes the provided query string, tokenizes the terms, and adds them to the provided Consumer.
analyzer - Variable in class org.apache.solr.spelling.QueryConverter
 
analyzer - Variable in class org.apache.solr.spelling.SolrSpellChecker
 
ANALYZER - Static variable in class org.apache.solr.schema.FieldType
 
analyzeValue(String, AnalysisRequestHandlerBase.AnalysisContext) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase
Analyzes the given value using the given Analyzer.
AnalyzingInfixLookupFactory - Class in org.apache.solr.spelling.suggest.fst
Factory for AnalyzingInfixSuggester
AnalyzingInfixLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
 
AnalyzingLookupFactory - Class in org.apache.solr.spelling.suggest.fst
Factory for AnalyzingSuggester
AnalyzingLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
 
AND - org.apache.solr.parser.QueryParser.Operator
 
AND - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
AND_OPERATOR - Static variable in class org.apache.solr.parser.SolrQueryParserBase
Alternative form of QueryParser.Operator.AND
AndFilter(MetricFilter...) - Constructor for class org.apache.solr.metrics.SolrMetricManager.AndFilter
 
AndFilter(Collection<MetricFilter>) - Constructor for class org.apache.solr.metrics.SolrMetricManager.AndFilter
 
andNot(int[], int, int[], int, int[]) - Static method in class org.apache.solr.search.SortedIntDocSet
puts the intersection of a and not b into the target array and returns the size
andNot(FixedBitSet, DocSet) - Static method in class org.apache.solr.search.BitDocSet
Helper method for andNot that takes FixedBitSet and DocSet.
andNot(DocSet) - Method in class org.apache.solr.search.BitDocSet
 
andNot(DocSet) - Method in class org.apache.solr.search.DocSet
Returns the documents in this set that are not in the other set.
andNot(DocSet) - Method in class org.apache.solr.search.SortedIntDocSet
 
andNotBinarySearch(int[], int, int[], int, int[]) - Static method in class org.apache.solr.search.SortedIntDocSet
 
andNotSize(DocSet) - Method in class org.apache.solr.search.BitDocSet
 
andNotSize(DocSet) - Method in class org.apache.solr.search.DocSet
Returns the number of documents in this set that are not in the other set.
AnnotatedApi - Class in org.apache.solr.api
This class implements an Api just from an annotated java class The class must have an annotation EndPoint Each method must have an annotation Command The methods that implement a command should have the first 2 parameters SolrQueryRequest and SolrQueryResponse or it may optionally have a third parameter which could be a java class annotated with jackson annotations.
AnnotatedApi(SpecProvider, EndPoint, Map<String, AnnotatedApi.Cmd>, Api) - Constructor for class org.apache.solr.api.AnnotatedApi
 
AnnotatedStat() - Constructor for class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
AnnotatedStat(Stat) - Constructor for class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
ANONYMOUS - org.apache.solr.security.AuditEvent.EventType
 
ANONYMOUS_REJECTED - org.apache.solr.security.AuditEvent.EventType
 
answer - Variable in class org.apache.solr.search.SolrIndexSearcher.ProcessedFilter
 
ANY - Static variable in interface org.apache.solr.security.PermissionNameProvider
 
Api - Class in org.apache.solr.api
Every version 2 API must extend the this class.
Api(SpecProvider) - Constructor for class org.apache.solr.api.Api
 
ApiBag - Class in org.apache.solr.api
 
ApiBag(boolean) - Constructor for class org.apache.solr.api.ApiBag
 
ApiBag.ExceptionWithErrObject - Exception in org.apache.solr.api
 
ApiBag.IntrospectApi - Class in org.apache.solr.api
 
ApiBag.LazyLoadedApi - Class in org.apache.solr.api
 
ApiBag.ReqHandlerToApi - Class in org.apache.solr.api
 
APIConfigProvider<T extends APIConfigProvider.APIConfig> - Interface in org.apache.solr.jersey
Interface to be implemented by the Request Handlers that need to provide some custom configuration to the V2 APIs
APIConfigProvider.APIConfig - Interface in org.apache.solr.jersey
 
APIConfigProviderBinder - Class in org.apache.solr.jersey
Jersey binder for APIConfigProvider
APIConfigProviderBinder(APIConfigProvider<?>) - Constructor for class org.apache.solr.jersey.APIConfigProviderBinder
 
ApiInfo(ContainerPluginsRegistry.PluginMetaHolder, List<String>) - Constructor for class org.apache.solr.api.ContainerPluginsRegistry.ApiInfo
 
ApiSupport - Interface in org.apache.solr.api
The interface that is implemented by a request handler to support the V2 end point
ApiTool - Class in org.apache.solr.cli
 
ApiTool() - Constructor for class org.apache.solr.cli.ApiTool
Used to send an arbitrary HTTP request to a Solr API endpoint.
ApiTool(PrintStream) - Constructor for class org.apache.solr.cli.ApiTool
 
append(char) - Method in class org.apache.solr.internal.csv.CharBuffer
Appends a single character to the end of this CharBuffer.
append(char) - Method in class org.apache.solr.security.PrintWriterWrapper
 
append(char[]) - Method in class org.apache.solr.internal.csv.CharBuffer
Appends data to the end of this CharBuffer.
append(CharSequence) - Method in class org.apache.solr.security.PrintWriterWrapper
 
append(CharSequence, int, int) - Method in class org.apache.solr.security.PrintWriterWrapper
 
append(String) - Method in class org.apache.solr.internal.csv.CharBuffer
Appends s to the end of this CharBuffer.
append(StringBuffer) - Method in class org.apache.solr.internal.csv.CharBuffer
Deprecated.
append(StringBuilder) - Method in class org.apache.solr.internal.csv.CharBuffer
Appends sb to the end of this CharBuffer.
append(List<Object>, Object) - Method in class org.apache.solr.request.json.ObjectUtil.ConflictHandler
 
append(LogEvent) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher.Log4j2Appender
 
append(CharBuffer) - Method in class org.apache.solr.internal.csv.CharBuffer
Appends the contents of cb to the end of this CharBuffer.
appendAttrs(Element, Map<String, ?>) - Static method in class org.apache.solr.rest.schema.FieldTypeXmlAdapter
 
appendDocs(String, List<SolrInputDocument>, int) - Method in class org.apache.solr.handler.designer.SampleDocuments
 
appender - Variable in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
appendFilterElements(Document, Element, String, List<Map<String, ?>>) - Static method in class org.apache.solr.rest.schema.FieldTypeXmlAdapter
 
appendParam(String, String) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Appends a URL query parameter to a URL
appends - Variable in class org.apache.solr.core.InitParams
 
appends - Variable in class org.apache.solr.handler.RequestHandlerBase
 
APPENDS - Static variable in class org.apache.solr.core.PluginInfo
 
APPENDS - Static variable in class org.apache.solr.core.RequestParams
 
appendUrlPath(URL, String) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Appends to the path of the URL
apply() - Method in interface org.apache.solr.update.VersionBucket.CheckedFunction
 
apply(PluginInfo) - Method in class org.apache.solr.core.InitParams
 
apply(T) - Method in interface org.apache.solr.util.IOFunction
 
applyBufferedUpdates() - Method in class org.apache.solr.update.UpdateLog
Returns the Future to wait on, or null if no replay was needed
applyCaseSetting(boolean, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
applyCaseSetting(boolean, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
applyDynamic() - Method in class org.apache.solr.schema.IndexSchema.SchemaProps
 
APPLYING_BUFFERED - org.apache.solr.update.UpdateLog.State
 
applyingBufferedOpsMeter - Variable in class org.apache.solr.update.UpdateLog
 
applyListUpdates(List<String>, boolean) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
applyListUpdates(List<String>, boolean) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
applyMapUpdates(Map<String, Object>, boolean) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
applyMapUpdates(Map<String, Object>, boolean) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
applyPartialUpdates(BytesRef, long, long, Set<String>, SolrDocumentBase<?, ?>) - Method in class org.apache.solr.update.UpdateLog
Goes over backwards, following the prevPointer, to merge all partial updates into the passed doc.
applyUpdatesToManagedData(Object) - Method in class org.apache.solr.rest.ManagedResource
Called during PUT/POST processing to apply updates to the managed data passed from the client.
applyUpdatesToManagedData(Object) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
applyUpdatesToManagedData(Object) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
applyUpdatesToManagedData(Object) - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
Applies updates to the word set being managed by this resource.
approxCheckMissingStats(ResponseBuilder, StatsSource, Consumer<Term>, Consumer<String>) - Method in class org.apache.solr.search.stats.StatsCache
Check if the statsSource is missing some term or field statistics info, which then needs to be retrieved.
arg - Variable in class org.apache.solr.search.facet.StrAggValueSource
 
args - Variable in class org.apache.solr.index.MergePolicyFactory
 
args - Variable in class org.apache.solr.schema.FieldType
additional arguments specified in the field type declaration
argsParser - Variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
argWasQuoted() - Method in class org.apache.solr.search.FunctionQParser
 
Artifact() - Constructor for class org.apache.solr.packagemanager.SolrPackage.Artifact
 
artifacts - Variable in class org.apache.solr.packagemanager.SolrPackage.SolrPackageRelease
 
AS_DISTINCT_TERMS - org.apache.solr.parser.SolrQueryParserBase.SynonymQueryStyle
each synonym scored indepedently, then added together (ie boolean query) so if "pants" has df 500, and "khakis" a df of 50, khakis matches are scored higher but summed with any "pants" matches appropriate when more specific synonyms should score higher, but we don't want to ignore less specific synonyms
AS_SAME_TERM - org.apache.solr.parser.SolrQueryParserBase.SynonymQueryStyle
(default) synonym terms share doc freq so if "pants" has df 500, and "khakis" a df of 50, uses 500 df when scoring both terms appropriate for exact synonyms see SynonymQuery
asc - org.apache.solr.search.facet.FacetRequest.SortDirection
 
asEntityResolver() - Method in class org.apache.solr.util.SystemIdResolver
 
asListenerConfig() - Method in class org.apache.solr.logging.LogWatcherConfig
 
asNamedList() - Method in class org.apache.solr.util.RTimerTree
 
assertAwareCompatibility(Class<?>, Object) - Static method in class org.apache.solr.core.SolrResourceLoader
Utility function to throw an exception if the class is invalid
assertConfigSetFolderLegal(Path) - Static method in class org.apache.solr.util.FileTypeMagicUtil
Asserts that an entire configset folder is legal to upload.
assertFileExists(String) - Static method in class org.apache.solr.cli.AssertTool
 
assertFileNotExists(String) - Static method in class org.apache.solr.cli.AssertTool
 
AssertionFailureException(String) - Constructor for exception org.apache.solr.cli.SolrCLI.AssertionFailureException
 
assertNoPathTraversal(Path) - Static method in class org.apache.solr.core.SolrPaths
Asserts that a path does not contain directory traversal
assertNotRootUser() - Static method in class org.apache.solr.cli.AssertTool
 
assertNotUnc(Path) - Static method in class org.apache.solr.core.SolrPaths
Asserts that a path is not a Windows UNC path
assertPathAllowed(Path) - Method in class org.apache.solr.core.CoreContainer
Checks that the given path is relative to SOLR_HOME, SOLR_DATA_HOME, coreRootDirectory or one of the paths specified in solr.xml's allowPaths element.
assertPathAllowed(Path, Set<Path>) - Static method in class org.apache.solr.core.SolrPaths
Checks that the given path is relative to one of the allowPaths supplied.
assertRootUser() - Static method in class org.apache.solr.cli.AssertTool
 
assertSolrNotRunning(String) - Static method in class org.apache.solr.cli.AssertTool
 
assertSolrNotRunningInCloudMode(String) - Static method in class org.apache.solr.cli.AssertTool
 
assertSolrRunning(String) - Static method in class org.apache.solr.cli.AssertTool
 
assertSolrRunningInCloudMode(String) - Static method in class org.apache.solr.cli.AssertTool
 
AssertTool - Class in org.apache.solr.cli
Asserts various conditions and exists with error code if fails, else continues with no output
AssertTool() - Constructor for class org.apache.solr.cli.AssertTool
 
AssertTool(PrintStream) - Constructor for class org.apache.solr.cli.AssertTool
 
assertWarnOrFail(String, boolean, boolean) - Static method in class org.apache.solr.core.XmlConfigFile
 
assign(SolrCloudManager, List<Assign.AssignRequest>) - Method in interface org.apache.solr.cloud.api.collections.Assign.AssignStrategy
Assign new replicas to nodes.
assign(SolrCloudManager, List<Assign.AssignRequest>) - Method in class org.apache.solr.cluster.placement.impl.PlacementPluginAssignStrategy
 
assign(SolrCloudManager, Assign.AssignRequest...) - Method in interface org.apache.solr.cloud.api.collections.Assign.AssignStrategy
Assign new replicas to nodes.
Assign - Class in org.apache.solr.cloud.api.collections
 
Assign() - Constructor for class org.apache.solr.cloud.api.collections.Assign
 
Assign.AssignmentException - Exception in org.apache.solr.cloud.api.collections
Thrown if there is an exception while assigning nodes for replicas
Assign.AssignRequest - Class in org.apache.solr.cloud.api.collections
 
Assign.AssignRequestBuilder - Class in org.apache.solr.cloud.api.collections
 
Assign.AssignStrategy - Interface in org.apache.solr.cloud.api.collections
Strategy for assigning replicas to nodes.
assignCoreNodeName(DistribStateManager, DocCollection) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
AssignmentException() - Constructor for exception org.apache.solr.cloud.api.collections.Assign.AssignmentException
 
AssignmentException(String) - Constructor for exception org.apache.solr.cloud.api.collections.Assign.AssignmentException
 
AssignmentException(String, Throwable) - Constructor for exception org.apache.solr.cloud.api.collections.Assign.AssignmentException
 
AssignmentException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.solr.cloud.api.collections.Assign.AssignmentException
 
AssignmentException(Throwable) - Constructor for exception org.apache.solr.cloud.api.collections.Assign.AssignmentException
 
assignNrtReplicas(int) - Method in class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
assignPullReplicas(int) - Method in class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
assignReplicaDetails(SolrCloudManager, ClusterState, ZkNodeProps, ReplicaPosition) - Static method in class org.apache.solr.cloud.api.collections.AddReplicaCmd
 
AssignRequest(String, List<String>, List<String>, int, int, int) - Constructor for class org.apache.solr.cloud.api.collections.Assign.AssignRequest
 
AssignRequestBuilder() - Constructor for class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
assignShard(DocCollection, Integer) - Static method in class org.apache.solr.cloud.api.collections.Assign
Assign a new unique id up to slices count - then add replicas evenly.
assignTlogReplicas(int) - Method in class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
asURIResolver() - Method in class org.apache.solr.util.SystemIdResolver
 
asXMLResolver() - Method in class org.apache.solr.util.SystemIdResolver
 
async - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.CreateAliasRequestBody
 
async - Variable in class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
async - Variable in class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
ASYNC_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
asyncId - Variable in class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
asyncRequestTracker(String) - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
asyncRequestTracker(String, CollectionCommandContext) - Static method in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
ATOMIC_FIELD_PREFIX - Static variable in class org.apache.solr.update.processor.AtomicUpdateProcessorFactory
 
AtomicUpdateDocumentMerger - Class in org.apache.solr.update.processor
 
AtomicUpdateDocumentMerger(SolrQueryRequest) - Constructor for class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
AtomicUpdateProcessorFactory - Class in org.apache.solr.update.processor
An update processor that will convert conventional field-value document to atomic update document
AtomicUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.AtomicUpdateProcessorFactory
 
ATTR_TRACING_SPAN - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
ATTR_TRACING_TRACER - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
AttributeFetcher - Interface in org.apache.solr.cluster.placement
Instances of this interface are used to fetch various attributes from nodes (and other sources) in the cluster.
AttributeFetcherImpl - Class in org.apache.solr.cluster.placement.impl
Implementation of AttributeFetcher that uses SolrCloudManager to access Solr cluster details.
attributes - Variable in class org.apache.solr.core.PluginInfo
 
attributes - Variable in class org.apache.solr.util.DataConfigNode
 
attributes() - Method in class org.apache.solr.util.DataConfigNode
 
attributes() - Method in class org.apache.solr.util.DOMConfigNode
 
AttributeValues - Interface in org.apache.solr.cluster.placement
 
AttributeValuesImpl - Class in org.apache.solr.cluster.placement.impl
Implementation of AttributeValues used by AttributeFetcherImpl.
AttributeValuesImpl(Map<String, Map<Node, String>>, Map<NodeMetric<?>, Map<Node, Object>>, Map<String, CollectionMetrics>) - Constructor for class org.apache.solr.cluster.placement.impl.AttributeValuesImpl
 
audit(AuditEvent) - Method in class org.apache.solr.security.AuditLoggerPlugin
This is the method that each Audit plugin has to implement to do the actual logging.
audit(AuditEvent) - Method in class org.apache.solr.security.MultiDestinationAuditLogger
Passes the AuditEvent to all sub plugins in parallel.
audit(AuditEvent) - Method in class org.apache.solr.security.SolrLogAuditLoggerPlugin
Audit logs an event to Solr log.
auditAsync(AuditEvent) - Method in class org.apache.solr.security.AuditLoggerPlugin
Enqueues an AuditEvent to a queue and returns immediately.
AuditEvent - Class in org.apache.solr.security
Audit event that takes request and auth context as input to be able to audit log custom things.
AuditEvent() - Constructor for class org.apache.solr.security.AuditEvent
 
AuditEvent(AuditEvent.EventType) - Constructor for class org.apache.solr.security.AuditEvent
Empty event, must be filled by user using setters.
AuditEvent(AuditEvent.EventType, Throwable, HttpServletRequest) - Constructor for class org.apache.solr.security.AuditEvent
Event based on an HttpServletRequest, typically used during authentication.
AuditEvent(AuditEvent.EventType, HttpServletRequest) - Constructor for class org.apache.solr.security.AuditEvent
 
AuditEvent(AuditEvent.EventType, HttpServletRequest, AuthorizationContext) - Constructor for class org.apache.solr.security.AuditEvent
Event based on request and AuthorizationContext.
AuditEvent(AuditEvent.EventType, HttpServletRequest, AuthorizationContext, double, Throwable) - Constructor for class org.apache.solr.security.AuditEvent
Event to log completed requests.
AuditEvent.EventType - Enum in org.apache.solr.security
 
AuditEvent.Level - Enum in org.apache.solr.security
 
AuditEvent.RequestType - Enum in org.apache.solr.security
 
AuditLoggerPlugin - Class in org.apache.solr.security
Base class for Audit logger plugins.
AuditLoggerPlugin() - Constructor for class org.apache.solr.security.AuditLoggerPlugin
 
AuditLoggerPlugin.AuditEventFormatter - Interface in org.apache.solr.security
Interface for formatting the event
AuditLoggerPlugin.JSONAuditEventFormatter - Class in org.apache.solr.security
Event formatter that returns event as JSON string
AuditLoggerPlugin.MuteRule - Interface in org.apache.solr.security
 
authenticate(String, String) - Method in class org.apache.solr.security.BasicAuthPlugin
 
authenticate(String, String) - Method in interface org.apache.solr.security.BasicAuthPlugin.AuthenticationProvider
 
authenticate(String, String) - Method in class org.apache.solr.security.Sha256AuthenticationProvider
 
authenticate(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.solr.security.AuthenticationPlugin
This method is called by SolrDispatchFilter in order to initiate authentication.
AUTHENTICATED - org.apache.solr.security.AuditEvent.EventType
 
AUTHENTICATION_PLUGIN_PROP - Static variable in class org.apache.solr.security.AuthenticationPlugin
 
AuthenticationPlugin - Class in org.apache.solr.security
 
AuthenticationPlugin() - Constructor for class org.apache.solr.security.AuthenticationPlugin
 
AUTHORIZATION_HEADER - Static variable in class org.apache.solr.security.MultiAuthPlugin
 
AuthorizationContext - Class in org.apache.solr.security
Request context for Solr to be used by Authorization plugin.
AuthorizationContext() - Constructor for class org.apache.solr.security.AuthorizationContext
 
AuthorizationContext.CollectionRequest - Class in org.apache.solr.security
 
AuthorizationContext.RequestType - Enum in org.apache.solr.security
 
AuthorizationFailure(int, String) - Constructor for class org.apache.solr.security.AuthorizationUtils.AuthorizationFailure
 
AuthorizationPlugin - Interface in org.apache.solr.security
Authorization interface that needs to be implemented to write an authorization plugin.
AuthorizationResponse - Class in org.apache.solr.security
 
AuthorizationResponse(int) - Constructor for class org.apache.solr.security.AuthorizationResponse
 
AuthorizationUtils - Class in org.apache.solr.security
 
AuthorizationUtils.AuthorizationFailure - Class in org.apache.solr.security
 
authorize(HttpServletRequest, HttpServletResponse, CoreContainer, AuthorizationContext) - Static method in class org.apache.solr.security.AuthorizationUtils
 
authorize(AuthorizationContext) - Method in interface org.apache.solr.security.AuthorizationPlugin
 
authorize(AuthorizationContext) - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
 
AUTHORIZED - org.apache.solr.security.AuditEvent.EventType
 
AuthTool - Class in org.apache.solr.cli
 
AuthTool() - Constructor for class org.apache.solr.cli.AuthTool
 
AuthTool(PrintStream) - Constructor for class org.apache.solr.cli.AuthTool
 
AUTO_CREATE_FIELDS - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
AUTO_GENERATE_PHRASE_QUERIES - Static variable in class org.apache.solr.schema.FieldType
 
autoCommitMaxSizeBytes - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
autoCommmitMaxDocs - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
autoCommmitMaxTime - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
AUTOCREATED_CONFIGSET_SUFFIX - Static variable in class org.apache.solr.handler.admin.ConfigSetsHandler
 
autoCreateSystemColl(String) - Method in class org.apache.solr.servlet.HttpSolrCall
 
autoDeleteAge - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
autoGeneratePhraseQueries - Variable in class org.apache.solr.schema.TextField
 
autoSoftCommmitMaxDocs - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
autoSoftCommmitMaxTime - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
autowarm - Variable in class org.apache.solr.search.SolrCacheBase
 
AutoWarmCountRef(String) - Constructor for class org.apache.solr.search.SolrCacheBase.AutoWarmCountRef
 
AUTOWARMING - org.apache.solr.search.SolrCache.State
:TODO
AVAILABILITY_ZONE_SYSPROP - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Name of the system property on a node indicating which (public cloud) Availability Zone that node is in.
available() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
AVAILABLE_PROCESSORS - Static variable in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
Number of available processors.
AveragingMetricProvider - Class in org.apache.solr.util.circuitbreaker
Averages the metric value over a period of time
AveragingMetricProvider(AveragingMetricProvider.MetricProvider, int, long) - Constructor for class org.apache.solr.util.circuitbreaker.AveragingMetricProvider
Creates an instance with an executor that runs every sampleInterval seconds and averages over numSamples samples.
AveragingMetricProvider.MetricProvider - Interface in org.apache.solr.util.circuitbreaker
Interface to provide the metric value.
aversion - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
avg(double, long) - Static method in class org.apache.solr.search.facet.AggUtil
Computes and returns average for given sum and count
AvgAgg - Class in org.apache.solr.search.facet
 
AvgAgg(ValueSource) - Constructor for class org.apache.solr.search.facet.AvgAgg
 
awaitNanos(long) - Method in class org.apache.solr.update.TimedVersionBucket
 
awaitNanos(long) - Method in class org.apache.solr.update.VersionBucket
 

B

b - Variable in class org.apache.solr.search.function.DualDoubleFunction
 
backup() - Method in class org.apache.solr.handler.IncrementalShardBackup
 
backup(IndexCommit) - Method in class org.apache.solr.handler.IncrementalShardBackup
 
BACKUP_NAME_PROP - Static variable in class org.apache.solr.core.backup.BackupManager
 
BACKUP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
BackupAPIBase - Class in org.apache.solr.handler.admin.api
Base class that facilitates reuse of common validation logic for collection-backup APIs.
BackupAPIBase(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.BackupAPIBase
 
BackupCmd - Class in org.apache.solr.cloud.api.collections
 
BackupCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.BackupCmd
 
BACKUPCORE_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
BackupFilePaths - Class in org.apache.solr.core.backup
Utility class for getting paths related to backups, or parsing information out of those paths.
BackupFilePaths(BackupRepository, URI) - Constructor for class org.apache.solr.core.backup.BackupFilePaths
Create a BackupFilePaths object.
backupId - Variable in class org.apache.solr.core.backup.BackupManager
 
backupId - Variable in class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
BackupId - Class in org.apache.solr.core.backup
Represents the ID of a particular backup.
BackupId(int) - Constructor for class org.apache.solr.core.backup.BackupId
 
BackupManager - Class in org.apache.solr.core.backup
This class implements functionality to create a backup with extension points provided to integrate with different types of file-systems.
backupPath - Variable in class org.apache.solr.core.backup.BackupManager
 
BackupProperties - Class in org.apache.solr.core.backup
Represents a backup[-*].properties file, responsible for holding whole-collection and whole-backup metadata.
BackupReplicationRequestBody() - Constructor for class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationRequestBody
 
BackupReplicationRequestBody(String, String, int, String, String) - Constructor for class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationRequestBody
 
BackupReplicationResponse() - Constructor for class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationResponse
 
BackupRepository - Interface in org.apache.solr.core.backup.repository
This interface defines the functionality required to backup/restore Solr indexes to an arbitrary storage system.
BackupRepository.PathType - Enum in org.apache.solr.core.backup.repository
This enumeration defines the type of a given path.
BackupRepositoryFactory - Class in org.apache.solr.core.backup.repository
 
BackupRepositoryFactory(PluginInfo[]) - Constructor for class org.apache.solr.core.backup.repository.BackupRepositoryFactory
 
BalancePlan - Interface in org.apache.solr.cluster.placement
A fully specified plan or instructions for replica balancing to be applied to the cluster.
BalancePlanFactory - Interface in org.apache.solr.cluster.placement
Allows plugins to create BalancePlans telling the Solr layer how to balance replicas following the processing of a BalanceRequest.
BalancePlanFactoryImpl - Class in org.apache.solr.cluster.placement.impl
Simple implementation of BalancePlanFactory.
BalancePlanFactoryImpl() - Constructor for class org.apache.solr.cluster.placement.impl.BalancePlanFactoryImpl
 
balanceReplicas(BalanceReplicasRequestBody) - Method in class org.apache.solr.handler.admin.api.BalanceReplicas
 
BalanceReplicas - Class in org.apache.solr.handler.admin.api
V2 API for balancing the replicas that already exist across a set of nodes.
BalanceReplicas(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.BalanceReplicas
 
BalanceReplicasCmd - Class in org.apache.solr.cloud.api.collections
 
BalanceReplicasCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.BalanceReplicasCmd
 
BalanceRequest - Interface in org.apache.solr.cluster.placement
A cluster related placement request that Solr asks a PlacementPlugin to resolve and compute replica balancing plan for replicas that already exist across a set of Nodes.
BalanceRequestImpl - Class in org.apache.solr.cluster.placement.impl
 
BalanceRequestImpl(Set<Node>) - Constructor for class org.apache.solr.cluster.placement.impl.BalanceRequestImpl
 
BalanceRequestImpl(Set<Node>, int) - Constructor for class org.apache.solr.cluster.placement.impl.BalanceRequestImpl
 
BalanceShardsUnique - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
BalanceShardsUniqueCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.BalanceShardsUniqueCmd
 
balanceShardUnique(String, BalanceShardUniqueRequestBody) - Method in class org.apache.solr.handler.admin.api.BalanceShardUnique
 
BalanceShardUnique - Class in org.apache.solr.handler.admin.api
V2 API implementation for insuring that a particular property is distributed evenly amongst the physical nodes comprising a collection.
BalanceShardUnique(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.BalanceShardUnique
 
BALANCESHARDUNIQUE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
BAREOPER - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
BASE_CONFIGSET - Static variable in class org.apache.solr.cloud.ConfigSetCmds
Name of the ConfigSet to copy from for CREATE
BASE_RAM_BYTES_USED - Static variable in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
BaseEditorialTransformer - Class in org.apache.solr.response.transform
 
BaseEditorialTransformer(String, String, FieldType) - Constructor for class org.apache.solr.response.transform.BaseEditorialTransformer
 
BaseHandlerApiSupport - Class in org.apache.solr.handler.admin
This is a utility class to provide an easy mapping of request handlers which support multiple commands to the V2 API format (core admin api, collections api).
BaseHandlerApiSupport() - Constructor for class org.apache.solr.handler.admin.BaseHandlerApiSupport
 
BaseHandlerApiSupport.ApiCommand - Interface in org.apache.solr.handler.admin
 
BaseManagedTokenFilterFactory - Class in org.apache.solr.rest.schema.analysis
Abstract based class for implementing TokenFilterFactory objects that are managed by the REST API.
BaseManagedTokenFilterFactory() - Constructor for class org.apache.solr.rest.schema.analysis.BaseManagedTokenFilterFactory
Default ctor for compatibility with SPI
BaseManagedTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.solr.rest.schema.analysis.BaseManagedTokenFilterFactory
 
BaseMessageBodyWriter() - Constructor for class org.apache.solr.jersey.MessageBodyWriters.BaseMessageBodyWriter
 
BaseSolrResource - Class in org.apache.solr.rest
Base class for delegating REST-oriented requests to ManagedResources.
BaseSolrResource() - Constructor for class org.apache.solr.rest.BaseSolrResource
 
BasicAuthPlugin - Class in org.apache.solr.security
 
BasicAuthPlugin() - Constructor for class org.apache.solr.security.BasicAuthPlugin
 
BasicAuthPlugin.AuthenticationProvider - Interface in org.apache.solr.security
 
BasicResultContext - Class in org.apache.solr.response
 
BasicResultContext(ResponseBuilder) - Constructor for class org.apache.solr.response.BasicResultContext
 
BasicResultContext(ResponseBuilder, DocList) - Constructor for class org.apache.solr.response.BasicResultContext
 
BasicResultContext(DocList, ReturnFields, SolrIndexSearcher, Query, SolrQueryRequest) - Constructor for class org.apache.solr.response.BasicResultContext
 
BATCH_SIZE_PARAM - Static variable in class org.apache.solr.handler.export.ExportWriter
 
BAYES - org.apache.solr.update.processor.ClassificationUpdateProcessorFactory.Algorithm
 
bbox - Variable in class org.apache.solr.search.SpatialOptions
Just do a "bounding box" - or any other quicker method / shape that still encompasses all of the points of interest, but may also encompass points outside.
BBoxField - Class in org.apache.solr.schema
 
BBoxField() - Constructor for class org.apache.solr.schema.BBoxField
 
BBoxStrategy - Class in org.apache.solr.legacy
Deprecated.
BBoxStrategy(SpatialContext, String, FieldType) - Constructor for class org.apache.solr.legacy.BBoxStrategy
Deprecated.
Creates this strategy.
beginColumn - Variable in class org.apache.solr.parser.Token
The column number of the first character of this Token.
beginLine - Variable in class org.apache.solr.parser.Token
The line number of the first character of this Token.
bgQ - Variable in class org.apache.solr.search.facet.RelatednessAgg
 
bin - Variable in class org.apache.solr.schema.PreAnalyzedField.ParseResult
 
BIN_PATH - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
BINARY - org.apache.solr.uninverting.UninvertingReader.Type
Single-valued Binary, (e.g.
BINARY - Static variable in class org.apache.solr.schema.FieldProperties
 
BINARY_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
BinaryDocValuesImpl(PagedBytes.Reader, PackedInts.Reader, Bits) - Constructor for class org.apache.solr.uninverting.FieldCacheImpl.BinaryDocValuesImpl
 
BinaryField - Class in org.apache.solr.schema
 
BinaryField() - Constructor for class org.apache.solr.schema.BinaryField
 
BinaryQueryResponseWriter - Interface in org.apache.solr.response
Implementations of BinaryQueryResponseWriter are used to write response in binary format.
BinaryResponseWriter - Class in org.apache.solr.response
 
BinaryResponseWriter() - Constructor for class org.apache.solr.response.BinaryResponseWriter
 
BinaryResponseWriter.Resolver - Class in org.apache.solr.response
 
BitDocSet - Class in org.apache.solr.search
A FixedBitSet based implementation of a DocSet.
BitDocSet() - Constructor for class org.apache.solr.search.BitDocSet
 
BitDocSet(FixedBitSet) - Constructor for class org.apache.solr.search.BitDocSet
Construct a BitDocSet.
BitDocSet(FixedBitSet, int) - Constructor for class org.apache.solr.search.BitDocSet
Construct a BitDocSet, and provides the number of set bits.
bits() - Method in class org.apache.solr.search.FilteredDocIdSet
 
BitsetBounds(long, long) - Constructor for class org.apache.solr.search.TopLevelJoinQuery.BitsetBounds
 
BitsFilteredPostingsEnum - Class in org.apache.solr.search
 
BLACK - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
BlendedInfixLookupFactory - Class in org.apache.solr.spelling.suggest.fst
BlendedInfixLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.BlendedInfixLookupFactory
 
blob - Variable in class org.apache.solr.core.BlobRepository.BlobContentRef
 
BLOB_STORE_ID - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
BlobContent(String, ByteBuffer) - Constructor for class org.apache.solr.core.BlobRepository.BlobContent
 
BlobContent(String, ByteBuffer, BlobRepository.Decoder<T>) - Constructor for class org.apache.solr.core.BlobRepository.BlobContent
 
BlobHandler - Class in org.apache.solr.handler
 
BlobHandler() - Constructor for class org.apache.solr.handler.BlobHandler
 
BlobRepository - Class in org.apache.solr.core
The purpose of this class is to store the Jars loaded in memory and to keep only one copy of the Jar in a single node.
BlobRepository(CoreContainer) - Constructor for class org.apache.solr.core.BlobRepository
 
BlobRepository.BlobContent<T> - Class in org.apache.solr.core
 
BlobRepository.BlobContentRef<T> - Class in org.apache.solr.core
 
BlobRepository.Decoder<T> - Interface in org.apache.solr.core
 
blockAndDoRetries() - Method in class org.apache.solr.update.SolrCmdDistributor
 
BlockJoin - Class in org.apache.solr.search.facet
 
BlockJoin() - Constructor for class org.apache.solr.search.facet.BlockJoin
 
BlockJoinChildQParser - Class in org.apache.solr.search.join
 
BlockJoinChildQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.join.BlockJoinChildQParser
 
BlockJoinChildQParserPlugin - Class in org.apache.solr.search.join
Usage: {!child of="PARENT:true"}PARENT_PRICE:10
BlockJoinChildQParserPlugin() - Constructor for class org.apache.solr.search.join.BlockJoinChildQParserPlugin
 
BlockJoinParentQParser - Class in org.apache.solr.search.join
 
BlockJoinParentQParserPlugin - Class in org.apache.solr.search.join
Usage: {!parent which="PARENT:true"}CHILD_PRICE:10 supports optional score parameter with one of ScoreMode values: None,Avg,Total,Min,Max.
BlockJoinParentQParserPlugin() - Constructor for class org.apache.solr.search.join.BlockJoinParentQParserPlugin
 
blockUntilFinished() - Method in class org.apache.solr.update.StreamingSolrClients
 
blockUpdates() - Method in class org.apache.solr.update.VersionInfo
 
BLUE - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
BM25SimilarityFactory - Class in org.apache.solr.search.similarities
Factory for BM25Similarity.
BM25SimilarityFactory() - Constructor for class org.apache.solr.search.similarities.BM25SimilarityFactory
 
BOGUS - org.apache.solr.core.SolrConfig.HttpCachingConfig.LastModFrom
 
boolAnalyzer - Static variable in class org.apache.solr.schema.BoolField
 
booleanQueryMaxClauseCount - Variable in class org.apache.solr.core.SolrConfig
 
BooleanSimilarityFactory - Class in org.apache.solr.search.similarities
Factory for BooleanSimilarity
BooleanSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.BooleanSimilarityFactory
 
BoolField - Class in org.apache.solr.schema
 
BoolField() - Constructor for class org.apache.solr.schema.BoolField
 
BoolQParserPlugin - Class in org.apache.solr.search
Create a boolean query from sub queries.
BoolQParserPlugin() - Constructor for class org.apache.solr.search.BoolQParserPlugin
 
boost - Variable in class org.apache.solr.handler.MoreLikeThisHandler.InterestingTerm
 
Boost - Static variable in interface org.apache.solr.parser.QueryParserConstants
Lexical state.
BOOST_FIELD_PARAM - Static variable in class org.apache.solr.update.processor.RegexpBoostProcessor
 
BOOST_FILENAME_PARAM - Static variable in class org.apache.solr.update.processor.RegexpBoostProcessor
 
BOOSTED - Static variable in class org.apache.solr.handler.component.QueryElevationComponent
Key to SolrQueryRequest.getContext() for a Set<BytesRef> of included IDs in configured order (so-called priority).
BoostedComp(IntIntHashMap, ScoreDoc[], float) - Constructor for class org.apache.solr.search.ReRankCollector.BoostedComp
 
boostedPriority - Variable in class org.apache.solr.search.AbstractReRankQuery
 
BOOSTFUNC - Static variable in class org.apache.solr.search.BoostQParserPlugin
 
boostFuncs - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
boostParams - Variable in class org.apache.solr.search.DisMaxQParser
 
boostParams - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
BoostQParserPlugin - Class in org.apache.solr.search
Create a boosted query from the input value.
BoostQParserPlugin() - Constructor for class org.apache.solr.search.BoostQParserPlugin
 
boostQueries - Variable in class org.apache.solr.search.DisMaxQParser
 
bootstrapConf(CoreContainer) - Static method in class org.apache.solr.core.ConfigSetService
If in SolrCloud mode, upload configSets for each SolrCore in solr.xml.
bootstrapFirstSearcher() - Method in class org.apache.solr.search.SolrIndexSearcher
Called on the initial searcher for each core, immediately before firstSearcherListeners are called for the searcher.
boundaryScanners - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
 
BoundedTreeSet<E> - Class in org.apache.solr.util
A TreeSet that ensures it never grows beyond a max size.
BoundedTreeSet(int) - Constructor for class org.apache.solr.util.BoundedTreeSet
 
BoundedTreeSet(int, Collection<? extends E>) - Constructor for class org.apache.solr.util.BoundedTreeSet
 
BoundedTreeSet(int, Comparator<? super E>) - Constructor for class org.apache.solr.util.BoundedTreeSet
 
BoundedTreeSet(int, SortedSet<E>) - Constructor for class org.apache.solr.util.BoundedTreeSet
 
boundingTimeMillis - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessageInfo
 
BRACES_PLACEHOLDER_PATTERN - Static variable in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
BreakIteratorBoundaryScanner - Class in org.apache.solr.highlight
 
BreakIteratorBoundaryScanner() - Constructor for class org.apache.solr.highlight.BreakIteratorBoundaryScanner
 
bucket(int) - Method in class org.apache.solr.update.VersionInfo
 
bucketHash(BytesRef) - Static method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
bucketWasMissing() - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
buf - Variable in class org.apache.solr.internal.csv.CSVPrinter
 
BUF_SIZE_INT - Static variable in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
The maximum term length (used for byte[] buffer size) for encoding int values.
BUF_SIZE_LONG - Static variable in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
The maximum term length (used for byte[] buffer size) for encoding long values.
buffer - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessageInfo
 
BUFFER_TLOG_NAME - Static variable in class org.apache.solr.update.UpdateLog
 
bufferedOpsGauge - Variable in class org.apache.solr.update.UpdateLog
 
BUFFERING - org.apache.solr.update.UpdateLog.State
 
BUFFERING - Static variable in class org.apache.solr.update.UpdateCommand
 
buffers - Variable in class org.apache.solr.update.MemOutputStream
 
bufferTlog - Variable in class org.apache.solr.update.UpdateLog
 
bufferUpdates() - Method in class org.apache.solr.update.UpdateLog
 
build() - Method in class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
build() - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder
 
build() - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ReplicaMetricsBuilder
 
build() - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ShardMetricsBuilder
 
build() - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
build() - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
build() - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
build() - Method in class org.apache.solr.core.SolrPaths.AllowPathBuilder
 
build() - Method in class org.apache.solr.handler.component.QueryElevationComponent.ElevationBuilder
 
build() - Method in class org.apache.solr.handler.component.QueryElevationComponent.TrieSubsetMatcher.Builder
 
build() - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
 
build() - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
 
build() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
 
build() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand.Builder
 
build() - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
build() - Method in class org.apache.solr.servlet.RateLimitManager.Builder
 
build(HttpClient, Supplier<String>) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
build(BooleanQuery.Builder, QParser) - Static method in class org.apache.solr.search.QueryUtils
 
build(InputIterator) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
 
build(FixedBitSet) - Method in class org.apache.solr.search.DocSetBuilder
 
build(SolrClientCache, Supplier<String>) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Build it.
build(SolrParams) - Static method in class org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelector
returns a new GroupHeadSelector based on the specified local params
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.FileBasedSpellChecker
 
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.IndexBasedSpellChecker
 
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.SolrSpellChecker
(re)Builds the spelling index.
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.SolrSuggester
Build the underlying Lucene Suggester
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.Suggester
 
build(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.WordBreakSolrSpellChecker
 
buildComponentsList() - Static method in class org.apache.solr.handler.component.TaskManagementHandler
 
buildCoreDescriptor(Path, CoreContainer) - Method in class org.apache.solr.core.CorePropertiesLocator
 
buildCoreParams(SolrParams) - Static method in class org.apache.solr.handler.admin.CoreAdminHandler
 
buildCoreProperties(CoreDescriptor) - Method in class org.apache.solr.core.CorePropertiesLocator
 
buildDoc(Map<String, Object>) - Static method in class org.apache.solr.handler.loader.JsonLoader
 
Builder() - Constructor for class org.apache.solr.cloud.RecoveryStrategy.Builder
 
Builder() - Constructor for class org.apache.solr.handler.component.QueryElevationComponent.TrieSubsetMatcher.Builder
 
Builder() - Constructor for class org.apache.solr.search.grouping.CommandHandler.Builder
 
Builder() - Constructor for class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
 
Builder() - Constructor for class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand.Builder
 
Builder() - Constructor for class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
Builder(SolrZkClient) - Constructor for class org.apache.solr.servlet.RateLimitManager.Builder
 
builderPhase - Variable in class org.apache.solr.util.vector.DenseVectorParser
 
buildExceptionResponse(Exception, SolrQueryRequest, ContainerRequestContext) - Static method in class org.apache.solr.jersey.CatchAllExceptionMapper
 
buildExistingBackupLocationURI(BackupRepository, URI, String) - Static method in class org.apache.solr.core.backup.BackupFilePaths
Builds the URI for the backup location given the user-provided 'location' and backup 'name'.
buildIndexSchema(String, SolrConfig) - Static method in class org.apache.solr.schema.IndexSchemaFactory
 
buildIndexSchema(String, SolrConfig, ConfigSetService) - Static method in class org.apache.solr.schema.IndexSchemaFactory
Instantiates the configured schema factory, then calls create on it.
buildMapToStore(Object) - Method in class org.apache.solr.rest.ManagedResource
Builds the JSON object to be stored, containing initArgs and managed data fields.
buildReplicaPositions(SolrCloudManager, ClusterState, String, ZkNodeProps, EnumMap<Replica.Type, Integer>, CoreContainer) - Static method in class org.apache.solr.cloud.api.collections.AddReplicaCmd
 
buildRequestBodyString(ContainerRequestContext) - Static method in class org.apache.solr.jersey.PostRequestLoggingFilter
 
buildRequestFrom(SolrCore, SolrParams, Collection<ContentStream>) - Method in class org.apache.solr.servlet.SolrRequestParsers
For embedded Solr use; not related to HTTP.
buildResponse() - Method in class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
buildResponse(String, ManagedIndexSchema, SchemaDesignerSettings, List<SolrInputDocument>) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
buildResponseBuilder(SolrQueryRequest, SolrQueryResponse, List<SearchComponent>) - Static method in class org.apache.solr.handler.component.TaskManagementHandler
 
buildSolrCoreName(String, String, Replica.Type, int) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
buildSolrCoreName(DistribStateManager, String, DocCollection, String, Replica.Type, boolean) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
buildSolrCoreName(DistribStateManager, DocCollection, String, Replica.Type) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
buildSpan(Tracer, HttpServletRequest) - Static method in class org.apache.solr.servlet.ServletUtils
 
buildSubstitutableProperties() - Method in class org.apache.solr.core.CoreDescriptor
Create the properties object used by resource loaders, etc., for property substitution.
buildUniqueInOrder(FixedBitSet) - Method in class org.apache.solr.search.DocSetBuilder
Only use this if you know there were no duplicates and that docs were collected in-order!
buildURLList(String) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
Creates a list of urls for the given shard.
buildWriteCommand(SolrCloudManager, ClusterState, ZkNodeProps) - Method in enum org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
mutating commands that return a single ZkWriteCommand override this method
bulkModifySchema(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.SchemaBulkModifyAPI
 
byDirectoryCache - Variable in class org.apache.solr.core.CachingDirectoryFactory
 
byPathCache - Variable in class org.apache.solr.core.CachingDirectoryFactory
 
ByteBuffersDirectoryFactory - Class in org.apache.solr.core
Factory to instantiate ByteBuffersDirectory
ByteBuffersDirectoryFactory() - Constructor for class org.apache.solr.core.ByteBuffersDirectoryFactory
 
ByteDenseVectorParser - Class in org.apache.solr.util.vector
 
ByteDenseVectorParser(int, Object, DenseVectorParser.BuilderPhase) - Constructor for class org.apache.solr.util.vector.ByteDenseVectorParser
 
BYTES_TO_GB_CONVERTER - Static variable in class org.apache.solr.cluster.placement.impl.MetricImpl
Bytes to gigabytes converter.
bytesToInt(byte[]) - Static method in class org.apache.solr.util.NumberUtils
 

C

CACHE - org.apache.solr.core.SolrInfoBean.Category
 
CACHE_FOR_MILLIS - Static variable in class org.apache.solr.update.processor.RoutedAliasUpdateProcessor
 
CACHE_KEY_PREFIX - Static variable in class org.apache.solr.schema.RptWithGeometrySpatialField
 
CACHE_KEY_PREFIX - Static variable in class org.apache.solr.search.join.HashRangeQuery
 
CACHE_MISS_LISTENER - Static variable in class org.apache.solr.schema.IndexSchemaFactory
 
CACHE_NAME - Static variable in class org.apache.solr.response.transform.ChildDocTransformerFactory
 
CACHE_NAME - Static variable in class org.apache.solr.search.join.BlockJoinParentQParser
implementation detail subject to change
CacheConfig - Class in org.apache.solr.search
Contains the knowledge of how cache config is stored in the solrconfig.xml file, and implements a factory to create caches.
CacheConfig() - Constructor for class org.apache.solr.search.CacheConfig
 
CacheConfig(Class<? extends SolrCache>, Map<String, String>, CacheRegenerator) - Constructor for class org.apache.solr.search.CacheConfig
 
CacheConfig(Integer) - Constructor for class org.apache.solr.core.MetricsConfig.CacheConfig
 
cacheDocSet(Query, DocSet, boolean) - Method in class org.apache.solr.search.SolrIndexSearcher
Compute and cache the DocSet that matches a query.
cacheElevationProvider - Variable in class org.apache.solr.handler.component.QueryElevationComponent
Cached elevation provider.
CacheEntry(K, V, long, long) - Constructor for class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
CacheEntry(IndexReader.CacheKey, String, Class<?>, Object, Accountable) - Constructor for class org.apache.solr.uninverting.FieldCache.CacheEntry
 
cacheFieldSources(IndexSchema) - Method in class org.apache.solr.schema.ExternalFileFieldReloader
Caches FileFloatSource's from all ExternalFileField instances in the schema
cacheInsert(String, Object, Object) - Method in class org.apache.solr.search.SolrIndexSearcher
insert an entry in a generic cache
cacheLookup(String, Object) - Method in class org.apache.solr.search.SolrIndexSearcher
lookup an entry in a generic cache
CacheRegenerator - Interface in org.apache.solr.search
Implementations of CacheRegenerator are used in autowarming to populate a new cache based on an old cache.
CacheValue(String, Directory) - Constructor for class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
cacheVersion - Variable in class org.apache.solr.handler.component.QueryElevationComponent
Cached version / timestamp of the data underlying QueryElevationComponent.cacheElevationProvider.
CachingDelegatingMessageBodyReader() - Constructor for class org.apache.solr.jersey.MessageBodyReaders.CachingDelegatingMessageBodyReader
 
CachingDirectoryFactory - Class in org.apache.solr.core
A DirectoryFactory impl base class for caching Directory instances per path.
CachingDirectoryFactory() - Constructor for class org.apache.solr.core.CachingDirectoryFactory
 
CachingDirectoryFactory.CacheValue - Class in org.apache.solr.core
 
CachingDirectoryFactory.CloseListener - Interface in org.apache.solr.core
 
CachingJsonMessageBodyReader() - Constructor for class org.apache.solr.jersey.MessageBodyReaders.CachingJsonMessageBodyReader
 
CaffeineCache<K,​V> - Class in org.apache.solr.search
A SolrCache backed by the Caffeine caching library [1].
CaffeineCache() - Constructor for class org.apache.solr.search.CaffeineCache
 
cal - Variable in class org.apache.solr.response.TextResponseWriter
 
calcCounts() - Method in class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
calcEtag(SolrQueryRequest) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Calculates a tag for the ETag header.
calcHitRatio(long, long) - Static method in class org.apache.solr.search.SolrCacheBase
Returns a "Hit Ratio" (ie: max of 1.00, not a percentage) suitable for display purposes.
calcLastModified(SolrQueryRequest) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Calculate the appropriate last-modified time for Solr relative the current request.
calcRelevantWeightWithReplica(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
calcShardHealth(float, boolean) - Static method in enum org.apache.solr.handler.admin.ClusterStatus.Health
 
calculateActions(String) - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
calculateActions(String) - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
Determine the combination of adds/deletes implied by the arrival of a document destined for the specified collection.
calculateActions(String) - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
Determine the combination of adds/deletes implied by the arrival of a document destined for the specified collection.
calculateActions(String) - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
calculateLiveCPUUsage() - Method in class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
Calculate the CPU usage for the system in percentage.
calculateLiveLoadAverage() - Method in class org.apache.solr.util.circuitbreaker.LoadAverageCircuitBreaker
 
calculateStats(StatsField.Stat) - Method in class org.apache.solr.handler.component.StatsField
 
calcWeight() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
CALENDAR_UNITS - Static variable in class org.apache.solr.util.DateMathParser
A mapping from (uppercased) String labels identifying time units, to the corresponding ChronoUnit enum (e.g.
call() - Method in class org.apache.solr.handler.component.IterativeMergeStrategy.CallBack
 
call() - Method in class org.apache.solr.handler.RestoreCore
 
call() - Method in class org.apache.solr.servlet.HttpSolrCall
This method processes the request.
call(int) - Method in interface org.apache.solr.search.facet.UnInvertedField.Callback
 
call(Object...) - Method in interface org.apache.solr.core.Diagnostics.Callable
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.AddReplicaCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.BackupCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.BalanceReplicasCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.AddReplicaPropCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.BalanceShardsUniqueCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in interface org.apache.solr.cloud.api.collections.CollApiCmds.CollectionApiCommand
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.DeleteReplicaPropCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.MockOperationCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.ModifyCollectionCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.RebalanceLeadersCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.ReloadCollectionCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CollApiCmds.TraceAwareCommand
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CreateAliasCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CreateCollectionCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CreateShardCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.CreateSnapshotCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.DeleteAliasCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.DeleteBackupCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.DeleteCollectionCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.DeleteNodeCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.DeleteReplicaCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.DeleteShardCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.DeleteSnapshotCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.InstallShardDataCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.MaintainRoutedAliasCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.MigrateCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.MigrateReplicasCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.MoveReplicaCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.OverseerRoleCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.OverseerStatusCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.RenameCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.ReplaceNodeCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.RestoreCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.SetAliasPropCmd
 
call(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.SplitShardCmd
 
call(Diagnostics.Callable, Object...) - Static method in class org.apache.solr.core.Diagnostics
 
call(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.api.AnnotatedApi
 
call(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.api.Api
The method that gets called for each request
call(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.api.ApiBag.IntrospectApi
 
call(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.api.ApiBag.LazyLoadedApi
 
call(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.api.ApiBag.ReqHandlerToApi
 
call(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.api.V2HttpCall.CompositeApi
 
callBack(List<ShardResponse>, QueryRequest) - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
callBack(ShardResponse, QueryRequest) - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
CallBack(ShardResponse, QueryRequest) - Constructor for class org.apache.solr.handler.component.IterativeMergeStrategy.CallBack
 
callGet(String) - Method in class org.apache.solr.cli.ApiTool
 
callPostCommitCallbacks() - Method in class org.apache.solr.update.UpdateHandler
 
callPostOptimizeCallbacks() - Method in class org.apache.solr.update.UpdateHandler
 
callPostSoftCommitCallbacks() - Method in class org.apache.solr.update.UpdateHandler
 
callRemoteNode(String, String, SolrParams, ZkController) - Static method in class org.apache.solr.handler.admin.AdminHandlersProxy
Makes a remote request and returns a future and the solr client.
canAddReplica(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
canBecomeLeader(String) - Method in class org.apache.solr.cloud.ZkShardTerms
Can this replica become leader?
canBecomeNonEmpty() - Method in class org.apache.solr.search.facet.FacetRequest.Domain
 
cancel() - Method in class org.apache.solr.search.CancellableCollector
 
cancelActiveTask(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.CancelTaskAPI
 
cancelAll() - Method in class org.apache.solr.handler.component.HttpShardHandler
 
cancelAll() - Method in class org.apache.solr.handler.component.ShardHandler
 
cancelApplyBufferUpdate - Variable in class org.apache.solr.update.UpdateLog
 
cancelAsyncId(String) - Method in class org.apache.solr.cloud.DistributedApiAsyncTracker
Cancels the tracking of an asyncId, if the corresponding command could not be executed.
cancelCoreRecoveries() - Method in class org.apache.solr.core.CoreContainer
 
cancelElection() - Method in class org.apache.solr.cloud.ElectionContext
 
CancellableCollector - Class in org.apache.solr.search
Allows a query to be cancelled
CancellableCollector(Collector) - Constructor for class org.apache.solr.search.CancellableCollector
 
CancellableCollector.QueryCancelledException - Exception in org.apache.solr.search
Thrown when a query gets cancelled
CancellableQueryTracker - Class in org.apache.solr.core
Tracks metadata for active queries and provides methods for access
CancellableQueryTracker() - Constructor for class org.apache.solr.core.CancellableQueryTracker
 
cancelPendingCommit() - Method in class org.apache.solr.update.CommitTracker
 
cancelRecovery() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
cancelRecovery() - Method in class org.apache.solr.update.SolrCoreState
 
CancelTaskAPI - Class in org.apache.solr.handler.admin.api
V2 API for cancelling a currently running "task".
CancelTaskAPI(QueryCancellationHandler) - Constructor for class org.apache.solr.handler.admin.api.CancelTaskAPI
 
canCreateTombstoneDocument(IndexSchema) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessorFactory
Validates that the schema would allow tombstones to be created by DocBasedVersionConstraintsProcessor by checking if the required fields are of known types
canProduceFromEmpty() - Method in class org.apache.solr.search.facet.FacetRequest
Returns true if this facet, or any sub-facets can produce results from an empty domain.
canRemoveReplicas(Collection<Replica>) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
Determine if the given replicas can be removed from the node.
canTransformDomain() - Method in class org.apache.solr.search.facet.FacetRequest.Domain
 
capacity() - Method in class org.apache.solr.internal.csv.CharBuffer
Returns the current capacity of the buffer.
CARAT - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
cardinality - org.apache.solr.handler.component.StatsField.Stat
 
cardinality() - Method in class org.apache.solr.util.hll.HLL
Computes the cardinality of the HLL.
cardinality() - Method in class org.apache.solr.util.LongSet
The number of values in the set
CatchAllExceptionMapper - Class in org.apache.solr.jersey
Flattens the exception and sets on a SolrJerseyResponse.
CatchAllExceptionMapper() - Constructor for class org.apache.solr.jersey.CatchAllExceptionMapper
 
category - Variable in class org.apache.solr.metrics.SolrMetricInfo
 
CATEGORY - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
CategoryRoutedAlias - Class in org.apache.solr.cloud.api.collections
 
CategoryRoutedAliasProperties() - Constructor for class org.apache.solr.handler.admin.api.CreateAliasAPI.CategoryRoutedAliasProperties
 
CatStream - Class in org.apache.solr.handler
 
CatStream(String, int) - Constructor for class org.apache.solr.handler.CatStream
 
CatStream(StreamExpression, StreamFactory) - Constructor for class org.apache.solr.handler.CatStream
 
CatStream.CrawlFile - Class in org.apache.solr.handler
 
CBOR_PATH - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
CborLoader - Class in org.apache.solr.handler.loader
This class can load a single document or a stream of documents in CBOR format this is equivalent of loading a single json documet or an array of json documents
CborLoader(CBORFactory, Consumer<SolrInputDocument>) - Constructor for class org.apache.solr.handler.loader.CborLoader
 
CborResponseWriter - Class in org.apache.solr.response
A response writer impl that can write results in CBOR (cbor.io) format when wt=cbor.
CborResponseWriter() - Constructor for class org.apache.solr.response.CborResponseWriter
 
cc - Variable in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
cd - Variable in class org.apache.solr.core.CoreContainer.CoreLoadFailure
 
CertAuthPlugin - Class in org.apache.solr.security
An authentication plugin that sets principal based on the certificate subject
CertAuthPlugin() - Constructor for class org.apache.solr.security.CertAuthPlugin
 
cfg - Variable in class org.apache.solr.core.CoreContainer
 
ch - Variable in class org.apache.solr.update.TransactionLog.ChannelFastInputStream
 
ch() - Method in class org.apache.solr.search.StrParser
 
changed(SolrPackageLoader.SolrPackage, PackageListeners.Listener.Ctx) - Method in interface org.apache.solr.pkg.PackageListeners.Listener
A callback when the package is updated
changed(SolrPackageLoader.SolrPackage, PackageListeners.Listener.Ctx) - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
changeLogLevel(String) - Static method in class org.apache.solr.util.StartupLoggingUtils
Dynamically change log4j log level through property solr.log.level
channel - Variable in class org.apache.solr.update.TransactionLog
 
CHANNEL_INPUT_STREAM_OPENER - Static variable in class org.apache.solr.update.TransactionLog
 
ChannelFastInputStream(FileChannel, long) - Constructor for class org.apache.solr.update.TransactionLog.ChannelFastInputStream
 
channelInputStreamOpener - Variable in class org.apache.solr.update.TransactionLog
 
CHAR_FILTER - Static variable in class org.apache.solr.schema.FieldType
 
CHAR_FILTERS - Static variable in class org.apache.solr.schema.FieldType
 
charAt(int) - Method in class org.apache.solr.internal.csv.CharBuffer
Returns the character at the specified position.
CharBuffer - Class in org.apache.solr.internal.csv
A simple StringBuffer replacement that aims to reduce copying as much as possible.
CharBuffer() - Constructor for class org.apache.solr.internal.csv.CharBuffer
Creates a new CharBuffer with an initial capacity of 32 characters.
CharBuffer(int) - Constructor for class org.apache.solr.internal.csv.CharBuffer
Creates a new CharBuffer with an initial capacity of length characters.
charLen() - Method in class org.apache.solr.handler.tagger.TagLL
 
CHECK_ROUTER_FIELD - Static variable in class org.apache.solr.search.join.ScoreJoinQParserPlugin
 
checkAllowList(List<String>) - Method in class org.apache.solr.security.AllowListUrlChecker
 
checkAllowList(List<String>, ClusterState) - Method in class org.apache.solr.security.AllowListUrlChecker
Checks that the given URLs are present in the configured allow-list or in the provided ClusterState (in case of cloud mode).
checkChrootPath(String, boolean) - Static method in class org.apache.solr.cloud.ZkController
Validates if the chroot exists in zk (or if it is successfully created).
checkCircuitBreakers(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ContentStreamHandlerBase
Check if SolrRequest.SolrRequestType.UPDATE circuit breakers are tripped.
checkCircuitBreakers(SolrQueryRequest, SolrQueryResponse, ResponseBuilder) - Method in class org.apache.solr.handler.component.SearchHandler
Check if SolrRequest.SolrRequestType.QUERY circuit breakers are tripped.
checkCodeForAuthError(int) - Static method in class org.apache.solr.cli.SolrCLI
 
checkCommunicationError(Exception) - Static method in class org.apache.solr.cli.SolrCLI
Determine if a request to Solr failed due to a communication error, which is generally retry-able.
checkConfigExists(String) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
checkConfigExists(String) - Method in class org.apache.solr.core.ConfigSetService
Check whether a config exists
checkConfigExists(String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
checkContains(Collection<String>) - Method in class org.apache.solr.core.PluginBag
Check if any of the mentioned names are missing.
checkDiskSpace(String, String, Replica, SolrIndexSplitter.SplitMethod, SolrCloudManager) - Static method in class org.apache.solr.cloud.api.collections.SplitShardCmd
 
checkEditable(String, boolean, List<String>) - Static method in class org.apache.solr.core.ConfigOverlay
 
checkError() - Method in class org.apache.solr.security.PrintWriterWrapper
 
checkErrors() - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
checkErrors() - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
checkETagValidators(HttpServletRequest, HttpServletResponse, Method, String) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Check for etag related conditional headers and set status
checkFieldCacheSource() - Method in class org.apache.solr.schema.SchemaField
Sanity checks that the properties of this field type are plausible for a field that may be used to get a FieldCacheSource, throwing an appropriate exception (including the field name) if it is not.
checkForDocValues - Variable in class org.apache.solr.uninverting.DocTermOrds
If true, check and throw an exception if the field has docValues enabled.
checkHttpCachingVeto(SolrQueryResponse, HttpServletResponse, Method) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Checks if the downstream request handler wants to avoid HTTP caching of the response.
checkIfCoreNodeNameAlreadyExists(CoreDescriptor) - Method in class org.apache.solr.cloud.ZkController
 
checkIfIamLeaderFired() - Method in class org.apache.solr.cloud.ElectionContext
 
checkIntegrity() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
checkLastModValidators(HttpServletRequest, HttpServletResponse, long) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Check for modify time related conditional headers and set status
checkLogDir() - Static method in class org.apache.solr.util.StartupLoggingUtils
Checks whether mandatory log dir is given
checkMincountOnExists(String, int) - Static method in class org.apache.solr.request.SimpleFacets
 
checkMutable(String, SolrQueryRequest) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
checkOverseerDesignate() - Method in class org.apache.solr.cloud.ZkController
 
checkPortConflict(String, File, int) - Method in class org.apache.solr.cli.RunExampleTool
 
checkPropertyIsNotEmpty(String, String) - Static method in class org.apache.solr.core.CoreDescriptor
 
checkReplicaTypes(ZkNodeProps) - Static method in class org.apache.solr.cloud.api.collections.CreateCollectionCmd
 
checkRequestLogging() - Static method in class org.apache.solr.util.StartupLoggingUtils
Check whether Jetty request logging is enabled and log info about it.
checkRetry(SolrCmdDistributor.SolrError) - Method in class org.apache.solr.update.SolrCmdDistributor.ForwardNode
 
checkRetry(SolrCmdDistributor.SolrError) - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
checkRetry(SolrCmdDistributor.SolrError) - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.BinaryField
 
checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.CurrencyFieldType
 
checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.DenseVectorField
 
checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.FieldType
Check's SchemaField instances constructed using this field type to ensure that they are valid.
checkSharedFSFailoverReplaced(CoreContainer, CoreDescriptor) - Static method in class org.apache.solr.cloud.CloudUtil
See if coreNodeName has been taken over by another baseUrl and unload core + throw exception if it has been.
checkSortability() - Method in class org.apache.solr.schema.SchemaField
Sanity checks that the properties of this field type are plausible for a field that may be used in sorting, throwing an appropriate exception (including the field name) if it is not.
checkSslStoreSysProp(String, String) - Static method in class org.apache.solr.cli.SolrCLI
 
checksum - Variable in class org.apache.solr.core.backup.Checksum
 
checksum - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileMetaData
 
checksum(Directory, String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
Get checksum of fileName at dir.
Checksum - Class in org.apache.solr.core.backup
Represents checksum information for an index file being backed up.
Checksum(long, long) - Constructor for class org.apache.solr.core.backup.Checksum
 
CHECKSUM - Static variable in class org.apache.solr.handler.ReplicationHandler
 
checkSupportsDocValues() - Method in class org.apache.solr.schema.CollationField
 
checkSupportsDocValues() - Method in class org.apache.solr.schema.FieldType
Called by FieldType.checkSchemaField(SchemaField) if the field has docValues.
checkSupportsDocValues() - Method in class org.apache.solr.schema.LatLonPointSpatialField
 
checkSupportsDocValues() - Method in class org.apache.solr.schema.PointType
 
checkSupportsDocValues() - Method in class org.apache.solr.schema.PrimitiveFieldType
 
checkSupportsDocValues() - Method in class org.apache.solr.schema.SortableTextField
Called by FieldType.checkSchemaField(SchemaField) if the field has docValues.
checkTragicException(SolrCore) - Method in class org.apache.solr.core.CoreContainer
 
checkTripped(SolrRequest.SolrRequestType) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
Check and return circuit breakers that have triggered
checkUnInvertedField(String, SolrIndexSearcher) - Static method in class org.apache.solr.search.facet.UnInvertedField
 
checkVectorDimension(int) - Method in class org.apache.solr.util.vector.DenseVectorParser
 
checkWriteHeader(TransactionLog.LogCodec, SolrInputDocument) - Method in class org.apache.solr.update.TransactionLog
 
child(String) - Method in class org.apache.solr.util.DataConfigNode
 
child(String) - Method in class org.apache.solr.util.DOMConfigNode
 
CHILD_DOC_KEY - Static variable in class org.apache.solr.handler.loader.JsonLoader
 
ChildDocTransformerFactory - Class in org.apache.solr.response.transform
Attaches all descendants (child documents) to each parent document.
ChildDocTransformerFactory() - Constructor for class org.apache.solr.response.transform.ChildDocTransformerFactory
 
ChildFieldValueSourceParser - Class in org.apache.solr.search.join
 
ChildFieldValueSourceParser() - Constructor for class org.apache.solr.search.join.ChildFieldValueSourceParser
 
childId - Variable in class org.apache.solr.rest.RestManager.ManagedEndpoint
 
children - Variable in class org.apache.solr.core.PluginInfo
 
children - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
children - Variable in class org.apache.solr.util.RTimerTree
 
children() - Method in class org.apache.solr.handler.CatStream
 
children() - Method in class org.apache.solr.handler.ClassifyStream
 
children() - Method in class org.apache.solr.handler.export.ExportWriterStream
 
children() - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
children() - Method in class org.apache.solr.handler.GraphHandler.TimerStream
 
children() - Method in class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
children() - Method in class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
children() - Method in class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
children() - Method in class org.apache.solr.handler.StreamHandler.TimerStream
 
CHK_COL_PREFIX - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
CircuitBreaker - Class in org.apache.solr.util.circuitbreaker
Default base class to define circuit breaker plugins for Solr.
CircuitBreaker() - Constructor for class org.apache.solr.util.circuitbreaker.CircuitBreaker
 
CircuitBreakerManager - Class in org.apache.solr.util.circuitbreaker
Deprecated.
Use individual Circuit Breakers instead
CircuitBreakerManager() - Constructor for class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
CircuitBreakerRegistry - Class in org.apache.solr.util.circuitbreaker
Keeps track of all registered circuit breaker instances for various request types.
CircuitBreakerRegistry(CoreContainer) - Constructor for class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
CircularList<T> - Class in org.apache.solr.logging
FIFO Circular List.
CircularList(int) - Constructor for class org.apache.solr.logging.CircularList
 
claimAsyncId(String) - Method in class org.apache.solr.cloud.ZkController
When an operation needs to be performed in an asynchronous mode, the asyncId needs to be claimed by calling this method to make sure it's not duplicate (hasn't been claimed by other request).
CLASS_NAME - Static variable in class org.apache.solr.schema.FieldType
 
CLASS_NAME - Static variable in class org.apache.solr.schema.SimilarityFactory
 
ClassicIndexSchemaFactory - Class in org.apache.solr.schema
 
ClassicIndexSchemaFactory() - Constructor for class org.apache.solr.schema.ClassicIndexSchemaFactory
 
ClassicSimilarityFactory - Class in org.apache.solr.search.similarities
Factory for ClassicSimilarity
ClassicSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.ClassicSimilarityFactory
 
ClassificationUpdateProcessorFactory - Class in org.apache.solr.update.processor
This class implements an UpdateProcessorFactory for the Classification Update Processor.
ClassificationUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ClassificationUpdateProcessorFactory
 
ClassificationUpdateProcessorFactory.Algorithm - Enum in org.apache.solr.update.processor
 
ClassificationUpdateProcessorParams - Class in org.apache.solr.update.processor
 
ClassificationUpdateProcessorParams() - Constructor for class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
ClassifyStream - Class in org.apache.solr.handler
The classify expression retrieves a model trained by the train expression and uses it to classify documents from a stream Syntax: classif(model(...), anyStream(...), field="body")
ClassifyStream(StreamExpression, StreamFactory) - Constructor for class org.apache.solr.handler.ClassifyStream
 
classLoader - Variable in class org.apache.solr.core.SolrResourceLoader
 
className - Variable in class org.apache.solr.core.PluginInfo
 
className - Variable in class org.apache.solr.core.PluginInfo.ClassName
 
className - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
ClassName(String) - Constructor for class org.apache.solr.core.PluginInfo.ClassName
 
classToXmlTag(Class<?>) - Static method in class org.apache.solr.rest.schema.FieldTypeXmlAdapter
Convert types produced by noggit's ObjectBuilder (Boolean, Double, Long, String) to plugin param XML tags.
classVsSolrPluginInfo - Static variable in class org.apache.solr.core.SolrConfig
 
Clause() - Constructor for class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
Clause(String) - Method in class org.apache.solr.parser.QueryParser
 
clauses() - Method in class org.apache.solr.search.join.FiltersQParser
 
clazz - Variable in class org.apache.solr.core.SolrConfig.SolrPluginInfo
 
CLEANUP_TEMP_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
CLEANUP_THREAD_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
cleanupCollectionLevelSnapshots(SolrZkClient, String) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method deletes all snapshots for the specified collection in Zookeeper.
cleanupOldIndexDirectories(boolean) - Method in class org.apache.solr.core.SolrCore
 
cleanupOldIndexDirectories(String, String, boolean) - Method in class org.apache.solr.core.DirectoryFactory
 
cleanupOldIndexDirectories(String, String, boolean) - Method in class org.apache.solr.core.EphemeralDirectoryFactory
 
cleanupTemp(String) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
cleanupTemp(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
clear() - Method in class org.apache.solr.cloud.DistributedMap
Helper method to clear all child nodes for a parent node.
clear() - Method in class org.apache.solr.cloud.Stats
 
clear() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
clear() - Method in class org.apache.solr.handler.tagger.TaggingAttributeImpl
 
clear() - Method in class org.apache.solr.internal.csv.CharBuffer
Empties the buffer.
clear() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.solr.logging.CircularList
 
clear() - Static method in class org.apache.solr.logging.MDCLoggingContext
clear() - Method in class org.apache.solr.metrics.AggregateMetric
 
clear() - Method in class org.apache.solr.search.CaffeineCache
 
clear() - Method in interface org.apache.solr.search.SolrCache
:TODO: copy from Map
clear() - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
clear() - Method in class org.apache.solr.search.stats.LRUStatsCache
 
clear() - Method in class org.apache.solr.search.stats.StatsCache
Clear cached statistics.
clear() - Method in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
clear() - Method in class org.apache.solr.spelling.Token
Deprecated.
Resets the term text, payload, flags, positionIncrement, positionLength, startOffset, endOffset and token type to default.
clear() - Method in class org.apache.solr.update.AddUpdateCommand
Reset state to reuse this object with a different document in the same request
clear() - Method in class org.apache.solr.update.DeleteUpdateCommand
 
clear() - Method in class org.apache.solr.util.ConcurrentLRUCache
 
clear() - Method in class org.apache.solr.util.hll.HLL
Clears the HLL.
clear() - Method in class org.apache.solr.util.LongPriorityQueue
Removes all entries from the PriorityQueue.
clear() - Method in class org.apache.solr.util.MapListener
 
clear() - Method in class org.apache.solr.util.MockSearchableSolrClient
 
clear(String) - Method in class org.apache.solr.metrics.AggregateMetric
 
CLEAR_CACHES - Static variable in class org.apache.solr.update.UpdateCommand
 
clearAsyncId(String) - Method in class org.apache.solr.cloud.ZkController
Clears an asyncId previously claimed by calling ZkController.claimAsyncId(String)
clearError() - Method in class org.apache.solr.security.PrintWriterWrapper
 
clearErrors() - Method in class org.apache.solr.update.StreamingSolrClients
 
clearFlags(int) - Method in class org.apache.solr.search.QueryCommand
 
clearIndex() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
clearLog(SolrCore, PluginInfo) - Method in class org.apache.solr.update.UpdateLog
Clears the logs on the file system.
clearMetrics(String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Remove some metrics from a named registry
clearRegistry(String) - Method in class org.apache.solr.metrics.SolrMetricManager
Remove all metrics from a specified registry.
clearRequestInfo() - Static method in class org.apache.solr.request.SolrRequestInfo
Removes the most recent SolrRequestInfo from the stack.
clearZkCollectionTerms() - Method in class org.apache.solr.cloud.ZkController
 
CLIO - Interface in org.apache.solr.cli
 
clk - Variable in class org.apache.solr.metrics.MetricSuppliers.DefaultMeterSupplier
 
clk - Variable in class org.apache.solr.metrics.MetricSuppliers.DefaultTimerSupplier
 
CLOCK - Static variable in class org.apache.solr.metrics.MetricSuppliers
Clock type parameter.
CLOCK_CPU - Static variable in class org.apache.solr.metrics.MetricSuppliers
CPU-time clock.
CLOCK_USER - Static variable in class org.apache.solr.metrics.MetricSuppliers
User-time clock.
clone() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
clone() - Method in class org.apache.solr.search.BitDocSet
 
clone() - Method in class org.apache.solr.search.DocSet
 
clone() - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
clone() - Method in class org.apache.solr.search.SortedIntDocSet
 
clone() - Method in class org.apache.solr.spelling.Token
Deprecated.
 
clone() - Method in class org.apache.solr.update.UpdateCommand
 
clone() - Method in class org.apache.solr.util.hll.HLL
Create a deep copy of this HLL.
CloneFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Clones the values found in any matching source field into a configured dest field.
CloneFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
close() - Method in class org.apache.solr.api.AnnotatedApi
 
close() - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
close() - Method in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
Closes any resources created by this instance
close() - Method in class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
 
close() - Method in class org.apache.solr.cloud.ElectionContext
 
close() - Method in class org.apache.solr.cloud.Overseer
 
close() - Method in class org.apache.solr.cloud.Overseer.OverseerThread
 
close() - Method in class org.apache.solr.cloud.OverseerTaskProcessor
 
close() - Method in class org.apache.solr.cloud.RecoveryStrategy
 
close() - Method in class org.apache.solr.cloud.SyncStrategy
 
close() - Method in class org.apache.solr.cloud.ZkController
Closes the underlying ZooKeeper client.
close() - Method in class org.apache.solr.cloud.ZkShardTerms
 
close() - Method in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
close() - Method in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
close() - Method in class org.apache.solr.cluster.events.impl.DefaultClusterEventProducer
 
close() - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
close() - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
close() - Method in class org.apache.solr.core.CachingDirectoryFactory
 
close() - Method in class org.apache.solr.core.DirectoryFactory
Close this factory and all of the Directories it contains.
close() - Method in class org.apache.solr.core.PluginBag
Close this registry.
close() - Method in class org.apache.solr.core.PluginBag.PluginHolder
 
close() - Method in class org.apache.solr.core.RequestHandlers
 
close() - Method in class org.apache.solr.core.SolrCore
Close all resources allocated by the core if it is no longer in use...
close() - Method in class org.apache.solr.core.SolrCores
 
close() - Method in class org.apache.solr.core.SolrResourceLoader
 
close() - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Called in order to free resources.
close() - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
close() - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
close() - Method in class org.apache.solr.core.ZkContainer
 
close() - Method in class org.apache.solr.handler.CatStream
 
close() - Method in class org.apache.solr.handler.ClassifyStream
 
close() - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
close() - Method in class org.apache.solr.handler.component.ShardHandlerFactory
 
close() - Method in class org.apache.solr.handler.export.ExportWriter
 
close() - Method in class org.apache.solr.handler.export.ExportWriterStream
 
close() - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
close() - Method in class org.apache.solr.handler.GraphHandler.TimerStream
 
close() - Method in class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
close() - Method in class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
close() - Method in class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
close() - Method in class org.apache.solr.handler.StreamHandler.TimerStream
 
close() - Method in class org.apache.solr.logging.jul.RecordHandler
 
close() - Method in class org.apache.solr.logging.MDCSnapshot
 
close() - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter
 
close() - Method in class org.apache.solr.metrics.reporters.ReporterClientCache
Empty this cache, and close all clients that are Closeable.
close() - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter
 
close() - Method in class org.apache.solr.metrics.reporters.SolrGraphiteReporter
 
close() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Stops the reporter from publishing metrics.
close() - Method in class org.apache.solr.metrics.reporters.SolrSlf4jReporter
 
close() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Closes reporters specific to this core and unregisters gauges with this core's instance tag.
close() - Method in interface org.apache.solr.metrics.SolrMetricProducer
Implementations should always call SolrMetricProducer.super.close() to ensure that metrics with the same life-cycle as this component are properly unregistered.
close() - Method in class org.apache.solr.packagemanager.PackageManager
 
close() - Method in class org.apache.solr.pkg.SolrPackageLoader
 
close() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage
 
close() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage.Version
 
close() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
close() - Method in interface org.apache.solr.request.SolrQueryRequest
This method should be called when all uses of this request are finished, so that resources can be freed.
close() - Method in class org.apache.solr.request.SolrQueryRequestBase
Frees resources associated with this request, this method must be called when the object is no longer in use.
close() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
close() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
close() - Method in class org.apache.solr.response.TextResponseWriter
done with this ResponseWriter...
close() - Method in class org.apache.solr.search.CaffeineCache
 
close() - Method in class org.apache.solr.search.facet.SlotAcc
 
close() - Method in class org.apache.solr.search.facet.UnInvertedField.DocToTerm
 
close() - Method in class org.apache.solr.search.facet.UnInvertedFieldAcc
 
close() - Method in class org.apache.solr.search.QueryContext
Don't call close explicitly! This will be automatically closed at the end of the request
close() - Method in interface org.apache.solr.search.SolrCache
Frees any non-memory resources
close() - Method in class org.apache.solr.search.SolrIndexSearcher
Free's resources associated with this searcher.
close() - Method in class org.apache.solr.security.AuditLoggerPlugin
Waits 30s for async queue to drain, then closes executor threads.
close() - Method in class org.apache.solr.security.BasicAuthPlugin
 
close() - Method in class org.apache.solr.security.MultiAuthPlugin
 
close() - Method in class org.apache.solr.security.MultiDestinationAuditLogger
 
close() - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
close() - Method in class org.apache.solr.security.PrintWriterWrapper
 
close() - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
 
close() - Method in class org.apache.solr.servlet.CoreContainerProvider
 
close() - Method in class org.apache.solr.servlet.DirectSolrConnection
Use this method to close the underlying SolrCore.
close() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
close() - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
close() - Method in class org.apache.solr.update.CommitTracker
 
close() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
close() - Method in class org.apache.solr.update.LoggingInfoStream
 
close() - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
 
close() - Method in class org.apache.solr.update.SolrCmdDistributor
 
close() - Method in class org.apache.solr.update.SolrIndexWriter
 
close() - Method in class org.apache.solr.update.TransactionLog.ChannelFastInputStream
 
close() - Method in class org.apache.solr.update.TransactionLog
 
close() - Method in class org.apache.solr.update.TransactionLog.FSReverseReader
 
close() - Method in class org.apache.solr.update.TransactionLog.LogReader
 
close() - Method in class org.apache.solr.update.TransactionLog.ReverseReader
 
close() - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
 
close() - Method in class org.apache.solr.update.UpdateShardHandler
 
close() - Method in class org.apache.solr.util.circuitbreaker.AveragingMetricProvider
 
close() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreaker
 
close() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
close() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
close() - Method in class org.apache.solr.util.circuitbreaker.MemoryCircuitBreaker
 
close() - Method in class org.apache.solr.util.MockSearchableSolrClient
 
close() - Method in class org.apache.solr.util.PropertiesInputStream
 
close() - Method in class org.apache.solr.util.PropertiesOutputStream
 
close() - Method in class org.apache.solr.util.RefCounted
 
close() - Method in class org.apache.solr.util.stats.InstrumentedPoolingHttpClientConnectionManager
 
close(boolean) - Method in class org.apache.solr.update.UpdateLog
 
close(boolean, boolean) - Method in class org.apache.solr.update.UpdateLog
 
close(SolrCoreState.IndexWriterCloser) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
close(SolrCoreState.IndexWriterCloser) - Method in class org.apache.solr.update.SolrCoreState
 
closeAndWait() - Method in class org.apache.solr.core.SolrCore
Close the core, if it is still in use waits until is no longer in use.
closeCacheValueCalled - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
closed - Variable in class org.apache.solr.update.SolrCoreState
 
CLOSED_SERVLET_INPUT_STREAM - Static variable in class org.apache.solr.servlet.ServletUtils.ClosedServletInputStream
 
CLOSED_SERVLET_OUTPUT_STREAM - Static variable in class org.apache.solr.servlet.ServletUtils.ClosedServletOutputStream
 
ClosedServletInputStream() - Constructor for class org.apache.solr.servlet.ServletUtils.ClosedServletInputStream
 
ClosedServletOutputStream() - Constructor for class org.apache.solr.servlet.ServletUtils.ClosedServletOutputStream
 
closeEntries - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
CloseHook - Interface in org.apache.solr.core
Used to request notification when the core is closed.
closeIndexWriter(SolrCore, boolean) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
closeIndexWriter(SolrCore, boolean) - Method in class org.apache.solr.update.SolrCoreState
Expert method that closes the IndexWriter - you must call SolrCoreState.openIndexWriter(SolrCore) in a finally block after calling this method.
closeListeners - Variable in class org.apache.solr.core.CachingDirectoryFactory
 
closeOnShutdown() - Method in interface org.apache.solr.core.ShutdownAwareDirectory
 
closeOutput() - Method in class org.apache.solr.update.TransactionLog
Move to a read-only state, closing and releasing resources while keeping the log available for reads
closeQuietly(Object) - Static method in class org.apache.solr.core.PluginBag
 
closeReporter(String, String, String) - Method in class org.apache.solr.metrics.SolrMetricManager
Close and unregister a named SolrMetricReporter for a registry.
closeReporters(String) - Method in class org.apache.solr.metrics.SolrMetricManager
Close and unregister all SolrMetricReporter-s for a registry.
closeReporters(String, String) - Method in class org.apache.solr.metrics.SolrMetricManager
Close and unregister all SolrMetricReporter-s for a registry.
closeRequest() - Method in class org.apache.solr.security.AuthenticationPlugin
Cleanup any per request data
closeRequest() - Method in class org.apache.solr.security.BasicAuthPlugin
 
closeRequest() - Method in class org.apache.solr.security.MultiAuthPlugin
 
closeSearcher() - Method in class org.apache.solr.core.SolrCore
 
closeShield(HttpServletRequest, boolean) - Static method in class org.apache.solr.servlet.ServletUtils
Wrap the request's input stream with a close shield.
closeShield(HttpServletResponse, boolean) - Static method in class org.apache.solr.servlet.ServletUtils
Wrap the response's output stream with a close shield.
closeWriter(IndexWriter) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
closeWriter(IndexWriter) - Method in interface org.apache.solr.update.SolrCoreState.IndexWriterCloser
 
cloudClient() - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
cloudClient(boolean) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
If true then use CloudSolrClient for communication.
CloudConfig - Class in org.apache.solr.core
 
CloudConfig.CloudConfigBuilder - Class in org.apache.solr.core
 
CloudConfigBuilder(String, int) - Constructor for class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
CloudConfigBuilder(String, int, String) - Constructor for class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
CloudDescriptor - Class in org.apache.solr.cloud
SolrCloud metadata attached to a CoreDescriptor.
CloudDescriptor(CoreDescriptor, String, Properties) - Constructor for class org.apache.solr.cloud.CloudDescriptor
 
cloudManager - Variable in class org.apache.solr.cloud.overseer.CollectionMutator
 
cloudManager - Variable in class org.apache.solr.cloud.overseer.ReplicaMutator
 
cloudManager - Variable in class org.apache.solr.cloud.overseer.SliceMutator
 
CloudMLTQParser - Class in org.apache.solr.search.mlt
 
CloudMLTQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.mlt.CloudMLTQParser
 
cloudOptions - Static variable in class org.apache.solr.cli.SolrCLI
 
CloudUtil - Class in org.apache.solr.cloud
 
CloudUtil() - Constructor for class org.apache.solr.cloud.CloudUtil
 
cluster - org.apache.solr.core.SolrInfoBean.Group
 
Cluster - Interface in org.apache.solr.cluster
A representation of the SolrCloud cluster state, providing information on which nodes and collections are part of the cluster and a way to get to more detailed info.
CLUSTER_MEMBER_NODE - Static variable in class org.apache.solr.security.PKIAuthenticationPlugin
 
CLUSTER_PLUGIN_EDIT_ENABLED - Static variable in class org.apache.solr.api.ContainerPluginsRegistry
 
CLUSTER_PLUGINS_PATH - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
CLUSTER_PROPERTIES_CHANGED - org.apache.solr.cluster.events.ClusterEvent.EventType
Cluster properties have changed.
ClusterAPI - Class in org.apache.solr.handler
All V2 APIs that have a prefix of /api/cluster/
ClusterAPI(CollectionsHandler, ConfigSetsHandler) - Constructor for class org.apache.solr.handler.ClusterAPI
 
ClusterAPI.Commands - Class in org.apache.solr.handler
 
ClusterAPI.RoleInfo - Class in org.apache.solr.handler
 
ClusterCreateCollection - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
ClusterDeleteCollection - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
ClusterEvent - Interface in org.apache.solr.cluster.events
Cluster-level event.
ClusterEvent.EventType - Enum in org.apache.solr.cluster.events
 
ClusterEventListener - Interface in org.apache.solr.cluster.events
Components that want to be notified of cluster-wide events should use this.
ClusterEventProducer - Interface in org.apache.solr.cluster.events
Component that produces ClusterEvent instances.
ClusterEventProducerBase - Class in org.apache.solr.cluster.events
Base class for implementing ClusterEventProducer.
ClusterEventProducerBase(CoreContainer) - Constructor for class org.apache.solr.cluster.events.ClusterEventProducerBase
 
ClusterEventProducerFactory - Class in org.apache.solr.cluster.events.impl
This class helps in handling the initial registration of plugin-based listeners, when both the final ClusterEventProducer implementation and listeners are configured using plugins.
ClusterEventProducerFactory(CoreContainer) - Constructor for class org.apache.solr.cluster.events.impl.ClusterEventProducerFactory
 
ClusterPluginsSource - Interface in org.apache.solr.api
A source for Cluster Plugin configurations
CLUSTERPROP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
ClusterPropertiesChangedEvent - Interface in org.apache.solr.cluster.events
Event generated when ZkStateReader.CLUSTER_PROPS is modified.
CLUSTERPROPS_PATH - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
clusterShape(int, int) - Static method in class org.apache.solr.cloud.CloudUtil
Return a CollectionStatePredicate that returns true if a collection has the expected number of active shards and replicas
clusterShape(int, int, boolean, boolean) - Static method in class org.apache.solr.cloud.CloudUtil
Return a CollectionStatePredicate that returns true if a collection has the expected number of shards and replicas.
ClusterSingleton - Interface in org.apache.solr.cloud
Intended for components that should be enabled only one instance per cluster.
ClusterSingleton.State - Enum in org.apache.solr.cloud
 
ClusterSingletons - Class in org.apache.solr.core
Helper class to manage the initial registration of ClusterSingleton plugins and to track the changes in loaded plugins in ContainerPluginsRegistry.
ClusterSingletons(Supplier<Boolean>, Consumer<Runnable>) - Constructor for class org.apache.solr.core.ClusterSingletons
Create a helper to manage singletons.
clusterState - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
 
clusterState - Variable in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
ClusterStateMutator - Class in org.apache.solr.cloud.overseer
 
ClusterStateMutator(SolrCloudManager) - Constructor for class org.apache.solr.cloud.overseer.ClusterStateMutator
 
ClusterStatus - Class in org.apache.solr.handler.admin
 
ClusterStatus(ZkStateReader, ZkNodeProps) - Constructor for class org.apache.solr.handler.admin.ClusterStatus
 
CLUSTERSTATUS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
Handle cluster status request.
ClusterStatus.Health - Enum in org.apache.solr.handler.admin
Shard / collection health state.
cmd - Variable in class org.apache.solr.update.SolrCmdDistributor.Req
 
CMD_ABORT_FETCH - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_BACKUP - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_DELETE_BACKUP - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_DETAILS - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_DISABLE_POLL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_DISABLE_REPL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_ENABLE_POLL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_ENABLE_REPL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_FETCH_INDEX - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_GET_FILE - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_GET_FILE_LIST - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_INDEX_VERSION - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_RESTORE - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_RESTORE_STATUS - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CMD_SHOW_COMMITS - Static variable in class org.apache.solr.handler.ReplicationHandler
 
cName - Variable in class org.apache.solr.core.PluginInfo
 
CodecFactory - Class in org.apache.solr.core
Factory for plugging in a custom Codec
CodecFactory() - Constructor for class org.apache.solr.core.CodecFactory
 
COL_STATS_KEY - Static variable in class org.apache.solr.search.stats.StatsCache
Value of CollectionStats.
COLL_EDIT_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
COLL_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
CollApiCmds - Class in org.apache.solr.cloud.api.collections
This class contains "smaller" Collection API commands implementation, the interface implemented by all commands and the class mapping a collection action to the actual command.
CollApiCmds() - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds
 
CollApiCmds.AddReplicaPropCmd - Class in org.apache.solr.cloud.api.collections
 
CollApiCmds.BalanceShardsUniqueCmd - Class in org.apache.solr.cloud.api.collections
 
CollApiCmds.CollectionApiCommand - Interface in org.apache.solr.cloud.api.collections
Interface implemented by all Collection API commands.
CollApiCmds.CommandMap - Class in org.apache.solr.cloud.api.collections
Map CollectionParams.CollectionAction to instances of CollApiCmds.CollectionApiCommand and being usable by both OverseerCollectionMessageHandler and DistributedCollectionConfigSetCommandRunner so that the mappings do not have to be maintained in two places.
CollApiCmds.DeleteReplicaPropCmd - Class in org.apache.solr.cloud.api.collections
 
CollApiCmds.MockOperationCmd - Class in org.apache.solr.cloud.api.collections
 
CollApiCmds.ModifyCollectionCmd - Class in org.apache.solr.cloud.api.collections
 
CollApiCmds.RebalanceLeadersCmd - Class in org.apache.solr.cloud.api.collections
 
CollApiCmds.ReloadCollectionCmd - Class in org.apache.solr.cloud.api.collections
 
CollApiCmds.TraceAwareCommand - Class in org.apache.solr.cloud.api.collections
 
COLLAPSE - org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
 
CollapseScoreFunction - Class in org.apache.solr.search.function
 
CollapseScoreFunction() - Constructor for class org.apache.solr.search.function.CollapseScoreFunction
 
CollapseScoreFunction.CollapseScoreFunctionValues - Class in org.apache.solr.search.function
 
CollapseScoreFunctionValues(Map<?, ?>) - Constructor for class org.apache.solr.search.function.CollapseScoreFunction.CollapseScoreFunctionValues
 
CollapsingPostFilter(SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
CollapsingQParserPlugin - Class in org.apache.solr.search
The CollapsingQParserPlugin is a PostFilter that performs field collapsing.
CollapsingQParserPlugin() - Constructor for class org.apache.solr.search.CollapsingQParserPlugin
 
CollapsingQParserPlugin.CollapseScore - Class in org.apache.solr.search
 
CollapsingQParserPlugin.CollapsingPostFilter - Class in org.apache.solr.search
 
CollapsingQParserPlugin.GroupHeadSelector - Class in org.apache.solr.search
Models all the information about how group head documents should be selected
CollapsingQParserPlugin.GroupHeadSelectorType - Enum in org.apache.solr.search
 
CollapsingQParserPlugin.NullPolicy - Enum in org.apache.solr.search
 
collate(SpellingResult, String, ResponseBuilder) - Method in class org.apache.solr.spelling.SpellCheckCollator
 
CollationField - Class in org.apache.solr.schema
Field for collated sort keys.
CollationField() - Constructor for class org.apache.solr.schema.CollationField
 
collations - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
collCreationParameters - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.CreateAliasRequestBody
 
collect(int) - Method in class org.apache.solr.search.DelegatingCollector
 
collect(int) - Method in class org.apache.solr.search.DocSetCollector
 
collect(int) - Method in class org.apache.solr.search.join.MultiValueTermOrdinalCollector
 
collect(int) - Method in class org.apache.solr.search.MaxScoreCollector
 
collect(int, int, IntFunction<SlotAcc.SlotContext>) - Method in class org.apache.solr.search.facet.DocValuesAcc
 
collect(int, int, IntFunction<SlotAcc.SlotContext>) - Method in class org.apache.solr.search.facet.SlotAcc
All subclasses must override this method to collect documents.
collect(DocSet, int, IntFunction<SlotAcc.SlotContext>) - Method in class org.apache.solr.search.facet.SlotAcc
Bulk collection of all documents in a slot.
COLLECT_ELEVATED_DOCS_WHEN_COLLAPSING - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
If elevation is used in combination with the collapse query parser, we can define that we only want to return the representative and not all elevated docs by setting this parameter to false (true by default).
collectDocs(FacetFieldProcessorByArrayUIF) - Method in class org.apache.solr.search.facet.UnInvertedField
 
collectDocsGeneric(FacetFieldProcessorByArrayUIF) - Method in class org.apache.solr.search.facet.UnInvertedField
 
collection - org.apache.solr.core.SolrInfoBean.Group
 
collection - Variable in class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
collection - Variable in class org.apache.solr.cloud.overseer.ZkWriteCommand
 
collection - Variable in class org.apache.solr.cloud.RefreshCollectionMessage
 
collection - Variable in class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
collection - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
collection - Variable in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
COLLECTION_ALIAS_PROP - Static variable in class org.apache.solr.core.backup.BackupManager
 
COLLECTION_LIST - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
COLLECTION_NAME_PROP - Static variable in class org.apache.solr.core.backup.BackupManager
 
COLLECTION_PARAM_PREFIX - Static variable in class org.apache.solr.cloud.ZkController
 
COLLECTION_PROPS_AND_DEFAULTS - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
COLLECTION_PROPS_FILE - Static variable in class org.apache.solr.core.backup.BackupManager
 
CollectionApiLockFactory - Class in org.apache.solr.cloud.api.collections
This class implements a higher level locking abstraction for the Collection API using lower level read and write locks.
CollectionCommandContext - Interface in org.apache.solr.cloud.api.collections
Data passed to Collection API command execution, to allow calls from either the OverseerCollectionMessageHandler when commands are executed on the Overseer, or - in a future change - allow Collection API commands to be executed in a distributed way, unrelated to and not depending upon Overseer abstractions (including overseer collection message handling).
CollectionCreateShard - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
CollectionDeleteShard - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
CollectionHandlingUtils - Class in org.apache.solr.cloud.api.collections
This class contains helper methods used by commands of the Collection API.
CollectionHandlingUtils() - Constructor for class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
CollectionHandlingUtils.ShardRequestTracker - Class in org.apache.solr.cloud.api.collections
 
CollectionMetrics - Interface in org.apache.solr.cluster.placement
Collection-level metrics.
CollectionMetricsBuilder - Class in org.apache.solr.cluster.placement.impl
Builder class for constructing instances of CollectionMetrics.
CollectionMetricsBuilder() - Constructor for class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder
 
CollectionMetricsBuilder.ReplicaMetricsBuilder - Class in org.apache.solr.cluster.placement.impl
 
CollectionMetricsBuilder.ShardMetricsBuilder - Class in org.apache.solr.cluster.placement.impl
 
CollectionModifyCollection - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
CollectionMutator - Class in org.apache.solr.cloud.overseer
 
CollectionMutator(SolrCloudManager) - Constructor for class org.apache.solr.cloud.overseer.CollectionMutator
 
collectionName - Variable in class org.apache.solr.cloud.api.collections.AddReplicaCmd.CreateReplica
 
collectionName - Variable in class org.apache.solr.cloud.api.collections.Assign.AssignRequest
 
collectionName - Variable in class org.apache.solr.security.AuthorizationContext.CollectionRequest
 
collectionNodeType - Variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
This property defines an additional constraint that the collection must be placed only on the nodes of the correct "node type".
COLLECTIONPROP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
CollectionProperty - Class in org.apache.solr.handler.admin.api
V2 API implementations for modifying collection-level properties.
CollectionProperty(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CollectionProperty
 
CollectionRequest(String) - Constructor for class org.apache.solr.security.AuthorizationContext.CollectionRequest
 
collections - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.CreateAliasRequestBody
 
collections() - Method in interface org.apache.solr.cluster.Cluster
Allow foreach iteration on all collections of the cluster, such as: for (SolrCollection c : cluster.collections()) {...}.
COLLECTIONS_ADDED - org.apache.solr.cluster.events.ClusterEvent.EventType
One or more collections have been added.
COLLECTIONS_REMOVED - org.apache.solr.cluster.events.ClusterEvent.EventType
One or more collections have been removed.
CollectionsAddedEvent - Interface in org.apache.solr.cluster.events
Event generated when some collections have been added.
collectionsHandler - Variable in class org.apache.solr.core.CoreContainer
 
CollectionsHandler - Class in org.apache.solr.handler.admin
 
CollectionsHandler() - Constructor for class org.apache.solr.handler.admin.CollectionsHandler
 
CollectionsHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.CollectionsHandler
Overloaded ctor to inject CoreContainer into the handler.
CollectionsHandler.CollectionOperation - Enum in org.apache.solr.handler.admin
 
collectionsList - Variable in class org.apache.solr.servlet.HttpSolrCall
 
CollectionSnapshotMetaData - Class in org.apache.solr.core.snapshots
This class defines the meta-data about a collection level snapshot
CollectionSnapshotMetaData(String) - Constructor for class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
CollectionSnapshotMetaData(String, CollectionSnapshotMetaData.SnapshotStatus, Date, List<CollectionSnapshotMetaData.CoreSnapshotMetaData>) - Constructor for class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
CollectionSnapshotMetaData(Map<String, Object>) - Constructor for class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
CollectionSnapshotMetaData(NamedList<?>) - Constructor for class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
CollectionSnapshotMetaData.CoreSnapshotMetaData - Class in org.apache.solr.core.snapshots
 
CollectionSnapshotMetaData.SnapshotStatus - Enum in org.apache.solr.core.snapshots
 
CollectionsRemovedEvent - Interface in org.apache.solr.cluster.events
Event generated when some collections have been removed.
CollectionsRepairEventListener - Class in org.apache.solr.cluster.events.impl
This is an illustration how to re-implement the combination of Solr 8x NodeLostTrigger and AutoAddReplicasPlanAction to maintain the collection's replicas when nodes are lost.
CollectionsRepairEventListener(CoreContainer) - Constructor for class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
collectionStatistics(String) - Method in class org.apache.solr.search.SolrIndexSearcher
 
collectionStatistics(SolrIndexSearcher, String) - Method in class org.apache.solr.search.stats.ExactStatsCache.ExactStatsSource
 
collectionStatistics(SolrIndexSearcher, String) - Method in class org.apache.solr.search.stats.LocalStatsSource
 
collectionStatistics(SolrIndexSearcher, String) - Method in class org.apache.solr.search.stats.StatsSource
 
CollectionStats - Class in org.apache.solr.search.stats
Modifiable version of CollectionStatistics useful for aggregation of per-shard stats.
CollectionStats(String) - Constructor for class org.apache.solr.search.stats.CollectionStats
 
CollectionStats(String, long, long, long, long) - Constructor for class org.apache.solr.search.stats.CollectionStats
 
CollectionStats(CollectionStatistics) - Constructor for class org.apache.solr.search.stats.CollectionStats
 
CollectionStatusAPI - Class in org.apache.solr.handler.admin.api
V2 API for displaying basic information about a single collection.
CollectionStatusAPI(CollectionsHandler) - Constructor for class org.apache.solr.handler.admin.api.CollectionStatusAPI
 
collectOrdToSlot(int, int) - Method in class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
collectSortedDocSet(DocSet, IndexReader, Collector) - Static method in class org.apache.solr.search.DocSetUtil
 
collectValues(int, int) - Method in class org.apache.solr.search.facet.DocValuesAcc
 
COLON - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
colStatsMapFromString(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
colStatsMapToString(Map<String, CollectionStats>) - Static method in class org.apache.solr.search.stats.StatsUtil
 
colStatsToString(CollectionStats) - Static method in class org.apache.solr.search.stats.StatsUtil
Make a String representation of CollectionStats
ColStatus - Class in org.apache.solr.handler.admin
Report low-level details of collection.
ColStatus(SolrClientCache, ClusterState, ZkNodeProps) - Constructor for class org.apache.solr.handler.admin.ColStatus
 
COLSTATUS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
combine(Collection<ClusterStatus.Health>) - Static method in enum org.apache.solr.handler.admin.ClusterStatus.Health
Combine multiple states into one.
combineQueryAndFilter(Query, Query) - Static method in class org.apache.solr.search.QueryUtils
Combines a scoring query with a non-scoring (filter) query.
combineScores(float, float, double, ReRankOperator) - Static method in class org.apache.solr.search.ReRankScaler
 
command() - Method in class org.apache.solr.schema.ZkIndexSchemaReader
Called after a ZooKeeper session expiration occurs; need to re-create the watcher and update the current schema from ZooKeeper.
Command<T> - Interface in org.apache.solr.search.grouping
Defines a grouping command.
Command - Annotation Type in org.apache.solr.api
 
Command() - Constructor for class org.apache.solr.packagemanager.SolrPackage.Command
 
Command() - Constructor for class org.apache.solr.search.Grouping.Command
 
COMMAND - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
COMMAND - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CommandField() - Constructor for class org.apache.solr.search.Grouping.CommandField
 
CommandFunc() - Constructor for class org.apache.solr.search.Grouping.CommandFunc
 
CommandHandler - Class in org.apache.solr.search.grouping
Responsible for executing a search with a number of Command instances.
CommandHandler.Builder - Class in org.apache.solr.search.grouping
 
CommandQuery() - Constructor for class org.apache.solr.search.Grouping.CommandQuery
 
commands - Variable in class org.apache.solr.handler.ClusterAPI
 
Commands() - Constructor for class org.apache.solr.handler.ClusterAPI.Commands
 
commandSchema - Variable in class org.apache.solr.api.Api
 
commandsMapping - Variable in class org.apache.solr.handler.admin.BaseHandlerApiSupport
 
COMMENT - Static variable in interface org.apache.solr.parser.QueryParserConstants
Lexical state.
COMMENTS_DISABLED - Static variable in class org.apache.solr.internal.csv.CSVStrategy
 
commit() - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Does a simple commit operation
commit() - Method in class org.apache.solr.jersey.container.JettyBridgeResponseWriter
 
commit(CommitUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
commit(CommitUpdateCommand) - Method in class org.apache.solr.update.UpdateHandler
 
COMMIT - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
COMMIT - Static variable in class org.apache.solr.update.UpdateLog
 
COMMIT_COMMAND_VERSION - Static variable in class org.apache.solr.update.SolrIndexWriter
 
COMMIT_END_POINT - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
COMMIT_TIME_MSEC_KEY - Static variable in class org.apache.solr.update.SolrIndexWriter
Stored into each Lucene commit to record the System.currentTimeMillis() when commit was called.
COMMIT_WITHIN - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
commitAndSwitchToNewTlog(CommitUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
Block updates, append a commit at current tlog, then copy over updates to a new tlog.
commitCallbacks - Variable in class org.apache.solr.update.UpdateHandler
 
commitData - Variable in class org.apache.solr.update.CommitUpdateCommand
User provided commit data.
commitData - Variable in class org.apache.solr.update.SplitIndexCommand
User provided commit data.
commitName - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationRequestBody
 
commitTracker - Variable in class org.apache.solr.update.DirectUpdateHandler2
 
CommitTracker - Class in org.apache.solr.update
Helper class for tracking autoCommit state.
CommitTracker(String, SolrCore, int, int, long, boolean, boolean) - Constructor for class org.apache.solr.update.CommitTracker
 
CommitUpdateCommand - Class in org.apache.solr.update
A commit index command encapsulated in an object.
CommitUpdateCommand(SolrQueryRequest, boolean) - Constructor for class org.apache.solr.update.CommitUpdateCommand
 
commitWithin - Variable in class org.apache.solr.update.AddUpdateCommand
 
commitWithin - Variable in class org.apache.solr.update.DeleteUpdateCommand
 
commitWithinSoftCommit - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
commitWithinSoftCommit - Variable in class org.apache.solr.update.DirectUpdateHandler2
 
commonResponse() - Method in class org.apache.solr.search.Grouping.Command
 
comp - Variable in class org.apache.solr.handler.export.IntValue
 
comp - Variable in class org.apache.solr.handler.export.LongValue
 
COMPACT_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
COMPARATOR_CLASS - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
COMPARATOR_CLASS - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
comparators - Variable in class org.apache.solr.handler.component.ShardFieldSortedHitQueue
Stores a comparator corresponding to each field being sorted by
compare(int) - Method in interface org.apache.solr.search.function.SolrComparisonBoolFunction.Compare
 
compare(int, int) - Method in interface org.apache.solr.handler.export.IntComp
 
compare(int, int) - Method in class org.apache.solr.handler.export.IntComp.IntAsc
 
compare(int, int) - Method in class org.apache.solr.handler.export.IntComp.IntDesc
 
compare(int, int) - Method in class org.apache.solr.search.facet.SlotAcc
 
compare(int, int) - Method in class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
compare(int, int) - Method in class org.apache.solr.search.facet.SlotAcc.IntSlotAcc
 
compare(int, int) - Method in class org.apache.solr.search.facet.SlotAcc.LongFuncSlotAcc
 
compare(int, int) - Method in class org.apache.solr.util.PrimUtils.IntComparator
 
compare(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.EqualFunction
 
compare(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.SolrComparisonBoolFunction
 
compare(ScoreDoc, ScoreDoc) - Method in class org.apache.solr.search.ReRankCollector.BoostedComp
 
compare(TermsResponse.Term, TermsResponse.Term) - Method in class org.apache.solr.handler.component.TermsComponent.TermCountComparator
 
compare(PivotFacetValue, PivotFacetValue) - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection.PivotFacetCountComparator
 
compare(PivotFacetValue, PivotFacetValue) - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection.PivotFacetValueComparator
 
compare(IndexFingerprint, IndexFingerprint) - Static method in class org.apache.solr.update.IndexFingerprint
returns 0 for equal, negative if f1 is less recent than f2, positive if more recent
compareFile(Directory, String, Long, Long) - Static method in class org.apache.solr.handler.IndexFetcher
 
compareMaps(Map<String, ?>, Map<String, ?>) - Static method in class org.apache.solr.api.ContainerPluginsRegistry
 
CompareResult() - Constructor for class org.apache.solr.handler.IndexFetcher.CompareResult
 
compareTo(OrderedNodePlacementPlugin.WeightedNode) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
compareTo(BackupId) - Method in class org.apache.solr.core.backup.BackupId
 
compareTo(SortValue) - Method in class org.apache.solr.handler.export.IntValue
 
compareTo(SortValue) - Method in class org.apache.solr.handler.export.LongValue
 
compareTo(LoggerInfo) - Method in class org.apache.solr.logging.LoggerInfo
 
compareTo(SolrPackage) - Method in class org.apache.solr.packagemanager.SolrPackage
 
compareTo(SimpleFacets.CountPair<K, V>) - Method in class org.apache.solr.request.SimpleFacets.CountPair
 
compareTo(CurrencyValue) - Method in class org.apache.solr.schema.CurrencyValue
 
compareTo(IndexSchema.DynamicReplacement) - Method in class org.apache.solr.schema.IndexSchema.DynamicReplacement
Sort order is based on length of regex.
compareTo(SpellCheckCollation) - Method in class org.apache.solr.spelling.SpellCheckCollation
 
compareTo(ConcurrentLRUCache.CacheEntry<K, V>) - Method in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
complainAboutUnknownAttributes(String, String...) - Method in class org.apache.solr.core.XmlConfigFile
Logs an error and throws an exception if any of the element(s) at the given elementXpath contains an attribute name that is not among knownAttributes.
complete() - Method in class org.apache.solr.search.DelegatingCollector
since 9.4
COMPLETED - org.apache.solr.security.AuditEvent.EventType
 
COMPLETED - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
ComplexPhraseQParserPlugin - Class in org.apache.solr.search
Parse Solr's variant on the Lucene ComplexPhraseQueryParser syntax.
ComplexPhraseQParserPlugin() - Constructor for class org.apache.solr.search.ComplexPhraseQParserPlugin
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.ActiveTasksListComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.DebugComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.ExpandComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.FacetComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.HighlightComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.MoreLikeThisComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
Name, also used as a request param to identify whether the user query concerns this component
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.QueryCancellationComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.QueryComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.RealTimeGetComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.ResponseLogComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.SpellCheckComponent
Base name for all spell checker query parameters.
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.StatsComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.SuggestComponent
Name used to identify whether the user query concerns this component
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.TermsComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.TermVectorComponent
 
COMPONENT_NAME - Static variable in class org.apache.solr.search.facet.FacetModule
 
components - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
components - Variable in class org.apache.solr.handler.component.SearchHandler
 
CompositeApi(Api) - Constructor for class org.apache.solr.api.V2HttpCall.CompositeApi
 
COMPRESSION - Static variable in class org.apache.solr.handler.ReplicationHandler
 
COMPRESSION_MODE - Static variable in class org.apache.solr.core.SchemaCodecFactory
Key to use in init arguments to set the compression mode in the codec.
compressor - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
 
compute(double[], double[]) - Method in class org.apache.solr.handler.HaversineMetersEvaluator.HaversineDistance
 
computeBalancing(BalanceRequest, PlacementContext) - Method in interface org.apache.solr.cluster.placement.PlacementPlugin
Request from plugin code to compute a balancing of replicas.
computeBalancing(BalanceRequest, PlacementContext) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
computeBaseDocSet() - Method in class org.apache.solr.handler.component.StatsField
Computes a base DocSet for the current request to be used when computing global stats for the local index.
computeCollectionUpdate(String, String, DocCollection, SolrZkClient) - Static method in class org.apache.solr.cloud.overseer.NodeMutator
Returns the write command needed to update the replicas of a given collection given the identity of a node being down.
computeDocSet(DocSet, List<String>) - Method in class org.apache.solr.request.SimpleFacets
 
computeFullUrl(URL, String) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Computes the full URL based on a base url and a possibly relative link found in the href param of an HTML anchor.
computeIfAbsent(String, Supplier<ApplicationHandler>) - Method in class org.apache.solr.jersey.JerseyAppHandlerCache
Return the 'ApplicationHandler' associated with the provided ID, creating it first if necessary.
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
computeIfAbsent(K, IOFunction<? super K, ? extends V>) - Method in class org.apache.solr.search.CaffeineCache
 
computeIfAbsent(K, IOFunction<? super K, ? extends V>) - Method in interface org.apache.solr.search.SolrCache
Get an existing element or atomically compute it if missing.
computeInitialCollectionName() - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
computeInitialCollectionName() - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
computeInitialCollectionName() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
computeInPlaceUpdatableFields(AddUpdateCommand) - Static method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
Given an add update command, compute a list of fields that can be updated in-place.
computeLocalStatsValues(DocSet) - Method in class org.apache.solr.handler.component.StatsField
Computes the StatsValues for this StatsField relative to the specified DocSet
computePlacement(PlacementRequest, PlacementContext) - Method in interface org.apache.solr.cluster.placement.PlacementPlugin
Request from plugin code to compute placement.
computePlacements(Collection<PlacementRequest>, PlacementContext) - Method in interface org.apache.solr.cluster.placement.PlacementPlugin
Request from plugin code to compute multiple placements.
computePlacements(Collection<PlacementRequest>, PlacementContext) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
computeRelatedness(long, long, long, long) - Static method in class org.apache.solr.search.facet.RelatednessAgg
This is an aproximated Z-Score, as described in the "Scoring Semantic Relationships" section of "The Semantic Knowledge Graph: A compact, auto-generated model for real-time traversal and ranking of any relationship within a domain"
computeReplicaBalancing(SolrCloudManager, Set<String>, int) - Method in interface org.apache.solr.cloud.api.collections.Assign.AssignStrategy
Balance replicas across nodes.
computeReplicaBalancing(SolrCloudManager, Set<String>, int) - Method in class org.apache.solr.cluster.placement.impl.PlacementPluginAssignStrategy
 
computeReplicaType() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
computeReplicaType() - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
ConcatFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Concatenates multiple values for fields matching the specified conditions using a configurable delimiter which defaults to ", ".
ConcatFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ConcatFieldUpdateProcessorFactory
 
ConcatStringFunction - Class in org.apache.solr.search.function
ConcatStringFunction concatenates the string values of its components in the order given.
ConcatStringFunction(ValueSource[]) - Constructor for class org.apache.solr.search.function.ConcatStringFunction
 
ConcurrentLRUCache<K,​V> - Class in org.apache.solr.util
A LRU cache implementation based upon ConcurrentHashMap and other techniques to reduce contention and synchronization overhead to utilize multiple CPU cores more effectively.
ConcurrentLRUCache(int, int) - Constructor for class org.apache.solr.util.ConcurrentLRUCache
 
ConcurrentLRUCache(int, int, int, int, boolean, boolean, ConcurrentLRUCache.EvictionListener<K, V>) - Constructor for class org.apache.solr.util.ConcurrentLRUCache
 
ConcurrentLRUCache(int, int, int, int, boolean, boolean, ConcurrentLRUCache.EvictionListener<K, V>, int) - Constructor for class org.apache.solr.util.ConcurrentLRUCache
 
ConcurrentLRUCache(long, long, boolean, ConcurrentLRUCache.EvictionListener<K, V>) - Constructor for class org.apache.solr.util.ConcurrentLRUCache
 
ConcurrentLRUCache(long, long, boolean, ConcurrentLRUCache.EvictionListener<K, V>, int) - Constructor for class org.apache.solr.util.ConcurrentLRUCache
 
ConcurrentLRUCache.CacheEntry<K,​V> - Class in org.apache.solr.util
 
ConcurrentLRUCache.EvictionListener<K,​V> - Interface in org.apache.solr.util
 
ConcurrentLRUCache.Stats - Class in org.apache.solr.util
 
condition - Variable in class org.apache.solr.packagemanager.SolrPackage.Command
 
CONF_CHECKSUM - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CONF_FILE_SHORT - Static variable in class org.apache.solr.handler.ReplicationHandler
 
CONF_FILES - Static variable in class org.apache.solr.handler.ReplicationHandler
 
confFiles - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileListResponse
 
config - Variable in class org.apache.solr.servlet.HttpSolrCall
 
CONFIG_EDIT_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
CONFIG_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
CONFIG_SET_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
CONFIG_SET_PROPERTY_PREFIX - Static variable in class org.apache.solr.cloud.ConfigSetCmds
Prefix for properties that should be applied to the ConfigSet for CREATE
CONFIG_SET_TIMEOUT - Static variable in class org.apache.solr.handler.admin.ConfigSetsHandler
 
CONFIG_STATE_DIR - Static variable in class org.apache.solr.core.backup.BackupManager
 
ConfigEditablePlugin - Interface in org.apache.solr.security
An interface to be implemented by a Plugin whose Configuration is runtime editable
configEditing_disabled - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
configFileName - Variable in class org.apache.solr.handler.component.QueryElevationComponent
 
CONFIGNAME_PROP - Static variable in class org.apache.solr.cloud.ZkController
 
ConfigOverlay - Class in org.apache.solr.core
This class encapsulates the config overlay json file.
ConfigOverlay(Map<String, Object>, int) - Constructor for class org.apache.solr.core.ConfigOverlay
 
CONFIGOVERLAY_JSON - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
CONFIGS_ZKNODE - Static variable in class org.apache.solr.cloud.ZkConfigSetService
ZkNode where named configs are stored
ConfigSet - Class in org.apache.solr.core
Stores a core's configuration in the form of a SolrConfig and IndexSchema.
ConfigSet(String, SolrConfig, ConfigSet.SchemaSupplier, NamedList<?>, boolean) - Constructor for class org.apache.solr.core.ConfigSet
 
CONFIGSET_EDITING_DISABLED_ARG - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
CONFIGSET_NAME_PLACEHOLDER - Static variable in class org.apache.solr.handler.configsets.DeleteConfigSetAPI
 
CONFIGSET_NAME_PLACEHOLDER - Static variable in class org.apache.solr.handler.configsets.UploadConfigSetAPI
 
CONFIGSET_NAME_PLACEHOLDER - Static variable in class org.apache.solr.handler.configsets.UploadConfigSetFileAPI
 
ConfigSetAPIBase - Class in org.apache.solr.handler.configsets
Parent class for all APIs that manipulate configsets
ConfigSetAPIBase(CoreContainer) - Constructor for class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
ConfigSetApiLockFactory - Class in org.apache.solr.cloud
This class implements a higher level locking abstraction for the Config Set API using lower level read and write locks.
ConfigSetApiLockFactory(DistributedConfigSetLockFactory) - Constructor for class org.apache.solr.cloud.ConfigSetApiLockFactory
 
ConfigSetCmds - Class in org.apache.solr.cloud
This class contains methods dealing with Config Sets and called for Config Set API execution, called from the OverseerConfigSetMessageHandler or from DistributedCollectionConfigSetCommandRunner.runConfigSetCommand(org.apache.solr.response.SolrQueryResponse, org.apache.solr.common.params.ConfigSetParams.ConfigSetAction, java.util.Map<java.lang.String, java.lang.Object>, long) depending on whether Collection and Config Set APIs are Overseer based or distributed.
ConfigSetCmds() - Constructor for class org.apache.solr.cloud.ConfigSetCmds
 
ConfigSetDownloadTool - Class in org.apache.solr.cli
 
ConfigSetDownloadTool() - Constructor for class org.apache.solr.cli.ConfigSetDownloadTool
 
ConfigSetDownloadTool(PrintStream) - Constructor for class org.apache.solr.cli.ConfigSetDownloadTool
 
configSetName(CoreDescriptor) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
configSetName(CoreDescriptor) - Method in class org.apache.solr.core.ConfigSetService
Return a name for the ConfigSet for a core to be used for printing/diagnostic purposes.
configSetName(CoreDescriptor) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
ConfigSetProperties - Class in org.apache.solr.core
Utility methods for reading configSet properties.
ConfigSetProperties() - Constructor for class org.apache.solr.core.ConfigSetProperties
 
CONFIGSETS_ACTION_PREFIX - Static variable in class org.apache.solr.cloud.OverseerConfigSetMessageHandler
Prefix to specify an action should be handled by this handler.
configSetService - Variable in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
ConfigSetService - Class in org.apache.solr.core
Service class used by the CoreContainer to load ConfigSets for use in SolrCore creation.
ConfigSetService(SolrResourceLoader, boolean) - Constructor for class org.apache.solr.core.ConfigSetService
Create a new ConfigSetService
ConfigSetService.ConfigResource - Interface in org.apache.solr.core
 
configSetsHandler - Variable in class org.apache.solr.core.CoreContainer
 
ConfigSetsHandler - Class in org.apache.solr.handler.admin
A SolrRequestHandler for ConfigSets API requests.
ConfigSetsHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.ConfigSetsHandler
Overloaded ctor to inject CoreContainer into the handler.
ConfigSetUploadTool - Class in org.apache.solr.cli
 
ConfigSetUploadTool() - Constructor for class org.apache.solr.cli.ConfigSetUploadTool
 
ConfigSetUploadTool(PrintStream) - Constructor for class org.apache.solr.cli.ConfigSetUploadTool
 
ConfigTool - Class in org.apache.solr.cli
Sends a POST to the Config API to perform a specified action.
ConfigTool() - Constructor for class org.apache.solr.cli.ConfigTool
 
ConfigTool(PrintStream) - Constructor for class org.apache.solr.cli.ConfigTool
 
ConfigurablePlugin<T extends org.apache.solr.common.MapWriter> - Interface in org.apache.solr.api
Implement this interface if your plugin needs to accept some configuration
configure() - Method in class org.apache.solr.jersey.APIConfigProviderBinder
 
configure(Object, Map<String, Object>, PluginMeta) - Static method in class org.apache.solr.api.ContainerPluginsRegistry
 
configure(AffinityPlacementConfig) - Method in class org.apache.solr.cluster.placement.plugins.AffinityPlacementFactory
 
configure(SolrResourceLoader, NamedList<String>) - Method in class org.apache.solr.rest.ManagedResourceStorage.FileStorageIO
 
configure(SolrResourceLoader, NamedList<String>) - Method in class org.apache.solr.rest.ManagedResourceStorage.InMemoryStorageIO
 
configure(SolrResourceLoader, NamedList<String>) - Method in interface org.apache.solr.rest.ManagedResourceStorage.StorageIO
 
configure(SolrResourceLoader, NamedList<String>) - Method in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
configure(T) - Method in interface org.apache.solr.api.ConfigurablePlugin
This is invoked soon after the Object is initialized.
configure(T) - Method in interface org.apache.solr.cluster.placement.PlacementPluginFactory
Default implementation is a no-op.
configuredDefaultStyle - Variable in class org.apache.solr.response.transform.ShardAugmenterFactory
 
ConflictHandler() - Constructor for class org.apache.solr.request.json.ObjectUtil.ConflictHandler
 
Conjunction() - Method in class org.apache.solr.parser.QueryParser
 
ConjunctionSolrSpellChecker - Class in org.apache.solr.spelling
This class lets a query be run through multiple spell checkers.
ConjunctionSolrSpellChecker() - Constructor for class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
Constants - Class in org.apache.solr.search.facet
constants used in facets package
constructChain(UpdateRequestProcessorChain, UpdateRequestProcessorChain.ProcessorInfo, SolrCore) - Static method in class org.apache.solr.update.processor.UpdateRequestProcessorChain
 
CONSTRUCTION - org.apache.solr.cluster.Shard.ShardState
 
constructRequest(ResponseBuilder) - Method in class org.apache.solr.search.grouping.distributed.requestfactory.SearchGroupsRequestFactory
 
constructRequest(ResponseBuilder) - Method in class org.apache.solr.search.grouping.distributed.requestfactory.StoredFieldsShardRequestFactory
 
constructRequest(ResponseBuilder) - Method in class org.apache.solr.search.grouping.distributed.requestfactory.TopGroupsShardRequestFactory
 
constructRequest(ResponseBuilder) - Method in interface org.apache.solr.search.grouping.distributed.ShardRequestFactory
Returns ShardRequest instances.
constructSpec(PluginInfo) - Static method in class org.apache.solr.api.ApiBag
 
consumeArgumentDelimiter() - Method in class org.apache.solr.search.FunctionQParser
Consume an argument delimiter (a comma) from the token stream.
CONTAINER - org.apache.solr.core.SolrInfoBean.Category
 
CONTAINER_IS_SHUTTING_DOWN - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
ContainerPluginsApi - Class in org.apache.solr.handler.admin
API to maintain container-level plugin configurations.
ContainerPluginsApi(CoreContainer, ClusterPluginsSource) - Constructor for class org.apache.solr.handler.admin.ContainerPluginsApi
 
ContainerPluginsApi.Edit - Class in org.apache.solr.handler.admin
API for editing the plugin configurations.
ContainerPluginsApi.Read - Class in org.apache.solr.handler.admin
API for reading the current plugin configurations.
ContainerPluginsRegistry - Class in org.apache.solr.api
This class manages the container-level plugins and their Api-s.
ContainerPluginsRegistry(CoreContainer, ApiBag, ClusterPluginsSource) - Constructor for class org.apache.solr.api.ContainerPluginsRegistry
 
ContainerPluginsRegistry.ApiInfo - Class in org.apache.solr.api
 
ContainerPluginsRegistry.Diff - Enum in org.apache.solr.api
 
ContainerPluginsRegistry.PluginRegistryListener - Interface in org.apache.solr.api
Listener for notifications about added / deleted / modified plugins.
containerProperties - Variable in class org.apache.solr.core.CoreContainer
 
containerRequestContext - Variable in class org.apache.solr.api.JerseyResource
 
ContainerRequestUtils - Class in org.apache.solr.jersey.container
Utility methods for creating and populating a ContainerRequest for use with Jersey ApplicationHandlers
contains(String) - Method in class org.apache.solr.cloud.DistributedMap
 
contains(String) - Method in class org.apache.solr.core.PluginBag
 
containsCore(String) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Returns whether the cache contains the named core.
containsCore(String) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
containsKey(Object) - Method in class org.apache.solr.util.MapListener
 
containsTaskWithRequestId(String, String) - Method in class org.apache.solr.cloud.OverseerTaskQueue
Returns true if the queue contains a task with the specified async id.
containsValue(Object) - Method in class org.apache.solr.util.MapListener
 
containsZero() - Method in class org.apache.solr.util.LongSet
 
CONTENT - Static variable in class org.apache.solr.response.RawResponseWriter
The key that should be used to add a ContentStream to the SolrQueryResponse if you intend to use this Writer.
CONTENT_TYPE - Static variable in class org.apache.solr.response.RawResponseWriter
 
CONTENT_TYPE_JSON_UTF8 - Static variable in class org.apache.solr.response.JSONResponseWriter
 
CONTENT_TYPE_TEXT_ASCII - Static variable in interface org.apache.solr.response.QueryResponseWriter
 
CONTENT_TYPE_TEXT_UTF8 - Static variable in interface org.apache.solr.response.QueryResponseWriter
 
CONTENT_TYPE_XML_UTF8 - Static variable in interface org.apache.solr.response.QueryResponseWriter
 
ContentStreamHandlerBase - Class in org.apache.solr.handler
Shares common code between various handlers that manipulate ContentStream objects.
ContentStreamHandlerBase() - Constructor for class org.apache.solr.handler.ContentStreamHandlerBase
 
ContentStreamLoader - Class in org.apache.solr.handler.loader
Load a ContentStream into Solr
ContentStreamLoader() - Constructor for class org.apache.solr.handler.loader.ContentStreamLoader
 
contentType - Variable in class org.apache.solr.handler.designer.SampleDocuments
 
context - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
context - Variable in class org.apache.solr.response.transform.DocTransformer
 
context - Variable in class org.apache.solr.search.DelegatingCollector
 
Context(int) - Constructor for class org.apache.solr.search.facet.FacetMerger.Context
 
CONTEXT_FIELD - Static variable in class org.apache.solr.spelling.suggest.DocumentDictionaryFactory
 
contextDestroyed(ServletContextEvent) - Method in class org.apache.solr.servlet.CoreContainerProvider
 
contextInitialized(ServletContextEvent) - Method in class org.apache.solr.servlet.CoreContainerProvider
 
CONTEXTS_FIELD_NAME - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
Clone of CONTEXTS_FIELD_NAME in AnalyzingInfixSuggester
contributeFromShard(int, ResponseBuilder, List<NamedList<Object>>) - Method in class org.apache.solr.handler.component.PivotFacetField
Recursively merges the contributions from the specified shard for each PivotFacetValue represended in the response.
convert(Object) - Method in class org.apache.solr.cluster.placement.impl.MetricImpl
 
convert(Object) - Method in interface org.apache.solr.cluster.placement.Metric
Convert raw value.
convert(String) - Method in class org.apache.solr.spelling.QueryConverter
Returns the Collection of Tokens for the query.
convert(String) - Method in class org.apache.solr.spelling.SpellingQueryConverter
Converts the original query string to a collection of Lucene Tokens.
convert(String) - Method in class org.apache.solr.spelling.SuggestQueryConverter
 
convertAmount(double, int, long, int) - Static method in class org.apache.solr.schema.CurrencyValue
Performs a currency conversion & unit conversion.
convertAmount(double, String, long, String) - Static method in class org.apache.solr.schema.CurrencyValue
Performs a currency conversion & unit conversion.
convertAmount(ExchangeRateProvider, String, long, String) - Static method in class org.apache.solr.schema.CurrencyValue
Performs a currency conversion & unit conversion.
convertDurationsTo(TimeUnit) - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
Convert durations to the given time unit.
convertDurationsTo(TimeUnit) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Convert durations to the given time unit.
converter - Variable in class org.apache.solr.cluster.placement.impl.MetricImpl
 
convertFromOrdinalsIntoToField(LongBitSet, SortedSetDocValues, LongBitSet, SortedSetDocValues) - Method in class org.apache.solr.search.TopLevelJoinQuery
 
convertHeapOptionStyleConfigStringToBytes(String) - Static method in class org.apache.solr.core.SolrConfig
Converts a Java heap option-like config string to bytes.
convertHighlights(NamedList<Object>) - Method in class org.apache.solr.handler.component.HighlightComponent
 
convertLuceneDocToSolrDoc(Document, IndexSchema) - Static method in class org.apache.solr.response.DocsStreamer
Deprecated.
use the 3 arg version for better performance
convertLuceneDocToSolrDoc(Document, IndexSchema, ReturnFields) - Static method in class org.apache.solr.response.DocsStreamer
Converts the specified Document into a SolrDocument.
convertMetric(String, Metric, Predicate<CharSequence>, boolean, boolean, boolean, boolean, String, BiConsumer<String, Object>) - Static method in class org.apache.solr.util.stats.MetricUtils
Convert a single instance of metric into a map or flattened object.
convertMetrics(MetricRegistry, Collection<String>) - Static method in class org.apache.solr.util.stats.MetricUtils
Convert selected metrics from a registry into a map, with metrics in a compact AND simple format.
convertMetrics(MetricRegistry, Collection<String>, boolean, boolean, boolean, boolean, BiConsumer<String, Object>) - Static method in class org.apache.solr.util.stats.MetricUtils
Convert selected metrics from a registry into maps (when compact==false) or flattened objects.
convertNamedListToMap(NamedList<?>) - Method in class org.apache.solr.rest.ManagedResource
Converts a NamedList<?> into an ordered Map for returning as JSON.
convertQueriesToList(ArrayList<Object>) - Static method in class org.apache.solr.core.QuerySenderListener
 
convertRatesTo(TimeUnit) - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
Convert rates to the given time unit.
convertRatesTo(TimeUnit) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Convert rates to the given time unit.
convertTimer(String, Timer, Predicate<CharSequence>, boolean, boolean, String, BiConsumer<String, Object>) - Static method in class org.apache.solr.util.stats.MetricUtils
Convert a Timer to a map.
convertTlogEntryToAddUpdateCommand(SolrQueryRequest, List<?>, int, long) - Static method in class org.apache.solr.update.UpdateLog
Given a entry from the transaction log containing a document, return a new AddUpdateCommand that can be applied to ADD the document or do an UPDATE_INPLACE.
convertTo(ExchangeRateProvider, String) - Method in class org.apache.solr.schema.CurrencyValue
Returns a new CurrencyValue that is the conversion of this CurrencyValue to the specified currency.
convertToListOfNamedLists() - Method in class org.apache.solr.handler.component.PivotFacetField
A recursive method for generating NamedLists from this field suitable for including in a pivot facet response to the original distributed request.
convertToNamedList() - Method in class org.apache.solr.handler.component.PivotFacetValue
A recursive method for generating a NamedList from this value suitable for including in a pivot facet response to the original distributed request.
convertToResponse(Map<String, StatsValues>) - Static method in class org.apache.solr.handler.component.StatsComponent
Given a map of StatsValues using the appropriate response key, builds up the necessary "stats" data structure for including in the response -- including the esoteric "stats_fields" wrapper.
convertV2CreateCollectionMapToV1ParamMap(Map<String, Object>) - Static method in class org.apache.solr.handler.admin.api.CreateCollection
Convert a map representing the v2 request body into v1-appropriate query-parameters.
CoordinateFieldType - Class in org.apache.solr.schema
A CoordinateFieldType is the base class for FieldTypes that have semantics related to items in a coordinate system.
CoordinateFieldType() - Constructor for class org.apache.solr.schema.CoordinateFieldType
 
COORDINATOR - org.apache.solr.core.NodeRoles.Role
 
CoordinatorHttpSolrCall - Class in org.apache.solr.servlet
A coordinator node can serve requests as if it hosts all collections in the cluster.
CoordinatorHttpSolrCall(CoordinatorHttpSolrCall.Factory, SolrDispatchFilter, CoreContainer, HttpServletRequest, HttpServletResponse, boolean) - Constructor for class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
CoordinatorHttpSolrCall.Factory - Class in org.apache.solr.servlet
 
CoordinatorV2HttpSolrCall - Class in org.apache.solr.api
 
CoordinatorV2HttpSolrCall(CoordinatorHttpSolrCall.Factory, SolrDispatchFilter, CoreContainer, HttpServletRequest, HttpServletResponse, boolean) - Constructor for class org.apache.solr.api.CoordinatorV2HttpSolrCall
 
copy() - Method in class org.apache.solr.cloud.ElectionContext
 
copy() - Method in class org.apache.solr.core.PluginInfo
 
copy() - Method in class org.apache.solr.handler.export.IntValue
 
copy() - Method in class org.apache.solr.handler.export.LongValue
 
copy() - Method in class org.apache.solr.pkg.PackageAPI.Packages
 
copy() - Method in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
COPY_FIELD - Static variable in class org.apache.solr.schema.IndexSchema
 
COPY_FIELDS - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
COPY_FIELDS - Static variable in class org.apache.solr.schema.IndexSchema
 
COPY_FROM_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
copyConfig(String, String) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
copyConfig(String, String) - Method in class org.apache.solr.core.ConfigSetService
Copy a config
copyConfig(String, String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
CopyField - Class in org.apache.solr.schema
CopyField contains all the information of a valid copy fields in an index.
CopyField(SchemaField, SchemaField) - Constructor for class org.apache.solr.schema.CopyField
 
CopyField(SchemaField, SchemaField, int) - Constructor for class org.apache.solr.schema.CopyField
 
copyFields - Variable in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListCopyFieldsResponse
 
copyFieldsMap - Variable in class org.apache.solr.schema.IndexSchema
 
copyFieldTargetCounts - Variable in class org.apache.solr.schema.IndexSchema
keys are all fields copied to, count is num of copyField directives that target them.
copyFile(File, File) - Static method in class org.apache.solr.util.FileUtils
 
copyFileFrom(Directory, String, URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
Copy a file from specified sourceDir to the destination repository (i.e.
copyFileTo(URI, String, Directory) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
Copy a file from specified sourceRepo to the destination directory (i.e.
copyIfNeeded(File, File) - Method in class org.apache.solr.cli.RunExampleTool
 
copyIndexFileFrom(Directory, String, URI, String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
Copy an index file from specified sourceDir to the destination repository (i.e.
copyIndexFileFrom(Directory, String, URI, String) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
copyIndexFileFrom(Directory, String, Directory, String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
 
copyIndexFileTo(URI, String, Directory, String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
Copy an index file from specified sourceRepo to the destination directory (i.e.
copyIndexFileTo(URI, String, Directory, String) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
copyNamedListIntoArrayByDocPosInResponse(NamedList<Object>, Map<Object, ShardDoc>, Map.Entry<String, Object>[]) - Static method in class org.apache.solr.util.SolrPluginUtils
Copies the given namedList assumed to have doc uniqueKey keyed data into destArr at the position of the document in the response.
copyOverBufferingUpdates(CommitUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
Block updates, append a commit at current tlog, then copy over buffer updates to new tlog and bring back ulog to active state.
copyOverOldUpdates(long) - Method in class org.apache.solr.update.UpdateLog
 
copyOverOldUpdates(long, TransactionLog) - Method in class org.apache.solr.update.UpdateLog
Copy over updates from prevTlog or last tlog (in tlog folder) to a new tlog
copyOverOldUpdatesMeter - Variable in class org.apache.solr.update.UpdateLog
 
copyPrefixedPropertiesWithoutPrefix(SolrParams, Map<String, String>, String) - Static method in class org.apache.solr.handler.admin.api.CreateCollection
 
copyTo(AttributeImpl) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.solr.handler.tagger.TaggingAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.solr.spelling.Token
Deprecated.
 
copyTo(FixedBitSet) - Method in class org.apache.solr.search.DocSetCollector.ExpandingIntArray
 
core - org.apache.solr.core.SolrInfoBean.Group
 
core - Variable in class org.apache.solr.metrics.SolrCoreReporter
 
core - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
core - Variable in class org.apache.solr.servlet.DirectSolrConnection
 
core - Variable in class org.apache.solr.servlet.HttpSolrCall
 
core - Variable in class org.apache.solr.spelling.suggest.Suggester
 
core - Variable in class org.apache.solr.update.UpdateHandler
 
CORE - org.apache.solr.core.SolrInfoBean.Category
 
CORE_COLLECTION - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_CONFIG - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_CONFIGSET - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_CONFIGSET_PROPERTIES - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_CONTAINER - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
CORE_DATADIR - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_DISCOVERY_COMPLETE - Static variable in class org.apache.solr.core.CoreContainer
 
CORE_EDIT_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
CORE_INFO_PARAM - Static variable in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
CORE_INFO_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
CORE_LOADONSTARTUP - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_NAME - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_NODE_NAME - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_PROPERTIES - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
CORE_ROLES - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_SCHEMA - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_SHARD - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_TRANSIENT - Static variable in class org.apache.solr.core.CoreDescriptor
 
CORE_ULOGDIR - Static variable in class org.apache.solr.core.CoreDescriptor
 
CoreAdminAPIBase - Class in org.apache.solr.handler.admin.api
A common parent for admin Core Jersey-based APIs.
CoreAdminAPIBase(CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CoreAdminAPIBase
 
CoreAdminAPIBase.CoreAdminAPIBaseException - Exception in org.apache.solr.handler.admin.api
Helper RuntimeException to allow passing checked exceptions to the caller of the handle method.
CoreAdminAPIBaseException(Exception) - Constructor for exception org.apache.solr.handler.admin.api.CoreAdminAPIBase.CoreAdminAPIBaseException
 
coreAdminAsyncTracker - Variable in class org.apache.solr.handler.admin.api.CoreAdminAPIBase
 
coreAdminAsyncTracker - Variable in class org.apache.solr.handler.admin.CoreAdminHandler
 
CoreAdminAsyncTracker() - Constructor for class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
coreAdminHandler - Variable in class org.apache.solr.core.CoreContainer
 
CoreAdminHandler - Class in org.apache.solr.handler.admin
 
CoreAdminHandler() - Constructor for class org.apache.solr.handler.admin.CoreAdminHandler
 
CoreAdminHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.CoreAdminHandler
Overloaded ctor to inject CoreContainer into the handler.
CoreAdminHandler.CallInfo - Class in org.apache.solr.handler.admin
 
CoreAdminHandler.CoreAdminAsyncTracker - Class in org.apache.solr.handler.admin
 
CoreAdminHandler.CoreAdminAsyncTracker.TaskObject - Class in org.apache.solr.handler.admin
Helper class to manage the tasks to be tracked.
CoreAdminHandler.CoreAdminOp - Interface in org.apache.solr.handler.admin
 
CoreAdminOperation - Enum in org.apache.solr.handler.admin
 
CoreAugmenterFactory - Class in org.apache.solr.response.transform
 
CoreAugmenterFactory() - Constructor for class org.apache.solr.response.transform.CoreAugmenterFactory
 
coreContainer - Variable in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
 
coreContainer - Variable in class org.apache.solr.core.DirectoryFactory
 
coreContainer - Variable in class org.apache.solr.handler.admin.api.AdminAPIBase
 
coreContainer - Variable in class org.apache.solr.handler.admin.api.CoreAdminAPIBase
 
coreContainer - Variable in class org.apache.solr.handler.admin.CollectionsHandler
 
coreContainer - Variable in class org.apache.solr.handler.admin.ConfigSetsHandler
 
coreContainer - Variable in class org.apache.solr.handler.admin.CoreAdminHandler
 
coreContainer - Variable in class org.apache.solr.handler.admin.InfoHandler
 
coreContainer - Variable in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
coreContainer - Variable in class org.apache.solr.metrics.SolrCoreContainerReporter
 
CoreContainer - Class in org.apache.solr.core
 
CoreContainer(Object) - Constructor for class org.apache.solr.core.CoreContainer
This method allows subclasses to construct a CoreContainer without any default init behavior.
CoreContainer(Path, Properties) - Constructor for class org.apache.solr.core.CoreContainer
Create a new CoreContainer using the given solr home directory.
CoreContainer(NodeConfig) - Constructor for class org.apache.solr.core.CoreContainer
Create a new CoreContainer using the given configuration.
CoreContainer(NodeConfig, boolean) - Constructor for class org.apache.solr.core.CoreContainer
 
CoreContainer(NodeConfig, CoresLocator) - Constructor for class org.apache.solr.core.CoreContainer
Create a new CoreContainer using the given configuration and locator.
CoreContainer(NodeConfig, CoresLocator, boolean) - Constructor for class org.apache.solr.core.CoreContainer
 
CoreContainer.CoreLoadFailure - Class in org.apache.solr.core
 
CoreContainerApp() - Constructor for class org.apache.solr.jersey.JerseyApplications.CoreContainerApp
 
CoreContainerProvider - Class in org.apache.solr.servlet
A service that can provide access to solr cores.
CoreContainerProvider() - Constructor for class org.apache.solr.servlet.CoreContainerProvider
 
CoreDescriptor - Class in org.apache.solr.core
Metadata about a SolrCore.
CoreDescriptor(String, Path, Map<String, String>, Properties, ZkController) - Constructor for class org.apache.solr.core.CoreDescriptor
Create a new CoreDescriptor.
CoreDescriptor(String, Path, CoreContainer, String...) - Constructor for class org.apache.solr.core.CoreDescriptor
TESTS ONLY
CoreDescriptor(String, CoreDescriptor) - Constructor for class org.apache.solr.core.CoreDescriptor
Create a new CoreDescriptor using the properties of an existing one
coreInitFailures - Variable in class org.apache.solr.core.CoreContainer
 
CoreIsClosedException() - Constructor for exception org.apache.solr.update.SolrCoreState.CoreIsClosedException
 
CoreIsClosedException(String) - Constructor for exception org.apache.solr.update.SolrCoreState.CoreIsClosedException
 
CoreLoadFailure(CoreDescriptor, Exception) - Constructor for class org.apache.solr.core.CoreContainer.CoreLoadFailure
 
coreName - Variable in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
 
coreName - Variable in class org.apache.solr.cloud.api.collections.AddReplicaCmd.CreateReplica
 
coreNodeName - Variable in class org.apache.solr.cloud.api.collections.AddReplicaCmd.CreateReplica
 
coreProperties - Variable in class org.apache.solr.core.CoreDescriptor
The properties for this core, as available through getProperty()
CorePropertiesLocator - Class in org.apache.solr.core
Persists CoreDescriptors as properties files
CorePropertiesLocator(Path) - Constructor for class org.apache.solr.core.CorePropertiesLocator
 
CorePropertiesLocator(NodeConfig) - Constructor for class org.apache.solr.core.CorePropertiesLocator
 
coreProvider - Variable in class org.apache.solr.core.SolrCore
 
CoreReplicationAPI - Class in org.apache.solr.handler.admin.api
V2 APIs for inspecting and replicating indices
CoreReplicationAPI(SolrCore, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CoreReplicationAPI
 
CoreReplicationAPI.FileListResponse - Class in org.apache.solr.handler.admin.api
CoreReplicationAPI.FileMetaData - Class in org.apache.solr.handler.admin.api
Contained in CoreReplicationAPI.FileListResponse, this holds metadata from a file for an index
CoreReplicationAPI.IndexVersionResponse - Class in org.apache.solr.handler.admin.api
cores - Variable in class org.apache.solr.handler.admin.SecurityConfHandler
 
cores - Variable in class org.apache.solr.servlet.HttpSolrCall
 
cores - Variable in class org.apache.solr.update.SplitIndexCommand
 
coresLocator - Variable in class org.apache.solr.core.CoreContainer
 
CoresLocator - Interface in org.apache.solr.core
Manage the discovery and persistence of core definitions across Solr restarts
CoreSnapshot - Class in org.apache.solr.handler.admin.api
V2 API for Creating, Listing, and Deleting Core Snapshots.
CoreSnapshot(SolrQueryRequest, SolrQueryResponse, CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker) - Constructor for class org.apache.solr.handler.admin.api.CoreSnapshot
 
CoreSnapshotMetaData(String, String, long, String, boolean, Collection<String>) - Constructor for class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
CoreSnapshotMetaData(NamedList<?>) - Constructor for class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
CoreSnapshotResponse() - Constructor for class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
CoreSorter - Class in org.apache.solr.core
This is a utility class that sorts cores in such a way as to minimize other cores waiting for replicas in the current node.
CoreSorter(CoreContainer) - Constructor for class org.apache.solr.core.CoreSorter
 
coreUrl - Variable in class org.apache.solr.servlet.HttpSolrCall
 
correctEndOffsetForCloseElement(int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
Correct endOffset for adjacent element at the right side.
corrections - Variable in class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
 
correctPair(int, int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
Corrects the start and end offset pair.
cost() - Method in class org.apache.solr.search.facet.FieldUtil.OrdValues
 
cost() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
count - org.apache.solr.handler.component.StatsField.Stat
 
count - Variable in class org.apache.solr.handler.component.FacetComponent.QueryFacet
 
count - Variable in class org.apache.solr.handler.component.FacetComponent.ShardFacetCount
 
count - Variable in class org.apache.solr.spelling.SpellingOptions
The number of suggestions to return, if there are any.
COUNT - org.apache.solr.util.PivotListEntry
 
COUNT_DESC - Static variable in class org.apache.solr.search.facet.FacetRequest.FacetSort
Commonly Re-used "count desc" (default)
CountAgg - Class in org.apache.solr.search.facet
 
CountAgg() - Constructor for class org.apache.solr.search.facet.CountAgg
 
countDistinct - org.apache.solr.handler.component.StatsField.Stat
 
countDocSetDelays - Static variable in class org.apache.solr.util.TestInjection
 
counted - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
counter(String, String...) - Method in class org.apache.solr.metrics.SolrDelegateRegistryMetricsContext
 
counter(String, String...) - Method in class org.apache.solr.metrics.SolrMetricsContext
counter(SolrMetricsContext, String, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Create or get an existing named Counter
counterSupplier(SolrResourceLoader, PluginInfo) - Static method in class org.apache.solr.metrics.MetricSuppliers
Create a Counter supplier.
CountFieldValuesUpdateProcessorFactory - Class in org.apache.solr.update.processor
Replaces any list of values for a field matching the specified conditions with the count of the number of values for that field.
CountFieldValuesUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.CountFieldValuesUpdateProcessorFactory
 
countIndexFiles(int, double) - Method in class org.apache.solr.core.backup.BackupProperties
 
CountPair(K, V) - Constructor for class org.apache.solr.request.SimpleFacets.CountPair
 
counts - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
countSorted - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
CountValsAgg - Class in org.apache.solr.search.facet
AggValueSource to count values for given ValueSource
CountValsAgg(ValueSource) - Constructor for class org.apache.solr.search.facet.CountValsAgg
 
CPUCircuitBreaker - Class in org.apache.solr.util.circuitbreaker
Tracks current CPU usage and triggers if the specified threshold is breached.
CPUCircuitBreaker() - Constructor for class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
 
CPUCircuitBreaker(CoreContainer) - Constructor for class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
 
CPUCircuitBreaker(SolrCore) - Constructor for class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
Deprecated.
CrawlFile(String, Path) - Constructor for class org.apache.solr.handler.CatStream.CrawlFile
 
create() - Static method in class org.apache.solr.logging.MDCSnapshot
 
create() - Method in interface org.apache.solr.search.grouping.Command
Returns a list of Collector instances to be included in the search based on the .
create() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand
 
create() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand
 
create() - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand
 
create(String, String, String, String, Map<String, String>) - Static method in class org.apache.solr.core.backup.BackupProperties
 
create(String, Path, Map<String, String>, boolean) - Method in class org.apache.solr.core.CoreContainer
Creates a new core in a specified instance directory, publishing the core state to the cluster
create(String, Map<String, String>) - Method in class org.apache.solr.core.CoreContainer
Creates a new core, publishing the core state to the cluster
create(String, LockFactory, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.ByteBuffersDirectoryFactory
 
create(String, LockFactory, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.DirectoryFactory
Creates a new Directory for a given path.
create(String, LockFactory, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.MMapDirectoryFactory
 
create(String, LockFactory, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.NIOFSDirectoryFactory
 
create(String, LockFactory, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.NRTCachingDirectoryFactory
 
create(String, LockFactory, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.RAMDirectoryFactory
 
create(String, LockFactory, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.StandardDirectoryFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.ChildDocTransformerFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.CoreAugmenterFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.DocIdAugmenterFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.ElevatedMarkerFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.ExcludedMarkerFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.ExplainAugmenterFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.GeoTransformerFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.RawValueTransformerFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.ShardAugmenterFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.SubQueryAugmenterFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.TransformerFactory
 
create(String, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.response.transform.ValueAugmenterFactory
 
create(String, SolrParams, SolrQueryRequest, Map<String, String>, Set<String>) - Method in class org.apache.solr.response.transform.GeoTransformerFactory
 
create(String, SolrParams, SolrQueryRequest, Map<String, String>, Set<String>) - Method in class org.apache.solr.response.transform.RawValueTransformerFactory
 
create(String, SolrParams, SolrQueryRequest, Map<String, String>, Set<String>) - Method in interface org.apache.solr.response.transform.TransformerFactory.FieldRenamer
Analogous to TransformerFactory.create(String, SolrParams, SolrQueryRequest), but to be implemented by TransformerFactorys that produce DocTransformers that may rename fields.
create(String, SolrConfig, ConfigSetService) - Method in class org.apache.solr.schema.IndexSchemaFactory
Returns an index schema created from a local resource.
create(String, SolrConfig, ConfigSetService) - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
First, try to locate the managed schema file named in the managedSchemaResourceName param.
create(TokenStream) - Method in class org.apache.solr.analysis.ReversedWildcardFilterFactory
 
create(TokenStream) - Method in class org.apache.solr.rest.schema.analysis.ManagedStopFilterFactory
Returns a StopFilter based on our managed stop word set.
create(TokenStream) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
 
create(TokenStream) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
 
create(AttributeFactory) - Method in class org.apache.solr.analysis.LowerCaseTokenizerFactory
Deprecated.
 
create(ContainerPluginsRegistry) - Method in class org.apache.solr.cluster.events.impl.ClusterEventProducerFactory
Create a ClusterEventProducer based on the current plugin configurations.
create(PayloadObj<CreateConfigPayload>) - Method in class org.apache.solr.handler.configsets.CreateConfigSetAPI
 
create(SolrClassLoader, String, String, ConfigNode) - Method in class org.apache.solr.schema.FieldTypePluginLoader
 
create(SolrClassLoader, String, String, ConfigNode) - Method in class org.apache.solr.util.plugin.AbstractPluginLoader
Create a plugin from an XML configuration.
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.fst.BlendedInfixLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.fst.FreeTextLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.fst.FSTLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.fst.WFSTLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookupFactory
 
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.LookupFactory
Create a Lookup using config options in params and current core
create(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.tst.TSTLookupFactory
 
create(BackupRepository, SolrCore, URI, String) - Static method in class org.apache.solr.handler.RestoreCore
 
create(CoreContainer, CoreDescriptor...) - Method in class org.apache.solr.core.CorePropertiesLocator
 
create(CoreContainer, CoreDescriptor...) - Method in interface org.apache.solr.core.CoresLocator
Make new cores available for discovery
create(CoreContainer, CoreDescriptor, RecoveryStrategy.RecoveryListener) - Method in class org.apache.solr.cloud.RecoveryStrategy.Builder
 
create(NodeConfig) - Static method in class org.apache.solr.security.AllowListUrlChecker
Creates a URL checker based on the NodeConfig property to configure the allowed URLs.
create(SolrCore, String, String, DirectoryFactory, boolean, IndexSchema, SolrIndexConfig, IndexDeletionPolicy, Codec) - Static method in class org.apache.solr.update.SolrIndexWriter
 
create(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.DictionaryFactory
Create a Dictionary using options in core and optionally uses searcher , in case of index based dictionaries
create(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.DocumentDictionaryFactory
 
create(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
 
create(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.FileDictionaryFactory
 
create(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.HighFrequencyDictionaryFactory
 
CREATE - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
CREATE_COLLECTION_OPTIONS - Static variable in class org.apache.solr.cli.SolrCLI
 
CREATE_COLLECTION_PREFIX - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
CREATE_NODE_SET - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
CREATE_NODE_SET_EMPTY - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
CREATE_NODE_SET_SHUFFLE - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
CREATE_NODE_SET_SHUFFLE_DEFAULT - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
CREATE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
CREATE_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
createAccs(long, int) - Method in class org.apache.solr.search.facet.FacetProcessor
 
createAlias(CreateAliasAPI.CreateAliasRequestBody) - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI
 
CREATEALIAS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
CreateAliasAPI - Class in org.apache.solr.handler.admin.api
V2 API for creating an alias
CreateAliasAPI(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CreateAliasAPI
 
CreateAliasAPI.CategoryRoutedAliasProperties - Class in org.apache.solr.handler.admin.api
 
CreateAliasAPI.CreateAliasRequestBody - Class in org.apache.solr.handler.admin.api
 
CreateAliasAPI.RoutedAliasProperties - Class in org.apache.solr.handler.admin.api
 
CreateAliasAPI.TimeRoutedAliasProperties - Class in org.apache.solr.handler.admin.api
 
CreateAliasCmd - Class in org.apache.solr.cloud.api.collections
 
CreateAliasCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CreateAliasCmd
 
CreateAliasRequestBody() - Constructor for class org.apache.solr.handler.admin.api.CreateAliasAPI.CreateAliasRequestBody
 
createAllGroupCollector() - Method in class org.apache.solr.search.Grouping.Command
Returns a collector that is able to return the most relevant document of all groups.
createAllGroupCollector() - Method in class org.apache.solr.search.Grouping.CommandField
 
createAllGroupCollector() - Method in class org.apache.solr.search.Grouping.CommandFunc
 
createAnalyzerElement(Document, String, Map<String, ?>) - Static method in class org.apache.solr.rest.schema.FieldTypeXmlAdapter
 
createAnalyzerTStream(SchemaField, String) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
 
createAndLoad(Path) - Static method in class org.apache.solr.core.CoreContainer
 
createAndLoad(Path, Path) - Static method in class org.apache.solr.core.CoreContainer
Create a new CoreContainer and load its cores
createAssignStrategy(CoreContainer) - Static method in class org.apache.solr.cloud.api.collections.Assign
Creates the appropriate instance of Assign.AssignStrategy based on how the cluster and/or individual collections are configured.
createBackup(String, CreateCoreBackupRequestBody) - Method in class org.apache.solr.handler.admin.api.CreateCoreBackup
 
createBackup(SnapshotBackupAPI.BackupReplicationRequestBody) - Method in class org.apache.solr.handler.admin.api.SnapshotBackupAPI
This API (POST /api/cores/coreName/replication/backups {...}) is analogous to the v1 /solr/coreName/replication?command=backup
createBackupRepository(String) - Method in class org.apache.solr.handler.admin.api.BackupAPIBase
 
createBalancePlan(BalanceRequest, Map<Replica, Node>) - Method in interface org.apache.solr.cluster.placement.BalancePlanFactory
Creates a BalancePlan for balancing replicas across the given nodes.
createBalancePlan(BalanceRequest, Map<Replica, Node>) - Method in class org.apache.solr.cluster.placement.impl.BalancePlanFactoryImpl
 
createBaseNode(ConfigSetService, boolean, boolean, String) - Method in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
createBJQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.join.BlockJoinChildQParserPlugin
 
createBJQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.join.BlockJoinParentQParserPlugin
 
createBuilder() - Method in class org.apache.solr.search.join.FiltersQParser
 
createCloudExampleCollection(int, Scanner, boolean, String) - Method in class org.apache.solr.cli.RunExampleTool
 
createClusterZkNodes(SolrZkClient) - Static method in class org.apache.solr.cloud.ZkController
Create the zknodes necessary for a cluster to operate
createCollection(CreateCollectionRequestBody) - Method in class org.apache.solr.handler.admin.api.CreateCollection
 
createCollection(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
CreateCollection - Class in org.apache.solr.handler.admin.api
V2 API for creating a SolrCLoud collection
CreateCollection(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CreateCollection
 
createCollectionBackup(String, String, CreateCollectionBackupRequestBody) - Method in class org.apache.solr.handler.admin.api.CreateCollectionBackup
 
CreateCollectionBackup - Class in org.apache.solr.handler.admin.api
V2 API for creating a new "backup" of a specified collection
CreateCollectionBackup(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CreateCollectionBackup
 
CreateCollectionCmd - Class in org.apache.solr.cloud.api.collections
 
CreateCollectionCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CreateCollectionCmd
 
createCollectionLevelSnapshot(SolrZkClient, String, CollectionSnapshotMetaData) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method creates an entry for the named snapshot for the specified collection in Zookeeper.
createCollectionParams - Variable in class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
createCollectionsIfRequired(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
Create any required collections and return the name of the collection to which the current document should be sent.
createCollectionSnapshot(String, String, CreateCollectionSnapshotRequestBody) - Method in class org.apache.solr.handler.admin.api.CreateCollectionSnapshot
This API is analogous to V1's (POST /solr/admin/collections?action=CREATESNAPSHOT)
CreateCollectionSnapshot - Class in org.apache.solr.handler.admin.api
V2 API implementation for creating a collection-level snapshot.
CreateCollectionSnapshot(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CreateCollectionSnapshot
 
CreateCollectionTool - Class in org.apache.solr.cli
Supports create_collection command in the bin/solr script.
CreateCollectionTool() - Constructor for class org.apache.solr.cli.CreateCollectionTool
 
CreateCollectionTool(PrintStream) - Constructor for class org.apache.solr.cli.CreateCollectionTool
 
createCollectionZkNode(DistribStateManager, String, Map<String, String>, ConfigSetService) - Static method in class org.apache.solr.cloud.api.collections.CreateCollectionCmd
 
createComponents(String) - Method in class org.apache.solr.analysis.TokenizerChain
 
createComponents(String) - Method in class org.apache.solr.schema.FieldType.DefaultAnalyzer
 
createConfigSet(ZkNodeProps, CoreContainer) - Static method in class org.apache.solr.cloud.ConfigSetCmds
 
CreateConfigSetAPI - Class in org.apache.solr.handler.configsets
V2 API for creating a new configset as a copy of an existing one.
CreateConfigSetAPI(CoreContainer) - Constructor for class org.apache.solr.handler.configsets.CreateConfigSetAPI
 
createConfigSetApiLock(String, String) - Method in class org.apache.solr.cloud.ConfigSetApiLockFactory
For the CollectionParams.LockLevel of the passed action, obtains the required locks (if any) and returns.
createConfigSetService(CoreContainer) - Static method in class org.apache.solr.core.ConfigSetService
 
createConfiguration(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Creates an instance of ExtendedDismaxConfiguration.
createContainerRequest(HttpServletRequest, HttpServletResponse, Configuration) - Static method in class org.apache.solr.jersey.container.ContainerRequestUtils
Creates a ContainerRequest
createCore(PayloadObj<CreateCorePayload>) - Method in class org.apache.solr.handler.admin.api.CreateCoreAPI
 
CreateCoreAPI - Class in org.apache.solr.handler.admin.api
V2 API for creating a new core on the receiving node.
CreateCoreAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.CreateCoreAPI
 
CreateCoreBackup - Class in org.apache.solr.handler.admin.api
 
CreateCoreBackup(CoreContainer, SolrQueryRequest, SolrQueryResponse, CoreAdminHandler.CoreAdminAsyncTracker) - Constructor for class org.apache.solr.handler.admin.api.CreateCoreBackup
 
createCoreContainer(Path, Properties) - Method in class org.apache.solr.servlet.CoreContainerProvider
CoreContainer initialization
createCoreResourceLoader(CoreDescriptor) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
createCoreResourceLoader(CoreDescriptor) - Method in class org.apache.solr.core.ConfigSetService
Create a SolrResourceLoader for a core
createCoreResourceLoader(CoreDescriptor) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
CreateCoreTool - Class in org.apache.solr.cli
 
CreateCoreTool() - Constructor for class org.apache.solr.cli.CreateCoreTool
 
CreateCoreTool(PrintStream) - Constructor for class org.apache.solr.cli.CreateCoreTool
 
CREATED - org.apache.solr.search.SolrCache.State
:TODO
createDefaultLoaders(NamedList<?>) - Method in class org.apache.solr.handler.UpdateRequestHandler
 
createDeleteCollectionRequest(DocCollection) - Static method in class org.apache.solr.cluster.placement.impl.ModificationRequestImpl
 
createDeleteReplicasRequest(SolrCollection, Set<Replica>) - Static method in class org.apache.solr.cluster.placement.impl.ModificationRequestImpl
Create a delete replicas request.
createDeleteReplicasRequest(DocCollection, String, Set<Replica>) - Static method in class org.apache.solr.cluster.placement.impl.ModificationRequestImpl
Create a delete replicas request using the internal Solr API.
createDeleteShardsRequest(SolrCollection, Set<String>) - Static method in class org.apache.solr.cluster.placement.impl.ModificationRequestImpl
 
createDeleteShardsRequest(DocCollection, Set<String>) - Static method in class org.apache.solr.cluster.placement.impl.ModificationRequestImpl
 
createDirectories(Path) - Static method in class org.apache.solr.util.FileUtils
 
createDirectory(URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method creates a directory at the specified path.
createDirectory(URI) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
createDirectoryURI(String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns the directory URI representation for the specified path.
createDistributedStats(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
createDocSet(SolrIndexSearcher) - Method in class org.apache.solr.query.SolrRangeQuery
 
createDocSet(SolrIndexSearcher) - Method in interface org.apache.solr.search.DocSetProducer
 
createDocSet(SolrIndexSearcher, Term) - Static method in class org.apache.solr.search.DocSetUtil
 
createDocSet(SolrIndexSearcher, Query, DocSet) - Static method in class org.apache.solr.search.DocSetUtil
 
createDocSetGeneric(SolrIndexSearcher, Query) - Static method in class org.apache.solr.search.DocSetUtil
 
createDomainQuery(FacetContext) - Method in class org.apache.solr.search.facet.FacetRequest.Domain.GraphField
Creates a Query that can be used to recompute the new "base" for this domain, relative to the current base of the FacetContext.
createDomainQuery(FacetContext) - Method in class org.apache.solr.search.facet.FacetRequest.Domain.JoinField
Creates a Query that can be used to recompute the new "base" for this domain, relative to the current base of the FacetContext.
createEdismaxQueryParser(QParser, String) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Creates an instance of ExtendedSolrQueryParser, the query parser that's going to be used to parse the query.
createElevationProvider(Map<QueryElevationComponent.ElevatingQuery, QueryElevationComponent.ElevationBuilder>) - Method in class org.apache.solr.handler.component.QueryElevationComponent
Creates the QueryElevationComponent.ElevationProvider to set during configuration loading.
createEventListener(PluginInfo) - Method in class org.apache.solr.core.SolrCore
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.AggValueSource
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.AvgAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.CountAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.CountValsAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.FacetField
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.FacetHeatmap
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.FacetQuery
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.FacetRange
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.FacetRequest
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.HLLAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.MinMaxAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.MissingAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.PercentileAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.RelatednessAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.StddevAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.SumAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.SumsqAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.UniqueAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.UniqueBlockAgg
 
createFacetMerger(Object) - Method in class org.apache.solr.search.facet.VarianceAgg
 
createFacetProcessor(FacetContext) - Method in class org.apache.solr.search.facet.FacetField
 
createFacetProcessor(FacetContext) - Method in class org.apache.solr.search.facet.FacetHeatmap
 
createFacetProcessor(FacetContext) - Method in class org.apache.solr.search.facet.FacetQuery
 
createFacetProcessor(FacetContext) - Method in class org.apache.solr.search.facet.FacetRange
 
createFacetProcessor(FacetContext) - Method in class org.apache.solr.search.facet.FacetRequest
 
createField(Object) - Method in class org.apache.solr.schema.SchemaField
 
createField(String, String, IndexableFieldType) - Method in class org.apache.solr.schema.FieldType
Create the field from native Lucene parts.
createField(String, String, IndexableFieldType) - Method in class org.apache.solr.schema.RankField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.BinaryField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.DatePointField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.DenseVectorField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.DoublePointField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.EnumFieldType
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.FieldType
Used for adding a document when a field needs to be created from a type and a string.
createField(SchemaField, Object) - Method in class org.apache.solr.schema.FloatPointField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.IntPointField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.LongPointField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.PointType
It never makes sense to create a single field, so make it impossible to happen by throwing UnsupportedOperationException
createField(SchemaField, Object) - Method in class org.apache.solr.schema.PreAnalyzedField
 
createField(SchemaField, Object) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
createFieldNameSelector(SolrResourceLoader, SolrCore, FieldMutatingUpdateProcessorFactory.SelectorParams, FieldMutatingUpdateProcessor.FieldNameSelector) - Static method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
Utility method that can be used to define a FieldNameSelector using the same types of rules as the FieldMutatingUpdateProcessor init code.
createFieldNameSelector(SolrResourceLoader, IndexSchema, FieldMutatingUpdateProcessorFactory.SelectorParams, FieldMutatingUpdateProcessor.FieldNameSelector) - Static method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
Utility method that can be used to define a FieldNameSelector using the same types of rules as the FieldMutatingUpdateProcessor init code.
createFields(Object) - Method in class org.apache.solr.schema.SchemaField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.BoolField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.CollationField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.CurrencyFieldType
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.DateRangeField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.DenseVectorField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.EnumFieldType
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.FieldType
Given a SchemaField, create one or more IndexableField instances
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.PointField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.PointType
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.SortableTextField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.StrField
 
createFields(SchemaField, Object) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
createFieldType(SchemaField) - Static method in class org.apache.solr.schema.PreAnalyzedField
Utility method to create a FieldType based on the SchemaField
createFirstPassCollector() - Method in class org.apache.solr.search.Grouping.Command
Returns one or more Collector instances that are needed to perform the first pass search.
createFirstPassCollector() - Method in class org.apache.solr.search.Grouping.CommandField
 
createFirstPassCollector() - Method in class org.apache.solr.search.Grouping.CommandFunc
 
createFirstPassCollector() - Method in class org.apache.solr.search.Grouping.CommandQuery
 
createFromListOfNamedLists(int, ResponseBuilder, PivotFacetValue, List<NamedList<Object>>) - Static method in class org.apache.solr.handler.component.PivotFacetField
A recursive method to construct a new PivotFacetField object from the contents of the NamedLists provided by the specified shard, relative to a parent value (if this is not the top field in the pivot hierarchy)
createFromNamedList(int, ResponseBuilder, PivotFacetField, NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetValue
A recursive method to construct a new PivotFacetValue object from the contents of the NamedList provided by the specified shard, relative to the specified field.
createFromSolrParams(String, SolrParams, String) - Static method in class org.apache.solr.handler.admin.api.CreateAliasAPI
 
createFromSolrParams(SolrParams) - Static method in class org.apache.solr.handler.admin.api.CreateAliasAPI
 
createFromSolrParams(SolrParams, String) - Static method in class org.apache.solr.handler.admin.api.CreateAliasAPI.CategoryRoutedAliasProperties
 
createFromSolrParams(SolrParams, String) - Static method in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
createGraphField(FacetRequest.Domain, Map<String, Object>) - Static method in class org.apache.solr.search.facet.FacetRequest.Domain.GraphField
Given a Domain, and a (JSON) map specifying the configuration for that Domain, validates if a 'graph' is specified, and if so creates a GraphField and sets it on the Domain.
createHandler(String, String, Class<T>) - Method in class org.apache.solr.core.CoreContainer
 
createHolder(PluginInfo, SolrCore, Class<T>, String) - Static method in class org.apache.solr.pkg.PackagePluginHolder
 
createHolder(T, Class<T>) - Static method in class org.apache.solr.pkg.PackagePluginHolder
 
createIdQuery(String, String) - Method in class org.apache.solr.search.mlt.SimpleMLTQParser
 
createIncrementalBackupFolders() - Method in class org.apache.solr.core.backup.BackupFilePaths
Create all locations required to store an incremental backup.
createIndexableFields(Shape) - Method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
createIndexableFields(Shape) - Method in class org.apache.solr.schema.LatLonPointSpatialField.LatLonPointSpatialStrategy
 
createIndexSchema(CoreDescriptor, SolrConfig, boolean) - Method in class org.apache.solr.core.ConfigSetService
Create an IndexSchema object for a core.
createInfo(Map<String, Object>, List<String>) - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
createInitInstance(PluginInfo, Class<T>, String, String) - Method in class org.apache.solr.core.SolrCore
 
createInstance(String, Class<T>, String, SolrCore, ResourceLoader) - Static method in class org.apache.solr.core.SolrCore
Creates an instance by trying a constructor that accepts a SolrCore before trying the default (no arg) constructor.
createInstance(SolrDispatchFilter, String, CoreContainer, HttpServletRequest, HttpServletResponse, boolean) - Method in class org.apache.solr.servlet.CoordinatorHttpSolrCall.Factory
 
createInstance(SolrDispatchFilter, String, CoreContainer, HttpServletRequest, HttpServletResponse, boolean) - Method in interface org.apache.solr.servlet.SolrDispatchFilter.HttpSolrCallFactory
 
createJoinField(FacetRequest.Domain, Map<String, Object>) - Static method in class org.apache.solr.search.facet.FacetRequest.Domain.JoinField
Given a Domain, and a (JSON) map specifying the configuration for that Domain, validates if a 'join' is specified, and if so creates a JoinField and sets it on the Domain.
createJoinQuery(Query, String, String, String) - Static method in class org.apache.solr.search.JoinQParserPlugin
A helper method for other plugins to create (non-scoring) JoinQueries wrapped around arbitrary queries against the same core.
createJoinQuery(Query, String, String, ScoreMode) - Static method in class org.apache.solr.search.join.ScoreJoinQParserPlugin
A helper method for other plugins to create single-core JoinQueries
createLeaderRegistryName(boolean, String, String) - Static method in class org.apache.solr.metrics.SolrCoreMetricManager
 
createLoader(SolrParams) - Static method in class org.apache.solr.handler.loader.CborLoader
 
createLock(boolean, String) - Method in interface org.apache.solr.cloud.DistributedConfigSetLockFactory
Create a new lock of the specified type (read or write) entering the "competition" for actually getting the lock for the configSetName
createLock(boolean, String) - Method in class org.apache.solr.cloud.ZkDistributedConfigSetLockFactory
 
createLock(boolean, CollectionParams.LockLevel, String, String, String) - Method in interface org.apache.solr.cloud.DistributedCollectionLockFactory
Create a new lock of the specified type (read or write) entering the "competition" for actually getting the lock at the given level for the given path i.e.
createLock(boolean, CollectionParams.LockLevel, String, String, String) - Method in class org.apache.solr.cloud.ZkDistributedCollectionLockFactory
 
createLockFactory(String) - Method in class org.apache.solr.core.ByteBuffersDirectoryFactory
 
createLockFactory(String) - Method in class org.apache.solr.core.DirectoryFactory
Creates a new LockFactory for a given path.
createLockFactory(String) - Method in class org.apache.solr.core.RAMDirectoryFactory
 
createLockFactory(String) - Method in class org.apache.solr.core.StandardDirectoryFactory
 
createMainQuery(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
createManagedResource(RestManager.ManagedResourceRegistration) - Method in class org.apache.solr.rest.RestManager
Creates a ManagedResource using registration information.
createName(String, String, String) - Method in class org.apache.solr.metrics.reporters.jmx.JmxObjectNameFactory
Create a hierarchical name.
createName(Properties, Path) - Static method in class org.apache.solr.core.CorePropertiesLocator
 
createNewAsyncJobTracker(String) - Method in class org.apache.solr.cloud.DistributedApiAsyncTracker
After a successful call to this method, caller MUST eventually call DistributedApiAsyncTracker.setTaskCompleted(java.lang.String, org.apache.solr.cloud.OverseerSolrResponse) or DistributedApiAsyncTracker.cancelAsyncId(java.lang.String) otherwise the task will forever be considered as in progress.
createNext(List<Object>) - Method in class org.apache.solr.search.CursorMark
Generates an new CursorMark bound for use with the same SortSpec as the current CursorMark but using the new SortValues.
createObjectMapper() - Static method in class org.apache.solr.util.SolrJacksonAnnotationInspector
 
createOrUpdateAliasProperty(String, String, UpdateAliasPropertyRequestBody) - Method in class org.apache.solr.handler.admin.api.AliasProperty
 
createOrUpdateCollectionProperty(String, String, UpdateCollectionPropertyRequestBody) - Method in class org.apache.solr.handler.admin.api.CollectionProperty
 
createOutput(URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns a OutputStream instance for the specified path
createOutput(URI) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
createParamSet(Map, Long) - Static method in class org.apache.solr.core.RequestParams
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.BoolQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.BoostQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.CollapsingQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.ComplexPhraseQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.DisMaxQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.ExportQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.ExtendedDismaxQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.FieldQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.FunctionQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.FunctionRangeQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.GraphTermsQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.HashQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.IGainTermsQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.join.BlockJoinParentQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.join.FiltersQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.join.GraphQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.join.HashRangeQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.join.ScoreJoinQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.JoinQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.LuceneQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.MaxScoreQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.MinHashQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.mlt.MLTContentQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.mlt.MLTQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.NestedQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.neural.KnnQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.PayloadCheckQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.PayloadScoreQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.PrefixQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.QParserPlugin
return a QParser
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.RankQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.RawQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.ReRankQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.SignificantTermsQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.SimpleQParserPlugin
Returns a QParser that will create a query by using Lucene's SimpleQueryParser.
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.SpatialBoxQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.SpatialFilterQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.SurroundQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.SwitchQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.TermQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.TermsQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.TextLogisticRegressionQParserPlugin
 
createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.XmlQParserPlugin
 
createPlacementPlan(PlacementRequest, Set<ReplicaPlacement>) - Method in class org.apache.solr.cluster.placement.impl.PlacementPlanFactoryImpl
 
createPlacementPlan(PlacementRequest, Set<ReplicaPlacement>) - Method in interface org.apache.solr.cluster.placement.PlacementPlanFactory
Creates a PlacementPlan for adding replicas to a given shard(s) of an existing collection.
createPlugin(PluginInfo) - Method in class org.apache.solr.core.PluginBag
 
createPluginInstance() - Method in class org.apache.solr.cluster.placement.impl.DelegatingPlacementPluginFactory
 
createPluginInstance() - Method in interface org.apache.solr.cluster.placement.PlacementPluginFactory
Returns an instance of the plugin that will be repeatedly (and concurrently) called to compute placement.
createPluginInstance() - Method in class org.apache.solr.cluster.placement.plugins.AffinityPlacementFactory
 
createPluginInstance() - Method in class org.apache.solr.cluster.placement.plugins.MinimizeCoresPlacementFactory
 
createPluginInstance() - Method in class org.apache.solr.cluster.placement.plugins.RandomPlacementFactory
 
createPluginInstance() - Method in class org.apache.solr.cluster.placement.plugins.SimplePlacementFactory
 
createProcessor(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain
Uses the factories in this chain to creates a new UpdateRequestProcessor instance specific for this request.
createProcessor(SolrQueryRequest, SolrQueryResponse, boolean, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain
 
createQuery(Query, Query, String) - Method in class org.apache.solr.search.join.BlockJoinChildQParser
 
createQuery(Query, Query, String) - Method in class org.apache.solr.search.join.BlockJoinParentQParser
 
createQueryCommand() - Method in class org.apache.solr.handler.component.ResponseBuilder
Creates a SolrIndexSearcher.QueryCommand from this ResponseBuilder.
createRegistryName(boolean, String, String, String, String) - Static method in class org.apache.solr.metrics.SolrCoreMetricManager
 
createRegistryName(SolrCore, String) - Static method in class org.apache.solr.metrics.SolrCoreMetricManager
This method is used by CoreContainer.rename(String, String).
createRemoteMessage(String, boolean, String, String) - Static method in class org.apache.solr.handler.admin.api.CreateCollectionSnapshot
 
createRemoteMessage(String, boolean, String, String) - Static method in class org.apache.solr.handler.admin.api.DeleteCollectionSnapshot
 
createRemoteMessage(String, Boolean, String) - Static method in class org.apache.solr.handler.admin.api.DeleteCollection
 
createRemoteMessage(String, String) - Static method in class org.apache.solr.handler.admin.api.DeleteAlias
 
createRemoteMessage(String, String, Boolean, Boolean, Boolean, Boolean, String) - Static method in class org.apache.solr.handler.admin.api.DeleteShard
 
createRemoteMessage(String, String, Integer, Boolean, String, String, String) - Static method in class org.apache.solr.handler.admin.api.DeleteCollectionBackup
 
createRemoteMessage(String, String, String, Integer, Boolean, Boolean, Boolean, Boolean, Boolean, String) - Static method in class org.apache.solr.handler.admin.api.DeleteReplica
 
createRemoteMessage(String, String, String, String) - Static method in class org.apache.solr.handler.admin.api.DeleteReplicaProperty
 
createRemoteMessage(String, String, String, String, AddReplicaPropertyRequestBody) - Method in class org.apache.solr.handler.admin.api.AddReplicaProperty
 
createRemoteMessage(String, String, CreateCollectionBackupRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateCollectionBackup
 
createRemoteMessage(String, String, CreateReplicaRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateReplica
 
createRemoteMessage(String, String, InstallShardDataRequestBody) - Static method in class org.apache.solr.handler.admin.api.InstallShardData
 
createRemoteMessage(String, Map<String, Object>, String) - Method in class org.apache.solr.handler.admin.api.AliasProperty
 
createRemoteMessage(String, BalanceShardUniqueRequestBody) - Static method in class org.apache.solr.handler.admin.api.BalanceShardUnique
 
createRemoteMessage(String, CreateShardRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateShard
 
createRemoteMessage(String, DeleteNodeRequestBody) - Static method in class org.apache.solr.handler.admin.api.DeleteNode
 
createRemoteMessage(String, ReloadCollectionRequestBody) - Static method in class org.apache.solr.handler.admin.api.ReloadCollectionAPI
 
createRemoteMessage(String, RenameCollectionRequestBody) - Static method in class org.apache.solr.handler.admin.api.RenameCollection
 
createRemoteMessage(String, ReplaceNodeRequestBody) - Method in class org.apache.solr.handler.admin.api.ReplaceNode
 
createRemoteMessage(String, RestoreCollectionAPI.RestoreCollectionRequestBody) - Static method in class org.apache.solr.handler.admin.api.RestoreCollectionAPI
 
createRemoteMessage(BalanceReplicasRequestBody) - Method in class org.apache.solr.handler.admin.api.BalanceReplicas
 
createRemoteMessage(CreateCollectionRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateCollection
 
createRemoteMessage(MigrateReplicasRequestBody) - Method in class org.apache.solr.handler.admin.api.MigrateReplicas
 
createRemoteMessageForRoutedAlias(CreateAliasAPI.CreateAliasRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateAliasAPI
 
createRemoteMessageForTraditionalAlias(CreateAliasAPI.CreateAliasRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateAliasAPI
 
createReplica(String, String, CreateReplicaRequestBody) - Method in class org.apache.solr.handler.admin.api.CreateReplica
 
CreateReplica - Class in org.apache.solr.handler.admin.api
V2 API implementation for adding a new replica to an existing shard.
CreateReplica(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CreateReplica
 
createReplicaPlacement(SolrCollection, String, Node, Replica.ReplicaType) - Method in class org.apache.solr.cluster.placement.impl.PlacementPlanFactoryImpl
 
createReplicaPlacement(SolrCollection, String, Node, Replica.ReplicaType) - Method in interface org.apache.solr.cluster.placement.PlacementPlanFactory
Creates a ReplicaPlacement to be passed to PlacementPlan factory methods.
createRequestBodyFromV1Params(String[]) - Static method in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelChange
 
createRequestBodyFromV1Params(SolrParams) - Static method in class org.apache.solr.handler.admin.api.CreateCollectionBackup
 
createRequestBodyFromV1Params(SolrParams) - Static method in class org.apache.solr.handler.admin.api.CreateReplica
 
createRequestBodyFromV1Params(SolrParams) - Static method in class org.apache.solr.handler.admin.api.CreateShard
 
createRequestBodyFromV1Params(SolrParams, boolean) - Static method in class org.apache.solr.handler.admin.api.CreateCollection
 
createResponseWriter() - Method in class org.apache.solr.jersey.MessageBodyWriters.BaseMessageBodyWriter
 
createResponseWriter() - Method in class org.apache.solr.jersey.MessageBodyWriters.CsvMessageBodyWriter
 
createResponseWriter() - Method in class org.apache.solr.jersey.MessageBodyWriters.JavabinMessageBodyWriter
 
createResponseWriter() - Method in class org.apache.solr.jersey.MessageBodyWriters.RawMessageBodyWriter
 
createResponseWriter() - Method in class org.apache.solr.jersey.MessageBodyWriters.XmlMessageBodyWriter
 
createRetrieveDocs(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
createScaleRequestBodyFromV1Params(SolrParams) - Static method in class org.apache.solr.handler.admin.api.DeleteReplica
 
createSchema(Method) - Static method in class org.apache.solr.api.AnnotatedApi
 
createSchemaWatcher() - Method in class org.apache.solr.schema.ZkIndexSchemaReader
Creates a schema watcher and returns it for controlling purposes.
createSecondPassCollector() - Method in class org.apache.solr.search.Grouping.Command
Returns zero or more Collector instances that are needed to perform the second pass search.
createSecondPassCollector() - Method in class org.apache.solr.search.Grouping.CommandField
 
createSecondPassCollector() - Method in class org.apache.solr.search.Grouping.CommandFunc
 
createShard(String, CreateShardRequestBody) - Method in class org.apache.solr.handler.admin.api.CreateShard
 
createShard(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.CollectionMutator
 
CreateShard - Class in org.apache.solr.handler.admin.api
V2 API for creating a new shard in a collection.
CreateShard(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.CreateShard
 
CREATESHARD_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
CreateShardCmd - Class in org.apache.solr.cloud.api.collections
 
CreateShardCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CreateShardCmd
 
createSimpleResponse() - Method in class org.apache.solr.search.Grouping.Command
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.AggValueSource
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.AvgAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.CountAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.CountValsAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.HLLAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.MinMaxAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.MissingAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.PercentileAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.RelatednessAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.StddevAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.SumAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.SumsqAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.UniqueAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.UniqueBlockAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.UniqueBlockFieldAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.UniqueBlockQueryAgg
 
createSlotAcc(FacetContext, long, int) - Method in class org.apache.solr.search.facet.VarianceAgg
 
createSnapAsync(int, Consumer<NamedList<?>>) - Method in class org.apache.solr.handler.SnapShooter
 
createSnapshot() - Method in class org.apache.solr.handler.SnapShooter
 
createSnapshot(String, String, String) - Method in class org.apache.solr.handler.admin.api.CoreSnapshot
This API is analogous to V1 (POST /solr/admin/cores?action=CREATESNAPSHOT)
createSnapshot(IndexCommit) - Method in class org.apache.solr.handler.SnapShooter
Handles the logic of creating a snapshot
CREATESNAPSHOT_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
CREATESNAPSHOT_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
CreateSnapshotCmd - Class in org.apache.solr.cloud.api.collections
This class implements the functionality of creating a collection level snapshot.
CreateSnapshotCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CreateSnapshotCmd
 
createsObjectNamesWith(ObjectNameFactory) - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
 
createSolrConfig(CoreDescriptor, SolrResourceLoader, boolean) - Method in class org.apache.solr.core.ConfigSetService
Create a SolrConfig object for a core
createSpanQuery(String, String, Analyzer) - Static method in class org.apache.solr.util.PayloadUtils
 
createSpanQuery(String, String, Analyzer, String) - Static method in class org.apache.solr.util.PayloadUtils
The generated SpanQuery will be either a SpanTermQuery or an ordered, zero slop SpanNearQuery, depending on how many tokens are emitted.
createSpatialQuery(QParser, SpatialOptions) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
Implemented for compatibility with geofilt & bbox query parsers: SpatialQueryable.
createSpatialQuery(QParser, SpatialOptions) - Method in class org.apache.solr.schema.PointType
Calculates the range and creates a RangeQuery (bounding box) wrapped in a BooleanQuery (unless the dimension is 1, one range for every dimension, AND'd together by a Boolean
createSpatialQuery(QParser, SpatialOptions) - Method in interface org.apache.solr.schema.SpatialQueryable
 
createStateChangeRecorder(String, boolean) - Method in class org.apache.solr.cloud.DistributedClusterStateUpdater
Create a new instance of DistributedClusterStateUpdater.StateChangeRecorder for a given collection and a given intention (collection creation vs.
createStatsCache() - Method in class org.apache.solr.core.SolrCore
Create an instance of StatsCache using configured parameters.
createStatsValues(StatsField) - Static method in class org.apache.solr.handler.component.StatsValuesFactory
Creates an instance of StatsValues which supports values from the specified StatsField
createStorage(ManagedResourceStorage.StorageIO, SolrResourceLoader) - Method in class org.apache.solr.rest.ManagedResource
Potential extension point allowing concrete implementations to supply their own storage implementation.
createSubRequests(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
createSuffixCache(int) - Method in class org.apache.solr.schema.AbstractSubTypeFieldType
 
createSystemIdFromResourceName(String) - Static method in class org.apache.solr.util.SystemIdResolver
 
createTombstoneDocument(IndexSchema, String, String[], String[], NamedList<Object>) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessor
Creates a tombstone document, that will be used to update a document that's being deleted by ID.
CreateTool - Class in org.apache.solr.cli
 
CreateTool() - Constructor for class org.apache.solr.cli.CreateTool
 
CreateTool(PrintStream) - Constructor for class org.apache.solr.cli.CreateTool
 
createURI(String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns the URI representation for the specified path.
createURI(String) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
createUsers(PayloadObj<Map<String, String>>) - Method in class org.apache.solr.handler.admin.api.ModifyBasicAuthConfigAPI
 
createUsers(PayloadObj<Map<String, String>>) - Method in class org.apache.solr.handler.admin.api.ModifyMultiPluginAuthConfigAPI
 
createWeight(Map<Object, Object>, IndexSearcher) - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
createWeight(Map<Object, Object>, IndexSearcher) - Method in class org.apache.solr.search.function.distance.HaversineConstFunction
 
createWeight(Map<Object, Object>, IndexSearcher) - Method in class org.apache.solr.search.function.distance.HaversineFunction
 
createWeight(Map<Object, Object>, IndexSearcher) - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
createWeight(Map<Object, Object>, IndexSearcher) - Method in class org.apache.solr.search.function.DualDoubleFunction
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.query.FilterQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.query.SolrRangeQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.AbstractReRankQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.FunctionRangeQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.join.GraphQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.join.HashRangeQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.MatchCostQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.TopLevelJoinQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.solr.search.WrappedQuery
 
createWithMetaFile(BackupRepository, SolrCore, URI, ShardBackupId) - Static method in class org.apache.solr.handler.RestoreCore
 
createZkStateDir() - Method in class org.apache.solr.core.backup.BackupManager
 
CREATION_DATE - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
CreationPlaceholder() - Constructor for class org.apache.solr.uninverting.FieldCache.CreationPlaceholder
 
credentialProviders - Variable in class org.apache.solr.util.configuration.SSLConfigurations
 
crossCheckReplicaStateWithLiveNodes(List<String>, NamedList<Object>) - Method in class org.apache.solr.handler.admin.ClusterStatus
Walks the tree of collection status to verify that any replicas not reporting a "down" status is on a live node, if any replicas reporting their status as "active" but the node is not live is marked as "down"; used by CLUSTERSTATUS.
CrossCollectionJoinQParser - Class in org.apache.solr.search.join
 
CrossCollectionJoinQParser(String, SolrParams, SolrParams, SolrQueryRequest, String, Set<String>) - Constructor for class org.apache.solr.search.join.CrossCollectionJoinQParser
 
CrossCollectionJoinQuery - Class in org.apache.solr.search.join
 
CrossCollectionJoinQuery(String, String, String, String, String, String, boolean, int, SolrParams) - Constructor for class org.apache.solr.search.join.CrossCollectionJoinQuery
 
CryptoKeys - Class in org.apache.solr.util
A utility class with helpers for various signature and certificate tasks
CryptoKeys(Map<String, byte[]>) - Constructor for class org.apache.solr.util.CryptoKeys
 
CryptoKeys.RSAKeyPair - Class in org.apache.solr.util
 
CSV_MULTI_VALUE_DELIM_PARAM - Static variable in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
CSV_PATH - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
CSVLoader - Class in org.apache.solr.handler.loader
 
CSVLoader() - Constructor for class org.apache.solr.handler.loader.CSVLoader
 
CSVLoaderBase - Class in org.apache.solr.handler.loader
 
CSVLoaderBase(SolrQueryRequest, UpdateRequestProcessor) - Constructor for class org.apache.solr.handler.loader.CSVLoaderBase
 
CsvMessageBodyWriter() - Constructor for class org.apache.solr.jersey.MessageBodyWriters.CsvMessageBodyWriter
 
CSVParser - Class in org.apache.solr.internal.csv
Parses CSV files according to the specified configuration.
CSVParser(Reader) - Constructor for class org.apache.solr.internal.csv.CSVParser
CSV parser using the default CSVStrategy.
CSVParser(Reader, CSVStrategy) - Constructor for class org.apache.solr.internal.csv.CSVParser
Customized CSV parser using the given CSVStrategy
CSVPrinter - Class in org.apache.solr.internal.csv
Print values as a comma separated list.
CSVPrinter(Writer, CSVStrategy) - Constructor for class org.apache.solr.internal.csv.CSVPrinter
Create a printer that will print values to the given stream following the CSVStrategy.
CSVResponseWriter - Class in org.apache.solr.response
Response writer for csv data
CSVResponseWriter() - Constructor for class org.apache.solr.response.CSVResponseWriter
 
CSVStrategy - Class in org.apache.solr.internal.csv
CSVStrategy
CSVStrategy(char, char, char) - Constructor for class org.apache.solr.internal.csv.CSVStrategy
 
CSVStrategy(char, char, char, char, boolean, boolean, boolean, boolean, String) - Constructor for class org.apache.solr.internal.csv.CSVStrategy
Customized CSV strategy setter.
CSVUtils - Class in org.apache.solr.internal.csv
Utility methods for dealing with CSV files
CSVUtils() - Constructor for class org.apache.solr.internal.csv.CSVUtils
CSVUtils instances should NOT be constructed in standard programming.
ctime - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
ctx - Variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
Ctx() - Constructor for class org.apache.solr.pkg.PackageListeners.Listener.Ctx
 
curChar - Variable in class org.apache.solr.parser.QueryParserTokenManager
 
CurrencyField - Class in org.apache.solr.schema
Deprecated.
CurrencyField() - Constructor for class org.apache.solr.schema.CurrencyField
Deprecated.
 
CurrencyFieldType - Class in org.apache.solr.schema
Field type for support of monetary values.
CurrencyFieldType() - Constructor for class org.apache.solr.schema.CurrencyFieldType
 
CurrencyValue - Class in org.apache.solr.schema
Represents a Currency field value, which includes a long amount and ISO currency code.
CurrencyValue(long, String) - Constructor for class org.apache.solr.schema.CurrencyValue
Constructs a new currency value.
current() - Static method in class org.apache.solr.util.configuration.SSLConfigurationsFactory
Creates if necessary and returns singleton object of Configurations.
CURRENT_VERSION - Static variable in class org.apache.solr.response.XMLWriter
 
currentCapacity - Variable in class org.apache.solr.util.LongPriorityQueue
 
currentDocBase - Variable in class org.apache.solr.search.facet.SlotAcc
 
currentIndex() - Method in class org.apache.solr.response.DocsStreamer
 
currentPos() - Method in class org.apache.solr.update.TransactionLog.LogReader
 
currentReaderContext - Variable in class org.apache.solr.search.facet.SlotAcc
 
currentSize() - Method in class org.apache.solr.update.TransactionLog.LogReader
 
currentToken - Variable in exception org.apache.solr.parser.ParseException
This is the last token that has been consumed successfully.
currentUser() - Static method in class org.apache.solr.cli.AssertTool
 
currentValue - Variable in class org.apache.solr.handler.export.IntValue
 
currentValue - Variable in class org.apache.solr.handler.export.LongValue
 
CursorMark - Class in org.apache.solr.search
An object that encapsulates the basic information about the current Mark Point of a "Cursor" based request.
CursorMark(IndexSchema, SortSpec) - Constructor for class org.apache.solr.search.CursorMark
Generates an empty CursorMark bound for use with the specified schema and SortSpec.
customParams - Variable in class org.apache.solr.spelling.SpellingOptions
Any other custom params can be passed through.
cversion - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
CYAN - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
czxid - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 

D

DaemonCollectionStream(Collection<DaemonStream>) - Constructor for class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
DaemonResponseStream(String) - Constructor for class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
data - Variable in class org.apache.solr.schema.IndexSchemaFactory.VersionedConfig
 
DATA - org.apache.solr.core.NodeRoles.Role
 
DataConfigNode - Class in org.apache.solr.util
ConfigNode impl that copies and maintains data internally from DOM
DataConfigNode(ConfigNode) - Constructor for class org.apache.solr.util.DataConfigNode
 
dataDir - Variable in class org.apache.solr.core.SolrConfig
 
dataDir - Variable in class org.apache.solr.update.UpdateLog
 
dataHomePath - Variable in class org.apache.solr.core.DirectoryFactory
 
dataLength - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
dataProvider - Variable in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
date - Variable in class org.apache.solr.packagemanager.SolrPackage.SolrPackageRelease
 
DATE - org.apache.solr.schema.NumberType
 
DATE_FMT - Static variable in class org.apache.solr.handler.SnapShooter
 
dateFacets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
DateMathParser - Class in org.apache.solr.util
A Simple Utility class for parsing "math" like strings relating to Dates.
DateMathParser() - Constructor for class org.apache.solr.util.DateMathParser
Chooses defaults based on the current request.
DateMathParser(Date, TimeZone) - Constructor for class org.apache.solr.util.DateMathParser
 
DateMathParser(TimeZone) - Constructor for class org.apache.solr.util.DateMathParser
 
DatePointField - Class in org.apache.solr.schema
FieldType that can represent any Date/Time with millisecond precision.
DatePointField() - Constructor for class org.apache.solr.schema.DatePointField
 
DateRangeField - Class in org.apache.solr.schema
A field for indexed dates and date ranges.
DateRangeField() - Constructor for class org.apache.solr.schema.DateRangeField
 
DateValueFieldType - Interface in org.apache.solr.schema
Marker interface for Date-valued field types.
DBQ() - Constructor for class org.apache.solr.update.UpdateLog.DBQ
 
DebugComponent - Class in org.apache.solr.handler.component
Adds debugging information to a request.
DebugComponent() - Constructor for class org.apache.solr.handler.component.DebugComponent
 
debugQuery - Variable in class org.apache.solr.search.ReRankScaler
 
dec() - Method in class org.apache.solr.metrics.DelegateRegistryCounter
 
dec(long) - Method in class org.apache.solr.metrics.DelegateRegistryCounter
 
decLevel() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
decLevel() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
decLevel() - Method in class org.apache.solr.response.TextResponseWriter
 
decode(InputStream) - Method in interface org.apache.solr.core.BlobRepository.Decoder
A routine that knows how to convert the stream of bytes from the blob into a Java object.
decode(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
decodeDocValueToString(long) - Static method in class org.apache.solr.schema.LatLonPointSpatialField
Decodes the docValues number into latitude and longitude components, formatting as "lat,lon".
decoder - Variable in class org.apache.solr.search.FloatPayloadValueSource
 
decodeRefinementValuePath(String) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
Decodes a value path string specified for refinement.
decorateDocValueFields(SolrDocumentBase<?, ?>, int, Set<String>, DocValuesIteratorCache) - Method in class org.apache.solr.search.SolrDocumentFetcher
This will fetch and add the docValues fields to a given SolrDocument/SolrInputDocument
decref() - Method in class org.apache.solr.update.TransactionLog
 
decref() - Method in class org.apache.solr.util.RefCounted
 
decrefSolrCoreState(SolrCoreState.IndexWriterCloser) - Method in class org.apache.solr.update.SolrCoreState
 
decrementActiveRequests(HttpServletRequest) - Method in class org.apache.solr.servlet.RateLimitManager
 
decrementBlobRefCount(BlobRepository.BlobContentRef<?>) - Method in class org.apache.solr.core.BlobRepository
This is to decrement a ref count
decryptRSA(byte[], PublicKey) - Static method in class org.apache.solr.util.CryptoKeys
 
DEFAULT - org.apache.solr.core.DirectoryFactory.DirContext
 
DEFAULT - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
 
DEFAULT - Static variable in interface org.apache.solr.parser.QueryParserConstants
Lexical state.
DEFAULT - Static variable in class org.apache.solr.servlet.SolrRequestParsers
Default instance for e.g.
DEFAULT - Static variable in interface org.apache.solr.uninverting.FieldCache
Expert: The cache used internally by sorting and range query classes.
DEFAULT - Static variable in class org.apache.solr.update.UpdateShardHandlerConfig
 
DEFAULT_ACCURACY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.solr.handler.export.ExportWriter
 
DEFAULT_CLOUD_REPORTER_PERIOD - Static variable in class org.apache.solr.metrics.SolrMetricManager
 
DEFAULT_COLLECTION_OP_TIMEOUT - Static variable in class org.apache.solr.handler.admin.CollectionsHandler
 
DEFAULT_CONCURRENT_REQUESTS - Static variable in class org.apache.solr.servlet.RateLimitManager
 
DEFAULT_CONF_FILE - Static variable in class org.apache.solr.core.SolrConfig
 
DEFAULT_CONFIG_SET - Static variable in class org.apache.solr.cli.SolrCLI
 
DEFAULT_CONFIGSET_NAME - Static variable in class org.apache.solr.handler.admin.ConfigSetsHandler
 
DEFAULT_CONTENT_TYPE - Static variable in class org.apache.solr.cli.SimplePostTool
Deprecated.
 
DEFAULT_CORE_LOAD_THREADS - Static variable in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
DEFAULT_CORE_LOAD_THREADS_IN_CLOUD - Static variable in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
DEFAULT_COUNT - Static variable in class org.apache.solr.handler.admin.LukeRequestHandler
 
DEFAULT_CREDENTIAL_KEY_MAP - Static variable in class org.apache.solr.util.configuration.providers.AbstractSSLCredentialProvider
 
DEFAULT_DEFAULT_CURRENCY - Static variable in class org.apache.solr.schema.CurrencyFieldType
 
DEFAULT_DICT_NAME - Static variable in class org.apache.solr.spelling.suggest.SolrSuggester
Name used when an unnamed suggester config is passed
DEFAULT_DICTIONARY_NAME - Static variable in class org.apache.solr.spelling.SolrSpellChecker
 
DEFAULT_DIMENSION - Static variable in class org.apache.solr.schema.CoordinateFieldType
2 dimensional by default
DEFAULT_DIST_ERR_PCT - Static variable in class org.apache.solr.schema.RptWithGeometrySpatialField
 
DEFAULT_DIST_ERR_PCT - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
DEFAULT_EXTERNAL_PROPERTIES_FILE - Static variable in class org.apache.solr.core.CoreDescriptor
 
DEFAULT_FACET_LIMIT - Static variable in class org.apache.solr.search.facet.FacetField
 
DEFAULT_FIELD_VALUES_ARRAY_LEN - Static variable in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
DEFAULT_FIELDTYPE - Static variable in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
pointValues, docValues, and nothing else.
DEFAULT_FILE_BASED_DICT - Static variable in class org.apache.solr.spelling.suggest.DictionaryFactory
Default dictionary implementation to use for FileBasedDictionaries
DEFAULT_FILE_BASED_DICT - Static variable in class org.apache.solr.spelling.suggest.LookupFactory
Default lookup implementation to use for SolrSuggester
DEFAULT_FILE_TYPES - Static variable in class org.apache.solr.cli.SimplePostTool
Deprecated.
 
DEFAULT_FILENAME - Static variable in class org.apache.solr.core.ConfigSetProperties
 
DEFAULT_HIDDEN_SYS_PROPS - Static variable in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
DEFAULT_INDEX_BASED_DICT - Static variable in class org.apache.solr.spelling.suggest.DictionaryFactory
Default dictionary implementation to use for IndexBasedDictionaries
DEFAULT_INDEX_INTERVAL_BITS - Static variable in class org.apache.solr.uninverting.DocTermOrds
Every 128th term is indexed, by default.
DEFAULT_IS_RECORDING - Static variable in class org.apache.solr.util.tracing.TraceUtils
 
DEFAULT_KNN_ALGORITHM - Static variable in class org.apache.solr.schema.DenseVectorField
 
DEFAULT_MANAGED_SCHEMA_RESOURCE_NAME - Static variable in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
DEFAULT_MATH_TZ - Static variable in class org.apache.solr.util.DateMathParser
Default TimeZone for DateMath rounding (UTC)
DEFAULT_MAX_CACHED_MB - Static variable in class org.apache.solr.core.NRTCachingDirectoryFactory
 
DEFAULT_MAX_CHARS - Static variable in class org.apache.solr.highlight.SolrHighlighter
 
DEFAULT_MAX_CHARS_FOR_DOC_VALUES - Static variable in class org.apache.solr.schema.SortableTextField
 
DEFAULT_MAX_IDLE_TIME - Static variable in class org.apache.solr.search.stats.LRUStatsCache
 
DEFAULT_MAX_MERGE_SIZE_MB - Static variable in class org.apache.solr.core.NRTCachingDirectoryFactory
 
DEFAULT_MAX_SIZE - Static variable in class org.apache.solr.search.stats.LRUStatsCache
 
DEFAULT_MAX_WORD_LEN - Static variable in class org.apache.solr.analysis.LowerCaseTokenizer
Deprecated.
 
DEFAULT_MAXEDITS - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_MAXINSPECTIONS - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_MAXQUERYFREQUENCY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_MAXQUERYLENGTH - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_MAXRECOVERYTHREADS - Static variable in class org.apache.solr.update.UpdateShardHandlerConfig
 
DEFAULT_MERGE_SCHEDULER_CLASSNAME - Static variable in class org.apache.solr.update.SolrIndexConfig
 
DEFAULT_METRICNAMESTRATEGY - Static variable in class org.apache.solr.update.UpdateShardHandlerConfig
 
DEFAULT_MINIMAL_FREE_DISK_GB - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
 
DEFAULT_MINPREFIX - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_MINQUERYLENGTH - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_ONLY_MORE_POPULAR - Static variable in class org.apache.solr.handler.component.SpellCheckComponent
 
DEFAULT_OPERATOR - Static variable in class org.apache.solr.search.PayloadScoreQParserPlugin
 
DEFAULT_PHRASE_LIMIT - Static variable in class org.apache.solr.highlight.SolrHighlighter
 
DEFAULT_POST_TAGS - Static variable in class org.apache.solr.highlight.SolrFragmentsBuilder
 
DEFAULT_PRE_TAGS - Static variable in class org.apache.solr.highlight.SolrFragmentsBuilder
 
DEFAULT_PRECISION_STEP - Static variable in class org.apache.solr.schema.CurrencyField
Deprecated.
 
DEFAULT_PRECISION_STEP - Static variable in class org.apache.solr.schema.EnumField
Deprecated.
 
DEFAULT_PRECISION_STEP - Static variable in class org.apache.solr.schema.TrieField
Deprecated.
 
DEFAULT_PRINTER_NEWLINE - Static variable in class org.apache.solr.internal.csv.CSVStrategy
 
DEFAULT_PRIORITIZED_FREE_DISK_GB - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
 
DEFAULT_PROVIDER_CHAIN - Static variable in class org.apache.solr.util.configuration.SSLCredentialProviderFactory
 
DEFAULT_QTYPE - Static variable in class org.apache.solr.search.QParserPlugin
internal use - name of the default parser
DEFAULT_QUEUE_SIZE - Static variable in class org.apache.solr.handler.export.ExportWriter
 
DEFAULT_RATE_PROVIDER_CLASS - Static variable in class org.apache.solr.schema.CurrencyFieldType
 
DEFAULT_REFRESH_INTERVAL - Static variable in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
DEFAULT_RESPONSE_WRITERS - Static variable in class org.apache.solr.core.SolrCore
 
DEFAULT_ROLES_STRING - Static variable in class org.apache.solr.core.NodeRoles
Roles to be assumed on nodes that don't have roles specified for them at startup
DEFAULT_SAMPLING_PERCENT - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
DEFAULT_SAMPLING_THRESHOLD - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
DEFAULT_SCHEMA_FILE - Static variable in class org.apache.solr.schema.IndexSchema
 
DEFAULT_SECURITY_CONTEXT - Static variable in class org.apache.solr.jersey.container.ContainerRequestUtils
 
DEFAULT_SHARDHANDLER_INFO - Static variable in class org.apache.solr.handler.component.ShardHandlerFactory
 
DEFAULT_SLOT_ACQUISITION_TIMEOUT_MS - Static variable in class org.apache.solr.servlet.RateLimitManager
 
DEFAULT_SPLIT_ON_WHITESPACE - Static variable in class org.apache.solr.parser.QueryParser
default split on whitespace behavior
DEFAULT_STATS - Static variable in class org.apache.solr.handler.component.StatsField
The set of stats computed by default when no localparams are used to specify explicit stats
DEFAULT_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.SSLConfigurations
 
DEFAULT_STRATEGY - Static variable in class org.apache.solr.internal.csv.CSVStrategy
 
DEFAULT_SUGGESTION_COUNT - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
DEFAULT_TAGGABLE - Static variable in interface org.apache.solr.handler.tagger.TaggingAttribute
By default this Attribute will be initialised with true.
DEFAULT_THRESHOLD_TOKEN_FREQUENCY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
DEFAULT_TIMEOUT - Static variable in class org.apache.solr.cloud.CloudUtil
 
DEFAULT_TRANSIENT_CACHE_SIZE - Static variable in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
DEFAULT_VALUE - Static variable in class org.apache.solr.schema.AbstractEnumField.EnumMapping
 
DEFAULT_WAIT_FOR_SEC - Static variable in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
DEFAULT_WAIT_TIMEOUT_SEC - Static variable in class org.apache.solr.core.ClusterSingletons
 
defaultClient - Variable in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
DefaultClusterEventProducer - Class in org.apache.solr.cluster.events.impl
Implementation of ClusterEventProducer.
DefaultClusterEventProducer(CoreContainer) - Constructor for class org.apache.solr.cluster.events.impl.DefaultClusterEventProducer
 
DefaultCounterSupplier() - Constructor for class org.apache.solr.metrics.MetricSuppliers.DefaultCounterSupplier
 
DefaultElevationProvider(QueryElevationComponent.TrieSubsetMatcher.Builder<String, QueryElevationComponent.Elevation>, Map<QueryElevationComponent.ElevatingQuery, QueryElevationComponent.ElevationBuilder>) - Constructor for class org.apache.solr.handler.component.QueryElevationComponent.DefaultElevationProvider
 
DefaultEncoder - Class in org.apache.solr.highlight
Use the DefaultEncoder
DefaultEncoder() - Constructor for class org.apache.solr.highlight.DefaultEncoder
 
defaultFactories - Static variable in class org.apache.solr.response.transform.TransformerFactory
 
DefaultHistogramSupplier(SolrResourceLoader) - Constructor for class org.apache.solr.metrics.MetricSuppliers.DefaultHistogramSupplier
 
DefaultMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for the default MergePolicy.
DefaultMergePolicyFactory() - Constructor for class org.apache.solr.index.DefaultMergePolicyFactory
 
DefaultMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.DefaultMergePolicyFactory
 
DefaultMeterSupplier() - Constructor for class org.apache.solr.metrics.MetricSuppliers.DefaultMeterSupplier
 
DefaultPackageRepository - Class in org.apache.solr.packagemanager
This is a serializable bean (for the JSON that is stored in /repository.json) representing a repository of Solr packages.
DefaultPackageRepository() - Constructor for class org.apache.solr.packagemanager.DefaultPackageRepository
 
DefaultPackageRepository(String, String) - Constructor for class org.apache.solr.packagemanager.DefaultPackageRepository
 
defaultPattern - Variable in class org.apache.solr.highlight.RegexFragmenter
 
defaultPatternRaw - Variable in class org.apache.solr.highlight.RegexFragmenter
 
defaults - Variable in class org.apache.solr.core.InitParams
 
defaults - Variable in class org.apache.solr.handler.RequestHandlerBase
 
defaults - Variable in class org.apache.solr.highlight.HighlightingPluginBase
 
DEFAULTS - Static variable in class org.apache.solr.core.PluginInfo
 
DefaultSampleDocumentsLoader - Class in org.apache.solr.handler.designer
 
DefaultSampleDocumentsLoader() - Constructor for class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
DefaultSchemaSuggester - Class in org.apache.solr.handler.designer
 
DefaultSchemaSuggester() - Constructor for class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
DefaultSolrCoreState - Class in org.apache.solr.update
 
DefaultSolrCoreState(DirectoryFactory) - Constructor for class org.apache.solr.update.DefaultSolrCoreState
Deprecated.
DefaultSolrCoreState(DirectoryFactory, RecoveryStrategy.Builder) - Constructor for class org.apache.solr.update.DefaultSolrCoreState
 
DefaultSolrHighlighter - Class in org.apache.solr.highlight
 
DefaultSolrHighlighter(SolrCore) - Constructor for class org.apache.solr.highlight.DefaultSolrHighlighter
 
DefaultSolrHighlighter.FvhContainer - Class in org.apache.solr.highlight
 
defaultStyle - Variable in class org.apache.solr.response.transform.ExplainAugmenterFactory
 
defaultSyncLevel - Variable in class org.apache.solr.update.UpdateLog
 
DefaultTimerSupplier(SolrResourceLoader) - Constructor for class org.apache.solr.metrics.MetricSuppliers.DefaultTimerSupplier
 
defaultUserArgs - Variable in class org.apache.solr.response.transform.TransformerFactory
 
defaultValue - Variable in class org.apache.solr.response.transform.ValueAugmenterFactory
 
defaultValue - Variable in class org.apache.solr.update.processor.DefaultValueUpdateProcessorFactory
 
defaultValueSource - Variable in class org.apache.solr.search.FloatPayloadValueSource
 
DefaultValueUpdateProcessorFactory - Class in org.apache.solr.update.processor
An update processor that adds a constant default value to any document being added that does not already have a value in the specified field.
DefaultValueUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.DefaultValueUpdateProcessorFactory
 
DEFTYPE - Static variable in class org.apache.solr.search.QueryParsing
 
DEGREES - Static variable in class org.apache.solr.util.DistanceUnits
 
DEGREES_PARAM - Static variable in class org.apache.solr.util.DistanceUnits
 
del(PayloadObj<PackagePayload.DelVersion>) - Method in class org.apache.solr.pkg.PackageAPI.Edit
 
delayBeforeCreatingNewDocSet - Static variable in class org.apache.solr.util.TestInjection
 
delayBeforeFollowerCommitRefresh - Static variable in class org.apache.solr.util.TestInjection
 
delayInExecutePlanAction - Static variable in class org.apache.solr.util.TestInjection
 
delegate - Variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
 
delegate - Variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
 
delegate - Variable in class org.apache.solr.search.DelegatingCollector
 
DelegateRegistryCounter - Class in org.apache.solr.metrics
A counter implementation that is aware of both primary and delegate metrics belonging to different registries and able to update metrics in multiple registries
DelegateRegistryCounter(Counter, Counter) - Constructor for class org.apache.solr.metrics.DelegateRegistryCounter
 
DelegateRegistryHistogram - Class in org.apache.solr.metrics
A meter implementation that is aware of both primary and delegate metrics belonging to different registries and able to update metrics in multiple registries
DelegateRegistryHistogram(Histogram, Histogram) - Constructor for class org.apache.solr.metrics.DelegateRegistryHistogram
 
DelegateRegistryMeter - Class in org.apache.solr.metrics
A meter implementation that is aware of both primary and delegate metrics belonging to different registries and able to update metrics in multiple registries
DelegateRegistryMeter(Meter, Meter) - Constructor for class org.apache.solr.metrics.DelegateRegistryMeter
 
DelegateRegistryTimer - Class in org.apache.solr.metrics
A timer implementation that is aware of both primary and delegate metrics belonging to different registries and able to update metrics in multiple registries
DelegateRegistryTimer(Clock, Timer, Timer) - Constructor for class org.apache.solr.metrics.DelegateRegistryTimer
 
delegateRequestToManagedResource() - Method in class org.apache.solr.rest.RestManager.ManagedEndpoint
 
DelegatingClusterEventProducer - Class in org.apache.solr.cluster.events.impl
This implementation allows Solr to dynamically change the underlying implementation of ClusterEventProducer in response to the changed plugin configuration.
DelegatingClusterEventProducer(CoreContainer) - Constructor for class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
DelegatingCollector - Class in org.apache.solr.search
A simple delegating collector where one can set the delegate after creation
DelegatingCollector() - Constructor for class org.apache.solr.search.DelegatingCollector
 
DelegatingEventListener - Class in org.apache.solr.core
A SolrEventListener wrapper that loads class from a package and reload if it's modified
DelegatingEventListener(PackagePluginHolder<SolrEventListener>) - Constructor for class org.apache.solr.core.DelegatingEventListener
 
DelegatingPlacementPluginFactory - Class in org.apache.solr.cluster.placement.impl
Helper class to support dynamic reloading of plugin implementations.
DelegatingPlacementPluginFactory(PlacementPluginFactory<?>) - Constructor for class org.apache.solr.cluster.placement.impl.DelegatingPlacementPluginFactory
Constructor.
DelegatingSolrQueryRequest - Class in org.apache.solr.request
A SolrQueryRequest implementation that defers to a delegate in all cases.
DelegatingSolrQueryRequest(SolrQueryRequest) - Constructor for class org.apache.solr.request.DelegatingSolrQueryRequest
 
delete(String) - Method in class org.apache.solr.filestore.DistribFileStore
 
delete(String) - Method in interface org.apache.solr.filestore.FileStore
Delete a file cluster-wide
delete(String) - Method in class org.apache.solr.rest.ManagedResourceStorage
Removes the given resourceId's persisted representation.
delete(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.FileStorageIO
 
delete(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.InMemoryStorageIO
 
delete(String) - Method in interface org.apache.solr.rest.ManagedResourceStorage.StorageIO
 
delete(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
delete(URI, Collection<String>) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
Delete files at path
delete(URI, Collection<String>) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
delete(URI, Collection<String>, boolean) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
delete(CoreContainer, CoreDescriptor...) - Method in class org.apache.solr.core.CorePropertiesLocator
 
delete(CoreContainer, CoreDescriptor...) - Method in interface org.apache.solr.core.CoresLocator
Ensure that the core definitions from the passed in CoreDescriptors are not available for discovery
delete(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.filestore.FileStoreAPI.FSWrite
 
delete(DeleteUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
delete(DeleteUpdateCommand) - Method in class org.apache.solr.update.UpdateHandler
 
delete(DeleteUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
 
DELETE - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
DELETE - Static variable in class org.apache.solr.update.UpdateLog
 
DELETE_BY_QUERY - Static variable in class org.apache.solr.update.UpdateLog
 
DELETE_COPY_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
DELETE_DYNAMIC_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
DELETE_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
DELETE_FIELD_TYPE - org.apache.solr.schema.SchemaManager.OpType
 
DELETE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DELETE_VALUE_SINGLETON - Static variable in class org.apache.solr.update.processor.AllValuesOrNoneFieldMutatingUpdateProcessor
 
DELETE_VALUE_SINGLETON - Static variable in class org.apache.solr.update.processor.FieldValueMutatingUpdateProcessor
 
deleteAlias(String, String) - Method in class org.apache.solr.handler.admin.api.DeleteAlias
 
DeleteAlias - Class in org.apache.solr.handler.admin.api
 
DeleteAlias(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteAlias
 
DELETEALIAS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DeleteAliasCmd - Class in org.apache.solr.cloud.api.collections
 
DeleteAliasCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.DeleteAliasCmd
 
deleteAliasProperty(String, String) - Method in class org.apache.solr.handler.admin.api.AliasProperty
 
deleteAll() - Method in class org.apache.solr.update.UpdateLog
currently for testing only
deleteAllAsyncIds() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
deleteAllAsyncIds() - Method in class org.apache.solr.cloud.DistributedApiAsyncTracker
Deletes all async id's for completed or failed async jobs.
DELETEBACKUP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DeleteBackupCmd - Class in org.apache.solr.cloud.api.collections
An overseer command used to delete files associated with incremental backups.
DeleteBackupCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.DeleteBackupCmd
 
deleteBufferLogs() - Method in class org.apache.solr.update.UpdateLog
 
deleteByQueries - Variable in class org.apache.solr.update.UpdateLog
 
deleteByQuery - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
 
deleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
deleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.UpdateHandler
 
deleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
 
deleteByQueryList - Variable in class org.apache.solr.update.UpdateLog.RecentUpdates
 
deleteCollection(String, Boolean, String) - Method in class org.apache.solr.handler.admin.api.DeleteCollection
 
deleteCollection(CommandLine) - Method in class org.apache.solr.cli.DeleteTool
 
deleteCollection(CloudSolrClient, CommandLine) - Method in class org.apache.solr.cli.DeleteTool
 
deleteCollection(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
DeleteCollection - Class in org.apache.solr.handler.admin.api
V2 API for deleting collections.
DeleteCollection(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteCollection
 
DeleteCollectionBackup - Class in org.apache.solr.handler.admin.api
V2 API definitions for collection-backup deletion.
DeleteCollectionBackup(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteCollectionBackup
 
DeleteCollectionCmd - Class in org.apache.solr.cloud.api.collections
 
DeleteCollectionCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.DeleteCollectionCmd
 
deleteCollectionLevelSnapshot(SolrZkClient, String, String) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method deletes an entry for the named snapshot for the specified collection in Zookeeper.
deleteCollectionProperty(String, String) - Method in class org.apache.solr.handler.admin.api.CollectionProperty
 
DeleteCollectionRequest - Interface in org.apache.solr.cluster.placement
Delete collection request.
deleteCollectionSnapshot(String, String, boolean, String) - Method in class org.apache.solr.handler.admin.api.DeleteCollectionSnapshot
 
DeleteCollectionSnapshot - Class in org.apache.solr.handler.admin.api
V2 API impl for Deleting Collection Snapshots.
DeleteCollectionSnapshot(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteCollectionSnapshot
 
deleteCommandStatus(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
deleteConfig(String) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
deleteConfig(String) - Method in class org.apache.solr.core.ConfigSetService
Delete a config (recursively deletes its files if not empty)
deleteConfig(String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
deleteConfigSet(ZkNodeProps, CoreContainer) - Static method in class org.apache.solr.cloud.ConfigSetCmds
 
deleteConfigSet(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.configsets.DeleteConfigSetAPI
 
DeleteConfigSetAPI - Class in org.apache.solr.handler.configsets
V2 API for deleting an existing configset
DeleteConfigSetAPI(CoreContainer) - Constructor for class org.apache.solr.handler.configsets.DeleteConfigSetAPI
 
deleteCopyFields(Map<String, Collection<String>>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema and deletes the given copy fields from the copy.
deleteCopyFields(Map<String, Collection<String>>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
deleteCore(CommandLine, SolrClient) - Method in class org.apache.solr.cli.DeleteTool
 
DELETECORE - org.apache.solr.cloud.overseer.OverseerAction
 
deleted(ContainerPluginsRegistry.ApiInfo) - Method in interface org.apache.solr.api.ContainerPluginsRegistry.PluginRegistryListener
Called when an existing plugin is deleted.
DELETED - Static variable in class org.apache.solr.handler.component.RealTimeGetComponent
 
deletedDocument(int) - Method in class org.apache.solr.update.CommitTracker
Indicate that documents have been deleted
deleteDirectory(URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method deletes a directory at the specified path.
deleteDirectory(URI) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
deleteDynamicFields(Collection<String>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, deletes the named dynamic fields from the copy.
deleteDynamicFields(Collection<String>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
deleteFields(Collection<String>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, deletes the named fields from the copy.
deleteFields(Collection<String>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
deleteFieldTypes(Collection<String>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, deletes the named field types from the copy.
deleteFieldTypes(Collection<String>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
deleteFile(Path) - Static method in class org.apache.solr.update.UpdateLog
 
deleteFilesFromConfig(String, List<String>) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
deleteFilesFromConfig(String, List<String>) - Method in class org.apache.solr.core.ConfigSetService
Delete files in config
deleteFilesFromConfig(String, List<String>) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
deleteList - Variable in class org.apache.solr.update.UpdateLog.RecentUpdates
 
deleteLocal(String) - Method in class org.apache.solr.filestore.DistribFileStore
 
deleteLocal(String) - Method in interface org.apache.solr.filestore.FileStore
Delete file from local file system
deleteLocal(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.filestore.FileStoreAPI.FSWrite
 
deleteManagedResource(ManagedResource) - Method in class org.apache.solr.rest.RestManager
Deletes a managed resource if it is not being used by any Solr components.
deleteMultipleBackupsByRecency(String, Integer, String, String, String) - Method in class org.apache.solr.handler.admin.api.DeleteCollectionBackup
 
deleteNamedPlugin(String, String) - Method in class org.apache.solr.core.ConfigOverlay
 
deleteNamedSnapshot(String) - Method in class org.apache.solr.core.SolrCore
This method deletes the snapshot with the specified name.
deleteNamedSnapshot(ReplicationHandler) - Method in class org.apache.solr.handler.SnapShooter
 
deleteNode(String, DeleteNodeRequestBody) - Method in class org.apache.solr.handler.admin.api.DeleteNode
 
DeleteNode - Class in org.apache.solr.handler.admin.api
V2 API for deleting all replicas of all collections in one node.
DeleteNode(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteNode
 
DELETENODE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DeleteNodeCmd - Class in org.apache.solr.cloud.api.collections
 
DeleteNodeCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.DeleteNodeCmd
 
deleteNonSnapshotIndexFiles(String) - Method in class org.apache.solr.core.SolrCore
This method deletes the index files not associated with any named snapshot only if the specified indexDirPath is not the *current* index directory.
deleteNonSnapshotIndexFiles(SolrCore, Directory, Collection<SolrSnapshotMetaDataManager.SnapshotMetaData>) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method deletes index files not associated with the specified snapshots.
deleteOldIndexDirectory(String) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
deleteOldIndexDirectory(String) - Method in class org.apache.solr.core.DirectoryFactory
 
deleteOnClose - Variable in class org.apache.solr.update.TransactionLog
 
deletePermission(PayloadObj<Integer>) - Method in class org.apache.solr.handler.admin.api.ModifyRuleBasedAuthConfigAPI
 
DeleteReplica - Class in org.apache.solr.handler.admin.api
V2 APIs for deleting one or more existing replicas from one or more shards.
DeleteReplica(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteReplica
 
DELETEREPLICA_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
deleteReplicaByName(String, String, String, Boolean, Boolean, Boolean, Boolean, Boolean, String) - Method in class org.apache.solr.handler.admin.api.DeleteReplica
 
DeleteReplicaCmd - Class in org.apache.solr.cloud.api.collections
 
DeleteReplicaCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.DeleteReplicaCmd
 
DELETEREPLICAPROP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DeleteReplicaPropCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.DeleteReplicaPropCmd
 
deleteReplicaProperty(String, String, String, String) - Method in class org.apache.solr.handler.admin.api.DeleteReplicaProperty
 
deleteReplicaProperty(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.ReplicaMutator
 
DeleteReplicaProperty - Class in org.apache.solr.handler.admin.api
V2 API implementation for removing a property from a collection replica
DeleteReplicaProperty(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteReplicaProperty
 
deleteReplicasByCount(String, String, Integer, Boolean, Boolean, Boolean, Boolean, Boolean, String) - Method in class org.apache.solr.handler.admin.api.DeleteReplica
 
deleteReplicasByCountAllShards(String, ScaleCollectionRequestBody) - Method in class org.apache.solr.handler.admin.api.DeleteReplica
 
DeleteReplicasRequest - Interface in org.apache.solr.cluster.placement
Delete replicas request.
deletes - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
 
deleteShard(String, String, Boolean, Boolean, Boolean, Boolean, String) - Method in class org.apache.solr.handler.admin.api.DeleteShard
 
deleteShard(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.CollectionMutator
 
DeleteShard - Class in org.apache.solr.handler.admin.api
V2 API implementation for deleting a particular shard from its collection.
DeleteShard(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.DeleteShard
 
DELETESHARD_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DeleteShardCmd - Class in org.apache.solr.cloud.api.collections
 
DeleteShardCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.DeleteShardCmd
 
DeleteShardsRequest - Interface in org.apache.solr.cluster.placement
Delete shards request.
deleteSingleAsyncId(String) - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
deleteSingleAsyncId(String) - Method in class org.apache.solr.cloud.DistributedApiAsyncTracker
Deletes a single async tracking ID if the corresponding job has completed or failed.
deleteSingleBackupById(String, String, String, String, String) - Method in class org.apache.solr.handler.admin.api.DeleteCollectionBackup
 
deleteSnapAsync(ReplicationHandler) - Method in class org.apache.solr.handler.SnapShooter
 
deleteSnapshot(String, String, String) - Method in class org.apache.solr.handler.admin.api.CoreSnapshot
This API is analogous to V1 (DELETE /solr/admin/cores?action=DELETESNAPSHOT)
DELETESNAPSHOT_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DELETESNAPSHOT_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
DeleteSnapshotCmd - Class in org.apache.solr.cloud.api.collections
This class implements the functionality of deleting a collection level snapshot.
DeleteSnapshotCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.DeleteSnapshotCmd
 
deleteSnapshotIndexFiles(SolrCore, Directory, long) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method deletes index files of the IndexCommit for the specified generation number.
DELETESTATUS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
deleteTargetCollection(ClusterState, NamedList<Object>, String, ZkStateReader.AliasesManager, RoutedAlias.Action) - Method in class org.apache.solr.cloud.api.collections.MaintainRoutedAliasCmd
 
DeleteTool - Class in org.apache.solr.cli
 
DeleteTool() - Constructor for class org.apache.solr.cli.DeleteTool
 
DeleteTool(PrintStream) - Constructor for class org.apache.solr.cli.DeleteTool
 
deleteUnloadedCore(CoreDescriptor, boolean, boolean) - Static method in class org.apache.solr.core.SolrCore
 
DeleteUpdate(long, byte[]) - Constructor for class org.apache.solr.update.UpdateLog.DeleteUpdate
 
DeleteUpdateCommand - Class in org.apache.solr.update
 
DeleteUpdateCommand(SolrQueryRequest) - Constructor for class org.apache.solr.update.DeleteUpdateCommand
 
deleteUsers(PayloadObj<List<String>>) - Method in class org.apache.solr.handler.admin.api.ModifyBasicAuthConfigAPI
 
deleteUsers(PayloadObj<List<String>>) - Method in class org.apache.solr.handler.admin.api.ModifyMultiPluginAuthConfigAPI
 
deleteZKFileEntry(SolrZkClient, String) - Static method in class org.apache.solr.filestore.DistribFileStore
 
DenseVectorField - Class in org.apache.solr.schema
Provides a field type to support Lucene's KnnVectorField.
DenseVectorField() - Constructor for class org.apache.solr.schema.DenseVectorField
 
DenseVectorField(int) - Constructor for class org.apache.solr.schema.DenseVectorField
 
DenseVectorField(int, VectorEncoding) - Constructor for class org.apache.solr.schema.DenseVectorField
 
DenseVectorField(int, VectorSimilarityFunction, VectorEncoding) - Constructor for class org.apache.solr.schema.DenseVectorField
 
DenseVectorParser - Class in org.apache.solr.util.vector
 
DenseVectorParser() - Constructor for class org.apache.solr.util.vector.DenseVectorParser
 
DenseVectorParser.BuilderPhase - Enum in org.apache.solr.util.vector
 
deploy(String, String, String[], boolean, String[], boolean, boolean) - Method in class org.apache.solr.packagemanager.PackageManager
Deploys a version of a package to a list of collections.
DeprecationLog - Class in org.apache.solr.logging
Utility to log a deprecation.
DeprecationLog() - Constructor for class org.apache.solr.logging.DeprecationLog
 
deregisterAll() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
deregisterGlobal() - Static method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
deregisterInFlightUpdate() - Method in class org.apache.solr.update.SolrCoreState
De-registers in-flight update requests to this core (marks them as completed)
desc - org.apache.solr.search.facet.FacetRequest.SortDirection
 
description - Variable in class org.apache.solr.packagemanager.SolrPackage
 
description - Variable in class org.apache.solr.packagemanager.SolrPackageInstance
 
description() - Method in class org.apache.solr.schema.RandomSortField.RandomValueSource
 
description() - Method in class org.apache.solr.schema.StrFieldSource
 
description() - Method in class org.apache.solr.search.facet.RelatednessAgg
 
description() - Method in class org.apache.solr.search.facet.SimpleAggValueSource
 
description() - Method in class org.apache.solr.search.facet.StrAggValueSource
 
description() - Method in class org.apache.solr.search.FloatPayloadValueSource
 
description() - Method in class org.apache.solr.search.function.CollapseScoreFunction
 
description() - Method in class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
description() - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
description() - Method in class org.apache.solr.search.function.distance.HaversineConstFunction
 
description() - Method in class org.apache.solr.search.function.distance.HaversineFunction
 
description() - Method in class org.apache.solr.search.function.distance.StringDistanceFunction
 
description() - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
description() - Method in class org.apache.solr.search.function.DualDoubleFunction
 
description() - Method in class org.apache.solr.search.function.FieldNameValueSource
 
description() - Method in class org.apache.solr.search.function.FileFloatSource
 
description() - Method in class org.apache.solr.search.function.MultiStringFunction
 
description() - Method in class org.apache.solr.search.function.OrdFieldSource
 
description() - Method in class org.apache.solr.search.function.ReverseOrdFieldSource
 
deserialize(byte[]) - Static method in class org.apache.solr.cloud.OverseerSolrResponseSerializer
 
DESERIALIZED_REQUEST_BODY_KEY - Static variable in class org.apache.solr.jersey.MessageBodyReaders.CachingDelegatingMessageBodyReader
 
deserializeX509PublicKey(String) - Static method in class org.apache.solr.util.CryptoKeys
 
DESIGNER_KEY - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
DESIGNER_PREFIX - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
DEST_PARAM - Static variable in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
DESTINATION - Static variable in class org.apache.solr.schema.IndexSchema
 
destroy() - Method in class org.apache.solr.handler.IndexFetcher
 
destroy() - Method in class org.apache.solr.servlet.SolrDispatchFilter
 
destroy() - Method in class org.apache.solr.util.ConcurrentLRUCache
 
DETAILS - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
detectTSV(String) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
determinePollInterval(SolrConfig.UpdateHandlerInfo) - Static method in class org.apache.solr.cloud.ReplicateFromLeader
Determine the poll interval for replicas based on the auto soft/hard commit schedule
determineReader(IndexReader) - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
determineReader(IndexReader) - Method in class org.apache.solr.spelling.FileBasedSpellChecker
Override to return null, since there is no reader associated with a file based index
determineReader(IndexReader) - Method in class org.apache.solr.spelling.IndexBasedSpellChecker
 
DEV_NULL_SLOT_ACC - Static variable in class org.apache.solr.search.facet.Constants
 
DFISimilarityFactory - Class in org.apache.solr.search.similarities
Factory for DFISimilarity
DFISimilarityFactory() - Constructor for class org.apache.solr.search.similarities.DFISimilarityFactory
 
DFRSimilarityFactory - Class in org.apache.solr.search.similarities
Factory for DFRSimilarity
DFRSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.DFRSimilarityFactory
 
Diagnostics - Class in org.apache.solr.core
 
Diagnostics() - Constructor for class org.apache.solr.core.Diagnostics
 
Diagnostics.Callable - Interface in org.apache.solr.core
 
dictionary - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
dictionary - Variable in class org.apache.solr.spelling.suggest.Suggester
 
DICTIONARY_IMPL - Static variable in class org.apache.solr.spelling.suggest.SolrSuggester
Fully-qualified class of the Dictionary implementation
DICTIONARY_NAME - Static variable in class org.apache.solr.spelling.SolrSpellChecker
 
DictionaryFactory - Class in org.apache.solr.spelling.suggest
Encapsulates shared fields for all types of dictionaryFactory classes
DictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.DictionaryFactory
 
didCommit() - Method in class org.apache.solr.update.CommitTracker
Inform tracker that a commit has occurred
didRollback() - Method in class org.apache.solr.update.CommitTracker
Inform tracker that a rollback has occurred, cancel any pending commits
diff(List<SimpleOrderedMap<Object>>, List<SimpleOrderedMap<Object>>) - Static method in class org.apache.solr.handler.designer.ManagedSchemaDiff
 
diff(Map<String, SimpleOrderedMap<Object>>, Map<String, SimpleOrderedMap<Object>>) - Static method in class org.apache.solr.handler.designer.ManagedSchemaDiff
Compute difference between two map objects with SimpleOrderedMap as values.
diff(ManagedIndexSchema, ManagedIndexSchema) - Static method in class org.apache.solr.handler.designer.ManagedSchemaDiff
Compute difference between two managed schemas.
diffNamedList(NamedList<?>, NamedList<?>) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
diffObject(Object, Object) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
dimension - Variable in class org.apache.solr.schema.CoordinateFieldType
The dimension of the coordinate system
dimension - Variable in class org.apache.solr.util.vector.DenseVectorParser
 
DIMENSION - Static variable in class org.apache.solr.schema.CoordinateFieldType
 
DIMENSIONAL - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
DimensionalRoutedAlias - Class in org.apache.solr.cloud.api.collections
 
dir - Variable in class org.apache.solr.cloud.DistributedMap
 
directory - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
DIRECTORY - org.apache.solr.core.backup.repository.BackupRepository.PathType
 
DIRECTORY - org.apache.solr.core.SolrInfoBean.Category
 
DIRECTORY - org.apache.solr.filestore.FileStore.FileType
 
DirectoryFactory - Class in org.apache.solr.core
Provides access to a Directory implementation.
DirectoryFactory() - Constructor for class org.apache.solr.core.DirectoryFactory
 
DirectoryFactory.DirContext - Enum in org.apache.solr.core
 
directoryName - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
DirectSolrConnection - Class in org.apache.solr.servlet
DirectSolrConnection provides an interface to Solr that is similar to the HTTP interface, but does not require an HTTP connection.
DirectSolrConnection(SolrCore) - Constructor for class org.apache.solr.servlet.DirectSolrConnection
Initialize using an explicit SolrCore
DirectSolrSpellChecker - Class in org.apache.solr.spelling
Spellchecker implementation that uses DirectSpellChecker
DirectSolrSpellChecker() - Constructor for class org.apache.solr.spelling.DirectSolrSpellChecker
 
DirectUpdateHandler2 - Class in org.apache.solr.update
DirectUpdateHandler2 implements an UpdateHandler where documents are added directly to the main Lucene index as opposed to adding to a separate smaller index.
DirectUpdateHandler2(SolrCore) - Constructor for class org.apache.solr.update.DirectUpdateHandler2
 
DirectUpdateHandler2(SolrCore, UpdateHandler) - Constructor for class org.apache.solr.update.DirectUpdateHandler2
 
directUpdateLatch - Static variable in class org.apache.solr.util.TestInjection
 
DIRLASTMOD - org.apache.solr.core.SolrConfig.HttpCachingConfig.LastModFrom
 
DISABLE - org.apache.solr.handler.PingRequestHandler.ACTIONS
 
DISABLE_CREATE_AUTH_CHECKS - Static variable in class org.apache.solr.handler.admin.ConfigSetsHandler
 
DISABLE_DESIGNER_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
disable_tracing() - Method in class org.apache.solr.parser.QueryParser
Disable tracing.
DISABLE_URL_ALLOW_LIST - Static variable in class org.apache.solr.security.AllowListUrlChecker
System property to disable URL checking and AllowListUrlChecker.ALLOW_ALL instead.
DISABLED - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
disableResponseCaching() - Method in class org.apache.solr.handler.admin.api.AdminAPIBase
 
discardReaderReference() - Method in class org.apache.solr.schema.ZkIndexSchemaReader.SchemaWatcher
Discard the reference to the ZkIndexSchemaReader.
DISCOUNT_OVERLAPS - Static variable in class org.apache.solr.search.similarities.ClassicSimilarityFactory
Init param name for specifying the value to use in TFIDFSimilarity.setDiscountOverlaps(boolean)
discountOverlaps - Variable in class org.apache.solr.search.similarities.ClassicSimilarityFactory
Controls the value of TFIDFSimilarity.setDiscountOverlaps(boolean) on newly constructed instances of ClassicSimilarity
discover(CoreContainer) - Method in class org.apache.solr.core.CorePropertiesLocator
 
discover(CoreContainer) - Method in interface org.apache.solr.core.CoresLocator
Load all the CoreDescriptors from persistence store
DisjunctionMaxQueryParser(QParser, String) - Constructor for class org.apache.solr.util.SolrPluginUtils.DisjunctionMaxQueryParser
 
DisMaxQParser - Class in org.apache.solr.search
Query parser for dismax queries
DisMaxQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.DisMaxQParser
 
DisMaxQParserPlugin - Class in org.apache.solr.search
Create a dismax query from the input value.
DisMaxQParserPlugin() - Constructor for class org.apache.solr.search.DisMaxQParserPlugin
 
dispose(SolrParams) - Method in class org.apache.solr.jersey.InjectionFactories.ReuseFromContextSolrParamsFactory
 
dispose(SolrCore) - Method in class org.apache.solr.jersey.InjectionFactories.ReuseFromContextSolrCoreFactory
 
dispose(SolrQueryRequest) - Method in class org.apache.solr.jersey.InjectionFactories.SolrQueryRequestFactory
 
dispose(SolrQueryResponse) - Method in class org.apache.solr.jersey.InjectionFactories.SolrQueryResponseFactory
 
dispose(IndexSchema) - Method in class org.apache.solr.jersey.InjectionFactories.ReuseFromContextIndexSchemaFactory
 
dispose(T) - Method in class org.apache.solr.jersey.InjectionFactories.SingletonFactory
 
dist - Variable in class org.apache.solr.search.function.distance.StringDistanceFunction
 
DIST_DOC_ID - Static variable in class org.apache.solr.handler.component.MoreLikeThisComponent
 
DIST_ERR_PARAM - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
DIST_ERR_PCT_PARAM - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
distance - Variable in class org.apache.solr.search.SpatialOptions
 
distance(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
distance(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.distance.HaversineFunction
 
distance(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.distance.SquaredEuclideanFunction
 
distance(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
Calculate the distance
DISTANCE - Static variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
distanceUnits - Variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
DistanceUnits - Class in org.apache.solr.util
Used with a spatial field type for all distance measurements.
distinctValues - org.apache.solr.handler.component.StatsField.Stat
 
DISTRIB_FROM - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
DISTRIB_FROM_COLLECTION - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
DISTRIB_FROM_PARENT - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
DISTRIB_FROM_SHARD - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
DISTRIB_INPLACE_PREVVERSION - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
DISTRIB_UPDATE_PARAM - Static variable in interface org.apache.solr.update.processor.DistributingUpdateProcessorFactory
Internal param used to specify the current phase of a distributed update, not intended for use by clients.
distribAdd(AddUpdateCommand, List<SolrCmdDistributor.Node>, ModifiableSolrParams) - Method in class org.apache.solr.update.SolrCmdDistributor
 
distribAdd(AddUpdateCommand, List<SolrCmdDistributor.Node>, ModifiableSolrParams, boolean) - Method in class org.apache.solr.update.SolrCmdDistributor
 
distribAdd(AddUpdateCommand, List<SolrCmdDistributor.Node>, ModifiableSolrParams, boolean, DistributedUpdateProcessor.RollupRequestReplicationTracker, DistributedUpdateProcessor.LeaderRequestReplicationTracker) - Method in class org.apache.solr.update.SolrCmdDistributor
 
distribCommit(CommitUpdateCommand, List<SolrCmdDistributor.Node>, ModifiableSolrParams) - Method in class org.apache.solr.update.SolrCmdDistributor
 
distribDelete(DeleteUpdateCommand, List<SolrCmdDistributor.Node>, ModifiableSolrParams) - Method in class org.apache.solr.update.SolrCmdDistributor
 
distribDelete(DeleteUpdateCommand, List<SolrCmdDistributor.Node>, ModifiableSolrParams, boolean, DistributedUpdateProcessor.RollupRequestReplicationTracker, DistributedUpdateProcessor.LeaderRequestReplicationTracker) - Method in class org.apache.solr.update.SolrCmdDistributor
 
DistribFileStore - Class in org.apache.solr.filestore
 
DistribFileStore(CoreContainer) - Constructor for class org.apache.solr.filestore.DistribFileStore
 
distribFinish(LinkedHashMap<String, SpatialHeatmapFacets.HeatmapFacet>, ResponseBuilder) - Static method in class org.apache.solr.handler.component.SpatialHeatmapFacets
Called by FacetComponent's impl of SearchComponent.finishStage(ResponseBuilder).
distribHandleResponse(LinkedHashMap<String, SpatialHeatmapFacets.HeatmapFacet>, NamedList<?>) - Static method in class org.apache.solr.handler.component.SpatialHeatmapFacets
Called by FacetComponent.countFacets which is in turn called by FC's impl of SearchComponent.handleResponses(ResponseBuilder, ShardRequest).
distribModifyRequest(ShardRequest, LinkedHashMap<String, SpatialHeatmapFacets.HeatmapFacet>) - Static method in class org.apache.solr.handler.component.SpatialHeatmapFacets
distribParse(SolrParams, ResponseBuilder) - Static method in class org.apache.solr.handler.component.SpatialHeatmapFacets
Parses request to "HeatmapFacet" instances.
DistributedApiAsyncTracker - Class in org.apache.solr.cloud
Class holding the implementation required for tracking asynchronous Collection API (or other) tasks when the Collection API is distributed.
DistributedApiAsyncTracker(SolrZkClient, String) - Constructor for class org.apache.solr.cloud.DistributedApiAsyncTracker
 
DISTRIBUTEDAPIPROCESSING_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
DistributedClusterStateUpdater - Class in org.apache.solr.cloud
Gives access to distributed cluster state update methods and allows code to inquire whether distributed state update is enabled.
DistributedClusterStateUpdater(boolean) - Constructor for class org.apache.solr.cloud.DistributedClusterStateUpdater
Builds an instance with the specified behavior regarding distribution of state updates, allowing to know distributed updates are not enabled (parameter useDistributedStateUpdate is false), or when they are (parameter is true), gives access to methods and classes allowing the execution of the updates.
DistributedClusterStateUpdater.MutatingCommand - Enum in org.apache.solr.cloud
Naming of enum instances are the mutator object name (e.g.
DistributedClusterStateUpdater.StateChangeRecorder - Class in org.apache.solr.cloud
Class handling the distributed updates of collection's Zookeeper files state.json based on multiple updates applied to a single collection (as is sometimes done by *Cmd classes implementing the Collection API commands).
DistributedCollectionCommandContext - Class in org.apache.solr.cloud.api.collections
 
DistributedCollectionCommandContext(CoreContainer, ExecutorService) - Constructor for class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
distributedCollectionConfigSetCommandRunner - Variable in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
DistributedCollectionConfigSetCommandRunner - Class in org.apache.solr.cloud.api.collections
Class for execution Collection API and Config Set API commands in a distributed way, without going through Overseer and OverseerCollectionMessageHandler or OverseerConfigSetMessageHandler.
DistributedCollectionConfigSetCommandRunner(CoreContainer) - Constructor for class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
 
DistributedCollectionLockFactory - Interface in org.apache.solr.cloud
 
DistributedConfigSetLockFactory - Interface in org.apache.solr.cloud
 
DistributedLock - Interface in org.apache.solr.cloud
A lock that can be used across cluster nodes.
DistributedMap - Class in org.apache.solr.cloud
A distributed map.
DistributedMap(SolrZkClient, String) - Constructor for class org.apache.solr.cloud.DistributedMap
 
DistributedMultiLock - Class in org.apache.solr.cloud
A lock as acquired for running a single API command (Collection or Config Set or anything else in the future).
DistributedMultiLock(List<DistributedLock>) - Constructor for class org.apache.solr.cloud.DistributedMultiLock
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.ExpandComponent
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.FacetComponent
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.SearchComponent
Process for a distributed search.
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.StatsComponent
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.SuggestComponent
Dispatch shard request in STAGE_EXECUTE_QUERY stage
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.TermsComponent
 
distributedProcess(ResponseBuilder) - Method in class org.apache.solr.search.facet.FacetModule
 
DistributedUpdateProcessor - Class in org.apache.solr.update.processor
 
DistributedUpdateProcessor(SolrQueryRequest, SolrQueryResponse, AtomicUpdateDocumentMerger, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.DistributedUpdateProcessor
Specification of AtomicUpdateDocumentMerger is currently experimental.
DistributedUpdateProcessor(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.DistributedUpdateProcessor
 
DistributedUpdateProcessor.DistribPhase - Enum in org.apache.solr.update.processor
Values this processor supports for the DISTRIB_UPDATE_PARAM.
DistributedUpdateProcessor.DistributedUpdatesAsyncException - Exception in org.apache.solr.update.processor
 
DistributedUpdateProcessor.LeaderRequestReplicationTracker - Class in org.apache.solr.update.processor
 
DistributedUpdateProcessor.RollupRequestReplicationTracker - Class in org.apache.solr.update.processor
 
DistributedUpdateProcessorFactory - Class in org.apache.solr.update.processor
DistributedUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.DistributedUpdateProcessorFactory
 
DistributedUpdatesAsyncException(List<SolrCmdDistributor.SolrError>) - Constructor for exception org.apache.solr.update.processor.DistributedUpdateProcessor.DistributedUpdatesAsyncException
 
DistributedZkUpdateProcessor - Class in org.apache.solr.update.processor
 
DistributedZkUpdateProcessor(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
DistributingUpdateProcessorFactory - Interface in org.apache.solr.update.processor
A marker interface for denoting that a factory is responsible for handling distributed communication of updates across a SolrCloud cluster.
distSquaredCartesian(double[], double[]) - Static method in class org.apache.solr.search.function.distance.VectorDistanceFunction
The square of the cartesian Distance.
doAdd(int, String[], SolrInputDocument, AddUpdateCommand) - Method in class org.apache.solr.handler.loader.CSVLoaderBase
this must be MT safe...
doAdd(SolrInputDocument, SolrInputField, Object) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
doAddDistinct(SolrInputDocument, SolrInputField, Object) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
doAfterFlush() - Method in class org.apache.solr.update.SolrIndexWriter
 
doAnalysis(SolrQueryRequest) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase
Performs the analysis based on the given solr request and returns the analysis result as a named list.
doAnalysis(SolrQueryRequest) - Method in class org.apache.solr.handler.DocumentAnalysisRequestHandler
 
doAnalysis(SolrQueryRequest) - Method in class org.apache.solr.handler.FieldAnalysisRequestHandler
 
doAnalytics - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
doAudit(AuditEvent) - Method in class org.apache.solr.security.AuditLoggerPlugin
Called by the framework, and takes care of metrics tracking and to dispatch to either synchronous or async logging.
doAuthenticate(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.solr.security.AuthenticationPlugin
This method attempts to authenticate the request.
doAuthenticate(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.solr.security.BasicAuthPlugin
 
doAuthenticate(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.solr.security.CertAuthPlugin
 
doAuthenticate(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.solr.security.MultiAuthPlugin
 
doAuthenticate(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
doc(int) - Method in class org.apache.solr.search.SolrDocumentFetcher
 
doc(int) - Method in class org.apache.solr.search.SolrIndexSearcher
Retrieve the Document instance corresponding to the document id.
doc(int, Set<String>) - Method in class org.apache.solr.search.SolrDocumentFetcher
Retrieve the Document instance corresponding to the document id.
doc(int, Set<String>) - Method in class org.apache.solr.search.SolrIndexSearcher
Retrieve the Document instance corresponding to the document id.
doc(int, StoredFieldVisitor) - Method in class org.apache.solr.search.SolrDocumentFetcher
 
doc(int, StoredFieldVisitor) - Method in class org.apache.solr.search.SolrIndexSearcher
Visit a document's fields using a StoredFieldVisitor.
DOC - org.apache.solr.handler.component.RealTimeGetComponent.Resolution
Resolve to a whole document, exclusive of children.
DOC_COMMIT_DELAY_MS - Static variable in class org.apache.solr.update.CommitTracker
 
DOC_ID - Static variable in class org.apache.solr.handler.admin.LukeRequestHandler
 
DOC_ID_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
DOC_PATH - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
DOC_VALUES - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
DOC_VALUES - Static variable in class org.apache.solr.schema.FieldProperties
 
doCacheHeaderValidation(SolrQueryRequest, HttpServletRequest, Method, HttpServletResponse) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Sets HTTP Response cache validator headers appropriately and validates the HTTP Request against these using any conditional request headers.
docBase - Variable in class org.apache.solr.search.DelegatingCollector
 
DocBasedVersionConstraintsProcessor - Class in org.apache.solr.update.processor
 
DocBasedVersionConstraintsProcessor(List<String>, boolean, List<String>, boolean, boolean, NamedList<Object>, SolrQueryRequest, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessor
 
DocBasedVersionConstraintsProcessorFactory - Class in org.apache.solr.update.processor
This Factory generates an UpdateProcessor that helps to enforce Version constraints on documents based on per-document version numbers using a configured versionField, a comma-delimited list of fields to check for version numbers.
DocBasedVersionConstraintsProcessorFactory() - Constructor for class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessorFactory
 
docCount - Variable in class org.apache.solr.search.stats.CollectionStats
 
DocExpirationUpdateProcessorFactory - Class in org.apache.solr.update.processor
Update Processor Factory for managing automatic "expiration" of documents.
DocExpirationUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.DocExpirationUpdateProcessorFactory
 
docFreq - Variable in class org.apache.solr.search.stats.TermStats
 
docFreq(Term) - Method in class org.apache.solr.search.SolrIndexSearcher
 
docID() - Method in class org.apache.solr.handler.component.QueryComponent.ScoreAndDoc
 
docID() - Method in class org.apache.solr.search.facet.FieldUtil.OrdValues
 
docID() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
DOCID - Static variable in class org.apache.solr.search.SortSpecParsing
 
DocIdAugmenterFactory - Class in org.apache.solr.response.transform
Augments the document with a [docid] integer containing it's current (internal) id in the lucene index.
DocIdAugmenterFactory() - Constructor for class org.apache.solr.response.transform.DocIdAugmenterFactory
 
DocIterator - Interface in org.apache.solr.search
Simple Iterator of document Ids which may include score information.
docList - Variable in class org.apache.solr.search.DocListAndSet
 
DocList - Interface in org.apache.solr.search
DocList represents the result of a query: an ordered list of document ids with optional score.
DocListAndSet - Class in org.apache.solr.search
A struct whose only purpose is to hold both a DocList and a DocSet so that both may be returned from a single method.
DocListAndSet() - Constructor for class org.apache.solr.search.DocListAndSet
 
doClose() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
doClose() - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
doClose() - Method in class org.apache.solr.update.processor.RoutedAliasUpdateProcessor
 
doClose() - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
Override to implement resource release logic that *must* be called at the end of a request.
docs - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessagesResponse
 
docs - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
docs - Variable in class org.apache.solr.search.SortedIntDocSet
 
docs - Variable in class org.apache.solr.util.MockSearchableSolrClient
 
DocsEnumState() - Constructor for class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
 
docSet - Variable in class org.apache.solr.search.DocListAndSet
 
DocSet - Class in org.apache.solr.search
An immutable ordered set of Lucene Document Ids.
DocSetBuilder - Class in org.apache.solr.search
Adapted from DocIdSetBuilder to build DocSets
DocSetBuilder(int, long) - Constructor for class org.apache.solr.search.DocSetBuilder
 
DocSetCollector - Class in org.apache.solr.search
 
DocSetCollector(int) - Constructor for class org.apache.solr.search.DocSetCollector
 
DocSetCollector(int, int) - Constructor for class org.apache.solr.search.DocSetCollector
 
DocSetCollector.ExpandingIntArray - Class in org.apache.solr.search
 
DocSetProducer - Interface in org.apache.solr.search
 
DocSetUtil - Class in org.apache.solr.search
 
DocSetUtil() - Constructor for class org.apache.solr.search.DocSetUtil
 
DocSlice - Class in org.apache.solr.search
DocSlice implements DocList as an array of docids and optional scores.
DocSlice(int, int, int[], float[], long, float, TotalHits.Relation) - Constructor for class org.apache.solr.search.DocSlice
Primary constructor for a DocSlice instance.
docsOrig - Variable in class org.apache.solr.request.SimpleFacets
The main set of documents all facet counts should be relative to
docsPerGroup - Variable in class org.apache.solr.search.Grouping.Command
 
DocsStreamer - Class in org.apache.solr.response
This streams SolrDocuments from a DocList and applies transformer
DocsStreamer(ResultContext) - Constructor for class org.apache.solr.response.DocsStreamer
 
DocTermOrds - Class in org.apache.solr.uninverting
This class enables fast access to multiple term ords for a specified field across all docIDs.
DocTermOrds(String, int, int) - Constructor for class org.apache.solr.uninverting.DocTermOrds
Subclass inits w/ this, but be sure you then call uninvert, only once
DocTermOrds(LeafReader, Bits, String) - Constructor for class org.apache.solr.uninverting.DocTermOrds
Inverts all terms.
DocTermOrds(LeafReader, Bits, String, BytesRef) - Constructor for class org.apache.solr.uninverting.DocTermOrds
Inverts only terms starting w/ prefix
DocTermOrds(LeafReader, Bits, String, BytesRef, int) - Constructor for class org.apache.solr.uninverting.DocTermOrds
Inverts only terms starting w/ prefix, and only terms whose docFreq (not taking deletions into account) is <= maxTermDocFreq
DocTermOrds(LeafReader, Bits, String, BytesRef, int, int) - Constructor for class org.apache.solr.uninverting.DocTermOrds
Inverts only terms starting w/ prefix, and only terms whose docFreq (not taking deletions into account) is <= maxTermDocFreq, with a custom indexing interval (default is every 128nd term).
docText - Variable in class org.apache.solr.handler.tagger.OffsetCorrector
Document text.
DocToTerm() - Constructor for class org.apache.solr.search.facet.UnInvertedField.DocToTerm
 
DocTransformer - Class in org.apache.solr.response.transform
A DocTransformer can add, remove or alter a Document before it is written out to the Response.
DocTransformer() - Constructor for class org.apache.solr.response.transform.DocTransformer
 
DocTransformer.NoopFieldTransformer - Class in org.apache.solr.response.transform
Trivial Impl that ensure that the specified field is requested as an "extra" field, but then does nothing during the transformation phase.
DocTransformers - Class in org.apache.solr.response.transform
Transform a document before it gets sent out
DocTransformers() - Constructor for class org.apache.solr.response.transform.DocTransformers
 
document(int, StoredFieldVisitor) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
DocumentAnalysisRequestHandler - Class in org.apache.solr.handler
An analysis handler that provides a breakdown of the analysis process of provided documents.
DocumentAnalysisRequestHandler() - Constructor for class org.apache.solr.handler.DocumentAnalysisRequestHandler
 
DocumentBuilder - Class in org.apache.solr.update
Builds a Lucene Document from a SolrInputDocument.
DocumentBuilder() - Constructor for class org.apache.solr.update.DocumentBuilder
 
documentCacheConfig - Variable in class org.apache.solr.core.SolrConfig
 
DocumentDictionaryFactory - Class in org.apache.solr.spelling.suggest
Factory for DocumentDictionary
DocumentDictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.DocumentDictionaryFactory
 
DocumentExpressionDictionaryFactory - Class in org.apache.solr.spelling.suggest
Factory for DocumentValueSourceDictionary
DocumentExpressionDictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
 
DocValuesAcc - Class in org.apache.solr.search.facet
Accumulates stats separated by slot number for the fields with DocValues
DocValuesAcc(FacetContext, SchemaField) - Constructor for class org.apache.solr.search.facet.DocValuesAcc
 
DocValuesFacets - Class in org.apache.solr.request
Computes term facets for docvalues field (single or multivalued).
docValuesFormat - Variable in class org.apache.solr.schema.FieldType
The docvalues format used for this field type
DocValuesIteratorCache - Class in org.apache.solr.search
A helper class for random-order value access over docValues (such as in the case of useDocValuesAsStored).
DocValuesIteratorCache(SolrIndexSearcher) - Constructor for class org.apache.solr.search.DocValuesIteratorCache
Construct an instance used to optimize random-order DocValues iterator access for the specified searcher.
DocValuesIteratorCache(SolrIndexSearcher, boolean) - Constructor for class org.apache.solr.search.DocValuesIteratorCache
Construct an instance used to optimize random-order DocValues iterator access for the specified searcher.
DocValuesIteratorCache.FieldDocValuesSupplier - Class in org.apache.solr.search
Supplies (and coordinates arbitrary-order value retrieval over) docValues iterators for a particular field, encapsulating the logic of iterator creation, reuse/caching, and advancing.
DocValuesStats - Class in org.apache.solr.request
Computes term stats for docvalues field (single or multivalued).
docValuesType() - Method in class org.apache.solr.schema.SchemaField
 
doDelete() - Method in class org.apache.solr.rest.RestManager.ManagedEndpoint
 
doDeleteById(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
doDeleteById(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
doDeleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
for implementing classes to setup request data(nodes, replicas)
doDeleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
doDeleteByQuery(DeleteUpdateCommand, List<SolrCmdDistributor.Node>, DocCollection) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
should be called by implementing class after setting up replicas
doDeleteChild(BaseSolrResource, String) - Method in class org.apache.solr.rest.ManagedResource
Called to delete a named part (the given childId) of the resource at the given endpoint
doDeleteChild(BaseSolrResource, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
doDeleteChild(BaseSolrResource, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
doDeleteChild(BaseSolrResource, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
Deletes words managed by this resource.
doDistribAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
doDistribAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
doDistribDeleteById(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
This method can be overridden to tamper with the cmd after the localDeleteById operation
doDistribDeleteById(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
doDistribDeleteByQuery(DeleteUpdateCommand, List<SolrCmdDistributor.Node>, DocCollection) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
This runs after versionDeleteByQuery is invoked, should be used to tamper or forward DeleteCommand
doDistribDeleteByQuery(DeleteUpdateCommand, List<SolrCmdDistributor.Node>, DocCollection) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
doDistribFinish() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
doDistribFinish() - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
doesUserHavePermission(Principal, PermissionNameProvider.Name) - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
 
doExpand - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
doFacets - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
doFetch(SolrParams, boolean) - Method in class org.apache.solr.handler.ReplicationHandler
 
doFetchFileList(long) - Method in class org.apache.solr.handler.admin.api.ReplicationAPIBase
 
doFetchIndexVersion() - Method in class org.apache.solr.handler.admin.api.ReplicationAPIBase
 
doFieldSortValues(ResponseBuilder, SolrIndexSearcher) - Method in class org.apache.solr.handler.component.QueryComponent
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.solr.servlet.SolrDispatchFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain, boolean) - Method in class org.apache.solr.servlet.SolrDispatchFilter
 
doGet(String) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Performs a simple get on the given URL
doGet(URL) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Performs a simple get on the given URL
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.solr.servlet.LoadAdminUiServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.solr.servlet.RedirectServlet
 
doGet(SolrQueryRequest) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
doGet(SolrQueryRequest) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
doGet(SolrQueryRequest) - Method in class org.apache.solr.search.stats.LocalStatsCache
 
doGet(SolrQueryRequest) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
doGet(SolrQueryRequest) - Method in class org.apache.solr.search.stats.StatsCache
 
doGet(BaseSolrResource, String) - Method in class org.apache.solr.rest.ManagedResource
Called to retrieve a named part (the given childId) of the resource at the given endpoint
doGet(BaseSolrResource, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
doGet(BaseSolrResource, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
doGet(BaseSolrResource, String) - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
Implements the GET request to provide the list of words to the client.
doHighlighting(DocList, Query, SolrQueryRequest, String[]) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Generates a list of Highlighted query fragments for each item in a list of documents, or returns null if highlighting is disabled.
doHighlighting(DocList, Query, SolrQueryRequest, String[]) - Method in class org.apache.solr.highlight.SolrHighlighter
Generates a list of Highlighted query fragments for each item in a list of documents, or returns null if highlighting is disabled.
doHighlighting(DocList, Query, SolrQueryRequest, String[]) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter
 
doHighlightingByFastVectorHighlighter(SolrDocument, int, SchemaField, DefaultSolrHighlighter.FvhContainer, IndexReader, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Highlights and returns the highlight object for this field -- a String[] by default.
doHighlightingByHighlighter(SolrDocument, int, SchemaField, Query, IndexReader, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Highlights and returns the highlight object for this field -- a String[] by default.
doHighlightingOfField(SolrDocument, int, SchemaField, DefaultSolrHighlighter.FvhContainer, Query, IndexReader, SolrQueryRequest, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
 
doHighlights - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
doInc(SolrInputDocument, SolrInputField, Object) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
doIndent - Variable in class org.apache.solr.response.TextResponseWriter
 
doIndent() - Method in class org.apache.solr.response.TextResponseWriter
 
doInit() - Method in class org.apache.solr.metrics.reporters.SolrGraphiteReporter
 
doInit() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
 
doInit() - Method in class org.apache.solr.metrics.reporters.SolrSlf4jReporter
 
doInit() - Method in class org.apache.solr.metrics.SolrMetricReporter
Reporter initialization implementation.
doInit(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.rest.BaseSolrResource
Pulls the SolrQueryRequest constructed in SolrDispatchFilter from the SolrRequestInfo thread local, then gets the SolrCore and IndexSchema and sets up the response.
doInit(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.rest.RestManager.ManagedEndpoint
Initialize objects needed to handle a request to the REST API.
doInPlaceUpdateMerge(AddUpdateCommand, Set<String>) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
Given an AddUpdateCommand containing update operations (e.g.
DOLLAR_BRACES_PLACEHOLDER_PATTERN - Static variable in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
doLocalCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
domain - Variable in class org.apache.solr.search.facet.FacetRequest
 
Domain() - Constructor for class org.apache.solr.search.facet.FacetRequest.Domain
 
DOMConfigNode - Class in org.apache.solr.util
Read using DOM
DOMConfigNode(Node) - Constructor for class org.apache.solr.util.DOMConfigNode
 
doMergeToGlobalStats(SolrQueryRequest, List<ShardResponse>) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
doMergeToGlobalStats(SolrQueryRequest, List<ShardResponse>) - Method in class org.apache.solr.search.stats.LocalStatsCache
 
doMergeToGlobalStats(SolrQueryRequest, List<ShardResponse>) - Method in class org.apache.solr.search.stats.StatsCache
 
doneRecovering(String) - Method in class org.apache.solr.cloud.ZkShardTerms
Mark coreNodeName as finished recovering
doneWithDir - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
doneWithDirectory(Directory) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
doneWithDirectory(Directory) - Method in class org.apache.solr.core.DirectoryFactory
Indicates a Directory will no longer be used, and when its ref count hits 0, it can be closed.
doPivots(NamedList<Integer>, String, String, Deque<String>, Deque<String>, SimpleFacets.ParsedParams, List<StatsField>, List<FacetComponent.FacetBase>, List<RangeFacetRequest>) - Method in class org.apache.solr.handler.component.PivotFacetProcessor
Recursive function to compute all the pivot counts for the values under the specified field
doPost(BaseSolrResource, Object) - Method in class org.apache.solr.rest.ManagedResource
Just calls ManagedResource.doPut(BaseSolrResource,Object); override to change the behavior of POST handling.
doPrefetch(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
doPut(BaseSolrResource, Object) - Method in class org.apache.solr.rest.ManagedResource
Applies changes to initArgs or managed data.
doReceiveGlobalStats(SolrQueryRequest) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
doReceiveGlobalStats(SolrQueryRequest) - Method in class org.apache.solr.search.stats.LocalStatsCache
 
doReceiveGlobalStats(SolrQueryRequest) - Method in class org.apache.solr.search.stats.StatsCache
 
doRecovery(CoreContainer, CoreDescriptor) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
doRecovery(CoreContainer, CoreDescriptor) - Method in class org.apache.solr.update.SolrCoreState
 
doRecovery(SolrCore) - Method in class org.apache.solr.cloud.RecoveryStrategy
 
doRefine() - Method in class org.apache.solr.search.facet.FacetRequest
 
doReloadAction(PackageListeners.Listener.Ctx) - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
doRemove(SolrInputDocument, SolrInputField, Object) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
doRemoveRegex(SolrInputDocument, SolrInputField, Object) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
doRestore() - Method in class org.apache.solr.handler.RestoreCore
 
doRetrieveStatsRequest(ResponseBuilder) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
doRetrieveStatsRequest(ResponseBuilder) - Method in class org.apache.solr.search.stats.LocalStatsCache
 
doRetrieveStatsRequest(ResponseBuilder) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
doRetrieveStatsRequest(ResponseBuilder) - Method in class org.apache.solr.search.stats.StatsCache
 
doReturnLocalStats(ResponseBuilder, SolrIndexSearcher) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
doReturnLocalStats(ResponseBuilder, SolrIndexSearcher) - Method in class org.apache.solr.search.stats.LocalStatsCache
 
doReturnLocalStats(ResponseBuilder, SolrIndexSearcher) - Method in class org.apache.solr.search.stats.StatsCache
 
doSendGlobalStats(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
doSendGlobalStats(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.stats.LocalStatsCache
 
doSendGlobalStats(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.stats.StatsCache
 
doSet(SolrInputDocument, SolrInputField, Object) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
doSetNextReader(LeafReaderContext) - Method in class org.apache.solr.search.DelegatingCollector
 
doSetNextReader(LeafReaderContext) - Method in class org.apache.solr.search.DocSetCollector
 
doSetNextReader(LeafReaderContext) - Method in class org.apache.solr.search.join.GraphPointsCollector
 
doSetNextReader(LeafReaderContext) - Method in class org.apache.solr.search.join.MultiValueTermOrdinalCollector
 
doSimpleQuery(String, SolrQueryRequest, int, int) - Static method in class org.apache.solr.util.SolrPluginUtils
Executes a basic query
doSingleStateUpdate(DistributedClusterStateUpdater.MutatingCommand, ZkNodeProps, SolrCloudManager, ZkStateReader) - Method in class org.apache.solr.cloud.DistributedClusterStateUpdater
Syntactic sugar to allow a single change to the cluster state to be made in a single call.
doSnapShoot(int, int, String, String, String, String, SolrCore, Consumer<NamedList<?>>) - Method in class org.apache.solr.handler.admin.api.SnapshotBackupAPI
Separate method helps with testing
doSnapShoot(int, int, String, String, String, String, SolrCore, Consumer<NamedList<?>>) - Static method in class org.apache.solr.handler.ReplicationHandler
 
doSplit() - Method in class org.apache.solr.update.SolrIndexSplitter
 
doStandardDebug(SolrQueryRequest, String, Query, DocList, boolean, boolean) - Static method in class org.apache.solr.util.SolrPluginUtils
Returns a NamedList containing many "standard" pieces of debugging information.
doStandardQueryDebug(SolrQueryRequest, String, Query, boolean, NamedList<Object>) - Static method in class org.apache.solr.util.SolrPluginUtils
 
doStandardResultsDebug(SolrQueryRequest, Query, DocList, boolean, NamedList<Object>) - Static method in class org.apache.solr.util.SolrPluginUtils
 
doStats - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
doSyncOrReplicateRecovery(SolrCore) - Method in class org.apache.solr.cloud.RecoveryStrategy
 
doTerms - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
DOUBLE - org.apache.solr.legacy.LegacyNumericType
Deprecated.
64-bit double numeric type
DOUBLE - org.apache.solr.schema.NumberType
 
DOUBLE_POINT - org.apache.solr.uninverting.UninvertingReader.Type
Single-valued Integer, (e.g.
DOUBLE_POINT_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
A parser instance for double values encoded by NumericUtils, e.g.
double2sortableStr(double) - Static method in class org.apache.solr.util.NumberUtils
 
double2sortableStr(String) - Static method in class org.apache.solr.util.NumberUtils
 
DoubleFuncSlotAcc(ValueSource, FacetContext, int) - Constructor for class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
DoubleFuncSlotAcc(ValueSource, FacetContext, int, double) - Constructor for class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
doubleOrFloat - Static variable in class org.apache.solr.schema.NumericFieldType
 
DoublePointField - Class in org.apache.solr.schema
PointField implementation for Double values.
DoublePointField() - Constructor for class org.apache.solr.schema.DoublePointField
 
doubleVal(int) - Method in class org.apache.solr.search.function.CollapseScoreFunction.CollapseScoreFunctionValues
 
DoubleValueFieldType - Interface in org.apache.solr.schema
Marker interface for double-valued field types.
DOWN - org.apache.solr.cluster.Replica.ReplicaState
 
download(String) - Method in class org.apache.solr.packagemanager.DefaultPackageRepository
 
download(String) - Method in class org.apache.solr.packagemanager.PackageRepository
Provides a method to download an artifact from this repository.
downloadCollectionProperties(String) - Method in class org.apache.solr.core.backup.BackupManager
 
downloadConfig(String, Path) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
downloadConfig(String, Path) - Method in class org.apache.solr.core.ConfigSetService
Download all files from this config to the filesystem at dir
downloadConfig(String, Path) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
downloadConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
downloadConfigDir(String, ConfigSetService) - Method in class org.apache.solr.core.backup.BackupManager
This method stores the contents of a specified Solr config at the specified location in repository.
downloadFileFromConfig(String, String) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
downloadFileFromConfig(String, String) - Method in class org.apache.solr.core.ConfigSetService
Download a file from config If the file does not exist, it returns null
downloadFileFromConfig(String, String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
downNode(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.NodeMutator
 
DOWNNODE - org.apache.solr.cloud.overseer.OverseerAction
 
doWork(Object...) - Method in class org.apache.solr.handler.HaversineMetersEvaluator
 
dropBufferedUpdates() - Method in class org.apache.solr.update.UpdateLog
Returns true if we were able to drop buffered updates and return to the ACTIVE state
DualDoubleFunction - Class in org.apache.solr.search.function
Abstract ValueSource implementation which wraps two ValueSources and applies an extendible double function to their values.
DualDoubleFunction(ValueSource, ValueSource) - Constructor for class org.apache.solr.search.function.DualDoubleFunction
 
DummyErrorStream(Exception) - Constructor for class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
DummyErrorStream(Exception) - Constructor for class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
DumpRequestHandler - Class in org.apache.solr.handler
 
DumpRequestHandler() - Constructor for class org.apache.solr.handler.DumpRequestHandler
 
DV - org.apache.solr.search.facet.FacetField.FacetMethod
 
DVHASH - org.apache.solr.search.facet.FacetField.FacetMethod
 
DVOrdValues(SortedDocValues, DocIdSetIterator) - Constructor for class org.apache.solr.search.facet.FieldUtil.DVOrdValues
 
DYNAMIC_FIELD - Static variable in class org.apache.solr.schema.IndexSchema
 
DYNAMIC_FIELDS - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
DYNAMIC_FIELDS - Static variable in class org.apache.solr.schema.IndexSchema
 
dynamicCopyFields - Variable in class org.apache.solr.schema.IndexSchema
 
dynamicFieldCache - Variable in class org.apache.solr.schema.IndexSchema
 
dynamicFieldInfo - Variable in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaGetDynamicFieldInfoResponse
 
dynamicFieldListToSortedArray(List<IndexSchema.DynamicField>) - Static method in class org.apache.solr.schema.IndexSchema
Sort the dynamic fields and stuff them in a normal array for faster access.
dynamicFields - Variable in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListDynamicFieldsResponse
 
dynamicFields - Variable in class org.apache.solr.schema.IndexSchema
 
DynamicMap - Interface in org.apache.solr.util
An efficient map for storing keys as integer in range from 0..n with n can be estimated up-front.
DynamicPattern(String, String) - Constructor for class org.apache.solr.schema.IndexSchema.DynamicReplacement.DynamicPattern
 
DynamicReplacement(String) - Constructor for class org.apache.solr.schema.IndexSchema.DynamicReplacement
 
dynFieldProps - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 

E

e - Variable in exception org.apache.solr.servlet.ExceptionWhileTracing
 
e - Variable in class org.apache.solr.update.SolrCmdDistributor.SolrError
 
EarlyTerminatingCollector - Class in org.apache.solr.search
A wrapper Collector that throws EarlyTerminatingCollectorException) once a specified maximum number of documents are collected.
EarlyTerminatingCollector(Collector, int) - Constructor for class org.apache.solr.search.EarlyTerminatingCollector
Wraps a Collector, throwing EarlyTerminatingCollectorException once the specified maximum is reached.
EarlyTerminatingCollectorException - Exception in org.apache.solr.search
Thrown by EarlyTerminatingCollector when the maximum to abort the scoring / collection process early, when the specified maximum number of documents were collected.
EarlyTerminatingCollectorException(int, int) - Constructor for exception org.apache.solr.search.EarlyTerminatingCollectorException
 
eatws() - Method in class org.apache.solr.search.StrParser
 
echo(String) - Method in class org.apache.solr.cli.ToolBase
 
echoIfVerbose(String, CommandLine) - Method in class org.apache.solr.cli.ToolBase
 
edit(Map<String, Object>, List<CommandOperation>) - Method in class org.apache.solr.security.BasicAuthPlugin
 
edit(Map<String, Object>, List<CommandOperation>) - Method in interface org.apache.solr.security.ConfigEditablePlugin
Operate the commands on the latest conf and return a new conf object If there are errors in the commands , throw a SolrException.
edit(Map<String, Object>, List<CommandOperation>) - Method in class org.apache.solr.security.MultiAuthPlugin
 
edit(Map<String, Object>, List<CommandOperation>) - Method in class org.apache.solr.security.MultiAuthRuleBasedAuthorizationPlugin
 
edit(Map<String, Object>, List<CommandOperation>) - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
 
edit(Map<String, Object>, List<CommandOperation>) - Method in class org.apache.solr.security.Sha256AuthenticationProvider
 
Edit() - Constructor for class org.apache.solr.handler.admin.ContainerPluginsApi.Edit
 
Edit() - Constructor for class org.apache.solr.pkg.PackageAPI.Edit
 
editAPI - Variable in class org.apache.solr.handler.admin.ContainerPluginsApi
 
editAPI - Variable in class org.apache.solr.pkg.PackageAPI
 
effectiveId() - Method in class org.apache.solr.core.SolrConfig
Generates a String ID to represent the SolrConfig
elapsed() - Method in interface org.apache.solr.util.RTimer.TimerImpl
 
ElectionContext - Class in org.apache.solr.cloud
 
ElectionContext(String, String, String, ZkNodeProps, SolrZkClient) - Constructor for class org.apache.solr.cloud.ElectionContext
 
elevatedIds - Variable in class org.apache.solr.handler.component.QueryElevationComponent.Elevation
 
ElevatedMarkerFactory - Class in org.apache.solr.response.transform
Used to mark whether a document has been elevated or not
ElevatedMarkerFactory() - Constructor for class org.apache.solr.response.transform.ElevatedMarkerFactory
 
ElevatingQuery(String, boolean) - Constructor for class org.apache.solr.handler.component.QueryElevationComponent.ElevatingQuery
 
Elevation(Set<BytesRef>, Set<BytesRef>, String) - Constructor for class org.apache.solr.handler.component.QueryElevationComponent.Elevation
Constructs an elevation.
Elevation(Set<BytesRef>, BooleanQuery, Set<BytesRef>, TermQuery[]) - Constructor for class org.apache.solr.handler.component.QueryElevationComponent.Elevation
 
ElevationBuilder() - Constructor for class org.apache.solr.handler.component.QueryElevationComponent.ElevationBuilder
 
EmbeddedSolrServer - Class in org.apache.solr.client.solrj.embedded
SolrClient that connects directly to a CoreContainer.
EmbeddedSolrServer(Path, String) - Constructor for class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
Create an EmbeddedSolrServer using a given solr home directory
EmbeddedSolrServer(CoreContainer, String) - Constructor for class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
Create an EmbeddedSolrServer wrapping a CoreContainer.
EmbeddedSolrServer(CoreContainer, String, EmbeddedSolrServer.RequestWriterSupplier) - Constructor for class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
Create an EmbeddedSolrServer wrapping a CoreContainer.
EmbeddedSolrServer(NodeConfig, String) - Constructor for class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
Create an EmbeddedSolrServer using a NodeConfig
EmbeddedSolrServer(SolrCore) - Constructor for class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
Create an EmbeddedSolrServer wrapping a particular SolrCore
EmbeddedSolrServer.RequestWriterSupplier - Enum in org.apache.solr.client.solrj.embedded
 
empty() - Static method in class org.apache.solr.core.backup.ShardBackupMetadata
 
empty() - Static method in class org.apache.solr.search.DocSet
An empty instance (has no docs).
empty(Directory) - Static method in class org.apache.solr.core.DirectoryFactory
Delete the files in the Directory
EMPTY - org.apache.solr.util.hll.HLLType
 
EMPTY - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
EMPTY - Static variable in class org.apache.solr.update.PeerSync.MissedUpdatesRequest
 
EMPTY - Static variable in class org.apache.solr.util.DataConfigNode
 
EMPTY_BYTES_SET - Static variable in class org.apache.solr.handler.AnalysisRequestHandlerBase
 
EMPTY_CONFIG_FILE - org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
The elevation configuration file (e.g.
EMPTY_INFO - Static variable in class org.apache.solr.core.PluginInfo
 
EMPTY_SPEC - Static variable in class org.apache.solr.api.ApiBag
 
emptyArray(String[]) - Method in class org.apache.solr.highlight.SolrHighlighter
 
ENABLE - org.apache.solr.handler.PingRequestHandler.ACTIONS
 
ENABLE_DYNAMIC_FIELDS_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
ENABLE_FIELD_GUESSING_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
ENABLE_GRAPH_QUERIES - Static variable in class org.apache.solr.schema.FieldType
 
ENABLE_NESTED_DOCS_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
enable_tracing() - Method in class org.apache.solr.parser.QueryParser
Enable tracing.
enabled - Variable in class org.apache.solr.metrics.SolrMetricReporter
 
enableDocIdsCache(int) - Method in class org.apache.solr.handler.tagger.Tagger
 
enableGraphQueries - Variable in class org.apache.solr.schema.TextField
 
enableLazyFieldLoading - Variable in class org.apache.solr.core.SolrConfig
 
enablePackages - Variable in class org.apache.solr.pkg.PackageAPI
 
enableResponseBuffering() - Method in class org.apache.solr.jersey.container.JettyBridgeResponseWriter
 
ENCAPSULATOR - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
ENCAPSULATOR_DISABLED - Static variable in class org.apache.solr.internal.csv.CSVStrategy
 
encode(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
encodeRefinementValuePath(List<String>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
Encodes a value path as a string for the purposes of a refinement request
encoders - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
 
encodeSnippets(String[], String[], Map<String, String[]>) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter
Encodes the resulting snippets into a namedlist
encrypt(ByteBuffer) - Method in class org.apache.solr.util.CryptoKeys.RSAKeyPair
 
end - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
end - Variable in class org.apache.solr.search.StrParser
 
end() - Method in class org.apache.solr.analysis.LowerCaseTokenizer
Deprecated.
 
END_MESSAGE - Static variable in class org.apache.solr.update.TransactionLog
 
END_TIME_PROP - Static variable in class org.apache.solr.core.backup.BackupManager
 
endColumn - Variable in class org.apache.solr.parser.Token
The column number of the last character of this Token.
endLine - Variable in class org.apache.solr.parser.Token
The line number of the last character of this Token.
endObj - Variable in class org.apache.solr.handler.component.RangeFacetRequest
The computed end value of this range taking into account facet.range.hardend
endOffsets - Variable in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory.Resolved
 
endpoint - Variable in class org.apache.solr.rest.RestManager
 
EndPoint - Annotation Type in org.apache.solr.api
 
endRecord(long) - Method in class org.apache.solr.update.TransactionLog
 
EndResultTransformer - Interface in org.apache.solr.search.grouping.endresulttransformer
Responsible for transforming the grouped result into the final format for displaying purposes.
EndResultTransformer.SolrDocumentSource - Interface in org.apache.solr.search.grouping.endresulttransformer
Abstracts the source for SolrDocument instances.
endsWithCommit() - Method in class org.apache.solr.update.TransactionLog
 
endTime - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
endTime - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
enforcePrefix(String) - Static method in class org.apache.solr.metrics.SolrMetricManager
Enforces the leading SolrMetricManager.REGISTRY_NAME_PREFIX in a name.
enqueueUpdate(ClusterState, List<ZkWriteCommand>, ZkStateWriter.ZkWriteCallback) - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
Applies the given ZkWriteCommand on the prevState.
ensureBufferTlog() - Method in class org.apache.solr.update.UpdateLog
 
ensureCollectionAndShardExist(ClusterState, String, String) - Static method in class org.apache.solr.handler.admin.api.InstallShardData
 
ensureConfigSetUploadEnabled() - Method in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
ensureHighestTermsAreNotZero() - Method in class org.apache.solr.cloud.ZkShardTerms
When first updates come in, all replicas have some data now, so we must switch from term 0 (registered) to 1 (have some data)
ensureLog() - Method in class org.apache.solr.update.UpdateLog
 
ensureNonEmptyInputStream(SolrQueryRequest) - Method in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
ensureRequiredFieldPresent(Object, String) - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.RoutedAliasProperties
 
ensureRequiredParameterProvided(String, Object) - Method in class org.apache.solr.api.JerseyResource
 
ensureRequiredRequestBodyProvided(Object) - Method in class org.apache.solr.api.JerseyResource
 
ensureTermsIsHigher(String, Set<String>) - Method in class org.apache.solr.cloud.ZkShardTerms
Ensure that terms are higher than some replica's terms.
ensureUniqueKey(SchemaField, List<SolrInputDocument>) - Method in interface org.apache.solr.handler.designer.SampleDocumentsLoader
Ensure every sample document has a unique ID, but only applies if the unique key field is a string.
ENTRY_SEPARATOR - Static variable in class org.apache.solr.search.stats.StatsUtil
 
ENTRY_SEPARATOR_CHAR - Static variable in class org.apache.solr.search.stats.StatsUtil
 
entrySet() - Method in class org.apache.solr.util.MapListener
 
ENUM - org.apache.solr.search.facet.FacetField.FacetMethod
 
EnumField - Class in org.apache.solr.schema
Deprecated.
use EnumFieldType instead.
EnumField() - Constructor for class org.apache.solr.schema.EnumField
Deprecated.
 
EnumFieldType - Class in org.apache.solr.schema
Field type for support of string values with custom sort order.
EnumFieldType() - Constructor for class org.apache.solr.schema.EnumFieldType
 
enumIntToStringMap - Variable in class org.apache.solr.schema.AbstractEnumField.EnumMapping
 
enumMapping - Variable in class org.apache.solr.schema.AbstractEnumField
 
EnumMapping(IndexSchema, FieldType, Map<String, String>) - Constructor for class org.apache.solr.schema.AbstractEnumField.EnumMapping
Takes in a FieldType and the initArgs Map used for that type, removing the keys that specify the enum.
enumStringToIntMap - Variable in class org.apache.solr.schema.AbstractEnumField.EnumMapping
 
envNameToSyspropName(String) - Static method in class org.apache.solr.core.TracerConfigurator
In OTEL Java SDK there is a convention that the java property name for OTEL_FOO_BAR is otel.foo.bar
EnvSSLCredentialProvider - Class in org.apache.solr.util.configuration.providers
Environment variable based SSL configuration provider
EnvSSLCredentialProvider() - Constructor for class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider
 
EnvSSLCredentialProvider.EnvVars - Class in org.apache.solr.util.configuration.providers
 
EnvVars() - Constructor for class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider.EnvVars
 
EOF - Static variable in interface org.apache.solr.parser.QueryParserConstants
End of File.
EOL - Static variable in exception org.apache.solr.parser.ParseException
The end of line string for this machine.
EphemeralDirectoryFactory - Class in org.apache.solr.core
Directory provider for implementations that do not persist over reboots.
EphemeralDirectoryFactory() - Constructor for class org.apache.solr.core.EphemeralDirectoryFactory
 
ephemeralOwner - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
EqualFunction - Class in org.apache.solr.search.function
Compares two values for equality.
EqualFunction(ValueSource, ValueSource, String) - Constructor for class org.apache.solr.search.function.EqualFunction
 
equals(int, int) - Method in class org.apache.solr.util.PrimUtils.IntComparator
 
equals(Object) - Method in class org.apache.solr.cloud.api.collections.RoutedAlias.Action
 
equals(Object) - Method in class org.apache.solr.cloud.OverseerTaskQueue.QueueEvent
 
equals(Object) - Method in class org.apache.solr.cloud.RecoveringCoreTermWatcher
 
equals(Object) - Method in class org.apache.solr.cluster.placement.impl.MetricImpl
 
equals(Object) - Method in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
equals(Object) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
equals(Object) - Method in class org.apache.solr.core.backup.BackupId
 
equals(Object) - Method in class org.apache.solr.core.backup.Checksum
 
equals(Object) - Method in class org.apache.solr.filestore.FileStoreAPI.MetaData
 
equals(Object) - Method in class org.apache.solr.handler.component.QueryElevationComponent.ElevatingQuery
 
equals(Object) - Method in class org.apache.solr.handler.component.ShardDoc
 
equals(Object) - Method in class org.apache.solr.legacy.LegacyFieldType
Deprecated.
 
equals(Object) - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
 
equals(Object) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
equals(Object) - Method in class org.apache.solr.metrics.SolrMetricInfo
 
equals(Object) - Method in class org.apache.solr.packagemanager.SolrPackageInstance
 
equals(Object) - Method in class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
equals(Object) - Method in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
equals(Object) - Method in class org.apache.solr.query.FilterQuery
 
equals(Object) - Method in class org.apache.solr.query.SolrRangeQuery
 
equals(Object) - Method in class org.apache.solr.request.SimpleFacets.CountPair
 
equals(Object) - Method in class org.apache.solr.schema.FileExchangeRateProvider
 
equals(Object) - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
equals(Object) - Method in class org.apache.solr.schema.RandomSortField.RandomValueSource
 
equals(Object) - Method in class org.apache.solr.schema.SchemaField
 
equals(Object) - Method in class org.apache.solr.schema.StrFieldSource
 
equals(Object) - Method in class org.apache.solr.schema.ZkIndexSchemaReader
 
equals(Object) - Method in class org.apache.solr.search.AnalyticsQuery
 
equals(Object) - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
equals(Object) - Method in class org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelector
 
equals(Object) - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
equals(Object) - Method in class org.apache.solr.search.facet.AggValueSource
 
equals(Object) - Method in class org.apache.solr.search.facet.FacetRequest.FacetSort
 
equals(Object) - Method in class org.apache.solr.search.facet.PercentileAgg
 
equals(Object) - Method in class org.apache.solr.search.facet.RelatednessAgg
 
equals(Object) - Method in class org.apache.solr.search.facet.SimpleAggValueSource
 
equals(Object) - Method in class org.apache.solr.search.facet.StrAggValueSource
 
equals(Object) - Method in class org.apache.solr.search.FloatPayloadValueSource
 
equals(Object) - Method in class org.apache.solr.search.function.CollapseScoreFunction
 
equals(Object) - Method in class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
equals(Object) - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
equals(Object) - Method in class org.apache.solr.search.function.distance.HaversineConstFunction
 
equals(Object) - Method in class org.apache.solr.search.function.distance.HaversineFunction
 
equals(Object) - Method in class org.apache.solr.search.function.distance.SquaredEuclideanFunction
 
equals(Object) - Method in class org.apache.solr.search.function.distance.StringDistanceFunction
 
equals(Object) - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
equals(Object) - Method in class org.apache.solr.search.function.DualDoubleFunction
 
equals(Object) - Method in class org.apache.solr.search.function.FieldNameValueSource
 
equals(Object) - Method in class org.apache.solr.search.function.FileFloatSource
 
equals(Object) - Method in class org.apache.solr.search.function.MultiStringFunction
 
equals(Object) - Method in class org.apache.solr.search.function.OrdFieldSource
 
equals(Object) - Method in class org.apache.solr.search.function.ReverseOrdFieldSource
 
equals(Object) - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
equals(Object) - Method in class org.apache.solr.search.FunctionRangeQuery
 
equals(Object) - Method in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
equals(Object) - Method in class org.apache.solr.search.join.GraphQuery
 
equals(Object) - Method in class org.apache.solr.search.join.HashRangeQuery
 
equals(Object) - Method in class org.apache.solr.search.MatchCostQuery
 
equals(Object) - Method in class org.apache.solr.search.QueryResultKey
 
equals(Object) - Method in class org.apache.solr.search.ReRankScaler
 
equals(Object) - Method in class org.apache.solr.search.WrappedQuery
 
equals(Object) - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
equals(Object) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
equals(Object) - Method in class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
 
equals(Object) - Method in class org.apache.solr.spelling.ResultEntry
 
equals(Object) - Method in class org.apache.solr.spelling.Token
Deprecated.
 
equals(Object) - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain.ProcessorInfo
 
equals(Object) - Method in class org.apache.solr.update.SolrCmdDistributor.ForwardNode
 
equals(Object) - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
equals(Object) - Method in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
equals(DocSet, DocSet) - Static method in class org.apache.solr.search.DocSetUtil
Iterates DocSets to test for equality - slow and for testing purposes only.
err - Variable in class org.apache.solr.response.SolrQueryResponse
 
err(String) - Static method in interface org.apache.solr.cli.CLIO
 
ERR - Static variable in class org.apache.solr.api.AnnotatedApi
 
ERR_MSG - Static variable in class org.apache.solr.pkg.PackageAPI
 
ERR_STATUS - Static variable in class org.apache.solr.handler.ReplicationHandler
 
error(String) - Method in class org.apache.solr.cloud.Stats
 
error(String) - Method in class org.apache.solr.util.RecordingJSONParser
 
error(String, String, Exception) - Method in class org.apache.solr.util.FileTypeMagicUtil
 
ERROR - org.apache.solr.metrics.SolrMetricManager.ResolutionStrategy
An exception will be thrown.
ERROR - org.apache.solr.security.AuditEvent.EventType
 
ERROR - org.apache.solr.security.AuditEvent.Level
 
ERROR_DETAILS - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
ERROR_MESSAGE - Static variable in class org.apache.solr.servlet.RateLimitManager
 
errorCode - Variable in class org.apache.solr.update.processor.IgnoreCommitOptimizeUpdateProcessorFactory
 
errorMessage() - Method in class org.apache.solr.util.vector.ByteDenseVectorParser
 
errorMessage() - Method in class org.apache.solr.util.vector.DenseVectorParser
 
errorMessage() - Method in class org.apache.solr.util.vector.FloatDenseVectorParser
 
errors - Variable in class org.apache.solr.cloud.Stats.Stat
 
errors - Variable in exception org.apache.solr.update.processor.DistributedUpdateProcessor.DistributedUpdatesAsyncException
 
errors - Variable in class org.apache.solr.update.SolrCmdDistributor.Response
 
errors - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
 
escape(String) - Static method in class org.apache.solr.parser.SolrQueryParserBase
Returns a String where those characters that QueryParser expects to be escaped are escaped by a preceding \.
ESCAPE - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
ESCAPE - Static variable in class org.apache.solr.search.stats.StatsUtil
 
ESCAPE_DISABLED - Static variable in class org.apache.solr.internal.csv.CSVStrategy
 
ESCAPE_ENTRY_SEPARATOR - Static variable in class org.apache.solr.search.stats.StatsUtil
 
estimate() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator
 
Estimate(Map<String, Long>, Map<String, Long>, Map<String, Object>, Map<String, Object>) - Constructor for class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
evaluate(String, QName) - Method in class org.apache.solr.core.XmlConfigFile
 
evaluate(Tuple) - Method in class org.apache.solr.handler.AnalyzeEvaluator
 
evaluate(Tuple) - Method in class org.apache.solr.handler.HaversineMetersEvaluator
 
eventTypes - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
evictedEntry(K, V) - Method in interface org.apache.solr.util.ConcurrentLRUCache.EvictionListener
 
EVICTIONS_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
EXACT_MATCH_FIRST - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
If true, exact suggestions are returned first, even if they are prefixes of other strings in the automaton (possibly with larger weights).
EXACT_MATCH_FIRST - Static variable in class org.apache.solr.spelling.suggest.fst.FSTLookupFactory
If true, exact suggestions are returned first, even if they are prefixes of other strings in the automaton (possibly with larger weights).
EXACT_MATCH_FIRST - Static variable in class org.apache.solr.spelling.suggest.fst.WFSTLookupFactory
If true, exact suggestions are returned first, even if they are prefixes of other strings in the automaton (possibly with larger weights).
ExactSharedStatsCache - Class in org.apache.solr.search.stats
This class implements exact caching of statistics.
ExactSharedStatsCache() - Constructor for class org.apache.solr.search.stats.ExactSharedStatsCache
 
ExactStatsCache - Class in org.apache.solr.search.stats
This class implements exact caching of statistics.
ExactStatsCache() - Constructor for class org.apache.solr.search.stats.ExactStatsCache
 
ExactStatsCache.ExactStatsSource - Class in org.apache.solr.search.stats
 
ExactStatsSource(StatsCache.StatsCacheMetrics, Map<String, TermStats>, Map<String, CollectionStats>) - Constructor for class org.apache.solr.search.stats.ExactStatsCache.ExactStatsSource
 
exampleDir - Variable in class org.apache.solr.cli.RunExampleTool
 
EXCEL_STRATEGY - Static variable in class org.apache.solr.internal.csv.CSVStrategy
 
exception - Variable in class org.apache.solr.core.CoreContainer.CoreLoadFailure
 
exception - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileListResponse
 
exception - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationResponse
 
EXCEPTION - Static variable in class org.apache.solr.handler.ReplicationHandler
 
exceptionIsAuthRelated(Exception) - Static method in class org.apache.solr.cli.SolrCLI
 
ExceptionWhileTracing - Exception in org.apache.solr.servlet
 
ExceptionWhileTracing(Exception) - Constructor for exception org.apache.solr.servlet.ExceptionWhileTracing
 
ExceptionWithErrObject(SolrException.ErrorCode, String, List<Map<String, Object>>) - Constructor for exception org.apache.solr.api.ApiBag.ExceptionWithErrObject
 
ExchangeRateProvider - Interface in org.apache.solr.schema
Interface for providing pluggable exchange rate providers to @CurrencyField
exclude(Collection<QParser>) - Method in class org.apache.solr.search.join.FiltersQParser
 
EXCLUDED - Static variable in class org.apache.solr.handler.component.QueryElevationComponent
Key to SolrQueryRequest.getContext() for a Set<BytesRef> of excluded IDs.
excludedIds - Variable in class org.apache.solr.handler.component.QueryElevationComponent.Elevation
 
ExcludedMarkerFactory - Class in org.apache.solr.response.transform
 
ExcludedMarkerFactory() - Constructor for class org.apache.solr.response.transform.ExcludedMarkerFactory
 
excludeQueries - Variable in class org.apache.solr.handler.component.QueryElevationComponent.Elevation
 
excludeTags - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
Specifies query/filter tags that should be excluded to re-compute the domain from the parent context.
execute() - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
After initialization, call execute to start the post job.
execute() - Method in class org.apache.solr.search.grouping.CommandHandler
 
execute() - Method in class org.apache.solr.search.Grouping
 
execute(Integer, Runnable) - Method in class org.apache.solr.util.OrderedExecutor
Execute the given command in the future.
execute(Runnable) - Method in class org.apache.solr.util.OrderedExecutor
 
execute(HttpRequest, HttpClientConnection, HttpContext) - Method in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
execute(CoreAdminHandler.CallInfo) - Method in interface org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminOp
 
execute(CoreAdminHandler.CallInfo) - Method in enum org.apache.solr.handler.admin.CoreAdminOperation
 
execute(CoreAdminHandler.CallInfo) - Method in class org.apache.solr.handler.admin.InstallCoreDataOp
 
execute(SolrQueryRequest, SolrQueryResponse, CollectionsHandler) - Method in enum org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
execute(SolrRequestHandler, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.core.SolrCore
 
executeCoreRequest(SolrQueryResponse) - Method in class org.apache.solr.api.V2HttpCall
Executes the API or Jersey resource corresponding to a core-level request.
executeCoreRequest(SolrQueryResponse) - Method in class org.apache.solr.servlet.HttpSolrCall
 
executeNodeDownStateUpdate(String, ZkStateReader) - Method in class org.apache.solr.cloud.DistributedClusterStateUpdater
 
executeStateUpdates(SolrCloudManager, ZkStateReader) - Method in class org.apache.solr.cloud.DistributedClusterStateUpdater.StateChangeRecorder
Using optimistic locking (and retries when needed) updates Zookeeper with the changes previously recorded by calls to DistributedClusterStateUpdater.StateChangeRecorder.record(MutatingCommand, ZkNodeProps).
executor - Variable in class org.apache.solr.cli.RunExampleTool
 
executorService - Variable in class org.apache.solr.handler.component.IterativeMergeStrategy
 
existingPropsFile - Variable in class org.apache.solr.core.backup.BackupManager
 
existOldBufferLog - Variable in class org.apache.solr.update.UpdateLog
 
existOldBufferLog() - Method in class org.apache.solr.update.UpdateLog
 
exists(int) - Method in class org.apache.solr.search.BitDocSet
Returns true of the doc exists in the set.
exists(int) - Method in class org.apache.solr.search.DocSet
Returns true if a document is in the DocSet.
exists(int) - Method in class org.apache.solr.search.SortedIntDocSet
 
exists(String) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
exists(String) - Method in class org.apache.solr.core.DirectoryFactory
Returns true if a Directory exists for a given path in the underlying (stable) storage and contains at least one file.
exists(String) - Method in class org.apache.solr.core.EphemeralDirectoryFactory
 
exists(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.FileStorageIO
 
exists(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.InMemoryStorageIO
 
exists(String) - Method in interface org.apache.solr.rest.ManagedResourceStorage.StorageIO
 
exists(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
exists(URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method checks if the specified path exists in this repository.
exists(URI) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
exit(int) - Static method in class org.apache.solr.cli.SolrCLI
 
expand() - Method in class org.apache.solr.request.macro.MacroExpander
 
expand(String) - Method in class org.apache.solr.request.macro.MacroExpander
 
expand(Map<String, String[]>) - Static method in class org.apache.solr.request.macro.MacroExpander
 
EXPAND - org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
 
ExpandComponent - Class in org.apache.solr.handler.component
The ExpandComponent is designed to work with the CollapsingPostFilter.
ExpandComponent() - Constructor for class org.apache.solr.handler.component.ExpandComponent
 
ExpandingIntArray(int) - Constructor for class org.apache.solr.search.DocSetCollector.ExpandingIntArray
 
expandWildcardsInFields(Supplier<Collection<String>>, String...) - Static method in class org.apache.solr.highlight.SolrHighlighter
 
expect(String) - Method in class org.apache.solr.search.StrParser
 
expect(JSONParser, int) - Static method in class org.apache.solr.request.json.JSONUtil
 
expected - Variable in class org.apache.solr.packagemanager.SolrPackage.Command
 
expectedTokenSequences - Variable in exception org.apache.solr.parser.ParseException
Each entry in this array is an array of integers.
EXPECTING_NON_LEADER - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
ExperimentalResponse - Class in org.apache.solr.jersey
SolrJerseyResponse implementation with a warning field indicating that the format may change
ExperimentalResponse() - Constructor for class org.apache.solr.jersey.ExperimentalResponse
 
explain() - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
explain(int, Explanation, Explanation) - Method in class org.apache.solr.search.ReRankScaler
 
explain(String) - Method in class org.apache.solr.search.ReRankScaler.MinMaxExplain
 
explain(LeafReaderContext, int) - Method in class org.apache.solr.search.join.GraphQuery.GraphQueryWeight
 
explain(LeafReaderContext, int) - Method in class org.apache.solr.search.ReRankWeight
 
explain(Query, int) - Method in class org.apache.solr.search.SolrIndexSearcher
 
ExplainAugmenterFactory - Class in org.apache.solr.response.transform
 
ExplainAugmenterFactory() - Constructor for class org.apache.solr.response.transform.ExplainAugmenterFactory
 
ExplainAugmenterFactory.Style - Enum in org.apache.solr.response.transform
 
explanation - Variable in enum org.apache.solr.security.AuditEvent.EventType
 
explanationsToNamedLists(NamedList<Explanation>) - Static method in class org.apache.solr.util.SolrPluginUtils
 
explanationToNamedList(Explanation) - Static method in class org.apache.solr.util.SolrPluginUtils
 
EXPLICIT - org.apache.solr.util.hll.HLLType
 
explicitField - Variable in class org.apache.solr.parser.SolrQueryParserBase
 
explicitQueries - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
An explicit query domain, ignoring all parent context, expressed in JSON query format.
EXPONENT - Static variable in class org.apache.solr.search.RankQParserPlugin
 
ExportHandler - Class in org.apache.solr.handler
 
ExportHandler() - Constructor for class org.apache.solr.handler.ExportHandler
 
ExportHandler.ExportHandlerStreamFactory - Class in org.apache.solr.handler
 
ExportHandlerStreamFactory() - Constructor for class org.apache.solr.handler.ExportHandler.ExportHandlerStreamFactory
 
ExportQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.ExportQParserPlugin.ExportQParser
 
ExportQParserPlugin - Class in org.apache.solr.search
 
ExportQParserPlugin() - Constructor for class org.apache.solr.search.ExportQParserPlugin
 
ExportQParserPlugin.ExportQParser - Class in org.apache.solr.search
 
ExportQParserPlugin.ExportQuery - Class in org.apache.solr.search
 
ExportQuery() - Constructor for class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
ExportQuery(SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
ExportTool - Class in org.apache.solr.cli
 
ExportTool() - Constructor for class org.apache.solr.cli.ExportTool
 
ExportTool.Info - Class in org.apache.solr.cli
 
ExportWriter - Class in org.apache.solr.handler.export
Prepares and writes the documents requested by /export requests
ExportWriter(SolrQueryRequest, SolrQueryResponse, String, StreamContext, SolrMetricsContext, String) - Constructor for class org.apache.solr.handler.export.ExportWriter
 
ExportWriter.IgnoreException - Exception in org.apache.solr.handler.export
 
ExportWriterStream - Class in org.apache.solr.handler.export
Stream implementation that helps supporting 'expr' streaming in export writer.
ExportWriterStream(StreamExpression, StreamFactory) - Constructor for class org.apache.solr.handler.export.ExportWriterStream
 
EXPR_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
ExpressibleHolder(PluginInfo, SolrCore, SolrConfig.SolrPluginInfo) - Constructor for class org.apache.solr.handler.StreamHandler.ExpressibleHolder
 
expungeDeletes - Variable in class org.apache.solr.update.CommitUpdateCommand
 
ExtendedDismaxConfiguration(SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
ExtendedDismaxQParser - Class in org.apache.solr.search
Query parser that generates DisjunctionMaxQueries based on user configuration.
ExtendedDismaxQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.ExtendedDismaxQParser
 
ExtendedDismaxQParser.Clause - Class in org.apache.solr.search
 
ExtendedDismaxQParser.ExtendedDismaxConfiguration - Class in org.apache.solr.search
Simple container for configuration information used when parsing queries
ExtendedDismaxQParser.ExtendedSolrQueryParser - Class in org.apache.solr.search
A subclass of SolrQueryParser that supports aliasing fields for constructing DisjunctionMaxQueries.
ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias - Class in org.apache.solr.search
A simple container for storing alias info
ExtendedDismaxQParserPlugin - Class in org.apache.solr.search
An advanced multi-field query parser based on the DisMax parser.
ExtendedDismaxQParserPlugin() - Constructor for class org.apache.solr.search.ExtendedDismaxQParserPlugin
 
ExtendedQuery - Interface in org.apache.solr.search
The ExtendedQuery interface provides extra metadata to a query.
ExtendedQueryBase - Class in org.apache.solr.search
 
ExtendedQueryBase() - Constructor for class org.apache.solr.search.ExtendedQueryBase
 
extendedResults - Variable in class org.apache.solr.spelling.SpellingOptions
Provide additional, per implementation, information about the results
ExtendedSolrQueryParser(QParser, String) - Constructor for class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
EXTERNAL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
ExternalFileField - Class in org.apache.solr.schema
Get values from an external file instead of the index.
ExternalFileField() - Constructor for class org.apache.solr.schema.ExternalFileField
 
ExternalFileFieldReloader - Class in org.apache.solr.schema
An event listener to reload ExternalFileFields for new searchers.
ExternalFileFieldReloader(SolrCore) - Constructor for class org.apache.solr.schema.ExternalFileFieldReloader
 
ExternalRoleRuleBasedAuthorizationPlugin - Class in org.apache.solr.security
Rule Based Authz plugin implementation which reads user roles from the request.
ExternalRoleRuleBasedAuthorizationPlugin() - Constructor for class org.apache.solr.security.ExternalRoleRuleBasedAuthorizationPlugin
 
extract(NamedList<T>) - Method in enum org.apache.solr.util.PivotListEntry
Given a NamedList representing a Pivot Value, extracts the Object which corresponds to this PivotListEntry, or returns null if not found.
extractCertificateFromPem(String) - Static method in class org.apache.solr.util.CryptoKeys
Given a file, will try to
extractHandlerFromURLPath(SolrRequestParsers) - Method in class org.apache.solr.servlet.HttpSolrCall
Extract handler from the URL path if not set.
extractPhrases(String, SchemaField, int, int) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Factory method for constructing a list of Phrases given the specified input and using the analyzer for the specified field.
extractRemotePath(String, String) - Method in class org.apache.solr.servlet.HttpSolrCall
 
extractSingleContentStream(SolrQueryRequest, boolean) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 

F

F - Static variable in class org.apache.solr.search.QueryParsing
 
facet(int) - Method in class org.apache.solr.handler.component.FieldFacetStats
 
FACET_COUNTS_KEY - Static variable in class org.apache.solr.handler.component.FacetComponent
 
FACET_FIELD_KEY - Static variable in class org.apache.solr.handler.component.FacetComponent
 
FACET_INTERVALS_KEY - Static variable in class org.apache.solr.handler.component.FacetComponent
 
FACET_QUERY_KEY - Static variable in class org.apache.solr.handler.component.FacetComponent
 
FACET_RANGES_KEY - Static variable in class org.apache.solr.handler.component.FacetComponent
 
FACET_TYPE_PARAMS - Static variable in class org.apache.solr.handler.component.FacetComponent
 
FacetBase(ResponseBuilder, String, String) - Constructor for class org.apache.solr.handler.component.FacetComponent.FacetBase
 
FacetBucket - Class in org.apache.solr.search.facet
 
FacetBucket(FacetModule.FacetBucketMerger, Comparable, FacetMerger.Context) - Constructor for class org.apache.solr.search.facet.FacetBucket
 
FacetComponent - Class in org.apache.solr.handler.component
Computes facets -- aggregations with counts of terms or ranges over the whole search results.
FacetComponent() - Constructor for class org.apache.solr.handler.component.FacetComponent
 
FacetComponent.DistribFieldFacet - Class in org.apache.solr.handler.component
This API is experimental and subject to change
FacetComponent.FacetBase - Class in org.apache.solr.handler.component
This API is experimental and subject to change
FacetComponent.FacetContext - Class in org.apache.solr.handler.component
Encapsulates facet ranges and facet queries such that their parameters are parsed and cached for efficient re-use.
FacetComponent.FacetInfo - Class in org.apache.solr.handler.component
This class is used exclusively for merging results from each shard in a distributed facet request.
FacetComponent.FieldFacet - Class in org.apache.solr.handler.component
This API is experimental and subject to change
FacetComponent.QueryFacet - Class in org.apache.solr.handler.component
This API is experimental and subject to change
FacetComponent.ShardFacetCount - Class in org.apache.solr.handler.component
This API is experimental and subject to change
FacetContext - Class in org.apache.solr.search.facet
 
FacetContext() - Constructor for class org.apache.solr.search.facet.FacetContext
 
FacetDebugInfo - Class in org.apache.solr.search.facet
 
FacetDebugInfo() - Constructor for class org.apache.solr.search.facet.FacetDebugInfo
 
FacetField - Class in org.apache.solr.search.facet
 
FacetField() - Constructor for class org.apache.solr.search.facet.FacetField
 
FacetField.FacetMethod - Enum in org.apache.solr.search.facet
 
FacetFieldMerger - Class in org.apache.solr.search.facet
 
FacetFieldMerger(FacetField) - Constructor for class org.apache.solr.search.facet.FacetFieldMerger
 
FacetHeatmap - Class in org.apache.solr.search.facet
JSON Facet API request for a 2D spatial summary of a rectangular region.
FacetInfo() - Constructor for class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
FacetInterval(SchemaField, String, String, boolean, boolean, String) - Constructor for class org.apache.solr.request.IntervalFacets.FacetInterval
Constructor that accepts already parsed values of start and end.
FacetMerger - Class in org.apache.solr.search.facet
 
FacetMerger() - Constructor for class org.apache.solr.search.facet.FacetMerger
 
FacetMerger.Context - Class in org.apache.solr.search.facet
 
facetMissingNum(int) - Method in class org.apache.solr.handler.component.FieldFacetStats
 
FacetModule - Class in org.apache.solr.search.facet
 
FacetModule() - Constructor for class org.apache.solr.search.facet.FacetModule
 
FacetProcessor<T extends FacetRequest> - Class in org.apache.solr.search.facet
Base abstraction for a class that computes facets.
FacetQuery - Class in org.apache.solr.search.facet
 
FacetQuery() - Constructor for class org.apache.solr.search.facet.FacetQuery
 
FacetRange - Class in org.apache.solr.search.facet
 
FacetRange() - Constructor for class org.apache.solr.search.facet.FacetRange
 
FacetRange(String, String, String, boolean, boolean) - Constructor for class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
Construct a facet range for the give name
FacetRange(FacetParams.FacetRangeOther, String, String, boolean, boolean) - Constructor for class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
Construct a facet range for a FacetParams.FacetRangeOther instance
FacetRangeMerger - Class in org.apache.solr.search.facet
 
FacetRangeMerger(FacetRange) - Constructor for class org.apache.solr.search.facet.FacetRangeMerger
 
facetRanges - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
FacetRequest - Class in org.apache.solr.search.facet
A request to do facets/stats that might itself be composed of sub-FacetRequests.
FacetRequest() - Constructor for class org.apache.solr.search.facet.FacetRequest
 
FacetRequest.Domain - Class in org.apache.solr.search.facet
 
FacetRequest.Domain.GraphField - Class in org.apache.solr.search.facet
Are we doing a query time graph across other documents
FacetRequest.Domain.JoinField - Class in org.apache.solr.search.facet
Are we doing a query time join across other documents
FacetRequest.FacetSort - Class in org.apache.solr.search.facet
Simple structure for encapsulating a sort variable and a direction
FacetRequest.RefineMethod - Enum in org.apache.solr.search.facet
 
FacetRequest.SortDirection - Enum in org.apache.solr.search.facet
 
facets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
FacetSort(String, FacetRequest.SortDirection) - Constructor for class org.apache.solr.search.facet.FacetRequest.FacetSort
 
facetStats - Variable in class org.apache.solr.search.facet.FacetRequest
 
facetStatsValues - Variable in class org.apache.solr.handler.component.FieldFacetStats
 
facetTermNum(int, int) - Method in class org.apache.solr.handler.component.FieldFacetStats
 
facetValue - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
factory - Variable in class org.apache.solr.search.facet.HLLAgg
 
Factory() - Constructor for class org.apache.solr.servlet.CoordinatorHttpSolrCall.Factory
 
failed - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
 
failed() - Method in interface org.apache.solr.cloud.RecoveryStrategy.RecoveryListener
 
failed() - Method in class org.apache.solr.update.DefaultSolrCoreState
called from recoveryStrat on a failed recovery
Failed - org.apache.solr.core.snapshots.CollectionSnapshotMetaData.SnapshotStatus
 
FAILED - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
FAILED_BY_EXCEPTION_MESSAGE - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
FAILED_BY_INTERRUPT_MESSAGE - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
FailedOp(ZkNodeProps, SolrResponse) - Constructor for class org.apache.solr.cloud.Stats.FailedOp
 
failIndexFingerprintRequests - Static variable in class org.apache.solr.util.TestInjection
 
failInExecutePlanAction - Static variable in class org.apache.solr.util.TestInjection
 
failReplicaRequests - Static variable in class org.apache.solr.util.TestInjection
 
failUpdateRequests - Static variable in class org.apache.solr.util.TestInjection
 
failure() - Static method in class org.apache.solr.update.PeerSync.PeerSyncResult
 
failure(boolean) - Static method in class org.apache.solr.update.PeerSync.PeerSyncResult
 
failure(Throwable) - Method in class org.apache.solr.jersey.container.JettyBridgeResponseWriter
 
failureDetails - Variable in class org.apache.solr.cloud.Stats.Stat
 
FALSE_TOKEN - Static variable in class org.apache.solr.schema.BoolField
 
falseProperties - Variable in class org.apache.solr.schema.FieldType
properties explicitly set to false
FAST_VECTOR - org.apache.solr.handler.component.HighlightComponent.HighlightMethod
 
fcontext - Variable in class org.apache.solr.search.facet.SlotAcc
 
FCOrdValues(FieldCacheImpl.SortedDocValuesImpl.Iter, DocIdSetIterator) - Constructor for class org.apache.solr.search.facet.FieldUtil.FCOrdValues
 
fdebug - Variable in class org.apache.solr.request.SimpleFacets
 
fdebugParent - Variable in class org.apache.solr.request.SimpleFacets
 
fetch(String, String) - Method in class org.apache.solr.filestore.DistribFileStore
 
fetch(String, String) - Method in interface org.apache.solr.filestore.FileStore
Fetch a resource from another node internal API
FETCH_FROM_LEADER - Static variable in class org.apache.solr.handler.ReplicationHandler
 
fetchAndValidateZooKeeperAwareCoreContainer() - Method in class org.apache.solr.handler.admin.api.AdminAPIBase
 
fetchAttributes() - Method in interface org.apache.solr.cluster.placement.AttributeFetcher
Fetches all requested node attributes from all nodes passed to AttributeFetcher.fetchFrom(Set) as well as non-node attributes (those requested using e.g.
fetchAttributes() - Method in class org.apache.solr.cluster.placement.impl.AttributeFetcherImpl
 
fetchAuthenticationConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetAuthenticationConfigAPI
 
fetchAuthorizationConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetAuthorizationConfigAPI
 
fetchFileList(long) - Method in class org.apache.solr.handler.admin.api.CoreReplicationAPI
 
fetchFrom(Set<Node>) - Method in interface org.apache.solr.cluster.placement.AttributeFetcher
The set of nodes from which to fetch all node related attributes.
fetchFrom(Set<Node>) - Method in class org.apache.solr.cluster.placement.impl.AttributeFetcherImpl
 
fetchIndexVersion() - Method in class org.apache.solr.handler.admin.api.CoreReplicationAPI
 
fetchInstalledPackageInstances() - Method in class org.apache.solr.packagemanager.PackageManager
 
fetchLatestSchema() - Method in class org.apache.solr.core.SolrCore
 
fetchLocalLogMessages(Long) - Method in class org.apache.solr.handler.admin.api.NodeLoggingAPI
 
fetchManifest(SolrClient, String, String) - Static method in class org.apache.solr.packagemanager.PackageUtils
Fetches a manifest file from the File Store / Package Store.
fgQ - Variable in class org.apache.solr.search.facet.RelatednessAgg
 
field - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.RoutedAliasProperties
 
field - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
field - Variable in class org.apache.solr.handler.component.PivotFacetField
 
field - Variable in class org.apache.solr.handler.export.IntValue
 
field - Variable in class org.apache.solr.handler.export.LongValue
 
field - Variable in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
 
field - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
field - Variable in class org.apache.solr.search.FloatPayloadValueSource
 
field - Variable in class org.apache.solr.search.function.OrdFieldSource
 
field - Variable in class org.apache.solr.search.function.ReverseOrdFieldSource
 
field - Variable in class org.apache.solr.search.join.HashRangeQuery
 
field - Variable in class org.apache.solr.search.SpatialOptions
 
field - Variable in class org.apache.solr.search.stats.CollectionStats
 
field - Variable in class org.apache.solr.spelling.SolrSpellChecker
 
field - Variable in class org.apache.solr.uninverting.DocTermOrds
Field we are uninverting.
FIELD - org.apache.solr.util.PivotListEntry
 
FIELD - Static variable in class org.apache.solr.response.GeoJSONResponseWriter
 
FIELD - Static variable in class org.apache.solr.schema.IndexSchema
 
FIELD - Static variable in class org.apache.solr.search.join.HashRangeQParser
 
FIELD - Static variable in class org.apache.solr.search.RankQParserPlugin
 
FIELD - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
FIELD - Static variable in class org.apache.solr.spelling.SolrSpellChecker
 
FIELD - Static variable in class org.apache.solr.spelling.suggest.DocumentDictionaryFactory
 
FIELD - Static variable in class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
Label for defining field to use for terms
FIELD_DELIMITER - Static variable in class org.apache.solr.spelling.suggest.FileDictionaryFactory
Label for defining fieldDelimiter to be used
FIELD_INFO_PARAM - Static variable in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
FIELD_INFO_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
FIELD_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
FIELD_SORT_VALUES - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
FIELD_SUFFIX_AMOUNT_RAW - Static variable in class org.apache.solr.schema.CurrencyField
Deprecated.
 
FIELD_SUFFIX_CURRENCY - Static variable in class org.apache.solr.schema.CurrencyField
Deprecated.
 
FIELD_TYPE - Static variable in class org.apache.solr.schema.IndexSchema
 
FIELD_TYPE - Static variable in class org.apache.solr.spelling.SolrSpellChecker
 
FIELD_TYPE_AMOUNT_RAW - Static variable in class org.apache.solr.schema.CurrencyField
Deprecated.
 
FIELD_TYPE_CURRENCY - Static variable in class org.apache.solr.schema.CurrencyField
Deprecated.
 
FIELD_TYPE_INVARIANTS - Static variable in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
FIELD_TYPES - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
FIELD_TYPES - Static variable in class org.apache.solr.schema.IndexSchema
 
FieldAnalysisRequestHandler - Class in org.apache.solr.handler
Provides the ability to specify multiple field types and field names in the same request.
FieldAnalysisRequestHandler() - Constructor for class org.apache.solr.handler.FieldAnalysisRequestHandler
 
FieldCache - Interface in org.apache.solr.uninverting
Expert: Maintains caches of term values.
FieldCache.CacheEntry - Class in org.apache.solr.uninverting
EXPERT: A unique Identifier/Description for each item in the FieldCache.
FieldCache.CreationPlaceholder - Class in org.apache.solr.uninverting
Placeholder indicating creation of this cache is currently in-progress.
FieldCache.Parser - Interface in org.apache.solr.uninverting
interface to all parsers.
FieldCache.PointParser - Class in org.apache.solr.uninverting
Base class for points parsers.
FieldCacheImpl - Class in org.apache.solr.uninverting
Expert: The default cache implementation, storing all values in memory.
FieldCacheImpl.BinaryDocValuesImpl - Class in org.apache.solr.uninverting
 
FieldCacheImpl.LongsFromArray - Class in org.apache.solr.uninverting
 
FieldCacheImpl.SortedDocValuesImpl - Class in org.apache.solr.uninverting
 
FieldCacheImpl.SortedDocValuesImpl.Iter - Class in org.apache.solr.uninverting
 
FieldCacheStats(String, String[]) - Constructor for class org.apache.solr.uninverting.UninvertingReader.FieldCacheStats
 
FieldExistsException(SolrException.ErrorCode, String) - Constructor for exception org.apache.solr.schema.ManagedIndexSchema.FieldExistsException
 
FieldFacet(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
FieldFacetStats - Class in org.apache.solr.handler.component
FieldFacetStats is a utility to accumulate statistics on a set of values in one field, for facet values present in another field.
FieldFacetStats(SolrIndexSearcher, SchemaField, StatsField) - Constructor for class org.apache.solr.handler.component.FieldFacetStats
 
fieldInfo - Variable in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaGetFieldInfoResponse
 
FieldLengthUpdateProcessorFactory - Class in org.apache.solr.update.processor
Replaces any CharSequence values found in fields matching the specified conditions with the lengths of those CharSequences (as an Integer).
FieldLengthUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.FieldLengthUpdateProcessorFactory
 
FieldMutatingUpdateProcessor - Class in org.apache.solr.update.processor
Reusable base class for UpdateProcessors that will consider AddUpdateCommands and mutate the values associated with configured fields.
FieldMutatingUpdateProcessor(FieldMutatingUpdateProcessor.FieldNameSelector, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
 
FieldMutatingUpdateProcessor.FieldNameSelector - Interface in org.apache.solr.update.processor
Interface for identifying which fields should be mutated
FieldMutatingUpdateProcessorFactory - Class in org.apache.solr.update.processor
Base class for implementing Factories for FieldMutatingUpdateProcessors and FieldValueMutatingUpdateProcessors.
FieldMutatingUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
 
FieldMutatingUpdateProcessorFactory.SelectorParams - Class in org.apache.solr.update.processor
 
fieldName - Variable in class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
 
fieldName - Variable in class org.apache.solr.update.processor.AbstractDefaultValueUpdateProcessorFactory
 
fieldName - Variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
 
fieldName - Variable in class org.apache.solr.update.processor.UUIDUpdateProcessorFactory
 
fieldNameMatchesSchemaField - Variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
 
FieldNameMutatingUpdateProcessorFactory - Class in org.apache.solr.update.processor
In the FieldNameMutatingUpdateProcessorFactory configured below, fields names will be mutated if the name contains space.
FieldNameMutatingUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.FieldNameMutatingUpdateProcessorFactory
 
fieldNames - Variable in class org.apache.solr.handler.component.ShardFieldSortedHitQueue
The order of these fieldNames should correspond to the order of sort field values retrieved from the shard
FIELDNAMES - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
FieldNameValueSource - Class in org.apache.solr.search.function
Placeholder value source.
FieldNameValueSource(String) - Constructor for class org.apache.solr.search.function.FieldNameValueSource
 
FieldParams - Class in org.apache.solr.search
A class to hold "phrase slop" and "boost" parameters for pf, pf2, pf3 parameters
FieldParams(String, int, int, float) - Constructor for class org.apache.solr.search.FieldParams
 
FieldProperties - Class in org.apache.solr.schema
 
FieldProperties() - Constructor for class org.apache.solr.schema.FieldProperties
 
FieldQParserPlugin - Class in org.apache.solr.search
Create a field query from the input value, applying text analysis and constructing a phrase query if appropriate.
FieldQParserPlugin() - Constructor for class org.apache.solr.search.FieldQParserPlugin
 
fieldRegex - Variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
 
fields - Variable in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListFieldsResponse
 
fields - Variable in class org.apache.solr.handler.component.ShardFieldSortedHitQueue
Stores the sort criteria being used.
fields - Variable in class org.apache.solr.schema.IndexSchema
 
fields - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias
 
fields - Variable in class org.apache.solr.util.SolrPluginUtils.DisjunctionMaxQueryParser.Alias
 
FIELDS - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
FIELDS - Static variable in class org.apache.solr.schema.IndexSchema
 
FIELDS_BY_SIZE - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
FIELDS_KEY - Static variable in class org.apache.solr.search.stats.StatsCache
List of fields in the query.
fieldsFromString(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
fieldsToString(Collection<String>) - Static method in class org.apache.solr.search.stats.StatsUtil
 
fieldSuffixAmountRaw - Variable in class org.apache.solr.schema.CurrencyFieldType
 
fieldSuffixCurrency - Variable in class org.apache.solr.schema.CurrencyFieldType
 
fieldsWithDefaultValue - Variable in class org.apache.solr.schema.IndexSchema
 
fieldToMap(SchemaField, ManagedIndexSchema) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
FieldType - Class in org.apache.solr.schema
Base class for all field types used by an index schema.
FieldType() - Constructor for class org.apache.solr.schema.FieldType
 
FieldType.DefaultAnalyzer - Class in org.apache.solr.schema
Default analyzer for types that only produce 1 verbatim token...
FieldType.MultiValueSelector - Enum in org.apache.solr.schema
An enumeration representing various options that may exist for selecting a single value from a multivalued field.
fieldTypeAmountRaw - Variable in class org.apache.solr.schema.CurrencyFieldType
 
fieldTypeCurrency - Variable in class org.apache.solr.schema.CurrencyFieldType
 
fieldTypeInfo - Variable in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaGetFieldTypeInfoResponse
 
fieldTypeName - Variable in class org.apache.solr.spelling.SolrSpellChecker
 
FieldTypePluginLoader - Class in org.apache.solr.schema
 
FieldTypePluginLoader(IndexSchema, Map<String, FieldType>, Collection<SchemaAware>) - Constructor for class org.apache.solr.schema.FieldTypePluginLoader
 
fieldTypes - Variable in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListFieldTypesResponse
 
fieldTypes - Variable in class org.apache.solr.schema.IndexSchema
 
FieldTypeXmlAdapter - Class in org.apache.solr.rest.schema
Utility class for converting a JSON definition of a FieldType into the XML format expected by the FieldTypePluginLoader.
FieldTypeXmlAdapter() - Constructor for class org.apache.solr.rest.schema.FieldTypeXmlAdapter
 
FieldUtil - Class in org.apache.solr.search.facet
 
FieldUtil() - Constructor for class org.apache.solr.search.facet.FieldUtil
 
FieldUtil.DVOrdValues - Class in org.apache.solr.search.facet
 
FieldUtil.FCOrdValues - Class in org.apache.solr.search.facet
 
FieldUtil.OrdFunc - Interface in org.apache.solr.search.facet
The following ord visitors and wrappers are a work in progress and experimental
FieldUtil.OrdValues - Class in org.apache.solr.search.facet
 
fieldValueCacheConfig - Variable in class org.apache.solr.core.SolrConfig
 
FieldValueMutatingUpdateProcessor - Class in org.apache.solr.update.processor
Abstract subclass of FieldMutatingUpdateProcessor for implementing UpdateProcessors that will mutate all individual values of a selected field independently
FieldValueMutatingUpdateProcessor(FieldMutatingUpdateProcessor.FieldNameSelector, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.FieldValueMutatingUpdateProcessor
 
FieldValueSubsetUpdateProcessorFactory - Class in org.apache.solr.update.processor
Base class for processors that want to mutate selected fields to only keep a subset of the original values.
FieldValueSubsetUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.FieldValueSubsetUpdateProcessorFactory
 
fieldWeights - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
FILE - org.apache.solr.core.backup.repository.BackupRepository.PathType
 
FILE - org.apache.solr.filestore.FileStore.FileType
 
FILE - Static variable in class org.apache.solr.handler.ReplicationHandler
 
FILE_LIST - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
FILE_STREAM - Static variable in class org.apache.solr.handler.ReplicationHandler
 
FileBasedSpellChecker - Class in org.apache.solr.spelling
A spell checker implementation that loads words from a text file (one word per line).
FileBasedSpellChecker() - Constructor for class org.apache.solr.spelling.FileBasedSpellChecker
 
fileChecksum - Variable in class org.apache.solr.core.backup.ShardBackupMetadata.BackedFile
 
fileCount - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
FileDictionaryFactory - Class in org.apache.solr.spelling.suggest
Factory for FileDictionary
FileDictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.FileDictionaryFactory
 
FileExchangeRateProvider - Class in org.apache.solr.schema
Configuration for currency.
FileExchangeRateProvider() - Constructor for class org.apache.solr.schema.FileExchangeRateProvider
 
fileExists(String) - Static method in class org.apache.solr.util.FileUtils
 
FileFloatSource - Class in org.apache.solr.search.function
Obtains float field values from an external file.
FileFloatSource(SchemaField, SchemaField, float, String) - Constructor for class org.apache.solr.search.function.FileFloatSource
Creates a new FileFloatSource
FileFloatSource.ReloadCacheRequestHandler - Class in org.apache.solr.search.function
 
fileList - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileListResponse
 
FileListResponse() - Constructor for class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileListResponse
 
FileMetaData() - Constructor for class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileMetaData
 
FileMetaData(long, String, long) - Constructor for class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileMetaData
 
fileName - Variable in class org.apache.solr.cloud.ZkSolrResourceLoader.ZkByteArrayInputStream
 
FILEPATH_PLACEHOLDER - Static variable in class org.apache.solr.handler.configsets.UploadConfigSetFileAPI
 
files - Variable in class org.apache.solr.packagemanager.SolrPackageInstance
 
files - Variable in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
fileSource - Variable in class org.apache.solr.handler.designer.SampleDocuments
 
FileStorageIO() - Constructor for class org.apache.solr.rest.ManagedResourceStorage.FileStorageIO
 
FileStore - Interface in org.apache.solr.filestore
The interface to be implemented by any package store provider * @lucene.experimental
FILESTORE_DIRECTORY - Static variable in class org.apache.solr.filestore.FileStoreAPI
 
FILESTORE_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
FILESTORE_WRITE_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
FileStore.FileDetails - Interface in org.apache.solr.filestore
 
FileStore.FileEntry - Class in org.apache.solr.filestore
 
FileStore.FileType - Enum in org.apache.solr.filestore
 
FileStoreAPI - Class in org.apache.solr.filestore
 
FileStoreAPI(CoreContainer) - Constructor for class org.apache.solr.filestore.FileStoreAPI
 
FileStoreAPI.FSRead - Class in org.apache.solr.filestore
 
FileStoreAPI.FSWrite - Class in org.apache.solr.filestore
 
FileStoreAPI.MetaData - Class in org.apache.solr.filestore
 
FileSystemConfigSetService - Class in org.apache.solr.core
FileSystem ConfigSetService impl.
FileSystemConfigSetService(Path) - Constructor for class org.apache.solr.core.FileSystemConfigSetService
Testing purpose
FileSystemConfigSetService(CoreContainer) - Constructor for class org.apache.solr.core.FileSystemConfigSetService
 
FileTypeMagicUtil - Class in org.apache.solr.util
Utility class to guess the mime type of file based on its magic number.
FileUtils - Class in org.apache.solr.util
 
FileUtils() - Constructor for class org.apache.solr.util.FileUtils
 
fill() - Method in class org.apache.solr.util.RecordingJSONParser
 
fillParams(ResponseBuilder, SolrParams, String) - Method in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
fillParams(ResponseBuilder, SolrParams, String) - Method in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
fillRanges(SolrCloudManager, ZkNodeProps, DocCollection, Slice, List<DocRouter.Range>, List<String>, List<String>, boolean) - Static method in class org.apache.solr.cloud.api.collections.SplitShardCmd
 
filter - Variable in class org.apache.solr.search.SolrIndexSearcher.ProcessedFilter
 
filter(MetricFilter) - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
Only report metrics which match the given filter.
filter(ContainerRequestContext) - Method in class org.apache.solr.jersey.RequestMetricHandling.PreRequestMetricsFilter
 
filter(ContainerRequestContext) - Method in class org.apache.solr.jersey.SolrRequestAuthorizer
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class org.apache.solr.jersey.MediaTypeOverridingFilter
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class org.apache.solr.jersey.PostRequestDecorationFilter
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class org.apache.solr.jersey.PostRequestLoggingFilter
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class org.apache.solr.jersey.RequestMetricHandling.PostRequestMetricsFilter
 
FILTER - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
FILTER - Static variable in class org.apache.solr.schema.FieldType
 
FILTER_PARAM - Static variable in class org.apache.solr.schema.AbstractSpatialFieldType
A local-param boolean that can be set to false to only return the FunctionQuery (score), and thus not do filtering.
filterAndStringifyQueryParameters(MultivaluedMap<String, String>) - Static method in class org.apache.solr.jersey.PostRequestLoggingFilter
 
filterCacheConfig - Variable in class org.apache.solr.core.SolrConfig
 
FilterCollector - Class in org.apache.solr.search.grouping.collector
A collector that filters incoming doc ids that are not in the filter.
FilterCollector(DocSet, Collector) - Constructor for class org.apache.solr.search.grouping.collector.FilterCollector
 
FilteredDocIdSet - Class in org.apache.solr.search
Abstract decorator class for a DocIdSet implementation that provides on-demand filtering/validation mechanism on a given DocIdSet.
FilteredDocIdSet(DocIdSet) - Constructor for class org.apache.solr.search.FilteredDocIdSet
Constructor.
FilteringSolrMetricReporter - Class in org.apache.solr.metrics
A SolrMetricReporter that supports (prefix) filters.
FilteringSolrMetricReporter(SolrMetricManager, String) - Constructor for class org.apache.solr.metrics.FilteringSolrMetricReporter
 
filterNonDataNodes(DistribStateManager, Collection<String>) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
filterParams(SolrParams) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
filterPrefixCodedInts(TermsEnum) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Filters the given TermsEnum by accepting only prefix coded 32 bit terms with a shift value of 0.
filterPrefixCodedLongs(TermsEnum) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Filters the given TermsEnum by accepting only prefix coded 64 bit terms with a shift value of 0.
FilterQuery - Class in org.apache.solr.query
A filtered query wrapped around another query similar to BooleanClause.Occur.FILTER -- it scores as 0.
FilterQuery(Query) - Constructor for class org.apache.solr.query.FilterQuery
 
filters - Variable in class org.apache.solr.metrics.FilteringSolrMetricReporter
 
filters - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
 
FILTERS - Static variable in class org.apache.solr.schema.FieldType
 
FiltersQParser - Class in org.apache.solr.search.join
 
FiltersQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.join.FiltersQParser
 
FiltersQParserPlugin - Class in org.apache.solr.search.join
 
FiltersQParserPlugin() - Constructor for class org.apache.solr.search.join.FiltersQParserPlugin
 
find(List<Long>, Object) - Method in class org.apache.solr.update.PeerSync.MissedUpdatesFinder
 
find(List<Long>, Object) - Method in class org.apache.solr.update.PeerSyncWithLeader.MissedUpdatesFinder
 
findAllBackupIdsFromFileListing(String[]) - Static method in class org.apache.solr.core.backup.BackupFilePaths
Identify all strings which appear to be the filename of a top-level backup properties file.
findCandidateGivenValue(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
findCandidateGivenValue(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
findCandidateGivenValue(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
Given the route key, finds the correct collection and an indication of any collection that needs to be created.
findClass(String, Class<T>) - Method in class org.apache.solr.core.SolrResourceLoader
 
findClass(String, Class<T>) - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
findClass(String, Class<T>, String...) - Method in class org.apache.solr.core.SolrResourceLoader
This method loads a class either with its FQN or a short-name (solr.class-simplename or class-simplename).
findClass(PluginInfo, Class<T>, boolean) - Method in class org.apache.solr.core.SolrResourceLoader
Load a class using an appropriate SolrResourceLoader depending of the package on that class
findFirstMBeanServer() - Static method in class org.apache.solr.util.JmxUtil
Retrieve the first MBeanServer found and if not found return the platform mbean server
findMBeanServerForAgentId(String) - Static method in class org.apache.solr.util.JmxUtil
Find a MBeanServer given an agent id.
findMBeanServerForServiceUrl(String) - Static method in class org.apache.solr.util.JmxUtil
Find a MBeanServer given a service url.
findMostRecentBackupIdFromFileListing(String[]) - Static method in class org.apache.solr.core.backup.BackupFilePaths
Identify the string from an array of filenames which represents the most recent top-level backup properties file.
findNameForDeserialization(Annotated) - Method in class org.apache.solr.util.SolrJacksonAnnotationInspector
 
findNameForSerialization(Annotated) - Method in class org.apache.solr.util.SolrJacksonAnnotationInspector
 
findPackageVersion(PluginInfo.ClassName, boolean) - Method in class org.apache.solr.pkg.PackageListeningClassLoader
This looks up for package and also listens for that package if required
findPropertyDefaultValue(Annotated) - Method in class org.apache.solr.util.SolrJacksonAnnotationInspector
 
findSubsetsMatching(Collection<E>) - Method in class org.apache.solr.handler.component.QueryElevationComponent.TrieSubsetMatcher
Returns an iterator over all the subsets that are contained by the provided set.
findTool(String[]) - Static method in class org.apache.solr.cli.SolrCLI
 
finish() - Method in class org.apache.solr.search.DelegatingCollector
From Solr 9.4 using Lucene 9.8 onwards DelegatingCollector.finish clashes with the super class's LeafCollector.finish method.
finish() - Method in class org.apache.solr.search.Grouping.Command
Performs any necessary post actions to prepare the response.
finish() - Method in class org.apache.solr.search.Grouping.CommandField
 
finish() - Method in class org.apache.solr.search.Grouping.CommandFunc
 
finish() - Method in class org.apache.solr.search.Grouping.CommandQuery
 
finish() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
finish() - Method in class org.apache.solr.update.processor.RoutedAliasUpdateProcessor
 
finish() - Method in class org.apache.solr.update.processor.TolerantUpdateProcessor
 
finish() - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
 
finish() - Method in class org.apache.solr.update.SolrCmdDistributor
 
finish(FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetFieldMerger
 
finish(FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetMerger
 
finish(FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetRangeMerger
 
finish(UpdateLog.SyncLevel) - Method in class org.apache.solr.update.TransactionLog
 
finish(UpdateLog.SyncLevel) - Method in class org.apache.solr.update.UpdateLog
 
finished - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
FINISHED - org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.DebugComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.ExpandComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.FacetComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.HighlightComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.SearchComponent
Called after all responses have been received for this stage.
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.StatsComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.SuggestComponent
Used in Distributed Search, merges the suggestion results from every shard
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.TermsComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.TermVectorComponent
 
finishStage(ResponseBuilder) - Method in class org.apache.solr.search.facet.FacetModule
 
fireEvent(ClusterEvent) - Method in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
FirstFieldValueUpdateProcessorFactory - Class in org.apache.solr.update.processor
Keeps only the first value of fields matching the specified conditions.
FirstFieldValueUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.FirstFieldValueUpdateProcessorFactory
 
firstPhaseElapsedTime - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
fis - Variable in class org.apache.solr.update.TransactionLog.LogReader
 
fixedStr - Variable in class org.apache.solr.schema.IndexSchema.DynamicReplacement.DynamicPattern
 
fixNegativeQuery(Query) - Static method in class org.apache.solr.search.QueryUtils
Fixes a negative query by adding a MatchAllDocs query clause.
FLAG_CONSUME_DELIMITER - Static variable in class org.apache.solr.search.FunctionQParser
 
FLAG_DEFAULT - Static variable in class org.apache.solr.search.FunctionQParser
 
FLAG_FILTER - Static variable in class org.apache.solr.search.QParser
 
FLAG_IS_AGG - Static variable in class org.apache.solr.search.FunctionQParser
 
FLAG_PARSE_VECTOR_BYTE_ENCODING - Static variable in class org.apache.solr.search.FunctionQParser
 
FLAG_USE_FIELDNAME_SOURCE - Static variable in class org.apache.solr.search.FunctionQParser
 
flags - Variable in class org.apache.solr.search.QParser
 
flags - Variable in class org.apache.solr.update.UpdateCommand
 
FLAGS_IDX - Static variable in class org.apache.solr.update.UpdateLog
The index of the flags value in an entry from the transaction log.
FLAGS_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
flattenBooleanQuery(BooleanQuery.Builder, BooleanQuery) - Static method in class org.apache.solr.util.SolrPluginUtils
Recursively walks the "from" query pulling out sub-queries and adding them to the "to" query.
flattenMapWithPrefix(Map<String, Object>, Map<String, Object>, String) - Static method in class org.apache.solr.handler.api.V2ApiUtils
 
flattenToCommaDelimitedString(Map<String, Object>, List<String>, String) - Static method in class org.apache.solr.handler.api.V2ApiUtils
 
FLOAT - org.apache.solr.legacy.LegacyNumericType
Deprecated.
32-bit float numeric type
FLOAT - org.apache.solr.schema.NumberType
 
FLOAT_POINT - org.apache.solr.uninverting.UninvertingReader.Type
Single-valued Integer, (e.g.
FLOAT_POINT_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
A parser instance for float values encoded by NumericUtils, e.g.
float2sortableStr(float) - Static method in class org.apache.solr.util.NumberUtils
 
float2sortableStr(String) - Static method in class org.apache.solr.util.NumberUtils
 
FloatConsumer - Interface in org.apache.solr.util
Represents an operation that accepts a single float-valued argument and returns no result.
FloatDenseVectorParser - Class in org.apache.solr.util.vector
 
FloatDenseVectorParser(int, Object, DenseVectorParser.BuilderPhase) - Constructor for class org.apache.solr.util.vector.FloatDenseVectorParser
 
FloatPayloadValueSource - Class in org.apache.solr.search
 
FloatPayloadValueSource(String, String, String, BytesRef, PayloadDecoder, PayloadFunction, ValueSource) - Constructor for class org.apache.solr.search.FloatPayloadValueSource
 
FloatPointField - Class in org.apache.solr.schema
PointField implementation for Float values.
FloatPointField() - Constructor for class org.apache.solr.schema.FloatPointField
 
floatVal(int) - Method in class org.apache.solr.search.function.CollapseScoreFunction.CollapseScoreFunctionValues
 
FloatValueFieldType - Interface in org.apache.solr.schema
Marker interface for float-valued field types.
flush() - Method in class org.apache.solr.internal.csv.CSVPrinter
 
flush() - Method in class org.apache.solr.logging.jul.RecordHandler
 
flush() - Method in class org.apache.solr.security.PrintWriterWrapper
 
flush() - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
flush() - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletOutputStream
 
flush(byte[], int, int) - Method in class org.apache.solr.update.MemOutputStream
 
FLUSH - org.apache.solr.update.UpdateLog.SyncLevel
 
flushAllLoggers() - Static method in class org.apache.solr.util.StartupLoggingUtils
This is primarily for tests to insure that log messages don't bleed from one test case to another, see: SOLR-13268.
flushCommandStatus(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
forBackup(BackupRepository, ZkStateReader, URI) - Static method in class org.apache.solr.core.backup.BackupManager
 
FORBIDDEN - Static variable in class org.apache.solr.security.AuthorizationResponse
 
forceClose() - Method in class org.apache.solr.update.TransactionLog
 
forceElevation - Variable in class org.apache.solr.handler.component.QueryElevationComponent
 
ForceLeader - Class in org.apache.solr.handler.admin.api
V2 API implementation for triggering a leader election on a particular collection and shard.
ForceLeader(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ForceLeader
 
FORCELEADER_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
forceShardLeader(String, String) - Method in class org.apache.solr.handler.admin.api.ForceLeader
 
forCollection(String) - Method in class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
forEachChild(Function<ConfigNode, Boolean>) - Method in class org.apache.solr.util.DataConfigNode
 
forEachChild(Function<ConfigNode, Boolean>) - Method in class org.apache.solr.util.DOMConfigNode
 
forEachRequestPurpose(Integer, Consumer<String>) - Static method in class org.apache.solr.util.SolrPluginUtils
Given the integer purpose of a request generates a readable value corresponding the request purposes (there can be more than one on a single request).
forEachValue(IntConsumer) - Method in class org.apache.solr.util.IntIntDynamicMap
 
forEachValue(LongConsumer) - Method in class org.apache.solr.util.IntLongDynamicMap
 
forEachValue(FloatConsumer) - Method in class org.apache.solr.util.IntFloatDynamicMap
 
forIncrementalBackup(BackupRepository, ZkStateReader, URI) - Static method in class org.apache.solr.core.backup.BackupManager
 
format - Variable in class org.apache.solr.search.Grouping.Command
 
format(String, Object...) - Method in class org.apache.solr.security.PrintWriterWrapper
 
format(Locale, String, Object...) - Method in class org.apache.solr.security.PrintWriterWrapper
 
FORMAT - Static variable in class org.apache.solr.schema.AbstractSpatialFieldType
Optional param to pick the string conversion
FORMAT_INTS2D - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
FORMAT_PARAM - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
FORMAT_PNG - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
formatCollectionNameFromInstant(String, Instant) - Static method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
formatEvent(AuditEvent) - Method in interface org.apache.solr.security.AuditLoggerPlugin.AuditEventFormatter
 
formatEvent(AuditEvent) - Method in class org.apache.solr.security.AuditLoggerPlugin.JSONAuditEventFormatter
Formats an audit event as a JSON string
formatShardResponse(List<PhrasesIdentificationComponent.Phrase>) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Format the phrases suitable for returning in a shard response
formatter - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
formatters - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
 
FORMDATA - Static variable in class org.apache.solr.servlet.SolrRequestParsers
 
forName(String) - Static method in enum org.apache.solr.handler.component.StatsField.Stat
Given a String, returns the corresponding Stat enum value if any, otherwise returns null.
forRegistry(MetricRegistry) - Static method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter
 
forReports(SolrMetricManager, List<SolrReporter.Report>) - Static method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Create a builder for SolrReporter.
forRestore(BackupRepository, ZkStateReader, URI) - Static method in class org.apache.solr.core.backup.BackupManager
 
forRestore(BackupRepository, ZkStateReader, URI, int) - Static method in class org.apache.solr.core.backup.BackupManager
 
forShard(List<String>) - Method in class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
FORWARD - org.apache.solr.servlet.SolrDispatchFilter.Action
 
FORWARD_CREDENTIALS - Static variable in class org.apache.solr.security.BasicAuthPlugin
 
ForwardNode(ZkCoreNodeProps, ZkStateReader, String, String, int) - Constructor for class org.apache.solr.update.SolrCmdDistributor.ForwardNode
 
forwardToLeader - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
fos - Variable in class org.apache.solr.update.TransactionLog
 
found - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessageInfo
 
fragListBuilders - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
 
fragmenters - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
 
fragmentsBuilders - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
 
FREE_DISK_GB - Static variable in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
Free (usable) disk space in GB.
FreeTextLookupFactory - Class in org.apache.solr.spelling.suggest.fst
LookupFactory implementation for FreeTextSuggester
FreeTextLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.FreeTextLookupFactory
 
freezeStage() - Method in interface org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttribute
 
freezeStage() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
freq - Variable in class org.apache.solr.spelling.ResultEntry
 
FREQ_COMP - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
FREQ_COMP - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
from - Variable in class org.apache.solr.search.facet.FacetRequest.Domain.JoinField
 
from(String) - Static method in class org.apache.solr.core.backup.ShardBackupId
 
from(BackupRepository, URI, ShardBackupId) - Static method in class org.apache.solr.core.backup.ShardBackupMetadata
Reads a shard metadata file from a BackupRepository and parses the result into a ShardBackupMetadata
FROM - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
FROM_INDEX - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
fromBytes(byte[]) - Static method in class org.apache.solr.util.hll.HLL
Deserializes the HLL (in HLL.toBytes(ISchemaVersion) format) serialized into bytes .
fromConfig(Path, Properties, boolean, ConfigNode, SolrResourceLoader) - Static method in class org.apache.solr.core.SolrXmlConfig
 
fromExpression(String, Set<SortField>) - Method in class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
 
fromField - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
fromFile(Path, Path, Properties) - Static method in class org.apache.solr.core.SolrXmlConfig
 
fromInputStream(Path, InputStream, Properties) - Static method in class org.apache.solr.core.SolrXmlConfig
 
fromInputStream(Path, InputStream, Properties, boolean) - Static method in class org.apache.solr.core.SolrXmlConfig
 
FROMLEADER - org.apache.solr.update.processor.DistributedUpdateProcessor.DistribPhase
 
fromMap(Map<?, ?>) - Static method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Report
 
fromObj(Object) - Static method in enum org.apache.solr.search.facet.FacetRequest.RefineMethod
 
fromObj(Object) - Static method in enum org.apache.solr.search.facet.FacetRequest.SortDirection
 
fromObject(Object) - Static method in class org.apache.solr.update.IndexFingerprint
Create an IndexFingerprint object from a deserialized generic object (Map or NamedList)
fromProps(String, Map<String, String>) - Static method in class org.apache.solr.cloud.api.collections.RoutedAlias
Factory method for implementations of this interface.
fromRemoteResponse(ObjectMapper, SolrResponse) - Static method in class org.apache.solr.handler.admin.api.DeleteCollectionBackup
 
fromShardMetadataFilename(String) - Static method in class org.apache.solr.core.backup.ShardBackupId
 
fromSolrHome(Path, Properties) - Static method in class org.apache.solr.core.SolrXmlConfig
 
fromString(String) - Static method in enum org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
 
fromString(String) - Static method in enum org.apache.solr.search.facet.FacetField.FacetMethod
 
fromString(Path, String) - Static method in class org.apache.solr.core.SolrXmlConfig
TEST-ONLY
fromString(SchemaField, String) - Method in class org.apache.solr.schema.PreAnalyzedField
 
fromV1Params(SolrParams) - Static method in class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
FSRead() - Constructor for class org.apache.solr.filestore.FileStoreAPI.FSRead
 
FSReverseReader() - Constructor for class org.apache.solr.update.TransactionLog.FSReverseReader
 
FSTLookupFactory - Class in org.apache.solr.spelling.suggest.fst
Factory for FSTCompletionLookup
FSTLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.FSTLookupFactory
 
FSWrite() - Constructor for class org.apache.solr.filestore.FileStoreAPI.FSWrite
 
FSYNC - org.apache.solr.update.UpdateLog.SyncLevel
 
ftype - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
FULL - org.apache.solr.util.hll.HLLType
 
fun - Variable in enum org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
func(int, FunctionValues[]) - Method in class org.apache.solr.search.function.ConcatStringFunction
 
func(int, FunctionValues[]) - Method in class org.apache.solr.search.function.MultiStringFunction
 
func(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.DualDoubleFunction
 
FuncSlotAcc(ValueSource, FacetContext, int) - Constructor for class org.apache.solr.search.facet.SlotAcc.FuncSlotAcc
 
FUNCTION - Static variable in class org.apache.solr.search.RankQParserPlugin
 
FunctionQParser - Class in org.apache.solr.search
 
FunctionQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.FunctionQParser
 
FunctionQParserPlugin - Class in org.apache.solr.search
Create a function query from the input value.
FunctionQParserPlugin() - Constructor for class org.apache.solr.search.FunctionQParserPlugin
 
FunctionRangeQParserPlugin - Class in org.apache.solr.search
Create a range query over a function.
FunctionRangeQParserPlugin() - Constructor for class org.apache.solr.search.FunctionRangeQParserPlugin
 
FunctionRangeQuery - Class in org.apache.solr.search
 
FunctionRangeQuery(ValueSourceRangeFilter) - Constructor for class org.apache.solr.search.FunctionRangeQuery
 
FUZZY_SLOP - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
FuzzyLookupFactory - Class in org.apache.solr.spelling.suggest.fst
Factory for FuzzySuggester
FuzzyLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
 
FvhContainer(FastVectorHighlighter, FieldQuery) - Constructor for class org.apache.solr.highlight.DefaultSolrHighlighter.FvhContainer
 

G

gap - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
GapFragmenter - Class in org.apache.solr.highlight
 
GapFragmenter() - Constructor for class org.apache.solr.highlight.GapFragmenter
 
gapObj - Variable in class org.apache.solr.handler.component.RangeFacetRequest
The computed gap between each range
garbageCollectUnusedBackupFiles(String, PurgeUnusedFilesRequestBody) - Method in class org.apache.solr.handler.admin.api.DeleteCollectionBackup
 
gauge(Gauge<?>, boolean, String, String...) - Method in class org.apache.solr.metrics.SolrMetricsContext
GaugeWrapper(Gauge<T>, String) - Constructor for class org.apache.solr.metrics.SolrMetricManager.GaugeWrapper
 
GB - Static variable in class org.apache.solr.cluster.placement.impl.MetricImpl
 
gen - Variable in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
gen - Variable in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
generateParseException() - Method in class org.apache.solr.parser.QueryParser
Generate ParseException.
generateQueryID(SolrQueryRequest) - Method in class org.apache.solr.core.CancellableQueryTracker
Generates a UUID for the given query or if the user provided a UUID for this query, uses that.
generation - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.IndexVersionResponse
 
GENERATION - Static variable in class org.apache.solr.handler.ReplicationHandler
 
GENERATION_NUM - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
GeoDistValueSourceParser - Class in org.apache.solr.search.function.distance
Parses "geodist" creating HaversineConstFunction or HaversineFunction or calling SpatialStrategy.makeDistanceValueSource(org.locationtech.spatial4j.shape.Point,double).
GeoDistValueSourceParser() - Constructor for class org.apache.solr.search.function.distance.GeoDistValueSourceParser
 
GeohashFunction - Class in org.apache.solr.search.function.distance
Deprecated.
GeohashFunction(ValueSource, ValueSource) - Constructor for class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
GeohashHaversineFunction - Class in org.apache.solr.search.function.distance
Deprecated.
GeohashHaversineFunction(ValueSource, ValueSource, double) - Constructor for class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
GeoJSONResponseWriter - Class in org.apache.solr.response
Extend the standard JSONResponseWriter to support GeoJSON.
GeoJSONResponseWriter() - Constructor for class org.apache.solr.response.GeoJSONResponseWriter
 
GEOM_PARAM - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
GeoTransformerFactory - Class in org.apache.solr.response.transform
This DocumentTransformer will write a Shape to the SolrDocument using the requested format.
GeoTransformerFactory() - Constructor for class org.apache.solr.response.transform.GeoTransformerFactory
 
get() - Method in class org.apache.solr.api.PayloadObj
 
get() - Method in class org.apache.solr.core.BlobRepository.BlobContent
Get the cached object.
get() - Method in interface org.apache.solr.core.ConfigSetService.ConfigResource
 
get() - Method in class org.apache.solr.core.PluginBag.LazyPluginHolder
 
get() - Method in class org.apache.solr.core.PluginBag.PluginHolder
 
get() - Method in class org.apache.solr.core.RequestParams.ParamSet
get the raw map
get() - Method in class org.apache.solr.handler.StreamHandler.ExpressibleHolder
 
get() - Method in interface org.apache.solr.metrics.reporters.ReporterClientCache.ClientProvider
Get an instance of a service client.
get() - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder
 
get() - Method in class org.apache.solr.util.RefCounted
 
get() - Method in class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
get(int) - Method in class org.apache.solr.logging.CircularList
 
get(int) - Method in class org.apache.solr.util.IntFloatDynamicMap
 
get(int) - Method in class org.apache.solr.util.IntIntDynamicMap
 
get(int) - Method in class org.apache.solr.util.IntLongDynamicMap
 
get(CharSequence) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
Returns the value for the specified key, or null if the key does not exist.
get(CharSequence) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Retrieve the object indexed by a key.
get(Comparable) - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Fast lookup to retrieve a PivotFacetValue from this collection if it exists
get(Object) - Static method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
 
get(Object) - Method in class org.apache.solr.util.MapListener
 
get(String) - Static method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.Cmd
 
get(String) - Method in class org.apache.solr.cloud.DistributedMap
 
get(String) - Static method in enum org.apache.solr.cloud.overseer.OverseerAction
 
get(String) - Method in class org.apache.solr.core.PluginBag
Get a plugin by name.
get(String) - Method in class org.apache.solr.core.RequestHandlers
 
get(String) - Method in class org.apache.solr.core.SolrConfig
fetches a child node by name.
get(String) - Method in class org.apache.solr.core.XmlConfigFile
 
get(String) - Method in class org.apache.solr.index.MergePolicyFactoryArgs
 
get(String) - Static method in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
 
get(String) - Static method in enum org.apache.solr.schema.SchemaManager.OpType
 
get(String) - Static method in enum org.apache.solr.search.ReRankOperator
 
get(String) - Static method in enum org.apache.solr.security.PermissionNameProvider.Name
 
get(String) - Static method in enum org.apache.solr.update.SolrIndexSplitter.SplitMethod
 
get(String) - Static method in enum org.apache.solr.util.PivotListEntry
Case-insensitive lookup of PivotListEntry by name
get(String, boolean) - Method in class org.apache.solr.core.PluginBag
Fetches a plugin by name , or the default
get(String, String) - Method in class org.apache.solr.core.XmlConfigFile
 
get(String, Consumer<FileStore.FileEntry>, boolean) - Method in class org.apache.solr.filestore.DistribFileStore
 
get(String, Consumer<FileStore.FileEntry>, boolean) - Method in interface org.apache.solr.filestore.FileStore
read file content from a given path
get(String, Predicate<ConfigNode>) - Method in class org.apache.solr.core.SolrConfig
 
get(String, SolrParams) - Method in class org.apache.solr.highlight.BreakIteratorBoundaryScanner
 
get(String, SolrParams) - Method in class org.apache.solr.highlight.SimpleBoundaryScanner
 
get(String, SolrParams) - Method in class org.apache.solr.highlight.SolrBoundaryScanner
 
get(String, DirectoryFactory.DirContext, String) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
get(String, DirectoryFactory.DirContext, String) - Method in class org.apache.solr.core.DirectoryFactory
Returns the Directory for a given path, using the specified rawLockType.
get(K) - Method in class org.apache.solr.search.CaffeineCache
 
get(K) - Method in interface org.apache.solr.search.SolrCache
:TODO: copy from Map
get(K) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
get(CollectionParams.CollectionAction) - Static method in enum org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
get(SolrQueryRequest) - Method in class org.apache.solr.search.stats.StatsCache
Prepare a StatsSource that provides stats information to perform local scoring (to be precise, to build a local Weight from the query).
get(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.pkg.PackageAPI.Read
 
get(Token) - Method in class org.apache.solr.spelling.SpellingResult
Gets the suggestions for the given token.
GET - org.apache.solr.servlet.cache.Method
 
GET_DOCLIST - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
GET_DOCSET - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
get_instanceTag() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.MetricMBean
 
GET_SCORES - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
get50thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
get50thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
get75thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
get75thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
get95thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
get95thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
get98thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
get98thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
get999thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
get999thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
get99thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
get99thPercentile() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
getAbs(Query) - Static method in class org.apache.solr.search.QueryUtils
Returns the original query if it was already a positive query, otherwise return the negative of the query (i.e., a positive query).
getAccuracy() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getAccuracy() - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
getAccuracy() - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
getAccuracy() - Method in class org.apache.solr.spelling.SolrSpellChecker
Get the value of SpellingParams.SPELLCHECK_ACCURACY if supported.
getAchievedRf() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor.LeaderRequestReplicationTracker
 
getAchievedRf() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor.RollupRequestReplicationTracker
 
getAction() - Method in class org.apache.solr.request.SolrRequestInfo
 
getActiveQueriesGenerated() - Method in class org.apache.solr.core.CancellableQueryTracker
 
getActiveReplicas() - Method in class org.apache.solr.cloud.ActiveReplicaWatcher
Return the list of active replicas found so far.
getActiveReplicas(ZkController, String) - Static method in class org.apache.solr.handler.SolrConfigHandler
 
getAdminFileFromFileSystem(SolrQueryRequest, SolrQueryResponse, Set<String>) - Static method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
getAdminFileFromZooKeeper(SolrQueryRequest, SolrQueryResponse, SolrZkClient, Set<String>) - Static method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
getAdminPath() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
admin path passed to Overseer is a constant, including in tests.
getAgentId() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Return configured agentId or null.
getAlgorithm() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getAlias(String) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
Returns the aliases found for a field.
getAliasByName(String) - Method in class org.apache.solr.handler.admin.api.ListAliases
 
getAliasedMultiTermQuery() - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
Delegates to the super class unless the field has been specified as an alias -- in which case we recurse on each of the aliased fields, and the results are composed into a DisjunctionMaxQuery.
getAliasedQuery() - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
Delegates to the super class unless the field has been specified as an alias -- in which case we recurse on each of the aliased fields, and the results are composed into a DisjunctionMaxQuery.
getAliases() - Method in class org.apache.solr.core.CoreContainer
Retrieve the aliases from zookeeper.
getAliases() - Method in class org.apache.solr.handler.admin.api.ListAliases
V2 API for listing all aliases known by Solr.
getAliasMetadata() - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
getAliasMetadata() - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
getAliasMetadata() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getAliasName() - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
getAliasName() - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
getAliasName() - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
The name of the alias.
getAliasName() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getAliasProperty(String, String) - Method in class org.apache.solr.handler.admin.api.AliasProperty
 
getAll(String) - Method in class org.apache.solr.util.DataConfigNode
 
getAll(String) - Method in class org.apache.solr.util.DOMConfigNode
 
getAll(Predicate<ConfigNode>, Set<String>) - Method in class org.apache.solr.util.DataConfigNode
 
getAllAliasProperties(String) - Method in class org.apache.solr.handler.admin.api.AliasProperty
 
getAllBlobs(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetBlobInfoAPI
 
getAllConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetConfigAPI
 
getAllConfigFiles(String) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
getAllConfigFiles(String) - Method in class org.apache.solr.core.ConfigSetService
Get the names of the files in config including dirs (mutable, non-null) sorted lexicographically e.g.
getAllConfigFiles(String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
getAllCoreNames() - Method in class org.apache.solr.core.CoreContainer
Gets a collection of all the cores, permanent and transient, that are currently known, whether they are loaded or not.
getAllCoreNames() - Method in class org.apache.solr.core.SolrCores
Gets a collection of all cores names, loaded and unloaded.
getAllCoreNames() - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Returns the names of all possible cores, whether they are currently loaded or not.
getAllCoreNames() - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
getAllCoreNames() - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getAllHighlights(Object[]) - Method in class org.apache.solr.handler.component.HighlightComponent
 
getAllLevels() - Method in class org.apache.solr.handler.admin.api.V2NodeLoggingAPI
 
getAllLevels() - Method in class org.apache.solr.logging.jul.JulWatcher
 
getAllLevels() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
getAllLevels() - Method in class org.apache.solr.logging.LogWatcher
 
getAllLoggers() - Method in class org.apache.solr.logging.jul.JulWatcher
 
getAllLoggers() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
getAllLoggers() - Method in class org.apache.solr.logging.LogWatcher
 
getAllowLeadingWildcard() - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getAllowListUrlChecker() - Method in class org.apache.solr.core.CoreContainer
Gets the URLs checker based on the allowUrls configuration of solr.xml.
getAllowPaths() - Method in class org.apache.solr.core.CoreContainer
Return the file system paths that should be allowed for various API requests.
getAllowPaths() - Method in class org.apache.solr.core.NodeConfig
Extra file paths that will be allowed for core creation, in addition to SOLR_HOME, SOLR_DATA_HOME and coreRootDir
getAllowUrls() - Method in class org.apache.solr.core.NodeConfig
Allow-list of Solr nodes URLs.
getAllParamSets(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetConfigAPI
 
getAllPhraseFields() - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
getAllQueryFacets() - Method in class org.apache.solr.handler.component.FacetComponent.FacetContext
 
getAllRangeFacetRequests() - Method in class org.apache.solr.handler.component.FacetComponent.FacetContext
 
getAllReplicaCount() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
getAllReplicasOnNode() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
getAllShardBackupMetadataFiles() - Method in class org.apache.solr.core.backup.BackupProperties
 
getAllStored() - Method in class org.apache.solr.search.SolrDocumentFetcher
 
getAllValues() - Method in class org.apache.solr.internal.csv.CSVParser
Parses the CSV according to the given strategy and returns the content as an array of records (whereas records are arrays of single values).
getAlternateUserQuery(SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
 
getAmount() - Method in class org.apache.solr.schema.CurrencyValue
The amount of the CurrencyValue.
getAnalyticsCollector(ResponseBuilder, IndexSearcher) - Method in class org.apache.solr.search.AnalyticsQuery
 
getAnalyticsRequestManager() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getAnalyzer() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
 
getAnalyzer() - Method in class org.apache.solr.spelling.QueryConverter
 
getAnalyzerProperties(Analyzer) - Static method in class org.apache.solr.schema.FieldType
Returns a description of the given analyzer, by either reporting the Analyzer class name (and optionally luceneMatchVersion) if it's not a TokenizerChain, or if it is, querying each analysis factory for its name and args.
getAndCheckVersionField(IndexSchema) - Static method in class org.apache.solr.update.VersionInfo
Gets and returns the CommonParams.VERSION_FIELD from the specified schema, after verifying that it is indexed, stored, and single-valued.
getAndIncrement(String) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Retrieve the Float indexed by key, increment it by one unit and store the new Float.
getAndPrepShardHandler(SolrQueryRequest, ResponseBuilder) - Method in class org.apache.solr.handler.component.SearchHandler
 
getAndSaveCommitPoint(Long) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Atomically Saves (via reference counting) & Returns the specified commit if available.
getAndSaveLatestCommit() - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Atomically Saves (via reference counting) & Returns the most recent commit point.
getAndSaveNamedIndexCommit(SolrCore, String) - Static method in class org.apache.solr.handler.SnapShooter
 
getAndValidateBackupLocation(String, String) - Method in class org.apache.solr.handler.admin.api.BackupAPIBase
 
getAndValidateIncrementalBackupLocation(String, String, String) - Method in class org.apache.solr.handler.admin.api.BackupAPIBase
 
getApiBag() - Method in class org.apache.solr.core.PluginBag
 
getApiInfo(PluginBag<SolrRequestHandler>, String, String, String, Map<String, String>) - Static method in class org.apache.solr.api.V2HttpCall
 
getApis() - Method in interface org.apache.solr.api.ApiSupport
Returns any (non-JAX-RS annotated) APIs associated with this request handler.
getApis() - Method in class org.apache.solr.handler.admin.BaseHandlerApiSupport
 
getApis() - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
getApis() - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
getApis() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
getApis() - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
getApis() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getApis() - Method in class org.apache.solr.handler.admin.LoggingHandler
 
getApis() - Method in class org.apache.solr.handler.admin.PropertiesRequestHandler
 
getApis() - Method in class org.apache.solr.handler.admin.SecurityConfHandler
 
getApis() - Method in class org.apache.solr.handler.admin.SystemInfoHandler
 
getApis() - Method in class org.apache.solr.handler.admin.ThreadDumpHandler
 
getApis() - Method in class org.apache.solr.handler.BlobHandler
 
getApis() - Method in class org.apache.solr.handler.component.ActiveTasksListHandler
 
getApis() - Method in class org.apache.solr.handler.component.QueryCancellationHandler
 
getApis() - Method in class org.apache.solr.handler.MoreLikeThisHandler
 
getApis() - Method in class org.apache.solr.handler.RealTimeGetHandler
 
getApis() - Method in class org.apache.solr.handler.RequestHandlerBase
 
getApis() - Method in class org.apache.solr.handler.SchemaHandler
 
getApis() - Method in class org.apache.solr.handler.SolrConfigHandler
 
getApis() - Method in class org.apache.solr.handler.V2UpdateRequestHandler
 
getApis() - Method in class org.apache.solr.security.PublicKeyHandler
 
getApis(Class<?>, Object, boolean) - Static method in class org.apache.solr.api.AnnotatedApi
Get a list of Api-s supported by this class.
getApis(Object) - Static method in class org.apache.solr.api.AnnotatedApi
 
getAppender() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
getArg() - Method in class org.apache.solr.search.facet.SimpleAggValueSource
 
getArg() - Method in class org.apache.solr.search.facet.StrAggValueSource
 
getArgs() - Method in class org.apache.solr.core.AbstractSolrEventListener
 
getArgs() - Method in class org.apache.solr.schema.SchemaField
 
getAssignedCoreNodeName(DocCollection, String, String) - Static method in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
getAssignedId(DocCollection, String) - Static method in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
getAsyncTaskRequestStatus(String) - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
getAsyncTaskRequestStatus(String) - Method in class org.apache.solr.cloud.DistributedApiAsyncTracker
This method implements the logic described in the class Javadoc table (DistributedApiAsyncTracker), using the two sets of tracking info to build the actual state of an async task.
getAt(int) - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Fetchs a PivotFacetValue from this collection via the index, may not be used to fetch the PivotFacetValue corrisponding to the missing-value.
getAttribute(String) - Method in class org.apache.solr.metrics.MetricsMap
 
getAttributeFetcher() - Method in class org.apache.solr.cluster.placement.impl.SimplePlacementContextImpl
 
getAttributeFetcher() - Method in interface org.apache.solr.cluster.placement.PlacementContext
Factory used by the plugin to fetch additional attributes from the cluster nodes, such as count of cores, system properties etc..
getAttributes() - Method in class org.apache.solr.schema.SchemaField
 
getAttributes(String[]) - Method in class org.apache.solr.metrics.MetricsMap
 
getAuditLoggerPlugin() - Method in class org.apache.solr.core.CoreContainer
 
GetAuthenticationConfigAPI - Class in org.apache.solr.handler.admin.api
V2 API for fetching the authentication section from Solr's security.json configuration.
GetAuthenticationConfigAPI(SecurityConfHandler) - Constructor for class org.apache.solr.handler.admin.api.GetAuthenticationConfigAPI
 
getAuthenticationPlugin() - Method in class org.apache.solr.core.CoreContainer
 
getAuthenticationProvider(Map<String, Object>) - Method in class org.apache.solr.security.BasicAuthPlugin
 
GetAuthorizationConfigAPI - Class in org.apache.solr.handler.admin.api
V2 API for fetching the authorization section of Solr's security.json configuration.
GetAuthorizationConfigAPI(SecurityConfHandler) - Constructor for class org.apache.solr.handler.admin.api.GetAuthorizationConfigAPI
 
getAuthorizationPlugin() - Method in class org.apache.solr.core.CoreContainer
 
getAutoDeleteAgeMath() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getAutoGeneratePhraseQueries() - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getAutoGeneratePhraseQueries() - Method in class org.apache.solr.schema.TextField
 
getAutowarmDescription() - Method in class org.apache.solr.search.SolrCacheBase
 
getAutResponse() - Method in class org.apache.solr.security.AuditEvent
The authorization response object from authorization plugin, or null authz has not happened
getAvgMemoryUsage() - Method in class org.apache.solr.util.circuitbreaker.MemoryCircuitBreaker
 
getBackingArray() - Method in class org.apache.solr.util.LongSet
Returns the long[] array that has entries filled in with values or "0" for empty.
getBackupId() - Method in class org.apache.solr.core.backup.BackupManager
 
getBackupLocation() - Method in class org.apache.solr.core.backup.BackupFilePaths
 
getBackupLocation(String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns the location where the backup should be stored (or restored from).
getBackupMetadataFilename() - Method in class org.apache.solr.core.backup.ShardBackupId
 
getBackupName() - Method in class org.apache.solr.core.backup.BackupProperties
 
getBackupPropsName(BackupId) - Static method in class org.apache.solr.core.backup.BackupFilePaths
Get the filename of the top-level backup properties file
getBackupRepository() - Method in class org.apache.solr.handler.SnapShooter
 
getBackupRepositoryPlugins() - Method in class org.apache.solr.core.NodeConfig
 
getBalancePlanFactory() - Method in class org.apache.solr.cluster.placement.impl.SimplePlacementContextImpl
 
getBalancePlanFactory() - Method in interface org.apache.solr.cluster.placement.PlacementContext
Factory used to create instances of BalancePlan to return computed decision.
getBase() - Method in class org.apache.solr.search.facet.FacetContext
 
getBaseConfigSetName(ConfigSetParams.ConfigSetAction, String) - Static method in class org.apache.solr.cloud.ConfigSetCmds
 
getBaseDir(Directory) - Method in class org.apache.solr.core.DirectoryFactory
 
getBaseUrl() - Method in class org.apache.solr.cloud.ZkController
 
getBaseUrl() - Method in class org.apache.solr.security.AuditEvent
First part of URL of the request, but not including request parameters, or null if not set
getBaseUrl() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
getBaseUrl() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
getBaseWeightedNodes(PlacementContext, Set<Node>, Iterable<SolrCollection>, boolean) - Method in class org.apache.solr.cluster.placement.plugins.AffinityPlacementFactory.AffinityPlacementPlugin
 
getBaseWeightedNodes(PlacementContext, Set<Node>, Iterable<SolrCollection>, boolean) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
getBaseWeightedNodes(PlacementContext, Set<Node>, Iterable<SolrCollection>, boolean) - Method in class org.apache.solr.cluster.placement.plugins.RandomPlacementFactory.RandomPlacementPlugin
 
getBaseWeightedNodes(PlacementContext, Set<Node>, Iterable<SolrCollection>, boolean) - Method in class org.apache.solr.cluster.placement.plugins.SimplePlacementFactory.SimplePlacementPlugin
 
getBaseWriter(SolrQueryRequest) - Method in class org.apache.solr.response.RawResponseWriter
 
getBigTerms(int, UnInvertedField.Callback) - Method in class org.apache.solr.search.facet.UnInvertedField.DocToTerm
 
getBinaryDocValues(int, LeafReader, int) - Method in class org.apache.solr.search.DocValuesIteratorCache.FieldDocValuesSupplier
Returns docValues for the specified doc id in the specified reader, if the specified doc holds docValues for this DocValuesIteratorCache.FieldDocValuesSupplier instance, otherwise returns null.
getBinaryDocValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getBinaryDocValues(String) - Method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
 
getBinaryDocValues(String) - Method in class org.apache.solr.uninverting.UninvertingReader
 
getBits() - Method in class org.apache.solr.search.BitDocSet
 
getBits() - Method in class org.apache.solr.search.DocSet
A Bits that has fast random access (as is generally required of Bits).
getBits() - Method in class org.apache.solr.search.SortedIntDocSet
 
getBlobByName(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetBlobInfoAPI
 
getBlobIncRef(String) - Method in class org.apache.solr.core.BlobRepository
Returns the contents of a blob containing a ByteBuffer and increments a reference count.
GetBlobInfoAPI - Class in org.apache.solr.handler.admin.api
V2 APIs for fetching blob(s) and their metadata
GetBlobInfoAPI(BlobHandler) - Constructor for class org.apache.solr.handler.admin.api.GetBlobInfoAPI
 
getBlobRepository() - Method in class org.apache.solr.core.CoreContainer
 
getBlockUnknown() - Method in class org.apache.solr.security.BasicAuthPlugin
 
getBool(String) - Method in class org.apache.solr.core.XmlConfigFile
 
getBool(String, boolean) - Method in class org.apache.solr.core.XmlConfigFile
 
getBooleanQuery(List<BooleanClause>) - Method in class org.apache.solr.parser.SolrQueryParserBase
Factory method for generating query, given a set of clauses.
getBooleanQuery(List<BooleanClause>) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getBooleanQueryMaxClauseCount() - Method in class org.apache.solr.core.NodeConfig
If null, the lucene default will not be overridden
getBoost() - Method in class org.apache.solr.search.FieldParams
 
getBoostDocs(SolrIndexSearcher, Set<BytesRef>, Map<Object, Object>) - Static method in class org.apache.solr.handler.component.QueryElevationComponent
Resolves a set of boosted docs by uniqueKey to a map of docIds mapped to a priority value > 0.
getBoostedMLTQuery() - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
 
getBoostedMLTQuery(int) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
getBoostFunctions() - Method in class org.apache.solr.search.ExtendedDismaxQParser
Parses all function queries
getBoostQueries() - Method in class org.apache.solr.search.ExtendedDismaxQParser
Parses all boost queries
getBoundaryScanner(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
 
getBoundaryScanner(String, SolrParams) - Method in class org.apache.solr.highlight.SolrBoundaryScanner
 
getBreakIterator(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getBuf() - Method in class org.apache.solr.util.RecordingJSONParser
 
getBuffer() - Method in class org.apache.solr.filestore.FileStore.FileEntry
For very large files , only a stream would be available This method would return null;
getBufferPos() - Method in class org.apache.solr.update.TransactionLog.ChannelFastInputStream
where is the start of the buffer relative to the whole file
getBufferSize() - Method in class org.apache.solr.logging.CircularList
 
getBufferSize() - Method in class org.apache.solr.update.TransactionLog.ChannelFastInputStream
 
getBufferUpdates() - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
 
getByte() - Method in class org.apache.solr.search.StrParser
 
getBytes() - Method in class org.apache.solr.cloud.OverseerTaskQueue.QueueEvent
 
getBytesRef() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
getBytesRef(Object) - Static method in class org.apache.solr.schema.StrField
 
getByteVector() - Method in class org.apache.solr.util.vector.ByteDenseVectorParser
 
getByteVector() - Method in class org.apache.solr.util.vector.DenseVectorParser
 
getByteVectorValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getCache() - Method in class org.apache.solr.query.FilterQuery
 
getCache() - Method in class org.apache.solr.search.AnalyticsQuery
 
getCache() - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
getCache() - Method in interface org.apache.solr.search.ExtendedQuery
Should this query be cached in the query cache or filter cache.
getCache() - Method in class org.apache.solr.search.ExtendedQueryBase
 
getCache(String) - Method in class org.apache.solr.core.CoreContainer
 
getCache(String) - Method in class org.apache.solr.search.SolrIndexSearcher
return the named generic cache
getCacheConfig() - Method in class org.apache.solr.core.MetricsConfig
 
getCacheControlHeader() - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
null if no Cache-Control header
getCachedBitSetProducer(SolrQueryRequest, Query) - Static method in class org.apache.solr.search.join.BlockJoinParentQParser
 
getCacheEntries() - Method in interface org.apache.solr.uninverting.FieldCache
EXPERT: Generates an array of CacheEntry objects representing all items currently in the FieldCache.
getCacheEntries() - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getCacheMetrics() - Method in class org.apache.solr.search.stats.StatsCache
 
getCachesConfig() - Method in class org.apache.solr.core.NodeConfig
 
getCacheType() - Method in class org.apache.solr.uninverting.FieldCache.CacheEntry
 
getCancellableQueryTracker() - Method in class org.apache.solr.core.SolrCore
 
getCancellableTask(String) - Method in class org.apache.solr.core.CancellableQueryTracker
 
getCancellationUUID() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getCanonicalUrl(URL) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
Gets a canonical form of the URL for use as main URL
getCategory() - Method in class org.apache.solr.core.SolrCore
 
getCategory() - Method in interface org.apache.solr.core.SolrInfoBean
Category of this component
getCategory() - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.LoggingHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.LukeRequestHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.MetricsHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.PluginInfoHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.PropertiesRequestHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.SecurityConfHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.SystemInfoHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.ThreadDumpHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.ZookeeperInfoHandler
 
getCategory() - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
 
getCategory() - Method in class org.apache.solr.handler.component.ActiveTasksListComponent
 
getCategory() - Method in class org.apache.solr.handler.component.ActiveTasksListHandler
 
getCategory() - Method in class org.apache.solr.handler.component.DebugComponent
 
getCategory() - Method in class org.apache.solr.handler.component.ExpandComponent
 
getCategory() - Method in class org.apache.solr.handler.component.FacetComponent
 
getCategory() - Method in class org.apache.solr.handler.component.HighlightComponent
 
getCategory() - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
getCategory() - Method in class org.apache.solr.handler.component.QueryCancellationComponent
 
getCategory() - Method in class org.apache.solr.handler.component.QueryCancellationHandler
 
getCategory() - Method in class org.apache.solr.handler.component.QueryComponent
 
getCategory() - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
getCategory() - Method in class org.apache.solr.handler.component.SearchComponent
 
getCategory() - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
getCategory() - Method in class org.apache.solr.handler.component.TermsComponent
 
getCategory() - Method in class org.apache.solr.handler.component.TermVectorComponent
 
getCategory() - Method in class org.apache.solr.handler.PingRequestHandler
 
getCategory() - Method in class org.apache.solr.handler.ReplicationHandler
 
getCategory() - Method in class org.apache.solr.handler.RequestHandlerBase
 
getCategory() - Method in class org.apache.solr.handler.SchemaHandler
 
getCategory() - Method in class org.apache.solr.handler.SolrConfigHandler
 
getCategory() - Method in class org.apache.solr.handler.UpdateRequestHandler
 
getCategory() - Method in class org.apache.solr.highlight.HighlightingPluginBase
 
getCategory() - Method in class org.apache.solr.search.facet.FacetModule
 
getCategory() - Method in class org.apache.solr.search.QParserPlugin
 
getCategory() - Method in class org.apache.solr.search.SolrCacheBase
 
getCategory() - Method in class org.apache.solr.search.SolrFieldCacheBean
 
getCategory() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getCategory() - Method in class org.apache.solr.security.AuditLoggerPlugin
 
getCategory() - Method in class org.apache.solr.security.AuthenticationPlugin
 
getCategory() - Method in class org.apache.solr.security.PublicKeyHandler
 
getCategory() - Method in class org.apache.solr.update.UpdateHandler
 
getCategory() - Method in class org.apache.solr.update.UpdateShardHandler
 
getCharacterEncoding() - Method in class org.apache.solr.spelling.FileBasedSpellChecker
 
getCharacters() - Method in class org.apache.solr.internal.csv.CharBuffer
Returns the contents of the buffer as a char[].
getCharFilterFactories() - Method in class org.apache.solr.analysis.TokenizerChain
 
getChild(String) - Method in class org.apache.solr.core.PluginInfo
 
getChildContext(Object) - Method in class org.apache.solr.metrics.SolrDelegateRegistryMetricsContext
 
getChildContext(Object) - Method in class org.apache.solr.metrics.SolrMetricsContext
Get a context with the same registry name but a tag that represents a parent-child relationship.
getChildPivot() - Method in class org.apache.solr.handler.component.PivotFacetValue
The PivotFacetField corrisponding to the nested child pivot for this PivotFacetValue.
getChildren() - Method in class org.apache.solr.search.facet.AggValueSource
 
getChildren() - Method in class org.apache.solr.util.RTimerTree
Manipulating this map may have undefined results.
getChildren(String) - Method in class org.apache.solr.core.PluginInfo
Filter children by type
getChildResources() - Method in class org.apache.solr.handler.component.SuggestComponent
 
getChildResources() - Method in class org.apache.solr.search.BitDocSet
 
getChildResources() - Method in class org.apache.solr.search.DocSlice
 
getChildResources() - Method in class org.apache.solr.search.FilteredDocIdSet
 
getChildResources() - Method in class org.apache.solr.search.SortedIntDocSet
 
getChildResources() - Method in class org.apache.solr.spelling.suggest.SolrSuggester
 
getChildResources() - Method in class org.apache.solr.uninverting.FieldCacheImpl.BinaryDocValuesImpl
 
getChildResources() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl
 
getChildResources() - Method in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
getChildResources() - Method in class org.apache.solr.util.ConcurrentLRUCache
 
getCircuitBreakerRegistry() - Method in class org.apache.solr.core.SolrCore
 
getClassArg() - Method in class org.apache.solr.schema.FieldType
 
getClassArg() - Method in class org.apache.solr.schema.SimilarityFactory
 
getClassificationParams() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorFactory
 
getClassLoader() - Method in class org.apache.solr.core.SolrResourceLoader
EXPERT
getClassName() - Method in class org.apache.solr.core.PluginBag.PluginHolder
 
getCleanTag() - Method in class org.apache.solr.core.SolrConfig.SolrPluginInfo
 
getClient() - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
getClientIp() - Method in class org.apache.solr.security.AuditEvent
IP address of the client doing the request
getClientKeyStorePassword() - Method in class org.apache.solr.util.configuration.SSLConfigurations
 
getClientString() - Method in class org.apache.solr.cloud.SolrZkServer
 
getClientTimeZone() - Method in class org.apache.solr.request.SolrRequestInfo
The TimeZone specified by the request, or UTC if none was specified.
getClientTrustStorePassword() - Method in class org.apache.solr.util.configuration.SSLConfigurations
 
getClock(PluginInfo, String) - Static method in class org.apache.solr.metrics.MetricSuppliers
 
getCloseableToLatchOn() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
getCloseableToLatchOn() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
getCloseableToLatchOn() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getCloseEndOff(int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
getCloseHooks() - Method in class org.apache.solr.core.SolrCore
 
getCloseStartOff(int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
getCloudConfig() - Method in class org.apache.solr.core.NodeConfig
 
getCloudDescriptor() - Method in class org.apache.solr.core.CoreDescriptor
 
getCloudDescriptor() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getCloudDescriptor() - Method in interface org.apache.solr.request.SolrQueryRequest
 
getCloudStatus(SolrClient, String) - Method in class org.apache.solr.cli.StatusTool
Calls the CLUSTERSTATUS endpoint in Solr to get basic status information about the SolrCloud cluster.
getCluster() - Method in class org.apache.solr.cluster.placement.impl.SimplePlacementContextImpl
 
getCluster() - Method in interface org.apache.solr.cluster.placement.PlacementContext
Initial state of the cluster.
getClusterEventProducer() - Method in class org.apache.solr.core.CoreContainer
 
getClusterPlugins() - Method in class org.apache.solr.core.NodeConfig
 
getClusterSingletons() - Method in class org.apache.solr.core.CoreContainer
 
getClusterState() - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
 
getClusterState() - Method in class org.apache.solr.cloud.ZkController
 
getClusterStatus(NamedList<Object>) - Method in class org.apache.solr.handler.admin.ClusterStatus
 
getClusterStatus(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
getCode() - Method in class org.apache.solr.handler.admin.SolrEnvironment
 
getCode() - Method in enum org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
 
getCodec() - Method in class org.apache.solr.core.CodecFactory
 
getCodec() - Method in class org.apache.solr.core.LuceneDefaultCodecFactory
 
getCodec() - Method in class org.apache.solr.core.SchemaCodecFactory
 
getCodec() - Method in class org.apache.solr.core.SimpleTextCodecFactory
 
getCodec() - Method in class org.apache.solr.core.SolrCore
 
getCollationQuery() - Method in class org.apache.solr.spelling.SpellCheckCollation
 
getCollection() - Method in class org.apache.solr.cloud.ActiveReplicaWatcher
Collection name.
getCollection() - Method in class org.apache.solr.cluster.placement.impl.BalanceRequestImpl
 
getCollection() - Method in class org.apache.solr.cluster.placement.impl.PlacementRequestImpl
 
getCollection() - Method in interface org.apache.solr.cluster.placement.ModificationRequest
The SolrCollection to modify.
getCollection() - Method in interface org.apache.solr.cluster.placement.ReplicaPlacement
 
getCollection() - Method in interface org.apache.solr.cluster.Shard
 
getCollection() - Method in class org.apache.solr.core.backup.BackupProperties
 
getCollection() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
getCollection() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
getCollection(String) - Method in interface org.apache.solr.cluster.Cluster
Returns info about the given collection if one exists.
getCollectionAlias() - Method in class org.apache.solr.core.backup.BackupProperties
 
getCollectionLevelSnapshot(SolrZkClient, String, String) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method returns the CollectionSnapshotMetaData for the named snapshot for the specified collection in Zookeeper.
getCollectionMetrics(String) - Method in interface org.apache.solr.cluster.placement.AttributeValues
Get collection metrics.
getCollectionMetrics(String) - Method in class org.apache.solr.cluster.placement.impl.AttributeValuesImpl
 
getCollectionName() - Method in class org.apache.solr.cloud.CloudDescriptor
 
getCollectionName() - Method in class org.apache.solr.core.CoreDescriptor
 
getCollectionName(ZkNodeProps) - Static method in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
Collection name can be found in either of two message parameters (why??).
getCollectionName(ZkNodeProps) - Method in enum org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
getCollectionNames() - Method in interface org.apache.solr.cluster.events.CollectionsAddedEvent
 
getCollectionNames() - Method in interface org.apache.solr.cluster.events.CollectionsRemovedEvent
 
getCollectionParamsPath(String) - Static method in class org.apache.solr.packagemanager.PackageUtils
 
getCollectionRequests() - Method in class org.apache.solr.security.AuthorizationContext
 
getCollectionRequests() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getCollectionRequests(String, List<String>, SolrParams) - Static method in class org.apache.solr.security.AuthorizationUtils
 
getCollections() - Method in class org.apache.solr.security.AuditEvent
List of collection names involved in request
getCollectionsHandler() - Method in class org.apache.solr.core.CoreContainer
 
getCollectionsHandlerClass() - Method in class org.apache.solr.core.NodeConfig
 
getCollectionsList() - Method in class org.apache.solr.servlet.HttpSolrCall
The collection(s) referenced in this request.
getCollectionsOnNode() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
getCollectionStatus(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.CollectionStatusAPI
 
getColor() - Method in class org.apache.solr.handler.admin.SolrEnvironment
 
getColStatus(NamedList<Object>) - Method in class org.apache.solr.handler.admin.ColStatus
 
getCommandFor(CollectionParams.CollectionAction) - Static method in enum org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
getCommandOperations(ContentStream, Map<String, JsonSchemaValidator>, boolean) - Static method in class org.apache.solr.api.ApiBag
 
getCommands() - Method in class org.apache.solr.api.AnnotatedApi
 
getCommands() - Method in class org.apache.solr.handler.admin.BaseHandlerApiSupport
 
getCommands() - Method in class org.apache.solr.search.Grouping
 
getCommands(boolean) - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getCommands(boolean) - Method in interface org.apache.solr.request.SolrQueryRequest
Only for v2 API if the request contains a command payload, it's parsed and returned as a list of CommandOperation objects
getCommands(boolean) - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getCommands(boolean) - Method in class org.apache.solr.servlet.HttpSolrCall
 
getCommandSchema() - Method in class org.apache.solr.api.Api
This method helps to cache the schema validator object
getCommandStatus(String) - Method in class org.apache.solr.handler.admin.api.GetNodeCommandStatus
 
getCommandStatus(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
getCommentStart() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getCommitCount() - Method in class org.apache.solr.update.CommitTracker
 
getCommitLock() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getCommitLock() - Method in class org.apache.solr.update.SolrCoreState
 
getCommitPoint(Long) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
getCommits() - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Returns a Map of all currently known commits, keyed by their generation.
getCommitTimestamp(IndexCommit) - Static method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Helper method for unpacking the timestamp info from the user data
getCommitTracker() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
getCommitVersion(SolrCore) - Static method in class org.apache.solr.cloud.ReplicateFromLeader
 
getComponentConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetConfigAPI
 
getComponents() - Method in class org.apache.solr.handler.component.SearchHandler
 
getConf(SolrQueryResponse, String) - Method in class org.apache.solr.handler.admin.SecurityConfHandler
 
getConf(SolrQueryResponse, String) - Method in class org.apache.solr.handler.admin.SecurityConfHandlerLocal
 
getConf(SolrQueryResponse, String) - Method in class org.apache.solr.handler.admin.SecurityConfHandlerZk
 
getConfFileInfoCache() - Method in class org.apache.solr.handler.ReplicationHandler
 
getConfFileInfoFromCache(NamedList<String>, Map<String, ReplicationHandler.FileInfo>) - Method in class org.apache.solr.handler.ReplicationHandler
For configuration files, checksum of the file is included because, unlike index files, they may have same content but different timestamps.
getConfFileNameAlias() - Method in class org.apache.solr.handler.ReplicationHandler
 
getConfig() - Method in class org.apache.solr.cluster.placement.impl.DelegatingPlacementPluginFactory
 
getConfig() - Method in interface org.apache.solr.cluster.placement.PlacementPluginFactory
Return the configuration of the plugin.
getConfig() - Method in class org.apache.solr.cluster.placement.plugins.AffinityPlacementFactory
 
getConfig() - Method in class org.apache.solr.core.CoreContainer
 
getConfig() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
getConfig(String, Map<String, String>) - Static method in class org.apache.solr.core.TracerConfigurator
Returns system property if found, else returns environment variable, or null if none found.
getConfig(SolrConfig, String, Map<String, String>, String) - Static method in class org.apache.solr.search.CacheConfig
 
getConfig(SolrConfig, ConfigNode, String) - Static method in class org.apache.solr.search.CacheConfig
 
getConfig(SolrResourceLoader, SolrConfig, String, Map<String, String>, String) - Static method in class org.apache.solr.search.CacheConfig
 
GetConfigAPI - Class in org.apache.solr.handler.admin.api
V2 APIs for retrieving some or all configuration relevant to a particular collection (or core).
GetConfigAPI(SolrConfigHandler) - Constructor for class org.apache.solr.handler.admin.api.GetConfigAPI
 
getConfigClass() - Method in class org.apache.solr.handler.ReplicationHandler
 
getConfigClass() - Method in interface org.apache.solr.jersey.APIConfigProvider
 
getConfigClass(ConfigurablePlugin<T>) - Static method in class org.apache.solr.api.ContainerPluginsRegistry
Get the generic type of a ConfigurablePlugin
getConfigDir() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
 
getConfigDir() - Method in class org.apache.solr.core.SolrResourceLoader
getConfigDir(String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
getConfigDirListener() - Method in class org.apache.solr.cloud.ZkController
 
getConfigMetadata(String) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
getConfigMetadata(String) - Method in class org.apache.solr.core.ConfigSetService
Get the config metadata (mutable, non-null)
getConfigMetadata(String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
getConfigName() - Method in class org.apache.solr.core.backup.BackupProperties
 
getConfigName() - Method in class org.apache.solr.core.CoreDescriptor
 
getConfigOverlay(SolrResourceLoader) - Static method in class org.apache.solr.core.SolrConfig
 
getConfigPath() - Method in class org.apache.solr.core.SolrResourceLoader
 
getConfigProperty(String) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns the value of the specified configuration property.
getConfigProperty(String) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
getConfigResource() - Method in class org.apache.solr.core.SolrCore
Gets the configuration resource name used by this core instance.
getConfigResource(ConfigSetService, InputStream, SolrResourceLoader, String) - Static method in class org.apache.solr.schema.IndexSchemaFactory
 
getConfigSet() - Method in class org.apache.solr.core.CoreDescriptor
 
getConfigSetBaseDirectory() - Method in class org.apache.solr.core.NodeConfig
Absolute.
getConfigsetPath(String, String) - Static method in class org.apache.solr.core.ConfigSetService
 
getConfigSetProperties() - Method in class org.apache.solr.core.SolrCore
 
getConfigSetPropertiesName() - Method in class org.apache.solr.core.CoreDescriptor
 
getConfigSetService() - Method in class org.apache.solr.core.CoreContainer
 
getConfigSetServiceClass() - Method in class org.apache.solr.core.NodeConfig
 
getConfigSetsHandler() - Method in class org.apache.solr.core.CoreContainer
 
getConfigSetsHandlerClass() - Method in class org.apache.solr.core.NodeConfig
 
getConfigSetZkPath() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
 
getConfigVersion(SolrCore) - Method in class org.apache.solr.handler.component.QueryElevationComponent
Returns a version number for the config file, or -1 if not supported.
getConfListener(SolrCore, ZkSolrResourceLoader) - Static method in class org.apache.solr.core.SolrCore
 
getConjunctionDocCount(String) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns the number of documents that contain all of the PhrasesIdentificationComponent.Phrase.getIndividualIndexedTerms() that make up this Phrase, in the specified field.
getConnectionTimeout() - Method in class org.apache.solr.update.UpdateShardHandler
 
getContainerPluginsRegistry() - Method in class org.apache.solr.core.CoreContainer
 
getContainerProperties() - Method in class org.apache.solr.core.CoreContainer
 
getContainingBackupId() - Method in class org.apache.solr.core.backup.ShardBackupId
 
getContentStreams() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getContentStreams() - Method in interface org.apache.solr.request.SolrQueryRequest
A Collection of ContentStreams passed to the request
getContentStreams() - Method in class org.apache.solr.request.SolrQueryRequestBase
A Collection of ContentStreams passed to the request
getContentType() - Method in interface org.apache.solr.core.SolrCore.RawWriter
 
getContentType() - Method in class org.apache.solr.handler.export.ExportWriter
 
getContentType() - Method in class org.apache.solr.rest.BaseSolrResource
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.BinaryResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.CborResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.CSVResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.GraphMLResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.JacksonJsonWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.JSONResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.PHPResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.PHPSerializedResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.PythonResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in interface org.apache.solr.response.QueryResponseWriter
Return the applicable Content Type for a request, this method must be thread safe.
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.RawResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.RubyResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.SchemaXmlResponseWriter
 
getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.XMLResponseWriter
 
getContext() - Method in class org.apache.solr.cloud.LeaderElector
 
getContext() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getContext() - Method in interface org.apache.solr.request.SolrQueryRequest
Generic information associated with this request that may be both read and updated.
getContext() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getContext() - Method in class org.apache.solr.security.AuditEvent
A general purpose context map with potential extra information about the event
getContext(Class<?>) - Method in class org.apache.solr.jersey.SolrJacksonMapper
 
getConvertedValueSource(String, CurrencyFieldType.RawCurrencyValueSource) - Method in class org.apache.solr.schema.CurrencyFieldType
Returns a ValueSource over this field in which the numeric value for each document represents the value from the underlying RawCurrencyValueSource as converted to the specified target Currency.
getCopyFieldList(ManagedIndexSchema) - Static method in class org.apache.solr.handler.designer.ManagedSchemaDiff
 
getCopyFieldProperties(boolean, Set<String>, Set<String>) - Method in class org.apache.solr.schema.IndexSchema
Returns a list of copyField directives, with optional details and optionally restricting to those directives that contain the requested source and/or destination field names.
getCopyFieldsList(String) - Method in class org.apache.solr.schema.IndexSchema
Get all copy fields for a specified source field, both static and dynamic ones.
getCopyFieldsMap() - Method in class org.apache.solr.schema.IndexSchema
 
getCopySources(String) - Method in class org.apache.solr.schema.IndexSchema
Get all copy fields, both the static and the dynamic ones.
getCore() - Method in class org.apache.solr.core.AbstractSolrEventListener
 
getCore() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
 
getCore() - Method in class org.apache.solr.metrics.SolrCoreReporter
 
getCore() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getCore() - Method in interface org.apache.solr.request.SolrQueryRequest
The solr core (coordinator, etc) associated with this request
getCore() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getCore() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getCore() - Method in class org.apache.solr.servlet.HttpSolrCall
 
getCore(String) - Method in class org.apache.solr.core.CoreContainer
 
getCore(String) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Gets the core associated with the name.
getCore(String) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
getCore(String, UUID) - Method in class org.apache.solr.core.CoreContainer
Gets a core by name and increase its refcount.
getCore(CoordinatorHttpSolrCall.Factory, HttpSolrCall, String, boolean) - Static method in class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
getCoreAdminAsyncTracker() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
The instance of CoreAdminAsyncTracker owned by this handler.
getCoreAdminHandlerActions() - Method in class org.apache.solr.core.NodeConfig
 
getCoreAdminHandlerClass() - Method in class org.apache.solr.core.NodeConfig
 
getCoreByCollection(String, boolean) - Method in class org.apache.solr.api.CoordinatorV2HttpSolrCall
 
getCoreByCollection(String, boolean) - Method in class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
getCoreByCollection(String, boolean) - Method in class org.apache.solr.servlet.HttpSolrCall
 
getCoreCacheHelper() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getCoreCacheHelper() - Method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
 
getCoreCacheHelper() - Method in class org.apache.solr.uninverting.UninvertingReader
 
getCoreContainer() - Method in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
Getter method for the CoreContainer
getCoreContainer() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
getCoreContainer() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
getCoreContainer() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getCoreContainer() - Method in class org.apache.solr.cloud.Overseer
 
getCoreContainer() - Method in class org.apache.solr.cloud.ZkController
 
getCoreContainer() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
 
getCoreContainer() - Method in class org.apache.solr.core.SolrCore
 
getCoreContainer() - Method in class org.apache.solr.core.SolrResourceLoader
 
getCoreContainer() - Method in class org.apache.solr.handler.admin.CollectionsHandler
The instance of CoreContainer this handler handles.
getCoreContainer() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
The instance of CoreContainer this handler handles.
getCoreContainer() - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
getCoreContainer() - Method in class org.apache.solr.handler.admin.InfoHandler
The instance of CoreContainer this handler handles.
getCoreContainer() - Method in class org.apache.solr.metrics.SolrCoreContainerReporter
 
getCoreContainer() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getCoreContainer() - Method in interface org.apache.solr.request.SolrQueryRequest
 
getCoreDescriptor() - Method in class org.apache.solr.core.SolrCore
 
getCoreDescriptor(String) - Method in class org.apache.solr.core.CoreContainer
 
getCoreDescriptor(String) - Method in class org.apache.solr.core.SolrCores
Return the CoreDescriptor corresponding to a given core name.
getCoreDescriptor(String) - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getCoreDescriptors() - Method in class org.apache.solr.core.CoreContainer
Get the CoreDescriptors for all cores managed by this container
getCoreDescriptors() - Method in class org.apache.solr.core.SolrCores
Get the CoreDescriptors for every SolrCore managed here (permanent and transient, loaded and unloaded).
getCoreDescriptors() - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getCoreFromAnyList(String, boolean) - Method in class org.apache.solr.core.SolrCores
 
getCoreFromAnyList(String, boolean, UUID) - Method in class org.apache.solr.core.SolrCores
 
getCoreInitFailures() - Method in class org.apache.solr.core.CoreContainer
Returns an immutable Map of Exceptions that occurred when initializing SolrCores (either at startup, or do to runtime requests to create cores) keyed off of the name (String) of the SolrCore that had the Exception during initialization.
getCoreLoadThreadCount(boolean) - Method in class org.apache.solr.core.NodeConfig
 
getCoreMetricManager() - Method in class org.apache.solr.core.SolrCore
Returns the SolrCoreMetricManager for this core.
getCoreName() - Method in interface org.apache.solr.cluster.Replica
The core name on disk
getCoreName() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
getCoreName() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
getCoreName() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
getCoreName(String, CoreContainer, SolrCore, String, String, SolrParams) - Static method in class org.apache.solr.search.join.ScoreJoinQParserPlugin
Returns a String with the name of a core.
getCoreNodeName() - Method in class org.apache.solr.cloud.CloudDescriptor
 
getCoreNodeName(CoreDescriptor) - Method in class org.apache.solr.cloud.ZkController
 
getCoreOrColName() - Method in class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
getCoreOrColName() - Method in class org.apache.solr.servlet.HttpSolrCall
 
getCoreProperty(String, String) - Method in class org.apache.solr.core.CoreDescriptor
Returns a specific property defined on this CoreDescriptor
getCoreRootDirectory() - Method in class org.apache.solr.core.CoreContainer
Where cores are created (absolute).
getCoreRootDirectory() - Method in class org.apache.solr.core.NodeConfig
Absolute.
getCores() - Method in class org.apache.solr.core.CoreContainer
Deprecated.
getCores() - Method in class org.apache.solr.core.SolrCores
Deprecated.
getCores() - Method in class org.apache.solr.servlet.SolrDispatchFilter
 
getCoresLocator() - Method in class org.apache.solr.core.CoreContainer
 
getCoresLocatorClass() - Method in class org.apache.solr.core.NodeConfig
 
getCoreSorter() - Method in class org.apache.solr.core.CoreContainer
 
getCoreSorterClass() - Method in class org.apache.solr.core.NodeConfig
 
getCoreStatus(CoreContainer, String, boolean) - Static method in enum org.apache.solr.handler.admin.CoreAdminOperation
Returns the core status for a particular core.
getCoreToClose() - Method in class org.apache.solr.core.SolrCores
 
getCoreZkRegisterExecutorService() - Method in class org.apache.solr.core.CoreContainer
 
getCoreZkRegisterExecutorService() - Method in class org.apache.solr.core.ZkContainer
 
getCorrection() - Method in class org.apache.solr.spelling.SpellCheckCorrection
 
getCost() - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
getCost() - Method in interface org.apache.solr.handler.component.MergeStrategy
Defines the order that the mergeStrategies are applied.
getCost() - Method in class org.apache.solr.search.AnalyticsQuery
 
getCost() - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
getCost() - Method in interface org.apache.solr.search.ExtendedQuery
Returns the cost of this query, used to order checking of filters that are not cached.
getCost() - Method in class org.apache.solr.search.ExtendedQueryBase
 
getCostAppliedQuery() - Method in interface org.apache.solr.search.ExtendedQuery
Returns this Query, applying QueryUtils.makeQueryable(Query) and maybe wrapping it to apply the ExtendedQuery.getCost() if it's above zero.
getCount() - Method in class org.apache.solr.handler.component.PivotFacetValue
The count corrisponding to the value modeled by this PivotFacetValue
getCount() - Method in class org.apache.solr.metrics.DelegateRegistryCounter
 
getCount() - Method in class org.apache.solr.metrics.DelegateRegistryHistogram
 
getCount() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
getCount() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getCount() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxCounterMBean
 
getCount() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
getCount() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxMeterMBean
 
getCount() - Method in class org.apache.solr.request.IntervalFacets.FacetInterval
 
getCount() - Method in class org.apache.solr.search.facet.FacetBucket
 
getCount() - Method in class org.apache.solr.search.SortSpec
Gets the number of documents to return after sorting.
getCount() - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
 
getCount(NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
 
getCounterNodePath(String) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
getCounterSupplier() - Method in class org.apache.solr.core.MetricsConfig
 
getCounterSupplier() - Method in class org.apache.solr.metrics.SolrMetricManager
 
getCountInternalLocks() - Method in class org.apache.solr.cloud.DistributedMultiLock
 
getCountReplicasToCreate(Replica.ReplicaType) - Method in class org.apache.solr.cluster.placement.impl.PlacementRequestImpl
 
getCountReplicasToCreate(Replica.ReplicaType) - Method in interface org.apache.solr.cluster.placement.PlacementRequest
Returns the number of replica to create for the given replica type.
getCounts(SolrIndexSearcher, StatsField, DocSet, String[]) - Static method in class org.apache.solr.request.DocValuesStats
 
getCounts(SolrIndexSearcher, DocSet, String, int, int, int, boolean, String, String, String, boolean, FacetDebugInfo) - Static method in class org.apache.solr.request.DocValuesFacets
 
getCounts(SolrIndexSearcher, DocSet, String, int, int, int, boolean, String, String, Predicate<BytesRef>, FacetDebugInfo) - Static method in class org.apache.solr.request.DocValuesFacets
 
getCountSorted() - Method in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
getCountSorted(HashMap<String, TermsResponse.Term>) - Method in class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
getCpuUsageThreshold() - Method in class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
 
getCreateCollectionWaitTimeTillActive() - Method in class org.apache.solr.core.CloudConfig
 
getCreationDate() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
getCredential(String) - Method in class org.apache.solr.util.configuration.providers.AbstractSSLCredentialProvider
 
getCredential(String) - Method in class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider
 
getCredential(String) - Method in class org.apache.solr.util.configuration.providers.SysPropSSLCredentialProvider
 
getCredential(SSLCredentialProvider.CredentialType) - Method in class org.apache.solr.util.configuration.providers.AbstractSSLCredentialProvider
 
getCredential(SSLCredentialProvider.CredentialType) - Method in interface org.apache.solr.util.configuration.SSLCredentialProvider
 
getCredentialKeyMap() - Method in class org.apache.solr.util.configuration.providers.AbstractSSLCredentialProvider
 
getCredentialKeyMap() - Method in class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider
 
getCredentialKeyMap() - Method in class org.apache.solr.util.configuration.providers.SysPropSSLCredentialProvider
 
getCumulativeEvictions() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCumulativeHits() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCumulativeIdleEvictions() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCumulativeLookups() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCumulativeMisses() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCumulativeNonLivePuts() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCumulativePuts() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCurrency(String) - Static method in class org.apache.solr.schema.CurrencyFieldType
A wrapper around Currency.getInstance that returns null instead of throwing IllegalArgumentException if the specified Currency does not exist in this JVM.
getCurrencyCode() - Method in class org.apache.solr.schema.CurrencyValue
The ISO currency code of the CurrencyValue.
getCurrentCapacity() - Method in class org.apache.solr.util.LongPriorityQueue
 
getCurrentLogSizeFromStream() - Method in class org.apache.solr.update.UpdateLog
 
getCurrentSchemaModificationVersion(String, SolrConfig, String) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
getCurrentSchemaModificationVersion(String, SolrConfig, String) - Method in class org.apache.solr.core.ConfigSetService
Returns a modification version for the schema file.
getCurrentSchemaModificationVersion(String, SolrConfig, String) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
getCurrentSize() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
getCurrentValue() - Method in class org.apache.solr.handler.export.IntValue
 
getCurrentValue() - Method in class org.apache.solr.handler.export.LongValue
 
getCursorMark() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getCursorMark() - Method in class org.apache.solr.search.QueryCommand
 
getCustom() - Method in class org.apache.solr.uninverting.FieldCache.CacheEntry
 
getCustomData() - Method in class org.apache.solr.packagemanager.SolrPackageInstance
 
getCustomParams(String, SolrParams) - Method in class org.apache.solr.handler.component.SpellCheckComponent
For every param that is of the form "spellcheck.[dictionary name].XXXX=YYYY, add XXXX=YYYY as a param to the custom param list
getCustomProperty(String) - Method in interface org.apache.solr.cluster.SolrCollection
Returns the value of a custom property name set on the SolrCollection or null when no such property was set.
getData() - Method in class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
 
getDataDir() - Method in class org.apache.solr.core.CoreDescriptor
 
getDataDir() - Method in class org.apache.solr.core.SolrConfig
 
getDataDir() - Method in class org.apache.solr.core.SolrCore
 
getDataHome(CoreDescriptor) - Method in class org.apache.solr.core.DirectoryFactory
Get the data home folder.
getDate() - Method in class org.apache.solr.security.AuditEvent
Date that the event happened
getDBQNewer(long) - Method in class org.apache.solr.update.UpdateLog
 
getDebugInfo() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getDebugInfo() - Method in class org.apache.solr.search.facet.FacetContext
 
getDebugInterests(String[], ResponseBuilder) - Static method in class org.apache.solr.util.SolrPluginUtils
 
getDefaultComponents() - Method in class org.apache.solr.handler.component.SearchHandler
 
getDefaultComponents() - Method in class org.apache.solr.handler.RealTimeGetHandler
 
getDefaultConfigDirPath() - Static method in class org.apache.solr.core.ConfigSetService
Gets the absolute filesystem path of the _default configset to bootstrap from.
getDefaultConnectionManager() - Method in class org.apache.solr.update.UpdateShardHandler
 
getDefaultCurrency() - Method in class org.apache.solr.schema.CurrencyFieldType
The identifier code for the default currency of this field type
getDefaultField() - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getDefaultHighlightFields() - Method in class org.apache.solr.search.DisMaxQParser
 
getDefaultHighlightFields() - Method in class org.apache.solr.search.ExtendedDismaxQParser
 
getDefaultHighlightFields() - Method in class org.apache.solr.search.LuceneQParser
 
getDefaultHighlightFields() - Method in class org.apache.solr.search.QParser
 
getDefaultHttpClient() - Method in class org.apache.solr.update.UpdateShardHandler
 
getDefaultLuceneMatchVersion() - Method in class org.apache.solr.schema.IndexSchema
The Default Lucene Match Version for this IndexSchema
getDefaultMultiValueSelectorForSort(SchemaField, boolean) - Method in class org.apache.solr.schema.FieldType
Method for indicating which FieldType.MultiValueSelector (if any) should be used when sorting on a multivalued field of this type for the specified direction (asc/desc).
getDefaultMultiValueSelectorForSort(SchemaField, boolean) - Method in class org.apache.solr.schema.PrimitiveFieldType
 
getDefaultMultiValueSelectorForSort(SchemaField, boolean) - Method in class org.apache.solr.schema.SortableTextField
 
getDefaultOperator() - Method in class org.apache.solr.parser.SolrQueryParserBase
Gets implicit operator setting, which will be either AND_OPERATOR or OR_OPERATOR.
getDefaultPackages() - Method in class org.apache.solr.util.plugin.AbstractPluginLoader
Where to look for classes
getDefaultPlacementPluginFactory() - Static method in class org.apache.solr.cluster.placement.impl.PlacementPluginFactoryLoader
Returns the default PlacementPluginFactory
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.ConcatFieldUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.FieldLengthUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
Defines the default selection behavior when the user has not configured any specific criteria for selecting fields.
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.FirstFieldValueUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.HTMLStripFieldUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.IgnoreFieldUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.LastFieldValueUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.MaxFieldValueUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.MinFieldValueUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.ParseBooleanFieldUpdateProcessorFactory
Returns true if the field doesn't match any schema field or dynamic field, or if the matched field's type is BoolField
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.ParseDateFieldUpdateProcessorFactory
Returns true if the field doesn't match any schema field or dynamic field, or if the matched field's type is BoolField
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.ParseNumericFieldUpdateProcessorFactory
Returns true if the field doesn't match any schema field or dynamic field, or if the matched field's type is compatible
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.RegexReplaceProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.TruncateFieldUpdateProcessorFactory
 
getDefaultSelector(SolrCore) - Method in class org.apache.solr.update.processor.UniqFieldsUpdateProcessorFactory
 
getDefaultSolrUrl() - Static method in class org.apache.solr.cli.SolrCLI
 
getDefaultValue() - Method in class org.apache.solr.schema.SchemaField
 
getDefaultWrappedMergePolicy() - Method in class org.apache.solr.index.WrapperMergePolicyFactory
Returns the default wrapped MergePolicy.
getDefaultWT() - Method in class org.apache.solr.handler.loader.ContentStreamLoader
 
getDefaultWT() - Method in class org.apache.solr.handler.loader.JsonLoader
 
getDefaultWT() - Method in class org.apache.solr.handler.loader.XMLLoader
 
getDefaultZkHost() - Method in class org.apache.solr.core.NodeConfig
This method returns the default "zkHost" value for this node -- either read from the system properties, or from the "extra" properties configured explicitly on the SolrDispatchFilter; or null if not specified.
getDelegate() - Method in class org.apache.solr.cluster.placement.impl.DelegatingPlacementPluginFactory
 
getDelegate() - Method in class org.apache.solr.jersey.MessageBodyReaders.CachingDelegatingMessageBodyReader
 
getDelegate() - Method in class org.apache.solr.jersey.MessageBodyReaders.CachingJsonMessageBodyReader
 
getDelegate() - Method in class org.apache.solr.search.DelegatingCollector
 
getDelegate() - Method in class org.apache.solr.search.FilteredDocIdSet
Return the wrapped DocIdSet.
getDelegate() - Method in class org.apache.solr.search.grouping.collector.FilterCollector
Returns the delegate collector
getDelegate() - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder.LazyUpdateRequestProcessorFactory
 
getDelegateCounter() - Method in class org.apache.solr.metrics.DelegateRegistryCounter
 
getDelegateHistogram() - Method in class org.apache.solr.metrics.DelegateRegistryHistogram
 
getDelegateMeter() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
getDelegateTimer() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getDeleteByQuery(long, LongSet) - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
Returns the list of deleteByQueries that happened after the given version
getDeletionPolicy() - Method in class org.apache.solr.core.SolrCore
 
getDelimiter() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getDeployedCollections(String) - Method in class org.apache.solr.packagemanager.PackageManager
Given a package, return a map of collections where this package is installed to the installed version (which can be SolrPackageLoader.LATEST)
getDescription() - Method in class org.apache.solr.core.SolrCore
 
getDescription() - Method in interface org.apache.solr.core.SolrInfoBean
Simple one or two line description
getDescription() - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.LoggingHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.LukeRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.MetricsCollectorHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.MetricsHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.PluginInfoHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.PropertiesRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.SecurityConfHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.SecurityConfHandlerLocal
 
getDescription() - Method in class org.apache.solr.handler.admin.SecurityConfHandlerZk
 
getDescription() - Method in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.SystemInfoHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.ThreadDumpHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.ZookeeperInfoHandler
 
getDescription() - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
 
getDescription() - Method in class org.apache.solr.handler.BlobHandler
 
getDescription() - Method in class org.apache.solr.handler.component.ActiveTasksListComponent
 
getDescription() - Method in class org.apache.solr.handler.component.ActiveTasksListHandler
 
getDescription() - Method in class org.apache.solr.handler.component.DebugComponent
 
getDescription() - Method in class org.apache.solr.handler.component.ExpandComponent
 
getDescription() - Method in class org.apache.solr.handler.component.FacetComponent
 
getDescription() - Method in class org.apache.solr.handler.component.HighlightComponent
 
getDescription() - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
getDescription() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
getDescription() - Method in class org.apache.solr.handler.component.QueryCancellationComponent
 
getDescription() - Method in class org.apache.solr.handler.component.QueryCancellationHandler
 
getDescription() - Method in class org.apache.solr.handler.component.QueryComponent
 
getDescription() - Method in class org.apache.solr.handler.component.QueryElevationComponent
 
getDescription() - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
getDescription() - Method in class org.apache.solr.handler.component.ResponseLogComponent
 
getDescription() - Method in class org.apache.solr.handler.component.SearchComponent
 
getDescription() - Method in class org.apache.solr.handler.component.SearchHandler
 
getDescription() - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
getDescription() - Method in class org.apache.solr.handler.component.StatsComponent
 
getDescription() - Method in class org.apache.solr.handler.component.SuggestComponent
 
getDescription() - Method in class org.apache.solr.handler.component.TermsComponent
 
getDescription() - Method in class org.apache.solr.handler.component.TermVectorComponent
 
getDescription() - Method in class org.apache.solr.handler.DocumentAnalysisRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.DumpRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.FieldAnalysisRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.GraphHandler
 
getDescription() - Method in class org.apache.solr.handler.MoreLikeThisHandler
 
getDescription() - Method in class org.apache.solr.handler.NotFoundRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.PingRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.RealTimeGetHandler
 
getDescription() - Method in class org.apache.solr.handler.ReplicationHandler
 
getDescription() - Method in class org.apache.solr.handler.RequestHandlerBase
 
getDescription() - Method in class org.apache.solr.handler.SchemaHandler
 
getDescription() - Method in class org.apache.solr.handler.SolrConfigHandler
 
getDescription() - Method in class org.apache.solr.handler.StandardRequestHandler
Deprecated.
 
getDescription() - Method in class org.apache.solr.handler.StreamHandler
 
getDescription() - Method in class org.apache.solr.handler.tagger.TaggerRequestHandler
 
getDescription() - Method in class org.apache.solr.handler.UpdateRequestHandler
 
getDescription() - Method in class org.apache.solr.highlight.BreakIteratorBoundaryScanner
 
getDescription() - Method in class org.apache.solr.highlight.DefaultEncoder
 
getDescription() - Method in class org.apache.solr.highlight.GapFragmenter
 
getDescription() - Method in class org.apache.solr.highlight.HighlightingPluginBase
 
getDescription() - Method in class org.apache.solr.highlight.HtmlEncoder
 
getDescription() - Method in class org.apache.solr.highlight.HtmlFormatter
 
getDescription() - Method in class org.apache.solr.highlight.RegexFragmenter
 
getDescription() - Method in class org.apache.solr.highlight.ScoreOrderFragmentsBuilder
 
getDescription() - Method in class org.apache.solr.highlight.SimpleBoundaryScanner
 
getDescription() - Method in class org.apache.solr.highlight.SimpleFragListBuilder
 
getDescription() - Method in class org.apache.solr.highlight.SimpleFragmentsBuilder
 
getDescription() - Method in class org.apache.solr.highlight.SingleFragListBuilder
 
getDescription() - Method in class org.apache.solr.highlight.WeightedFragListBuilder
 
getDescription() - Method in class org.apache.solr.search.CaffeineCache
 
getDescription() - Method in class org.apache.solr.search.facet.FacetModule
 
getDescription() - Method in class org.apache.solr.search.function.FileFloatSource.ReloadCacheRequestHandler
 
getDescription() - Method in class org.apache.solr.search.QParserPlugin
 
getDescription() - Method in class org.apache.solr.search.SolrFieldCacheBean
 
getDescription() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getDescription() - Method in class org.apache.solr.security.AuditLoggerPlugin
 
getDescription() - Method in class org.apache.solr.security.AuthenticationPlugin
 
getDescription() - Method in class org.apache.solr.security.PublicKeyHandler
 
getDescription() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
getDescription() - Method in class org.apache.solr.update.UpdateShardHandler
 
getDeserializer(HLLType, int, byte[]) - Method in interface org.apache.solr.util.hll.ISchemaVersion
Builds an HLL deserializer that matches this schema version.
getDestDynamicBase() - Method in class org.apache.solr.schema.IndexSchema.DynamicCopy
 
getDestFieldName() - Method in class org.apache.solr.schema.IndexSchema.DynamicCopy
 
getDestination() - Method in class org.apache.solr.schema.CopyField
 
getDestination() - Method in class org.apache.solr.schema.IndexSchema.DynamicCopy
 
getDetails() - Method in class org.apache.solr.core.backup.BackupProperties
 
getDetails() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
getDetails() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
 
getDictionaryName() - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
getDictionaryName() - Method in class org.apache.solr.spelling.SolrSpellChecker
 
getDiff(NamedList<NamedList<NamedList<Object>>>, NamedList<NamedList<NamedList<Object>>>, boolean) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
getDimension() - Method in class org.apache.solr.schema.CoordinateFieldType
 
getDimension() - Method in class org.apache.solr.schema.DenseVectorField
 
getDirectoryFactory() - Method in class org.apache.solr.core.SolrCore
 
getDirectoryFactory() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getDirectoryFactory() - Method in class org.apache.solr.update.SolrCoreState
 
getDistanceUnits() - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getDistribDeps() - Method in enum org.apache.solr.handler.component.StatsField.Stat
The stats that must be computed and returned by each shard involved in a distributed request in order to compute the overall value for this stat across the entire distributed result set.
getDistributedClusterStateUpdater() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
getDistributedClusterStateUpdater() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
getDistributedClusterStateUpdater() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getDistributedClusterStateUpdater() - Method in class org.apache.solr.cloud.Overseer
 
getDistributedClusterStateUpdater() - Method in class org.apache.solr.cloud.ZkController
 
getDistributedClusterStateUpdates() - Method in class org.apache.solr.core.CloudConfig
 
getDistributedCollectionCommandRunner() - Method in class org.apache.solr.core.CoreContainer
 
getDistributedCollectionConfigSetExecution() - Method in class org.apache.solr.core.CloudConfig
 
getDistributedConnectionTimeout() - Method in class org.apache.solr.update.UpdateShardHandlerConfig
 
getDistributedSocketTimeout() - Method in class org.apache.solr.update.UpdateShardHandlerConfig
 
getDocFetcher() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getDocFreq(String) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns the number of documents that contain this (indexed) Phrase as term in the specified field.
getDocList() - Method in class org.apache.solr.response.BasicResultContext
 
getDocList() - Method in class org.apache.solr.response.ResultContext
 
getDocList() - Method in class org.apache.solr.search.QueryResult
 
getDocList(GroupDocs<?>) - Method in class org.apache.solr.search.Grouping.Command
 
getDocList(Query, List<Query>, Sort, int, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and the intersection of the filterList , sorted by sort.
getDocList(Query, Query, Sort, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and filter and sorted by sort.
getDocList(Query, DocSet, Sort, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and filter and sorted by sort.
getDocListAndSet() - Method in class org.apache.solr.search.QueryResult
 
getDocListAndSet(Query, List<Query>, Sort, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and the intersection of filterList , sorted by sort.
getDocListAndSet(Query, List<Query>, Sort, int, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and the intersection of filterList , sorted by sort.
getDocListAndSet(Query, Query, Sort, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and filter and sorted by sort.
getDocListAndSet(Query, Query, Sort, int, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and filter and sorted by sort.
getDocListAndSet(Query, DocSet, Sort, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and filter and sorted by sort.
getDocListAndSet(Query, DocSet, Sort, int, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns documents matching both query and filter and sorted by sort.
getDocPrefetchFieldNames(String[], SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Returns the field names to be passed to SolrDocumentFetcher.solrDoc(int, SolrReturnFields).
getDocs() - Method in class org.apache.solr.search.SortedIntDocSet
 
getDocSet() - Method in class org.apache.solr.search.DocSetCollector
 
getDocSet() - Method in class org.apache.solr.search.QueryResult
 
getDocSet(List<Query>) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns the set of document ids matching all queries.
getDocSet(Query) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns the set of document ids matching both the query.
getDocSet(Query, DocSet) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns the set of document ids matching both the query and the filter.
getDocSet(DocSetCollector, SolrIndexSearcher) - Static method in class org.apache.solr.search.DocSetUtil
This variant of getDocSet will attempt to do some deduplication on certain DocSets such as DocSets that match numDocs.
getDocSet(DocSet, SolrIndexSearcher) - Static method in class org.apache.solr.search.DocSetUtil
This variant of getDocSet maps all sets with size numDocs to searcher.getLiveDocs.
getDocSet(SolrIndexSearcher.DocsEnumState) - Method in class org.apache.solr.search.SolrIndexSearcher
 
getDocSetBits(Query) - Method in class org.apache.solr.search.SolrIndexSearcher
 
getDocSetNC(Query, DocSet) - Method in class org.apache.solr.search.SolrIndexSearcher
 
getDocsOrig() - Method in class org.apache.solr.request.SimpleFacets
 
getDocsWithField(LeafReader, String, FieldCache.Parser) - Method in interface org.apache.solr.uninverting.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms/points in field and returns a bit set at the size of reader.maxDoc() , with turned on bits for each docid that does have a value for this field.
getDocsWithField(LeafReader, String, FieldCache.Parser) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getDocTermOrds(LeafReader, String, BytesRef) - Method in interface org.apache.solr.uninverting.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the term values in field and returns a DocTermOrds instance, providing a method to retrieve the terms (as ords) per document.
getDocTermOrds(LeafReader, String, BytesRef) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getDocument() - Method in class org.apache.solr.core.XmlConfigFile
 
getDocumentCache() - Method in class org.apache.solr.search.SolrDocumentFetcher
 
getDocuments(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.MoreLikeThisAPI
 
getDocuments(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.RealTimeGetAPI
 
getDocValuesFormat() - Method in class org.apache.solr.schema.FieldType
 
getDocValuesFormat() - Method in class org.apache.solr.schema.SchemaField
Expert/advanced method to get the field DocValuesFormat.
getDocValuesRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.NumericFieldType
 
getDomain() - Method in class org.apache.solr.metrics.reporters.jmx.JmxObjectNameFactory
Return current domain.
getDomain() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Return configured domain or null.
getDouble() - Method in class org.apache.solr.search.facet.SumAgg.Merger
 
getDouble() - Method in class org.apache.solr.search.StrParser
 
getDouble(String) - Method in class org.apache.solr.core.XmlConfigFile
 
getDouble(String, double) - Method in class org.apache.solr.core.XmlConfigFile
 
getDurationUnit() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
getDvsCanSubstituteStored() - Method in class org.apache.solr.search.SolrDocumentFetcher
 
getDynamicCopyFields() - Method in class org.apache.solr.schema.IndexSchema
 
getDynamicFieldInfo(String) - Method in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
getDynamicFieldPrototypes() - Method in class org.apache.solr.schema.IndexSchema
 
getDynamicFields() - Method in class org.apache.solr.schema.IndexSchema
 
getDynamicFieldType(String) - Method in class org.apache.solr.schema.IndexSchema
Returns the FieldType of the best matching dynamic field for the specified field name
getDynamicPattern(String) - Method in class org.apache.solr.schema.IndexSchema
 
getEarthRadius() - Method in class org.apache.solr.util.DistanceUnits
 
getEditableSubProperties(String) - Method in class org.apache.solr.core.ConfigOverlay
 
getEditApi() - Method in interface org.apache.solr.api.ClusterPluginsSource
Get the Edit Api for this plugin source, if it supports edit operations
getEditApi() - Method in class org.apache.solr.api.NodeConfigClusterPluginsSource
 
getEditApi() - Method in class org.apache.solr.api.ZkClusterPluginsSource
 
getElapsedTime() - Method in class org.apache.solr.cloud.OverseerSolrResponse
 
getElevation(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryElevationComponent
 
getElevationForQuery(String) - Method in class org.apache.solr.handler.component.QueryElevationComponent.DefaultElevationProvider
 
getElevationForQuery(String) - Method in interface org.apache.solr.handler.component.QueryElevationComponent.ElevationProvider
Gets the elevation associated to the provided query.
getElevationProvider(IndexReader, SolrCore) - Method in class org.apache.solr.handler.component.QueryElevationComponent
Gets the QueryElevationComponent.ElevationProvider; typically cached.
getEnableGraphQueries() - Method in class org.apache.solr.schema.TextField
 
getEncapsulator() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getEncoder(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultEncoder
 
getEncoder(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return an Encoder appropriate for this field.
getEncoder(String, SolrParams) - Method in class org.apache.solr.highlight.HtmlEncoder
 
getEncoder(String, SolrParams) - Method in interface org.apache.solr.highlight.SolrEncoder
Return an Encoder appropriate for this field.
getEnd() - Method in class org.apache.solr.handler.component.RangeFacetRequest
The end of this facet.range as specified by FacetParams.FACET_RANGE_END parameter
getEndObj() - Method in class org.apache.solr.handler.component.RangeFacetRequest
The end of this facet.range as calculated using the value of facet.range.end parameter and facet.range.hardend.
getEndOffset() - Method in class org.apache.solr.handler.tagger.TagLL
 
getEndPoint() - Method in class org.apache.solr.api.AnnotatedApi
 
getEndPoints() - Method in class org.apache.solr.handler.admin.BaseHandlerApiSupport
 
getEndTime() - Method in class org.apache.solr.core.backup.BackupProperties
 
getEnumMapping() - Method in class org.apache.solr.schema.AbstractEnumField
 
getErrorCode(List<CircuitBreaker>) - Static method in class org.apache.solr.util.circuitbreaker.CircuitBreaker
Deprecated.
Remove in 10.0
getErrorCount(String) - Method in class org.apache.solr.cloud.Stats
 
getErrorHandler() - Method in class org.apache.solr.search.SolrCoreParser
 
getErrorInfo(Throwable, NamedList<Object>, Logger) - Static method in class org.apache.solr.servlet.ResponseUtils
Adds the given Throwable's message to the given NamedList.
getErrorInfo(Throwable, NamedList<Object>, Logger, boolean) - Static method in class org.apache.solr.servlet.ResponseUtils
Adds the given Throwable's message to the given NamedList.
getErrorMessage() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreaker
Get error message when the circuit breaker triggers
getErrorMessage() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
getErrorMessage() - Method in class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
 
getErrorMessage() - Method in class org.apache.solr.util.circuitbreaker.LoadAverageCircuitBreaker
 
getErrorMessage() - Method in class org.apache.solr.util.circuitbreaker.MemoryCircuitBreaker
 
getErrors() - Method in class org.apache.solr.update.SolrCmdDistributor
 
getErrors() - Method in class org.apache.solr.update.StreamingSolrClients
 
getErrorStr(Exception) - Static method in class org.apache.solr.schema.SchemaManager
 
getErrs() - Method in exception org.apache.solr.api.ApiBag.ExceptionWithErrObject
 
getErrStream() - Static method in interface org.apache.solr.cli.CLIO
 
getEscape() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getEstimatedSize() - Method in class org.apache.solr.uninverting.FieldCache.CacheEntry
The most recently estimated size of the value, null unless estimateSize has been called.
getEtagSeed() - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
 
getEventType() - Method in class org.apache.solr.security.AuditEvent
EventType tells the outcome of the event such as REJECTED, UNAUTHORIZED or ERROR
getExactQuery(SchemaField, String) - Method in class org.apache.solr.schema.DatePointField
 
getExactQuery(SchemaField, String) - Method in class org.apache.solr.schema.DoublePointField
 
getExactQuery(SchemaField, String) - Method in class org.apache.solr.schema.FloatPointField
 
getExactQuery(SchemaField, String) - Method in class org.apache.solr.schema.IntPointField
 
getExactQuery(SchemaField, String) - Method in class org.apache.solr.schema.LongPointField
 
getExactQuery(SchemaField, String) - Method in class org.apache.solr.schema.PointField
 
getException() - Method in class org.apache.solr.handler.component.ShardResponse
 
getException() - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
getException() - Method in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
getException() - Method in class org.apache.solr.response.SolrQueryResponse
Returns an Exception if there was a fatal error in processing the request.
getException() - Method in class org.apache.solr.security.AuditEvent
In case of ERROR event, find the exception causing the error
getExchangeRate(String, String) - Method in interface org.apache.solr.schema.ExchangeRateProvider
Get the exchange rate between the two given currencies
getExchangeRate(String, String) - Method in class org.apache.solr.schema.FileExchangeRateProvider
Returns the currently known exchange rate between two currencies.
getExchangeRate(String, String) - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
Returns the currently known exchange rate between two currencies.
getExcludeTags() - Method in class org.apache.solr.handler.component.FacetComponent.FacetBase
 
getExecutorService() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
getExecutorService() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
getExecutorService() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getExistenceQuery(String) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getExistenceQuery(QParser, SchemaField) - Method in class org.apache.solr.schema.CurrencyFieldType
Override the default existenceQuery implementation to run an existence query on the underlying amountField instead.
getExistenceQuery(QParser, SchemaField) - Method in class org.apache.solr.schema.FieldType
Returns a Query instance for doing existence searches for a field.
getExistenceQuery(QParser, SchemaField) - Method in class org.apache.solr.schema.RankField
 
getExplanations(Query, DocList, SolrIndexSearcher, IndexSchema) - Static method in class org.apache.solr.util.SolrPluginUtils
Generates an NamedList of Explanations for each item in a list of docs.
getExplicitField() - Method in class org.apache.solr.parser.SolrQueryParserBase
For a fielded query, returns the actual field specified (i.e.
getExplicitlyRequestedFieldNames() - Method in class org.apache.solr.search.ReturnFields
The explicitly requested field names (includes pseudo fields)
getExplicitlyRequestedFieldNames() - Method in class org.apache.solr.search.SolrReturnFields
 
getExplicitValuesList() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Read-Only access to the Collection of PivotFacetValues corrisponding to non-missing values.
getExplicitValuesListSize() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
getExternalSubset(String, String) - Method in class org.apache.solr.util.SystemIdResolver
 
getExternalVals() - Method in class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
getExtraProperties() - Method in class org.apache.solr.core.backup.BackupProperties
 
getExtraRequestFields() - Method in class org.apache.solr.response.transform.DocTransformer
When a transformer needs access to fields that are not automatically derived from the input fields names, this option lets us explicitly say the field names that we hope will be in the SolrDocument.
getExtraRequestFields() - Method in class org.apache.solr.response.transform.DocTransformer.NoopFieldTransformer
 
getExtraRequestFields() - Method in class org.apache.solr.response.transform.RenameFieldTransformer
 
getFacetComponentState(ResponseBuilder) - Method in class org.apache.solr.search.facet.FacetModule
 
getFacetContext(SolrQueryRequest) - Static method in class org.apache.solr.handler.component.FacetComponent.FacetContext
Return the FacetComponent.FacetContext instance cached in the request context.
getFacetCounts(SimpleFacets) - Static method in class org.apache.solr.handler.component.FacetComponent
 
getFacetCounts(SimpleFacets, FacetDebugInfo) - Static method in class org.apache.solr.handler.component.FacetComponent
Looks at various Params to determining if any simple Facet Constraint count computations are desired.
getFacetDebugInfo() - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
getFacetDescription() - Method in class org.apache.solr.search.facet.FacetField
 
getFacetDescription() - Method in class org.apache.solr.search.facet.FacetHeatmap
 
getFacetDescription() - Method in class org.apache.solr.search.facet.FacetQuery
 
getFacetDescription() - Method in class org.apache.solr.search.facet.FacetRange
 
getFacetDescription() - Method in class org.apache.solr.search.facet.FacetRequest
 
getFacetFieldCounts() - Method in class org.apache.solr.request.SimpleFacets
Returns a list of value constraints and the associated facet counts for each facet field specified in the params.
getFacetInfo() - Method in class org.apache.solr.search.facet.FacetContext
 
getFacetIntervalCounts() - Method in class org.apache.solr.request.SimpleFacets
Returns a NamedList with each entry having the "key" of the interval as name and the count of docs in that interval as value.
getFacetProcessor() - Method in class org.apache.solr.search.facet.FacetContext
 
getFacetQueryCount(SimpleFacets.ParsedParams, NamedList<Integer>) - Method in class org.apache.solr.request.SimpleFacets
 
getFacetQueryCounts() - Method in class org.apache.solr.request.SimpleFacets
Returns a list of facet counts for each of the facet queries specified in the params
getFacetRangeCounts() - Method in class org.apache.solr.handler.component.RangeFacetProcessor
Returns a list of value constraints and the associated facet counts for each facet numerical field, range, and interval specified in the SolrParams
getFacetRangeCounts(RangeFacetRequest, NamedList<Object>) - Method in class org.apache.solr.handler.component.RangeFacetProcessor
Returns a list of value constraints and the associated facet counts for each facet range specified by the given RangeFacetRequest
getFacetRanges() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getFacetStats() - Method in class org.apache.solr.search.facet.FacetRequest
 
getFacetTermEnumCounts(SolrIndexSearcher, DocSet, String, int, int, int, boolean, String, String, String, boolean, boolean) - Method in class org.apache.solr.request.SimpleFacets
getFacetTermEnumCounts(SolrIndexSearcher, DocSet, String, int, int, int, boolean, String, String, Predicate<BytesRef>, boolean) - Method in class org.apache.solr.request.SimpleFacets
Returns a list of terms in the specified field along with the corresponding count of documents in the set that match that constraint.
getFailureDetails(String) - Method in class org.apache.solr.cloud.Stats
 
getFetchOptimizer(Supplier<SolrDocumentFetcher.RetrieveFieldsOptimizer>) - Method in class org.apache.solr.search.SolrReturnFields
 
getField() - Method in class org.apache.solr.handler.export.IntValue
 
getField() - Method in class org.apache.solr.handler.export.LongValue
 
getField() - Method in class org.apache.solr.query.SolrRangeQuery
 
getField() - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
getField() - Method in class org.apache.solr.search.FieldParams
 
getField() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getField(String) - Method in class org.apache.solr.parser.SolrQueryParserBase
Handles the default field if null is passed
getField(String) - Method in class org.apache.solr.schema.IndexSchema
Returns the SchemaField that should be used for the specified field name
getField(NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
 
getFieldFlags() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getFieldFlagsKey() - Static method in class org.apache.solr.handler.admin.LukeRequestHandler
 
getFieldInfo(String) - Method in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
getFieldInfo(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getFieldInfos() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getFieldInfos() - Method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
 
getFieldInfos() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getFieldInfos() - Method in class org.apache.solr.uninverting.UninvertingReader
 
getFieldMatcher(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getFieldMissingCount(SolrIndexSearcher, DocSet, String) - Static method in class org.apache.solr.request.SimpleFacets
Returns a count of the documents in the set which do not have any terms for for the specified field.
getFieldName() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
 
getFieldName() - Method in class org.apache.solr.search.function.FieldNameValueSource
 
getFieldName() - Method in class org.apache.solr.uninverting.FieldCache.CacheEntry
 
getFieldName(String, int, int) - Method in class org.apache.solr.search.ExtendedDismaxQParser
returns a field name or legal field alias from the current position of the string
getFieldName(StrParser) - Static method in class org.apache.solr.search.SolrReturnFields
 
getFieldNames() - Method in class org.apache.solr.search.SolrIndexSearcher
Returns a collection of all field names the index reader knows about.
getFieldOrNull(String) - Method in class org.apache.solr.schema.IndexSchema
Returns the SchemaField that should be used for the specified field name, or null if none exists.
getFieldQuery(String, String, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getFieldQuery(String, String, boolean, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getFieldQuery(String, String, boolean, boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getFieldQuery(String, String, boolean, boolean) - Method in class org.apache.solr.util.SolrPluginUtils.DisjunctionMaxQueryParser
Delegates to the super class unless the field has been specified as an alias -- in which case we recurse on each of the aliased fields, and the results are composed into a DisjunctionMaxQuery.
getFieldQuery(String, String, int) - Method in class org.apache.solr.parser.SolrQueryParserBase
getFieldQuery(String, String, int) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getFieldQuery(String, List<String>, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getFieldQuery(String, List<String>, boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.AbstractSubTypeFieldType
Throws UnsupportedOperationException()
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.CurrencyFieldType
 
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.DenseVectorField
Not Supported.
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.FieldType
Returns a Query instance for doing searches against a field.
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.PointField
 
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.PointType
 
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.RankField
 
getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.TextField
 
getFieldRenames() - Method in class org.apache.solr.search.ReturnFields
Get the fields which have been renamed
getFieldRenames() - Method in class org.apache.solr.search.SolrReturnFields
 
getFields() - Method in class org.apache.solr.response.TabularResponseWriter
Returns fields to be returned in the response
getFields() - Method in class org.apache.solr.schema.IndexSchema
Provides direct access to the Map containing all explicit (ie: non-dynamic) fields in the index, keyed on field name.
getFields() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
getFieldsBySize() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
getFieldScore(String) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns the score for this Phrase in this given field.
getFieldsFromDoc(SolrDocument) - Method in class org.apache.solr.search.mlt.CloudMLTQParser
 
getFieldSources() - Method in class org.apache.solr.search.SolrReturnFields
 
getFieldsWithDefaultValue() - Method in class org.apache.solr.schema.IndexSchema
Provides direct access to the List containing all fields with a default value
getFieldTermQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.FieldType
Returns a Query instance for doing a single term search against a field.
getFieldTermQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.TextField
 
getFieldType() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
 
getFieldType() - Method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
Returns a field type representing the set of field options.
getFieldType(String) - Method in class org.apache.solr.schema.IndexSchema
Returns the FieldType for the specified field name.
getFieldTypeByName(String) - Method in class org.apache.solr.schema.IndexSchema
Given the name of a FieldType (not to be confused with IndexSchema.getFieldType(String) which takes in the name of a field), return the FieldType.
getFieldTypeInfo(String) - Method in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
getFieldTypeName() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getFieldTypeNoEx(String) - Method in class org.apache.solr.schema.IndexSchema
Returns the FieldType for the specified field name.
getFieldTypes() - Method in class org.apache.solr.schema.IndexSchema
Provides direct access to the Map containing all Field Types in the index, keyed on field type name.
getFieldValueCache() - Method in class org.apache.solr.search.SolrIndexSearcher
expert: internal API, subject to change
getFieldValues(SolrDocument, String, int, int, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Fetches field values to highlight.
getFieldWriters(String[], SolrQueryRequest) - Method in class org.apache.solr.handler.export.ExportWriter
 
getFifteenMinuteRate() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
getFifteenMinuteRate() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getFifteenMinuteRate() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxMeterMBean
 
getFile(String) - Method in class org.apache.solr.core.backup.ShardBackupMetadata
 
getFileContents(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
getFileFilterFromFileTypes(String) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
 
getFileFloatSource(SchemaField) - Method in class org.apache.solr.schema.ExternalFileField
Get a FileFloatSource for the given field, using the datadir from the IndexSchema
getFileFloatSource(SchemaField, String) - Method in class org.apache.solr.schema.ExternalFileField
Get a FileFloatSource for the given field.
getFileFromJarsAsString(List<Path>, String) - Static method in class org.apache.solr.packagemanager.PackageUtils
Search through the list of jar files for a given file.
getFileList(long, ReplicationHandler) - Method in class org.apache.solr.handler.admin.api.ReplicationAPIBase
 
getFiles() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
getFiles() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage.Version
 
getFileStore() - Method in class org.apache.solr.filestore.FileStoreAPI
 
getFileStoreAPI() - Method in class org.apache.solr.core.CoreContainer
 
getFileStoreDirPath(Path) - Static method in class org.apache.solr.filestore.DistribFileStore
 
getFilter() - Method in class org.apache.solr.search.facet.FacetContext
 
getFilter() - Method in class org.apache.solr.search.QueryCommand
 
getFilterCache() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getFilterCollector(IndexSearcher) - Method in class org.apache.solr.search.AnalyticsQuery
 
getFilterCollector(IndexSearcher) - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
getFilterCollector(IndexSearcher) - Method in class org.apache.solr.search.FunctionRangeQuery
 
getFilterCollector(IndexSearcher) - Method in interface org.apache.solr.search.PostFilter
Returns a DelegatingCollector to be run after the main query and all of its filters, but before any sorting or grouping collectors
getFilteredURLs(Path, String) - Static method in class org.apache.solr.core.SolrResourceLoader
Utility method to get the URLs of all paths under a given directory that match a regex
getFilterList() - Method in class org.apache.solr.search.QueryCommand
 
getFilters() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getFiltersParamName() - Method in class org.apache.solr.search.join.BlockJoinParentQParser
 
getFiltersParamName() - Method in class org.apache.solr.search.join.FiltersQParser
 
getFingerprint(SolrCore, long) - Static method in class org.apache.solr.update.IndexFingerprint
Opens a new realtime searcher and returns it's (possibly cached) fingerprint
getFingerprint(SolrIndexSearcher, LeafReaderContext, Long) - Static method in class org.apache.solr.update.IndexFingerprint
 
getFirstMatch(Term) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns the first document number containing the term t Returns -1 if no document was found.
getFiveMinuteRate() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
getFiveMinuteRate() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getFiveMinuteRate() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxMeterMBean
 
getFixedBitSet() - Method in class org.apache.solr.search.BitDocSet
 
getFixedBitSet() - Method in class org.apache.solr.search.DocSet
 
getFixedBitSet() - Method in class org.apache.solr.search.SortedIntDocSet
 
getFixedBitSetClone() - Method in class org.apache.solr.search.BitDocSet
 
getFixedBitSetClone() - Method in class org.apache.solr.search.DocSet
 
getFixedBitSetClone() - Method in class org.apache.solr.search.SortedIntDocSet
 
getFlags() - Method in class org.apache.solr.search.facet.FacetContext
 
getFlags() - Method in class org.apache.solr.search.QParser
 
getFlags() - Method in class org.apache.solr.search.QueryCommand
 
getFlags() - Method in class org.apache.solr.spelling.Token
Deprecated.
getFlags() - Method in class org.apache.solr.update.UpdateCommand
 
getFlags(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getFloat() - Method in class org.apache.solr.search.StrParser
 
getFloat(String) - Method in class org.apache.solr.core.XmlConfigFile
 
getFloat(String, float) - Method in class org.apache.solr.core.XmlConfigFile
 
getFloatVector() - Method in class org.apache.solr.util.vector.DenseVectorParser
 
getFloatVector() - Method in class org.apache.solr.util.vector.FloatDenseVectorParser
 
getFloatVectorValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getFormatter(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getFormatter(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return a Formatter appropriate for this field.
getFormatter(String, SolrParams) - Method in class org.apache.solr.highlight.HtmlFormatter
 
getFormatter(String, SolrParams) - Method in interface org.apache.solr.highlight.SolrFormatter
Return a Formatter appropriate for this field.
getFormUploadLimitKB() - Method in class org.apache.solr.core.SolrConfig
 
getFragListBuilder(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
 
getFragListBuilder(SolrParams) - Method in class org.apache.solr.highlight.SimpleFragListBuilder
 
getFragListBuilder(SolrParams) - Method in class org.apache.solr.highlight.SingleFragListBuilder
 
getFragListBuilder(SolrParams) - Method in interface org.apache.solr.highlight.SolrFragListBuilder
Return a FragListBuilder.
getFragListBuilder(SolrParams) - Method in class org.apache.solr.highlight.WeightedFragListBuilder
 
getFragmenter(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return a Fragmenter appropriate for this field.
getFragmenter(String, SolrParams) - Method in class org.apache.solr.highlight.GapFragmenter
 
getFragmenter(String, SolrParams) - Method in class org.apache.solr.highlight.RegexFragmenter
 
getFragmenter(String, SolrParams) - Method in interface org.apache.solr.highlight.SolrFragmenter
Return a Fragmenter appropriate for this field.
getFragmentsBuilder(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
 
getFragmentsBuilder(SolrParams, String[], String[], BoundaryScanner) - Method in class org.apache.solr.highlight.ScoreOrderFragmentsBuilder
 
getFragmentsBuilder(SolrParams, String[], String[], BoundaryScanner) - Method in class org.apache.solr.highlight.SimpleFragmentsBuilder
 
getFragmentsBuilder(SolrParams, String[], String[], BoundaryScanner) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
 
getFragmentsBuilder(SolrParams, BoundaryScanner) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
Return a FragmentsBuilder appropriate for this field.
getFreshRequestParams(SolrResourceLoader, RequestParams) - Static method in class org.apache.solr.core.RequestParams
 
getFromCache(String, SolrResourceLoader, Supplier<ObjectCache>, Supplier<IndexSchemaFactory.VersionedConfig>) - Static method in class org.apache.solr.schema.IndexSchemaFactory
 
getFromField() - Method in class org.apache.solr.search.join.GraphQuery
 
getFromSyspropOrClusterprop(ZkStateReader) - Static method in class org.apache.solr.handler.admin.SolrEnvironment
Gets and parses the solr environment configuration string from either System properties "solr.environment" or from Clusterprop "environment"
getFunctions() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
getFuzzyMinSim() - Method in class org.apache.solr.parser.SolrQueryParserBase
Get the minimal similarity for fuzzy queries.
getFuzzyPrefixLength() - Method in class org.apache.solr.parser.SolrQueryParserBase
Get the prefix length for fuzzy queries.
getFuzzyQuery(String, String, float) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getFuzzyQuery(String, String, float) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getGap() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getGapObj() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getGauge() - Method in class org.apache.solr.metrics.SolrMetricManager.GaugeWrapper
 
getGenerationNumber() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
getGenerationNumber() - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager.SnapshotMetaData
 
getGenericCoreNodeNames() - Method in class org.apache.solr.core.CloudConfig
 
getGlobalParams() - Method in class org.apache.solr.request.SimpleFacets
 
getGlobbedId(String) - Method in class org.apache.solr.search.StrParser
 
getGroupCount() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommandResult
 
getGroupedCounts(SolrIndexSearcher, DocSet, String, boolean, int, int, int, boolean, String, String, Predicate<BytesRef>) - Method in class org.apache.solr.request.SimpleFacets
 
getGroupedFacetQueryCount(Query, DocSet) - Method in class org.apache.solr.request.SimpleFacets
Returns a grouped facet count for the facet query
getGroupingSpec() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getGroupSort() - Method in interface org.apache.solr.search.grouping.Command
 
getGroupSort() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand
 
getGroupSort() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand
 
getGroupSort() - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand
 
getGroupSortSpec() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
getHandler() - Method in class org.apache.solr.security.AuthorizationContext
 
getHandler() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getHasher() - Method in class org.apache.solr.handler.component.StatsField.HllOptions
May be null if user has indicated that field values are pre-hashed
getHeadCollectionIfOrdered(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
getHeadCollectionIfOrdered(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
getHeadCollectionIfOrdered(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
Calculate the head collection (i.e.
getHeadCollectionIfOrdered(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getHeaderNames() - Method in class org.apache.solr.security.AuthorizationContext
 
getHeaderNames() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getHeaders() - Method in class org.apache.solr.security.AuditEvent
Map of all HTTP request headers belonging to the request
getHealthCheckHandler() - Method in class org.apache.solr.core.CoreContainer
 
getHealthCheckHandler() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getHealthCheckHandlerClass() - Method in class org.apache.solr.core.NodeConfig
 
getHeatmapCounts() - Method in class org.apache.solr.request.SimpleFacets
 
getHeatmapForField(String, String, ResponseBuilder, SolrParams, DocSet) - Static method in class org.apache.solr.handler.component.SpatialHeatmapFacets
Called by SimpleFacets to compute heatmap facets.
getHiddenFiles() - Method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
getHiddenSysProps() - Method in class org.apache.solr.core.NodeConfig
Returns the list of hidden system properties.
getHierarchicalParametersByPrefix(SolrParams, String) - Static method in class org.apache.solr.handler.admin.api.CreateAliasAPI
Returns a SolrParams object containing only those values whose keys match a specified prefix (with that prefix removed)
getHighestTerm() - Method in class org.apache.solr.cloud.ZkShardTerms
 
getHighlighter(Query, String, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return a Highlighter appropriate for this field.
getHighlighter(SolrParams) - Method in class org.apache.solr.handler.component.HighlightComponent
The highlighter given the param HighlightParams.METHOD.
getHighlighter(SolrQueryRequest) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter
Creates an instance of the Lucene UnifiedHighlighter.
getHighlightFields(Query, SolrQueryRequest, String[]) - Method in class org.apache.solr.highlight.SolrHighlighter
Return a String array of the fields to be highlighted.
getHighlightQuery() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getHighlightQuery() - Method in class org.apache.solr.search.DisMaxQParser
 
getHighlightQuery() - Method in class org.apache.solr.search.ExtendedDismaxQParser
 
getHighlightQuery() - Method in class org.apache.solr.search.QParser
 
getHistogramSupplier() - Method in class org.apache.solr.core.MetricsConfig
 
getHistogramSupplier() - Method in class org.apache.solr.metrics.SolrMetricManager
 
getHistory(long, AtomicBoolean) - Method in class org.apache.solr.logging.LogWatcher
 
getHistorySize() - Method in class org.apache.solr.logging.LogWatcher
 
getHits() - Method in class org.apache.solr.spelling.SpellCheckCollation
 
getHLL() - Method in class org.apache.solr.search.facet.HLLAgg.HLLFactory
 
getHllOptions() - Method in class org.apache.solr.handler.component.StatsField
 
getHnswBeamWidth() - Method in class org.apache.solr.schema.DenseVectorField
 
getHnswMaxConn() - Method in class org.apache.solr.schema.DenseVectorField
 
getHost() - Method in class org.apache.solr.core.CloudConfig
 
getHostAllowList() - Method in class org.apache.solr.security.AllowListUrlChecker
Only for testing.
getHostName() - Method in class org.apache.solr.cloud.ZkController
 
getHostName() - Method in class org.apache.solr.core.CoreContainer
 
getHostPort() - Method in class org.apache.solr.cloud.ZkController
 
getHostToAdvertise() - Static method in class org.apache.solr.util.AddressUtils
 
getHttpCachingConfig() - Method in class org.apache.solr.core.SolrConfig
 
getHttpClient() - Method in class org.apache.solr.servlet.SolrDispatchFilter
 
getHttpClient() - Method in class org.apache.solr.update.StreamingSolrClients
 
getHttpClientBuilder(SolrHttpClientBuilder) - Method in interface org.apache.solr.security.HttpClientBuilderPlugin
 
getHttpClientBuilder(SolrHttpClientBuilder) - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
getHttpHeader(String) - Method in class org.apache.solr.response.SolrQueryResponse
Gets the value of the response header with the given name.
getHttpHeader(String) - Method in class org.apache.solr.security.AuthorizationContext
 
getHttpHeader(String) - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getHttpHeaders(String) - Method in class org.apache.solr.response.SolrQueryResponse
Gets the values of the response header with the given name.
getHttpMethod() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getHttpMethod() - Method in interface org.apache.solr.request.SolrQueryRequest
 
getHttpMethod() - Method in class org.apache.solr.security.AuditEvent
The HTTP method.
getHttpMethod() - Method in class org.apache.solr.security.AuthorizationContext
 
getHttpMethod() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getHttpQueryString() - Method in class org.apache.solr.security.AuditEvent
Query part of URL or null if query part
getHttpSolrCall() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getHttpSolrCall() - Method in interface org.apache.solr.request.SolrQueryRequest
 
getHttpSolrCall(HttpServletRequest, HttpServletResponse, boolean) - Method in class org.apache.solr.servlet.SolrDispatchFilter
Allow a subclass to modify the HttpSolrCall.
getHumanReadableFieldsBySize() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
getHumanReadableTypesBySize() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
getId() - Method in class org.apache.solr.cloud.OverseerTaskQueue.QueueEvent
 
getId() - Method in class org.apache.solr.core.backup.BackupId
 
getId() - Method in class org.apache.solr.search.StrParser
 
getId() - Method in class org.apache.solr.update.DeleteUpdateCommand
 
getId(String) - Method in class org.apache.solr.search.StrParser
 
getIdAsString() - Method in class org.apache.solr.core.backup.ShardBackupId
 
getIdSet() - Method in class org.apache.solr.response.transform.BaseEditorialTransformer
 
getIgnoreCase() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
getIgnoreCase() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
getIgnoreCase() - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
Returns the boolean value of the ManagedWordSetResource.IGNORE_CASE_INIT_ARG init arg, or the default value (false) if it has not been specified
getIgnoreCase(NamedList<?>) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
getIgnoreCase(NamedList<?>) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
getIgnoreCase(NamedList<?>) - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
Returns the boolean value of the ManagedWordSetResource.IGNORE_CASE_INIT_ARG init arg, or the default value (false) if it has not been specified
getIgnoreEmptyLines() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getIgnoreLeadingWhitespaces() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getIgnoreTrailingWhitespaces() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getImmutable(SolrCore) - Static method in class org.apache.solr.handler.SolrConfigHandler
 
getImplicitHandlers() - Method in class org.apache.solr.core.SolrCore
 
getInclude() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getIncludeConfFiles() - Method in class org.apache.solr.handler.ReplicationHandler
 
getIndexAnalyzer() - Method in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
This analyzer is not actually used for indexing.
getIndexAnalyzer() - Method in class org.apache.solr.schema.BoolField
 
getIndexAnalyzer() - Method in class org.apache.solr.schema.CollationField
 
getIndexAnalyzer() - Method in class org.apache.solr.schema.FieldType
Returns the Analyzer to be used when indexing fields of this type.
getIndexAnalyzer() - Method in class org.apache.solr.schema.IndexSchema
Returns the Analyzer used when indexing documents for this index
getIndexAnalyzer() - Method in class org.apache.solr.schema.PreAnalyzedField
Overridden to return an analyzer consisting of a PreAnalyzedField.PreAnalyzedTokenizer.
getIndexAnalyzer() - Method in class org.apache.solr.schema.RptWithGeometrySpatialField
 
getIndexCommitByName(String) - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
This method returns the IndexCommit associated with the specified commitName .
getIndexDir() - Method in class org.apache.solr.core.backup.BackupFilePaths
Return a URI for the 'index' location, responsible for holding index files for all backups at this location.
getIndexDir() - Method in class org.apache.solr.core.SolrCore
 
getIndexDir() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getIndexDirPath() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
getIndexDirPath() - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager.SnapshotMetaData
 
getIndexedFieldNames() - Method in class org.apache.solr.search.SolrDocumentFetcher
Returns a collection of the names of all indexed fields which the index reader knows about.
getIndexedId() - Method in class org.apache.solr.update.AddUpdateCommand
Returns the indexed ID that we route this document on.
getIndexedId() - Method in class org.apache.solr.update.DeleteUpdateCommand
Returns the indexed ID for this delete.
getIndexedIdStr() - Method in class org.apache.solr.update.AddUpdateCommand
Returns the indexed ID that we route this document on.
getIndexedSuperPhrases() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns all phrases larger then this phrase, which fully include this phrase, and are indexed.
getIndexFingerprint(long) - Method in class org.apache.solr.search.SolrIndexSearcher
 
getIndexFingerprint(SolrIndexSearcher, LeafReaderContext, long) - Method in class org.apache.solr.core.SolrCore
Computes fingerprint of a segment and caches it only if all the version in segment are included in the fingerprint.
getIndexInfo(DirectoryReader) - Static method in class org.apache.solr.handler.admin.LukeRequestHandler
 
getIndexReader() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getIndexReaderFactory() - Method in class org.apache.solr.core.SolrCore
 
getIndexSchema() - Method in class org.apache.solr.core.ConfigSet
 
getIndexSchema(boolean) - Method in class org.apache.solr.core.ConfigSet
 
getIndexSize() - Method in class org.apache.solr.core.SolrCore
 
getIndexVersion() - Method in class org.apache.solr.core.backup.BackupProperties
 
getIndexVersionResponse() - Method in class org.apache.solr.handler.ReplicationHandler
 
getIndexWriter(SolrCore) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getIndexWriter(SolrCore) - Method in class org.apache.solr.update.SolrCoreState
Get the current IndexWriter.
getIndividualIndexedTerms() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns the list of "individual" (ie: getPositionLength()==1 terms.
getInfo() - Method in class org.apache.solr.api.ContainerPluginsRegistry.ApiInfo
 
getInfo() - Method in class org.apache.solr.logging.LoggerInfo
 
getInfo() - Method in class org.apache.solr.rest.ManagedResourceStorage.FileStorageIO
 
getInfo() - Method in class org.apache.solr.rest.ManagedResourceStorage.InMemoryStorageIO
 
getInfo() - Method in interface org.apache.solr.rest.ManagedResourceStorage.StorageIO
 
getInfo() - Method in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
getInfo() - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
getInfo(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
getInfoHandler() - Method in class org.apache.solr.core.CoreContainer
 
getInfoHandlerClass() - Method in class org.apache.solr.core.NodeConfig
 
getInfoMBeans() - Method in class org.apache.solr.core.SolrResourceLoader
 
getInfoRegistry() - Method in class org.apache.solr.core.SolrCore
Returns a Map of name vs SolrInfoBean objects.
getInheritableThreadLocalProvider() - Static method in class org.apache.solr.request.SolrRequestInfo
 
getInitArgs() - Method in class org.apache.solr.handler.RequestHandlerBase
 
getInitializedOn() - Method in class org.apache.solr.rest.ManagedResource
Returns this resource's initialization timestamp.
getInitParams() - Method in class org.apache.solr.core.SolrConfig
 
getInputDocument(SolrCore, BytesRef, BytesRef, AtomicLong, Set<String>, RealTimeGetComponent.Resolution) - Static method in class org.apache.solr.handler.component.RealTimeGetComponent
Obtains the latest document for a given id from the tlog or through the realtime searcher (if not found in the tlog).
getInputDocumentFromTlog(SolrCore, BytesRef, AtomicLong, Set<String>, RealTimeGetComponent.Resolution) - Static method in class org.apache.solr.handler.component.RealTimeGetComponent
returns the SolrInputDocument from the current tlog, or DELETED if it has been deleted, or null if there is no record of it in the current update log.
getInputFieldNames() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getInputStream() - Method in class org.apache.solr.filestore.FileStore.FileEntry
 
getInstance() - Method in class org.apache.solr.api.ContainerPluginsRegistry.ApiInfo
 
getInstance() - Method in class org.apache.solr.core.PluginBag.PluginHolder
 
getInstance() - Static method in class org.apache.solr.search.SolrQueryTimeoutImpl
Return singleton instance
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.AddSchemaFieldsUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.AtomicUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ConcatFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.CountFieldValuesUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.DefaultValueUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.DocExpirationUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.FieldLengthUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.FieldNameMutatingUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.FieldValueSubsetUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.HTMLStripFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.IgnoreCommitOptimizeUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.IgnoreFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.IgnoreLargeDocumentProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.LogUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.NestedUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.NoOpDistributingUpdateProcessorFactory
Returns the next
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ParseBooleanFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ParseDateFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ParseDoubleFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ParseFloatFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ParseIntFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.ParseLongFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.PreAnalyzedUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.RegexpBoostProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.RegexReplaceProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.RemoveBlankFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.RunUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.SkipExistingDocumentsProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.TimestampUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.TrimFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.TruncateFieldUpdateProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder.LazyUpdateRequestProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.UpdateRequestProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.URLClassifyProcessorFactory
 
getInstance(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Method in class org.apache.solr.update.processor.UUIDUpdateProcessorFactory
 
getInstanceDir() - Method in class org.apache.solr.core.CoreDescriptor
The core instance directory (absolute).
getInstancePath() - Method in class org.apache.solr.core.SolrCore
The core's instance directory (absolute).
getInstancePath() - Method in class org.apache.solr.core.SolrResourceLoader
The instance path for this resource loader, as passed in from the constructor.
getInstanceTag() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
For unit tests.
getInt() - Method in class org.apache.solr.search.StrParser
 
getInt(String) - Method in class org.apache.solr.core.XmlConfigFile
 
getInt(String, int) - Method in class org.apache.solr.core.XmlConfigFile
 
getInterestingTerms(BooleanQuery, int) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
Yields terms with boosts from the boosted MLT query.
getInternalArray() - Method in class org.apache.solr.util.LongPriorityQueue
Returns the array used to hold the heap, with the smallest item at array[1] and the last (but not necessarily largest) at array[size()].
getInternalCollector() - Method in class org.apache.solr.search.CancellableCollector
 
getInternalName() - Method in class org.apache.solr.cluster.placement.impl.MetricImpl
 
getInternalName() - Method in interface org.apache.solr.cluster.placement.Metric
Return the internal name of a Solr metric associated with this attribute.
getInternalRank() - Method in class org.apache.solr.spelling.SpellCheckCollation
 
getIntervalMath() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getIsShard() - Method in class org.apache.solr.handler.component.StatsField
 
getJaxrsRegistry() - Method in class org.apache.solr.core.PluginBag
 
getJerseyAppHandlerCache() - Method in class org.apache.solr.core.CoreContainer
 
getJerseyApplicationHandler() - Method in class org.apache.solr.core.CoreContainer
 
getJerseyApplicationHandler() - Method in class org.apache.solr.core.SolrCore
 
getJerseyEndpoints() - Method in class org.apache.solr.core.PluginBag
 
getJerseyResources() - Method in interface org.apache.solr.api.ApiSupport
Returns any JAX-RS annotated v2 APIs associated with this request handler.
getJerseyResources() - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
getJerseyResources() - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
getJerseyResources() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
getJerseyResources() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getJerseyResources() - Method in class org.apache.solr.handler.admin.LoggingHandler
 
getJerseyResources() - Method in class org.apache.solr.handler.ReplicationHandler
 
getJerseyResources() - Method in class org.apache.solr.handler.SchemaHandler
 
getJerseyResources() - Method in class org.apache.solr.security.PublicKeyHandler
 
getJoinedExternalVal() - Method in class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
getJson(SolrClient, String, Class<T>) - Static method in class org.apache.solr.packagemanager.PackageUtils
Download JSON from a Solr url and deserialize into klass.
getJSON() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getJSON() - Method in interface org.apache.solr.request.SolrQueryRequest
Returns any associated JSON (or null if none) in deserialized generic form.
getJSON() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getJsonStringFromUrl(SolrClient, String, SolrParams) - Static method in class org.apache.solr.packagemanager.PackageUtils
Returns JSON string from a given Solr URL
getJvmInfo(NodeConfig) - Static method in class org.apache.solr.handler.admin.SystemInfoHandler
Get JVM Info - including memory info
getK() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getKey() - Method in class org.apache.solr.handler.component.FacetComponent.FacetBase
returns the key in the response that this facet will be under
getKey() - Method in class org.apache.solr.request.IntervalFacets.FacetInterval
 
getKey() - Method in interface org.apache.solr.search.grouping.Command
 
getKey() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand
 
getKey() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand
 
getKey() - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand
 
getKey(SolrDocument) - Method in class org.apache.solr.response.transform.BaseEditorialTransformer
 
getKey(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the key that indexes the node argument.
getKeyPair() - Method in class org.apache.solr.security.PublicKeyHandler
 
getKeyPair() - Method in class org.apache.solr.security.SolrNodeKeyPair
 
getKeys() - Method in class org.apache.solr.filestore.DistribFileStore
 
getKeys() - Method in interface org.apache.solr.filestore.FileStore
Get all the keys in the package store.
getKeySizeInBytes() - Method in class org.apache.solr.util.CryptoKeys.RSAKeyPair
 
getKeyStorePassword() - Method in class org.apache.solr.util.configuration.SSLConfigurations
 
getKnnAlgorithm() - Method in class org.apache.solr.schema.DenseVectorField
 
getKnnVectorQuery(String, String, int, Query) - Method in class org.apache.solr.schema.DenseVectorField
 
getLabel() - Method in class org.apache.solr.handler.admin.SolrEnvironment
 
getLargestIndexedSubPhrases() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns the list of (overlapping) sub phrases that have the largest possible size based on the effective value of PhrasesIdentificationComponent.PhrasesContextData.maxIndexedPositionLength.
getLastActionStartedAt() - Method in class org.apache.solr.cloud.ActionThrottle
 
getLastEvent() - Method in class org.apache.solr.logging.LogWatcher
 
getLastLogId() - Method in class org.apache.solr.update.UpdateLog
 
getLastModFrom() - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
 
getLastModified() - Method in class org.apache.solr.core.SolrResourceLoader.SolrFileInputStream
 
getLastPackageRelease(String) - Method in class org.apache.solr.packagemanager.RepositoryManager
 
getLastPublished() - Method in class org.apache.solr.cloud.CloudDescriptor
 
getLastReplicateIndexSuccess() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getLastReplicateIndexSuccess() - Method in class org.apache.solr.update.SolrCoreState
 
getLatest() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage
 
getLatest(String) - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage
 
getLatestAccessedItems(int) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
getLatestCommit() - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Returns the most recent commit point.
getLatestFile(String, String) - Static method in class org.apache.solr.util.VersionedFile
 
getLatestSchema() - Method in class org.apache.solr.core.SolrCore
 
getLatestVersion() - Method in class org.apache.solr.handler.IndexFetcher
Gets the latest commit version and generation from the leader
getLeader() - Method in interface org.apache.solr.cluster.Shard
 
getLeaderConflictResolveWait() - Method in class org.apache.solr.cloud.ZkController
 
getLeaderConflictResolveWait() - Method in class org.apache.solr.core.CloudConfig
 
getLeaderId(SolrZkClient) - Static method in class org.apache.solr.cloud.OverseerTaskProcessor
 
getLeaderMetrics() - Method in interface org.apache.solr.cluster.placement.ShardMetrics
 
getLeaderNode(SolrZkClient) - Static method in class org.apache.solr.cloud.OverseerTaskProcessor
 
getLeaderProps(String, String, int) - Method in class org.apache.solr.cloud.ZkController
Get leader props directly from zk nodes.
getLeaderProps(String, String, int, boolean) - Method in class org.apache.solr.cloud.ZkController
Get leader props directly from zk nodes.
getLeaderRegistryName() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Metric registry name for leader metrics.
getLeaderThrottle() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getLeaderThrottle() - Method in class org.apache.solr.update.SolrCoreState
 
getLeaderUrl(String) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
getLeaderUrl(String) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
getLeaderVoteWait() - Method in class org.apache.solr.cloud.ZkController
 
getLeaderVoteWait() - Method in class org.apache.solr.core.CloudConfig
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.solr.search.CancellableCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.solr.search.EarlyTerminatingCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.solr.search.grouping.collector.FilterCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.solr.search.ReRankCollector
 
getLen() - Method in class org.apache.solr.search.QueryCommand
 
getLevel() - Method in class org.apache.solr.logging.jul.JulInfo
 
getLevel() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher.Log4j2Info
 
getLevel() - Method in class org.apache.solr.logging.LoggerInfo
 
getLevel() - Method in class org.apache.solr.security.AuditEvent
Level of this event.
getLexSorted() - Method in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
getLexSorted(HashMap<String, TermsResponse.Term>) - Method in class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
getLimitedValue(String) - Method in class org.apache.solr.schema.CopyField
 
getLine() - Method in class org.apache.solr.internal.csv.CSVParser
Parses from the current point in the stream til the end of the current line.
getLineNumber() - Method in class org.apache.solr.internal.csv.CSVParser
Returns the current line number in the input stream.
getLines(String) - Method in class org.apache.solr.core.SolrResourceLoader
Accesses a resource by name and returns the (non comment) lines containing data.
getLines(String, String) - Method in class org.apache.solr.core.SolrResourceLoader
Accesses a resource by name and returns the (non comment) lines containing data using the given character encoding.
getLines(String, Charset) - Method in class org.apache.solr.core.SolrResourceLoader
 
getListedTermCounts(String, SimpleFacets.ParsedParams, List<String>) - Method in class org.apache.solr.request.SimpleFacets
Computes the term->count counts for the specified term values relative to the
getListeners() - Method in class org.apache.solr.pkg.PackageListeners
 
getListValue(Map<String, Object>, String) - Static method in class org.apache.solr.handler.admin.SecurityConfHandler
 
getLiveDataNodes() - Method in interface org.apache.solr.cluster.Cluster
 
getLiveDocs() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getLiveDocsBits() - Method in class org.apache.solr.search.SolrIndexSearcher
Returns an efficient random-access Bits of the live docs.
getLiveDocSet() - Method in class org.apache.solr.search.SolrIndexSearcher
Returns an efficient random-access DocSet of the live docs.
getLiveNodes() - Method in interface org.apache.solr.cluster.Cluster
 
getLiveOrLiveAndCreateNodeSetList(Set<String>, ZkNodeProps, Random, DistribStateManager) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
getLivePaths() - Method in class org.apache.solr.core.CachingDirectoryFactory
Method for inspecting the cache
getLoadAverageThreshold() - Method in class org.apache.solr.util.circuitbreaker.LoadAverageCircuitBreaker
 
getLoadedCoreNames() - Method in class org.apache.solr.core.CoreContainer
Gets the permanent and transient cores that are currently loaded, i.e.
getLoadedCoreNames() - Method in class org.apache.solr.core.SolrCores
Gets the cores that are currently loaded, i.e.
getLoadedCoreNames() - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Returns the names of all currently loaded cores.
getLoadedCoreNames() - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
getLoadedCoreNames() - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getLoadedCoreWithoutIncrement(String) - Method in class org.apache.solr.core.SolrCores
(internal) Return a core that is already loaded, if it is.
getLoadedCoreWithoutIncrement(String) - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getLoader() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage.Version
 
getLocalParams() - Method in class org.apache.solr.search.QParser
 
getLocalParams(String, String) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getLocalParams(String, SolrParams) - Static method in class org.apache.solr.search.QueryParsing
"foo" returns null "{!prefix f=myfield}yes" returns type="prefix",f="myfield",v="yes" "{!prefix f=myfield v=$p}" returns type="prefix",f="myfield",v=params.get("p")
getLocation() - Method in class org.apache.solr.handler.SnapShooter
Gets the parent directory of the snapshots.
getLog2m() - Method in class org.apache.solr.handler.component.StatsField.HllOptions
 
getLogDir() - Method in class org.apache.solr.update.UpdateLog
 
getLogFileSize() - Method in class org.apache.solr.update.TransactionLog
Gets the log file data size.
getLoggerConfig(LoggerContext, String) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
getLoggerImplStr() - Static method in class org.apache.solr.util.StartupLoggingUtils
 
getLogging() - Method in class org.apache.solr.core.CoreContainer
 
getLoggingClass() - Method in class org.apache.solr.logging.LogWatcherConfig
Get the implementation of the LogWatcher to use.
getLoggingHandler() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getLogLevelString() - Static method in class org.apache.solr.util.StartupLoggingUtils
Return a string representing the current static ROOT logging level
getLogList(File) - Method in class org.apache.solr.update.UpdateLog
 
getLogSize() - Method in class org.apache.solr.update.TransactionLog
 
getLogSizeFromStream() - Method in class org.apache.solr.update.TransactionLog
 
getLogWatcherConfig() - Method in class org.apache.solr.core.NodeConfig
 
getLookupResult(String, String) - Method in class org.apache.solr.spelling.suggest.SuggesterResult
Get a list of lookup result for a given token null can be returned, if there are no lookup results for the token
getLower() - Method in class org.apache.solr.query.SolrRangeQuery
 
getLowerVal() - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
getLuceneFieldNames() - Method in class org.apache.solr.search.ReturnFields
Set of field names with their exact names from the lucene index.
getLuceneFieldNames() - Method in class org.apache.solr.search.SolrReturnFields
 
getLuceneFieldNames(boolean) - Method in class org.apache.solr.search.ReturnFields
Set of field names with their exact names from the lucene index.
getLuceneFieldNames(boolean) - Method in class org.apache.solr.search.SolrReturnFields
 
getMainQueryMax() - Method in class org.apache.solr.search.ReRankScaler
 
getMainQueryMin() - Method in class org.apache.solr.search.ReRankScaler
 
getMainScale() - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
getMainScaleExplain() - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
getMainValuePrefix(FieldType) - Static method in class org.apache.solr.schema.TrieField
Deprecated.
expert internal use, subject to change.
getManagedResource(String) - Method in class org.apache.solr.rest.RestManager
Returns the ManagedResource subclass instance corresponding to the given resourceId from the registry.
getManagedResourceImplClass() - Method in class org.apache.solr.rest.schema.analysis.BaseManagedTokenFilterFactory
Let the concrete analysis component determine the ManagedResource implementation.
getManagedResourceImplClass() - Method in class org.apache.solr.rest.schema.analysis.ManagedStopFilterFactory
Returns the implementation class for managing stop words.
getManagedResourceImplClass() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
 
getManagedResourceImplClass() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
 
getManagedResourceOrNull(String) - Method in class org.apache.solr.rest.RestManager
Returns the ManagedResource subclass instance corresponding to the given resourceId from the registry, or null if no resource has been registered with the given resourceId.
getManagedResourceRegistry() - Method in class org.apache.solr.core.SolrResourceLoader
 
getManagedSchemaResourceName() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
getManagedSchemaZkPath(String) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
getManagementPath() - Method in class org.apache.solr.core.CoreContainer
Gets the alternate path for multicore handling: This is used in case there is a registered unnamed core (aka name is "") to declare an alternate way of accessing named cores.
getManagementPath() - Method in class org.apache.solr.core.NodeConfig
 
getMap() - Method in class org.apache.solr.util.ConcurrentLRUCache
 
getMapper() - Static method in class org.apache.solr.packagemanager.PackageUtils
 
getMapValue(Map<String, Object>, String) - Static method in class org.apache.solr.handler.admin.SecurityConfHandler
 
getMapWithVersion(Map<String, Object>, int) - Static method in class org.apache.solr.core.RequestParams
 
getMarkerChar() - Method in class org.apache.solr.analysis.ReversedWildcardFilterFactory
 
getMatched() - Method in class org.apache.solr.metrics.SolrMetricManager.PrefixFilter
Return the set of names that matched this filter.
getMatched() - Method in class org.apache.solr.metrics.SolrMetricManager.RegexFilter
Return the set of names that matched this filter.
getMatches() - Method in class org.apache.solr.search.grouping.collector.FilterCollector
 
getMatches() - Method in class org.apache.solr.search.Grouping.Command
Returns the number of matches for this Command.
getMatches() - Method in class org.apache.solr.search.Grouping.CommandField
 
getMatches() - Method in class org.apache.solr.search.Grouping.CommandFunc
 
getMatches() - Method in class org.apache.solr.search.Grouping.CommandQuery
 
getMatches() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommandResult
 
getMax() - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Returns the upper value of this range query
getMax() - Method in class org.apache.solr.metrics.AggregateMetric
 
getMax() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
getMax() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
getMax(int, int, int) - Static method in class org.apache.solr.search.Grouping
Returns offset + len if len equals zero or higher.
getMaxAge() - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
null if no max age limitation
getMaxChars() - Method in class org.apache.solr.schema.CopyField
 
getMaxChars() - Method in class org.apache.solr.schema.IndexSchema.DynamicCopy
 
getMaxCommitAge() - Method in class org.apache.solr.core.SolrDeletionPolicy
 
getMaxCommitsToKeep() - Method in class org.apache.solr.core.SolrDeletionPolicy
 
getMaxDepth() - Method in class org.apache.solr.search.join.GraphQuery
 
getMaxDoc() - Method in class org.apache.solr.update.IndexFingerprint
 
getMaxFutureMs() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getMaximumBalanceSkew() - Method in interface org.apache.solr.cluster.placement.BalanceRequest
 
getMaximumBalanceSkew() - Method in class org.apache.solr.cluster.placement.impl.BalanceRequestImpl
 
getMaxInHash() - Method in class org.apache.solr.update.IndexFingerprint
 
getMaxInt(Terms) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns the maximum int value indexed into this numeric field or null if no terms exist.
getMaxLong(Terms) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns the maximum long value indexed into this numeric field or null if no terms exist.
getMaxNoHighlightPassages(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getMaxNumLogsToKeep() - Method in class org.apache.solr.update.UpdateLog
 
getMaxOptimizedCommitsToKeep() - Method in class org.apache.solr.core.SolrDeletionPolicy
 
getMaxPermits() - Method in class org.apache.solr.util.AdjustableSemaphore
 
getMaxPredictedClasses() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getMaxRamMB() - Method in class org.apache.solr.search.CaffeineCache
 
getMaxRamMB() - Method in interface org.apache.solr.search.SolrCache
Returns maximum size limit (in MB) if set and supported, -1 otherwise.
getMaxRecentVersion() - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
 
getMaxRecoveryThreads() - Method in class org.apache.solr.update.UpdateShardHandlerConfig
 
getMaxRetries() - Method in class org.apache.solr.cloud.RecoveryStrategy
 
getMaxRetries() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
getMaxRetries() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
getMaxScore() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommandResult
 
getMaxScore() - Method in class org.apache.solr.search.MaxScoreCollector
 
getMaxShingleSize(Analyzer) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent
Helper method, public for testing purposes only.
getMaxSize() - Method in class org.apache.solr.search.CaffeineCache
 
getMaxSize() - Method in interface org.apache.solr.search.SolrCache
Returns maximum size limit (number of items) if set and supported, -1 otherwise.
getMaxSize() - Method in class org.apache.solr.util.BoundedTreeSet
 
getMaxSnippets(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return the max number of snippets for this field.
getMaxUpdateConnections() - Method in class org.apache.solr.update.UpdateShardHandlerConfig
 
getMaxUpdateConnectionsPerHost() - Method in class org.apache.solr.update.UpdateShardHandlerConfig
 
getMaxVersionEncountered() - Method in class org.apache.solr.update.IndexFingerprint
 
getMaxVersionSpecified() - Method in class org.apache.solr.update.IndexFingerprint
 
getMBeanInfo() - Method in class org.apache.solr.metrics.MetricsMap
 
getMBeanInfo(SolrQueryRequest) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
getMBeanServer() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Return the reporter's MBeanServer.
getMean() - Method in class org.apache.solr.metrics.AggregateMetric
 
getMean() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
getMean() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
getMeanRate() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
getMeanRate() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getMeanRate() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxMeterMBean
 
getMediaTypeFromWtParam(SolrQueryRequest, String) - Static method in class org.apache.solr.handler.api.V2ApiUtils
 
getMergedBucket() - Method in class org.apache.solr.search.facet.FacetBucket
 
getMergedResult() - Method in class org.apache.solr.search.facet.FacetFieldMerger
 
getMergedResult() - Method in class org.apache.solr.search.facet.FacetMerger
 
getMergedResult() - Method in class org.apache.solr.search.facet.FacetRangeMerger
 
getMergeIterator(List<LeafReaderContext>, FixedBitSet[], SortDoc) - Method in class org.apache.solr.handler.export.ExportWriter
 
getMergePolicy() - Method in class org.apache.solr.index.DefaultMergePolicyFactory
 
getMergePolicy() - Method in class org.apache.solr.index.MergePolicyFactory
 
getMergePolicy() - Method in class org.apache.solr.index.SimpleMergePolicyFactory
 
getMergePolicy() - Method in class org.apache.solr.index.WrapperMergePolicyFactory
Returns a wrapping MergePolicy with its set parameters configured.
getMergePolicyInstance() - Method in class org.apache.solr.index.LogByteSizeMergePolicyFactory
 
getMergePolicyInstance() - Method in class org.apache.solr.index.LogDocMergePolicyFactory
 
getMergePolicyInstance() - Method in class org.apache.solr.index.NoMergePolicyFactory
 
getMergePolicyInstance() - Method in class org.apache.solr.index.SimpleMergePolicyFactory
 
getMergePolicyInstance() - Method in class org.apache.solr.index.TieredMergePolicyFactory
 
getMergePolicyInstance(MergePolicy) - Method in class org.apache.solr.index.SortingMergePolicyFactory
 
getMergePolicyInstance(MergePolicy) - Method in class org.apache.solr.index.UpgradeIndexMergePolicyFactory
 
getMergePolicyInstance(MergePolicy) - Method in class org.apache.solr.index.WrapperMergePolicyFactory
Returns an instance of the wrapping MergePolicy without configuring its set parameters.
getMergePolicySort() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getMergePolicySort() - Method in class org.apache.solr.update.SolrCoreState
Get the current Sort of the current IndexWriter's MergePolicy..
getMergeStrategies() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getMergeStrategy() - Method in class org.apache.solr.search.AbstractReRankQuery
 
getMergeStrategy() - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
getMergeStrategy() - Method in class org.apache.solr.search.RankQuery
 
getMessage() - Method in exception org.apache.solr.api.ApiBag.ExceptionWithErrObject
 
getMessage() - Method in exception org.apache.solr.cluster.placement.PlacementModificationException
 
getMessage() - Method in exception org.apache.solr.handler.export.ExportWriter.IgnoreException
 
getMessage() - Method in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
getMessage() - Method in error org.apache.solr.parser.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessage() - Method in class org.apache.solr.security.AuditEvent
The human readable message about this event
getMessage() - Method in class org.apache.solr.security.AuthorizationResponse
 
getMessage() - Method in class org.apache.solr.security.AuthorizationUtils.AuthorizationFailure
 
getMetaData() - Method in interface org.apache.solr.filestore.FileStore.FileDetails
 
getMetaData() - Method in class org.apache.solr.filestore.FileStore.FileEntry
 
getMetaData() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getMeterSupplier() - Method in class org.apache.solr.core.MetricsConfig
 
getMeterSupplier() - Method in class org.apache.solr.metrics.SolrMetricManager
 
getMethod() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getMethod(String) - Static method in enum org.apache.solr.servlet.cache.Method
 
getMethodName() - Method in enum org.apache.solr.handler.component.HighlightComponent.HighlightMethod
 
getMetricManager() - Method in class org.apache.solr.core.CoreContainer
 
getMetricManager() - Method in class org.apache.solr.metrics.SolrMetricsContext
Return the instance of SolrMetricManager used in this context.
getMetricName() - Method in class org.apache.solr.metrics.SolrMetricInfo
Returns the metric name defined by this object.
getMetricNames() - Method in class org.apache.solr.metrics.SolrMetricsContext
Return a modifiable set of metric names that this component registers.
getMetricNameStrategy() - Method in class org.apache.solr.update.UpdateShardHandlerConfig
 
getMetricRegistry() - Method in class org.apache.solr.metrics.SolrMetricsContext
Get the MetricRegistry instance that is used for registering metrics in this context.
getMetricReporters() - Method in class org.apache.solr.core.MetricsConfig
 
getMetrics() - Method in class org.apache.solr.metrics.AltBufferPoolMetricSet
 
getMetrics() - Method in class org.apache.solr.metrics.OperatingSystemMetricSet
 
getMetrics(String, MetricFilter) - Method in class org.apache.solr.metrics.SolrMetricManager
Retrieve matching metrics and their names.
getMetricsConfig() - Method in class org.apache.solr.core.NodeConfig
 
getMetricsConfig() - Method in class org.apache.solr.metrics.SolrMetricManager
 
getMetricsForThisRequest(SolrQueryRequest) - Method in class org.apache.solr.handler.component.SearchHandler
 
getMetricsForThisRequest(SolrQueryRequest) - Method in class org.apache.solr.handler.RequestHandlerBase
The metrics to be used for this request.
getMetricsHandler() - Method in class org.apache.solr.core.CoreContainer
 
getMetricsSnapshot() - Method in class org.apache.solr.metrics.SolrMetricsContext
Return a snapshot of metric values that this component reports.
getMetricTag() - Method in class org.apache.solr.core.SolrCore
 
getMetricTag(NodeMetric<?>) - Static method in class org.apache.solr.cluster.placement.impl.AttributeFetcherImpl
 
getMetricValue() - Method in class org.apache.solr.util.circuitbreaker.AveragingMetricProvider
Return current average.
getMetricValue() - Method in interface org.apache.solr.util.circuitbreaker.AveragingMetricProvider.MetricProvider
 
getMin() - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Returns the lower value of this range query
getMin() - Method in class org.apache.solr.metrics.AggregateMetric
 
getMin() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
getMin() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
getMinCount() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getMinDf() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getMinExactCount() - Method in class org.apache.solr.search.QueryCommand
 
getMinInt(Terms) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns the minimum int value indexed into this numeric field or null if no terms exist.
getMinLong(Terms) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns the minimum long value indexed into this numeric field or null if no terms exist.
getMinMaxExplain(float, float, Map<Integer, Float>) - Static method in class org.apache.solr.search.ReRankScaler
 
getMinStateByteLenForCompression() - Method in class org.apache.solr.core.CloudConfig
 
getMinTf() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getMissingValue() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
The PivotFacetValue with corresponding to a value of null when FacetParams.FACET_MISSING is used.
getMisspellingsAndCorrections() - Method in class org.apache.solr.spelling.SpellCheckCollation
 
getModified(PackageAPI.Packages, PackageAPI.Packages) - Method in class org.apache.solr.pkg.SolrPackageLoader
 
getModifyLock() - Method in class org.apache.solr.core.SolrCores
 
getModuleLibPath(Path, String) - Static method in class org.apache.solr.util.ModuleUtils
Returns a path to a module's lib folder
getModules() - Method in class org.apache.solr.core.NodeConfig
Returns the modules as configured in solr.xml.
getModulesPath(Path) - Static method in class org.apache.solr.util.ModuleUtils
Returns path for modules directory, given the solr install dir path
getMoreLikeThis() - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
 
getMoreLikeThis(int, int, int, List<Query>, int) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
 
getMoreLikeThis(Reader, int, int, List<Query>, int) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
 
getMultiCoreHandler() - Method in class org.apache.solr.core.CoreContainer
 
getMultipartUploadLimitKB() - Method in class org.apache.solr.core.SolrConfig
 
getMultipleConfigs(SolrResourceLoader, SolrConfig, String, List<ConfigNode>) - Static method in class org.apache.solr.search.CacheConfig
 
getMultiplicativeBoosts() - Method in class org.apache.solr.search.ExtendedDismaxQParser
Parses all multiplicative boosts
getMultiplier() - Method in enum org.apache.solr.search.facet.FacetRequest.SortDirection
 
getMultiTermAnalyzer() - Method in class org.apache.solr.analysis.TokenizerChain
 
getMultiTermAnalyzer() - Method in class org.apache.solr.schema.TextField
Returns the Analyzer to be used when searching fields of this type when mult-term queries are specified.
getMultiTermQueries(ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getMultiTermRewriteMethod() - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getMultiValuedSeparatorChar(SolrParams) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
 
getMutableSchemaForConfigSet(String, int, String) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
getMutableValue() - Method in class org.apache.solr.search.PointMerger.ValueIterator
 
getMyName() - Method in class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
 
getMyName() - Method in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
getName() - Method in class org.apache.solr.cli.ApiTool
 
getName() - Method in class org.apache.solr.cli.AssertTool
 
getName() - Method in class org.apache.solr.cli.AuthTool
 
getName() - Method in class org.apache.solr.cli.ConfigSetDownloadTool
 
getName() - Method in class org.apache.solr.cli.ConfigSetUploadTool
 
getName() - Method in class org.apache.solr.cli.ConfigTool
 
getName() - Method in class org.apache.solr.cli.CreateCollectionTool
 
getName() - Method in class org.apache.solr.cli.CreateCoreTool
 
getName() - Method in class org.apache.solr.cli.CreateTool
 
getName() - Method in class org.apache.solr.cli.DeleteTool
 
getName() - Method in class org.apache.solr.cli.ExportTool
 
getName() - Method in class org.apache.solr.cli.HealthcheckTool
 
getName() - Method in class org.apache.solr.cli.PackageTool
 
getName() - Method in class org.apache.solr.cli.PostLogsTool
 
getName() - Method in class org.apache.solr.cli.PostTool
 
getName() - Method in class org.apache.solr.cli.RunExampleTool
 
getName() - Method in class org.apache.solr.cli.StatusTool
 
getName() - Method in interface org.apache.solr.cli.Tool
Defines the interface to a Solr tool that can be run from this command-line app.
getName() - Method in class org.apache.solr.cli.VersionTool
 
getName() - Method in class org.apache.solr.cli.ZkCpTool
 
getName() - Method in class org.apache.solr.cli.ZkLsTool
 
getName() - Method in class org.apache.solr.cli.ZkMkrootTool
 
getName() - Method in class org.apache.solr.cli.ZkMvTool
 
getName() - Method in class org.apache.solr.cli.ZkRmTool
 
getName() - Method in class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
 
getName() - Method in interface org.apache.solr.cloud.ClusterSingleton
Unique name of this singleton.
getName() - Method in class org.apache.solr.cloud.OverseerConfigSetMessageHandler
 
getName() - Method in interface org.apache.solr.cloud.OverseerMessageHandler
 
getName() - Method in interface org.apache.solr.cluster.events.ClusterEventProducer
 
getName() - Method in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
getName() - Method in interface org.apache.solr.cluster.Node
 
getName() - Method in class org.apache.solr.cluster.placement.impl.MetricImpl
 
getName() - Method in interface org.apache.solr.cluster.placement.Metric
Return the short-hand name that identifies this attribute.
getName() - Method in interface org.apache.solr.cluster.SolrCollection
The collection name (value passed to Cluster.getCollection(String)).
getName() - Method in interface org.apache.solr.core.BlobRepository.Decoder
A name by which to distinguish this decoding.
getName() - Method in class org.apache.solr.core.ConfigSet
 
getName() - Method in class org.apache.solr.core.CoreDescriptor
 
getName() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
getName() - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager.SnapshotMetaData
 
getName() - Method in class org.apache.solr.core.SolrConfig
 
getName() - Method in class org.apache.solr.core.SolrCore
 
getName() - Method in interface org.apache.solr.core.SolrInfoBean
Simple common usage name, e.g.
getName() - Method in class org.apache.solr.core.XmlConfigFile
 
getName() - Method in class org.apache.solr.handler.component.SearchComponent
 
getName() - Method in class org.apache.solr.handler.RequestHandlerBase
 
getName() - Method in class org.apache.solr.highlight.HighlightingPluginBase
 
getName() - Method in class org.apache.solr.logging.jul.JulWatcher
 
getName() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
getName() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher.Log4j2Info
 
getName() - Method in class org.apache.solr.logging.LoggerInfo
 
getName() - Method in class org.apache.solr.logging.LogWatcher
 
getName() - Method in class org.apache.solr.response.transform.BaseEditorialTransformer
 
getName() - Method in class org.apache.solr.response.transform.DocTransformer
 
getName() - Method in class org.apache.solr.response.transform.DocTransformer.NoopFieldTransformer
 
getName() - Method in class org.apache.solr.response.transform.DocTransformers
 
getName() - Method in class org.apache.solr.response.transform.RenameFieldTransformer
 
getName() - Method in class org.apache.solr.response.transform.ScoreAugmenter
 
getName() - Method in class org.apache.solr.response.transform.ValueSourceAugmenter
 
getName() - Method in class org.apache.solr.schema.SchemaField
 
getName() - Method in class org.apache.solr.search.CaffeineCache
 
getName() - Method in enum org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
 
getName() - Method in class org.apache.solr.search.join.HashRangeQParserPlugin
 
getName() - Method in class org.apache.solr.search.QParserPlugin
 
getName() - Method in class org.apache.solr.search.SolrFieldCacheBean
 
getName() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getName() - Method in class org.apache.solr.security.AuditLoggerPlugin
 
getName() - Method in class org.apache.solr.security.AuthenticationPlugin
 
getName() - Method in class org.apache.solr.spelling.suggest.SolrSuggester
Returns the unique name of the suggester
getName() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
getName() - Method in class org.apache.solr.update.UpdateShardHandler
 
getName() - Method in enum org.apache.solr.util.PivotListEntry
Name of this entry when used in response
getNamedListStyle() - Method in class org.apache.solr.response.JSONWriter
 
getNamedPlugins(String) - Method in class org.apache.solr.core.ConfigOverlay
 
getNamedPropertyValues() - Method in class org.apache.solr.schema.IndexSchema
Get a map of property name -> value for the whole schema.
getNamedPropertyValues() - Method in class org.apache.solr.schema.SimilarityFactory
Returns a serializable description of this similarity(factory)
getNamedPropertyValues(boolean) - Method in class org.apache.solr.schema.FieldType
Get a map of property name -> value for this field type.
getNamedPropertyValues(boolean) - Method in class org.apache.solr.schema.SchemaField
Get a map of property name -> value for this field.
getNamedPropertyValues(String, SolrParams) - Method in class org.apache.solr.schema.IndexSchema
 
getNameFor(String, HttpRequest) - Method in interface org.apache.solr.util.stats.HttpClientMetricNameStrategy
 
getNameFor(String, Request) - Method in interface org.apache.solr.util.stats.InstrumentedHttpListenerFactory.NameStrategy
 
getNameLower() - Method in enum org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
getNewBucketNumber() - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
getNewClock() - Method in class org.apache.solr.update.VersionInfo
 
getNewClusterProperties() - Method in interface org.apache.solr.cluster.events.ClusterPropertiesChangedEvent
 
getNewestSearcher(boolean) - Method in class org.apache.solr.core.SolrCore
Return the newest normal RefCounted<SolrIndexSearcher> with the reference count incremented.
getNewIndexDir() - Method in class org.apache.solr.core.SolrCore
Returns the indexdir as given in index.properties.
getNewSize() - Method in class org.apache.solr.search.facet.SlotAcc.Resizer
 
getNewSlot(int) - Method in class org.apache.solr.search.facet.SlotAcc.Resizer
 
getNextCount() - Method in class org.apache.solr.search.PointMerger.ValueIterator
 
getNextCursorMark() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getNextCursorMark() - Method in class org.apache.solr.search.QueryResult
 
getNextLevelValuesToRefine() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Returns the appropriate sub-list of the explicit values that need to be refined, based on the FacetParams.FACET_OFFSET & FacetParams.FACET_LIMIT for this field.
getNextTag() - Method in class org.apache.solr.handler.tagger.TagLL
 
getNextToken() - Method in class org.apache.solr.parser.QueryParser
Get the next Token.
getNextToken() - Method in class org.apache.solr.parser.QueryParserTokenManager
Get the next Token.
getNode() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
getNode() - Method in interface org.apache.solr.cluster.placement.ReplicaPlacement
 
getNode() - Method in interface org.apache.solr.cluster.Replica
Node on which this Replica is located.
getNode(CharSequence) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the node indexed by key, or null if that node doesn't exist.
getNode(CharSequence, JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the node indexed by key, or null if that node doesn't exist.
getNode(String, boolean) - Method in class org.apache.solr.core.XmlConfigFile
 
getNode(String, Document, boolean) - Method in class org.apache.solr.core.XmlConfigFile
 
GetNodeCommandStatus - Class in org.apache.solr.handler.admin.api
Implementation of V2 API interface GetNodeCommandStatusApi for checking the status of a core-level asynchronous command.
GetNodeCommandStatus(CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.GetNodeCommandStatus
 
getNodeConfig() - Method in class org.apache.solr.core.CoreContainer
 
getNodeList(String, boolean) - Method in class org.apache.solr.core.XmlConfigFile
 
getNodeMetric(Node, NodeMetric<T>) - Method in interface org.apache.solr.cluster.placement.AttributeValues
For the given node: metric identified by an instance of NodeMetric
getNodeMetric(Node, NodeMetric<T>) - Method in class org.apache.solr.cluster.placement.impl.AttributeValuesImpl
 
getNodeName() - Method in class org.apache.solr.cloud.ZkController
 
getNodeName() - Method in class org.apache.solr.core.NodeConfig
 
getNodeName() - Method in class org.apache.solr.handler.component.ShardResponse
 
getNodeName() - Static method in class org.apache.solr.logging.MDCLoggingContext
 
getNodeName() - Method in class org.apache.solr.search.CacheConfig
 
getNodeName() - Method in class org.apache.solr.security.AuditEvent
Node name of Solr node, on the internal format host:port_context, e.g.
getNodeName(String) - Static method in class org.apache.solr.cloud.LeaderElector
 
getNodeNames() - Method in interface org.apache.solr.cluster.events.NodesDownEvent
 
getNodeNames() - Method in interface org.apache.solr.cluster.events.NodesUpEvent
 
getNodeProps() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
getNodeProps() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
getNodes() - Method in interface org.apache.solr.cluster.placement.BalanceRequest
Replicas should only be balanced on nodes in the set returned by this method.
getNodes() - Method in class org.apache.solr.cluster.placement.impl.BalanceRequestImpl
 
getNodes(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
getNodesByRole(NodeRoles.Role, String, DistribStateManager) - Static method in class org.apache.solr.handler.ClusterAPI
 
getNodesByRoutingRules(ClusterState, DocCollection, String, SolrInputDocument) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
For CollectionParams.CollectionAction.MIGRATE
getNodesForNewReplicas(ClusterState, String, String, int, int, int, Object, SolrCloudManager, CoreContainer) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
getNodesFromParam(ZkNodeProps, String) - Method in class org.apache.solr.cloud.api.collections.MigrateReplicasCmd
 
getNodesFromXP(Node, String) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Gets all nodes matching an XPath
getNodeStatus(String, int) - Method in class org.apache.solr.cli.RunExampleTool
 
getNonFieldPropertyArgs() - Method in class org.apache.solr.schema.FieldType
Returns args to this field type that aren't standard field properties
getNonShardValue(int) - Method in class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
getNonStoredDVs(boolean) - Method in class org.apache.solr.search.SolrDocumentFetcher
Returns an unmodifiable set of non-stored docValues field names.
getNonStoredDVsWithoutCopyTargets() - Method in class org.apache.solr.search.SolrDocumentFetcher
Returns an unmodifiable set of names of non-stored docValues fields, except those that are targets of a copy field.
getNonZkLeaderAssumption(SolrQueryRequest) - Static method in class org.apache.solr.update.processor.DistributedUpdateProcessor
Returns a boolean indicating whether or not the caller should behave as if this is the "leader" even when ZooKeeper is not enabled.
getNoOpGauge(Gauge<T>) - Static method in class org.apache.solr.metrics.MetricSuppliers
 
getNormalizedURL(String) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
 
getNormValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getNotANumber() - Method in class org.apache.solr.core.MetricsConfig
 
getNow() - Method in class org.apache.solr.util.DateMathParser
Returns a clone of this instance's concept of "now" (never null).
getNOW() - Method in class org.apache.solr.request.SolrRequestInfo
 
getNullNumber() - Method in class org.apache.solr.core.MetricsConfig
 
getNullObject() - Method in class org.apache.solr.core.MetricsConfig
 
getNullString() - Method in class org.apache.solr.core.MetricsConfig
 
getNumAllCores() - Method in class org.apache.solr.core.CoreContainer
Gets the total number of cores, including permanent and transient cores, loaded and unloaded cores.
getNumAllCores() - Method in class org.apache.solr.core.SolrCores
Gets the total number of cores, including permanent and transient cores, loaded and unloaded cores.
getNumAllCores() - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getNumber() - Method in class org.apache.solr.search.StrParser
 
getNumberBackupsToKeep() - Method in class org.apache.solr.handler.ReplicationHandler.ReplicationHandlerConfig
 
getNumberCollected() - Method in exception org.apache.solr.search.EarlyTerminatingCollectorException
The number of documents collected that resulted in early termination
getNumberDocumentsFound() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getNumberOfGroups() - Method in class org.apache.solr.search.Grouping.Command
Returns the number of groups found for this Command.
getNumberOfGroups() - Method in class org.apache.solr.search.Grouping.CommandField
 
getNumberOfGroups() - Method in class org.apache.solr.search.Grouping.CommandFunc
 
getNumberOfOccurences() - Method in class org.apache.solr.spelling.SpellCheckCorrection
 
getNumberScanned() - Method in exception org.apache.solr.search.EarlyTerminatingCollectorException
The total number of documents in the index that were "scanned" by the index when collecting the EarlyTerminatingCollectorException.getNumberCollected() documents that triggered this exception.
getNumberType() - Method in class org.apache.solr.schema.AbstractEnumField
 
getNumberType() - Method in class org.apache.solr.schema.FieldType
Return the numeric type of this field, or null if this field is not a numeric field.
getNumberType() - Method in class org.apache.solr.schema.NumericFieldType
 
getNumDocs() - Method in class org.apache.solr.update.IndexFingerprint
 
getNumericDocValues(int, LeafReader, int) - Method in class org.apache.solr.search.DocValuesIteratorCache.FieldDocValuesSupplier
Returns docValues for the specified doc id in the specified reader, if the specified doc holds docValues for this DocValuesIteratorCache.FieldDocValuesSupplier instance, otherwise returns null.
getNumericDocValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getNumericDocValues(String) - Method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
 
getNumericDocValues(String) - Method in class org.apache.solr.uninverting.UninvertingReader
 
getNumericDocValues(QueryContext, SchemaField, QParser) - Static method in class org.apache.solr.search.facet.FieldUtil
 
getNumerics(LeafReader, String, FieldCache.Parser) - Method in interface org.apache.solr.uninverting.FieldCache
Returns a NumericDocValues over the values found in documents in the given field.
getNumerics(LeafReader, String, FieldCache.Parser) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getNumericSort(SchemaField, NumberType, boolean) - Method in class org.apache.solr.schema.FieldType
Utility usable by subclasses when they want to get basic Numeric sorting using common checks.
getNumFiles() - Method in class org.apache.solr.core.backup.AggregateBackupStats
 
getNumLoadedPermanentCores() - Method in class org.apache.solr.core.SolrCores
Gets the number of currently loaded permanent (non transient) cores.
getNumLoadedTransientCores() - Method in class org.apache.solr.core.SolrCores
Gets the number of currently loaded transient cores.
getNumLoadedTransientCores() - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getNumQueries() - Method in class org.apache.solr.util.MockSearchableSolrClient
 
getNumRecordsToKeep() - Method in class org.apache.solr.update.UpdateLog
 
getNumShards() - Method in class org.apache.solr.cloud.CloudDescriptor
 
getNumTerms() - Method in class org.apache.solr.search.facet.UnInvertedField
 
getNumUnloadedCores() - Method in class org.apache.solr.core.SolrCores
Gets the number of unloaded cores, including permanent and transient cores.
getNumUnloadedCores() - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
getNumUpdates() - Method in class org.apache.solr.util.MockSearchableSolrClient
 
getNumVersionBuckets() - Method in class org.apache.solr.update.UpdateLog
 
getNumVersions() - Method in class org.apache.solr.update.IndexFingerprint
 
getObjectCache() - Method in class org.apache.solr.core.CoreContainer
 
getObjectFrom(String, String) - Static method in class org.apache.solr.response.transform.ValueAugmenterFactory
 
getObjectMapper() - Static method in class org.apache.solr.jersey.SolrJacksonMapper
 
getObjectWithBackwardCompatibility(NamedList<?>, String, String) - Static method in class org.apache.solr.handler.ReplicationHandler
 
getOffset() - Method in class org.apache.solr.search.QueryCommand
 
getOffset() - Method in class org.apache.solr.search.SortSpec
Offset into the list of results.
getOffsetCorrector(SolrParams, Callable<String>) - Method in class org.apache.solr.handler.tagger.TaggerRequestHandler
 
getOffsetEnd() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
 
getOffsetSource(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getOffsetStart() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
 
getOldClock() - Method in class org.apache.solr.update.VersionInfo
 
getOldestAccessedItems(int) - Method in class org.apache.solr.util.ConcurrentLRUCache
Returns 'n' number of oldest accessed entries present in this cache.
getOneMinuteRate() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
getOneMinuteRate() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getOneMinuteRate() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxMeterMBean
 
getOpenCount() - Method in class org.apache.solr.core.SolrCore
Current core usage count.
getOpenEndOff(int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
getOpenNanoTime() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getOpenSearcher() - Method in class org.apache.solr.update.CommitTracker
 
getOpenStartOff(int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
getOpenTimeStamp() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getOperationRspObject() - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
getOptionalParams() - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
getOptionalParams() - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
getOptionalParams() - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
 
getOptionalParams() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getOptions() - Method in class org.apache.solr.cli.ApiTool
 
getOptions() - Method in class org.apache.solr.cli.AssertTool
 
getOptions() - Method in class org.apache.solr.cli.AuthTool
 
getOptions() - Method in class org.apache.solr.cli.ConfigSetDownloadTool
 
getOptions() - Method in class org.apache.solr.cli.ConfigSetUploadTool
 
getOptions() - Method in class org.apache.solr.cli.ConfigTool
 
getOptions() - Method in class org.apache.solr.cli.CreateCollectionTool
 
getOptions() - Method in class org.apache.solr.cli.CreateCoreTool
 
getOptions() - Method in class org.apache.solr.cli.CreateTool
 
getOptions() - Method in class org.apache.solr.cli.DeleteTool
 
getOptions() - Method in class org.apache.solr.cli.ExportTool
 
getOptions() - Method in class org.apache.solr.cli.HealthcheckTool
 
getOptions() - Method in class org.apache.solr.cli.PackageTool
 
getOptions() - Method in class org.apache.solr.cli.PostLogsTool
 
getOptions() - Method in class org.apache.solr.cli.PostTool
 
getOptions() - Method in class org.apache.solr.cli.RunExampleTool
 
getOptions() - Method in class org.apache.solr.cli.StatusTool
 
getOptions() - Method in interface org.apache.solr.cli.Tool
 
getOptions() - Method in class org.apache.solr.cli.VersionTool
 
getOptions() - Method in class org.apache.solr.cli.ZkCpTool
 
getOptions() - Method in class org.apache.solr.cli.ZkLsTool
 
getOptions() - Method in class org.apache.solr.cli.ZkMkrootTool
 
getOptions() - Method in class org.apache.solr.cli.ZkMvTool
 
getOptions() - Method in class org.apache.solr.cli.ZkRmTool
 
getOptions() - Method in class org.apache.solr.search.ExtendedQueryBase
 
getOptionsString(ExtendedQuery) - Static method in class org.apache.solr.search.ExtendedQueryBase
 
getOrCreate(String, ReporterClientCache.ClientProvider<T>) - Method in class org.apache.solr.metrics.reporters.ReporterClientCache
Get existing or register a new client.
getOrCreateNode(CharSequence) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the node indexed by key, creating that node if it doesn't exist, and creating any required intermediate nodes if they don't exist.
getOrd() - Method in class org.apache.solr.search.facet.FieldUtil.OrdValues
 
getOrd(int) - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
getOrdTermsEnum(LeafReader) - Method in class org.apache.solr.uninverting.DocTermOrds
Returns a TermsEnum that implements ord, or null if no terms in field.
getOrdValues(SortedDocValues, DocIdSetIterator) - Static method in class org.apache.solr.search.facet.FieldUtil
 
getOrGenerateRequestId(SolrQueryRequest) - Static method in class org.apache.solr.handler.component.SearchHandler
Returns a String to use as an identifier for this request.
getOriginal() - Method in class org.apache.solr.spelling.SpellCheckCorrection
 
getOriginalAsString() - Method in class org.apache.solr.spelling.SpellCheckCorrection
 
getOriginalParams() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getOriginalParams() - Method in interface org.apache.solr.request.SolrQueryRequest
Returns the original request parameters.
getOriginalParams() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getOriginalShardResponse() - Method in class org.apache.solr.handler.component.IterativeMergeStrategy.CallBack
 
getOtherHasVersions() - Method in class org.apache.solr.update.PeerSync.PeerSyncResult
 
getOthers() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getOutputKey() - Method in class org.apache.solr.handler.component.StatsField
The key to be used when refering to this StatsField instance in the response tp clients.
getOutStream() - Static method in interface org.apache.solr.cli.CLIO
 
getOverlay() - Method in class org.apache.solr.core.SolrConfig
 
getOverseer() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerCollectionQueue() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerCompletedMap() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerConfigSetQueue() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerElector() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerFailureMap() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerId() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
getOverseerId() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getOverseerJobQueue() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerRunningMap() - Method in class org.apache.solr.cloud.ZkController
 
getOverseerStats() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
Command delegating to Overseer to retrieve cluster state update stats from a Collection API call.
getOverseerStats() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getOverseerStatus(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
getOverwriteDupes() - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
getPackage(String) - Method in class org.apache.solr.packagemanager.DefaultPackageRepository
 
getPackage(String) - Method in class org.apache.solr.packagemanager.PackageRepository
 
getPackage(String) - Method in class org.apache.solr.pkg.SolrPackageLoader
 
getPackageAPI() - Method in class org.apache.solr.pkg.SolrPackageLoader
 
getPackageInstance(String, String) - Method in class org.apache.solr.packagemanager.PackageManager
Get the installed instance of a specific version of a package.
getPackageListeners() - Method in class org.apache.solr.core.SolrCore
 
getPackageLoader() - Method in class org.apache.solr.core.CoreContainer
 
getPackages() - Method in class org.apache.solr.packagemanager.DefaultPackageRepository
 
getPackages() - Method in class org.apache.solr.packagemanager.PackageRepository
Returns a map of package name to SolrPackages.
getPackages() - Method in class org.apache.solr.packagemanager.RepositoryManager
 
getPackages() - Method in class org.apache.solr.pkg.SolrPackageLoader
 
getPackagesDeployed(String) - Method in class org.apache.solr.packagemanager.PackageManager
 
getPackagesDeployedAsClusterLevelPlugins() - Method in class org.apache.solr.packagemanager.PackageManager
Get a map of packages (key: package name, value: package instance) that have their plugins deployed as cluster level plugins.
getPackagesMap() - Method in class org.apache.solr.packagemanager.RepositoryManager
Get a map of package name to SolrPackage objects
getPackageVersion(String, String) - Method in class org.apache.solr.pkg.SolrPackageLoader
 
getPackageVersion(PluginInfo.ClassName) - Method in interface org.apache.solr.pkg.PackageListeners.Listener
 
getPackageVersion(PluginInfo.ClassName) - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
getParam(String) - Method in class org.apache.solr.search.QParser
check both local and global params
getParam(String) - Method in class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
 
getParameter(NamedList<?>, String, T, StringBuilder) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
getParameter(NamedList<?>, String, T, StringBuilder) - Method in class org.apache.solr.handler.IndexFetcher
 
getParams() - Method in class org.apache.solr.cloud.CloudDescriptor
Optional parameters that can change how a core is created.
getParams() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getParams() - Method in interface org.apache.solr.request.SolrQueryRequest
returns the current request parameters
getParams() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getParams() - Method in class org.apache.solr.schema.SimilarityFactory
 
getParams() - Method in class org.apache.solr.search.QParser
 
getParams() - Method in class org.apache.solr.security.AuthorizationContext
 
getParams() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getParams(String) - Method in class org.apache.solr.core.RequestParams
 
getParams(String) - Method in class org.apache.solr.core.RequestParams.ParamSet
 
getParams(String) - Method in class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
returns value from init args or request parameter.
getParams(String, String) - Method in class org.apache.solr.core.RequestParams
 
getParamString() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getParamString() - Method in interface org.apache.solr.request.SolrQueryRequest
Returns a string representing all the important parameters.
getParamString() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getParent() - Method in class org.apache.solr.search.facet.FacetContext
 
getParentFilterLocalParamName() - Method in class org.apache.solr.search.join.BlockJoinChildQParser
 
getParentFilterLocalParamName() - Method in class org.apache.solr.search.join.BlockJoinParentQParser
 
getParentSlice(ClusterState, String, AtomicReference<String>, String) - Static method in class org.apache.solr.cloud.api.collections.SplitShardCmd
 
getParentTag(int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
getParsedResponse(SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.response.BinaryResponseWriter
TODO -- there may be a way to do this without marshal at all...
getParsedSchema(InputStream, SolrResourceLoader, String) - Static method in class org.apache.solr.schema.IndexSchemaFactory
 
getParsedSchema(ValidatingJsonMap) - Static method in class org.apache.solr.api.ApiBag
 
getParseMultipleSources() - Method in class org.apache.solr.search.FunctionQParser
parse multiple comma separated value sources
getParser(String, String, boolean, SolrQueryRequest) - Static method in class org.apache.solr.search.QParser
Expert: Create a QParser to parse qstr using the parserName parser, while allowing a toggle for whether local-params may be parsed.
getParser(String, String, SolrQueryRequest) - Static method in class org.apache.solr.search.QParser
Create a QParser to parse qstr using the defaultParser.
getParser(String, SolrQueryRequest) - Static method in class org.apache.solr.search.QParser
Create a QParser to parse qstr, using the "lucene" (QParserPlugin.DEFAULT_QTYPE) query parser.
getParser(Map<String, Float>, String, SolrParams, float) - Method in class org.apache.solr.search.DisMaxQParser
 
getParseToEnd() - Method in class org.apache.solr.search.FunctionQParser
throw exception if there is extra stuff at the end of the parsed valuesource(s).
getPassword(SSLCredentialProvider.CredentialType) - Method in class org.apache.solr.util.configuration.SSLConfigurations
 
getPath() - Method in class org.apache.solr.filestore.FileStore.FileEntry
 
getPath() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getPath() - Method in interface org.apache.solr.request.SolrQueryRequest
 
getPath() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getPath() - Method in class org.apache.solr.servlet.HttpSolrCall
 
getPath(Directory) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
getPathAfterContext(HttpServletRequest) - Static method in class org.apache.solr.servlet.ServletUtils
Use this to get the full path after context path "/solr", which is a combination of servletPath and pathInfo.
getPathSegments() - Method in class org.apache.solr.api.V2HttpCall
 
getPathTemplateValues() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getPathTemplateValues() - Method in interface org.apache.solr.request.SolrQueryRequest
Only for V2 API.
getPathType(URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns the type of a specified path
getPathType(URI) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
getPayload() - Method in class org.apache.solr.spelling.Token
Deprecated.
getPayloadDecoder(String) - Method in class org.apache.solr.schema.IndexSchema
 
getPayloadDecoder(FieldType) - Static method in class org.apache.solr.util.PayloadUtils
 
getPayloadEncoder(FieldType) - Static method in class org.apache.solr.util.PayloadUtils
 
getPayloadFunction(String) - Static method in class org.apache.solr.util.PayloadUtils
 
getPercentilesList() - Method in class org.apache.solr.handler.component.StatsField
 
getPeriod() - Method in class org.apache.solr.metrics.SolrMetricReporter
 
getPermissionName() - Method in enum org.apache.solr.security.PermissionNameProvider.Name
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.api.AnnotatedApi
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.api.ApiBag.ReqHandlerToApi
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.InfoHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.LoggingHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.LukeRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.MetricsCollectorHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.MetricsHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.PluginInfoHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.PropertiesRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.SecurityConfHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.SystemInfoHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.ThreadDumpHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.ZookeeperInfoHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.BlobHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.component.ActiveTasksListHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.component.QueryCancellationHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.component.SearchHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.DocumentAnalysisRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.DumpRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.FieldAnalysisRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.GraphHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.MoreLikeThisHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.NotFoundRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.PingRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.ReplicationHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.SchemaHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.SolrConfigHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.StreamHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.tagger.TaggerRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.handler.UpdateRequestHandler
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.search.function.FileFloatSource.ReloadCacheRequestHandler
 
getPermissionName(AuthorizationContext) - Method in interface org.apache.solr.security.PermissionNameProvider
 
getPermissionName(AuthorizationContext) - Method in class org.apache.solr.security.PublicKeyHandler
 
getPermissionNamesForRoles(Collection<String>) - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
Retrieves permission names for a given set of roles.
getPerShardColStats(ResponseBuilder, String) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
getPerShardColStats(ResponseBuilder, String) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
getPerShardColStats(ResponseBuilder, String) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
getPerShardTermStats(SolrQueryRequest, String, String) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
getPerShardTermStats(SolrQueryRequest, String, String) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
getPerShardTermStats(SolrQueryRequest, String, String) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
getPersistableStandardProperties() - Method in class org.apache.solr.core.CoreDescriptor
Get the standard properties in persistable form
getPersistableUserProperties() - Method in class org.apache.solr.core.CoreDescriptor
Get user-defined core properties in persistable form
getPhraseHighlighter(Query, String, SolrQueryRequest, TokenStream) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return a phrase Highlighter appropriate for this field.
getPhraseQuery(String, SolrPluginUtils.DisjunctionMaxQueryParser) - Method in class org.apache.solr.search.DisMaxQParser
 
getPhraseSlop() - Method in class org.apache.solr.parser.SolrQueryParserBase
Gets the default slop for phrases.
getPivots(NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
 
getPkgVersion() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage.Version
 
getPkiAuthenticationSecurityBuilder() - Method in class org.apache.solr.core.CoreContainer
 
getPkiHandlerPrivateKeyPath() - Method in class org.apache.solr.core.CloudConfig
 
getPkiHandlerPublicKeyPath() - Method in class org.apache.solr.core.CloudConfig
 
getPlacementPlanFactory() - Method in class org.apache.solr.cluster.placement.impl.SimplePlacementContextImpl
 
getPlacementPlanFactory() - Method in interface org.apache.solr.cluster.placement.PlacementContext
Factory used to create instances of PlacementPlan to return computed decision.
getPlacementPluginFactory() - Method in class org.apache.solr.core.CoreContainer
 
getPlugin(String) - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
getPluginInfo() - Method in class org.apache.solr.core.PluginBag.PluginHolder
 
getPluginInfo() - Method in class org.apache.solr.handler.RequestHandlerBase
 
getPluginInfo() - Method in class org.apache.solr.metrics.SolrMetricReporter
Get the effective PluginInfo instance that was used for initialization of this plugin.
getPluginInfo(String) - Method in class org.apache.solr.core.SolrConfig
 
getPluginInfos(String) - Method in class org.apache.solr.core.SolrConfig
SolrConfig keeps a repository of plugins by the type.
getPluginRegistryListener() - Method in class org.apache.solr.cluster.events.impl.ClusterEventProducerFactory
This method returns an initial plugin registry listener that helps to capture the freshly loaded listener plugins before the final cluster event producer is created.
getPluginRegistryListener() - Method in class org.apache.solr.core.ClusterSingletons
 
getPointRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.DatePointField
 
getPointRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.DoublePointField
 
getPointRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.FloatPointField
 
getPointRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.IntPointField
 
getPointRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.LongPointField
 
getPointRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.PointField
 
getPointValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getPositionEnd() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
NOTE: positions start at '1'
getPositionIncrementGap(String) - Method in class org.apache.solr.analysis.SolrAnalyzer
 
getPositionLength() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
 
getPositions() - Method in interface org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttribute
 
getPositions() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
getPositionsBitSet() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Each set bit identifies a position filled by this Phrase
getPositionStart() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
NOTE: positions start at '1'
getPostingsFormat() - Method in class org.apache.solr.schema.FieldType
 
getPostingsFormat() - Method in class org.apache.solr.schema.SchemaField
Expert/advanced method to get the field PostingsFormat.
getPostTags(SolrParams, String) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
 
getPrecisionStep() - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Returns the precision step.
getPrecisionStep() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Returns the precision step.
getPrecisionStep() - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
getPredictedClassField() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getPreemptiveCreateWindow() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getPrefixCodedIntShift(BytesRef) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns the shift value from a prefix encoded int.
getPrefixCodedLongShift(BytesRef) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns the shift value from a prefix encoded long.
getPrefixQuery(String, String) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getPrefixQuery(String, String) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getPrefixQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.FieldType
Returns a Query instance for doing prefix searches on this field type.
getPrefixQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.PointField
 
getPreTags(SolrParams, String) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
 
getPrevTag() - Method in class org.apache.solr.handler.tagger.TagLL
 
getPrimaryCounter() - Method in class org.apache.solr.metrics.DelegateRegistryCounter
 
getPrimaryHistogram() - Method in class org.apache.solr.metrics.DelegateRegistryHistogram
 
getPrimaryMeter() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
getPrimaryTimer() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getPrintableId() - Method in class org.apache.solr.update.AddUpdateCommand
The ID for logging purposes.
getPrinterNewline() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getProcessedDocuments() - Method in class org.apache.solr.response.ResultContext
 
getProcessedFilter(DocSet, List<Query>) - Method in class org.apache.solr.search.SolrIndexSearcher
INTERNAL: Processes conjunction (AND) of both args into a SolrIndexSearcher.ProcessedFilter result.
getProcessors() - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain
Returns the underlying array of factories used in this chain.
getPromptHeaders() - Method in interface org.apache.solr.security.BasicAuthPlugin.AuthenticationProvider
 
getPromptHeaders() - Method in class org.apache.solr.security.Sha256AuthenticationProvider
 
getProperties() - Method in class org.apache.solr.core.ConfigSet
 
getProperties() - Method in class org.apache.solr.schema.SchemaField
 
getPropertiesHandler() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getPropertiesName() - Method in class org.apache.solr.core.CoreDescriptor
 
getPrototype() - Method in class org.apache.solr.schema.IndexSchema.DynamicField
 
getProvider() - Method in class org.apache.solr.schema.CurrencyFieldType
 
getProviders() - Method in class org.apache.solr.util.configuration.SSLCredentialProviderFactory
 
getPublicKey() - Method in class org.apache.solr.security.GetPublicKey
 
getPublicKey() - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
getPublicKey() - Method in class org.apache.solr.util.CryptoKeys.RSAKeyPair
 
GetPublicKey - Class in org.apache.solr.security
V2 API implementation to fetch the public key of the receiving node.
GetPublicKey(SolrNodeKeyPair) - Constructor for class org.apache.solr.security.GetPublicKey
 
getPublicKeyStr() - Method in class org.apache.solr.util.CryptoKeys.RSAKeyPair
 
getPushWriter(Writer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.response.JSONResponseWriter
 
getQ() - Method in class org.apache.solr.search.join.GraphQuery
 
getQparser() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getQTime() - Method in class org.apache.solr.security.AuditEvent
Request time in milliseconds for completed requests
getQueries() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
getQueries(ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getQuery() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getQuery() - Method in class org.apache.solr.query.FilterQuery
 
getQuery() - Method in class org.apache.solr.response.BasicResultContext
 
getQuery() - Method in class org.apache.solr.response.ResultContext
 
getQuery() - Method in class org.apache.solr.search.QParser
Returns the resulting query from this QParser, calling parse() only the first time and caching the Query result.
getQuery() - Method in class org.apache.solr.search.QueryCommand
 
getQuery() - Method in class org.apache.solr.update.DeleteUpdateCommand
 
getQuery(Element) - Method in class org.apache.solr.search.LegacyNumericRangeQueryBuilder
Deprecated.
 
getQueryAnalyzer() - Method in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
getQueryAnalyzer() - Method in class org.apache.solr.schema.BoolField
 
getQueryAnalyzer() - Method in class org.apache.solr.schema.CollationField
 
getQueryAnalyzer() - Method in class org.apache.solr.schema.FieldType
Returns the Analyzer to be used when searching fields of this type.
getQueryAnalyzer() - Method in class org.apache.solr.schema.IndexSchema
Returns the Analyzer used when searching this index
getQueryAnalyzer() - Method in class org.apache.solr.schema.PreAnalyzedField
Returns the query analyzer defined via the schema, unless there is none, in which case the index-time pre-analyzer is returned.
getQueryAnalyzer() - Method in class org.apache.solr.schema.RptWithGeometrySpatialField
 
getQueryAnalyzer() - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
getQueryAnalyzer() - Method in class org.apache.solr.spelling.SolrSpellChecker
 
getQueryContext() - Method in class org.apache.solr.search.facet.FacetContext
 
getQueryCounts(NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
 
getQueryFacetsForTag(String) - Method in class org.apache.solr.handler.component.FacetComponent.FacetContext
 
getQueryFromSpatialArgs(QParser, SchemaField, SpatialArgs) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getQueryID() - Method in class org.apache.solr.search.QueryCommand
 
getQueryParams() - Method in class org.apache.solr.servlet.HttpSolrCall
 
getQueryPlugin(String) - Method in class org.apache.solr.core.SolrCore
 
getQueryResponseWriter(String) - Method in class org.apache.solr.core.SolrCore
Finds a writer by name, or returns the default writer if not found.
getQueryResponseWriter(SolrQueryRequest) - Method in class org.apache.solr.core.SolrCore
Returns the appropriate writer for a request.
getQueryScorer(Query, String, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return a Scorer suitable for this Query and field.
getQueryString() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getQueryTokenSet(String, Analyzer) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase
Analyzes the given text using the given analyzer and returns the produced tokens.
getQueuedRefinements(int) - Method in class org.apache.solr.handler.component.PivotFacet
An immutable List of the PivotFacetValues that need to be refined for this pivot.
getQueueLength() - Method in class org.apache.solr.cloud.Stats
 
getQuotedString() - Method in class org.apache.solr.search.StrParser
 
getRangeFacetRequestsForTag(String) - Method in class org.apache.solr.handler.component.FacetComponent.FacetContext
 
getRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.DenseVectorField
Not Supported
getRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.FieldType
Returns a Query instance for doing range searches on this field type.
getRangeQueryForFloatDoubleDocValues(SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.NumericFieldType
 
getRangeQueryForMultiValuedDoubleDocValues(SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.NumericFieldType
 
getRangeQueryForMultiValuedFloatDocValues(SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.NumericFieldType
 
getRangeQueryImpl(String, String, String, boolean, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getRanges - Variable in class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
getRanges(NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
 
getRankQuery() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getRateLimiterConfig() - Method in class org.apache.solr.servlet.RequestRateLimiter
 
getRateLimitManager() - Method in class org.apache.solr.servlet.CoreContainerProvider
 
getRateUnit() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxMeterMBean
 
getRawFields() - Method in class org.apache.solr.response.transform.DocTransformer
If this transformer wants to bypass escaping in the TextResponseWriter and write content directly to output for certain field(s), the names of any such field(s) should be returned
getRawFields() - Method in class org.apache.solr.response.transform.DocTransformers
 
getRawMLTQuery() - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
 
getRawReader() - Method in class org.apache.solr.search.SolrIndexSearcher
Raw reader (no fieldcaches etc).
getRawValue() - Method in interface org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttribute
Deprecated.
Returns current token's raw value as long with all LegacyNumericTokenStream.LegacyNumericTermAttribute.getShift() applied, undefined before first token
getRawValue() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
getReadApi() - Method in interface org.apache.solr.api.ClusterPluginsSource
Get the Read Api for this plugin source
getReadApi() - Method in class org.apache.solr.api.NodeConfigClusterPluginsSource
 
getReadApi() - Method in class org.apache.solr.api.ZkClusterPluginsSource
 
getReader(long) - Method in class org.apache.solr.update.TransactionLog
Returns a reader that can be used while a log is still in use.
getReaderCacheHelper() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getReaderCacheHelper() - Method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
 
getReaderCacheHelper() - Method in class org.apache.solr.uninverting.UninvertingReader
 
getReaderKey() - Method in class org.apache.solr.uninverting.FieldCache.CacheEntry
 
getRealMLTQuery() - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
 
getRealName() - Method in enum org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
getRealpath(String) - Method in class org.apache.solr.filestore.DistribFileStore
 
getRealpath(String) - Method in interface org.apache.solr.filestore.FileStore
get the real path on filesystem
getRealtimeSearcher() - Method in class org.apache.solr.core.SolrCore
Gets the latest real-time searcher w/o forcing open a new searcher if one already exists.
getRecentUpdates() - Method in class org.apache.solr.update.UpdateLog
The RecentUpdates object returned must be closed after use
getRecoveringAfterStartup() - Method in class org.apache.solr.cloud.RecoveryStrategy
 
getRecoveryExecutor() - Method in class org.apache.solr.update.UpdateShardHandler
 
getRecoveryLock() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getRecoveryLock() - Method in class org.apache.solr.update.SolrCoreState
 
getRecoveryOnlyConnectionManager() - Method in class org.apache.solr.update.UpdateShardHandler
 
getRecoveryOnlyHttpClient() - Method in class org.apache.solr.update.UpdateShardHandler
 
getRecoveryStrategyBuilder() - Method in class org.apache.solr.update.DefaultSolrCoreState
 
getRecoveryStrategyBuilder() - Method in class org.apache.solr.update.SolrCoreState
 
getRedactedSysPropValue(String) - Method in class org.apache.solr.core.NodeConfig
Returns the a system property value, or "--REDACTED--" if the system property is hidden
getRefcount() - Method in class org.apache.solr.util.RefCounted
 
getRefinement(FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetMerger
 
getRefinement(FacetMerger.Context, Collection<String>) - Method in class org.apache.solr.search.facet.FacetBucket
 
getRefinement2(FacetMerger.Context, Collection<String>) - Method in class org.apache.solr.search.facet.FacetBucket
 
getRefineMethod() - Method in class org.apache.solr.search.facet.FacetRequest
Returns null if unset
getRegenerator() - Method in class org.apache.solr.search.CacheConfig
 
getRegex() - Method in class org.apache.solr.schema.IndexSchema.DynamicReplacement
Returns the regex used to create this instance's pattern
getRegexpQuery(String, String) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getRegistered() - Method in class org.apache.solr.rest.RestManager.Registry
Get a view of the currently registered resources.
getRegisteredSearcher() - Method in class org.apache.solr.core.SolrCore
Returns the current registered searcher with its reference count incremented, or null if none are registered.
getRegistry() - Method in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
getRegistry() - Method in interface org.apache.solr.cluster.placement.NodeMetric
Metric registry.
getRegistry() - Method in class org.apache.solr.core.PluginBag
 
getRegistry() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Return the registry used by this SolrCore.
getRegistry(String) - Method in class org.apache.solr.api.ApiBag
 
getRegistryName() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Metric registry name of the manager.
getRegistryName() - Method in class org.apache.solr.metrics.SolrMetricsContext
Return metric registry name used in this context.
getRegistryName(SolrInfoBean.Group, String...) - Static method in class org.apache.solr.metrics.SolrMetricManager
Helper method to construct a properly prefixed registry name based on the group.
getRegwidth() - Method in class org.apache.solr.handler.component.StatsField.HllOptions
 
getReindexingState(DistribStateManager, String) - Static method in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
getRejectedModifications() - Method in exception org.apache.solr.cluster.placement.PlacementModificationException
Return rejected modifications and reasons for rejections.
getReloadLock() - Method in class org.apache.solr.handler.SolrConfigHandler
 
getReloadLock() - Method in class org.apache.solr.update.SolrCoreState
 
getRemoteAddr() - Method in class org.apache.solr.security.AuthorizationContext
 
getRemoteAddr() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getRemoteCoreUrl(String, String) - Method in class org.apache.solr.servlet.HttpSolrCall
 
getRemoteHost() - Method in class org.apache.solr.security.AuthorizationContext
 
getRemoteHost() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getReplaceRescorer() - Method in class org.apache.solr.search.ReRankScaler
 
getReplayUpdatesExecutor() - Method in class org.apache.solr.core.CoreContainer
 
getReplayUpdatesThreads() - Method in class org.apache.solr.core.NodeConfig
 
getReplica(String) - Method in interface org.apache.solr.cluster.Shard
Returns the Replica of the given name for that shard, if such a replica exists.
getReplicaIds() - Method in class org.apache.solr.cloud.ActiveReplicaWatcher
Return the list of replica id-s that are not active yet (or unverified).
getReplicaListTransformer(SolrQueryRequest) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
getReplicaMetric(ReplicaMetric<T>) - Method in interface org.apache.solr.cluster.placement.ReplicaMetrics
 
getReplicaMetrics(String) - Method in interface org.apache.solr.cluster.placement.ShardMetrics
 
getReplicaMetricsBuilders() - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ShardMetricsBuilder
 
getReplicaMovements() - Method in interface org.apache.solr.cluster.placement.BalancePlan
 
getReplicaName() - Method in interface org.apache.solr.cluster.placement.ReplicaMetrics
 
getReplicaName() - Method in interface org.apache.solr.cluster.Replica
 
getReplicaNodesForLeader(String, Replica, int) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
getReplicaPlacements() - Method in interface org.apache.solr.cluster.placement.PlacementPlan
 
getReplicas() - Method in interface org.apache.solr.cluster.placement.DeleteReplicasRequest
 
getReplicasForShardOnNode(Shard) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
getReplicaSnapshots() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
getReplicaSnapshotsForShard(String) - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
getReplicateLeaderUrl(ZkNodeProps) - Method in class org.apache.solr.cloud.RecoveryStrategy
This method may change in future and customisations are not supported between versions in terms of API or back compat behaviour.
getReplicaType() - Method in class org.apache.solr.cloud.CloudDescriptor
 
getReplicaType() - Method in interface org.apache.solr.cluster.placement.ReplicaPlacement
 
getReporterName() - Method in class org.apache.solr.metrics.reporters.jmx.JmxObjectNameFactory
Return current reporterName.
getReporters(String) - Method in class org.apache.solr.metrics.SolrMetricManager
Get a map of reporters for a registry.
getRepositories() - Method in class org.apache.solr.packagemanager.RepositoryManager
List of added repositories
getRepository() - Method in class org.apache.solr.packagemanager.SolrPackage
 
getReq() - Method in class org.apache.solr.request.SolrRequestInfo
 
getReq() - Method in class org.apache.solr.search.QParser
 
getReq() - Method in class org.apache.solr.servlet.HttpSolrCall
 
getReq() - Method in class org.apache.solr.update.UpdateCommand
 
getRequest() - Method in class org.apache.solr.api.PayloadObj
 
getRequest() - Method in interface org.apache.solr.cluster.placement.BalancePlan
 
getRequest() - Method in interface org.apache.solr.cluster.placement.PlacementPlan
 
getRequest() - Method in class org.apache.solr.request.SimpleFacets
 
getRequest() - Method in class org.apache.solr.response.BasicResultContext
 
getRequest() - Method in class org.apache.solr.response.ResultContext
Note: do not use the request to get the searcher! A cross-core request may have a different searcher (for the other core) than the original request.
getRequest() - Method in class org.apache.solr.search.facet.FacetContext
 
getRequestContext() - Method in class org.apache.solr.jersey.InjectionFactories.RequestContextBasedFactory
 
getRequestedFieldNames() - Method in class org.apache.solr.search.ReturnFields
The requested field names (includes pseudo fields)
getRequestedFieldNames() - Method in class org.apache.solr.search.SolrReturnFields
 
getRequestedProperties(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.NodePropertiesAPI
 
getRequestHandler(String) - Method in class org.apache.solr.core.CoreContainer
 
getRequestHandler(String) - Method in class org.apache.solr.core.SolrCore
Get the request handler registered to a given name.
getRequestHandler(String, PluginBag<SolrRequestHandler>) - Static method in class org.apache.solr.handler.RequestHandlerBase
Get the request handler registered to a given name.
getRequestHandlers() - Method in class org.apache.solr.core.CoreContainer
 
getRequestHandlers() - Method in class org.apache.solr.core.RequestHandlers
Returns an unmodifiable Map containing the registered handlers
getRequestHandlers() - Method in class org.apache.solr.core.SolrCore
Returns an unmodifiable Map containing the registered handlers
getRequestInfo() - Static method in class org.apache.solr.request.SolrRequestInfo
 
getRequestParams() - Method in class org.apache.solr.core.SolrConfig
 
getRequestParsers() - Method in class org.apache.solr.core.SolrConfig
 
getRequestPurpose(Integer) - Static method in class org.apache.solr.util.SolrPluginUtils
Given the integer purpose of a request generates a readable value corresponding the request purposes (there can be more than one on a single request).
getRequestPurposeNames(Integer) - Static method in class org.apache.solr.cli.PostLogsTool
 
getRequestRateLimiter(SolrRequest.SolrRequestType) - Method in class org.apache.solr.servlet.RateLimitManager
 
getRequestStatusMap(String) - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
getRequestTimer() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getRequestTimer() - Method in interface org.apache.solr.request.SolrQueryRequest
The timer for this request, created when the request started being processed
getRequestTimer() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getRequestType() - Method in class org.apache.solr.security.AuditEvent
Determines the type of request.
getRequestType() - Method in class org.apache.solr.security.AuthorizationContext
 
getRequestType() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getRequestTypes() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreaker
 
getRequestUrl() - Method in class org.apache.solr.security.AuditEvent
Deprecated.
Please use AuditEvent.getBaseUrl() instead
getRequiredFields() - Method in class org.apache.solr.schema.IndexSchema
Provides direct access to the List containing all required fields.
getRequiredParam(String, SolrQueryRequest) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
getRequiredParams() - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
getRequiredParams() - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
getRequiredParams() - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
 
getRequiredParams() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getReRankQueryMax() - Method in class org.apache.solr.search.ReRankScaler
 
getReRankQueryMin() - Method in class org.apache.solr.search.ReRankScaler
 
getReRankScale() - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
getReRankScaleExplain() - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
getReRankScalerExplain() - Method in class org.apache.solr.search.ReRankScaler
 
getReRankScaleWeight() - Method in class org.apache.solr.search.ReRankScaler
 
getReserveCommitDuration() - Method in class org.apache.solr.handler.ReplicationHandler
 
getReservedEndpoints() - Method in class org.apache.solr.rest.RestManager.Registry
Returns the set of non-registrable endpoints.
getReservoir() - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultHistogramSupplier
 
getReservoir() - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultTimerSupplier
 
getResolved(String, Cache<String, TemplateUpdateProcessorFactory.Resolved>, Pattern) - Static method in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
getResource() - Method in class org.apache.solr.security.AuditEvent
Identifies the resource being operated on.
getResource() - Method in class org.apache.solr.security.AuthorizationContext
 
getResource() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getResourceId() - Method in class org.apache.solr.rest.ManagedResource
Gets the resource ID for this managed resource.
getResourceId() - Method in class org.apache.solr.rest.schema.analysis.BaseManagedTokenFilterFactory
Let the concrete analysis component decide the path it wishes to be managed at.
getResourceId() - Method in class org.apache.solr.rest.schema.analysis.ManagedStopFilterFactory
This analysis component knows the most logical "path" for which to manage stop words from.
getResourceId() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
 
getResourceId() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
 
getResourceLoader() - Method in class org.apache.solr.core.CoreContainer
 
getResourceLoader() - Method in class org.apache.solr.core.SolrConfig
 
getResourceLoader() - Method in class org.apache.solr.core.SolrCore
The SolrResourceLoader used to load all resources for this core.
getResourceLoader() - Method in class org.apache.solr.core.XmlConfigFile
 
getResourceLoader() - Method in class org.apache.solr.rest.ManagedResource
Returns the resource loader used by this resource.
getResourceLoader() - Method in class org.apache.solr.rest.ManagedResourceStorage
Returns the resource loader used by this storage instance
getResourceLoader() - Method in class org.apache.solr.schema.IndexSchema
The resource loader to be used to load components related to the schema when the schema is loading / initialising.
getResourceLoader() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
getResourceLoader(String) - Method in class org.apache.solr.core.SolrCore
Gets the SolrResourceLoader for a given package
getResourceName() - Method in class org.apache.solr.core.SolrConfig
 
getResourceName() - Method in class org.apache.solr.core.XmlConfigFile
 
getResourceName() - Method in class org.apache.solr.schema.IndexSchema
Gets the name of the resource used to instantiate this schema.
getResponse() - Method in class org.apache.solr.api.PayloadObj
 
getResponse() - Method in class org.apache.solr.cloud.OverseerSolrResponse
 
getResponse() - Method in class org.apache.solr.handler.component.IterativeMergeStrategy.CallBack
 
getResponse() - Method in class org.apache.solr.response.SolrQueryResponse
Return response
getResponse() - Method in class org.apache.solr.search.facet.FacetProcessor
 
getResponseBuilder() - Method in class org.apache.solr.request.SimpleFacets
 
getResponseBuilder() - Method in class org.apache.solr.request.SolrRequestInfo
May return null if the request handler is not based on SearchHandler
getResponseDocs() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getResponseForFragments(List<TextFragment>, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Given the fragments, return the result to be put in the field NamedList.
getResponseFormat() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
getResponseHeader() - Method in class org.apache.solr.response.SolrQueryResponse
Response header to be logged
getResponseWriter() - Method in class org.apache.solr.servlet.HttpSolrCall
Returns QueryResponseWriter to be used.
getResponseWriters() - Method in class org.apache.solr.core.SolrCore
 
getRestManager() - Method in class org.apache.solr.core.SolrCore
 
getResultQuery(SchemaField, boolean) - Method in class org.apache.solr.search.join.GraphPointsCollector
 
getResults() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getReturnFields() - Method in class org.apache.solr.response.BasicResultContext
 
getReturnFields() - Method in class org.apache.solr.response.ResultContext
 
getReturnFields() - Method in class org.apache.solr.response.SolrQueryResponse
Gets the document field names of fields to return by default when returning DocLists
getReversedWildcardFilterFactory(FieldType) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getReverseReader() - Method in class org.apache.solr.update.TransactionLog
Returns a single threaded reverse reader
getRewriteMethod(QParser, SchemaField) - Method in class org.apache.solr.schema.FieldType
Expert: Returns the rewrite method for multiterm queries such as wildcards.
getRole(String) - Static method in enum org.apache.solr.core.NodeRoles.Role
 
getRoleMode(NodeRoles.Role) - Method in class org.apache.solr.core.NodeRoles
 
getRoles() - Method in class org.apache.solr.cloud.CloudDescriptor
 
getRoles() - Method in class org.apache.solr.core.NodeRoles
 
getRoute() - Method in class org.apache.solr.update.UpdateCommand
 
getRoutedAliasType() - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
getRoutedAliasType() - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
getRoutedAliasType() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getRouteField() - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
getRouteField() - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
getRouteField() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getRsp() - Method in class org.apache.solr.request.SolrRequestInfo
 
getRspObject() - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
getRuleExpiryLock() - Method in class org.apache.solr.core.SolrCore
 
getRunningMerges() - Method in class org.apache.solr.update.SolrIndexWriter
 
getSafeContentType(String) - Static method in class org.apache.solr.handler.admin.ShowFileRequestHandler
Checks content type string and returns it if it is one of allowed types.
getSaltedHashedValue(String) - Static method in class org.apache.solr.security.Sha256AuthenticationProvider
 
getSampleValue(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
getSchema() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getSchema() - Method in interface org.apache.solr.request.SolrQueryRequest
The schema snapshot from core.getLatestSchema() at request creation.
getSchema() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getSchema() - Method in class org.apache.solr.rest.BaseSolrResource
 
getSchema() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
getSchema() - Method in class org.apache.solr.search.SolrIndexSearcher
Direct access to the IndexSchema for use with this searcher
GetSchema - Class in org.apache.solr.handler.admin.api
 
GetSchema(SolrCore, IndexSchema) - Constructor for class org.apache.solr.handler.admin.api.GetSchema
 
getSchemaDiff(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
Return the diff of designer schema with the source schema (either previously published or the copyFrom).
getSchemaField() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getSchemaField() - Method in class org.apache.solr.handler.component.StatsField
The SchemaField whose results these stats are computed over, may be null if the stats are computed over the results of a function or query
GetSchemaFieldAPI - Class in org.apache.solr.handler.admin.api
GetSchemaFieldAPI contains the V2 APIs for all field related endpoint which are /fields /fields/{fieldName} /copyfields /dynamicfields /dynamicfields/{fieldName} /fieldtypes /fieldtypes/{fieldTypeName}
GetSchemaFieldAPI(IndexSchema, SolrParams) - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
GetSchemaFieldAPI.SchemaGetDynamicFieldInfoResponse - Class in org.apache.solr.handler.admin.api
 
GetSchemaFieldAPI.SchemaGetFieldInfoResponse - Class in org.apache.solr.handler.admin.api
 
GetSchemaFieldAPI.SchemaGetFieldTypeInfoResponse - Class in org.apache.solr.handler.admin.api
 
GetSchemaFieldAPI.SchemaListCopyFieldsResponse - Class in org.apache.solr.handler.admin.api
 
GetSchemaFieldAPI.SchemaListDynamicFieldsResponse - Class in org.apache.solr.handler.admin.api
 
GetSchemaFieldAPI.SchemaListFieldsResponse - Class in org.apache.solr.handler.admin.api
 
GetSchemaFieldAPI.SchemaListFieldTypesResponse - Class in org.apache.solr.handler.admin.api
 
getSchemaFields() - Method in class org.apache.solr.search.SortSpec
Gets the Solr SchemaFields that correspond to each of the SortFields used in this sort.
getSchemaInfo() - Method in class org.apache.solr.handler.admin.api.GetSchema
 
getSchemaLoader() - Method in class org.apache.solr.core.SolrResourceLoader
 
getSchemaName() - Method in class org.apache.solr.core.CoreDescriptor
 
getSchemaName() - Method in class org.apache.solr.handler.admin.api.GetSchema
 
getSchemaName() - Method in class org.apache.solr.schema.IndexSchema
Gets the name of the schema as specified in the schema resource.
getSchemaResource() - Method in class org.apache.solr.core.SolrCore
Gets the schema resource name used by this core instance.
getSchemaResourceName(String) - Method in class org.apache.solr.schema.IndexSchemaFactory
Returns the resource (file) name that will be used for the schema itself.
getSchemaResourceName(String) - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
getSchemaSimilarity() - Method in class org.apache.solr.handler.admin.api.GetSchema
 
getSchemaUniqueKey() - Method in class org.apache.solr.handler.admin.api.GetSchema
 
getSchemaUpdateLock() - Method in class org.apache.solr.schema.IndexSchema
Returns the schema update lock that should be synchronized on to update the schema.
getSchemaUpdateLock() - Method in class org.apache.solr.schema.ManagedIndexSchema
 
getSchemaUpdateLock() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
getSchemaUpdateLock() - Method in class org.apache.solr.schema.ZkIndexSchemaReader
 
getSchemaVersion() - Method in class org.apache.solr.handler.admin.api.GetSchema
 
getSchemaZkVersion() - Method in class org.apache.solr.schema.ManagedIndexSchema
 
getSchemaZkVersion(Integer) - Method in class org.apache.solr.handler.admin.api.GetSchema
 
getScorer(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
getSearchAfterFieldDoc() - Method in class org.apache.solr.search.CursorMark
Returns a synthetically constructed FieldDoc whose FieldDoc.fields match the values of this object.
getSearchComponent(String) - Method in class org.apache.solr.core.SolrCore
 
getSearchComponents() - Method in class org.apache.solr.core.SolrCore
Accessor for all the Search Components
getSearcher() - Method in class org.apache.solr.core.SolrCore
Return a registered RefCounted<SolrIndexSearcher> with the reference count incremented.
getSearcher() - Method in class org.apache.solr.handler.component.StatsField
The searcher that should be used for processing local stats
getSearcher() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getSearcher() - Method in interface org.apache.solr.request.SolrQueryRequest
The index searcher associated with this request
getSearcher() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getSearcher() - Method in class org.apache.solr.response.BasicResultContext
 
getSearcher() - Method in class org.apache.solr.response.ResultContext
 
getSearcher() - Method in class org.apache.solr.search.facet.FacetContext
 
getSearcher(boolean, boolean, Future<Void>[]) - Method in class org.apache.solr.core.SolrCore
 
getSearcher(boolean, boolean, Future<Void>[], boolean) - Method in class org.apache.solr.core.SolrCore
Get a SolrIndexSearcher or start the process of creating a new one.
getSearchGroups() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommandResult
 
getSecurityConfig(boolean) - Method in class org.apache.solr.handler.admin.SecurityConfHandler
Gets security.json from source
getSecurityConfig(boolean) - Method in class org.apache.solr.handler.admin.SecurityConfHandlerLocal
Fetches security props from SOLR_HOME
getSecurityConfig(boolean) - Method in class org.apache.solr.handler.admin.SecurityConfHandlerZk
Fetches security props from Zookeeper and adds version
getSecurityInfo(SolrQueryRequest) - Method in class org.apache.solr.handler.admin.SystemInfoHandler
Get Security Info
getSeenKeys() - Method in class org.apache.solr.util.MapListener
 
getSegmentCount() - Method in class org.apache.solr.core.SolrCore
 
getSegmentTerminatedEarly() - Method in class org.apache.solr.search.QueryResult
 
getSegmentTerminateEarly() - Method in class org.apache.solr.search.QueryCommand
 
getSelector() - Method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
 
getSelfOrNestedDocIdStr() - Method in class org.apache.solr.update.AddUpdateCommand
Returns the ID of the doc itself, possibly different from AddUpdateCommand.getIndexedIdStr() which points to the root doc.
getSeq(String) - Static method in class org.apache.solr.cloud.LeaderElector
Returns int given String of form n_0000000001 or n_0000000003, etc.
getSerializedTotem() - Method in class org.apache.solr.search.CursorMark
Generates a Base64 encoded serialized representation of the sort values encapsulated by this object, for use in cursor requests.
getSerializer(HLLType, int, int) - Method in interface org.apache.solr.util.hll.ISchemaVersion
Builds an HLL serializer that matches this schema version.
getServerResourceClass() - Method in class org.apache.solr.rest.ManagedResource
Gets the ServerResource class to register this endpoint with the Rest API router; in most cases, the default RestManager.ManagedEndpoint class is sufficient but ManagedResource implementations can override this method if a different ServerResource class is needed.
getServers() - Method in class org.apache.solr.cloud.SolrZkServer
 
getServiceUrl() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Return configured serviceUrl or null.
getSession() - Method in class org.apache.solr.cloud.LockTree
 
getSession() - Method in class org.apache.solr.security.AuditEvent
Session identifier
getSetQuery(QParser, SchemaField, Collection<String>) - Method in class org.apache.solr.schema.DatePointField
 
getSetQuery(QParser, SchemaField, Collection<String>) - Method in class org.apache.solr.schema.DoublePointField
 
getSetQuery(QParser, SchemaField, Collection<String>) - Method in class org.apache.solr.schema.FieldType
 
getSetQuery(QParser, SchemaField, Collection<String>) - Method in class org.apache.solr.schema.FloatPointField
 
getSetQuery(QParser, SchemaField, Collection<String>) - Method in class org.apache.solr.schema.IntPointField
 
getSetQuery(QParser, SchemaField, Collection<String>) - Method in class org.apache.solr.schema.LongPointField
 
getSetQuery(QParser, SchemaField, Collection<String>) - Method in class org.apache.solr.schema.PointField
 
getShard() - Method in interface org.apache.solr.cluster.Replica
 
getShard() - Method in class org.apache.solr.handler.component.ShardResponse
 
getShard(String) - Method in interface org.apache.solr.cluster.SolrCollection
Returns the Shard of the given name for that collection, if such a shard exists.
getShardAddress() - Method in class org.apache.solr.handler.component.ShardResponse
What was the shard address that returned this response.
getShardBackupIdFor(String) - Method in class org.apache.solr.core.backup.BackupProperties
 
getShardBackupMetadataDir() - Method in class org.apache.solr.core.backup.BackupFilePaths
Return a URI for the 'shard_backup_metadata' location, which contains metadata files about each shard backup.
getShardFlag(int) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
getShardFlag(int, int) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
getShardHandler() - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
Get ShardHandler that uses the default http client.
getShardHandler() - Method in class org.apache.solr.handler.component.ShardHandlerFactory
 
getShardHandlerFactory() - Method in class org.apache.solr.core.CoreContainer
The default ShardHandlerFactory used to communicate with other solr instances
getShardHandlerFactory() - Method in class org.apache.solr.handler.component.HttpShardHandler
 
getShardHandlerFactory() - Method in class org.apache.solr.handler.component.ShardHandler
 
getShardHandlerFactoryPluginInfo() - Method in class org.apache.solr.core.NodeConfig
 
getShardId() - Method in class org.apache.solr.cloud.CloudDescriptor
 
getShardId() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
getShardId() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
getShardId() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
getShardMetrics(String) - Method in interface org.apache.solr.cluster.placement.CollectionMetrics
 
getShardMetricsBuilders() - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder
 
getShardName() - Method in interface org.apache.solr.cluster.placement.ReplicaPlacement
 
getShardName() - Method in interface org.apache.solr.cluster.placement.ShardMetrics
 
getShardName() - Method in interface org.apache.solr.cluster.Shard
 
getShardName() - Method in class org.apache.solr.core.backup.ShardBackupId
 
getShardNames() - Method in interface org.apache.solr.cluster.placement.DeleteShardsRequest
 
getShardNames() - Method in class org.apache.solr.cluster.placement.impl.PlacementRequestImpl
 
getShardNames() - Method in interface org.apache.solr.cluster.placement.PlacementRequest
Shard name(s) for which new replicas placement should be computed.
getShardNames() - Method in interface org.apache.solr.cluster.SolrCollection
 
getShardNames(Integer, List<String>) - Static method in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
getShardNames(List<String>, String) - Static method in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
getShardNum(String) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getShardRequest() - Method in class org.apache.solr.handler.component.ShardResponse
 
getShards() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
getShardsOnNode(String) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
getShardTerms() - Method in class org.apache.solr.cloud.ZkShardTerms
 
getShardTerms(String, String) - Method in class org.apache.solr.cloud.ZkController
 
getSharedLibDirectory() - Method in class org.apache.solr.core.NodeConfig
Returns a directory, optionally a comma separated list of directories that will be added to Solr's class path for searching for classes and plugins.
getShift() - Method in interface org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttribute
Deprecated.
Returns current shift value, undefined before first token
getShift() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
getSigFields() - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
getSignature() - Method in class org.apache.solr.update.processor.Lookup3Signature
 
getSignature() - Method in class org.apache.solr.update.processor.MD5Signature
 
getSignature() - Method in class org.apache.solr.update.processor.Signature
 
getSignature() - Method in class org.apache.solr.update.processor.TextProfileSignature
 
getSignatureClass() - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
getSignatureField() - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
getSimilarity() - Method in class org.apache.solr.schema.FieldType
Gets the Similarity used when scoring fields of this type
getSimilarity() - Method in class org.apache.solr.schema.IndexSchema
Returns the Similarity used for this index
getSimilarity() - Method in class org.apache.solr.schema.SimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.BM25SimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.BooleanSimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.ClassicSimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.DFISimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.DFRSimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.IBSimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.LMDirichletSimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.LMJelinekMercerSimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.SchemaSimilarityFactory
 
getSimilarity() - Method in class org.apache.solr.search.similarities.SweetSpotSimilarityFactory
 
getSimilarityFactory() - Method in class org.apache.solr.schema.FieldType
Gets the factory for the Similarity used when scoring fields of this type
getSimilarityFactory() - Method in class org.apache.solr.schema.IndexSchema
Returns the SimilarityFactory that constructed the Similarity for this index
getSimilarityFunction() - Method in class org.apache.solr.schema.DenseVectorField
 
getSimpleString() - Method in class org.apache.solr.search.StrParser
Skips leading whitespace and returns whatever sequence of non whitespace it can find (or hte empty string)
getSingleParamSet(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetConfigAPI
 
getSingletons() - Method in class org.apache.solr.core.ClusterSingletons
Return modifiable registry of name / ClusterSingleton.
getSingleValueSource(SortedNumericSelector.Type, SchemaField) - Method in class org.apache.solr.schema.DatePointField
 
getSingleValueSource(SortedNumericSelector.Type, SchemaField) - Method in class org.apache.solr.schema.DoublePointField
 
getSingleValueSource(SortedNumericSelector.Type, SchemaField) - Method in class org.apache.solr.schema.FloatPointField
 
getSingleValueSource(SortedNumericSelector.Type, SchemaField) - Method in class org.apache.solr.schema.IntPointField
 
getSingleValueSource(SortedNumericSelector.Type, SchemaField) - Method in class org.apache.solr.schema.LongPointField
 
getSingleValueSource(SortedNumericSelector.Type, SchemaField) - Method in class org.apache.solr.schema.PointField
Helper method that will only be called for multivalued Point fields that have doc values.
getSingleValueSource(SortedSetSelector.Type, SchemaField) - Method in class org.apache.solr.schema.TrieDoubleField
Deprecated.
 
getSingleValueSource(SortedSetSelector.Type, SchemaField) - Method in class org.apache.solr.schema.TrieField
Deprecated.
Helper method that will only be called for multivalued Trie fields that have doc values.
getSingleValueSource(SortedSetSelector.Type, SchemaField) - Method in class org.apache.solr.schema.TrieFloatField
Deprecated.
 
getSingleValueSource(SortedSetSelector.Type, SchemaField) - Method in class org.apache.solr.schema.TrieIntField
Deprecated.
 
getSingleValueSource(SortedSetSelector.Type, SchemaField) - Method in class org.apache.solr.schema.TrieLongField
Deprecated.
 
getSingleValueSource(FieldType.MultiValueSelector, SchemaField, QParser) - Method in class org.apache.solr.schema.EnumFieldType
 
getSingleValueSource(FieldType.MultiValueSelector, SchemaField, QParser) - Method in class org.apache.solr.schema.FieldType
Method for dynamically building a ValueSource based on a single value of a multivalued field.
getSingleValueSource(FieldType.MultiValueSelector, SchemaField, QParser) - Method in class org.apache.solr.schema.PointField
 
getSingleValueSource(FieldType.MultiValueSelector, SchemaField, QParser) - Method in class org.apache.solr.schema.SortableTextField
 
getSingleValueSource(FieldType.MultiValueSelector, SchemaField, QParser) - Method in class org.apache.solr.schema.StrField
 
getSingleValueSource(FieldType.MultiValueSelector, SchemaField, QParser) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
getSlop() - Method in class org.apache.solr.search.FieldParams
 
getSlotQuery() - Method in class org.apache.solr.search.facet.SlotAcc.SlotContext
behavior of this method is undefined if SlotAcc.SlotContext.isAllBuckets() returns true
getSlowAtomicReader() - Method in class org.apache.solr.search.SolrIndexSearcher
Not recommended to call this method unless there is some particular reason due to internally calling SlowCompositeReaderWrapper.
getSmallTerms(int, UnInvertedField.Callback) - Method in class org.apache.solr.search.facet.UnInvertedField.DocToTerm
 
getSnapshot() - Method in class org.apache.solr.metrics.DelegateRegistryHistogram
 
getSnapshot() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
getSnapshot(BiConsumer<String, Object>) - Method in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
getSnapshotMetaData(String) - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
This method returns the snapshot meta-data for the specified name (if it exists).
getSnapshotMetaDataManager() - Method in class org.apache.solr.core.SolrCore
 
getSnapshotsDir() - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
 
getSnapshotSize() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
getSocketTimeout() - Method in class org.apache.solr.update.UpdateShardHandler
 
getSoftCommitTracker() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
getSolrClassLoader() - Method in class org.apache.solr.schema.IndexSchema
 
getSolrClient(String) - Static method in class org.apache.solr.cli.SolrCLI
 
getSolrClient(SolrCmdDistributor.Req) - Method in class org.apache.solr.update.StreamingSolrClients
 
getSolrClientCache() - Method in class org.apache.solr.core.CoreContainer
 
getSolrCloudManager() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
getSolrCloudManager() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
getSolrCloudManager() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getSolrCloudManager() - Method in class org.apache.solr.cloud.Overseer
 
getSolrCloudManager() - Method in class org.apache.solr.cloud.ZkConfigSetService
 
getSolrCloudManager() - Method in class org.apache.solr.cloud.ZkController
 
getSolrConfig() - Method in class org.apache.solr.core.ConfigSet
 
getSolrConfig() - Method in class org.apache.solr.core.SolrCore
Gets the configuration object used by this core instance.
getSolrConfig() - Method in class org.apache.solr.core.SolrResourceLoader
 
getSolrCore() - Method in class org.apache.solr.rest.BaseSolrResource
 
getSolrCoreNames() - Method in class org.apache.solr.cloud.ActiveReplicaWatcher
Return a list of SolrCore names that are not active yet (or unverified).
getSolrCoreState() - Method in class org.apache.solr.core.SolrCore
 
getSolrCoreState() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
getSolrCoreState() - Method in class org.apache.solr.update.UpdateHandler
 
getSolrDataHome() - Method in class org.apache.solr.core.NodeConfig
Absolute.
getSolrFragmentsBuilder(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
 
getSolrHome() - Method in class org.apache.solr.core.CoreContainer
The primary path of a Solr server's config, cores, and misc things.
getSolrHome() - Method in class org.apache.solr.core.NodeConfig
 
getSolrHost() - Method in class org.apache.solr.security.AuditEvent
Host name of the Solr node logging the event
getSolrHostContext() - Method in class org.apache.solr.core.CloudConfig
 
getSolrHostPort() - Method in class org.apache.solr.core.CloudConfig
 
getSolrInputDocument() - Method in class org.apache.solr.update.AddUpdateCommand
 
getSolrInstallDir() - Static method in class org.apache.solr.core.NodeConfig
Obtain the path of solr's binary installation directory, e.g.
getSolrIp() - Method in class org.apache.solr.security.AuditEvent
IP address of the Solr node logging the event
getSolrMetricsContext() - Method in class org.apache.solr.core.SolrCore
 
getSolrMetricsContext() - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
getSolrMetricsContext() - Method in class org.apache.solr.handler.component.SearchComponent
 
getSolrMetricsContext() - Method in class org.apache.solr.handler.RequestHandlerBase
 
getSolrMetricsContext() - Method in class org.apache.solr.highlight.HighlightingPluginBase
 
getSolrMetricsContext() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
 
getSolrMetricsContext() - Method in interface org.apache.solr.metrics.SolrMetricProducer
Implementations should return the context used in SolrMetricProducer.initializeMetrics(SolrMetricsContext, String) to ensure proper cleanup of metrics at the end of the life-cycle of this component.
getSolrMetricsContext() - Method in class org.apache.solr.search.CaffeineCache
 
getSolrMetricsContext() - Method in class org.apache.solr.search.QParserPlugin
 
getSolrMetricsContext() - Method in class org.apache.solr.search.SolrFieldCacheBean
 
getSolrMetricsContext() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getSolrMetricsContext() - Method in class org.apache.solr.security.AuditLoggerPlugin
 
getSolrMetricsContext() - Method in class org.apache.solr.security.AuthenticationPlugin
 
getSolrMetricsContext() - Method in class org.apache.solr.update.PeerSync
 
getSolrMetricsContext() - Method in class org.apache.solr.update.PeerSyncWithLeader
 
getSolrMetricsContext() - Method in class org.apache.solr.update.UpdateHandler
 
getSolrMetricsContext() - Method in class org.apache.solr.update.UpdateLog
 
getSolrMetricsContext() - Method in class org.apache.solr.update.UpdateShardHandler
 
getSolrMetricsContext() - Method in class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
getSolrMetricsContext() - Method in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
getSolrMetricsContext() - Method in class org.apache.solr.util.stats.InstrumentedPoolingHttpClientConnectionManager
 
getSolrParamAsString(String) - Method in class org.apache.solr.security.AuditEvent
Gets first value of a certain Solr request parameter
getSolrParams() - Method in class org.apache.solr.security.AuditEvent
Map of all Solr request parameters attached to the request.
getSolrParamsFromNamedList(NamedList<?>, String) - Static method in class org.apache.solr.handler.RequestHandlerBase
 
getSolrParamsFromUri(URI) - Static method in class org.apache.solr.cli.ApiTool
 
getSolrPort() - Method in class org.apache.solr.security.AuditEvent
Port number of the Solr node logging the event
getSolrProperties() - Method in class org.apache.solr.core.NodeConfig
 
getSolrRequest() - Method in class org.apache.solr.rest.BaseSolrResource
 
getSolrResourceLoader() - Method in class org.apache.solr.core.NodeConfig
 
getSolrResourceLoader() - Method in class org.apache.solr.handler.SolrDefaultStreamFactory
 
getSolrResponse() - Method in class org.apache.solr.handler.component.ShardResponse
 
getSolrResponse() - Method in class org.apache.solr.rest.BaseSolrResource
 
getSolrUrlFromUri(URI) - Static method in class org.apache.solr.cli.ApiTool
Get Solr base url with port if present and root from URI
getSort() - Method in class org.apache.solr.index.SortingMergePolicy
Return the Sort order that is used to sort segments when merging.
getSort() - Method in class org.apache.solr.search.QueryCommand
 
getSort() - Method in class org.apache.solr.search.SortSpec
Gets the Lucene Sort object, or null for the default sort by score descending.
getSort(SolrQueryRequest) - Static method in class org.apache.solr.util.SolrPluginUtils
Determines the correct Sort based on the request parameter "sort"
getSortDirection() - Method in class org.apache.solr.search.StrParser
Sort direction or null if current position does not indicate a sort direction.
getSortedDocValues(int, LeafReader, int) - Method in class org.apache.solr.search.DocValuesIteratorCache.FieldDocValuesSupplier
Returns docValues for the specified doc id in the specified reader, if the specified doc holds docValues for this DocValuesIteratorCache.FieldDocValuesSupplier instance, otherwise returns null.
getSortedDocValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getSortedDocValues(String) - Method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
 
getSortedDocValues(String) - Method in class org.apache.solr.uninverting.UninvertingReader
 
getSortedDocValues(QueryContext, SchemaField, QParser) - Static method in class org.apache.solr.search.facet.FieldUtil
 
getSortedDocValues(SolrIndexSearcher, String) - Static method in class org.apache.solr.search.facet.FieldUtil
Simpler method that creates a request context and looks up the field for you
getSortedElectionNodes(SolrZkClient, String) - Static method in class org.apache.solr.cloud.OverseerTaskProcessor
 
getSortedNumericDocValues(int, LeafReader, int) - Method in class org.apache.solr.search.DocValuesIteratorCache.FieldDocValuesSupplier
Returns docValues for the specified doc id in the specified reader, if the specified doc holds docValues for this DocValuesIteratorCache.FieldDocValuesSupplier instance, otherwise returns null.
getSortedNumericDocValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getSortedNumericSelectorType() - Method in enum org.apache.solr.schema.FieldType.MultiValueSelector
The appropriate SortedNumericSelector.Type option for this MultiValueSelector, may be null if there is no equivalent
getSortedNumericSortField(SchemaField, SortField.Type, SortedNumericSelector.Type, boolean, Object, Object) - Static method in class org.apache.solr.schema.FieldType
getSortedOverseerNodeNames(SolrZkClient) - Static method in class org.apache.solr.cloud.OverseerTaskProcessor
 
getSortedReader(long) - Method in class org.apache.solr.update.TransactionLog
 
getSortedSetDocValues(int, LeafReader, int) - Method in class org.apache.solr.search.DocValuesIteratorCache.FieldDocValuesSupplier
Returns docValues for the specified doc id in the specified reader, if the specified doc holds docValues for this DocValuesIteratorCache.FieldDocValuesSupplier instance, otherwise returns null.
getSortedSetDocValues(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getSortedSetDocValues(String) - Method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
 
getSortedSetDocValues(String) - Method in class org.apache.solr.uninverting.UninvertingReader
 
getSortedSetDocValues(QueryContext, SchemaField, QParser) - Static method in class org.apache.solr.search.facet.FieldUtil
 
getSortedSetSelectorType() - Method in enum org.apache.solr.schema.FieldType.MultiValueSelector
The appropriate SortedSetSelector.Type option for this MultiValueSelector , may be null if there is no equivalent
getSortedSetSortField(SchemaField, SortedSetSelector.Type, boolean, Object, Object) - Static method in class org.apache.solr.schema.FieldType
getSortField(boolean) - Method in class org.apache.solr.schema.SchemaField
Delegates to the FieldType for this field
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.AbstractEnumField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.BinaryField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.BoolField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.CollationField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.CurrencyFieldType
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.DenseVectorField
Not Supported
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.EnumFieldType
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.ExternalFileField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.FieldType
Returns the SortField instance that should be used to sort fields of this type.
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.PointField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.PointType
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.PreAnalyzedField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.RandomSortField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.RankField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.SortableTextField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.StrField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.TextField
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
getSortField(SchemaField, boolean) - Method in class org.apache.solr.schema.UUIDField
 
getSortField(SchemaField, SortField.Type, boolean, Object, Object) - Static method in class org.apache.solr.schema.FieldType
A Helper utility method for use by subclasses.
getSortSpec() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getSortSpec() - Method in class org.apache.solr.search.CursorMark
Returns the SortSpec used by this object.
getSortSpec(boolean) - Method in class org.apache.solr.search.QParser
 
getSortValues() - Method in class org.apache.solr.search.CursorMark
Returns a copy of the (raw, unmarshalled) sort values used by this object, or null if first page of docs should be returned (ie: no sort after)
getSource() - Method in class org.apache.solr.handler.designer.SampleDocuments
 
getSource() - Method in class org.apache.solr.handler.GraphHandler
 
getSource() - Method in class org.apache.solr.handler.StreamHandler
 
getSource() - Method in class org.apache.solr.schema.CopyField
 
getSourceDynamicBase() - Method in class org.apache.solr.schema.IndexSchema.DynamicCopy
 
getSourceLocation() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getSourceSelector() - Method in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
getSpan() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getSpan() - Method in interface org.apache.solr.request.SolrQueryRequest
The distributed tracing Span for the request itself; never null.
getSpan() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getSpan() - Method in class org.apache.solr.servlet.HttpSolrCall
Get the span for this request.
getSpanQueryScorer(Query, String, TokenStream, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return a QueryScorer suitable for this Query and field.
getSpatialContext() - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getSpec() - Method in class org.apache.solr.api.Api
Get the specification of the API as a Map
getSpec() - Method in class org.apache.solr.api.V2HttpCall
 
getSpec() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getSpec() - Method in class org.apache.solr.security.BasicAuthPlugin
 
getSpec() - Method in class org.apache.solr.security.MultiAuthPlugin
 
getSpec() - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
 
getSpec() - Method in class org.apache.solr.security.Sha256AuthenticationProvider
 
getSpec() - Method in class org.apache.solr.servlet.HttpSolrCall
 
getSpecializedExistenceQuery(QParser, SchemaField) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getSpecializedExistenceQuery(QParser, SchemaField) - Method in class org.apache.solr.schema.FieldType
Returns a Query instance for doing existence searches for a field without certain options, such as docValues or norms.
getSpecializedExistenceQuery(QParser, SchemaField) - Method in class org.apache.solr.schema.NumericFieldType
Override the default existence behavior, so that the non-docValued/norms implementation matches NaN values for double and float fields.
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.CollationField
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.CurrencyFieldType
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.DateRangeField
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.EnumFieldType
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.FieldType
Returns a Query instance for doing range searches on this field type.
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.PointField
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.PointType
Care should be taken in calling this with higher order dimensions for performance reasons.
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.RankField
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.TextField
 
getSpecializedRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
getSpellChecker() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getSpellChecker(String) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
getSpellChecker(SolrParams) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
getSpellCheckers() - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
getSphereRadius() - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getSphereRadius() - Method in class org.apache.solr.schema.PointType
 
getSphereRadius() - Method in interface org.apache.solr.schema.SpatialQueryable
 
getSplitOnWhitespace() - Method in class org.apache.solr.parser.QueryParser
 
getStart() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getStartingRecoveryDelayMilliSeconds() - Method in class org.apache.solr.cloud.RecoveryStrategy
 
getStartingVersions() - Method in class org.apache.solr.update.UpdateLog
 
getStartNanoTime() - Method in class org.apache.solr.core.SolrCore
 
getStartObj() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
getStartOffset() - Method in class org.apache.solr.handler.tagger.TagLL
 
getStartTime() - Method in class org.apache.solr.core.backup.BackupProperties
 
getStartTime() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getStartTime() - Method in interface org.apache.solr.request.SolrQueryRequest
The start time of this request in milliseconds.
getStartTime() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getStartTimeStamp() - Method in class org.apache.solr.core.SolrCore
 
getStat() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader.ZkByteArrayInputStream
 
getState() - Method in interface org.apache.solr.cloud.ClusterSingleton
Returns the current state of the component.
getState() - Method in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
getState() - Method in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
getState() - Method in interface org.apache.solr.cluster.Replica
 
getState() - Method in interface org.apache.solr.cluster.Shard
 
getState() - Method in interface org.apache.solr.search.SolrCache
Returns the last State set on this instance
getState() - Method in class org.apache.solr.search.SolrCacheBase
 
getState() - Method in class org.apache.solr.update.UpdateLog
 
getStateCompressorClass() - Method in class org.apache.solr.core.CloudConfig
 
getStats() - Method in class org.apache.solr.cloud.Overseer
Stop ClusterSingleton plugins when we lose leadership.
getStats() - Method in class org.apache.solr.cloud.Stats
 
getStats() - Method in class org.apache.solr.cloud.ZkDistributedQueue
 
getStats() - Method in class org.apache.solr.util.ConcurrentLRUCache
 
getStats(NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
 
getStatsCache() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getStatsValues() - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
getStatsValues() - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
getStatsValues() - Method in interface org.apache.solr.handler.component.StatsValues
Translates the values into a NamedList representation
getStatus() - Method in class org.apache.solr.core.CoreContainer
 
getStatus() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
getStatus() - Method in class org.apache.solr.security.AuditEvent
HTTP status code of event, i.e.
getStatus(String) - Method in class org.apache.solr.cli.StatusTool
 
getStatus(String) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Gets a custom status for the given core name.
getStatus(String) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
getStatusCode() - Method in class org.apache.solr.security.AuthorizationUtils.AuthorizationFailure
 
getStatusOfAllCores(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.AllCoresStatusAPI
 
getStatusOfSingleCore(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.SingleCoreStatusAPI
 
getStdDev() - Method in class org.apache.solr.metrics.AggregateMetric
 
getStdDev() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
getStdDev() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
getStorageIO() - Method in class org.apache.solr.rest.ManagedResourceStorage
Returns the storageIO instance used by this storage instance
getStoredField(SchemaField, Object) - Method in class org.apache.solr.schema.DatePointField
 
getStoredField(SchemaField, Object) - Method in class org.apache.solr.schema.DoublePointField
 
getStoredField(SchemaField, Object) - Method in class org.apache.solr.schema.FloatPointField
 
getStoredField(SchemaField, Object) - Method in class org.apache.solr.schema.IntPointField
 
getStoredField(SchemaField, Object) - Method in class org.apache.solr.schema.LongPointField
 
getStoredField(SchemaField, Object) - Method in class org.apache.solr.schema.PointField
 
getStoredHighlightFieldNames() - Method in class org.apache.solr.search.SolrDocumentFetcher
Returns a collection of the names of all stored fields which can be highlighted the index reader knows about.
getStoredResourceId(String) - Method in class org.apache.solr.rest.ManagedResourceStorage
Gets the unique identifier for a stored resource, typically based on the resourceId and some storage-specific information, such as file extension and storage root directory.
getStoredResourceId(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.JsonStorage
Determines the relative path (from the storage root) for the given resource.
getStoredValue(Shape, String) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
getStoredValue(Shape, String) - Method in class org.apache.solr.schema.DateRangeField
 
getStoredView() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
Returns a Map of how we store and load data managed by this resource, which is different than how it is managed at runtime in order to support the ignoreCase setting.
getStoredView() - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
Returns a Map of how we store and load data managed by this resource, which is different than how it is managed at runtime in order to support the ignoreCase setting.
getStoreFile() - Method in class org.apache.solr.spelling.suggest.SolrSuggester
 
getStrategy() - Method in class org.apache.solr.internal.csv.CSVParser
Obtain the specified CSV Strategy.
getStrategy(String) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
Gets the cached strategy for this field, creating it if necessary via AbstractSpatialFieldType.newSpatialStrategy(String).
getStreamer(Consumer<SolrDocument>) - Static method in class org.apache.solr.cli.ExportTool.Info
 
getStreamSort() - Method in class org.apache.solr.handler.CatStream
 
getStreamSort() - Method in class org.apache.solr.handler.ClassifyStream
 
getStreamSort() - Method in class org.apache.solr.handler.export.ExportWriterStream
 
getStreamSort() - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
getStreamSort() - Method in class org.apache.solr.handler.GraphHandler.TimerStream
 
getStreamSort() - Method in class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
getStreamSort() - Method in class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
getStreamSort() - Method in class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
getStreamSort() - Method in class org.apache.solr.handler.StreamHandler.TimerStream
 
getString() - Method in class org.apache.solr.search.QParser
 
getStringDistance() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getStringDistance() - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
getStringDistance() - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
getStringDistance() - Method in class org.apache.solr.spelling.SolrSpellChecker
Get the distance implementation used by this spellchecker, or NULL if not applicable.
getStringIdentifier() - Method in class org.apache.solr.util.DistanceUnits
 
getStringSort(SchemaField, boolean) - Method in class org.apache.solr.schema.FieldType
Utility usable by subclasses when they want to get basic String sorting using common checks.
getStyle(String) - Static method in class org.apache.solr.response.transform.ExplainAugmenterFactory
 
getStyle(String) - Static method in enum org.apache.solr.response.transform.ShardAugmenterFactory.Style
 
getSubFacets() - Method in class org.apache.solr.search.facet.FacetRequest
 
getSubHandler(String) - Method in class org.apache.solr.handler.admin.InfoHandler
 
getSubHandler(String) - Method in class org.apache.solr.handler.BlobHandler
 
getSubHandler(String) - Method in class org.apache.solr.handler.component.ActiveTasksListHandler
 
getSubHandler(String) - Method in class org.apache.solr.handler.component.QueryCancellationHandler
 
getSubHandler(String) - Method in class org.apache.solr.handler.DumpRequestHandler
 
getSubHandler(String) - Method in interface org.apache.solr.handler.NestedRequestHandler
Return a RequestHandler to handle a subpath from the path this handler is registered.
getSubHandler(String) - Method in class org.apache.solr.handler.RequestHandlerBase
 
getSubHandler(String) - Method in class org.apache.solr.handler.SchemaHandler
 
getSubHandler(String) - Method in class org.apache.solr.handler.SolrConfigHandler
 
getSubsectionFromShardResponse(ResponseBuilder, ShardResponse, String, boolean) - Static method in class org.apache.solr.util.SolrResponseUtil
 
getSubSequence() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
The characters from the original input that corrispond with this Phrase
getSubsetCount() - Method in class org.apache.solr.handler.component.QueryElevationComponent.TrieSubsetMatcher
Gets the number of subsets in this matcher.
getSubShardLeaders(DocCollection, String, String, SolrInputDocument) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
For CollectionParams.CollectionAction.SPLITSHARD
getSubstitutableProperties() - Method in class org.apache.solr.core.CoreDescriptor
Returns all substitutable properties defined on this CoreDescriptor
getSubstituteProperties() - Method in class org.apache.solr.core.SolrConfig
 
getSubstituteProperties() - Method in class org.apache.solr.core.XmlConfigFile
Returns non-null props to substitute.
getSubsWithPartial(FacetRequest) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
getSubsWithRefinement(FacetRequest) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
getSubType() - Method in class org.apache.solr.schema.AbstractSubTypeFieldType
 
getSuccessCount(String) - Method in class org.apache.solr.cloud.Stats
 
getSuccessful() - Method in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
getSuffixChar() - Method in enum org.apache.solr.cluster.Replica.ReplicaType
 
getSuffixedNameForAutoGeneratedConfigSet(String) - Static method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
getSuggesterNames() - Method in class org.apache.solr.spelling.suggest.SuggesterResult
Get the set of suggesterNames for which this instance holds results
getSuggestions() - Method in class org.apache.solr.spelling.SpellingResult
All the suggestions.
getSuggestions(SpellingOptions) - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
getSuggestions(SpellingOptions) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
getSuggestions(SpellingOptions) - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
getSuggestions(SpellingOptions) - Method in class org.apache.solr.spelling.SolrSpellChecker
Get suggestions for the given query.
getSuggestions(SpellingOptions) - Method in class org.apache.solr.spelling.suggest.Suggester
 
getSuggestions(SpellingOptions) - Method in class org.apache.solr.spelling.WordBreakSolrSpellChecker
 
getSuggestions(SuggesterOptions) - Method in class org.apache.solr.spelling.suggest.SolrSuggester
Returns suggestions based on the SuggesterOptions passed
getSum() - Method in class org.apache.solr.metrics.AggregateMetric
 
getSummary() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
getSupersetMaxDoc() - Method in class org.apache.solr.search.QueryCommand
 
getSupplier(String) - Method in class org.apache.solr.search.DocValuesIteratorCache
 
getSupportedEventTypes() - Method in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
getSupportedEventTypes() - Method in class org.apache.solr.cluster.events.impl.ClusterEventProducerFactory
 
getSupportedEventTypes() - Method in class org.apache.solr.cluster.events.impl.DefaultClusterEventProducer
 
getSupportedEventTypes() - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
getSupportedEventTypes() - Method in class org.apache.solr.cluster.events.NoOpProducer
 
getSupportedMediaType() - Method in class org.apache.solr.jersey.MessageBodyWriters.BaseMessageBodyWriter
 
getSupportedMediaType() - Method in class org.apache.solr.jersey.MessageBodyWriters.CsvMessageBodyWriter
 
getSupportedMediaType() - Method in class org.apache.solr.jersey.MessageBodyWriters.JavabinMessageBodyWriter
 
getSupportedMediaType() - Method in class org.apache.solr.jersey.MessageBodyWriters.RawMessageBodyWriter
 
getSupportedMediaType() - Method in class org.apache.solr.jersey.MessageBodyWriters.XmlMessageBodyWriter
 
getSupportedScoreModes() - Method in class org.apache.solr.schema.AbstractSpatialFieldType
The set of values supported for the score local-param.
getSupportedUnits() - Static method in class org.apache.solr.util.DistanceUnits
 
getSyncLevel(String) - Static method in enum org.apache.solr.update.UpdateLog.SyncLevel
 
getSynonymQueryStyle() - Method in class org.apache.solr.parser.SolrQueryParserBase
Gets how overlapping query terms should be scored
getSynonymQueryStyle() - Method in class org.apache.solr.schema.TextField
 
getSyntheticCollectionName(String) - Static method in class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
getSysPropsCacher() - Method in class org.apache.solr.cloud.ZkController
 
getSystemInfo() - Static method in class org.apache.solr.handler.admin.SystemInfoHandler
Get system info
getSystemInfoHandler() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getSystemInformation(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.NodeHealthAPI
 
getSystemInformation(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.NodeSystemInfoAPI
 
getSystemProperty(Node, String) - Method in interface org.apache.solr.cluster.placement.AttributeValues
For the given node: system property value (system properties are passed to Java using -Dname=value
getSystemProperty(Node, String) - Method in class org.apache.solr.cluster.placement.impl.AttributeValuesImpl
 
getSystemPropertySnitchTag(String) - Static method in class org.apache.solr.cluster.placement.impl.AttributeFetcherImpl
 
getTag() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Return a tag specific to this instance.
getTag() - Method in class org.apache.solr.metrics.SolrMetricManager.GaugeWrapper
 
getTag() - Method in class org.apache.solr.metrics.SolrMetricsContext
Metrics tag that represents objects with the same life-cycle.
getTagCleanLower() - Method in class org.apache.solr.core.SolrConfig.SolrPluginInfo
 
getTaggedQueries(SolrQueryRequest, Collection<String>) - Static method in class org.apache.solr.search.QueryUtils
Returns a Set containing all of the Queries in the designated SolrQueryRequest possessing a tag in the provided list of desired tags.
getTagList() - Method in class org.apache.solr.handler.component.StatsField
 
getTags() - Method in class org.apache.solr.handler.component.FacetComponent.FacetBase
 
getTailId() - Method in class org.apache.solr.cloud.OverseerTaskQueue
Gets last element of the Queue without removing it.
getTargetField(String) - Method in class org.apache.solr.schema.IndexSchema.DynamicCopy
Generates a destination field name based on this source pattern, by substituting the remainder of this source pattern into the the given destination pattern.
getTargetNodes() - Method in class org.apache.solr.cluster.placement.impl.PlacementRequestImpl
 
getTargetNodes() - Method in interface org.apache.solr.cluster.placement.PlacementRequest
Replicas should only be placed on nodes in the set returned by this method.
getTaskKey(ZkNodeProps) - Method in class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
 
getTaskKey(ZkNodeProps) - Method in class org.apache.solr.cloud.OverseerConfigSetMessageHandler
 
getTaskKey(ZkNodeProps) - Method in interface org.apache.solr.cloud.OverseerMessageHandler
 
getTaskStatusCheckUUID() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getTdigestCompression() - Method in class org.apache.solr.handler.component.StatsField
 
getTempDir() - Static method in class org.apache.solr.spelling.suggest.LookupFactory
 
getTerm(String) - Method in class org.apache.solr.cloud.ZkShardTerms
 
getTermCount() - Method in class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
getTermCounts(String, SimpleFacets.ParsedParams) - Method in class org.apache.solr.request.SimpleFacets
Term counts for use in field faceting that resepects the appropriate mincount
getTermCountsForPivots(String, SimpleFacets.ParsedParams) - Method in class org.apache.solr.request.SimpleFacets
Term counts for use in pivot faceting that resepcts the appropriate mincount
getTerminateEarly() - Method in class org.apache.solr.search.QueryCommand
 
getTerms(LeafReader, String) - Method in interface org.apache.solr.uninverting.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the term values in field and returns a BinaryDocValues instance, providing a method to retrieve the term (as a BytesRef) per document.
getTerms(LeafReader, String) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getTerms(LeafReader, String, float) - Method in interface org.apache.solr.uninverting.FieldCache
Expert: just like FieldCache.getTerms(org.apache.lucene.index.LeafReader,String), but you can specify whether more RAM should be consumed in exchange for faster lookups (default is "true").
getTerms(LeafReader, String, float) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getTermsEnum() - Method in class org.apache.solr.search.facet.UnInvertedField.DocToTerm
 
getTermsEnum(LeafReaderContext) - Method in class org.apache.solr.query.SolrRangeQuery
 
getTermsEnum(Terms, AttributeSource) - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
 
getTermsIndex(LeafReader, String) - Method in interface org.apache.solr.uninverting.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the term values in field and returns a SortedDocValues instance, providing methods to retrieve sort ordinals and terms (as a ByteRef) per document.
getTermsIndex(LeafReader, String) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getTermsIndex(LeafReader, String, float) - Method in interface org.apache.solr.uninverting.FieldCache
Expert: just like FieldCache.getTermsIndex(org.apache.lucene.index.LeafReader,String), but you can specify whether more RAM should be consumed in exchange for faster lookups (default is "true").
getTermsIndex(LeafReader, String, float) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
getTermsToMatch() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
 
getTermVectors(int) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
getThread() - Method in class org.apache.solr.cloud.Overseer.OverseerThread
 
getThreadCount() - Method in class org.apache.solr.handler.component.FacetComponent.FacetBase
 
getThreadDumpHandler() - Method in class org.apache.solr.handler.admin.InfoHandler
 
getThreshold() - Method in class org.apache.solr.logging.jul.JulWatcher
 
getThreshold() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
getThreshold() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher.Log4j2Appender
 
getThreshold() - Method in class org.apache.solr.logging.LogWatcher
 
getThreshold() - Method in class org.apache.solr.spelling.IndexBasedSpellChecker
 
getTiebreaker() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
getTime() - Method in class org.apache.solr.util.RTimer
Get total elapsed time for this timer.
getTimeAllowed() - Method in class org.apache.solr.search.QueryCommand
 
getTimeoutAtNs() - Static method in class org.apache.solr.search.SolrQueryTimeoutImpl
The time (nanoseconds) at which the request should be considered timed out.
getTimer() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
getTimerName(String) - Method in class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
 
getTimerName(String) - Method in class org.apache.solr.cloud.OverseerConfigSetMessageHandler
 
getTimerName(String) - Method in interface org.apache.solr.cloud.OverseerMessageHandler
 
getTimerSupplier() - Method in class org.apache.solr.core.MetricsConfig
 
getTimerSupplier() - Method in class org.apache.solr.metrics.SolrMetricManager
 
getTimestamp() - Method in interface org.apache.solr.cluster.events.ClusterEvent
Get event timestamp.
getTimeStamp() - Method in interface org.apache.solr.filestore.FileStore.FileDetails
 
getTimeUpperBound() - Method in class org.apache.solr.update.CommitTracker
 
getTimeZone() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
getTimeZone() - Method in class org.apache.solr.util.DateMathParser
 
getTimeZone(String) - Static method in class org.apache.solr.util.TimeZoneUtils
This method is provided as a replacement for TimeZone.getTimeZone but without the annoying behavior of returning "GMT" for gibberish input.
getTlogDir(SolrCore, PluginInfo) - Method in class org.apache.solr.update.UpdateLog
 
getToField() - Method in class org.apache.solr.search.join.GraphQuery
 
getToken(int) - Method in class org.apache.solr.parser.QueryParser
Get the specific Token.
getTokenFilterFactories() - Method in class org.apache.solr.analysis.TokenizerChain
 
getTokenFrequency() - Method in class org.apache.solr.spelling.SpellingResult
 
getTokenFrequency(Token) - Method in class org.apache.solr.spelling.SpellingResult
The token frequency of the input token in the collection
getTokenizerFactory() - Method in class org.apache.solr.analysis.TokenizerChain
 
getTokens() - Method in class org.apache.solr.spelling.SpellingResult
 
getTokens(String) - Method in class org.apache.solr.spelling.suggest.SuggesterResult
Get the set of tokens that are present in the instance
getToLog() - Method in class org.apache.solr.response.SolrQueryResponse
Get loggable items.
getToLogAsString() - Method in class org.apache.solr.response.SolrQueryResponse
 
getToLogAsString(String) - Method in class org.apache.solr.response.SolrQueryResponse
Returns a string of the form "prefix name1=value1 name2=value2 ..."
getToolOptions(Tool) - Static method in class org.apache.solr.cli.SolrCLI
 
getTopDocs() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommandResult
 
getTopDocsCollector(int, QueryCommand, IndexSearcher) - Method in class org.apache.solr.search.AbstractReRankQuery
 
getTopDocsCollector(int, QueryCommand, IndexSearcher) - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
getTopDocsCollector(int, QueryCommand, IndexSearcher) - Method in class org.apache.solr.search.RankQuery
 
getTopFieldCacheReader(SolrIndexSearcher, String) - Static method in class org.apache.solr.search.CollapsingQParserPlugin
This forces the use of the top level field cache for String fields.
getTotalHitCount() - Method in class org.apache.solr.search.grouping.CommandHandler
 
getTotalHits() - Method in class org.apache.solr.search.ReRankCollector
 
getTotalLogsNumber() - Method in class org.apache.solr.update.UpdateLog
 
getTotalLogsSize() - Method in class org.apache.solr.update.UpdateLog
 
getTotalScore() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns the overall score for this Phrase.
getTotalSize() - Method in class org.apache.solr.core.backup.AggregateBackupStats
 
getTraceId() - Static method in class org.apache.solr.logging.MDCLoggingContext
 
getTracer() - Method in class org.apache.solr.core.CoreContainer
Never null but may implement NoopTracer.
getTracer() - Method in class org.apache.solr.core.TracerConfigurator
 
getTracer() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getTracer() - Method in interface org.apache.solr.request.SolrQueryRequest
Distributed tracing Tracer.
getTracer() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getTracer() - Method in class org.apache.solr.update.UpdateCommand
Distributed tracing Tracer.
getTracerConfiguratorPluginInfo() - Method in class org.apache.solr.core.NodeConfig
 
getTragicException() - Method in class org.apache.solr.update.SolrCoreState
 
getTrainingClassField() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getTrainingFilterQuery() - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
getTransformer() - Method in class org.apache.solr.search.ReturnFields
Returns the DocTransformer used to modify documents, or null
getTransformer() - Method in class org.apache.solr.search.SolrReturnFields
 
getTransformer(int) - Method in class org.apache.solr.response.transform.DocTransformers
 
getTransformerFactory(String) - Method in class org.apache.solr.core.SolrCore
 
getTransientCacheSize() - Method in class org.apache.solr.core.NodeConfig
 
getTransientDescriptor(String) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Gets the CoreDescriptor for a transient core (loaded or unloaded).
getTransientDescriptor(String) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
getTransientDescriptors() - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Gets the CoreDescriptor for all transient cores (loaded and unloaded).
getTransientDescriptors() - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
getTraversalFilter() - Method in class org.apache.solr.search.join.GraphQuery
 
getTrimmedPivotsAsListOfNamedLists() - Method in class org.apache.solr.handler.component.PivotFacet
A recursive method for generating NamedLists for this pivot suitable for including in a pivot facet response to the original distributed request.
getTrustedKeys(SolrZkClient, String) - Static method in class org.apache.solr.cloud.CloudUtil
Read the list of public keys from ZK
getTrustStorePassword() - Method in class org.apache.solr.util.configuration.SSLConfigurations
 
getTTF(String) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Returns the number of total TTF of this (indexed) Phrase as term in the specified field.
getType() - Method in interface org.apache.solr.cluster.events.ClusterEvent
Get event type.
getType() - Method in interface org.apache.solr.cluster.events.ClusterPropertiesChangedEvent
 
getType() - Method in interface org.apache.solr.cluster.events.CollectionsAddedEvent
 
getType() - Method in interface org.apache.solr.cluster.events.CollectionsRemovedEvent
 
getType() - Method in interface org.apache.solr.cluster.events.NodesDownEvent
 
getType() - Method in interface org.apache.solr.cluster.events.NodesUpEvent
 
getType() - Method in interface org.apache.solr.cluster.Replica
 
getType() - Method in class org.apache.solr.handler.component.FacetComponent.FacetBase
 
getType() - Method in class org.apache.solr.schema.SchemaField
 
getType() - Method in class org.apache.solr.util.hll.HLL
 
getType(String, boolean) - Method in class org.apache.solr.filestore.DistribFileStore
 
getType(String, boolean) - Method in interface org.apache.solr.filestore.FileStore
The type of the resource
getTypedErrorInfo(Throwable, Logger) - Static method in class org.apache.solr.servlet.ResponseUtils
Adds information about the given Throwable to a returned ErrorInfo
getTypedErrorInfo(Throwable, Logger, boolean) - Static method in class org.apache.solr.servlet.ResponseUtils
Adds information about the given Throwable to a returned ErrorInfo
getTypeName() - Method in class org.apache.solr.schema.FieldType
The Name of this FieldType as specified in the schema file
getTypesBySize() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
getUlogDir() - Method in class org.apache.solr.core.CoreDescriptor
 
getUlogDir() - Method in class org.apache.solr.core.SolrCore
 
getUnicodeEscapeInterpretation() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
getUninversionMapper() - Method in class org.apache.solr.schema.IndexSchema
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.BinaryField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.BoolField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.CollationField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.CurrencyFieldType
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.DatePointField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.DenseVectorField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.DoublePointField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.EnumFieldType
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.ExternalFileField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.FieldType
If DocValues is not enabled for a field, but it's indexed, docvalues can be constructed on the fly (uninverted, aka fieldcache) on the first request to sort, facet, etc.
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.FloatPointField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.IntPointField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.LongPointField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.PointType
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.PreAnalyzedField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.RandomSortField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.RankField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.SortableTextField
If DocValues is not enabled for a field, but it's indexed, docvalues can be constructed on the fly (uninverted, aka fieldcache) on the first request to sort, facet, etc.
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.StrField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.TextField
 
getUninversionType(SchemaField) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
getUnInvertedField(String, SolrIndexSearcher) - Static method in class org.apache.solr.search.facet.UnInvertedField
 
getUninvertedStats() - Static method in class org.apache.solr.uninverting.UninvertingReader
Return information about the backing cache
getUninvertedStatsSize() - Static method in class org.apache.solr.uninverting.UninvertingReader
 
getUniqueCoreId() - Method in class org.apache.solr.schema.ZkIndexSchemaReader
 
getUniqueKeyField() - Method in class org.apache.solr.schema.IndexSchema
Unique Key field specified in the schema file
getUniqueKeyField(Document) - Method in class org.apache.solr.schema.IndexSchema
The raw (field type encoded) value of the Unique Key field for the specified Document
getUniqueKeys(SolrIndexSearcher, int[]) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter
Retrieves the unique keys for the topdocs to key the results
getUniqueMetricTag(Object, String) - Static method in interface org.apache.solr.metrics.SolrMetricProducer
Unique metric tag identifies components with the same life-cycle, which should be registered / unregistered together.
getUnknownAttributes(Element, String...) - Method in class org.apache.solr.core.XmlConfigFile
Returns the set of attributes on the given element that are not among the given knownAttributes, or null if all attributes are known.
getUpdatedSinceInitialization() - Method in class org.apache.solr.rest.ManagedResource
Returns the timestamp of the most recent update, or null if this resource has not been updated since initialization.
getUpdateExecutor() - Method in class org.apache.solr.update.StreamingSolrClients
 
getUpdateExecutor() - Method in class org.apache.solr.update.UpdateShardHandler
This method returns an executor that is meant for non search related tasks.
getUpdateHandler() - Method in class org.apache.solr.core.SolrCore
RequestHandlers need access to the updateHandler so they can all talk to the same RAM indexer.
getUpdateHandlerInfo() - Method in class org.apache.solr.core.SolrConfig
 
getUpdateLock() - Method in class org.apache.solr.update.SolrCoreState
 
getUpdateLog() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
getUpdateLog() - Method in class org.apache.solr.update.UpdateHandler
 
getUpdateOnlyHttpClient() - Method in class org.apache.solr.update.UpdateShardHandler
 
getUpdateProcessingChain(String) - Method in class org.apache.solr.core.SolrCore
 
getUpdateProcessorChain(SolrParams) - Method in class org.apache.solr.core.SolrCore
 
getUpdateProcessors() - Method in class org.apache.solr.core.SolrCore
 
getUpdaterThread() - Method in class org.apache.solr.cloud.Overseer
For tests.
getUpdateShardHandler() - Method in class org.apache.solr.core.CoreContainer
 
getUpdateShardHandlerConfig() - Method in class org.apache.solr.core.NodeConfig
 
getUpdateTimeoutSecs() - Method in class org.apache.solr.rest.BaseSolrResource
 
getUpper() - Method in class org.apache.solr.query.SolrRangeQuery
 
getUpperVal() - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
getUptimeMs() - Method in class org.apache.solr.core.SolrCore
 
getUrl() - Method in class org.apache.solr.security.AuditEvent
Full URL of the original request.
getUrl() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
 
getUrl() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
getUrlParts() - Method in class org.apache.solr.api.V2HttpCall
 
getURLs(Path) - Static method in class org.apache.solr.core.SolrResourceLoader
Utility method to get the URLs of all paths under a given directory
getURLs(Path, DirectoryStream.Filter<Path>) - Static method in class org.apache.solr.core.SolrResourceLoader
Utility method to get the URLs of all paths under a given directory that match a filter
getUserFilesPath() - Method in class org.apache.solr.core.CoreContainer
A path where Solr users can retrieve arbitrary files from.
getUsername() - Method in class org.apache.solr.security.AuditEvent
Username of logged in user, or null if no authenticated user
getUserName() - Method in class org.apache.solr.security.AuthorizationContext
This method returns the name of the authenticated user for the current request.
getUserName() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getUserPrincipal() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
getUserPrincipal() - Method in class org.apache.solr.request.LocalSolrQueryRequest
 
getUserPrincipal() - Method in interface org.apache.solr.request.SolrQueryRequest
 
getUserPrincipal() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getUserPrincipal() - Method in class org.apache.solr.request.SolrRequestInfo
 
getUserPrincipal() - Method in class org.apache.solr.security.AuthorizationContext
This method returns the Principal corresponding to the authenticated user for the current request.
getUserPrincipal() - Method in class org.apache.solr.security.HttpServletAuthorizationContext
 
getUserProps() - Method in class org.apache.solr.core.ConfigOverlay
 
getUserQuery(String, SolrPluginUtils.DisjunctionMaxQueryParser, SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
 
getUserRoles(Principal) - Method in class org.apache.solr.security.ExternalRoleRuleBasedAuthorizationPlugin
Pulls roles from the Principal
getUserRoles(Principal) - Method in class org.apache.solr.security.MultiAuthRuleBasedAuthorizationPlugin
Pulls roles from the Principal
getUserRoles(Principal) - Method in class org.apache.solr.security.RuleBasedAuthorizationPlugin
Look up user's role from the explicit user-role mapping.
getUserRoles(Principal) - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
Finds users roles
getUserRoles(AuthorizationContext) - Method in class org.apache.solr.security.RuleBasedAuthorizationPlugin
 
getUserRoles(AuthorizationContext) - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
Finds user roles
getVal(String, boolean) - Method in class org.apache.solr.core.XmlConfigFile
 
getValidators() - Method in class org.apache.solr.api.V2HttpCall
 
getValidators() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
getValidators() - Method in class org.apache.solr.servlet.HttpSolrCall
 
getValue() - Method in class org.apache.solr.handler.component.PivotFacetValue
The value of the asssocated field modeled by this PivotFacetValue.
getValue() - Method in class org.apache.solr.metrics.MetricsMap
 
getValue() - Method in class org.apache.solr.metrics.MetricSuppliers.NoOpGauge
 
getValue() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxGaugeMBean
 
getValue() - Method in class org.apache.solr.metrics.SolrMetricManager.GaugeWrapper
 
getValue() - Method in class org.apache.solr.parser.Token
An optional attribute value of the Token.
getValue() - Method in class org.apache.solr.uninverting.FieldCache.CacheEntry
 
getValue() - Method in enum org.apache.solr.update.UpdateLog.State
 
getValue(boolean) - Method in class org.apache.solr.metrics.MetricsMap
 
getValue(int) - Method in class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
getValue(int) - Method in class org.apache.solr.search.facet.SlotAcc
 
getValue(int) - Method in class org.apache.solr.search.facet.SlotAcc.IntSlotAcc
 
getValue(int) - Method in class org.apache.solr.search.facet.SlotAcc.LongFuncSlotAcc
 
getValue(int) - Method in class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
getValue(NamedList<Object>) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
 
getValue(SchemaField, IndexableField) - Static method in class org.apache.solr.response.DocsStreamer
 
getValueCount() - Method in class org.apache.solr.search.facet.FieldUtil.OrdValues
 
getValueCount() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
getValueFromDigest(AVLTreeDigest) - Method in class org.apache.solr.search.facet.PercentileAgg
 
getValuePath() - Method in class org.apache.solr.handler.component.PivotFacetField
A recursive method that walks up the tree of pivot fields/values to build a list of String representations of the values that lead down to this PivotFacetField.
getValuePath() - Method in class org.apache.solr.handler.component.PivotFacetValue
A recursive method that walks up the tree of pivot fields/values to build a list of the String representations of the values that lead down to this PivotFacetValue.
getValues() - Method in class org.apache.solr.metrics.AggregateMetric
 
getValues() - Method in class org.apache.solr.response.SolrQueryResponse
Gets data to be returned in this response
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.schema.RandomSortField.RandomValueSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.schema.StrFieldSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.facet.AggValueSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.facet.RelatednessAgg
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.facet.SimpleAggValueSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.FloatPayloadValueSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.CollapseScoreFunction
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.distance.HaversineConstFunction
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.distance.HaversineFunction
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.distance.StringDistanceFunction
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.DualDoubleFunction
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.FieldNameValueSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.FileFloatSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.MultiStringFunction
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.OrdFieldSource
 
getValues(Map<Object, Object>, LeafReaderContext) - Method in class org.apache.solr.search.function.ReverseOrdFieldSource
 
getValueSize() - Method in interface org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttribute
Deprecated.
Returns value size in bits (32 for float, int; 64 for double, long)
getValueSize() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
getValueSource() - Method in class org.apache.solr.handler.component.StatsField
The ValueSource of a function or query whose results these stats are computed over, may be null if the stats are directly over a SchemaField
getValueSource() - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.AbstractEnumField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.BoolField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.CurrencyFieldType
Returns a ValueSource over this field in which the numeric value for each document represents the indexed value as converted to the default currency for the field, normalized to its most granular form based on the default fractional digits.
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.DatePointField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.DenseVectorField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.DoublePointField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.ExternalFileField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.FieldType
called to get the default value source (normally, from the Lucene FieldCache.)
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.FloatPointField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.IntPointField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.LongPointField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.PointType
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.PreAnalyzedField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.RandomSortField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.SortableTextField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.StrField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.TextField
 
getValueSource(SchemaField, QParser) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
getValueSourceFromSpatialArgs(QParser, SchemaField, SpatialArgs, String, BBoxStrategy) - Method in class org.apache.solr.schema.BBoxField
 
getValueSourceFromSpatialArgs(QParser, SchemaField, SpatialArgs, String, T) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
getValueSourceParser(String) - Method in class org.apache.solr.core.SolrCore
 
getVariables(String, Cache<String, TemplateUpdateProcessorFactory.Resolved>, Pattern) - Static method in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
Get a list of variables embedded in the template string.
getVectorBuilder(Object, DenseVectorParser.BuilderPhase) - Method in class org.apache.solr.schema.DenseVectorField
Index Time Parsing The inputValue is an ArrayList with a type that depends on the loader used: - XMLLoader, CSVLoader produces an ArrayList of String - JsonLoader produces an ArrayList of Double - JavabinLoader produces an ArrayList of Float
getVectorEncoding() - Method in class org.apache.solr.schema.DenseVectorField
 
getVerifiedRoles() - Method in interface org.apache.solr.security.VerifiedUserRoles
Gets a set of roles that have been verified to belong to a user
getVersion() - Method in class org.apache.solr.core.backup.BackupManager
 
getVersion() - Method in class org.apache.solr.core.ConfigOverlay
 
getVersion() - Method in class org.apache.solr.core.RequestParams.ParamSet
 
getVersion() - Method in class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
 
getVersion() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage.Version
 
getVersion() - Method in class org.apache.solr.schema.IndexSchema
 
getVersion() - Method in class org.apache.solr.search.SolrCacheBase
 
getVersion() - Method in class org.apache.solr.update.UpdateCommand
 
getVersion(String) - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage
 
getVersionBucketLockTimeoutMs() - Method in class org.apache.solr.update.VersionInfo
 
getVersionedBlobByName(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.GetBlobInfoAPI
 
getVersionField() - Method in class org.apache.solr.update.VersionInfo
 
getVersionFromIndex(BytesRef) - Method in class org.apache.solr.update.VersionInfo
Returns the latest version from the index, searched by the given id (bytes) as seen from the realtime searcher.
getVersionInfo() - Method in class org.apache.solr.update.UpdateLog
 
getVersions(int) - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
 
getVersions(int, long) - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
 
getVersionsHash() - Method in class org.apache.solr.update.IndexFingerprint
 
getWaitForUpdatesWithStaleStatePauseMilliSeconds() - Method in class org.apache.solr.cloud.RecoveryStrategy
 
getWarmCount(int) - Method in class org.apache.solr.search.SolrCacheBase.AutoWarmCountRef
 
getWarmupTime() - Method in class org.apache.solr.search.SolrIndexSearcher
 
getWatchedEvent() - Method in class org.apache.solr.cloud.OverseerTaskQueue.QueueEvent
 
getWatcherSize() - Method in class org.apache.solr.logging.LogWatcherConfig
 
getWatcherThreshold() - Method in class org.apache.solr.logging.LogWatcherConfig
 
getWeightedNodes(PlacementContext, Set<Node>, Iterable<SolrCollection>, boolean) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
getWildcardQuery(String, String) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
getWildcardQuery(String, String) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
getWithinGroupSort() - Method in interface org.apache.solr.search.grouping.Command
 
getWithinGroupSort() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand
 
getWithinGroupSort() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand
 
getWithinGroupSort() - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand
 
getWithinGroupSortSpec() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
getWordGrams() - Method in class org.apache.solr.search.FieldParams
 
getWordSet() - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
Returns the set of words in this managed word set.
getWrappedDeletionPolicy() - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
 
getWrappedMergePolicy() - Method in class org.apache.solr.index.WrapperMergePolicyFactory
Returns an instance of the wrapped MergePolicy after it has been configured with all set parameters.
getWrappedQuery() - Method in class org.apache.solr.search.WrappedQuery
 
getWriter() - Method in class org.apache.solr.response.TextResponseWriter
returns the Writer that the response is being written to
getWriter(OutputStream, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.JacksonJsonWriter
 
getX509PublicKey(byte[]) - Static method in class org.apache.solr.util.CryptoKeys
Create PublicKey from a .DER file
getXP(Node, String, boolean) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Gets the string content of the matching an XPath
getXPath() - Method in class org.apache.solr.core.XmlConfigFile
 
getXPathProperty(String) - Method in class org.apache.solr.core.ConfigOverlay
 
getXPathProperty(String, boolean) - Method in class org.apache.solr.core.ConfigOverlay
 
getXPathProperty(List<String>) - Method in class org.apache.solr.core.ConfigOverlay
 
getZkACLProviderClass() - Method in class org.apache.solr.core.CloudConfig
 
getZkClient() - Method in class org.apache.solr.cloud.ZkController
 
getZkClientTimeout() - Method in class org.apache.solr.core.CloudConfig
 
getZkController() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
 
getZkController() - Method in class org.apache.solr.core.CoreContainer
 
getZkController() - Method in class org.apache.solr.core.ZkContainer
 
getZkCredentialsInjectorClass() - Method in class org.apache.solr.core.CloudConfig
 
getZkCredentialsProviderClass() - Method in class org.apache.solr.core.CloudConfig
 
getZkHost() - Method in class org.apache.solr.core.CloudConfig
 
getZkHost(CommandLine) - Static method in class org.apache.solr.cli.SolrCLI
Get the ZooKeeper connection string from either the zkHost command-line option or by looking it up from a running Solr instance based on the solrUrl option.
getZkIndexSchemaReader() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
 
getZkMetricsProducer() - Method in class org.apache.solr.core.ZkContainer
 
getZkRawResponse(String, String) - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
Sends a four-letter-word command to one particular Zookeeper server and returns the response as list of strings
getZkResourceInfo(String) - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
 
getZkServerAddress() - Method in class org.apache.solr.cloud.ZkController
 
getZkStateDir(BackupId) - Static method in class org.apache.solr.core.backup.BackupFilePaths
Get the directory name used to hold backed up ZK state
getZkStateReader() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
getZkStateReader() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
getZkStateReader() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
getZkStateReader() - Method in class org.apache.solr.cloud.Overseer
 
getZkStateReader() - Method in class org.apache.solr.cloud.ZkController
 
getZkStats() - Method in class org.apache.solr.cloud.ZkDistributedQueue
 
getZkStatus(String, ZkDynamicConfig) - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
For each zk host, resolved either from zk connection string or from zk dynamic reconfiguration config, fetch all config and status info from ZK API and returns as a map, where key is hostname
getZnodeForResource(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
Returns the Znode for the given storedResourceId by combining it with the znode base.
getZNodeForRole(NodeRoles.Role) - Static method in class org.apache.solr.core.NodeRoles
 
getZNodeForRoleMode(NodeRoles.Role, String) - Static method in class org.apache.solr.core.NodeRoles
 
getZnodeVersion() - Method in class org.apache.solr.core.RequestParams
 
getZnodeVersion() - Method in class org.apache.solr.core.SolrConfig
 
getZnodeVersion() - Method in class org.apache.solr.core.XmlConfigFile
If this config is loaded from zk the version is relevant otherwise -1 is returned
getZnodeVersion() - Method in class org.apache.solr.security.SecurityPluginHolder
 
giveupLeadership(CoreDescriptor) - Method in class org.apache.solr.cloud.ZkController
Best effort to give up the leadership of a shard in a core after hitting a tragic exception
global - Variable in class org.apache.solr.request.SimpleFacets
Configuration params behavior should be driven by
globalStringList - Variable in class org.apache.solr.update.TransactionLog
 
globalStringMap - Variable in class org.apache.solr.update.TransactionLog
 
globalStrings - Variable in class org.apache.solr.update.UpdateLog
 
graphField - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
 
GraphHandler - Class in org.apache.solr.handler
Solr Request Handler for graph traversal with streaming functions that responds with GraphML markup.
GraphHandler() - Constructor for class org.apache.solr.handler.GraphHandler
 
GraphHandler.DummyErrorStream - Class in org.apache.solr.handler
 
GraphHandler.TimerStream - Class in org.apache.solr.handler
 
GraphMLResponseWriter - Class in org.apache.solr.response
 
GraphMLResponseWriter() - Constructor for class org.apache.solr.response.GraphMLResponseWriter
 
GraphPointsCollector - Class in org.apache.solr.search.join
 
GraphPointsCollector(SchemaField, DocSet, DocSet) - Constructor for class org.apache.solr.search.join.GraphPointsCollector
 
GraphQParserPlugin - Class in org.apache.solr.search.join
Query parser plugin for solr to wrap the graph query parser.
GraphQParserPlugin() - Constructor for class org.apache.solr.search.join.GraphQParserPlugin
 
GraphQuery - Class in org.apache.solr.search.join
GraphQuery - search for nodes and traverse edges in an index.
GraphQuery(Query, String, String) - Constructor for class org.apache.solr.search.join.GraphQuery
Create a graph query q - the starting node query fromField - the field containing the node id toField - the field containing the edge ids
GraphQuery(Query, String, String, Query) - Constructor for class org.apache.solr.search.join.GraphQuery
Create a graph query with a traversal filter applied while traversing the frontier.
GraphQuery.GraphQueryWeight - Class in org.apache.solr.search.join
 
GraphQueryParser - Class in org.apache.solr.search.join
Solr query parser that will handle parsing graph query requests.
GraphQueryParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.join.GraphQueryParser
 
GraphQueryWeight(SolrIndexSearcher, float) - Constructor for class org.apache.solr.search.join.GraphQuery.GraphQueryWeight
 
GraphTermsQParserPlugin - Class in org.apache.solr.search
The GraphTermsQuery builds a disjunction query from a list of terms.
GraphTermsQParserPlugin() - Constructor for class org.apache.solr.search.GraphTermsQParserPlugin
 
GREEN - org.apache.solr.handler.admin.ClusterStatus.Health
All replicas up, leader exists.
GREEN - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
grid - Variable in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
GROUP_ID - Static variable in class org.apache.solr.metrics.reporters.solr.SolrReporter
 
GROUP_NULL_VALUE - Static variable in class org.apache.solr.search.grouping.distributed.requestfactory.TopGroupsShardRequestFactory
Represents a string value for
GROUP_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
groupBy - Variable in class org.apache.solr.search.Grouping.CommandField
 
groupBy - Variable in class org.apache.solr.search.Grouping.CommandFunc
 
grouped - org.apache.solr.search.Grouping.Format
Grouped result.
grouped - org.apache.solr.search.Grouping.TotalCount
Computations should be based on groups.
groupedDistributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
GroupedEndResultTransformer - Class in org.apache.solr.search.grouping.endresulttransformer
Implementation of EndResultTransformer that keeps each grouped result separate in the final response.
GroupedEndResultTransformer(SolrIndexSearcher) - Constructor for class org.apache.solr.search.grouping.endresulttransformer.GroupedEndResultTransformer
 
groupedFinishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
groupedResults - Variable in class org.apache.solr.search.QueryResult
 
groupFacet - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
grouping() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
Grouping - Class in org.apache.solr.search
Basic Solr Grouping infrastructure.
Grouping(SolrIndexSearcher, QueryResult, QueryCommand, boolean, int, boolean) - Constructor for class org.apache.solr.search.Grouping
 
Grouping.Command<T> - Class in org.apache.solr.search
General group command.
Grouping.CommandField - Class in org.apache.solr.search
A group command for grouping on a field.
Grouping.CommandFunc - Class in org.apache.solr.search
A command for grouping on a function.
Grouping.CommandQuery - Class in org.apache.solr.search
A group command for grouping on a query.
Grouping.Format - Enum in org.apache.solr.search
 
Grouping.TotalCount - Enum in org.apache.solr.search
 
GroupingSpecification - Class in org.apache.solr.search.grouping
Encapsulates the grouping options like fields group sort and more specified by clients.
GroupingSpecification() - Constructor for class org.apache.solr.search.grouping.GroupingSpecification
 
groupOffset - Variable in class org.apache.solr.search.Grouping.Command
 
groupPattern - Variable in class org.apache.solr.metrics.reporters.solr.SolrReporter.Report
 
groupSort - Variable in class org.apache.solr.search.Grouping.Command
 
grow(int) - Method in class org.apache.solr.search.DocSetBuilder
 
guaranteedSlotsThreshold - Variable in class org.apache.solr.core.RateLimiterConfig
 
guessFieldProps(String, FieldType, List<Object>, boolean, IndexSchema) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
guessFieldType(String, List<Object>, IndexSchema, boolean, Locale) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
guessMimeType(byte[]) - Method in class org.apache.solr.util.FileTypeMagicUtil
Guess the mime type of file bytes based on its magic number.
guessMimeType(Path) - Method in class org.apache.solr.util.FileTypeMagicUtil
Guess the mime type of file based on its magic number.
guessType(File) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Guesses the type of file, based on file name suffix Returns "application/octet-stream" if no corresponding mimeMap type.

H

handle - Variable in class org.apache.solr.rest.schema.analysis.BaseManagedTokenFilterFactory
 
handleAdmin(SolrQueryResponse) - Method in class org.apache.solr.api.V2HttpCall
 
handleAdmin(SolrQueryResponse) - Method in class org.apache.solr.servlet.HttpSolrCall
 
handleAdminOrRemoteRequest() - Method in class org.apache.solr.api.V2HttpCall
Differentiate between "admin" and "remotequery"-type requests; executing each as appropriate.
handleAdminOrRemoteRequest() - Method in class org.apache.solr.servlet.HttpSolrCall
Handle a request whose "type" could not be discerned in advance and may be either "admin" or "remotequery".
handleAnalysisRequest(FieldAnalysisRequest, IndexSchema) - Method in class org.apache.solr.handler.FieldAnalysisRequestHandler
Handles the resolved analysis request and returns the analysis breakdown response as a named list.
handleCommit(SolrQueryRequest, UpdateRequestProcessor, SolrParams, boolean) - Static method in class org.apache.solr.handler.RequestHandlerUtils
Check the request parameters and decide if it should commit or optimize.
handleConfigLoadingException(E) - Method in class org.apache.solr.handler.component.QueryElevationComponent
Handles an exception that occurred while loading the configuration resource.
handleConflict(Map<String, Object>, List<String>, String, Object, Object) - Method in class org.apache.solr.request.json.ObjectUtil.ConflictHandler
 
handleCustomAction(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.CoreAdminHandler
Deprecated.
Use actions defined via solr.xml instead.
handleEnable(boolean) - Method in class org.apache.solr.handler.PingRequestHandler
 
handleException(Logger) - Method in class org.apache.solr.rest.BaseSolrResource
If there is an exception on the SolrResponse: error info is added to the SolrResponse; the response status code is set to the error code from the exception; and the exception message is added to the list of things to be logged.
handleGroupedResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.QueryComponent
 
handleInitializationException(Exception, QueryElevationComponent.InitializationExceptionCause) - Method in class org.apache.solr.handler.component.QueryElevationComponent
Handles the exception that occurred while initializing this component or when parsing a new config file at runtime.
handleMergeFields(ResponseBuilder, SolrIndexSearcher) - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
handleMergeFields(ResponseBuilder, SolrIndexSearcher) - Method in interface org.apache.solr.handler.component.MergeStrategy
Implement handleMergeFields(ResponseBuilder rb, SolrIndexSearch searcher) if your merge strategy needs more complex data then the sort fields provide.
handleOrd(int, int) - Method in interface org.apache.solr.search.facet.FieldUtil.OrdFunc
 
handlePing(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.PingRequestHandler
 
handlePostExecution(Logger) - Method in class org.apache.solr.rest.BaseSolrResource
Deal with an exception on the SolrResponse, fill in response header info, and log the accumulated messages on the SolrResponse.
handlePotentiallyAsynchronousTask(T, String, String, String, Supplier<T>) - Method in class org.apache.solr.handler.admin.api.CoreAdminAPIBase
Wraps the subclasses logic with extra bookkeeping logic.
handler - Variable in class org.apache.solr.handler.admin.CoreAdminHandler.CallInfo
 
handler - Variable in class org.apache.solr.servlet.HttpSolrCall
 
HANDLER_METRICS - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
HANDLER_NAME - Static variable in class org.apache.solr.api.ApiBag
 
HANDLER_NAME_SPEC_PROVIDER - Static variable in class org.apache.solr.api.ApiBag
 
HANDLER_PATH - Static variable in class org.apache.solr.handler.admin.MetricsCollectorHandler
 
handleRegularResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.QueryComponent
 
handleRequest() - Method in class org.apache.solr.servlet.RequestRateLimiter
Handles an incoming request.
handleRequest(HttpServletRequest) - Method in class org.apache.solr.servlet.RateLimitManager
 
handleRequest(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.RequestHandlerBase
 
handleRequest(SolrQueryRequest, SolrQueryResponse) - Method in interface org.apache.solr.request.SolrRequestHandler
Handles a query request, this method must be thread safe.
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.InfoHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.LoggingHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.LukeRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.MetricsCollectorHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.MetricsHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.PluginInfoHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.PropertiesRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.SecurityConfHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.SystemInfoHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.ThreadDumpHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.ZookeeperInfoHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.BlobHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.component.ActiveTasksListHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.component.QueryCancellationHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.component.SearchHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ContentStreamHandlerBase
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.DumpRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ExportHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.GraphHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.MoreLikeThisHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.NotFoundRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.PingRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.RealTimeGetHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ReplicationHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.RequestHandlerBase
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.SchemaHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.SolrConfigHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.StreamHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.tagger.TaggerRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.search.function.FileFloatSource.ReloadCacheRequestHandler
 
handleRequestBody(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.security.PublicKeyHandler
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.ActiveTasksListComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.DebugComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.ExpandComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.FacetComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.HighlightComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.QueryCancellationComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.QueryComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.SearchComponent
Called after all responses for a single request were received
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.StatsComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.TermsComponent
 
handleResponses(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.facet.FacetModule
 
HandlerMetrics(SolrMetricsContext, String...) - Constructor for class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
handleRollback(SolrQueryRequest, UpdateRequestProcessor, SolrParams, boolean) - Static method in class org.apache.solr.handler.RequestHandlerUtils
 
handlesMergeFields() - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
handlesMergeFields() - Method in interface org.apache.solr.handler.component.MergeStrategy
handlesMergeFields must return true if the MergeStrategy implements a custom handleMergeFields(ResponseBuilder rb, SolrIndexSearch searcher)
handleZkErr(Exception) - Method in class org.apache.solr.pkg.PackageAPI
 
hardEnd - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
hasBoostFunctions() - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
hasBoostParams() - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
hasChangesSinceInitialization() - Method in class org.apache.solr.rest.ManagedResource
Returns true if this resource has been changed since initialization.
hasCollectionOnNode(String) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
hasDocValues() - Method in class org.apache.solr.schema.SchemaField
 
hasExplicitAllowList() - Method in class org.apache.solr.security.AllowListUrlChecker
Whether this checker has been created with a non-empty allow-list of URLs.
hasExplicitField(String) - Method in class org.apache.solr.schema.IndexSchema
Does the schema explicitly define the specified field, i.e.
hash - Variable in class org.apache.solr.update.processor.Lookup3Signature
 
hashCode() - Method in class org.apache.solr.cloud.api.collections.RoutedAlias.Action
 
hashCode() - Method in class org.apache.solr.cloud.OverseerTaskQueue.QueueEvent
 
hashCode() - Method in class org.apache.solr.cloud.RecoveringCoreTermWatcher
 
hashCode() - Method in class org.apache.solr.cluster.placement.impl.MetricImpl
 
hashCode() - Method in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
hashCode() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
hashCode() - Method in class org.apache.solr.core.backup.BackupId
 
hashCode() - Method in class org.apache.solr.core.backup.Checksum
 
hashCode() - Method in class org.apache.solr.filestore.FileStoreAPI.MetaData
 
hashCode() - Method in class org.apache.solr.handler.component.QueryElevationComponent.ElevatingQuery
 
hashCode() - Method in class org.apache.solr.handler.component.ShardDoc
 
hashCode() - Method in class org.apache.solr.legacy.LegacyFieldType
Deprecated.
 
hashCode() - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
 
hashCode() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
hashCode() - Method in class org.apache.solr.metrics.SolrMetricInfo
 
hashCode() - Method in class org.apache.solr.packagemanager.SolrPackageInstance
 
hashCode() - Method in class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
hashCode() - Method in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
hashCode() - Method in class org.apache.solr.query.FilterQuery
 
hashCode() - Method in class org.apache.solr.query.SolrRangeQuery
 
hashCode() - Method in class org.apache.solr.request.SimpleFacets.CountPair
 
hashCode() - Method in class org.apache.solr.schema.FileExchangeRateProvider
 
hashCode() - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
hashCode() - Method in class org.apache.solr.schema.RandomSortField.RandomValueSource
 
hashCode() - Method in class org.apache.solr.schema.SchemaField
 
hashCode() - Method in class org.apache.solr.schema.StrFieldSource
 
hashCode() - Method in class org.apache.solr.schema.ZkIndexSchemaReader
 
hashCode() - Method in class org.apache.solr.search.AnalyticsQuery
 
hashCode() - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
hashCode() - Method in class org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelector
 
hashCode() - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
hashCode() - Method in class org.apache.solr.search.facet.FacetRequest.FacetSort
 
hashCode() - Method in class org.apache.solr.search.facet.PercentileAgg
 
hashCode() - Method in class org.apache.solr.search.facet.RelatednessAgg
 
hashCode() - Method in class org.apache.solr.search.facet.SimpleAggValueSource
 
hashCode() - Method in class org.apache.solr.search.facet.StrAggValueSource
 
hashCode() - Method in class org.apache.solr.search.FloatPayloadValueSource
 
hashCode() - Method in class org.apache.solr.search.function.CollapseScoreFunction
 
hashCode() - Method in class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
hashCode() - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
hashCode() - Method in class org.apache.solr.search.function.distance.HaversineConstFunction
 
hashCode() - Method in class org.apache.solr.search.function.distance.HaversineFunction
 
hashCode() - Method in class org.apache.solr.search.function.distance.SquaredEuclideanFunction
 
hashCode() - Method in class org.apache.solr.search.function.distance.StringDistanceFunction
 
hashCode() - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
hashCode() - Method in class org.apache.solr.search.function.DualDoubleFunction
 
hashCode() - Method in class org.apache.solr.search.function.FieldNameValueSource
 
hashCode() - Method in class org.apache.solr.search.function.FileFloatSource
 
hashCode() - Method in class org.apache.solr.search.function.MultiStringFunction
 
hashCode() - Method in class org.apache.solr.search.function.OrdFieldSource
 
hashCode() - Method in class org.apache.solr.search.function.ReverseOrdFieldSource
 
hashCode() - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
hashCode() - Method in class org.apache.solr.search.FunctionRangeQuery
 
hashCode() - Method in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
hashCode() - Method in class org.apache.solr.search.join.GraphQuery
 
hashCode() - Method in class org.apache.solr.search.join.HashRangeQuery
 
hashCode() - Method in class org.apache.solr.search.MatchCostQuery
 
hashCode() - Method in class org.apache.solr.search.QueryResultKey
 
hashCode() - Method in class org.apache.solr.search.ReRankScaler
 
hashCode() - Method in class org.apache.solr.search.WrappedQuery
 
hashCode() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
hashCode() - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
hashCode() - Method in class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
 
hashCode() - Method in class org.apache.solr.spelling.ResultEntry
 
hashCode() - Method in class org.apache.solr.spelling.Token
Deprecated.
 
hashCode() - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain.ProcessorInfo
 
hashCode() - Method in class org.apache.solr.update.SolrCmdDistributor.ForwardNode
 
hashCode() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
hashCode() - Method in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
HashQParserPlugin - Class in org.apache.solr.search
syntax fq={!hash workers=11 worker=4 keys=field1,field2}
HashQParserPlugin() - Constructor for class org.apache.solr.search.HashQParserPlugin
 
HashRangeQParser - Class in org.apache.solr.search.join
 
HashRangeQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.join.HashRangeQParser
 
HashRangeQParserPlugin - Class in org.apache.solr.search.join
Matches documents where the specified field hashes to a value within the given range.
HashRangeQParserPlugin() - Constructor for class org.apache.solr.search.join.HashRangeQParserPlugin
 
HashRangeQuery - Class in org.apache.solr.search.join
 
HashRangeQuery(String, int, int) - Constructor for class org.apache.solr.search.join.HashRangeQuery
 
HasImplicitIndexAnalyzer - Interface in org.apache.solr.schema
Marker interface for field types that have an implicit (non-user-configurable) index-time schema.
hasMoreArguments() - Method in class org.apache.solr.search.FunctionQParser
Are there more arguments in the argument list being parsed?
hasMultiplicativeBoosts() - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
hasNext() - Method in class org.apache.solr.response.DocsStreamer
 
hasNext() - Method in class org.apache.solr.spelling.PossibilityIterator
 
hasNext() - Method in interface org.apache.solr.util.LongIterator
 
hasNonWhitespace(int, int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
hasPackage(String) - Method in class org.apache.solr.packagemanager.DefaultPackageRepository
 
hasPackage(String) - Method in class org.apache.solr.packagemanager.PackageRepository
 
hasPackageUpdate(String) - Method in class org.apache.solr.packagemanager.RepositoryManager
Is there a version of the package available in the repositories that is more latest than our latest installed version of the package?
hasPatternMatching() - Method in class org.apache.solr.search.ReturnFields
Returns true if the fieldnames should be picked with a pattern
hasPatternMatching() - Method in class org.apache.solr.search.SolrReturnFields
 
hasPending() - Method in class org.apache.solr.update.CommitTracker
 
hasPendingCoreOps(String) - Method in class org.apache.solr.core.SolrCores
The core is currently loading, unloading, or reloading.
hasPendingUpdates() - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
 
hasProperty(int) - Method in class org.apache.solr.schema.FieldType
Check if a property is set
hasRegistered() - Method in class org.apache.solr.cloud.CloudDescriptor
 
hasRegistry(String) - Method in class org.apache.solr.metrics.SolrMetricManager
Check whether a registry with a given name already exists.
hasRequiredMarker(AnnotatedMember) - Method in class org.apache.solr.util.SolrJacksonAnnotationInspector
 
hasSchemaCache() - Method in class org.apache.solr.core.NodeConfig
 
hasScores() - Method in interface org.apache.solr.search.DocList
True if scores were retained
hasScores() - Method in class org.apache.solr.search.DocSlice
 
hasShardOnNode(Shard) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
hasSpecialSyntax - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
hasTimedOut() - Method in class org.apache.solr.util.TimeOut
 
hasTokenFrequencyInfo() - Method in class org.apache.solr.spelling.SpellingResult
 
hasUncommittedChanges() - Method in class org.apache.solr.update.UpdateLog
 
hasWhitespace - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
HaversineConstFunction - Class in org.apache.solr.search.function.distance
Haversine function with one point constant
HaversineConstFunction(double, double, VectorValueSource) - Constructor for class org.apache.solr.search.function.distance.HaversineConstFunction
 
HaversineDistance() - Constructor for class org.apache.solr.handler.HaversineMetersEvaluator.HaversineDistance
 
HaversineFunction - Class in org.apache.solr.search.function.distance
Calculate the Haversine formula (distance) between any two points on a sphere Takes in four value sources: (latA, lonA); (latB, lonB).
HaversineFunction(MultiValueSource, MultiValueSource, double) - Constructor for class org.apache.solr.search.function.distance.HaversineFunction
 
HaversineFunction(MultiValueSource, MultiValueSource, double, boolean) - Constructor for class org.apache.solr.search.function.distance.HaversineFunction
 
HaversineMetersEvaluator - Class in org.apache.solr.handler
 
HaversineMetersEvaluator(StreamExpression, StreamFactory) - Constructor for class org.apache.solr.handler.HaversineMetersEvaluator
 
HaversineMetersEvaluator.HaversineDistance - Class in org.apache.solr.handler
 
HEAD - org.apache.solr.servlet.cache.Method
 
HEADER - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
HEADER - Static variable in class org.apache.solr.security.PKIAuthenticationPlugin
 
HEADER_V2 - Static variable in class org.apache.solr.security.PKIAuthenticationPlugin
 
headers - Variable in class org.apache.solr.handler.configsets.ListConfigSets
 
headerSize(Float, Boolean) - Method in class org.apache.solr.response.JSONWriter
 
HEALTH_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
HEALTHCHECK_FILE_PARAM - Static variable in class org.apache.solr.handler.PingRequestHandler
 
healthCheckHandler - Variable in class org.apache.solr.core.CoreContainer
 
HealthCheckHandler - Class in org.apache.solr.handler.admin
Health Check Handler for reporting the health of a specific node.
HealthCheckHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.HealthCheckHandler
 
HealthcheckTool - Class in org.apache.solr.cli
 
HealthcheckTool() - Constructor for class org.apache.solr.cli.HealthcheckTool
Requests health information about a specific collection in SolrCloud.
HealthcheckTool(PrintStream) - Constructor for class org.apache.solr.cli.HealthcheckTool
 
heap - Variable in class org.apache.solr.util.LongPriorityQueue
 
HEAP_USAGE - Static variable in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
HeatmapFacet(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.SpatialHeatmapFacets.HeatmapFacet
 
heatmapFacets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
HIDDEN - Static variable in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
hiddenFiles - Variable in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
hideStackTrace() - Method in class org.apache.solr.core.CoreContainer
 
hideStackTraces() - Method in class org.apache.solr.core.NodeConfig
 
HighFrequencyDictionaryFactory - Class in org.apache.solr.spelling.suggest
Factory for HighFrequencyDictionary
HighFrequencyDictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.HighFrequencyDictionaryFactory
 
HIGHLIGHT - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
Highlight suggest terms - default is true.
HighlightComponent - Class in org.apache.solr.handler.component
Highlights query words in the search results.
HighlightComponent() - Constructor for class org.apache.solr.handler.component.HighlightComponent
 
HighlightComponent.HighlightMethod - Enum in org.apache.solr.handler.component
 
HIGHLIGHTER - org.apache.solr.core.SolrInfoBean.Category
 
HighlightingPluginBase - Class in org.apache.solr.highlight
 
HighlightingPluginBase() - Constructor for class org.apache.solr.highlight.HighlightingPluginBase
 
highlightingResponseField() - Method in class org.apache.solr.handler.component.HighlightComponent
 
hint - Variable in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
HINT_BLOCK - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
Indicates that values in the collapse field are unique per contiguous block, and a single pass "block based" collapse algorithm can be used.
HINT_MULTI_DOCVALUES - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
Deprecated.
HINT_TOP_FC - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
 
histogram(String, String...) - Method in class org.apache.solr.metrics.SolrDelegateRegistryMetricsContext
 
histogram(String, String...) - Method in class org.apache.solr.metrics.SolrMetricsContext
histogram(SolrMetricsContext, String, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Create or get an existing named Histogram
histogramSupplier(SolrResourceLoader, PluginInfo) - Static method in class org.apache.solr.metrics.MetricSuppliers
Create a Histogram supplier.
history - Variable in class org.apache.solr.logging.LogWatcher
 
HIT_RATIO_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
hitCountRelation() - Method in interface org.apache.solr.search.DocList
 
hitCountRelation() - Method in class org.apache.solr.search.DocSlice
 
HITS_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
HLL - Class in org.apache.solr.util.hll
A probabilistic set of hashed long elements.
HLL(int, int) - Constructor for class org.apache.solr.util.hll.HLL
Construct an empty HLL with the given log2m and regwidth.
HLL(int, int, int, boolean, HLLType) - Constructor for class org.apache.solr.util.hll.HLL
NOTE: Arguments here are named and structured identically to those in the PostgreSQL implementation, which can be found here.
HLLAgg - Class in org.apache.solr.search.facet
 
HLLAgg(String) - Constructor for class org.apache.solr.search.facet.HLLAgg
 
HLLAgg.HLLFactory - Class in org.apache.solr.search.facet
 
HLLFactory() - Constructor for class org.apache.solr.search.facet.HLLAgg.HLLFactory
 
HLLType - Enum in org.apache.solr.util.hll
The types of algorithm/data structure that HLL can utilize.
HNSW_ALGORITHM - Static variable in class org.apache.solr.schema.DenseVectorField
 
HOST_AND_METHOD - Static variable in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
html - org.apache.solr.response.transform.ExplainAugmenterFactory.Style
 
HtmlEncoder - Class in org.apache.solr.highlight
Use the SimpleHTMLEncoder
HtmlEncoder() - Constructor for class org.apache.solr.highlight.HtmlEncoder
 
HtmlFormatter - Class in org.apache.solr.highlight
Use the SimpleHTMLFormatter
HtmlFormatter() - Constructor for class org.apache.solr.highlight.HtmlFormatter
 
HTMLStripFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Strips all HTML Markup in any CharSequence values found in fields matching the specified conditions.
HTMLStripFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.HTMLStripFieldUpdateProcessorFactory
 
HTTP - org.apache.solr.core.SolrInfoBean.Category
 
HTTP_HEADER_X_SOLR_AUTHDATA - Static variable in class org.apache.solr.security.AuthenticationPlugin
 
HTTP_SERVLET_REQ - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
HTTP_SERVLET_RSP - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
HttpCacheHeaderUtil - Class in org.apache.solr.servlet.cache
 
HttpCacheHeaderUtil() - Constructor for class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
 
httpCaching - Variable in class org.apache.solr.handler.RequestHandlerBase
 
httpCaching - Variable in class org.apache.solr.response.SolrQueryResponse
Should this response be tagged with HTTP caching headers?
httpClient - Variable in class org.apache.solr.handler.component.IterativeMergeStrategy
 
HttpClientBuilderPlugin - Interface in org.apache.solr.security
Plugin interface for configuring internal HttpClients.
HttpClientMetricNameStrategy - Interface in org.apache.solr.util.stats
Strategy for creating metric names for HttpClient Copied from metrics-httpclient library
httpHeaders() - Method in class org.apache.solr.response.SolrQueryResponse
Returns a new iterator of response headers
httpListenerFactory - Variable in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
httpRequest - Variable in class org.apache.solr.request.SolrRequestInfo
 
HttpServletAuthorizationContext - Class in org.apache.solr.security
An AuthorizationContext implementation that delegates many methods to an underlying HttpServletRequest
HttpServletAuthorizationContext(HttpServletRequest) - Constructor for class org.apache.solr.security.HttpServletAuthorizationContext
 
HttpServletCarrier - Class in org.apache.solr.util.tracing
A Carrier for extract Span context out of request headers
HttpServletCarrier(HttpServletRequest) - Constructor for class org.apache.solr.util.tracing.HttpServletCarrier
 
HttpShardHandler - Class in org.apache.solr.handler.component
 
HttpShardHandler(HttpShardHandlerFactory) - Constructor for class org.apache.solr.handler.component.HttpShardHandler
 
HttpShardHandlerFactory - Class in org.apache.solr.handler.component
 
HttpShardHandlerFactory() - Constructor for class org.apache.solr.handler.component.HttpShardHandlerFactory
 
HttpSolrCall - Class in org.apache.solr.servlet
This class represents a call made to Solr
HttpSolrCall(SolrDispatchFilter, CoreContainer, HttpServletRequest, HttpServletResponse, boolean) - Constructor for class org.apache.solr.servlet.HttpSolrCall
 

I

IBSimilarityFactory - Class in org.apache.solr.search.similarities
Factory for IBSimilarity
IBSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.IBSimilarityFactory
 
id - Variable in class org.apache.solr.core.backup.BackupId
 
id - Variable in class org.apache.solr.handler.component.ShardDoc
 
id - Variable in class org.apache.solr.update.DeleteUpdateCommand
 
id - Variable in class org.apache.solr.update.UpdateLog.DeleteUpdate
 
id - Variable in class org.apache.solr.update.UpdateLog
 
ID - org.apache.solr.response.transform.ShardAugmenterFactory.Style
 
ID - Static variable in class org.apache.solr.handler.admin.LukeRequestHandler
 
IDENTITY_CONVERTER - Variable in class org.apache.solr.cluster.placement.impl.MetricImpl
Identity converter.
idField - Variable in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
idField - Variable in class org.apache.solr.update.UpdateHandler
 
idFieldType - Variable in class org.apache.solr.update.UpdateHandler
 
IDLE - org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
 
IDS - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
IdUtils - Class in org.apache.solr.util
Helper class for generating unique ID-s.
IdUtils() - Constructor for class org.apache.solr.util.IdUtils
 
ifNotNoop(Span, Consumer<Span>) - Static method in class org.apache.solr.util.tracing.TraceUtils
 
IGainTermsQParserPlugin - Class in org.apache.solr.search
 
IGainTermsQParserPlugin() - Constructor for class org.apache.solr.search.IGainTermsQParserPlugin
 
IGNORE - org.apache.solr.metrics.SolrMetricManager.ResolutionStrategy
The existing metric will be kept and the new metric will be ignored.
IGNORE - org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
 
IGNORE_AUTOCOMMIT - Static variable in class org.apache.solr.update.UpdateCommand
 
IGNORE_CASE_INIT_ARG - Static variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
 
IGNORE_CASE_INIT_ARG - Static variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
 
IGNORE_CASE_INIT_ARG - Static variable in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
 
IGNORE_INDEXWRITER - Static variable in class org.apache.solr.update.UpdateCommand
 
IGNORE_STOPWORDS - Static variable in class org.apache.solr.handler.tagger.TaggerRequestHandler
Request parameter.
IgnoreCommitOptimizeUpdateProcessorFactory - Class in org.apache.solr.update.processor
Gives system administrators a way to ignore explicit commit or optimize requests from clients.
IgnoreCommitOptimizeUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.IgnoreCommitOptimizeUpdateProcessorFactory
 
IgnoreException() - Constructor for exception org.apache.solr.handler.export.ExportWriter.IgnoreException
 
IgnoreFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Ignores & removes fields matching the specified conditions from any document being added to the index.
IgnoreFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.IgnoreFieldUpdateProcessorFactory
 
IgnoreLargeDocumentProcessorFactory - Class in org.apache.solr.update.processor
Gives system administrators a way to ignore very large update from clients.
IgnoreLargeDocumentProcessorFactory() - Constructor for class org.apache.solr.update.processor.IgnoreLargeDocumentProcessorFactory
 
ignoreOptimizeOnly - Variable in class org.apache.solr.update.processor.IgnoreCommitOptimizeUpdateProcessorFactory
 
image - Variable in class org.apache.solr.parser.Token
The string image of the token.
IMMUTABLE_CONFIGSET_ARG - Static variable in class org.apache.solr.core.ConfigSetProperties
 
implicits - Static variable in class org.apache.solr.update.processor.UpdateRequestProcessorChain
 
INACTIVE - org.apache.solr.cluster.Shard.ShardState
 
inc() - Method in class org.apache.solr.metrics.DelegateRegistryCounter
 
inc(long) - Method in class org.apache.solr.metrics.DelegateRegistryCounter
 
incAndGetId(DistribStateManager, String, int) - Static method in class org.apache.solr.cloud.api.collections.Assign
 
incCount(FacetComponent.ShardFacetCount, long) - Method in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
incLevel() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
incLevel() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
incLevel() - Method in class org.apache.solr.response.TextResponseWriter
 
include - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
INCLUDE_INDEX_FIELD_FLAGS - Static variable in class org.apache.solr.handler.admin.LukeRequestHandler
 
includeInResponse(StatsField.Stat) - Method in class org.apache.solr.handler.component.StatsField
 
includeLower - Variable in class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
 
includeLower() - Method in class org.apache.solr.query.SolrRangeQuery
 
includeQuery - Variable in class org.apache.solr.handler.component.QueryElevationComponent.Elevation
 
includes(long) - Method in class org.apache.solr.request.IntervalFacets.FacetInterval
Method to use to check whether a document should be counted for an interval or not.
includesMax() - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Returns true if the upper endpoint is inclusive
includesMin() - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Returns true if the lower endpoint is inclusive
includesNonScoreOrDocField() - Method in class org.apache.solr.search.SortSpec
Returns whether SortFields for the Sort includes a field besides SortField.Type.SCORE or SortField.Type.DOC
includesNonScoreOrDocField(Sort) - Static method in class org.apache.solr.search.SortSpec
Returns whether SortFields for the Sort includes a field besides SortField.Type.SCORE or SortField.Type.DOC
includesScore() - Method in class org.apache.solr.search.SortSpec
 
includesScore(Sort) - Static method in class org.apache.solr.search.SortSpec
 
includeString(String) - Method in class org.apache.solr.request.RegexBytesRefFilter
 
includeString(String) - Method in class org.apache.solr.request.SubstringBytesRefFilter
 
includeUpper - Variable in class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
 
includeUpper() - Method in class org.apache.solr.query.SolrRangeQuery
 
incref() - Method in class org.apache.solr.update.TransactionLog
 
incref() - Method in class org.apache.solr.util.RefCounted
 
incRef(Directory) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
incRef(Directory) - Method in class org.apache.solr.core.DirectoryFactory
Increment the number of references to the given Directory.
increfSolrCoreState() - Method in class org.apache.solr.update.SolrCoreState
 
IncrementalShardBackup - Class in org.apache.solr.handler
Responsible for orchestrating the actual incremental backup process.
IncrementalShardBackup(BackupRepository, SolrCore, BackupFilePaths, ShardBackupId, ShardBackupId, Optional<String>) - Constructor for class org.apache.solr.handler.IncrementalShardBackup
 
IncrementalShardBackup.IncrementalShardSnapshotResponse - Class in org.apache.solr.handler
 
IncrementalShardSnapshotResponse() - Constructor for class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
incrementToken() - Method in class org.apache.solr.analysis.LowerCaseTokenizer
Deprecated.
 
incrementToken() - Method in class org.apache.solr.analysis.ReversedWildcardFilter
 
incrementToken() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.ListBasedTokenStream
 
incrementToken() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
 
incShift() - Method in interface org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttribute
Deprecated.
Don't call this method!
incShift() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
indent() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
indent() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
indent(int) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
indent(int) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
index - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
index - Variable in class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
 
index - Variable in class org.apache.solr.uninverting.DocTermOrds
Holds the per-document ords or a pointer to the ords.
INDEX - org.apache.solr.core.SolrInfoBean.Category
 
INDEX - org.apache.solr.util.vector.DenseVectorParser.BuilderPhase
 
INDEX - Static variable in class org.apache.solr.schema.FieldType
 
INDEX_ANALYZER - Static variable in class org.apache.solr.schema.FieldType
 
INDEX_ASC - Static variable in class org.apache.solr.search.facet.FacetRequest.FacetSort
Commonly Re-used "index asc" (index order / streaming)
INDEX_DIR - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
INDEX_DIR_PATH - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
INDEX_FETCH_FAILURE - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
INDEX_FETCH_SUCCESS - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
INDEX_PATH - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
The path where the underlying index is stored if no index is found, it will be generated by the AnalyzingInfixSuggester
INDEX_PROPERTIES - Static variable in class org.apache.solr.handler.IndexFetcher
 
INDEX_SIZE_GB - Static variable in class org.apache.solr.cluster.placement.impl.ReplicaMetricImpl
Replica index size in GB.
INDEX_TO_COLLECTION_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
INDEX_VERSION_PROP - Static variable in class org.apache.solr.core.backup.BackupManager
 
INDEX_W_TIMESTAMP_REGEX - Static variable in class org.apache.solr.core.DirectoryFactory
 
indexableUniqueKey(String) - Method in class org.apache.solr.schema.IndexSchema
Given a readable/printable uniqueKey value, return an indexable version
IndexBasedSpellChecker - Class in org.apache.solr.spelling
A spell checker implementation that loads words from Solr as well as arbitrary Lucene indices.
IndexBasedSpellChecker() - Constructor for class org.apache.solr.spelling.IndexBasedSpellChecker
 
indexConfig - Variable in class org.apache.solr.core.SolrConfig
 
IndexDeletionPolicyWrapper - Class in org.apache.solr.core
A wrapper for an IndexDeletionPolicy instance.
IndexDeletionPolicyWrapper(IndexDeletionPolicy, SolrSnapshotMetaDataManager) - Constructor for class org.apache.solr.core.IndexDeletionPolicyWrapper
 
indexDir - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
indexed - Variable in class org.apache.solr.handler.component.FacetComponent.ShardFacetCount
 
indexed() - Method in class org.apache.solr.schema.SchemaField
 
INDEXED - Static variable in class org.apache.solr.schema.FieldProperties
 
indexedBytes - Variable in class org.apache.solr.search.FloatPayloadValueSource
 
indexedField - Variable in class org.apache.solr.search.FloatPayloadValueSource
 
indexedId - Variable in class org.apache.solr.update.DeleteUpdateCommand
 
indexedTermsArray - Variable in class org.apache.solr.uninverting.DocTermOrds
Holds the indexed (by default every 128th) terms.
indexedToReadable(String) - Method in class org.apache.solr.schema.BoolField
 
indexedToReadable(String) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
indexedToReadable(String) - Method in class org.apache.solr.schema.EnumFieldType
 
indexedToReadable(String) - Method in class org.apache.solr.schema.FieldType
Given an indexed term, return the human readable representation
indexedToReadable(String) - Method in class org.apache.solr.schema.PointField
 
indexedToReadable(String) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
indexedToReadable(BytesRef) - Method in class org.apache.solr.schema.DatePointField
 
indexedToReadable(BytesRef) - Method in class org.apache.solr.schema.DoublePointField
 
indexedToReadable(BytesRef) - Method in class org.apache.solr.schema.FloatPointField
 
indexedToReadable(BytesRef) - Method in class org.apache.solr.schema.IntPointField
 
indexedToReadable(BytesRef) - Method in class org.apache.solr.schema.LongPointField
 
indexedToReadable(BytesRef) - Method in class org.apache.solr.schema.PointField
 
indexedToReadable(BytesRef, CharsRefBuilder) - Method in class org.apache.solr.schema.BoolField
 
indexedToReadable(BytesRef, CharsRefBuilder) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
indexedToReadable(BytesRef, CharsRefBuilder) - Method in class org.apache.solr.schema.EnumFieldType
 
indexedToReadable(BytesRef, CharsRefBuilder) - Method in class org.apache.solr.schema.FieldType
Given an indexed term, append the human readable representation
indexedToReadable(BytesRef, CharsRefBuilder) - Method in class org.apache.solr.schema.PointField
 
indexedToReadable(BytesRef, CharsRefBuilder) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
indexEnabled - Variable in class org.apache.solr.core.SolrCore
 
IndexFetcher - Class in org.apache.solr.handler
Provides functionality of downloading changed index files as well as config files and a timer for scheduling fetches from the leader.
IndexFetcher(NamedList<?>, ReplicationHandler, SolrCore) - Constructor for class org.apache.solr.handler.IndexFetcher
 
IndexFetcher.CompareResult - Class in org.apache.solr.handler
 
IndexFetcher.IndexFetchResult - Class in org.apache.solr.handler
 
indexFileCount - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
indexFileCount - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
IndexFingerprint - Class in org.apache.solr.update
 
IndexFingerprint() - Constructor for class org.apache.solr.update.IndexFingerprint
 
IndexFingerprint(long) - Constructor for class org.apache.solr.update.IndexFingerprint
 
indexMap(SolrQueryRequest, SolrQueryResponse, Map<String, Object>) - Static method in class org.apache.solr.handler.BlobHandler
 
indexOptions() - Method in class org.apache.solr.schema.SchemaField
 
IndexReaderFactory - Class in org.apache.solr.core
Factory used to build a new IndexReader instance.
IndexReaderFactory() - Constructor for class org.apache.solr.core.IndexReaderFactory
 
indexSampleDocs(String, List<SolrInputDocument>, String, boolean) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
indexSampleDocsWithRebuildOnAnalysisError(String, List<SolrInputDocument>, String, boolean, String[]) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
indexSchema - Variable in class org.apache.solr.handler.admin.api.GetSchema
 
IndexSchema - Class in org.apache.solr.schema
IndexSchema contains information about the valid fields in an index and the types of those fields.
IndexSchema(String, ConfigSetService.ConfigResource, Version, SolrResourceLoader, Properties) - Constructor for class org.apache.solr.schema.IndexSchema
Constructs a schema using the specified resource name and stream.
IndexSchema(Version, SolrResourceLoader, Properties) - Constructor for class org.apache.solr.schema.IndexSchema
 
IndexSchema.DynamicCopy - Class in org.apache.solr.schema
 
IndexSchema.DynamicField - Class in org.apache.solr.schema
 
IndexSchema.DynamicReplacement - Class in org.apache.solr.schema
 
IndexSchema.DynamicReplacement.DynamicPattern - Class in org.apache.solr.schema
 
IndexSchema.SchemaProps - Class in org.apache.solr.schema
 
IndexSchema.SchemaProps.Handler - Enum in org.apache.solr.schema
 
IndexSchemaFactory - Class in org.apache.solr.schema
Base class for factories for IndexSchema implementations
IndexSchemaFactory() - Constructor for class org.apache.solr.schema.IndexSchemaFactory
 
IndexSchemaFactory.VersionedConfig - Class in org.apache.solr.schema
 
indexSearcher() - Method in class org.apache.solr.search.QueryContext
 
IndexSizeEstimator - Class in org.apache.solr.handler.admin
Estimates the raw size of all uncompressed indexed data by scanning term, docValues and stored fields data.
IndexSizeEstimator(IndexReader, int, int, boolean, boolean) - Constructor for class org.apache.solr.handler.admin.IndexSizeEstimator
 
IndexSizeEstimator.Estimate - Class in org.apache.solr.handler.admin
 
IndexSizeEstimator.Item - Class in org.apache.solr.handler.admin
 
IndexSizeEstimator.ItemPriorityQueue - Class in org.apache.solr.handler.admin
 
IndexSizeEstimator.MapWriterSummaryStatistics - Class in org.apache.solr.handler.admin
 
indexSizeMB - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
indexVersion - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.IndexVersionResponse
 
IndexVersionResponse() - Constructor for class org.apache.solr.handler.admin.api.CoreReplicationAPI.IndexVersionResponse
 
IndexVersionResponse(Long, Long, String) - Constructor for class org.apache.solr.handler.admin.api.CoreReplicationAPI.IndexVersionResponse
 
inDomain(String) - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
 
info - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessagesResponse
 
info - Variable in class org.apache.solr.handler.component.HighlightComponent
 
info - Variable in class org.apache.solr.uninverting.UninvertingReader.FieldCacheStats
 
Info(String) - Constructor for class org.apache.solr.cli.ExportTool.Info
 
INFO - org.apache.solr.security.AuditEvent.Level
 
InfoHandler - Class in org.apache.solr.handler.admin
 
InfoHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.InfoHandler
Overloaded ctor to inject CoreContainer into the handler.
inform(Map<String, SolrInfoBean>) - Method in class org.apache.solr.core.SolrResourceLoader
Register any SolrInfoBeans
inform(ResourceLoader) - Method in class org.apache.solr.core.SolrResourceLoader
Tell all ResourceLoaderAware instances about the loader
inform(ResourceLoader) - Method in class org.apache.solr.rest.schema.analysis.BaseManagedTokenFilterFactory
Registers an endpoint with the RestManager so that this component can be managed using the REST API.
inform(ResourceLoader) - Method in class org.apache.solr.schema.CurrencyFieldType
Load the currency config when resource loader initialized.
inform(ResourceLoader) - Method in interface org.apache.solr.schema.ExchangeRateProvider
Passes a ResourceLoader, used to read config files from e.g.
inform(ResourceLoader) - Method in class org.apache.solr.schema.FileExchangeRateProvider
 
inform(ResourceLoader) - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
inform(ResourceLoader) - Method in class org.apache.solr.security.MultiDestinationAuditLogger
 
inform(SolrCore) - Method in class org.apache.solr.core.SchemaCodecFactory
 
inform(SolrCore) - Method in class org.apache.solr.core.SolrResourceLoader
Tell all SolrCoreAware instances about the SolrCore
inform(SolrCore) - Method in class org.apache.solr.handler.component.HighlightComponent
 
inform(SolrCore) - Method in class org.apache.solr.handler.component.QueryElevationComponent
 
inform(SolrCore) - Method in class org.apache.solr.handler.component.SearchHandler
Initialize the components based on name.
inform(SolrCore) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
inform(SolrCore) - Method in class org.apache.solr.handler.component.SuggestComponent
 
inform(SolrCore) - Method in class org.apache.solr.handler.component.TaskManagementHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.DumpRequestHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.ExportHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.GraphHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.PingRequestHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.ReplicationHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.SchemaHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.SolrConfigHandler
 
inform(SolrCore) - Method in class org.apache.solr.handler.StreamHandler
 
inform(SolrCore) - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
inform(SolrCore) - Method in class org.apache.solr.search.similarities.SchemaSimilarityFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.AddSchemaFieldsUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.AtomicUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.DocExpirationUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.PreAnalyzedUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.SkipExistingDocumentsProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessorFactory
 
inform(SolrCore) - Method in class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
 
inform(SolrCore) - Method in interface org.apache.solr.util.plugin.SolrCoreAware
 
inform(IndexSchema) - Method in class org.apache.solr.schema.AbstractSubTypeFieldType
Registers the polyfield dynamic prototype for this field type: : "*___(field type name)"
inform(IndexSchema) - Method in class org.apache.solr.schema.BBoxField
 
inform(IndexSchema) - Method in class org.apache.solr.schema.CurrencyField
Deprecated.
When index schema is informed, add dynamic fields "*____currency" and "*____amount_raw".
inform(IndexSchema) - Method in class org.apache.solr.schema.CurrencyFieldType
When index schema is informed, get field types for the configured dynamic sub-fields
inform(IndexSchema) - Method in class org.apache.solr.schema.ExternalFileField
 
inform(IndexSchema) - Method in class org.apache.solr.schema.LatLonPointSpatialField
 
inform(IndexSchema) - Method in interface org.apache.solr.schema.SchemaAware
Informs the IndexSchema provided by the schema parameter of an event (e.g., a new FieldType was added, etc.
informAware(ResourceLoader, ResourceLoaderAware) - Static method in class org.apache.solr.core.SolrResourceLoader
Set the current ResourceLoaderAware object in thread local so that appropriate classloader can be used for package loaded classes
informEventListeners(SolrCore) - Method in class org.apache.solr.update.UpdateHandler
Call the SolrCoreAware.inform(SolrCore) on all the applicable registered listeners.
infoStream - Variable in class org.apache.solr.update.SolrIndexConfig
 
init - Variable in class org.apache.solr.servlet.SolrDispatchFilter
 
init() - Method in class org.apache.solr.api.ContainerPluginsRegistry.ApiInfo
 
init() - Method in class org.apache.solr.api.CoordinatorV2HttpSolrCall
 
init() - Method in class org.apache.solr.api.V2HttpCall
 
init() - Method in class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
init() - Method in class org.apache.solr.servlet.HttpSolrCall
 
init() - Method in class org.apache.solr.util.configuration.SSLConfigurations
Initiates javax.net.ssl.* system properties from the proper sources.
init(long, int, int, int) - Method in interface org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttribute
Deprecated.
Don't call this method!
init(long, int, int, int) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
init(String, QParser) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
init(Map<String, Object>) - Method in class org.apache.solr.security.AuditLoggerPlugin
Initialize the plugin from security.json.
init(Map<String, Object>) - Method in class org.apache.solr.security.AuthenticationPlugin
This is called upon loading up of a plugin, used for setting it up.
init(Map<String, Object>) - Method in interface org.apache.solr.security.AuthorizationPlugin
 
init(Map<String, Object>) - Method in interface org.apache.solr.security.BasicAuthPlugin.AuthenticationProvider
 
init(Map<String, Object>) - Method in class org.apache.solr.security.BasicAuthPlugin
 
init(Map<String, Object>) - Method in class org.apache.solr.security.CertAuthPlugin
 
init(Map<String, Object>) - Method in class org.apache.solr.security.ExternalRoleRuleBasedAuthorizationPlugin
 
init(Map<String, Object>) - Method in class org.apache.solr.security.MultiAuthPlugin
 
init(Map<String, Object>) - Method in class org.apache.solr.security.MultiAuthRuleBasedAuthorizationPlugin
 
init(Map<String, Object>) - Method in class org.apache.solr.security.MultiDestinationAuditLogger
Initialize the plugin from security.json
init(Map<String, Object>) - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
init(Map<String, Object>) - Method in class org.apache.solr.security.RuleBasedAuthorizationPlugin
 
init(Map<String, Object>) - Method in class org.apache.solr.security.RuleBasedAuthorizationPluginBase
 
init(Map<String, Object>) - Method in class org.apache.solr.security.Sha256AuthenticationProvider
 
init(Map<String, Object>) - Method in class org.apache.solr.security.SolrLogAuditLoggerPlugin
Initialize the plugin from security.json
init(Map<String, String>) - Method in interface org.apache.solr.schema.ExchangeRateProvider
Initializes the provider by passing in a set of key/value configs as a map.
init(Map<String, String>) - Method in class org.apache.solr.schema.FileExchangeRateProvider
 
init(Map<String, String>) - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
init(Map<String, String>) - Method in interface org.apache.solr.util.plugin.MapInitializedPlugin
 
init(Map<String, String>, Object, CacheRegenerator) - Method in class org.apache.solr.search.CaffeineCache
 
init(Map<String, String>, Object, CacheRegenerator) - Method in interface org.apache.solr.search.SolrCache
The initialization routine.
init(Map<String, String>, CacheRegenerator) - Method in class org.apache.solr.search.SolrCacheBase
 
init(FilterConfig) - Method in class org.apache.solr.servlet.SolrDispatchFilter
 
init(ServletConfig) - Method in class org.apache.solr.servlet.RedirectServlet
 
init(ServletContext) - Method in class org.apache.solr.servlet.CoreContainerProvider
 
init(SolrParams) - Method in class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
init(SolrParams) - Method in class org.apache.solr.handler.loader.ContentStreamLoader
This should be called once for each RequestHandler
init(SolrParams) - Method in class org.apache.solr.handler.loader.XMLLoader
 
init(SolrParams) - Method in class org.apache.solr.schema.SimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.BM25SimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.ClassicSimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.DFISimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.DFRSimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.IBSimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.LMDirichletSimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.LMJelinekMercerSimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.SchemaSimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.search.similarities.SweetSpotSimilarityFactory
 
init(SolrParams) - Method in class org.apache.solr.update.processor.Signature
 
init(SolrParams) - Method in class org.apache.solr.update.processor.TextProfileSignature
 
init(NamedList<?>) - Method in class org.apache.solr.cloud.RecoveryStrategy.Builder
 
init(NamedList<?>) - Method in class org.apache.solr.core.AbstractSolrEventListener
 
init(NamedList<?>) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
init(NamedList<?>) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
init(NamedList<?>) - Method in class org.apache.solr.core.IndexReaderFactory
init will be called just once, immediately after creation.
init(NamedList<?>) - Method in class org.apache.solr.core.MMapDirectoryFactory
 
init(NamedList<?>) - Method in class org.apache.solr.core.NRTCachingDirectoryFactory
 
init(NamedList<?>) - Method in class org.apache.solr.core.SchemaCodecFactory
 
init(NamedList<?>) - Method in class org.apache.solr.core.SimpleTextCodecFactory
 
init(NamedList<?>) - Method in class org.apache.solr.core.SolrDeletionPolicy
 
init(NamedList<?>) - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.admin.InfoHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.admin.MetricsCollectorHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.component.QueryElevationComponent
 
init(NamedList<?>) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
init(NamedList<?>) - Method in class org.apache.solr.handler.component.SuggestComponent
 
init(NamedList<?>) - Method in class org.apache.solr.handler.component.TermVectorComponent
 
init(NamedList<?>) - Method in class org.apache.solr.handler.ContentStreamHandlerBase
 
init(NamedList<?>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
init(NamedList<?>) - Method in class org.apache.solr.handler.DocumentAnalysisRequestHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.DumpRequestHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.PingRequestHandler
 
init(NamedList<?>) - Method in class org.apache.solr.handler.RequestHandlerBase
Initializes the SolrRequestHandler by creating three SolrParams named.
init(NamedList<?>) - Method in class org.apache.solr.handler.UpdateRequestHandler
 
init(NamedList<?>) - Method in class org.apache.solr.highlight.HighlightingPluginBase
 
init(NamedList<?>) - Method in class org.apache.solr.highlight.RegexFragmenter
 
init(NamedList<?>) - Method in interface org.apache.solr.request.SolrRequestHandler
init will be called just once, immediately after creation.
init(NamedList<?>) - Method in class org.apache.solr.response.JSONResponseWriter
 
init(NamedList<?>) - Method in class org.apache.solr.response.PHPResponseWriter
 
init(NamedList<?>) - Method in class org.apache.solr.response.PHPSerializedResponseWriter
 
init(NamedList<?>) - Method in class org.apache.solr.response.RawResponseWriter
 
init(NamedList<?>) - Method in class org.apache.solr.response.transform.ExplainAugmenterFactory
 
init(NamedList<?>) - Method in class org.apache.solr.response.transform.RawValueTransformerFactory
 
init(NamedList<?>) - Method in class org.apache.solr.response.transform.ShardAugmenterFactory
 
init(NamedList<?>) - Method in class org.apache.solr.response.transform.TransformerFactory
 
init(NamedList<?>) - Method in class org.apache.solr.response.transform.ValueAugmenterFactory
 
init(NamedList<?>) - Method in class org.apache.solr.schema.ClassicIndexSchemaFactory
 
init(NamedList<?>) - Method in class org.apache.solr.schema.ExternalFileFieldReloader
 
init(NamedList<?>) - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
init(NamedList<?>) - Method in class org.apache.solr.search.ComplexPhraseQParserPlugin
 
init(NamedList<?>) - Method in class org.apache.solr.search.JoinQParserPlugin
 
init(NamedList<?>) - Method in class org.apache.solr.search.SolrCoreParser
 
init(NamedList<?>) - Method in class org.apache.solr.search.XmlQParserPlugin
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.AbstractDefaultValueUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.AddSchemaFieldsUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.ConcatFieldUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.DefaultValueUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.DocExpirationUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.FieldLengthUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
Handles common initialization related to source fields for constructing the FieldNameSelector to be used.
init(NamedList<?>) - Method in class org.apache.solr.update.processor.FieldNameMutatingUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.IgnoreCommitOptimizeUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.IgnoreLargeDocumentProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.LogUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.ParseBooleanFieldUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.ParseDateFieldUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.ParseNumericFieldUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.PreAnalyzedUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.RegexpBoostProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.RegexReplaceProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.SkipExistingDocumentsProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.TruncateFieldUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.URLClassifyProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.update.processor.UUIDUpdateProcessorFactory
 
init(NamedList<?>) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreaker
 
init(NamedList<?>) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
init(NamedList<?>) - Method in interface org.apache.solr.util.plugin.NamedListInitializedPlugin
init will be called just once, immediately after creation.
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.FileBasedSpellChecker
 
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.IndexBasedSpellChecker
 
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.SolrSpellChecker
 
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.SolrSuggester
Uses the config and the core to initialize the underlying Lucene suggester
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.suggest.Suggester
 
init(NamedList<?>, SolrCore) - Method in class org.apache.solr.spelling.WordBreakSolrSpellChecker
 
init(PluginInfo) - Method in class org.apache.solr.handler.BlobHandler
 
init(PluginInfo) - Method in class org.apache.solr.handler.component.ExpandComponent
 
init(PluginInfo) - Method in class org.apache.solr.handler.component.HighlightComponent
 
init(PluginInfo) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
init(PluginInfo) - Method in class org.apache.solr.handler.component.SearchHandler
 
init(PluginInfo) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
 
init(PluginInfo) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter
 
init(PluginInfo) - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultHistogramSupplier
 
init(PluginInfo) - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultMeterSupplier
 
init(PluginInfo) - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultTimerSupplier
 
init(PluginInfo) - Method in class org.apache.solr.metrics.SolrCoreContainerReporter
 
init(PluginInfo) - Method in class org.apache.solr.metrics.SolrCoreReporter
 
init(PluginInfo) - Method in class org.apache.solr.metrics.SolrMetricReporter
Initializes a SolrMetricReporter with the plugin's configuration.
init(PluginInfo) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
init(PluginInfo) - Method in class org.apache.solr.search.stats.StatsCache
 
init(PluginInfo) - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain
Initializes the chain using the factories specified by the PluginInfo.
init(PluginInfo) - Method in class org.apache.solr.update.UpdateLog
 
init(PluginInfo) - Method in interface org.apache.solr.util.plugin.PluginInfoInitialized
 
init(PluginInfo, CoreContainer) - Method in class org.apache.solr.metrics.SolrCoreContainerReporter
 
init(PluginInfo, SolrCore) - Method in class org.apache.solr.metrics.SolrCoreReporter
 
init(SolrResourceLoader, NamedList<String>, ManagedResourceStorage.StorageIO) - Method in class org.apache.solr.rest.RestManager
Initializes the RestManager with the storageIO being optionally created outside of this implementation such as to use ZooKeeper instead of the local FS.
init(FieldType, ConfigNode) - Method in class org.apache.solr.schema.FieldTypePluginLoader
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.AbstractEnumField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.AbstractSubTypeFieldType
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.BBoxField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.CollationField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.CurrencyField
Deprecated.
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.CurrencyFieldType
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.DateRangeField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.DenseVectorField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.ExternalFileField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.FieldType
subclasses should initialize themselves with the args provided and remove valid arguments.
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.PointField
NOTE: This method can be removed completely when PointField.TEST_HACK_IGNORE_USELESS_TRIEFIELD_ARGS is removed
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.PointType
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.PreAnalyzedField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.PrimitiveFieldType
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.RankField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.RptWithGeometrySpatialField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.SortableTextField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.SpatialRecursivePrefixTreeFieldType
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.StrField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.TextField
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
init(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.UUIDField
 
init(UpdateHandler, SolrCore) - Method in class org.apache.solr.update.UpdateLog
 
init(T, ConfigNode) - Method in class org.apache.solr.util.plugin.AbstractPluginLoader
Initialize the plugin.
init(T, ConfigNode) - Method in class org.apache.solr.util.plugin.MapPluginLoader
 
init(T, ConfigNode) - Method in class org.apache.solr.util.plugin.NamedListPluginLoader
 
INIT_ARGS_JSON_FIELD - Static variable in class org.apache.solr.rest.ManagedResource
 
initArgs - Variable in class org.apache.solr.core.PluginInfo
 
initArgs - Variable in class org.apache.solr.handler.component.QueryElevationComponent
 
initArgs - Variable in class org.apache.solr.handler.RequestHandlerBase
 
initArgs - Variable in class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
 
initBooleanParsing(NamedList<?>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
initContext(ResponseBuilder) - Static method in class org.apache.solr.handler.component.FacetComponent.FacetContext
Initializes FacetContext using request parameters and saves it in the request context which can be retrieved via FacetComponent.FacetContext.getFacetContext(SolrQueryRequest)
initCoreContainer(CoreContainer) - Method in class org.apache.solr.core.DirectoryFactory
 
initDateTimeFormatters(NamedList<?>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
initDefaultPlugin(Object, Class<?>) - Method in class org.apache.solr.core.SolrCore
 
initHidden(SolrParams) - Static method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
INITIAL_CORE_LOAD_COMPLETE - Static variable in class org.apache.solr.core.CoreContainer
 
INITIAL_SIZE_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
initialize(int) - Method in class org.apache.solr.util.LongPriorityQueue
 
initialized - Variable in class org.apache.solr.handler.component.QueryElevationComponent
If QueryElevationComponent.inform(SolrCore) completed without error.
INITIALIZED_ON_JSON_FIELD - Static variable in class org.apache.solr.rest.ManagedResource
 
initializedOn - Variable in class org.apache.solr.rest.ManagedResource
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.core.SolrCore
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.component.SearchComponent
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.component.SearchHandler
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.component.SuggestComponent
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.ExportHandler
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.ReplicationHandler
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.handler.RequestHandlerBase
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.highlight.HighlightingPluginBase
 
initializeMetrics(SolrMetricsContext, String) - Method in interface org.apache.solr.metrics.SolrMetricProducer
Initialize metrics specific to this producer.
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.search.CaffeineCache
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.search.QParserPlugin
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.search.SolrFieldCacheBean
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.search.SolrIndexSearcher
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.security.AuditLoggerPlugin
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.security.AuthenticationPlugin
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.security.MultiAuthPlugin
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.security.MultiDestinationAuditLogger
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.update.PeerSync
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.update.PeerSyncWithLeader
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.update.UpdateLog
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.update.UpdateShardHandler
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
initializeMetrics(SolrMetricsContext, String) - Method in class org.apache.solr.util.stats.InstrumentedPoolingHttpClientConnectionManager
 
initialLimit - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
initialMincount - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
initialSearcher(SolrIndexSearcher) - Method in interface org.apache.solr.search.SolrCache
A hook for caches that would like to perform some initialization for the first registered searcher.
initialValue - Variable in class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
initialValue - Variable in class org.apache.solr.search.facet.SlotAcc.IntSlotAcc
 
initialValue - Variable in class org.apache.solr.search.facet.SlotAcc.LongFuncSlotAcc
 
initIndex() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
initInstance(Object, PluginInfo) - Static method in class org.apache.solr.core.PluginBag
 
initModules(SolrResourceLoader, String) - Static method in class org.apache.solr.core.NodeConfig
 
initNewInstance(SolrPackageLoader.SolrPackage.Version, SolrCore) - Method in class org.apache.solr.handler.StreamHandler.ExpressibleHolder
 
initNewInstance(SolrPackageLoader.SolrPackage.Version, SolrCore) - Method in class org.apache.solr.pkg.PackagePluginHolder
 
initParams - Variable in class org.apache.solr.handler.component.SpellCheckComponent
 
initParams - Variable in class org.apache.solr.handler.component.SuggestComponent
 
initParams - Variable in class org.apache.solr.handler.component.TermVectorComponent
 
InitParams - Class in org.apache.solr.core
An Object which represents a <initParams> tag
InitParams(PluginInfo) - Constructor for class org.apache.solr.core.InitParams
 
initPlugin(PluginInfo, T) - Static method in class org.apache.solr.core.SolrCore
 
initPluginForScheme(Map<String, Object>) - Method in class org.apache.solr.security.MultiAuthPlugin
 
initPluginForScheme(Map<String, Object>) - Method in class org.apache.solr.security.MultiAuthRuleBasedAuthorizationPlugin
 
initPlugins(List<PluginInfo>, Class<T>, String) - Method in class org.apache.solr.core.SolrCore
For a given List of PluginInfo return the instances as a List
initPlugins(List<PluginInfo>, Map<String, T>, Class<T>, String) - Method in class org.apache.solr.core.SolrCore
 
initPlugins(Map<String, T>, Class<T>) - Method in class org.apache.solr.core.SolrCore
 
initReader(String, Reader) - Method in class org.apache.solr.analysis.SolrAnalyzer
 
initReader(String, Reader) - Method in class org.apache.solr.analysis.TokenizerChain
 
initReaderForNormalization(String, Reader) - Method in class org.apache.solr.analysis.TokenizerChain
 
initRegenerators(SolrConfig) - Static method in class org.apache.solr.search.SolrIndexSearcher
 
initReplica(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
initReplicaWeights(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
initRestManager() - Method in class org.apache.solr.core.SolrCore
Creates and initializes a RestManager based on configuration args in solrconfig.xml.
initZooKeeper(CoreContainer, CloudConfig) - Method in class org.apache.solr.core.ZkContainer
 
injectDelayBeforeFollowerCommitRefresh() - Static method in class org.apache.solr.util.TestInjection
 
injectDirectUpdateLatch() - Static method in class org.apache.solr.util.TestInjection
 
injectDocSetDelay(Object) - Static method in class org.apache.solr.util.TestInjection
 
injectFailIndexFingerprintRequests() - Static method in class org.apache.solr.util.TestInjection
 
injectFailReplicaRequests() - Static method in class org.apache.solr.util.TestInjection
 
injectFailUpdateRequests() - Static method in class org.apache.solr.util.TestInjection
 
InjectionFactories - Class in org.apache.solr.jersey
 
InjectionFactories() - Constructor for class org.apache.solr.jersey.InjectionFactories
 
InjectionFactories.RequestContextBasedFactory - Class in org.apache.solr.jersey
Allows access to a ContainerRequestContext via a ServiceLocator
InjectionFactories.ReuseFromContextIndexSchemaFactory - Class in org.apache.solr.jersey
 
InjectionFactories.ReuseFromContextSolrCoreFactory - Class in org.apache.solr.jersey
Fetch the (existing) SolrCore from the request context
InjectionFactories.ReuseFromContextSolrParamsFactory - Class in org.apache.solr.jersey
 
InjectionFactories.SingletonFactory<T> - Class in org.apache.solr.jersey
 
InjectionFactories.SolrQueryRequestFactory - Class in org.apache.solr.jersey
 
InjectionFactories.SolrQueryResponseFactory - Class in org.apache.solr.jersey
 
injectLeaderTragedy(SolrCore) - Static method in class org.apache.solr.util.TestInjection
 
injectNonExistentCoreExceptionAfterUnload(String) - Static method in class org.apache.solr.util.TestInjection
 
injectNonGracefullClose(CoreContainer) - Static method in class org.apache.solr.util.TestInjection
 
injectPrepRecoveryOpPauseForever() - Static method in class org.apache.solr.util.TestInjection
 
injectRandomDelayInCoreCreation() - Static method in class org.apache.solr.util.TestInjection
 
injectReindexFailure() - Static method in class org.apache.solr.util.TestInjection
 
injectReindexLatch() - Static method in class org.apache.solr.util.TestInjection
 
injectSearcherHooks(String) - Static method in class org.apache.solr.util.TestInjection
 
injectSkipIndexWriterCommitOnClose(Object) - Static method in class org.apache.solr.util.TestInjection
injectSplitFailureAfterReplicaCreation() - Static method in class org.apache.solr.util.TestInjection
 
injectSplitFailureBeforeReplicaCreation() - Static method in class org.apache.solr.util.TestInjection
 
injectSplitLatch() - Static method in class org.apache.solr.util.TestInjection
 
injectTraceContext(HttpRequest) - Static method in class org.apache.solr.util.tracing.TraceUtils
 
injectTraceContext(Request, Span) - Static method in class org.apache.solr.util.tracing.TraceUtils
 
injectUIFOutOfMemoryError() - Static method in class org.apache.solr.util.TestInjection
 
injectUpdateLogReplayRandomPause() - Static method in class org.apache.solr.util.TestInjection
 
injectUpdateRandomPause() - Static method in class org.apache.solr.util.TestInjection
 
injectWrongIndexFingerprint() - Static method in class org.apache.solr.util.TestInjection
 
InMemoryStorageIO() - Constructor for class org.apache.solr.rest.ManagedResourceStorage.InMemoryStorageIO
 
InProgress - org.apache.solr.core.snapshots.CollectionSnapshotMetaData.SnapshotStatus
 
INPUT_ENCODING_KEY - Static variable in class org.apache.solr.servlet.SolrRequestParsers
 
INPUT_FIELD_PARAM - Static variable in class org.apache.solr.update.processor.RegexpBoostProcessor
 
input_stream - Variable in class org.apache.solr.parser.QueryParserTokenManager
 
inputFactory - Variable in class org.apache.solr.handler.loader.XMLLoader
 
inputValue - Variable in class org.apache.solr.util.vector.DenseVectorParser
 
insert(long) - Method in class org.apache.solr.util.LongPriorityQueue
inserts the element and returns true if this element caused another element to be dropped from the queue.
insertIfNotNull(Map<String, Object>, String, Object) - Static method in class org.apache.solr.handler.admin.api.AdminAPIBase
 
INSERTS_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
insertWithOverflow(long) - Method in class org.apache.solr.util.LongPriorityQueue
Adds an object to a PriorityQueue in log(size) time.
inst - Variable in class org.apache.solr.core.PluginBag.PluginHolder
 
install(String, String) - Method in class org.apache.solr.packagemanager.RepositoryManager
Install a version of the package.
installCoreData(String, InstallCoreDataRequestBody) - Method in class org.apache.solr.handler.admin.api.InstallCoreData
 
InstallCoreData - Class in org.apache.solr.handler.admin.api
V2 API implementation of the "Install Core Data" Core-Admin API
InstallCoreData(CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.InstallCoreData
 
INSTALLCOREDATA_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
InstallCoreDataOp - Class in org.apache.solr.handler.admin
v1 shim implementation of the "Install Core Data" API, a core-admin API used to implement the "Install Shard Data" Collection-Admin functionality
InstallCoreDataOp() - Constructor for class org.apache.solr.handler.admin.InstallCoreDataOp
 
installShardData(String, String, InstallShardDataRequestBody) - Method in class org.apache.solr.handler.admin.api.InstallShardData
 
InstallShardData - Class in org.apache.solr.handler.admin.api
V2 API implementation allowing users to import offline-constructed index into a shard.
InstallShardData(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.InstallShardData
 
INSTALLSHARDDATA_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
InstallShardDataCmd - Class in org.apache.solr.cloud.api.collections
Overseer processing for the "install shard data" API.
InstallShardDataCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.InstallShardDataCmd
 
InstallShardDataCmd.RemoteMessage - Class in org.apache.solr.cloud.api.collections
A value-type representing the message received by InstallShardDataCmd
INSTANCE - Static variable in class org.apache.solr.metrics.MetricSuppliers.NoOpCounterSupplier
 
INSTANCE - Static variable in class org.apache.solr.metrics.MetricSuppliers.NoOpGauge
 
INSTANCE - Static variable in class org.apache.solr.metrics.MetricSuppliers.NoOpHistogramSupplier
 
INSTANCE - Static variable in class org.apache.solr.metrics.MetricSuppliers.NoOpMeterSupplier
 
INSTANCE - Static variable in class org.apache.solr.metrics.MetricSuppliers.NoOpTimerSupplier
 
INSTANCE - Static variable in class org.apache.solr.util.FileTypeMagicUtil
 
INSTANCE - Static variable in class org.apache.solr.util.SolrJacksonAnnotationInspector
 
INSTANCE_TAG - Static variable in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter
 
instantiate(NodeConfig) - Static method in interface org.apache.solr.core.CoresLocator
Returns a new instance of CoresLocator, depending on provided config.
instantiateJerseyResponse(Class<T>) - Method in class org.apache.solr.api.JerseyResource
Create an instance of the SolrJerseyResponse subclass; registering it with the Jersey request-context upon creation.
instantiateJerseyResponse(Supplier<T>) - Method in class org.apache.solr.api.JerseyResource
Create an instance of the SolrJerseyResponse subclass; registering it with the Jersey request-context upon creation.
instrumentedExecutorService(ExecutorService, SolrInfoBean, MetricRegistry, String) - Static method in class org.apache.solr.util.stats.MetricUtils
Returns an instrumented wrapper over the given executor service.
InstrumentedHttpListenerFactory - Class in org.apache.solr.util.stats
A HttpListenerFactory tracking metrics and distributed tracing.
InstrumentedHttpListenerFactory(InstrumentedHttpListenerFactory.NameStrategy) - Constructor for class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
InstrumentedHttpListenerFactory.NameStrategy - Interface in org.apache.solr.util.stats
 
InstrumentedHttpRequestExecutor - Class in org.apache.solr.util.stats
Sub-class of HttpRequestExecutor which tracks metrics interesting to solr Inspired and partially copied from dropwizard httpclient library
InstrumentedHttpRequestExecutor(int, HttpClientMetricNameStrategy) - Constructor for class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
InstrumentedHttpRequestExecutor(HttpClientMetricNameStrategy) - Constructor for class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
InstrumentedPoolingHttpClientConnectionManager - Class in org.apache.solr.util.stats
Sub-class of PoolingHttpClientConnectionManager which tracks metrics interesting to Solr.
InstrumentedPoolingHttpClientConnectionManager(Registry<ConnectionSocketFactory>) - Constructor for class org.apache.solr.util.stats.InstrumentedPoolingHttpClientConnectionManager
 
INT - org.apache.solr.legacy.LegacyNumericType
Deprecated.
32-bit integer numeric type
INT_POINT_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
A parser instance for int values encoded by NumericUtils, e.g.
int2sortableStr(int) - Static method in class org.apache.solr.util.NumberUtils
 
int2sortableStr(int, char[], int) - Static method in class org.apache.solr.util.NumberUtils
 
int2sortableStr(String) - Static method in class org.apache.solr.util.NumberUtils
 
INT32_TERM_PREFIX - Static variable in interface org.apache.solr.uninverting.FieldCache
INT64_TERM_PREFIX - Static variable in interface org.apache.solr.uninverting.FieldCache
IntAsc() - Constructor for class org.apache.solr.handler.export.IntComp.IntAsc
 
IntComp - Interface in org.apache.solr.handler.export
 
IntComp.IntAsc - Class in org.apache.solr.handler.export
 
IntComp.IntDesc - Class in org.apache.solr.handler.export
 
IntComparator() - Constructor for class org.apache.solr.util.PrimUtils.IntComparator
 
IntDesc() - Constructor for class org.apache.solr.handler.export.IntComp.IntDesc
 
INTEGER - org.apache.solr.schema.NumberType
 
INTEGER_POINT - org.apache.solr.uninverting.UninvertingReader.Type
Single-valued Integer, (e.g.
interceptInternodeRequest(HttpRequest, HttpContext) - Method in class org.apache.solr.security.AuthenticationPlugin
Override this method to intercept internode requests.
interceptInternodeRequest(HttpRequest, HttpContext) - Method in class org.apache.solr.security.BasicAuthPlugin
 
interceptInternodeRequest(HttpRequest, HttpContext) - Method in class org.apache.solr.security.MultiAuthPlugin
 
interceptInternodeRequest(Request) - Method in class org.apache.solr.security.AuthenticationPlugin
Override this method to intercept internode requests.
interceptInternodeRequest(Request) - Method in class org.apache.solr.security.BasicAuthPlugin
 
interceptInternodeRequest(Request) - Method in class org.apache.solr.security.MultiAuthPlugin
 
InterestingTerm() - Constructor for class org.apache.solr.handler.MoreLikeThisHandler.InterestingTerm
 
INTERNAL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
INTERNAL_DISTANCE - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
INTERNAL_POLY_FIELD_PREFIX - Static variable in class org.apache.solr.schema.IndexSchema
 
INTERNAL_RANK_FIELD_NAME - Static variable in class org.apache.solr.schema.RankField
 
INTERNAL_REQUEST_COUNT - Static variable in class org.apache.solr.servlet.HttpSolrCall
 
internalName - Variable in class org.apache.solr.cluster.placement.impl.MetricImpl
 
intersection(int[], int, int[], int, int[]) - Static method in class org.apache.solr.search.SortedIntDocSet
puts the intersection of a and b into the target array and returns the size
intersection(DocSet) - Method in class org.apache.solr.search.BitDocSet
 
intersection(DocSet) - Method in class org.apache.solr.search.DocSet
Returns the intersection of this set with another set.
intersection(DocSet) - Method in class org.apache.solr.search.SortedIntDocSet
 
intersectionBinarySearch(int[], int, int[], int, int[]) - Static method in class org.apache.solr.search.SortedIntDocSet
Puts the intersection of a and b into the target array and returns the size.
intersectionSize(int[], int[]) - Static method in class org.apache.solr.search.SortedIntDocSet
 
intersectionSize(DocSet) - Method in class org.apache.solr.search.BitDocSet
 
intersectionSize(DocSet) - Method in class org.apache.solr.search.DocSet
Returns the number of documents of the intersection of this set with another set.
intersectionSize(DocSet) - Method in class org.apache.solr.search.SortedIntDocSet
 
intersects(int[], int[]) - Static method in class org.apache.solr.search.SortedIntDocSet
 
intersects(DocSet) - Method in class org.apache.solr.search.BitDocSet
 
intersects(DocSet) - Method in class org.apache.solr.search.DocSet
Returns true if these sets have any elements in common
intersects(DocSet) - Method in class org.apache.solr.search.SortedIntDocSet
 
intersects(DocSet, SolrIndexSearcher.DocsEnumState) - Method in class org.apache.solr.search.SolrIndexSearcher
 
interval - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
INTERVAL_ERR_MSG - Static variable in class org.apache.solr.handler.ReplicationHandler
 
intervalFacets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
IntervalFacets - Class in org.apache.solr.request
Computes interval facets for docvalues field (single or multivalued).
IntervalFacets(SchemaField, SolrIndexSearcher, DocSet, String[], SolrParams) - Constructor for class org.apache.solr.request.IntervalFacets
Constructor that accepts un-parsed intervals using "interval faceting" syntax.
IntervalFacets(SchemaField, SolrIndexSearcher, DocSet, IntervalFacets.FacetInterval[]) - Constructor for class org.apache.solr.request.IntervalFacets
Constructor that accepts an already constructed array of IntervalFacets.FacetInterval objects.
IntervalFacets.FacetInterval - Class in org.apache.solr.request
Helper class to match and count of documents in specified intervals
IntFloatDynamicMap - Class in org.apache.solr.util
 
IntFloatDynamicMap(int, float) - Constructor for class org.apache.solr.util.IntFloatDynamicMap
Create map with expected max value of key.
IntIntDynamicMap - Class in org.apache.solr.util
 
IntIntDynamicMap(int, int) - Constructor for class org.apache.solr.util.IntIntDynamicMap
Create map with expected max value of key.
IntLongDynamicMap - Class in org.apache.solr.util
 
IntLongDynamicMap(int, long) - Constructor for class org.apache.solr.util.IntLongDynamicMap
Create map with expected max value of key.
IntPointField - Class in org.apache.solr.schema
PointField implementation for Integer values.
IntPointField() - Constructor for class org.apache.solr.schema.IntPointField
 
IntRangeBuilder() - Constructor for class org.apache.solr.legacy.LegacyNumericUtils.IntRangeBuilder
Deprecated.
 
IntrospectApi(Api, boolean) - Constructor for class org.apache.solr.api.ApiBag.IntrospectApi
 
IntSlotAcc(FacetContext, int, int) - Constructor for class org.apache.solr.search.facet.SlotAcc.IntSlotAcc
 
intToBytes(int) - Static method in class org.apache.solr.util.NumberUtils
 
intToPrefixCoded(int, int, BytesRefBuilder) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns prefix coded bits after reducing the precision by shift bits.
intVal(int) - Method in class org.apache.solr.search.function.CollapseScoreFunction.CollapseScoreFunctionValues
 
IntValue - Class in org.apache.solr.handler.export
 
IntValue(String, IntComp) - Constructor for class org.apache.solr.handler.export.IntValue
 
IntValueFieldType - Interface in org.apache.solr.schema
Marker interface for int-valued field types.
intValueToStringValue(Integer) - Method in class org.apache.solr.schema.AbstractEnumField.EnumMapping
Converting the (internal) integer value (indicating the sort order) to string (displayed) value
INVALID_LEXICAL_STATE - Static variable in error org.apache.solr.parser.TokenMgrError
Tried to change to an invalid lexical state.
invalidState - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
Set to true if we ever get a BadVersionException so that we can disallow future operations with this instance
invalidStates - Variable in class org.apache.solr.servlet.HttpSolrCall
 
invariants - Variable in class org.apache.solr.core.InitParams
 
invariants - Variable in class org.apache.solr.handler.RequestHandlerBase
 
INVARIANTS - Static variable in class org.apache.solr.core.PluginInfo
 
INVARIANTS - Static variable in class org.apache.solr.core.RequestParams
 
invoke(String, Object[], String[]) - Method in class org.apache.solr.metrics.MetricsMap
 
invoke(SolrQueryRequest, SolrQueryResponse, BaseHandlerApiSupport) - Method in interface org.apache.solr.handler.admin.BaseHandlerApiSupport.ApiCommand
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.BalanceShardUnique
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.CreateShard
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.DeleteCollectionBackup
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.ForceLeader
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.ListCollectionBackups
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.ReloadCollectionAPI
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.RenameCollection
 
invokeFromV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.SyncShard
 
invokeFromV1Params(SolrQueryRequest, SolrQueryResponse, CoreContainer) - Static method in class org.apache.solr.handler.admin.api.CreateCollectionBackup
 
invokeFromV1Params(SolrQueryRequest, SolrQueryResponse, CoreContainer) - Static method in class org.apache.solr.handler.admin.api.RestoreCollectionAPI
 
invokeSetters(Object, Iterable<? extends Map.Entry<String, ?>>) - Static method in class org.apache.solr.util.SolrPluginUtils
 
invokeSetters(Object, Iterable<? extends Map.Entry<String, ?>>, boolean) - Static method in class org.apache.solr.util.SolrPluginUtils
 
invokeSetters(MergePolicy) - Method in class org.apache.solr.index.MergePolicyFactoryArgs
 
invokeUsingV1Inputs(DeleteNode, SolrParams) - Static method in class org.apache.solr.handler.admin.api.DeleteNode
 
invokeUsingV1Inputs(DeleteReplicaProperty, SolrParams) - Static method in class org.apache.solr.handler.admin.api.DeleteReplicaProperty
 
invokeWithV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.DeleteReplica
 
invokeWithV1Params(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.handler.admin.api.DeleteShard
 
IOCONTEXT_NO_CACHE - Static variable in class org.apache.solr.core.DirectoryFactory
 
IOFunction<T,​R> - Interface in org.apache.solr.util
A Function that may throw an IOException
IS_RECORDING - Static variable in class org.apache.solr.util.tracing.TraceUtils
this should only be changed in the context of testing, otherwise it would risk not recording trace data.
IS_REFINEMENT - Static variable in class org.apache.solr.search.facet.FacetContext
 
IS_SHARD - Static variable in class org.apache.solr.search.facet.FacetContext
 
isAbsolute(String) - Method in class org.apache.solr.core.DirectoryFactory
 
isAbsolute(String) - Method in class org.apache.solr.core.EphemeralDirectoryFactory
 
isAcquired() - Method in interface org.apache.solr.cloud.DistributedLock
 
isAcquired() - Method in class org.apache.solr.cloud.DistributedMultiLock
 
isActive() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
For unit tests.
isAddHttpRequestToContext() - Method in class org.apache.solr.core.SolrConfig
 
isAddRequestHeadersToContext() - Method in class org.apache.solr.servlet.SolrRequestParsers
 
isAllBuckets() - Method in class org.apache.solr.search.facet.SlotAcc.SlotContext
 
isAllowSubQueryParsing() - Method in class org.apache.solr.parser.SolrQueryParserBase
 
isAnalytics() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isAtomicUpdate(AddUpdateCommand) - Static method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
Utility method that examines the SolrInputDocument in an AddUpdateCommand and returns true if the documents contains atomic update instructions.
isAutoGeneratedConfigSet(String) - Static method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
isAutowarmingOn() - Method in class org.apache.solr.search.SolrCacheBase
 
isAutoWarmingOn() - Method in class org.apache.solr.search.SolrCacheBase.AutoWarmCountRef
 
isBoolean(List<Object>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
isBuffer - Variable in class org.apache.solr.update.TransactionLog
 
isCacheable(LeafReaderContext) - Method in class org.apache.solr.search.join.GraphQuery.GraphQueryWeight
 
isCachingEnabled() - Method in class org.apache.solr.search.SolrIndexSearcher
 
isCancellation() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
ISchemaVersion - Interface in org.apache.solr.util.hll
A serialization schema for HLLs.
isClosed - Variable in class org.apache.solr.cloud.Overseer.OverseerThread
 
isClosed() - Method in class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
 
isClosed() - Method in class org.apache.solr.cloud.Overseer
 
isClosed() - Method in class org.apache.solr.cloud.Overseer.OverseerThread
 
isClosed() - Method in class org.apache.solr.cloud.OverseerTaskProcessor
 
isClosed() - Method in class org.apache.solr.cloud.RecoveryStrategy
 
isClosed() - Method in class org.apache.solr.core.SolrCore
Whether this core is closed.
isCollectionCreation() - Method in enum org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
Given only one command creates a collection DistributedClusterStateUpdater.MutatingCommand.ClusterCreateCollection, the default implementation is provided here.
isCommentingDisabled() - Method in class org.apache.solr.internal.csv.CSVStrategy
 
isConfigSetTrusted() - Method in class org.apache.solr.core.CoreDescriptor
 
isConfigSetTrusted(String) - Method in class org.apache.solr.core.ConfigSetService
Return whether the given configSet is trusted.
isConfigSetTrusted(SolrResourceLoader) - Method in class org.apache.solr.core.ConfigSetService
Return whether the configSet used for the given resourceLoader is trusted.
isConnected() - Method in class org.apache.solr.cloud.ZkController
 
isConstantScoreQuery(Query) - Static method in class org.apache.solr.search.QueryUtils
Recursively unwraps the specified query to determine whether it is capable of producing a score that varies across different documents.
isCopyFieldTarget(SchemaField) - Method in class org.apache.solr.schema.IndexSchema
Check if a field is used as the destination of a copyField operation
isCoreLoading(String) - Method in class org.apache.solr.core.CoreContainer
 
isCoreLoading(String) - Method in class org.apache.solr.core.SolrCores
 
isCreateCollectionCheckLeaderActive() - Method in class org.apache.solr.core.CloudConfig
 
isDateTime(List<Object>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
isDebug() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isDebugAll() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isDebugQuery() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isDebugResults() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isDebugTimings() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isDebugTrack() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isDefault() - Method in class org.apache.solr.core.PluginInfo
 
isDefined() - Method in class org.apache.solr.handler.admin.SolrEnvironment
 
isDeleteById() - Method in class org.apache.solr.update.DeleteUpdateCommand
 
isDeleted() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage
 
isDerivedFromDoc(SolrInputDocument, SolrInputDocument) - Static method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
isDir() - Method in interface org.apache.solr.filestore.FileStore.FileDetails
 
isDistributed() - Method in class org.apache.solr.handler.component.ResponseBuilder
This function will return true if this was a distributed search request.
isDistributedCollectionAPI() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
When this method returns true, Overseer specific actions do not make sense and commands should not be doing them.
isDistributedCollectionAPI() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
isDistributedCollectionAPI() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
isDistributedStateUpdate() - Method in class org.apache.solr.cloud.DistributedClusterStateUpdater
When this method returns false the legacy behavior of enqueueing cluster state update messages to Overseer should be used and no other method of this class should be called.
isDuplicateDynField(List<IndexSchema.DynamicField>, SchemaField) - Method in class org.apache.solr.schema.IndexSchema
 
isDynamicField(String) - Method in class org.apache.solr.schema.IndexSchema
Is the specified field dynamic or not.
isEditableProp(String, boolean, List<String>) - Static method in class org.apache.solr.core.ConfigOverlay
 
isEmpty() - Method in class org.apache.solr.logging.CircularList
 
isEmpty() - Method in class org.apache.solr.metrics.AggregateMetric
 
isEmpty() - Method in class org.apache.solr.uninverting.DocTermOrds
Returns true if no terms were indexed.
isEmpty() - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain.ProcessorInfo
 
isEmpty() - Method in class org.apache.solr.util.MapListener
 
isEnabled - Variable in class org.apache.solr.core.RateLimiterConfig
 
isEnabled() - Method in class org.apache.solr.core.MetricsConfig
 
isEnabled() - Method in class org.apache.solr.core.PluginInfo
 
isEnabled() - Method in class org.apache.solr.handler.admin.MetricsHandler
 
isEnabled() - Static method in class org.apache.solr.handler.api.V2ApiUtils
 
isEnabled() - Method in class org.apache.solr.logging.LogWatcherConfig
 
isEnabled() - Method in class org.apache.solr.pkg.PackageAPI
 
isEnabled() - Method in class org.apache.solr.security.AllowListUrlChecker
Whether the URL checking is enabled.
isEnabled() - Method in class org.apache.solr.update.processor.RegexpBoostProcessor
 
isEnabled() - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
isEnabled() - Method in class org.apache.solr.update.processor.URLClassifyProcessor
 
isEnabled(String) - Method in class org.apache.solr.update.LoggingInfoStream
 
isEnabled(SolrRequest.SolrRequestType) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
isEnableRemoteStreams() - Method in class org.apache.solr.servlet.SolrRequestParsers
 
isEqual(String) - Method in enum org.apache.solr.cloud.overseer.OverseerAction
 
isExpensive() - Method in class org.apache.solr.handler.admin.api.MergeIndexes
 
isExpensive() - Method in interface org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminOp
 
isExpensive() - Method in enum org.apache.solr.handler.admin.CoreAdminOperation
 
isExplicitAnalyzer() - Method in class org.apache.solr.schema.FieldType
 
isExplicitMultiTermAnalyzer() - Method in class org.apache.solr.schema.TextField
 
isExplicitQueryAnalyzer() - Method in class org.apache.solr.schema.FieldType
 
isExplicitSimilarity - Variable in class org.apache.solr.schema.IndexSchema
 
isFieldCache(SortedDocValues) - Static method in class org.apache.solr.search.facet.FieldUtil
 
isFieldUsed(SchemaField) - Method in class org.apache.solr.schema.PointField
 
isFileForbiddenInConfigset(byte[]) - Static method in class org.apache.solr.util.FileTypeMagicUtil
Determine forbidden file type based on magic bytes matching of the first bytes of the file.
isFileForbiddenInConfigset(Path) - Static method in class org.apache.solr.util.FileTypeMagicUtil
Determine forbidden file type based on magic bytes matching of the file itself.
isFilter() - Method in class org.apache.solr.search.QParser
 
isFinished() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
isFinished() - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletInputStream
 
isFloatOrDouble(List<Object>, Locale) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
isFollower() - Method in class org.apache.solr.handler.ReplicationHandler
 
isFromSolrConfig() - Method in class org.apache.solr.core.PluginInfo
 
isFromZookeeper() - Method in class org.apache.solr.core.NodeConfig
True if this node config was loaded from zookeeper
isGroupFacet() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
isHandleSelect() - Method in class org.apache.solr.core.SolrConfig
 
isHandleSelect() - Method in class org.apache.solr.servlet.SolrRequestParsers
 
isHardEnd() - Method in class org.apache.solr.handler.component.RangeFacetRequest
 
isHiddenFile(SolrQueryRequest, SolrQueryResponse, String, boolean, Set<String>) - Static method in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
isHighlightingEnabled(SolrParams) - Method in class org.apache.solr.highlight.SolrHighlighter
Check whether Highlighting is enabled for this request.
isHttpCaching() - Method in class org.apache.solr.response.SolrQueryResponse
Should this response emit HTTP caching headers?
isIncludeGroupCount() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
isIncludeLower() - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
isIncludeUpper() - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
isIndexChanged - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
isInPlaceUpdate() - Method in class org.apache.solr.update.AddUpdateCommand
Is this add update an in-place update? An in-place update is one where only docValues are updated, and a new document is not indexed.
isInterceptorRegistered() - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
isInternalShardRequest(SolrQueryRequest) - Static method in class org.apache.solr.handler.RequestHandlerBase
Checks whether the given request is an internal request to a shard.
isIntOrLong(List<Object>, Locale) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
isJarInuse(String) - Method in class org.apache.solr.pkg.PackageAPI
 
isLandingPage(URL) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
Calculates whether the URL is a landing page or not
isLarge() - Method in class org.apache.solr.schema.SchemaField
 
isLastDocInBatch - Variable in class org.apache.solr.update.AddUpdateCommand
 
isLazyFieldLoadingEnabled() - Method in class org.apache.solr.search.SolrDocumentFetcher
 
isLeader - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
isLeader() - Method in class org.apache.solr.cloud.CloudDescriptor
 
isLeader() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
isList(Map<String, Object>, List<String>, String, Object, Object) - Method in class org.apache.solr.request.json.ObjectUtil.ConflictHandler
 
isLoaded() - Method in class org.apache.solr.core.PluginBag.LazyPluginHolder
 
isLoaded() - Method in class org.apache.solr.core.PluginBag.PluginHolder
 
isLoaded(String) - Method in class org.apache.solr.core.CoreContainer
Determines whether the core is already loaded or not but does NOT load the core
isLoaded(String) - Method in class org.apache.solr.core.PluginBag
To check if a plugin by a specified name is already loaded
isLoaded(String) - Method in class org.apache.solr.core.SolrCores
 
isLoaded(String) - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
isLoadedNotPendingClose(String) - Method in class org.apache.solr.core.SolrCores
 
isLoadOnStartup() - Method in class org.apache.solr.core.CoreDescriptor
 
isMain() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
isMatchingEtag(List<String>, String) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Checks if one of the tags in the list equals the given etag.
isMergeContiguousFragments(String, SolrParams) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Return whether adjacent fragments should be merged.
isMetaDataFile(String) - Static method in class org.apache.solr.filestore.DistribFileStore
 
isMultipart(HttpServletRequest) - Static method in class org.apache.solr.servlet.SolrRequestParsers
 
isMultiValued() - Method in class org.apache.solr.schema.FieldType
Returns true if fields can have multiple values
isMultiValued(String, List<SolrInputDocument>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
isMultiValued(String, List<SolrInputDocument>) - Method in interface org.apache.solr.handler.designer.SchemaSuggester
 
isMultiValued(List<Object>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
isMutable() - Method in class org.apache.solr.schema.IndexSchema
 
isMutable() - Method in class org.apache.solr.schema.ManagedIndexSchema
 
isMutable() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
isNeedDocList() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isNeedDocSet() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isNeedDocSet() - Method in class org.apache.solr.search.QueryCommand
 
isNeedScore() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
isNegative(Query) - Static method in class org.apache.solr.search.QueryUtils
return true if this query has no positive components
isNever304() - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
 
isOlapAnalytics() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isOn(String) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Tests if a string is either "true", "on", "yes" or "1"
isOnlyLeafNodes() - Method in class org.apache.solr.search.join.GraphQuery
 
isOriginalToQuery(String) - Method in class org.apache.solr.handler.component.SpellCheckMergeData
 
isOverseerAllowedOrPreferred() - Method in class org.apache.solr.core.NodeRoles
 
isPartialResults() - Method in class org.apache.solr.search.QueryResult
 
isPerReplicaStateCollection - Variable in class org.apache.solr.cloud.overseer.ZkWriteCommand
 
isPersistent() - Method in class org.apache.solr.core.DirectoryFactory
 
isPersistent() - Method in class org.apache.solr.core.EphemeralDirectoryFactory
 
isPersistent() - Method in class org.apache.solr.core.StandardDirectoryFactory
 
isPhrase - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
isPingDisabled() - Method in class org.apache.solr.handler.PingRequestHandler
Returns true if the healthcheck flag-file is enabled but does not exist, otherwise (no file configured, or file configured and exists) returns false.
isPointField() - Method in class org.apache.solr.schema.FieldType
 
isPointField() - Method in class org.apache.solr.schema.PointField
 
isPolyField() - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
isPolyField() - Method in class org.apache.solr.schema.CurrencyFieldType
 
isPolyField() - Method in class org.apache.solr.schema.FieldType
A "polyField" is a FieldType that can produce more than one IndexableField instance for a single value, via the FieldType.createFields(org.apache.solr.schema.SchemaField, Object) method.
isPolyField() - Method in class org.apache.solr.schema.PointType
 
isPolyField() - Method in class org.apache.solr.schema.SchemaField
If true, then use SchemaField.createFields(Object), else use SchemaField.createField(java.lang.Object) to save an extra allocation
isPortAvailable(int) - Method in class org.apache.solr.cli.RunExampleTool
 
isPresent() - Method in class org.apache.solr.handler.export.IntValue
 
isPresent() - Method in class org.apache.solr.handler.export.LongValue
 
isQueryCancellable() - Method in class org.apache.solr.search.QueryCommand
 
isQueryIdActive(String) - Method in class org.apache.solr.core.CancellableQueryTracker
 
isRangeShouldBeProtectedFromReverse(String, String) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.solr.jersey.MessageBodyReaders.CachingDelegatingMessageBodyReader
 
isReady() - Method in class org.apache.solr.core.ClusterSingletons
Return true when this helper is ready to be used for singleton management.
isReady() - Method in class org.apache.solr.core.SolrCore
Returns true if the core is ready for use.
isReady() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
isReady() - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
isReady() - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletInputStream
 
isReady() - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletOutputStream
 
isRecovering(String) - Method in class org.apache.solr.cloud.ZkShardTerms
 
isRecursionSupported() - Method in class org.apache.solr.search.CaffeineCache
 
isRecursionSupported() - Method in interface org.apache.solr.search.SolrCache
Check if this SolrCache supports recursive calls to SolrCache.computeIfAbsent(Object, IOFunction).
isRefinementsRequired() - Method in class org.apache.solr.handler.component.PivotFacet
If true, then additional refinement requests are needed to flesh out the correct counts for this Pivot
isReloaded() - Method in class org.apache.solr.core.SolrCore
 
isRequired() - Method in class org.apache.solr.schema.SchemaField
 
isReturnRoot() - Method in class org.apache.solr.search.join.GraphQuery
 
isRootLogger(String) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
isSchemaFieldTypeCompatible(FieldType) - Method in class org.apache.solr.update.processor.ParseDoubleFieldUpdateProcessorFactory
 
isSchemaFieldTypeCompatible(FieldType) - Method in class org.apache.solr.update.processor.ParseFloatFieldUpdateProcessorFactory
 
isSchemaFieldTypeCompatible(FieldType) - Method in class org.apache.solr.update.processor.ParseIntFieldUpdateProcessorFactory
 
isSchemaFieldTypeCompatible(FieldType) - Method in class org.apache.solr.update.processor.ParseLongFieldUpdateProcessorFactory
 
isSchemaFieldTypeCompatible(FieldType) - Method in class org.apache.solr.update.processor.ParseNumericFieldUpdateProcessorFactory
Returns true if the given FieldType is compatible with this parsing factory.
isSet() - Method in class org.apache.solr.logging.jul.JulInfo
 
isSet() - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher.Log4j2Info
 
isSet() - Method in class org.apache.solr.logging.LoggerInfo
 
isShard() - Method in class org.apache.solr.search.facet.FacetContext
 
isSharedFs(CoreDescriptor) - Method in class org.apache.solr.core.CoreContainer
 
isSharedStorage() - Method in class org.apache.solr.core.DirectoryFactory
 
isShutDown() - Method in class org.apache.solr.core.CoreContainer
 
isSignalCacheWarning() - Method in class org.apache.solr.search.Grouping
Returns whether a cache warning should be send to the client.
isSlotBorrowingEnabled - Variable in class org.apache.solr.core.RateLimiterConfig
 
isSnapshotExists(String, Replica) - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
isSnapshotted(long) - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
This method returns if snapshot is created for the specified generation number in the *current* index directory.
isSnapshotted(String, long) - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
This method returns if snapshot is created for the specified generation number in the specified index directory.
isStarted() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
For unit tests.
isSubsetMatchPolicy(String) - Method in class org.apache.solr.handler.component.QueryElevationComponent
 
isSubShardLeader - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
isSuccess() - Method in class org.apache.solr.update.PeerSync.PeerSyncResult
 
isSuggestionsMayOverlap() - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
isSuggestionsMayOverlap() - Method in class org.apache.solr.spelling.SolrSpellChecker
 
isSuggestionsMayOverlap() - Method in class org.apache.solr.spelling.WordBreakSolrSpellChecker
 
isSupportedFieldForInPlaceUpdate(SchemaField) - Static method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
Given a schema field, return whether or not such a field is supported for an in-place update.
isSysPropHidden(String) - Method in class org.apache.solr.core.NodeConfig
Returns whether a given system property is hidden
isTaggable() - Method in interface org.apache.solr.handler.tagger.TaggingAttribute
Getter for the taggable state of the current Token
isTaggable() - Method in class org.apache.solr.handler.tagger.TaggingAttributeImpl
 
isTaskListRequest() - Method in class org.apache.solr.handler.component.ResponseBuilder
 
isText(List<Object>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
isTimeoutEnabled() - Method in class org.apache.solr.search.SolrQueryTimeoutImpl
 
isTokenized() - Method in class org.apache.solr.schema.AbstractEnumField
 
isTokenized() - Method in class org.apache.solr.schema.FieldType
Returns true if fields of this type should be tokenized
isTokenized() - Method in class org.apache.solr.schema.PointField
 
isTokenized() - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
isTopLevelPage(URL) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
Calculates whether a URL is a top level page
isTransient() - Method in class org.apache.solr.core.CoreDescriptor
 
isTripped() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreaker
Check if circuit breaker is tripped.
isTripped() - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
isTripped() - Method in class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
 
isTripped() - Method in class org.apache.solr.util.circuitbreaker.LoadAverageCircuitBreaker
 
isTripped() - Method in class org.apache.solr.util.circuitbreaker.MemoryCircuitBreaker
 
isTruncateGroups() - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
isTrusted() - Method in class org.apache.solr.core.ConfigSet
 
isTrusted(Principal, AuthenticationPlugin) - Static method in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
isUninvertible() - Method in class org.apache.solr.schema.SchemaField
 
isUsableForChildDocs() - Method in class org.apache.solr.schema.IndexSchema
Helper method that returns true if the IndexSchema.ROOT_FIELD_NAME uses the exact same 'type' as the IndexSchema.getUniqueKeyField()
isUseAutn() - Method in class org.apache.solr.search.join.GraphQuery
 
isUserDefinedProperty(String) - Static method in class org.apache.solr.core.CoreDescriptor
Is this property a Solr-standard property, or is it an extra property defined per-core by the user?
isUtf8Field() - Method in class org.apache.solr.schema.FieldType
 
isUtf8Field() - Method in class org.apache.solr.schema.StrField
 
isUtf8Field() - Method in class org.apache.solr.schema.TextField
 
isV2Enabled - Variable in class org.apache.solr.servlet.SolrDispatchFilter
 
isValidConfig(File, String) - Method in class org.apache.solr.cli.RunExampleTool
 
isValidDynamicField(List<IndexSchema.DynamicField>, SchemaField) - Method in class org.apache.solr.schema.IndexSchema
 
isValidFieldGlob(String) - Static method in class org.apache.solr.schema.IndexSchema
Returns true if the given name has exactly one asterisk either at the start or end of the name
isValidName(String) - Static method in class org.apache.solr.util.ModuleUtils
Returns true if module name is valid
isWritable(String) - Method in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.solr.jersey.MessageBodyWriters.BaseMessageBodyWriter
 
isZooKeeperAware() - Method in class org.apache.solr.core.CoreContainer
 
Item(Object, long) - Constructor for class org.apache.solr.handler.admin.IndexSizeEstimator.Item
 
ItemPriorityQueue(int) - Constructor for class org.apache.solr.handler.admin.IndexSizeEstimator.ItemPriorityQueue
 
Iter() - Constructor for class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
IterativeMergeStrategy - Class in org.apache.solr.handler.component
 
IterativeMergeStrategy() - Constructor for class org.apache.solr.handler.component.IterativeMergeStrategy
 
IterativeMergeStrategy.CallBack - Class in org.apache.solr.handler.component
 
iterator() - Method in interface org.apache.solr.cluster.Cluster
 
iterator() - Method in interface org.apache.solr.cluster.placement.CollectionMetrics
 
iterator() - Method in interface org.apache.solr.cluster.placement.ReplicaMetrics
 
iterator() - Method in interface org.apache.solr.cluster.placement.ShardMetrics
 
iterator() - Method in interface org.apache.solr.cluster.Shard
 
iterator() - Method in interface org.apache.solr.cluster.SolrCollection
 
iterator() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Iterator over all elements in this Collection, including the result of PivotFacetFieldValueCollection.getMissingValue() as the last element (if it exists)
iterator() - Method in class org.apache.solr.logging.CircularList
 
iterator() - Method in class org.apache.solr.request.IntervalFacets
Iterate over all the intervals
iterator() - Method in class org.apache.solr.search.BitDocSet
 
iterator() - Method in interface org.apache.solr.search.DocList
Returns an iterator that may be used to iterate over the documents in this DocList
iterator() - Method in class org.apache.solr.search.DocSet
Returns an ordered iterator of the documents in the set.
iterator() - Method in class org.apache.solr.search.DocSlice
 
iterator() - Method in class org.apache.solr.search.FilteredDocIdSet
Implementation of the contract to build a DocIdSetIterator.
iterator() - Method in class org.apache.solr.search.SortedIntDocSet
 
iterator() - Method in class org.apache.solr.uninverting.FieldCacheImpl.BinaryDocValuesImpl
 
iterator() - Method in class org.apache.solr.uninverting.FieldCacheImpl.LongsFromArray
 
iterator() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl
 
iterator() - Method in class org.apache.solr.util.LongSet
Returns an iterator over the values in the set.
iterator() - Method in class org.apache.solr.util.tracing.HttpServletCarrier
 
iterator() - Method in class org.apache.solr.util.tracing.SolrApacheHttpRequestCarrier
 
iterator() - Method in class org.apache.solr.util.tracing.SolrJettyRequestCarrier
 
iterator(LeafReader) - Method in class org.apache.solr.uninverting.DocTermOrds
Returns a SortedSetDocValues view of this instance
iterator(LeafReaderContext) - Method in class org.apache.solr.search.BitDocSet
 
iterator(LeafReaderContext) - Method in class org.apache.solr.search.DocSet
Returns an ordered iterator of the documents in the set for the specified LeafReaderContext.
iterator(LeafReaderContext) - Method in class org.apache.solr.search.SortedIntDocSet
 
IWordDeserializer - Interface in org.apache.solr.util.hll
Reads 'words' of a fixed width, in sequence, from a byte array.

J

JacksonJsonWriter - Class in org.apache.solr.response
A JSON ResponseWriter that uses jackson.
JacksonJsonWriter() - Constructor for class org.apache.solr.response.JacksonJsonWriter
 
JacksonJsonWriter.WriterImpl - Class in org.apache.solr.response
 
JacksonReflectMapWriter - Interface in org.apache.solr.jersey
A MapWriter implementation that relies on Jackson's JsonProperty annotation.
JaspellLookup - Class in org.apache.solr.spelling.suggest.jaspell
Deprecated.
Migrate to one of the newer suggesters which are much more RAM efficient.
JaspellLookup() - Constructor for class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
Creates a new empty trie
JaspellLookupFactory - Class in org.apache.solr.spelling.suggest.jaspell
Factory for JaspellLookup Note: This Suggester is not very RAM efficient.
JaspellLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.jaspell.JaspellLookupFactory
 
JaspellTernarySearchTrie - Class in org.apache.solr.spelling.suggest.jaspell
Deprecated.
Migrate to one of the newer suggesters which are much more RAM efficient.
JaspellTernarySearchTrie() - Constructor for class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Constructs an empty Ternary Search Trie.
JaspellTernarySearchTrie(Path) - Constructor for class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Constructs a Ternary Search Trie and loads data from a Path into the Trie.
JaspellTernarySearchTrie(Path, boolean) - Constructor for class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Constructs a Ternary Search Trie and loads data from a File into the Trie.
JaspellTernarySearchTrie(Locale) - Constructor for class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Constructs an empty Ternary Search Trie, specifying the Locale used for lowercasing.
JaspellTernarySearchTrie.TSTNode - Class in org.apache.solr.spelling.suggest.jaspell
Deprecated.
An inner class of Ternary Search Trie that represents a node in the trie.
JavaBin - org.apache.solr.client.solrj.embedded.EmbeddedSolrServer.RequestWriterSupplier
 
JavabinLoader - Class in org.apache.solr.handler.loader
Update handler which uses the JavaBin format
JavabinLoader() - Constructor for class org.apache.solr.handler.loader.JavabinLoader
 
JavabinLoader(ContentStreamLoader) - Constructor for class org.apache.solr.handler.loader.JavabinLoader
 
JavabinMessageBodyWriter() - Constructor for class org.apache.solr.jersey.MessageBodyWriters.JavabinMessageBodyWriter
 
JaxrsResourceToHandlerMappings() - Constructor for class org.apache.solr.core.PluginBag.JaxrsResourceToHandlerMappings
 
JerseyAppHandlerCache - Class in org.apache.solr.jersey
Stores Jersey 'ApplicationHandler' instances by an ID or hash derived from their ConfigSet.
JerseyAppHandlerCache() - Constructor for class org.apache.solr.jersey.JerseyAppHandlerCache
 
JerseyApplications - Class in org.apache.solr.jersey
JAX-RS "application" configurations for Solr's CoreContainer and SolrCore instances
JerseyApplications() - Constructor for class org.apache.solr.jersey.JerseyApplications
 
JerseyApplications.CoreContainerApp - Class in org.apache.solr.jersey
 
JerseyApplications.SolrCoreApp - Class in org.apache.solr.jersey
 
JerseyResource - Class in org.apache.solr.api
A marker parent type for all Jersey "resource" classes.
JerseyResource() - Constructor for class org.apache.solr.api.JerseyResource
 
jetty - org.apache.solr.core.SolrInfoBean.Group
 
JETTY_REGISTRY - Static variable in class org.apache.solr.metrics.SolrMetricManager
Registry name for Jetty-specific metrics.
JettyBridgeResponseWriter - Class in org.apache.solr.jersey.container
A ResponseWriter which copies that output of JAX-RS computation over to HttpServletResponse object used by the Jetty server.
JettyBridgeResponseWriter(HttpServletResponse) - Constructor for class org.apache.solr.jersey.container.JettyBridgeResponseWriter
 
jj_nt - Variable in class org.apache.solr.parser.QueryParser
Next token.
jjFillToken() - Method in class org.apache.solr.parser.QueryParserTokenManager
 
jjnewLexState - Static variable in class org.apache.solr.parser.QueryParserTokenManager
Lex State array.
jjstrLiteralImages - Static variable in class org.apache.solr.parser.QueryParserTokenManager
Token literal values.
JmxMetricsReporter - Class in org.apache.solr.metrics.reporters.jmx
This is a modified copy of Dropwizard's JmxReporter and classes that it internally uses, with a few important differences: this class knows that it can directly use MetricsMap as a dynamic MBean.
JmxMetricsReporter.Builder - Class in org.apache.solr.metrics.reporters.jmx
Builder for the JmxMetricsReporter class.
JmxMetricsReporter.JmxCounterMBean - Interface in org.apache.solr.metrics.reporters.jmx
 
JmxMetricsReporter.JmxGaugeMBean - Interface in org.apache.solr.metrics.reporters.jmx
 
JmxMetricsReporter.JmxHistogramMBean - Interface in org.apache.solr.metrics.reporters.jmx
 
JmxMetricsReporter.JmxMeterMBean - Interface in org.apache.solr.metrics.reporters.jmx
 
JmxMetricsReporter.JmxTimerMBean - Interface in org.apache.solr.metrics.reporters.jmx
 
JmxMetricsReporter.MetricMBean - Interface in org.apache.solr.metrics.reporters.jmx
 
JmxObjectNameFactory - Class in org.apache.solr.metrics.reporters.jmx
Factory to create MBean names for a given metric.
JmxObjectNameFactory(String, String, String...) - Constructor for class org.apache.solr.metrics.reporters.jmx.JmxObjectNameFactory
Create ObjectName factory.
JmxUtil - Class in org.apache.solr.util
Utility methods to find a MBeanServer.
JmxUtil() - Constructor for class org.apache.solr.util.JmxUtil
 
joinedElectionFired() - Method in class org.apache.solr.cloud.ElectionContext
 
joinElection(ElectionContext, boolean) - Method in class org.apache.solr.cloud.LeaderElector
 
joinElection(ElectionContext, boolean, boolean) - Method in class org.apache.solr.cloud.LeaderElector
Begin participating in the election process.
joinField - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
 
joinOptions(List<Option>, List<Option>) - Static method in class org.apache.solr.cli.SolrCLI
 
joinOverseerLeaderElection(PayloadObj<OverseerOperationPayload>) - Method in class org.apache.solr.handler.admin.api.OverseerOperationAPI
 
JoinQParserPlugin - Class in org.apache.solr.search
 
JoinQParserPlugin() - Constructor for class org.apache.solr.search.JoinQParserPlugin
 
json - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
JSON_PATH - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
JSONAuditEventFormatter() - Constructor for class org.apache.solr.security.AuditLoggerPlugin.JSONAuditEventFormatter
 
jsonFacetMerger - Variable in class org.apache.solr.handler.component.SpatialHeatmapFacets.HeatmapFacet
 
jsonfactory - Variable in class org.apache.solr.response.JacksonJsonWriter
 
JsonLoader - Class in org.apache.solr.handler.loader
 
JsonLoader() - Constructor for class org.apache.solr.handler.loader.JsonLoader
 
jsonPathConfiguration() - Static method in class org.apache.solr.packagemanager.PackageUtils
 
JsonPreAnalyzedParser - Class in org.apache.solr.schema
 
JsonPreAnalyzedParser() - Constructor for class org.apache.solr.schema.JsonPreAnalyzedParser
 
JSONResponseWriter - Class in org.apache.solr.response
 
JSONResponseWriter() - Constructor for class org.apache.solr.response.JSONResponseWriter
 
JsonStorage(ManagedResourceStorage.StorageIO, SolrResourceLoader) - Constructor for class org.apache.solr.rest.ManagedResourceStorage.JsonStorage
Uses JSONWriter.DEFAULT_INDENT space characters as an indent.
JsonStorage(ManagedResourceStorage.StorageIO, SolrResourceLoader, int) - Constructor for class org.apache.solr.rest.ManagedResourceStorage.JsonStorage
 
JSONUtil - Class in org.apache.solr.request.json
 
JSONUtil() - Constructor for class org.apache.solr.request.json.JSONUtil
 
JSONWriter - Class in org.apache.solr.response
 
JSONWriter(Writer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.response.JSONWriter
 
JSONWriter(Writer, SolrQueryRequest, SolrQueryResponse, String, String) - Constructor for class org.apache.solr.response.JSONWriter
 
JulInfo - Class in org.apache.solr.logging.jul
 
JulInfo(String, Logger) - Constructor for class org.apache.solr.logging.jul.JulInfo
 
JulWatcher - Class in org.apache.solr.logging.jul
 
JulWatcher(String) - Constructor for class org.apache.solr.logging.jul.JulWatcher
 
jvm - org.apache.solr.core.SolrInfoBean.Group
 
JVM_REGISTRY - Static variable in class org.apache.solr.metrics.SolrMetricManager
Registry name for JVM-specific metrics.

K

key - Variable in class org.apache.solr.core.BlobRepository.BlobContent
 
key - Variable in class org.apache.solr.request.SimpleFacets.CountPair
 
key - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
key - Variable in class org.apache.solr.search.Grouping.Command
 
KEY_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
keys() - Method in class org.apache.solr.cloud.DistributedMap
Returns the keys of all the elements in the map
keys() - Method in class org.apache.solr.index.MergePolicyFactoryArgs
 
KEYS_DIR - Static variable in class org.apache.solr.filestore.FileStoreAPI
 
keySet() - Method in class org.apache.solr.core.PluginBag
 
keySet() - Method in class org.apache.solr.util.MapListener
 
kids - Variable in class org.apache.solr.util.DataConfigNode
 
KILOMETERS - Static variable in class org.apache.solr.util.DistanceUnits
 
KILOMETERS_PARAM - Static variable in class org.apache.solr.util.DistanceUnits
 
kind - Variable in class org.apache.solr.parser.Token
An integer that describes the kind of this token.
KNN - org.apache.solr.update.processor.ClassificationUpdateProcessorFactory.Algorithm
 
KnnQParser - Class in org.apache.solr.search.neural
 
KnnQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.neural.KnnQParser
Constructor for the QParser
KnnQParserPlugin - Class in org.apache.solr.search.neural
A neural query parser to run K-nearest neighbors search on Dense Vector fields.
KnnQParserPlugin() - Constructor for class org.apache.solr.search.neural.KnnQParserPlugin
 
KNOWN_METRIC_NAME_STRATEGIES - Static variable in class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
KNOWN_METRIC_NAME_STRATEGIES - Static variable in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
KNOWN_TIMEZONE_IDS - Static variable in class org.apache.solr.util.TimeZoneUtils
An immutable Set of all TimeZone IDs supported by the TimeZone class at the moment the TimeZoneUtils was initialized.
KNOWN_TYPES - Static variable in class org.apache.solr.api.ApiBag
 
KNOWN_TYPES - Static variable in class org.apache.solr.response.DocsStreamer
 
knownShards - Variable in class org.apache.solr.handler.component.PivotFacet
 

L

LABEL_ID - Static variable in class org.apache.solr.metrics.reporters.solr.SolrReporter
 
labelPattern - Variable in class org.apache.solr.metrics.reporters.solr.SolrReporter.Report
 
LANGUAGES_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
LARGE_FIELD - Static variable in class org.apache.solr.schema.FieldProperties
 
last - Variable in class org.apache.solr.logging.LogWatcher
 
lastDataDir - Variable in class org.apache.solr.update.UpdateLog
 
LastFieldValueUpdateProcessorFactory - Class in org.apache.solr.update.processor
Keeps only the last value of fields matching the specified conditions.
LastFieldValueUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.LastFieldValueUpdateProcessorFactory
 
lastRecordTimestampMillis - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessageInfo
 
lastSeenValuesPerSlot - Variable in class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
lastUpdatedTime - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
 
lastUpdateSinceInitialization - Variable in class org.apache.solr.rest.ManagedResource
 
lat - Variable in class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
LATEST - Static variable in class org.apache.solr.packagemanager.PackageUtils
Represents a version which denotes the latest version available at the moment.
LATEST - Static variable in class org.apache.solr.pkg.PackagePluginHolder
 
LATEST - Static variable in class org.apache.solr.pkg.SolrPackageLoader
 
LatLonPointSpatialField - Class in org.apache.solr.schema
A spatial implementation based on Lucene's LatLonPoint and LatLonDocValuesField.
LatLonPointSpatialField() - Constructor for class org.apache.solr.schema.LatLonPointSpatialField
 
LatLonPointSpatialField.LatLonPointSpatialStrategy - Class in org.apache.solr.schema
 
LatLonPointSpatialStrategy(SpatialContext, String, boolean, boolean) - Constructor for class org.apache.solr.schema.LatLonPointSpatialField.LatLonPointSpatialStrategy
 
LAZY - org.apache.solr.core.SolrConfig.PluginOpts
 
LazyLoadedApi(SpecProvider, PluginBag.PluginHolder<SolrRequestHandler>) - Constructor for class org.apache.solr.api.ApiBag.LazyLoadedApi
 
LazyUpdateProcessorFactoryHolder(PluginBag.PluginHolder<UpdateRequestProcessorFactory>) - Constructor for class org.apache.solr.update.processor.UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder
 
LazyUpdateRequestProcessorFactory(PluginBag.PluginHolder<UpdateRequestProcessorFactory>) - Constructor for class org.apache.solr.update.processor.UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder.LazyUpdateRequestProcessorFactory
 
LEADER - org.apache.solr.cloud.overseer.OverseerAction
 
LEADER - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
LEADER_IS_NOT_ACTIVE - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
LEADER_SEQ - Static variable in class org.apache.solr.cloud.LeaderElector
 
LEADER_URL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
LEADER_VERSION_ZERO - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
LeaderElector - Class in org.apache.solr.cloud
Leader Election process.
LeaderElector(SolrZkClient) - Constructor for class org.apache.solr.cloud.LeaderElector
 
LeaderElector(SolrZkClient, ZkController.ContextKey, Map<ZkController.ContextKey, ElectionContext>) - Constructor for class org.apache.solr.cloud.LeaderElector
 
LeaderRecoveryWatcher - Class in org.apache.solr.cloud.api.collections
We use this watcher to wait for any eligible replica in a shard to become active so that it can become a leader.
LeaderRequestReplicationTracker(String) - Constructor for class org.apache.solr.update.processor.DistributedUpdateProcessor.LeaderRequestReplicationTracker
 
leaderTragedy - Static variable in class org.apache.solr.util.TestInjection
 
leafDelegate - Variable in class org.apache.solr.search.DelegatingCollector
 
LEGACY_DOUBLE - org.apache.solr.uninverting.UninvertingReader.Type
Deprecated.
Index with points and use UninvertingReader.Type.DOUBLE_POINT instead.
LEGACY_DOUBLE_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
Deprecated.
Index with points and use FieldCache.DOUBLE_POINT_PARSER instead.
LEGACY_FIELDTYPE - Static variable in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
LEGACY_FLOAT - org.apache.solr.uninverting.UninvertingReader.Type
Deprecated.
Index with points and use UninvertingReader.Type.FLOAT_POINT instead.
LEGACY_FLOAT_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
Deprecated.
Index with points and use FieldCache.FLOAT_POINT_PARSER instead.
LEGACY_INT_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
Deprecated.
Index with points and use FieldCache.INT_POINT_PARSER instead.
LEGACY_INTEGER - org.apache.solr.uninverting.UninvertingReader.Type
Deprecated.
Index with points and use UninvertingReader.Type.INTEGER_POINT instead.
LEGACY_LEADER_URL - Static variable in class org.apache.solr.handler.ReplicationHandler
Deprecated.
Only used for backwards compatibility. Use ReplicationHandler.LEADER_URL
LEGACY_LONG - org.apache.solr.uninverting.UninvertingReader.Type
Deprecated.
Index with points and use UninvertingReader.Type.LONG_POINT instead.
LEGACY_LONG_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
Deprecated.
Index with points and use FieldCache.LONG_POINT_PARSER instead.
LEGACY_MANAGED_SCHEMA_RESOURCE_NAME - Static variable in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
LEGACY_SKIP_COMMIT_ON_LEADER_VERSION_ZERO - Static variable in class org.apache.solr.handler.ReplicationHandler
Deprecated.
Only used for backwards compatibility. Use ReplicationHandler.SKIP_COMMIT_ON_LEADER_VERSION_ZERO
LegacyDoubleField - Class in org.apache.solr.legacy
Deprecated.
Please use DoublePoint instead
LegacyDoubleField(String, double, Field.Store) - Constructor for class org.apache.solr.legacy.LegacyDoubleField
Deprecated.
Creates a stored or un-stored LegacyDoubleField with the provided value and default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT (16).
LegacyDoubleField(String, double, LegacyFieldType) - Constructor for class org.apache.solr.legacy.LegacyDoubleField
Deprecated.
Expert: allows you to customize the LegacyFieldType.
LegacyFacet - Class in org.apache.solr.search.facet
 
LegacyFacet(SolrParams) - Constructor for class org.apache.solr.search.facet.LegacyFacet
 
LegacyFacet.Subfacet - Class in org.apache.solr.search.facet
 
LegacyField - Class in org.apache.solr.legacy
Deprecated.
Please switch to PointValues instead
LegacyField(String, LegacyFieldType) - Constructor for class org.apache.solr.legacy.LegacyField
Deprecated.
Expert: creates a field with no initial value.
LegacyFieldType - Class in org.apache.solr.legacy
Deprecated.
Please switch to PointValues instead
LegacyFieldType() - Constructor for class org.apache.solr.legacy.LegacyFieldType
Deprecated.
Create a new FieldType with default properties.
LegacyFieldType(LegacyFieldType) - Constructor for class org.apache.solr.legacy.LegacyFieldType
Deprecated.
Create a new mutable LegacyFieldType with all of the properties from ref
LegacyFloatField - Class in org.apache.solr.legacy
Deprecated.
Please use FloatPoint instead
LegacyFloatField(String, float, Field.Store) - Constructor for class org.apache.solr.legacy.LegacyFloatField
Deprecated.
Creates a stored or un-stored LegacyFloatField with the provided value and default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT_32 (8).
LegacyFloatField(String, float, LegacyFieldType) - Constructor for class org.apache.solr.legacy.LegacyFloatField
Deprecated.
Expert: allows you to customize the LegacyFieldType.
LegacyIntField - Class in org.apache.solr.legacy
Deprecated.
Please use IntPoint instead
LegacyIntField(String, int, Field.Store) - Constructor for class org.apache.solr.legacy.LegacyIntField
Deprecated.
Creates a stored or un-stored LegacyIntField with the provided value and default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT_32 (8).
LegacyIntField(String, int, LegacyFieldType) - Constructor for class org.apache.solr.legacy.LegacyIntField
Deprecated.
Expert: allows you to customize the LegacyFieldType.
LegacyLongField - Class in org.apache.solr.legacy
Deprecated.
Please use LongPoint instead
LegacyLongField(String, long, Field.Store) - Constructor for class org.apache.solr.legacy.LegacyLongField
Deprecated.
Creates a stored or un-stored LegacyLongField with the provided value and default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT (16).
LegacyLongField(String, long, LegacyFieldType) - Constructor for class org.apache.solr.legacy.LegacyLongField
Deprecated.
Expert: allows you to customize the LegacyFieldType.
LegacyNumericRangeQuery<T extends Number> - Class in org.apache.solr.legacy
Deprecated.
Instead index with IntPoint, LongPoint, FloatPoint, DoublePoint, and create range queries with IntPoint.newRangeQuery(), LongPoint.newRangeQuery(), FloatPoint.newRangeQuery(), DoublePoint.newRangeQuery() respectively. See PointValues for background information on Points.
LegacyNumericRangeQueryBuilder - Class in org.apache.solr.search
Deprecated.
Index with points and use PointRangeQueryBuilder instead
LegacyNumericRangeQueryBuilder() - Constructor for class org.apache.solr.search.LegacyNumericRangeQueryBuilder
Deprecated.
 
LegacyNumericTermAttributeImpl() - Constructor for class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
Creates, but does not yet initialize this attribute instance
LegacyNumericTokenStream - Class in org.apache.solr.legacy
Deprecated.
Please switch to PointValues instead
LegacyNumericTokenStream() - Constructor for class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Creates a token stream for numeric values using the default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT (16).
LegacyNumericTokenStream(int) - Constructor for class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Creates a token stream for numeric values with the specified precisionStep.
LegacyNumericTokenStream(AttributeFactory, int) - Constructor for class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Expert: Creates a token stream for numeric values with the specified precisionStep using the given AttributeFactory.
LegacyNumericTokenStream.LegacyNumericTermAttribute - Interface in org.apache.solr.legacy
Deprecated.
Expert: Use this attribute to get the details of the currently generated token.
LegacyNumericTokenStream.LegacyNumericTermAttributeImpl - Class in org.apache.solr.legacy
Deprecated.
LegacyNumericType - Enum in org.apache.solr.legacy
Deprecated.
Please switch to PointValues instead
LegacyNumericUtils - Class in org.apache.solr.legacy
Deprecated.
Please use PointValues instead.
LegacyNumericUtils.IntRangeBuilder - Class in org.apache.solr.legacy
Deprecated.
LegacyNumericUtils.LongRangeBuilder - Class in org.apache.solr.legacy
Deprecated.
LEN - Static variable in class org.apache.solr.handler.ReplicationHandler
 
length() - Method in class org.apache.solr.internal.csv.CharBuffer
Returns the number of characters in the buffer.
length() - Method in class org.apache.solr.schema.IndexSchema.DynamicReplacement.DynamicPattern
Returns the length of the original regex, including the asterisk, if any.
length(URL) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
Calculates the length of the URL in characters
lessThan(int, int) - Method in class org.apache.solr.util.PrimUtils.IntComparator
 
lessThan(IndexSizeEstimator.Item, IndexSizeEstimator.Item) - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.ItemPriorityQueue
 
lessThan(ShardDoc, ShardDoc) - Method in class org.apache.solr.handler.component.ShardFieldSortedHitQueue
 
level - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelChange
 
level - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelInfo
 
level - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.SetThresholdRequestBody
 
level - Variable in class org.apache.solr.logging.LoggerInfo
 
level - Variable in class org.apache.solr.response.TextResponseWriter
 
level - Variable in enum org.apache.solr.security.AuditEvent.EventType
 
level() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
level() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
level() - Method in class org.apache.solr.response.TextResponseWriter
 
LEVEL_PARAM - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
levels - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.ListLevelsResponse
 
levels - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessageInfo
 
levels(URL) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
Calculates the number of path levels in the given URL
LEXICAL_ERROR - Static variable in error org.apache.solr.parser.TokenMgrError
Lexical error occurred.
LexicalErr(boolean, int, int, int, String, int) - Static method in error org.apache.solr.parser.TokenMgrError
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
lexStateNames - Static variable in class org.apache.solr.parser.QueryParserTokenManager
Lexer state names.
likeContent(MoreLikeThis, String) - Method in class org.apache.solr.search.mlt.MLTContentQParserPlugin
 
likeDoc(MoreLikeThis, SolrDocument) - Method in class org.apache.solr.search.mlt.CloudMLTQParser
 
limit - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
LIMIT_SIZE_PARAM - Static variable in class org.apache.solr.update.processor.IgnoreLargeDocumentProcessorFactory
 
LINK - org.apache.solr.update.SolrIndexSplitter.SplitMethod
 
linkConfSet(SolrZkClient, String, String) - Static method in class org.apache.solr.cloud.ZkController
 
list(String, Predicate<String>) - Method in class org.apache.solr.filestore.DistribFileStore
 
list(String, Predicate<String>) - Method in interface org.apache.solr.filestore.FileStore
 
list(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.ContainerPluginsApi.Read
 
LIST_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
Handle list collection request.
listActiveTasks(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.ListActiveTasksAPI
 
ListActiveTasksAPI - Class in org.apache.solr.handler.admin.api
V2 API for listing any currently running "tasks".
ListActiveTasksAPI(ActiveTasksListHandler) - Constructor for class org.apache.solr.handler.admin.api.ListActiveTasksAPI
 
ListAliases - Class in org.apache.solr.handler.admin.api
V2 API implementation for listing and inspecting collection aliases
ListAliases(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ListAliases
 
LISTALIASES_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
List the aliases and associated properties.
listAll(URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns all the entries (files and directories) in the specified directory.
listAll(URI) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
listAllLoggersAndLevels() - Method in class org.apache.solr.handler.admin.api.NodeLoggingAPI
 
listAllOrEmpty(URI) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
List all files or directories directly under path.
listAvailableCurrencies() - Method in interface org.apache.solr.schema.ExchangeRateProvider
List all configured currency codes which are valid as source/target for this Provider
listAvailableCurrencies() - Method in class org.apache.solr.schema.FileExchangeRateProvider
 
listAvailableCurrencies() - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
listAvailableModules(Path) - Static method in class org.apache.solr.util.ModuleUtils
Returns nam of all existing modules
LISTBACKUP_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
listBackupsAtLocation(String, String, String) - Method in class org.apache.solr.handler.admin.api.ListCollectionBackups
 
ListCollectionBackups - Class in org.apache.solr.handler.admin.api
V2 API implementations for collection-backup "listing".
ListCollectionBackups(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ListCollectionBackups
 
listCollections() - Method in class org.apache.solr.handler.admin.api.ListCollections
 
ListCollections - Class in org.apache.solr.handler.admin.api
V2 API for listing collections.
ListCollections(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ListCollections
 
listCollectionsForConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
ListCollectionSnapshotsAPI - Class in org.apache.solr.handler.admin.api
V2 API for Listing Collection Snapshots.
ListCollectionSnapshotsAPI(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ListCollectionSnapshotsAPI
 
ListCollectionSnapshotsAPI.ListSnapshotsResponse - Class in org.apache.solr.handler.admin.api
listConfigs() - Method in class org.apache.solr.cloud.ZkConfigSetService
 
listConfigs() - Method in class org.apache.solr.core.ConfigSetService
List the names of configs (non-null)
listConfigs() - Method in class org.apache.solr.core.FileSystemConfigSetService
 
listConfigs(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
listConfigSet() - Method in class org.apache.solr.handler.configsets.ListConfigSets
 
ListConfigSets - Class in org.apache.solr.handler.configsets
V2 API implementation for listing all available configsets.
ListConfigSets(CoreContainer) - Constructor for class org.apache.solr.handler.configsets.ListConfigSets
 
listCopyFields() - Method in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
listDynamicFields() - Method in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
listEnabledConfigs() - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
ListenerConfig - Class in org.apache.solr.logging
 
ListenerConfig() - Constructor for class org.apache.solr.logging.ListenerConfig
 
ListenerConfig(int, String) - Constructor for class org.apache.solr.logging.ListenerConfig
 
listeners - Variable in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
listGlobal() - Static method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
List all registered circuit breakers for global context
ListLevelsResponse() - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.ListLevelsResponse
 
listNodes(String, Boolean) - Method in class org.apache.solr.handler.admin.ZookeeperReadAPI
List the children of a certain zookeeper znode
listOriginalFileNames() - Method in class org.apache.solr.core.backup.ShardBackupMetadata
 
listSchemaFields() - Method in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
listSchemaFieldTypes() - Method in class org.apache.solr.handler.admin.api.GetSchemaFieldAPI
 
listSnapshots() - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
 
listSnapshots(String) - Method in class org.apache.solr.handler.admin.api.CoreSnapshot
This API is analogous to V1 (GET /solr/admin/cores?action=LISTSNAPSHOTS)
listSnapshots(String) - Method in class org.apache.solr.handler.admin.api.ListCollectionSnapshotsAPI
This API is analogous to V1's (POST /solr/admin/collections?action=LISTSNAPSHOTS)
listSnapshots(SolrZkClient, String) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method returns the CollectionSnapshotMetaData for each named snapshot for the specified collection in Zookeeper.
LISTSNAPSHOTS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
LISTSNAPSHOTS_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
listSnapshotsInIndexDir(String) - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
This method returns a list of snapshots created in a specified index directory.
ListSnapshotsResponse() - Constructor for class org.apache.solr.handler.admin.api.ListCollectionSnapshotsAPI.ListSnapshotsResponse
 
listUniqueFileNames() - Method in class org.apache.solr.core.backup.ShardBackupMetadata
 
ListZkChildrenResponse() - Constructor for class org.apache.solr.handler.admin.ZookeeperReadAPI.ListZkChildrenResponse
 
LITERALS_PREFIX - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
LIVE - org.apache.solr.search.SolrCache.State
:TODO
liveDocs - Variable in class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
 
LMDirichletSimilarityFactory - Class in org.apache.solr.search.similarities
Factory for LMDirichletSimilarity
LMDirichletSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.LMDirichletSimilarityFactory
 
LMJelinekMercerSimilarityFactory - Class in org.apache.solr.search.similarities
Factory for LMJelinekMercerSimilarity
LMJelinekMercerSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.LMJelinekMercerSimilarityFactory
 
load() - Method in class org.apache.solr.core.CoreContainer
Load the cores defined for this CoreContainer
load() - Static method in class org.apache.solr.util.tracing.SimplePropagator
 
load(String) - Method in class org.apache.solr.rest.ManagedResourceStorage
Loads a resource from storage; the default implementation makes the assumption that the data is stored as UTF-8 encoded text, such as JSON.
load(DataInput) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
 
load(DelegatingPlacementPluginFactory, ContainerPluginsRegistry) - Static method in class org.apache.solr.cluster.placement.impl.PlacementPluginFactoryLoader
Loads the PlacementPluginFactory configured in cluster plugins and then keep it up to date as the plugin configuration changes.
load(SolrClassLoader, List<ConfigNode>) - Method in class org.apache.solr.util.plugin.AbstractPluginLoader
Initializes and registers each plugin in the list.
load(SolrQueryRequest, SolrQueryResponse, ContentStream, UpdateRequestProcessor) - Method in class org.apache.solr.handler.loader.ContentStreamLoader
Loaders are responsible for closing the stream
load(SolrQueryRequest, SolrQueryResponse, ContentStream, UpdateRequestProcessor) - Method in class org.apache.solr.handler.loader.CSVLoader
 
load(SolrQueryRequest, SolrQueryResponse, ContentStream, UpdateRequestProcessor) - Method in class org.apache.solr.handler.loader.CSVLoaderBase
load the CSV input
load(SolrQueryRequest, SolrQueryResponse, ContentStream, UpdateRequestProcessor) - Method in class org.apache.solr.handler.loader.JavabinLoader
 
load(SolrQueryRequest, SolrQueryResponse, ContentStream, UpdateRequestProcessor) - Method in class org.apache.solr.handler.loader.JsonLoader
 
load(SolrQueryRequest, SolrQueryResponse, ContentStream, UpdateRequestProcessor) - Method in class org.apache.solr.handler.loader.XMLLoader
 
LOAD_COMPLETE - Static variable in class org.apache.solr.core.CoreContainer
 
LoadAdminUiServlet - Class in org.apache.solr.servlet
A simple servlet to load the Solr Admin UI
LoadAdminUiServlet() - Constructor for class org.apache.solr.servlet.LoadAdminUiServlet
 
LoadAverageCircuitBreaker - Class in org.apache.solr.util.circuitbreaker
Tracks current system load average and triggers if the specified threshold is breached.
LoadAverageCircuitBreaker() - Constructor for class org.apache.solr.util.circuitbreaker.LoadAverageCircuitBreaker
 
loadbalancer - Variable in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
loadClusterPluginsSource(CoreContainer, SolrResourceLoader) - Static method in interface org.apache.solr.api.ClusterPluginsSource
 
loadClusterReporters(PluginInfo[], CoreContainer) - Method in class org.apache.solr.metrics.SolrMetricManager
 
loadConfigSet(CoreDescriptor) - Method in class org.apache.solr.core.ConfigSetService
Load the ConfigSet for a core
loadConfigSetFlags(SolrResourceLoader) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
loadConfigSetFlags(SolrResourceLoader) - Method in class org.apache.solr.core.ConfigSetService
Return the ConfigSet flags or null if none.
loadConfigSetProperties(CoreDescriptor, SolrResourceLoader) - Method in class org.apache.solr.core.ConfigSetService
Return the ConfigSet properties or null if none.
loadCopyFields(ConfigNode) - Method in class org.apache.solr.schema.IndexSchema
Loads the copy fields
loadCsvDocs(SolrParams, String, byte[], String, int) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
loadDecodeAndCacheBlob(String, BlobRepository.Decoder<T>) - Method in class org.apache.solr.core.SolrCore
Convenience method to load a blob.
loadElevationConfiguration(SolrCore) - Method in class org.apache.solr.handler.component.QueryElevationComponent
(Re)Loads elevation configuration.
loadElevationProvider(SolrCore) - Method in class org.apache.solr.handler.component.QueryElevationComponent
loadElevationProvider(Document) - Method in class org.apache.solr.handler.component.QueryElevationComponent
loader - Variable in class org.apache.solr.core.CoreContainer
 
loader - Variable in class org.apache.solr.core.NodeConfig
 
loader - Variable in class org.apache.solr.rest.ManagedResourceStorage
 
loader - Variable in class org.apache.solr.rest.RestManager
 
loader - Variable in class org.apache.solr.schema.IndexSchema
 
loaders - Variable in class org.apache.solr.handler.UpdateRequestHandler
 
loadExtraProperties() - Method in class org.apache.solr.core.CoreDescriptor
Load properties specified in an external properties file.
loadFields(ConfigNode) - Method in class org.apache.solr.schema.IndexSchema
Loads fields and dynamic fields.
loadFieldValues(String[], DocIdSetIterator, int) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
loadFieldValuesTimer - Variable in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
loadJsonDocs(SolrParams, ContentStreamBase.ByteArrayStream, int) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
loadJsonLines(String[]) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
loadJsonLines(SolrParams, ContentStreamBase.ByteArrayStream, int) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
loadManagedDataAndNotify(Collection<ManagedResourceObserver>) - Method in class org.apache.solr.rest.ManagedResource
Called once during core initialization to get the managed data loaded from storage and notify observers.
loadNodeConfig(Path, Properties) - Static method in class org.apache.solr.core.NodeConfig
Get the NodeConfig whether stored on disk, in ZooKeeper, etc.
loadReporter(String, CoreContainer, PluginInfo) - Method in class org.apache.solr.metrics.SolrMetricManager
loadReporter(String, SolrCore, PluginInfo, String) - Method in class org.apache.solr.metrics.SolrMetricManager
loadReporter(String, SolrResourceLoader, CoreContainer, SolrCore, PluginInfo, String) - Method in class org.apache.solr.metrics.SolrMetricManager
Create and register an instance of SolrMetricReporter.
loadReporters() - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Load reporters configured globally and specific to SolrInfoBean.Group.core group or with a registry name specific to this core.
loadReporters(PluginInfo[], SolrResourceLoader, CoreContainer, SolrCore, String, SolrInfoBean.Group, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Create and register SolrMetricReporter-s specific to a SolrInfoBean.Group.
loadSampleDocuments(SolrQueryRequest, String) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
loadShardReporters(PluginInfo[], SolrCore) - Method in class org.apache.solr.metrics.SolrMetricManager
 
loadSingle(SolrClassLoader, ConfigNode) - Method in class org.apache.solr.util.plugin.AbstractPluginLoader
Initializes and registers a single plugin.
loadTracer(SolrResourceLoader, PluginInfo) - Static method in class org.apache.solr.core.TracerConfigurator
 
loadUpdatehandlerInfo() - Method in class org.apache.solr.core.SolrConfig
 
loadXmlDocs(SolrParams, ContentStreamBase.ByteArrayStream, int) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
LOCAL_ACTIVITY_DURING_REPLICATION - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
localCollectionStatistics(String) - Method in class org.apache.solr.search.SolrIndexSearcher
 
locale - Variable in class org.apache.solr.update.processor.ParseNumericFieldUpdateProcessorFactory
 
LocaleUtils - Class in org.apache.solr.util
 
LocalFileSystemRepository - Class in org.apache.solr.core.backup.repository
A concrete implementation of BackupRepository interface supporting backup/restore of Solr indexes to a local file-system.
LocalFileSystemRepository() - Constructor for class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
localMax - Variable in class org.apache.solr.search.ReRankScaler.MinMaxExplain
 
localMin - Variable in class org.apache.solr.search.ReRankScaler.MinMaxExplain
 
LOCALPARAM_END - Static variable in class org.apache.solr.search.QueryParsing
 
LOCALPARAM_START - Static variable in class org.apache.solr.search.QueryParsing
 
localParams - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
localParams - Variable in class org.apache.solr.search.facet.FacetRequest.Domain.GraphField
 
localParams - Variable in class org.apache.solr.search.QParser
 
localParamsEnd - Variable in class org.apache.solr.search.QParser
 
LocalSolrQueryRequest - Class in org.apache.solr.request
 
LocalSolrQueryRequest(SolrCore, String, String, int, int, Map<?, ?>) - Constructor for class org.apache.solr.request.LocalSolrQueryRequest
 
LocalSolrQueryRequest(SolrCore, Map<String, String[]>) - Constructor for class org.apache.solr.request.LocalSolrQueryRequest
 
LocalSolrQueryRequest(SolrCore, SolrParams) - Constructor for class org.apache.solr.request.LocalSolrQueryRequest
 
LocalSolrQueryRequest(SolrCore, NamedList<?>) - Constructor for class org.apache.solr.request.LocalSolrQueryRequest
 
LocalStatsCache - Class in org.apache.solr.search.stats
Default implementation that simply ignores global term statistics, and always uses local term statistics.
LocalStatsCache() - Constructor for class org.apache.solr.search.stats.LocalStatsCache
 
LocalStatsSource - Class in org.apache.solr.search.stats
Convenience class that wraps a local SolrIndexSearcher to provide local statistics.
LocalStatsSource(StatsCache.StatsCacheMetrics) - Constructor for class org.apache.solr.search.stats.LocalStatsSource
 
localTermStatistics(Term, int, long) - Method in class org.apache.solr.search.SolrIndexSearcher
 
locateInstanceDir(CoreDescriptor) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
location - Variable in class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
location - Variable in class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
location - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationRequestBody
 
LOCATION - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
LOCATION - Static variable in class org.apache.solr.spelling.suggest.SolrSuggester
Location of the source data - either a path to a file, or null for the current IndexReader.
LOCATION - Static variable in class org.apache.solr.spelling.suggest.Suggester
Location of the source data - either a path to a file, or null for the current IndexReader.
lock(CollectionParams.CollectionAction, List<String>) - Method in class org.apache.solr.cloud.LockTree.Session
 
LOCK_OBTAIN_FAILED - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
LOCK_TYPE_NATIVE - Static variable in class org.apache.solr.core.DirectoryFactory
 
LOCK_TYPE_NONE - Static variable in class org.apache.solr.core.DirectoryFactory
 
LOCK_TYPE_SIMPLE - Static variable in class org.apache.solr.core.DirectoryFactory
 
LOCK_TYPE_SINGLE - Static variable in class org.apache.solr.core.DirectoryFactory
 
lockForSplit(SolrCloudManager, String, String) - Static method in class org.apache.solr.cloud.api.collections.SplitShardCmd
 
lockForUpdate() - Method in class org.apache.solr.update.VersionInfo
 
lockTask(ZkNodeProps, long) - Method in class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
Grabs an exclusive lock for this particular task.
lockTask(ZkNodeProps, long) - Method in class org.apache.solr.cloud.OverseerConfigSetMessageHandler
 
lockTask(ZkNodeProps, long) - Method in interface org.apache.solr.cloud.OverseerMessageHandler
Grabs an exclusive lock for this particular task.
LockTree - Class in org.apache.solr.cloud
This is a utility class that offers fine grained locking for various Collection Operations This class is designed for single threaded operation.
LockTree() - Constructor for class org.apache.solr.cloud.LockTree
 
LockTree.Session - Class in org.apache.solr.cloud
This class is used to mark nodes for which acquiring a lock was attempted but didn't succeed.
lockType - Variable in class org.apache.solr.update.SolrIndexConfig
 
log - Static variable in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
log - Variable in class org.apache.solr.update.UpdateLog.Update
 
log(String, String) - Static method in class org.apache.solr.logging.DeprecationLog
Logs a deprecation warning for the provided feature, but only the first time.
LOG_FILENAME_PATTERN - Static variable in class org.apache.solr.update.UpdateLog
 
LOG_PREFIX - Static variable in class org.apache.solr.logging.DeprecationLog
 
LOG_REPLAY - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
Log4j2Info(String, Level, boolean) - Constructor for class org.apache.solr.logging.log4j2.Log4j2Watcher.Log4j2Info
 
Log4j2Watcher - Class in org.apache.solr.logging.log4j2
 
Log4j2Watcher() - Constructor for class org.apache.solr.logging.log4j2.Log4j2Watcher
 
Log4j2Watcher.Log4j2Appender - Class in org.apache.solr.logging.log4j2
 
Log4j2Watcher.Log4j2Info - Class in org.apache.solr.logging.log4j2
 
logAndFlushAdminRequest(SolrQueryResponse) - Method in class org.apache.solr.servlet.HttpSolrCall
 
LogByteSizeMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for LogByteSizeMergePolicy objects.
LogByteSizeMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.LogByteSizeMergePolicyFactory
 
LogCodec(JavaBinCodec.ObjectResolver) - Constructor for class org.apache.solr.update.TransactionLog.LogCodec
 
LogDocMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for LogDocMergePolicy objects.
LogDocMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.LogDocMergePolicyFactory
 
logger - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelChange
 
LoggerInfo - Class in org.apache.solr.logging
Wrapper class for Logger implementations
LoggerInfo(String) - Constructor for class org.apache.solr.logging.LoggerInfo
 
loggers - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.ListLevelsResponse
 
logging - Variable in class org.apache.solr.core.CoreContainer
 
LoggingHandler - Class in org.apache.solr.handler.admin
A request handler to show which loggers are registered and allows you to set them
LoggingHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.LoggingHandler
 
LoggingInfoStream - Class in org.apache.solr.update
An InfoStream implementation which passes messages on to Solr's logging.
LoggingInfoStream() - Constructor for class org.apache.solr.update.LoggingInfoStream
 
LoggingResponse() - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.LoggingResponse
 
LogLevelChange() - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelChange
 
LogLevelChange(String, String) - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelChange
 
LogLevelInfo() - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelInfo
 
LogLevelInfo(String, String, boolean) - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelInfo
 
LogMessageInfo() - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessageInfo
 
LogMessagesResponse() - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessagesResponse
 
LogPtr(long, long) - Constructor for class org.apache.solr.update.UpdateLog.LogPtr
Creates an object that contains the position and version of an update.
LogPtr(long, long, long) - Constructor for class org.apache.solr.update.UpdateLog.LogPtr
 
LogReader() - Constructor for class org.apache.solr.update.TransactionLog.LogReader
 
LogReader(long) - Constructor for class org.apache.solr.update.TransactionLog.LogReader
 
LogRecordReader(BufferedReader) - Constructor for class org.apache.solr.cli.PostLogsTool.LogRecordReader
 
logs - Variable in class org.apache.solr.update.UpdateLog
 
logThreadDumps(String) - Static method in class org.apache.solr.core.Diagnostics
 
LogUpdateProcessorFactory - Class in org.apache.solr.update.processor
A logging processor.
LogUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.LogUpdateProcessorFactory
 
LogWatcher<E> - Class in org.apache.solr.logging
A Class to monitor Logging events and hold N events in memory
LogWatcher() - Constructor for class org.apache.solr.logging.LogWatcher
 
LogWatcherConfig - Class in org.apache.solr.logging
Defines the configuration of a LogWatcher
LogWatcherConfig(boolean, String, String, int) - Constructor for class org.apache.solr.logging.LogWatcherConfig
 
lon - Variable in class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
LONG - org.apache.solr.legacy.LegacyNumericType
Deprecated.
64-bit long numeric type
LONG - org.apache.solr.schema.NumberType
 
LONG_POINT - org.apache.solr.uninverting.UninvertingReader.Type
Single-valued Integer, (e.g.
LONG_POINT_PARSER - Static variable in interface org.apache.solr.uninverting.FieldCache
A parser instance for long values encoded by NumericUtils, e.g.
long2sortableStr(long) - Static method in class org.apache.solr.util.NumberUtils
 
long2sortableStr(long, char[], int) - Static method in class org.apache.solr.util.NumberUtils
 
long2sortableStr(String) - Static method in class org.apache.solr.util.NumberUtils
 
LONGEST_DOMINANT_RIGHT - Static variable in interface org.apache.solr.handler.tagger.TagClusterReducer
 
LongFuncSlotAcc(ValueSource, FacetContext, int, long) - Constructor for class org.apache.solr.search.facet.SlotAcc.LongFuncSlotAcc
 
LongIterator - Interface in org.apache.solr.util
A long-based iterator.
LongPointField - Class in org.apache.solr.schema
PointField implementation for Long values.
LongPointField() - Constructor for class org.apache.solr.schema.LongPointField
 
LongPriorityQueue - Class in org.apache.solr.util
A native long priority queue.
LongPriorityQueue(int, int, long) - Constructor for class org.apache.solr.util.LongPriorityQueue
 
LongRangeBuilder() - Constructor for class org.apache.solr.legacy.LegacyNumericUtils.LongRangeBuilder
Deprecated.
 
LongSet - Class in org.apache.solr.util
Collects long values in a hash set (closed hashing on power-of-two sized long[])
LongSet(int) - Constructor for class org.apache.solr.util.LongSet
 
LongsFromArray(String, PackedInts.Reader, long, Bits) - Constructor for class org.apache.solr.uninverting.FieldCacheImpl.LongsFromArray
 
longToPrefixCoded(long, int, BytesRefBuilder) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns prefix coded bits after reducing the precision by shift bits.
LongValue - Class in org.apache.solr.handler.export
 
LongValue(String, LongComp) - Constructor for class org.apache.solr.handler.export.LongValue
 
LongValueFieldType - Interface in org.apache.solr.schema
Marker interface for long-valued field types.
lookup - Variable in class org.apache.solr.spelling.suggest.Suggester
 
lookup(long) - Method in class org.apache.solr.update.TransactionLog
 
lookup(long) - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
 
lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
 
lookup(String) - Static method in enum org.apache.solr.schema.FieldType.MultiValueSelector
Returns a MultiValueSelector matching the specified (case insensitive) label, or null if no corrisponding MultiValueSelector exists.
lookup(String, String, Map<String, String>) - Method in class org.apache.solr.api.ApiBag
 
lookup(BytesRef) - Method in class org.apache.solr.update.UpdateLog
 
LOOKUP_IMPL - Static variable in class org.apache.solr.spelling.suggest.SolrSuggester
Fully-qualified class of the Lookup implementation.
LOOKUP_IMPL - Static variable in class org.apache.solr.spelling.suggest.Suggester
Fully-qualified class of the Lookup implementation.
Lookup3Signature - Class in org.apache.solr.update.processor
 
Lookup3Signature() - Constructor for class org.apache.solr.update.processor.Lookup3Signature
 
lookupDocIds(Object) - Method in class org.apache.solr.handler.tagger.Tagger
Returns a sorted array of integer docIds given the corresponding key.
LookupFactory - Class in org.apache.solr.spelling.suggest
Suggester factory for creating Lookup instances.
LookupFactory() - Constructor for class org.apache.solr.spelling.suggest.LookupFactory
 
lookupId(BytesRef) - Method in class org.apache.solr.search.SolrIndexSearcher
lookup the docid by the unique key field, and return the id *within* the leaf reader in the low 32 bits, and the index of the leaf reader in the high 32 bits.
lookupImpl - Variable in class org.apache.solr.spelling.suggest.Suggester
 
lookupLocalManagedSchemaPath() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
Lookup the path to the managed schema, dealing with falling back to the legacy managed-schema file, instead of the expected managed-schema.xml file if the legacy file exists.
lookupOrd(int) - Method in class org.apache.solr.search.facet.FieldUtil.DVOrdValues
 
lookupOrd(int) - Method in class org.apache.solr.search.facet.FieldUtil.FCOrdValues
 
lookupOrd(int) - Method in class org.apache.solr.search.facet.UnInvertedField.DocToTerm
 
lookupOrd(int) - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
lookups - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
LOOKUPS_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
lookupTag(int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
lookupTerm(TermsEnum, int) - Method in class org.apache.solr.uninverting.DocTermOrds
Returns the term (BytesRef) corresponding to the provided ordinal.
lookupVersion(BytesRef) - Method in class org.apache.solr.update.UpdateLog
 
lookupVersion(BytesRef) - Method in class org.apache.solr.update.VersionInfo
 
lookupZKManagedSchemaPath() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
Lookup the path to the managed schema, dealing with falling back to the legacy managed-schema file, instead of the expected managed-schema.xml file if the legacy file exists.
LOOP_DETECTED - Static variable in error org.apache.solr.parser.TokenMgrError
Detected (and bailed out of) an infinite loop in the token manager.
lower - Variable in class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
 
lower - Variable in class org.apache.solr.search.join.HashRangeQuery
 
lower - Variable in class org.apache.solr.search.TopLevelJoinQuery.BitsetBounds
 
LOWER_BOUND - Static variable in class org.apache.solr.search.join.HashRangeQParser
 
lowercaseOperators - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
LowerCaseTokenizer - Class in org.apache.solr.analysis
Deprecated.
Use LetterTokenizer and LowerCaseFilter
LowerCaseTokenizer() - Constructor for class org.apache.solr.analysis.LowerCaseTokenizer
Deprecated.
Construct a new LowerCaseTokenizer.
LowerCaseTokenizer(AttributeFactory) - Constructor for class org.apache.solr.analysis.LowerCaseTokenizer
Deprecated.
Construct a new LowerCaseTokenizer using a given AttributeFactory.
LowerCaseTokenizer(AttributeFactory, int) - Constructor for class org.apache.solr.analysis.LowerCaseTokenizer
Deprecated.
Construct a new LowerCaseTokenizer using a given AttributeFactory.
LowerCaseTokenizerFactory - Class in org.apache.solr.analysis
Deprecated.
Use LetterTokenizerFactory and LowerCaseFilterFactory
LowerCaseTokenizerFactory() - Constructor for class org.apache.solr.analysis.LowerCaseTokenizerFactory
Deprecated.
Default ctor for compatibility with SPI
LowerCaseTokenizerFactory(Map<String, String>) - Constructor for class org.apache.solr.analysis.LowerCaseTokenizerFactory
Deprecated.
Creates a new LowerCaseTokenizerFactory
LPARAMS - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
LPAREN - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
LRUStatsCache - Class in org.apache.solr.search.stats
Unlike ExactStatsCache this implementation preserves term stats across queries in a set of LRU caches (with the same life-cycle as SolrIndexSearcher), and based on surface features of a query it determines the need to send additional requests to retrieve local term and collection statistics from shards.
LRUStatsCache() - Constructor for class org.apache.solr.search.stats.LRUStatsCache
 
LUCENE_MATCH_VERSION_PARAM - Static variable in class org.apache.solr.schema.IndexSchema
 
LuceneDefaultCodecFactory - Class in org.apache.solr.core
Simple factory for returning the Lucene default Codec
LuceneDefaultCodecFactory() - Constructor for class org.apache.solr.core.LuceneDefaultCodecFactory
 
luceneMatchVersion - Variable in class org.apache.solr.core.SolrConfig
 
LuceneQParser - Class in org.apache.solr.search
 
LuceneQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.LuceneQParser
 
LuceneQParserPlugin - Class in org.apache.solr.search
Parse Solr's variant on the Lucene QueryParser syntax.
LuceneQParserPlugin() - Constructor for class org.apache.solr.search.LuceneQParserPlugin
 
luceneVersion - Variable in class org.apache.solr.schema.IndexSchema
 
LukeRequestHandler - Class in org.apache.solr.handler.admin
Exposes the internal lucene index.
LukeRequestHandler() - Constructor for class org.apache.solr.handler.admin.LukeRequestHandler
 

M

MACRO_START - Static variable in class org.apache.solr.request.macro.MacroExpander
 
MacroExpander - Class in org.apache.solr.request.macro
 
MacroExpander(Map<String, String[]>) - Constructor for class org.apache.solr.request.macro.MacroExpander
 
MacroExpander(Map<String, String[]>, boolean) - Constructor for class org.apache.solr.request.macro.MacroExpander
 
main - Variable in class org.apache.solr.search.Grouping.Command
 
main(String[]) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
See usage() for valid command line usage
main(String[]) - Static method in class org.apache.solr.cli.SolrCLI
Runs a tool.
main(String[]) - Static method in class org.apache.solr.cli.SolrLogPostTool
Deprecated.
 
main(String[]) - Static method in class org.apache.solr.cloud.ZkCLI
Allows you to perform a variety of zookeeper related tasks, such as:
main(String[]) - Static method in class org.apache.solr.handler.admin.IndexSizeEstimator
 
MAIN_END_RESULT_TRANSFORMER - Static variable in class org.apache.solr.handler.component.QueryComponent
 
MainEndResultTransformer - Class in org.apache.solr.search.grouping.endresulttransformer
Implementation of EndResultTransformer that transforms the grouped result into the main result list in the response.
MainEndResultTransformer() - Constructor for class org.apache.solr.search.grouping.endresulttransformer.MainEndResultTransformer
 
mainQuery - Variable in class org.apache.solr.search.AbstractReRankQuery
 
mainQueryMax - Variable in class org.apache.solr.search.ReRankScaler
 
mainQueryMin - Variable in class org.apache.solr.search.ReRankScaler
 
mainResult - Variable in class org.apache.solr.search.Grouping
 
MaintainRoutedAliasCmd - Class in org.apache.solr.cloud.api.collections
 
makeDistanceValueSource(Point, double) - Method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
makeDistanceValueSource(Point, double) - Method in class org.apache.solr.schema.LatLonPointSpatialField.LatLonPointSpatialStrategy
 
makeDom(byte[]) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Takes a string as input and returns a DOM
makeList(Object, Object) - Method in class org.apache.solr.request.json.ObjectUtil.ConflictHandler
 
makeName(List<String>, String) - Static method in class org.apache.solr.metrics.SolrMetricManager
 
makeOverlapRatioValueSource(Rectangle, double) - Method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
Returns a similarity based on BBoxOverlapRatioValueSource.
makeParams(String, String, int, int, Map<?, ?>) - Static method in class org.apache.solr.request.LocalSolrQueryRequest
 
makeQuery() - Method in class org.apache.solr.search.BitDocSet
 
makeQuery() - Method in class org.apache.solr.search.DocSet
Returns a Query matching these documents with a score of 1.
makeQuery() - Method in class org.apache.solr.search.SortedIntDocSet
 
makeQuery(SpatialArgs) - Method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
makeQuery(SpatialArgs) - Method in class org.apache.solr.schema.LatLonPointSpatialField.LatLonPointSpatialStrategy
 
makeQueryable(Query) - Static method in class org.apache.solr.search.QueryUtils
Makes negative queries suitable for querying by lucene.
makeQueryFromDocValues(Shape) - Method in class org.apache.solr.schema.LatLonPointSpatialField.LatLonPointSpatialStrategy
 
makeQueryFromIndex(Shape) - Method in class org.apache.solr.schema.LatLonPointSpatialField.LatLonPointSpatialStrategy
 
makeQueryRequest(ShardRequest, ModifiableSolrParams, String) - Method in class org.apache.solr.handler.component.HttpShardHandler
Subclasses could modify the request based on the shard
makeShapeValueSource() - Method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
Provides access to each rectangle per document
managed - Variable in class org.apache.solr.rest.RestManager
 
MANAGED_ENDPOINT - Static variable in class org.apache.solr.rest.RestManager
 
MANAGED_JSON_LIST_FIELD - Static variable in class org.apache.solr.rest.ManagedResource
 
MANAGED_JSON_MAP_FIELD - Static variable in class org.apache.solr.rest.ManagedResource
 
MANAGED_SCHEMA_RESOURCE_NAME - Static variable in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
ManagedEndpoint(RestManager) - Constructor for class org.apache.solr.rest.RestManager.ManagedEndpoint
 
ManagedIndexSchema - Class in org.apache.solr.schema
Solr-managed schema - non-user-editable, but can be mutable via internal and external REST API requests.
ManagedIndexSchema.FieldExistsException - Exception in org.apache.solr.schema
 
ManagedIndexSchema.SchemaChangedInZkException - Exception in org.apache.solr.schema
 
ManagedIndexSchemaFactory - Class in org.apache.solr.schema
Factory for ManagedIndexSchema
ManagedIndexSchemaFactory() - Constructor for class org.apache.solr.schema.ManagedIndexSchemaFactory
 
managedInitArgs - Variable in class org.apache.solr.rest.ManagedResource
 
managedResource - Variable in class org.apache.solr.rest.RestManager.ManagedEndpoint
 
ManagedResource - Class in org.apache.solr.rest
Supports Solr components that have external data that needs to be managed using the REST API.
ManagedResource(String, SolrResourceLoader, ManagedResourceStorage.StorageIO) - Constructor for class org.apache.solr.rest.ManagedResource
Initializes this managed resource, including setting up JSON-based storage using the provided storageIO implementation, such as ZK.
ManagedResource.ChildResourceSupport - Interface in org.apache.solr.rest
Marker interface to indicate a ManagedResource implementation class also supports managing child resources at path: /<resource>/{child}
ManagedResourceObserver - Interface in org.apache.solr.rest
Allows a Solr component to register as an observer of important ManagedResource events, such as when the managed data is loaded.
ManagedResourceStorage - Class in org.apache.solr.rest
Abstract base class that provides most of the functionality needed to store arbitrary data for managed resources.
ManagedResourceStorage(ManagedResourceStorage.StorageIO, SolrResourceLoader) - Constructor for class org.apache.solr.rest.ManagedResourceStorage
 
ManagedResourceStorage.FileStorageIO - Class in org.apache.solr.rest
Local file-based storage implementation.
ManagedResourceStorage.InMemoryStorageIO - Class in org.apache.solr.rest
Memory-backed storage IO; not really intended for storage large amounts of data in production, but useful for testing and other transient workloads.
ManagedResourceStorage.JsonStorage - Class in org.apache.solr.rest
Default storage implementation that uses JSON as the storage format for managed data.
ManagedResourceStorage.StorageIO - Interface in org.apache.solr.rest
Hides the underlying storage implementation for data being managed by a ManagedResource.
ManagedResourceStorage.ZooKeeperStorageIO - Class in org.apache.solr.rest
ZooKeeper based storage implementation that uses the SolrZkClient provided by the CoreContainer.
ManagedSchemaDiff - Class in org.apache.solr.handler.designer
Utility methods for comparing managed index schemas
ManagedSchemaDiff() - Constructor for class org.apache.solr.handler.designer.ManagedSchemaDiff
 
ManagedStopFilterFactory - Class in org.apache.solr.rest.schema.analysis
TokenFilterFactory that uses the ManagedWordSetResource implementation for managing stop words using the REST API.
ManagedStopFilterFactory() - Constructor for class org.apache.solr.rest.schema.analysis.ManagedStopFilterFactory
Default ctor for compatibility with SPI
ManagedStopFilterFactory(Map<String, String>) - Constructor for class org.apache.solr.rest.schema.analysis.ManagedStopFilterFactory
Initialize the managed "handle"
ManagedSynonymFilterFactory - Class in org.apache.solr.rest.schema.analysis
Deprecated.
Use ManagedSynonymGraphFilterFactory instead, but be sure to also use FlattenGraphFilterFactory at index time (not at search time) as well.
ManagedSynonymFilterFactory() - Constructor for class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
Default ctor for compatibility with SPI
ManagedSynonymFilterFactory(Map<String, String>) - Constructor for class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
 
ManagedSynonymFilterFactory.SynonymManager - Class in org.apache.solr.rest.schema.analysis
Deprecated.
ManagedResource implementation for synonyms, which are so specialized that it makes sense to implement this class as an inner class as it has little application outside the SynonymFilterFactory use cases.
ManagedSynonymGraphFilterFactory - Class in org.apache.solr.rest.schema.analysis
TokenFilterFactory and ManagedResource implementation for doing CRUD on synonyms using the REST API.
ManagedSynonymGraphFilterFactory() - Constructor for class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
Default ctor for compatibility with SPI
ManagedSynonymGraphFilterFactory(Map<String, String>) - Constructor for class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
 
ManagedSynonymGraphFilterFactory.SynonymManager - Class in org.apache.solr.rest.schema.analysis
ManagedResource implementation for synonyms, which are so specialized that it makes sense to implement this class as an inner class as it has little application outside the SynonymFilterFactory use cases.
ManagedWordSetResource - Class in org.apache.solr.rest.schema.analysis
ManagedResource implementation for managing a set of words using the REST API; useful for managing stop words and/or protected words for analysis components like the KeywordMarkerFilter.
ManagedWordSetResource(String, SolrResourceLoader, ManagedResourceStorage.StorageIO) - Constructor for class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
 
manifest - Variable in class org.apache.solr.packagemanager.SolrPackage.SolrPackageRelease
 
manifest - Variable in class org.apache.solr.packagemanager.SolrPackageInstance
 
manifest - Variable in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
Manifest() - Constructor for class org.apache.solr.packagemanager.SolrPackage.Manifest
 
manifestSHA512 - Variable in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
map - Variable in class org.apache.solr.update.UpdateLog
 
MAP - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
mapDynamicFieldToPropValues(IndexSchema.DynamicField[]) - Static method in class org.apache.solr.handler.designer.ManagedSchemaDiff
 
mapExpectedElements(int) - Method in interface org.apache.solr.util.DynamicMap
Compute expected elements for hppc maps, so resizing won't happen if we store less elements than threshold
mapFieldsToPropertyValues(Map<String, SchemaField>) - Static method in class org.apache.solr.handler.designer.ManagedSchemaDiff
 
mapFieldTypesToPropValues(Map<String, FieldType>) - Static method in class org.apache.solr.handler.designer.ManagedSchemaDiff
 
MapInitializedPlugin - Interface in org.apache.solr.util.plugin
A plugin that can be initialized with a Map<String,String>
MapListener<K,​V> - Class in org.apache.solr.util
Wraps another map, keeping track of each key that was seen via MapListener.get(Object) or MapListener.remove(Object).
MapListener(Map<K, V>) - Constructor for class org.apache.solr.util.MapListener
 
MapPluginLoader<T extends MapInitializedPlugin> - Class in org.apache.solr.util.plugin
 
MapPluginLoader(String, Class<T>, Map<String, T>) - Constructor for class org.apache.solr.util.plugin.MapPluginLoader
 
MapWriterSummaryStatistics() - Constructor for class org.apache.solr.handler.admin.IndexSizeEstimator.MapWriterSummaryStatistics
 
mark() - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
mark(int) - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
mark(long) - Method in class org.apache.solr.metrics.DelegateRegistryMeter
 
markAndSweep() - Method in class org.apache.solr.util.ConcurrentLRUCache
Removes items from the cache to bring the size down to an acceptable value.
markAttemptingAction() - Method in class org.apache.solr.cloud.ActionThrottle
 
markCoreAsLoading(CoreDescriptor) - Method in class org.apache.solr.core.SolrCores
 
markCoreAsNotLoading(CoreDescriptor) - Method in class org.apache.solr.core.SolrCores
 
markDirty() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Indicates that the values in this collection have been modified by the caller.
markSupported() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
marshalBase64SortValue(Object) - Static method in class org.apache.solr.schema.FieldType
Marshals a binary field value.
marshalSortValue(Object) - Method in class org.apache.solr.schema.BoolField
 
marshalSortValue(Object) - Method in class org.apache.solr.schema.CollationField
 
marshalSortValue(Object) - Method in class org.apache.solr.schema.FieldType
Convert a value used by the FieldComparator for this FieldType's SortField into a marshalable value for distributed sorting.
marshalSortValue(Object) - Method in class org.apache.solr.schema.StrField
 
marshalSortValue(Object) - Method in class org.apache.solr.schema.TextField
 
marshalStringSortValue(Object) - Static method in class org.apache.solr.schema.FieldType
Marshals a string-based field value.
match(int) - Method in class org.apache.solr.search.FilteredDocIdSet
Validation method to determine whether a docid should be in the result set.
MATCH_TEXT - Static variable in class org.apache.solr.handler.tagger.TaggerRequestHandler
Request parameter.
matchAlmost(CharSequence, int) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns a List of keys that almost match the argument key.
matchAlmost(String) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns a List of keys that almost match the argument key.
MatchCostQuery - Class in org.apache.solr.search
Wraps a Query to customize the TwoPhaseIterator.matchCost().
MatchCostQuery(Query, float) - Constructor for class org.apache.solr.search.MatchCostQuery
 
matches() - Method in interface org.apache.solr.search.DocList
Returns the total number of matches for the search (as opposed to just the number collected according to offset() and size()).
matches() - Method in class org.apache.solr.search.DocSlice
 
matches(String) - Method in class org.apache.solr.schema.IndexSchema.DynamicReplacement
 
matches(String, Metric) - Method in class org.apache.solr.metrics.SolrMetricManager.AndFilter
 
matches(String, Metric) - Method in class org.apache.solr.metrics.SolrMetricManager.OrFilter
 
matches(String, Metric) - Method in class org.apache.solr.metrics.SolrMetricManager.PrefixFilter
 
matches(String, Metric) - Method in class org.apache.solr.metrics.SolrMetricManager.RegexFilter
 
matchPath(String) - Method in class org.apache.solr.core.InitParams
 
matchPrefix(CharSequence, int) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns an alphabetical List of all keys in the trie that begin with a given prefix.
matchPrefix(String) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns an alphabetical List of all keys in the trie that begin with a given prefix.
max - org.apache.solr.handler.component.StatsField.Stat
 
MAX - org.apache.solr.schema.FieldType.MultiValueSelector
 
MAX - org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelectorType
 
MAX_BLOCKED_TASKS - Static variable in class org.apache.solr.cloud.OverseerTaskProcessor
 
MAX_CELLS_PARAM - Static variable in class org.apache.solr.search.facet.FacetHeatmap
 
MAX_CHARS - Static variable in class org.apache.solr.schema.IndexSchema
 
MAX_EDITS - Static variable in class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
Maximum number of edits allowed, used by LevenshteinAutomata.toAutomaton(int) in bytes or Unicode code points (if FuzzyLookupFactory.UNICODE_AWARE option is set to true).
MAX_EXPANSIONS - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
When building the FST ("index-time"), we add each path through the tokenstream graph as an individual entry.
MAX_FREQ - org.apache.solr.spelling.WordBreakSolrSpellChecker.BreakSuggestionTieBreaker
See WordBreakSpellChecker.BreakSuggestionSortMethod.NUM_CHANGES_THEN_MAX_FREQUENCY #
MAX_IDLE_TIME_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
MAX_PARALLEL_TASKS - Static variable in class org.apache.solr.cloud.OverseerTaskProcessor
Maximum number of overseer collection operations which can be executed concurrently
MAX_RAM_MB_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
MAX_SAMPLE_DOCS - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
MAX_SIZE_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
MAX_SURFACE_FORMS - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
When multiple suggestions collide to the same analyzed form, this is the limit of how many unique surface forms we keep.
MAX_TRACKED_ASYNC_TASKS - Static variable in class org.apache.solr.cloud.DistributedApiAsyncTracker
Corresponds to Overseer.NUM_RESPONSES_TO_STORE.
MAX_WRITE_PER_SECOND - Static variable in class org.apache.solr.handler.ReplicationHandler
 
maxBufferedDocs - Variable in class org.apache.solr.update.SolrIndexConfig
 
maxCardinality - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.CategoryRoutedAliasProperties
 
maxCommitMergeWaitMillis - Variable in class org.apache.solr.update.SolrIndexConfig
When using a custom merge policy that allows triggering synchronous merges on commit (see MergePolicy.findFullFlushMerges(org.apache.lucene.index.MergeTrigger, org.apache.lucene.index.SegmentInfos, org.apache.lucene.index.MergePolicy.MergeContext)), a timeout (in milliseconds) can be set for those merges to finish.
maxDoc - Variable in class org.apache.solr.search.stats.CollectionStats
 
maxDoc() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
maxDoc() - Method in class org.apache.solr.search.SolrIndexSearcher
 
MAXEDITS - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
MaxFieldValueUpdateProcessorFactory - Class in org.apache.solr.update.processor
An update processor that keeps only the maximum value from any selected fields where multiple values are found.
MaxFieldValueUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.MaxFieldValueUpdateProcessorFactory
 
maxFutureMs - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
MAXIMUM_EXPLICIT_THRESHOLD - Static variable in class org.apache.solr.util.hll.HLL
 
MAXIMUM_EXPTHRESH_PARAM - Static variable in class org.apache.solr.util.hll.HLL
 
MAXIMUM_LOG2M_PARAM - Static variable in class org.apache.solr.util.hll.HLL
 
MAXIMUM_REGWIDTH_PARAM - Static variable in class org.apache.solr.util.hll.HLL
 
maxIndexedPositionLength - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
MAXINSPECTIONS - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
maxNumLogsToKeep - Variable in class org.apache.solr.update.UpdateLog
 
maxOptimizeSegments - Variable in class org.apache.solr.update.CommitUpdateCommand
During optimize, optimize down to <= this many segments.
maxPackageVersion(String) - Method in class org.apache.solr.core.SolrConfig
The version of package that should be loaded for a given package name This information is stored in the params.json in the same configset If params.json is absent or there is no corresponding version specified for a given package, this returns a null and the latest is used by the caller
MAXQUERYFREQUENCY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
MAXQUERYLENGTH - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
maxQueryPositionLength - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
maxReplicasPerShardInDomain - Variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Determines the maximum number of replicas of a particular type of a particular shard that can be placed within a single domain (as defined by the @link #SPREAD_DOMAIN_SYSPROP} System property.
maxRetriesOnForward - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
Number of times requests forwarded to some other shard's leader can be retried
maxRetriesToFollowers - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
Number of times requests from leaders to followers can be retried
maxScore() - Method in interface org.apache.solr.search.DocList
The maximum score for the search...
maxScore() - Method in class org.apache.solr.search.DocSlice
 
MaxScoreCollector - Class in org.apache.solr.search
A Collector for the maximum score value.
MaxScoreCollector() - Constructor for class org.apache.solr.search.MaxScoreCollector
 
MaxScoreQParser - Class in org.apache.solr.search
 
MaxScoreQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.MaxScoreQParser
 
MaxScoreQParserPlugin - Class in org.apache.solr.search
Parses a query like Lucene query parser, but scoring with max score, not sum
Accepts the "tie" request parameter as with dismax.
MaxScoreQParserPlugin() - Constructor for class org.apache.solr.search.MaxScoreQParserPlugin
 
maxSize - Variable in class org.apache.solr.util.LongPriorityQueue
 
maxTermDocFreq - Variable in class org.apache.solr.uninverting.DocTermOrds
Don't uninvert terms that exceed this count.
maxWarmingSearchers - Variable in class org.apache.solr.core.SolrConfig
 
maybeProxyToNodes(SolrQueryRequest, SolrQueryResponse, CoreContainer) - Static method in class org.apache.solr.handler.admin.AdminHandlersProxy
 
mayModifyValue() - Method in class org.apache.solr.response.transform.RawValueTransformerFactory
 
mayModifyValue() - Method in interface org.apache.solr.response.transform.TransformerFactory.FieldRenamer
Returns true if implementations of this class may (even subtly) modify field values.
MD5Signature - Class in org.apache.solr.update.processor
 
MD5Signature() - Constructor for class org.apache.solr.update.processor.MD5Signature
 
MDCLoggingContext - Class in org.apache.solr.logging
Set's per thread context info for logging.
MDCLoggingContext() - Constructor for class org.apache.solr.logging.MDCLoggingContext
 
MDCSnapshot - Class in org.apache.solr.logging
Takes a 'snapshot' of the current MDC context map which is restored on (auto) close.
mean - org.apache.solr.handler.component.StatsField.Stat
 
measStr - Variable in class org.apache.solr.search.SpatialOptions
 
MediaTypeOverridingFilter - Class in org.apache.solr.jersey
Overrides the content-type of the response based on an optional user-provided 'wt' parameter
MediaTypeOverridingFilter() - Constructor for class org.apache.solr.jersey.MediaTypeOverridingFilter
 
MemoryCircuitBreaker - Class in org.apache.solr.util.circuitbreaker
Tracks the current JVM heap usage and triggers if a moving heap usage average over 30 seconds exceeds the defined percentage of the maximum heap size allocated to the JVM.
MemoryCircuitBreaker() - Constructor for class org.apache.solr.util.circuitbreaker.MemoryCircuitBreaker
Creates an instance which averages over 6 samples during last 30 seconds.
MemoryCircuitBreaker(int, int) - Constructor for class org.apache.solr.util.circuitbreaker.MemoryCircuitBreaker
Constructor that allows override of sample interval for which the memory usage is fetched.
MemOutputStream - Class in org.apache.solr.update
 
MemOutputStream(byte[]) - Constructor for class org.apache.solr.update.MemOutputStream
 
memSize() - Method in class org.apache.solr.search.facet.UnInvertedField
 
merge(Object, Object, Set<String>) - Method in class org.apache.solr.handler.component.DebugComponent
 
merge(Object, FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetFieldMerger
 
merge(Object, FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetMerger
 
merge(Object, FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetRangeMerger
 
merge(Object, FacetMerger.Context) - Method in class org.apache.solr.search.facet.SumAgg.Merger
 
merge(MergePolicy.OneMerge) - Method in class org.apache.solr.update.SolrIndexWriter
 
merge(SolrInputDocument, SolrInputDocument) - Method in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
Merges the fromDoc into the toDoc using the atomic update syntax.
merge(SimpleOrderedMap<?>, FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetFieldMerger
 
merge(SimpleOrderedMap<?>, FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetRangeMerger
 
merge(QueryElevationComponent.ElevationBuilder) - Method in class org.apache.solr.handler.component.QueryElevationComponent.ElevationBuilder
 
merge(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
merge(ResponseBuilder, ShardRequest) - Method in interface org.apache.solr.handler.component.MergeStrategy
merge defines the merging behaving of results that are collected from the shards during a distributed search.
MERGE_COMP - Static variable in interface org.apache.solr.handler.component.MergeStrategy
 
mergeBucket(SimpleOrderedMap<?>, FacetMerger.Context) - Method in class org.apache.solr.search.facet.FacetBucket
 
mergeContributionFromShard(int, ResponseBuilder, NamedList<Object>) - Method in class org.apache.solr.handler.component.PivotFacetValue
Merges in the count contributions from the specified shard for each.
mergedGroupCounts - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
mergedQueryCommandResults - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
mergedSearchGroups - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
mergedSegmentWarmerInfo - Variable in class org.apache.solr.update.SolrIndexConfig
 
mergedTopGroups - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
mergeFieldHandler - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
mergeIds(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.QueryComponent
 
mergeIndexes(String, MergeIndexesRequestBody) - Method in class org.apache.solr.handler.admin.api.MergeIndexes
 
mergeIndexes(MergeIndexesCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
mergeIndexes(MergeIndexesCommand) - Method in class org.apache.solr.update.UpdateHandler
 
MergeIndexes - Class in org.apache.solr.handler.admin.api
Implementation of V2 API interface MergeIndexesApi for merging one or more indexes to another index.
MergeIndexes(CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.MergeIndexes
 
MERGEINDEXES_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
MergeIndexesCommand - Class in org.apache.solr.update
A merge indexes command encapsulated in an object.
MergeIndexesCommand(List<DirectoryReader>, SolrQueryRequest) - Constructor for class org.apache.solr.update.MergeIndexesCommand
 
mergeMap(Map<String, Object>, Map<String, Object>, List<String>) - Method in class org.apache.solr.request.json.ObjectUtil.ConflictHandler
 
mergeObjects(Map<String, Object>, List<String>, Object, ObjectUtil.ConflictHandler) - Static method in class org.apache.solr.request.json.ObjectUtil
 
MergePolicyFactory - Class in org.apache.solr.index
A factory for creating a MergePolicy.
MergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.MergePolicyFactory
 
MergePolicyFactoryArgs - Class in org.apache.solr.index
 
MergePolicyFactoryArgs() - Constructor for class org.apache.solr.index.MergePolicyFactoryArgs
 
MergePolicyFactoryArgs(Iterable<? extends Map.Entry<String, ?>>) - Constructor for class org.apache.solr.index.MergePolicyFactoryArgs
 
mergePolicyFactoryInfo - Variable in class org.apache.solr.update.SolrIndexConfig
 
Merger() - Constructor for class org.apache.solr.search.facet.SumAgg.Merger
 
mergeResponseFromShard(int, ResponseBuilder, List<NamedList<Object>>) - Method in class org.apache.solr.handler.component.PivotFacet
Recursively merges the response from the specified shard, tracking the known shards.
mergeSchedulerInfo - Variable in class org.apache.solr.update.SolrIndexConfig
 
mergesIds() - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
mergesIds() - Method in interface org.apache.solr.handler.component.MergeStrategy
mergesIds must return true if the merge method merges document ids from the shards.
mergeSolrDocumentList(SolrDocumentList, SolrDocumentList, int, String) - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
mergeSort - Variable in class org.apache.solr.index.SortingMergePolicyFactory
 
mergeStats(Map<String, StatsValues>, NamedList<NamedList<NamedList<?>>>, StatsInfo) - Static method in class org.apache.solr.handler.component.PivotFacetHelper
Given a mapping of keys to StatsValues representing the currently known "merged" stats (which may be null if none exist yet), and a NamedList containing the "stats" response block returned by an individual shard, this method accumulates the stats for each StatsField found in the shard response with the existing mergeStats
MergeStrategy - Interface in org.apache.solr.handler.component
The MergeStrategy class defines custom merge logic for distributed searches.
mergeSuggestions(SpellCheckMergeData, int, int, boolean) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
mergeSuggestions(SpellCheckMergeData, int, int, boolean) - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
mergeSuggestions(SpellCheckMergeData, int, int, boolean) - Method in class org.apache.solr.spelling.SolrSpellChecker
Integrate spelling suggestions from the various shards in a distributed environment.
mergeToGlobalStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
mergeToGlobalStats(SolrQueryRequest, List<ShardResponse>) - Method in class org.apache.solr.search.stats.StatsCache
Process shard responses that contain partial local stats.
mergeWith(QueryElevationComponent.Elevation) - Method in class org.apache.solr.handler.component.QueryElevationComponent.Elevation
Merges this QueryElevationComponent.Elevation with another and creates a new QueryElevationComponent.Elevation.
message - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileListResponse
 
message - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationResponse
 
message - Variable in enum org.apache.solr.security.AuditEvent.EventType
 
message(String, String) - Method in class org.apache.solr.update.LoggingInfoStream
 
MESSAGE - Static variable in class org.apache.solr.handler.ReplicationHandler
 
MessageBodyReaders - Class in org.apache.solr.jersey
A collection point for various MessageBodyReader implementations.
MessageBodyReaders() - Constructor for class org.apache.solr.jersey.MessageBodyReaders
 
MessageBodyReaders.CachingDelegatingMessageBodyReader - Class in org.apache.solr.jersey
Caches the deserialized request body in the ContainerRequestContext for use later in the request lifecycle.
MessageBodyReaders.CachingJsonMessageBodyReader - Class in org.apache.solr.jersey
A JSON MessageBodyReader that caches request bodies for use later in the request lifecycle.
MessageBodyWriters - Class in org.apache.solr.jersey
A collection of thin Jersey shims around Solr's existing QueryResponseWriter interface
MessageBodyWriters() - Constructor for class org.apache.solr.jersey.MessageBodyWriters
 
MessageBodyWriters.BaseMessageBodyWriter - Class in org.apache.solr.jersey
 
MessageBodyWriters.CsvMessageBodyWriter - Class in org.apache.solr.jersey
 
MessageBodyWriters.JavabinMessageBodyWriter - Class in org.apache.solr.jersey
 
MessageBodyWriters.RawMessageBodyWriter - Class in org.apache.solr.jersey
 
MessageBodyWriters.XmlMessageBodyWriter - Class in org.apache.solr.jersey
 
meta - Variable in class org.apache.solr.core.RequestParams.ParamSet
 
meta() - Method in interface org.apache.solr.handler.admin.BaseHandlerApiSupport.ApiCommand
 
META_DATA - org.apache.solr.core.DirectoryFactory.DirContext
 
MetaData(Map<String, Object>) - Constructor for class org.apache.solr.filestore.FileStoreAPI.MetaData
 
METADATA - org.apache.solr.filestore.FileStore.FileType
 
METADATA_FILE - Static variable in class org.apache.solr.core.FileSystemConfigSetService
.metadata.json hidden file where metadata is stored
meter(String, String...) - Method in class org.apache.solr.metrics.SolrDelegateRegistryMetricsContext
 
meter(String, String...) - Method in class org.apache.solr.metrics.SolrMetricsContext
meter(SolrMetricsContext, String, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Create or get an existing named Meter
meterSupplier(SolrResourceLoader, PluginInfo) - Static method in class org.apache.solr.metrics.MetricSuppliers
Create a Meter supplier.
method - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
method - Variable in class org.apache.solr.packagemanager.SolrPackage.Command
 
method - Variable in class org.apache.solr.search.facet.FacetRequest.Domain.JoinField
 
method() - Method in annotation type org.apache.solr.api.EndPoint
 
Method - Enum in org.apache.solr.servlet.cache
 
METHOD_ONLY - Static variable in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
Metric<T> - Interface in org.apache.solr.cluster.placement
Metric-related attribute of a node or replica.
METRIC_NAME - Static variable in class org.apache.solr.util.stats.MetricUtils
 
METRIC_SCOPE - Static variable in class org.apache.solr.update.PeerSync
 
METRIC_SCOPE - Static variable in class org.apache.solr.update.PeerSyncWithLeader
 
metricFilters - Variable in class org.apache.solr.metrics.reporters.solr.SolrReporter.Report
 
MetricImpl<T> - Class in org.apache.solr.cluster.placement.impl
Base class for Metric implementations.
MetricImpl(String, String) - Constructor for class org.apache.solr.cluster.placement.impl.MetricImpl
Create a metric attribute.
MetricImpl(String, String, Function<Object, T>) - Constructor for class org.apache.solr.cluster.placement.impl.MetricImpl
Create a metric attribute.
metricManager - Variable in class org.apache.solr.core.CoreContainer
 
metricManager - Variable in class org.apache.solr.metrics.SolrMetricReporter
 
metricNames - Variable in class org.apache.solr.highlight.HighlightingPluginBase
 
metrics - Variable in class org.apache.solr.handler.RequestHandlerBase
 
METRICS_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
MetricsCollectorHandler - Class in org.apache.solr.handler.admin
Handler to collect and aggregate metric reports.
MetricsCollectorHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.MetricsCollectorHandler
 
MetricsConfig - Class in org.apache.solr.core
 
MetricsConfig.CacheConfig - Class in org.apache.solr.core
 
MetricsConfig.MetricsConfigBuilder - Class in org.apache.solr.core
 
MetricsConfigBuilder() - Constructor for class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
metricsHandler - Variable in class org.apache.solr.core.CoreContainer
 
MetricsHandler - Class in org.apache.solr.handler.admin
Request handler to return metrics
MetricsHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.MetricsHandler
 
MetricsHandler(SolrMetricManager) - Constructor for class org.apache.solr.handler.admin.MetricsHandler
 
metricsInfo - Variable in class org.apache.solr.update.SolrIndexConfig
 
MetricsMap - Class in org.apache.solr.metrics
Dynamically constructed map of metrics, intentionally different from MetricSet where each metric had to be known in advance and registered separately in MetricRegistry.
MetricsMap(MapWriter) - Constructor for class org.apache.solr.metrics.MetricsMap
Create an instance that reports values to a MapWriter.
MetricSuppliers - Class in org.apache.solr.metrics
Helper class for constructing instances of MetricRegistry.MetricSupplier based on plugin configuration.
MetricSuppliers() - Constructor for class org.apache.solr.metrics.MetricSuppliers
 
MetricSuppliers.DefaultCounterSupplier - Class in org.apache.solr.metrics
Default Counter supplier.
MetricSuppliers.DefaultHistogramSupplier - Class in org.apache.solr.metrics
Default supplier of Histogram instances, with configurable reservoir.
MetricSuppliers.DefaultMeterSupplier - Class in org.apache.solr.metrics
Default Meter supplier.
MetricSuppliers.DefaultTimerSupplier - Class in org.apache.solr.metrics
Default supplier of Timer instances, with configurable clock and reservoir.
MetricSuppliers.NoOpCounterSupplier - Class in org.apache.solr.metrics
No-op implementation of Counter supplier.
MetricSuppliers.NoOpGauge - Class in org.apache.solr.metrics
No-op implementation of Gauge.
MetricSuppliers.NoOpHistogramSupplier - Class in org.apache.solr.metrics
No-op implementation of Histogram supplier.
MetricSuppliers.NoOpMeterSupplier - Class in org.apache.solr.metrics
No-op implementation of Meter supplier.
MetricSuppliers.NoOpMetric - Interface in org.apache.solr.metrics
Marker interface for all no-op metrics.
MetricSuppliers.NoOpTimerSupplier - Class in org.apache.solr.metrics
No-op implementation of Timer supplier.
metricTag - Variable in class org.apache.solr.core.CoreContainer
 
MetricUtils - Class in org.apache.solr.util.stats
Metrics specific utility functions.
MetricUtils() - Constructor for class org.apache.solr.util.stats.MetricUtils
 
MIGRATE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
MigrateCmd - Class in org.apache.solr.cloud.api.collections
 
MigrateCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.MigrateCmd
 
migrateDocs(PayloadObj<MigrateDocsPayload>) - Method in class org.apache.solr.handler.admin.api.MigrateDocsAPI
 
MigrateDocsAPI - Class in org.apache.solr.handler.admin.api
V2 API for migrating docs from one collection to another.
MigrateDocsAPI(CollectionsHandler) - Constructor for class org.apache.solr.handler.admin.api.MigrateDocsAPI
 
migrateReplicas(MigrateReplicasRequestBody) - Method in class org.apache.solr.handler.admin.api.MigrateReplicas
 
MigrateReplicas - Class in org.apache.solr.handler.admin.api
V2 API for migrating replicas from a set of nodes to another set of nodes.
MigrateReplicas(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.MigrateReplicas
 
MigrateReplicasCmd - Class in org.apache.solr.cloud.api.collections
 
MigrateReplicasCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.MigrateReplicasCmd
 
MILES - Static variable in class org.apache.solr.util.DistanceUnits
 
MILES_PARAM - Static variable in class org.apache.solr.util.DistanceUnits
 
min - org.apache.solr.handler.component.StatsField.Stat
 
MIN - org.apache.solr.schema.FieldType.MultiValueSelector
 
MIN - org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelectorType
 
MIN_FUZZY_LENGTH - Static variable in class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
Minimum length of lookup key before any edits are allowed for the suggestions in bytes or Unicode code points (if FuzzyLookupFactory.UNICODE_AWARE option is set to true).
MIN_MAX - Static variable in enum org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelectorType
 
min_pop - Variable in class org.apache.solr.search.facet.RelatednessAgg
 
MIN_PREFIX_CHARS - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
Minimum number of leading characters before PrefixQuery is used (default 4).
MIN_SEG_BUFFER_SIZE - Static variable in class org.apache.solr.search.PointMerger
 
minCount - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
minCount - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
MinFieldValueUpdateProcessorFactory - Class in org.apache.solr.update.processor
An update processor that keeps only the minimum value from any selected fields where multiple values are found.
MinFieldValueUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.MinFieldValueUpdateProcessorFactory
 
MinHashQParser - Class in org.apache.solr.search
The query parser can be used in two modes 1) where text is analysed and generates min hashes as part of normal lucene analysis 2) where text is pre-analysed and hashes are added as string to the index An analyzer can still be defined to support text based query against the text field
MinHashQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.MinHashQParser
 
MinHashQParserPlugin - Class in org.apache.solr.search
MinHashQParserPlugin() - Constructor for class org.apache.solr.search.MinHashQParserPlugin
 
MINIMAL_REQUIRED_PARAMS - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
minimalFreeDiskGB - Variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
If a node has strictly less GB of free disk than this value, the node is excluded from assignment decisions.
MinimizeCoresPlacementFactory - Class in org.apache.solr.cluster.placement.plugins
Factory for creating MinimizeCoresPlacementFactory.MinimizeCoresPlacementPlugin, a Placement plugin implementing placing replicas to minimize number of cores per Node, while not placing two replicas of the same shard on the same node.
MinimizeCoresPlacementFactory() - Constructor for class org.apache.solr.cluster.placement.plugins.MinimizeCoresPlacementFactory
 
MINIMUM_EXPTHRESH_PARAM - Static variable in class org.apache.solr.util.hll.HLL
 
MINIMUM_LOG2M_PARAM - Static variable in class org.apache.solr.util.hll.HLL
 
MINIMUM_REGWIDTH_PARAM - Static variable in class org.apache.solr.util.hll.HLL
 
minimumWaitBetweenActions() - Method in class org.apache.solr.cloud.ActionThrottle
 
MinMaxAgg - Class in org.apache.solr.search.facet
 
MinMaxAgg(String, ValueSource) - Constructor for class org.apache.solr.search.facet.MinMaxAgg
 
MinMaxExplain(float, float, float, float) - Constructor for class org.apache.solr.search.ReRankScaler.MinMaxExplain
 
minMaxScaleScores(Map<Integer, Float>, ReRankScaler.MinMaxExplain) - Static method in class org.apache.solr.search.ReRankScaler
 
MINPREFIX - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
MINQUERYLENGTH - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
minSetSizeCached - Variable in class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
 
minShouldMatch - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
minStateByteLenForCompression - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
 
MINUS - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
missing - org.apache.solr.handler.component.StatsField.Stat
 
missing - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
missing() - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
missing() - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
missing() - Method in interface org.apache.solr.handler.component.StatsValues
Updates the statistics when a document is missing a value
MISSING_CONFIG_FILE - org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
The elevation configuration file (e.g.
MISSING_UNIQUE_KEY_FIELD - org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
This component requires the schema to have a uniqueKeyField, which it does not have.
MissingAgg - Class in org.apache.solr.search.facet
AggValueSource to compute missing counts for given ValueSource
MissingAgg(ValueSource) - Constructor for class org.apache.solr.search.facet.MissingAgg
 
missingCount - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
missingGlobalFieldStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
missingGlobalTermStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
missingMax - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
missingMaxPossible - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
MIXED_SOURCES - org.apache.solr.search.SolrReturnFields.FIELD_SOURCES
 
mkName(String, String...) - Static method in class org.apache.solr.metrics.SolrMetricManager
This method creates a hierarchical name with arbitrary levels of hierarchy
MLTContentQParserPlugin - Class in org.apache.solr.search.mlt
 
MLTContentQParserPlugin() - Constructor for class org.apache.solr.search.mlt.MLTContentQParserPlugin
 
MLTQParserPlugin - Class in org.apache.solr.search.mlt
Usage: {!mlt qf=queryField1,queryField2}uniqueId
MLTQParserPlugin() - Constructor for class org.apache.solr.search.mlt.MLTQParserPlugin
 
MMapDirectoryFactory - Class in org.apache.solr.core
Directly provide MMapDirectory instead of relying on FSDirectory.open(java.nio.file.Path).
MMapDirectoryFactory() - Constructor for class org.apache.solr.core.MMapDirectoryFactory
 
mmAutoRelax - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
MOCK_COLL_TASK_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
MockOperationCmd() - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.MockOperationCmd
 
MockSearchableSolrClient - Class in org.apache.solr.util
Simple mock client that collects added documents and supports simple search by id (both {!term f=id} and id: syntax is supported) or *:*.
MockSearchableSolrClient() - Constructor for class org.apache.solr.util.MockSearchableSolrClient
 
MODE_ALLOWED - Static variable in class org.apache.solr.core.NodeRoles
 
MODE_DISALLOWED - Static variable in class org.apache.solr.core.NodeRoles
 
MODE_OFF - Static variable in class org.apache.solr.core.NodeRoles
 
MODE_ON - Static variable in class org.apache.solr.core.NodeRoles
 
MODE_PREFERRED - Static variable in class org.apache.solr.core.NodeRoles
 
modeWhenRoleIsAbsent() - Method in enum org.apache.solr.core.NodeRoles.Role
Default mode for a role in nodes where this role is not specified.
ModificationRequest - Interface in org.apache.solr.cluster.placement
Collection modification request.
ModificationRequestImpl - Class in org.apache.solr.cluster.placement.impl
Helper class to create modification request instances.
ModificationRequestImpl() - Constructor for class org.apache.solr.cluster.placement.impl.ModificationRequestImpl
 
modified(ContainerPluginsRegistry.ApiInfo, ContainerPluginsRegistry.ApiInfo) - Method in interface org.apache.solr.api.ContainerPluginsRegistry.PluginRegistryListener
Called when an existing plugin is replaced.
Modifiers() - Method in class org.apache.solr.parser.QueryParser
 
ModifyBasicAuthConfigAPI - Class in org.apache.solr.handler.admin.api
V2 API to modify configuration for Solr's BasicAuthPlugin
ModifyBasicAuthConfigAPI() - Constructor for class org.apache.solr.handler.admin.api.ModifyBasicAuthConfigAPI
 
modifyCollection(PayloadObj<ModifyCollectionPayload>) - Method in class org.apache.solr.handler.admin.api.ModifyCollectionAPI
 
modifyCollection(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.CollectionMutator
 
MODIFYCOLLECTION_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
ModifyCollectionAPI - Class in org.apache.solr.handler.admin.api
V2 API for modifying collections.
ModifyCollectionAPI(CollectionsHandler) - Constructor for class org.apache.solr.handler.admin.api.ModifyCollectionAPI
 
ModifyCollectionCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.ModifyCollectionCmd
 
modifyConfigComponent(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.ModifyConfigComponentAPI
 
ModifyConfigComponentAPI - Class in org.apache.solr.handler.admin.api
V2 APIs for creating, updating, or deleting individual components in a collection configuration.
ModifyConfigComponentAPI(SolrConfigHandler) - Constructor for class org.apache.solr.handler.admin.api.ModifyConfigComponentAPI
 
modifyIndexProps(String) - Method in class org.apache.solr.core.SolrCore
 
modifyLocalLogLevel(List<NodeLoggingAPI.LogLevelChange>) - Method in class org.apache.solr.handler.admin.api.NodeLoggingAPI
 
modifyLock - Variable in class org.apache.solr.core.SolrCores
 
ModifyMultiPluginAuthConfigAPI - Class in org.apache.solr.handler.admin.api
V2 API to modify configuration options for the MultiAuthPlugin.
ModifyMultiPluginAuthConfigAPI() - Constructor for class org.apache.solr.handler.admin.api.ModifyMultiPluginAuthConfigAPI
 
ModifyNoAuthPluginSecurityConfigAPI - Class in org.apache.solr.handler.admin.api
V2 API for POST requests received when no authentication plugin is active.
ModifyNoAuthPluginSecurityConfigAPI(SecurityConfHandler) - Constructor for class org.apache.solr.handler.admin.api.ModifyNoAuthPluginSecurityConfigAPI
 
ModifyNoAuthzPluginSecurityConfigAPI - Class in org.apache.solr.handler.admin.api
V2 API for POST requests received when no authorization plugin is active.
ModifyNoAuthzPluginSecurityConfigAPI(SecurityConfHandler) - Constructor for class org.apache.solr.handler.admin.api.ModifyNoAuthzPluginSecurityConfigAPI
 
ModifyParamSetAPI - Class in org.apache.solr.handler.admin.api
V2 APIs for creating, modifying, or deleting paramsets.
ModifyParamSetAPI(SolrConfigHandler) - Constructor for class org.apache.solr.handler.admin.api.ModifyParamSetAPI
 
modifyParamSets(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.ModifyParamSetAPI
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.DebugComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.ExpandComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.FacetComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.HighlightComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.SearchComponent
Called after another component adds a request
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.StatsComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.TermVectorComponent
 
modifyRequest(ResponseBuilder, SearchComponent, ShardRequest) - Method in class org.apache.solr.search.facet.FacetModule
 
modifyRequest(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
modifyRequest(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
modifyRequest(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.spelling.SolrSpellChecker
modify the shard request to be used in a distributed environment.
ModifyRuleBasedAuthConfigAPI - Class in org.apache.solr.handler.admin.api
V2 API to modify configuration options for the RuleBasedAuthorizationPlugin.
ModifyRuleBasedAuthConfigAPI() - Constructor for class org.apache.solr.handler.admin.api.ModifyRuleBasedAuthConfigAPI
 
moduleExists(Path, String) - Static method in class org.apache.solr.util.ModuleUtils
Returns true if a module name is valid and exists in the system
ModuleUtils - Class in org.apache.solr.util
Parses the list of modules the user has requested in solr.xml, property solr.modules or environment SOLR_MODULES.
ModuleUtils() - Constructor for class org.apache.solr.util.ModuleUtils
 
monitorZookeeper(String) - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
 
MoreLikeThisAPI - Class in org.apache.solr.handler.admin.api
V2 API for performing a more like this request to a solr collection.
MoreLikeThisAPI(MoreLikeThisHandler) - Constructor for class org.apache.solr.handler.admin.api.MoreLikeThisAPI
 
MoreLikeThisComponent - Class in org.apache.solr.handler.component
TODO!
MoreLikeThisComponent() - Constructor for class org.apache.solr.handler.component.MoreLikeThisComponent
 
MoreLikeThisHandler - Class in org.apache.solr.handler
Solr MoreLikeThis --
MoreLikeThisHandler() - Constructor for class org.apache.solr.handler.MoreLikeThisHandler
 
MoreLikeThisHandler.InterestingTerm - Class in org.apache.solr.handler
 
MoreLikeThisHandler.MoreLikeThisHelper - Class in org.apache.solr.handler
Helper class for MoreLikeThis that can be called from other request handlers
MoreLikeThisHelper(SolrParams, SolrIndexSearcher) - Constructor for class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
 
move(Directory, Directory, String, IOContext) - Method in class org.apache.solr.core.DirectoryFactory
Override for more efficient moves.
move(Directory, Directory, String, IOContext) - Method in class org.apache.solr.core.StandardDirectoryFactory
Override for more efficient moves.
moveReplica(PayloadObj<MoveReplicaPayload>) - Method in class org.apache.solr.handler.admin.api.MoveReplicaAPI
 
MOVEREPLICA_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
MoveReplicaAPI - Class in org.apache.solr.handler.admin.api
V2 API for moving a collection replica to a different physical node.
MoveReplicaAPI(CollectionsHandler) - Constructor for class org.apache.solr.handler.admin.api.MoveReplicaAPI
 
MoveReplicaCmd - Class in org.apache.solr.cloud.api.collections
 
MoveReplicaCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.MoveReplicaCmd
 
mtime - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
multBoosts - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
MULTI_OK - org.apache.solr.core.SolrConfig.PluginOpts
 
MULTI_TERM - Static variable in class org.apache.solr.schema.FieldType
 
MULTI_TERM_ANALYZER - Static variable in class org.apache.solr.schema.FieldType
 
MultiAuthPlugin - Class in org.apache.solr.security
Authentication plugin that supports multiple Authorization schemes, such as Bearer and Basic.
MultiAuthPlugin(CoreContainer) - Constructor for class org.apache.solr.security.MultiAuthPlugin
 
MultiAuthRuleBasedAuthorizationPlugin - Class in org.apache.solr.security
Authorization plugin designed to work with the MultiAuthPlugin to support different AuthorizationPlugin per scheme.
MultiAuthRuleBasedAuthorizationPlugin(CoreContainer) - Constructor for class org.apache.solr.security.MultiAuthRuleBasedAuthorizationPlugin
 
MultiDestinationAuditLogger - Class in org.apache.solr.security
Audit logger that chains other loggers.
MultiDestinationAuditLogger() - Constructor for class org.apache.solr.security.MultiDestinationAuditLogger
 
MULTIPART - Static variable in class org.apache.solr.servlet.SolrRequestParsers
 
multiplierFromDegreesToThisUnit() - Method in class org.apache.solr.util.DistanceUnits
 
multiplierFromThisUnitToDegrees() - Method in class org.apache.solr.util.DistanceUnits
 
MULTIPLY - org.apache.solr.search.ReRankOperator
 
MultiStringFunction - Class in org.apache.solr.search.function
Abstract ValueSource implementation which wraps multiple ValueSources and applies an extendible string function to their values.
MultiStringFunction(ValueSource[]) - Constructor for class org.apache.solr.search.function.MultiStringFunction
 
MultiTerm(String, List<BooleanClause>) - Method in class org.apache.solr.parser.QueryParser
 
multiTermAnalyzer - Variable in class org.apache.solr.schema.TextField
Analyzer set by schema for text types to use when searching fields of this type, subclasses can set analyzer themselves or override getIndexAnalyzer() This analyzer is used to process wildcard, prefix, regex and other multiterm queries.
multiValued() - Method in class org.apache.solr.schema.SchemaField
 
MULTIVALUED - Static variable in class org.apache.solr.schema.FieldProperties
 
multiValuedFieldCache() - Method in class org.apache.solr.schema.FieldType
Returns true if a single field value of this type has multiple logical values for the purposes of faceting, sorting, etc.
multiValuedFieldCache() - Method in class org.apache.solr.schema.PointField
 
multiValuedFieldCache() - Method in class org.apache.solr.schema.SortableTextField
Returns true if a single field value of this type has multiple logical values for the purposes of faceting, sorting, etc.
multiValuedFieldCache() - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
MultiValueTermOrdinalCollector - Class in org.apache.solr.search.join
Populates a bitset of (top-level) ordinals based on field values in a multi-valued field.
MultiValueTermOrdinalCollector(String, SortedSetDocValues, LongBitSet) - Constructor for class org.apache.solr.search.join.MultiValueTermOrdinalCollector
 
must - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
mustMatch - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.CategoryRoutedAliasProperties
 
mutate(SolrInputField) - Method in class org.apache.solr.update.processor.AllValuesOrNoneFieldMutatingUpdateProcessor
 
mutate(SolrInputField) - Method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
Method for mutating SolrInputFields associated with fields identified by the FieldNameSelector associated with this processor
mutate(SolrInputField) - Method in class org.apache.solr.update.processor.FieldValueMutatingUpdateProcessor
 
mutateValue(Object) - Method in class org.apache.solr.update.processor.AllValuesOrNoneFieldMutatingUpdateProcessor
Mutates individual values of a field as needed, or returns the original value.
mutateValue(Object) - Method in class org.apache.solr.update.processor.FieldValueMutatingUpdateProcessor
Mutates individual values of a field as needed, or returns the original value.
mutator(FieldMutatingUpdateProcessor.FieldNameSelector, UpdateRequestProcessor, Function<SolrInputField, SolrInputField>) - Static method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
 
muteConsole() - Static method in class org.apache.solr.util.StartupLoggingUtils
Disables all log4j2 ConsoleAppender's by modifying log4j configuration dynamically.
mzxid - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 

N

name - Variable in class org.apache.solr.cloud.overseer.ZkWriteCommand
 
name - Variable in class org.apache.solr.cluster.placement.impl.MetricImpl
 
name - Variable in class org.apache.solr.core.InitParams
 
name - Variable in class org.apache.solr.core.PluginInfo
 
name - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileMetaData
 
name - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.CreateAliasRequestBody
 
name - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelInfo
 
name - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationRequestBody
 
name - Variable in class org.apache.solr.handler.component.FacetComponent.ShardFacetCount
 
name - Variable in class org.apache.solr.handler.component.FieldFacetStats
 
name - Variable in class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
 
name - Variable in class org.apache.solr.logging.LoggerInfo
 
name - Variable in class org.apache.solr.metrics.SolrMetricInfo
 
name - Variable in class org.apache.solr.packagemanager.PackageRepository
 
name - Variable in class org.apache.solr.packagemanager.SolrPackage
 
name - Variable in class org.apache.solr.packagemanager.SolrPackage.Plugin
 
name - Variable in class org.apache.solr.packagemanager.SolrPackageInstance
 
name - Variable in class org.apache.solr.response.transform.ValueSourceAugmenter
 
name - Variable in class org.apache.solr.schema.IndexSchema
 
name - Variable in class org.apache.solr.schema.IndexSchema.SchemaProps
 
name - Variable in class org.apache.solr.search.facet.AggValueSource
 
name - Variable in class org.apache.solr.search.function.distance.SquaredEuclideanFunction
 
name - Variable in class org.apache.solr.spelling.SolrSpellChecker
Dictionary name
name - Variable in class org.apache.solr.util.DataConfigNode
 
name() - Method in annotation type org.apache.solr.api.Command
if this is not a json command , leave it empty.
name() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage
 
name() - Method in class org.apache.solr.search.facet.AggValueSource
 
name() - Method in class org.apache.solr.search.FloatPayloadValueSource
 
name() - Method in class org.apache.solr.search.function.ConcatStringFunction
 
name() - Method in class org.apache.solr.search.function.distance.GeohashFunction
Deprecated.
 
name() - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
Deprecated.
 
name() - Method in class org.apache.solr.search.function.distance.HaversineConstFunction
 
name() - Method in class org.apache.solr.search.function.distance.HaversineFunction
 
name() - Method in class org.apache.solr.search.function.distance.SquaredEuclideanFunction
 
name() - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
name() - Method in class org.apache.solr.search.function.DualDoubleFunction
 
name() - Method in class org.apache.solr.search.function.MultiStringFunction
 
name() - Method in interface org.apache.solr.search.SolrCache
Name the Cache can be referenced with by SolrRequestHandlers.
name() - Method in class org.apache.solr.search.SolrCacheBase
 
name() - Method in class org.apache.solr.update.AddUpdateCommand
 
name() - Method in class org.apache.solr.update.CommitUpdateCommand
 
name() - Method in class org.apache.solr.update.DeleteUpdateCommand
 
name() - Method in class org.apache.solr.update.MergeIndexesCommand
 
name() - Method in class org.apache.solr.update.RollbackUpdateCommand
 
name() - Method in class org.apache.solr.update.SplitIndexCommand
 
name() - Method in class org.apache.solr.update.UpdateCommand
 
name() - Method in class org.apache.solr.util.DataConfigNode
 
name() - Method in class org.apache.solr.util.DOMConfigNode
 
NAME - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
NAME - Static variable in class org.apache.solr.analysis.LowerCaseTokenizerFactory
Deprecated.
SPI name
NAME - Static variable in class org.apache.solr.analysis.ReversedWildcardFilterFactory
SPI name
NAME - Static variable in class org.apache.solr.core.ConfigOverlay
 
NAME - Static variable in class org.apache.solr.core.RequestParams
 
NAME - Static variable in class org.apache.solr.response.SolrQueryResponse
 
NAME - Static variable in class org.apache.solr.rest.schema.analysis.ManagedStopFilterFactory
SPI name
NAME - Static variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
SPI name
NAME - Static variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
SPI name
NAME - Static variable in class org.apache.solr.schema.IndexSchema
 
NAME - Static variable in class org.apache.solr.search.BoolQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.BoostQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.ComplexPhraseQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.DisMaxQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.ExportQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.ExtendedDismaxQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.facet.RelatednessAgg
 
NAME - Static variable in class org.apache.solr.search.FieldQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.function.ConcatStringFunction
 
NAME - Static variable in class org.apache.solr.search.FunctionQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.FunctionRangeQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.GraphTermsQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.HashQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.IGainTermsQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.join.BlockJoinChildQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.join.BlockJoinParentQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.join.ChildFieldValueSourceParser
 
NAME - Static variable in class org.apache.solr.search.join.FiltersQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.join.GraphQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.join.HashRangeQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.JoinQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.LuceneQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.MaxScoreQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.MinHashQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.mlt.MLTContentQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.mlt.MLTQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.NestedQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.neural.KnnQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.PayloadCheckQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.PayloadScoreQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.PrefixQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.RankQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.RawQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.SignificantTermsQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.SimpleQParserPlugin
The name that can be used to specify this plugin should be used to parse the query.
NAME - Static variable in class org.apache.solr.search.SpatialBoxQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.SpatialFilterQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.SurroundQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.SwitchQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.TermQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.TermsQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.TextLogisticRegressionQParserPlugin
 
NAME - Static variable in class org.apache.solr.search.XmlQParserPlugin
 
NAME - Static variable in class org.apache.solr.update.processor.AtomicUpdateProcessorFactory
 
NAME - Static variable in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
NAME - Static variable in class org.apache.solr.update.processor.UUIDUpdateProcessorFactory
 
NamedListInitializedPlugin - Interface in org.apache.solr.util.plugin
A plugin that can be initialized with a NamedList
NamedListPluginLoader<T extends NamedListInitializedPlugin> - Class in org.apache.solr.util.plugin
 
NamedListPluginLoader(String, Class<T>, Map<String, T>) - Constructor for class org.apache.solr.util.plugin.NamedListPluginLoader
 
NamedListSerializer() - Constructor for class org.apache.solr.jersey.SolrJacksonMapper.NamedListSerializer
 
NamedListSerializer(Class<NamedList>) - Constructor for class org.apache.solr.jersey.SolrJacksonMapper.NamedListSerializer
 
namedListStyle - Variable in class org.apache.solr.response.JSONWriter
 
nameLower - Variable in enum org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
nameMapping - Static variable in class org.apache.solr.schema.IndexSchema
 
nameStrategy - Variable in class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
nameStrategy - Variable in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
nameToDetailsMapping - Variable in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
Used to map snapshot name to snapshot meta-data.
needRefinements - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
needsAuthorization(HttpServletRequest) - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
needsSolrIndexSearcher() - Method in class org.apache.solr.response.transform.DocTransformer
Indicates if this transformer requires access to the underlying index to perform it's functions.
needsSolrIndexSearcher() - Method in class org.apache.solr.response.transform.DocTransformers
Returns true if and only if at least 1 child transformer returns true
needsSolrIndexSearcher() - Method in class org.apache.solr.response.transform.ValueSourceAugmenter
Always returns true
NEST_PARENT_FIELD_NAME - Static variable in class org.apache.solr.schema.IndexSchema
 
NEST_PATH_FIELD_NAME - Static variable in class org.apache.solr.schema.IndexSchema
 
NestedQParserPlugin - Class in org.apache.solr.search
Create a nested query, with the ability of that query to redefine its type via local parameters.
NestedQParserPlugin() - Constructor for class org.apache.solr.search.NestedQParserPlugin
 
NestedRequestHandler - Interface in org.apache.solr.handler
An interface for RequestHandlers need to handle all paths under its registered path
NestedUpdateProcessorFactory - Class in org.apache.solr.update.processor
Adds fields to nested documents to support some nested search requirements.
NestedUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.NestedUpdateProcessorFactory
 
NestPathField - Class in org.apache.solr.schema
To be used for field IndexSchema.NEST_PATH_FIELD_NAME for enhanced nested doc information.
NestPathField() - Constructor for class org.apache.solr.schema.NestPathField
 
NEW_COLLECTION_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
newAliasMustExistException(String) - Static method in class org.apache.solr.cloud.api.collections.RoutedAlias
 
newBackupRepository(String) - Method in class org.apache.solr.core.CoreContainer
This method instantiates a new instance of BackupRepository.
newBooleanClause(Query, BooleanClause.Occur) - Method in class org.apache.solr.parser.SolrQueryParserBase
Builds a new BooleanClause instance
newBytesRefFilter(String, SolrParams) - Method in class org.apache.solr.request.SimpleFacets
Create a new bytes ref filter for filtering facet terms.
newContext(IndexSearcher) - Static method in class org.apache.solr.search.QueryContext
 
newDefaultUpdateLog() - Method in class org.apache.solr.core.DirectoryFactory
Returns a default Update Log instance.
newDoubleRange(String, int, Double, Double, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a double range using the given precisionStep.
newDoubleRange(String, Double, Double, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a double range using the default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT (16).
newDynamicField(String, String, Map<String, ?>) - Method in class org.apache.solr.schema.IndexSchema
Returns a SchemaField if the given dynamic field glob does not already exist in this schema, and does not match any dynamic fields in this schema.
newDynamicField(String, String, Map<String, ?>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
newestLogsOnStartup - Variable in class org.apache.solr.update.UpdateLog
 
newExcludeBytesRefFilter(String, SolrParams) - Method in class org.apache.solr.request.SimpleFacets
Create a new bytes ref filter for excluding facet terms.
newField(String, String, Map<String, ?>) - Method in class org.apache.solr.schema.IndexSchema
Returns a SchemaField if the given fieldName does not already exist in this schema, and does not match any dynamic fields in this schema.
newField(String, String, Map<String, ?>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
newFieldQuery(Analyzer, String, String, boolean, boolean, boolean, SolrQueryParserBase.SynonymQueryStyle) - Method in class org.apache.solr.parser.QueryParser
 
newFieldQuery(Analyzer, String, String, boolean, boolean, boolean, SolrQueryParserBase.SynonymQueryStyle) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
newFieldQuery(Analyzer, String, String, boolean, boolean, boolean, SolrQueryParserBase.SynonymQueryStyle) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
newFieldType(String, String, Map<String, ?>) - Method in class org.apache.solr.schema.IndexSchema
Returns a FieldType if the given typeName does not already exist in this schema.
newFieldType(String, String, Map<String, ?>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
newFloatRange(String, int, Float, Float, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a float range using the given precisionStep.
newFloatRange(String, Float, Float, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a float range using the default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT_32 (8).
newFuzzyQuery(Term, float, int) - Method in class org.apache.solr.parser.SolrQueryParserBase
Builds a new FuzzyQuery instance
newGraphSynonymQuery(Iterator<Query>) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
newHighlightsArray(int) - Method in class org.apache.solr.handler.component.HighlightComponent
 
newHLL() - Method in class org.apache.solr.handler.component.StatsField.HllOptions
 
newIndexSchemaFactory(SolrConfig) - Static method in class org.apache.solr.schema.IndexSchemaFactory
Instantiates us from SolrConfig.
newIndexWriter(boolean) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
newIndexWriter(boolean) - Method in class org.apache.solr.update.UpdateHandler
Called when the Writer should be opened again - eg when replication replaces all of the index files.
newIndexWriter(SolrCore, boolean) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
newIndexWriter(SolrCore, boolean) - Method in class org.apache.solr.update.SolrCoreState
Force the creation of a new IndexWriter using the settings from the given SolrCore.
newInstance() - Method in class org.apache.solr.search.CacheConfig
 
newInstance(String, Class<T>) - Method in class org.apache.solr.core.SolrResourceLoader
 
newInstance(String, Class<T>, String...) - Method in class org.apache.solr.core.SolrResourceLoader
 
newInstance(String, Class<T>, String...) - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
newInstance(String, Class<T>, String[], Class<?>[], Object[]) - Method in class org.apache.solr.core.SolrResourceLoader
 
newInstance(String, Class<T>, String[], Class<?>[], Object[]) - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
newInstance(PluginInfo, Class<T>, boolean) - Method in class org.apache.solr.core.SolrResourceLoader
Create an instance of a class using an appropriate SolrResourceLoader depending on the package of that class
newInstance(PluginInfo, SolrResourceLoader) - Static method in class org.apache.solr.handler.component.ShardHandlerFactory
Create a new ShardHandlerFactory instance
newInstance(SolrResourceLoader) - Method in class org.apache.solr.core.backup.repository.BackupRepositoryFactory
 
newInstance(SolrResourceLoader, String) - Method in class org.apache.solr.core.backup.repository.BackupRepositoryFactory
 
newInstance(SpatialContext, String) - Static method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
Creates a new BBoxStrategy instance that uses DoublePoint and DoublePoint.newRangeQuery(java.lang.String, double, double)
newIntRange(String, int, Integer, Integer, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a int range using the given precisionStep.
newIntRange(String, Integer, Integer, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a int range using the default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT_32 (8).
newLBHttpSolrClientReq(QueryRequest, List<String>) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
newLegacyInstance(SpatialContext, String) - Static method in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
LegacyNumerics will be removed
newLine - Variable in class org.apache.solr.internal.csv.CSVPrinter
True if we just began a new line.
newLoader(SolrQueryRequest, UpdateRequestProcessor) - Method in class org.apache.solr.handler.ContentStreamHandlerBase
 
newLoader(SolrQueryRequest, UpdateRequestProcessor) - Method in class org.apache.solr.handler.UpdateRequestHandler
 
newLongRange(String, int, Long, Long, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a long range using the given precisionStep.
newLongRange(String, Long, Long, boolean, boolean) - Static method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
Factory that creates a LegacyNumericRangeQuery, that queries a long range using the default precisionStep LegacyNumericUtils.PRECISION_STEP_DEFAULT (16).
newMap() - Method in class org.apache.solr.update.UpdateLog
 
newMatchAllDocsQuery() - Method in class org.apache.solr.parser.SolrQueryParserBase
Builds a new MatchAllDocsQuery instance
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultCounterSupplier
 
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultHistogramSupplier
 
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultMeterSupplier
 
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.DefaultTimerSupplier
 
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.NoOpCounterSupplier
 
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.NoOpHistogramSupplier
 
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.NoOpMeterSupplier
 
newMetric() - Method in class org.apache.solr.metrics.MetricSuppliers.NoOpTimerSupplier
 
newMetricFilter() - Method in class org.apache.solr.metrics.FilteringSolrMetricReporter
Report only metrics with names matching any of the prefix filters.
newPrefixQuery(Term) - Method in class org.apache.solr.parser.SolrQueryParserBase
Builds a new PrefixQuery instance
newPrefixTreeStrategy(String) - Method in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
newPrefixTreeStrategy(String) - Method in class org.apache.solr.schema.DateRangeField
 
newPrefixTreeStrategy(String) - Method in class org.apache.solr.schema.SpatialRecursivePrefixTreeFieldType
 
newReader(IndexWriter, SolrCore) - Method in class org.apache.solr.core.IndexReaderFactory
Creates a new IndexReader instance using the given IndexWriter.
newReader(IndexWriter, SolrCore) - Method in class org.apache.solr.core.StandardIndexReaderFactory
 
newReader(Directory, SolrCore) - Method in class org.apache.solr.core.IndexReaderFactory
Creates a new IndexReader instance using the given Directory.
newReader(Directory, SolrCore) - Method in class org.apache.solr.core.StandardIndexReaderFactory
 
newRecoveryStrategy(CoreContainer, CoreDescriptor, RecoveryStrategy.RecoveryListener) - Method in class org.apache.solr.cloud.RecoveryStrategy.Builder
 
newRegexpQuery(Term) - Method in class org.apache.solr.parser.SolrQueryParserBase
Builds a new RegexpQuery instance
newRegisteredLogWatcher(LogWatcherConfig, SolrResourceLoader) - Static method in class org.apache.solr.logging.LogWatcher
Create and register a LogWatcher.
newRequestWriter() - Method in enum org.apache.solr.client.solrj.embedded.EmbeddedSolrServer.RequestWriterSupplier
 
newResponseBuilder(SolrQueryRequest, SolrQueryResponse, List<SearchComponent>) - Method in class org.apache.solr.handler.component.SearchHandler
Override this method if you require a custom ResponseBuilder e.g.
newSampleDocumentsLoader(CoreContainer) - Static method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
newSchemaSuggester(CoreContainer) - Static method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
newSearcher(String) - Method in interface org.apache.solr.util.TestInjection.Hook
 
newSearcher(SolrIndexSearcher, SolrIndexSearcher) - Method in class org.apache.solr.core.AbstractSolrEventListener
 
newSearcher(SolrIndexSearcher, SolrIndexSearcher) - Method in class org.apache.solr.core.DelegatingEventListener
 
newSearcher(SolrIndexSearcher, SolrIndexSearcher) - Method in class org.apache.solr.core.QuerySenderListener
 
newSearcher(SolrIndexSearcher, SolrIndexSearcher) - Method in interface org.apache.solr.core.SolrEventListener
The searchers passed here are only guaranteed to be valid for the duration of this method call, so care should be taken not to spawn threads or asynchronous tasks with references to these searchers.
newSearcher(SolrIndexSearcher, SolrIndexSearcher) - Method in class org.apache.solr.schema.ExternalFileFieldReloader
 
newSearcherHook(TestInjection.Hook) - Static method in class org.apache.solr.util.TestInjection
 
newShard(String) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
newShardHandler() - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
newShardHandler() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionCommandContext
 
newShardHandler() - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
newSimpleFacets(SolrQueryRequest, DocSet, SolrParams, ResponseBuilder) - Method in class org.apache.solr.handler.component.FacetComponent
 
newSolrCores(CoreContainer) - Static method in class org.apache.solr.core.SolrCores
 
newSpatialArgsParser() - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
newSpatialStrategy(String) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
Called from AbstractSpatialFieldType.getStrategy(String) upon first use by fieldName.
newSpatialStrategy(String) - Method in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
newSpatialStrategy(String) - Method in class org.apache.solr.schema.BBoxField
 
newSpatialStrategy(String) - Method in class org.apache.solr.schema.LatLonPointSpatialField
 
newSpatialStrategy(String) - Method in class org.apache.solr.schema.RptWithGeometrySpatialField
 
newState(ClusterState, String, DocCollection) - Static method in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
newStorageIO(String, SolrResourceLoader, NamedList<String>) - Static method in class org.apache.solr.rest.ManagedResourceStorage
Creates a new StorageIO instance for a Solr core, taking into account whether the core is running in cloud mode as well as initArgs.
newSynonymQuery(String, QueryBuilder.TermAndBoost[]) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
newTimer() - Method in class org.apache.solr.util.RTimerTree
 
newTimerImpl() - Method in class org.apache.solr.util.RTimer
 
newToken(int) - Static method in class org.apache.solr.parser.Token
 
newToken(int, String) - Static method in class org.apache.solr.parser.Token
Returns a new Token object, by default.
newTransactionLog(Path, Collection<String>, boolean) - Method in class org.apache.solr.update.UpdateLog
Returns a new TransactionLog.
newUpdateComparePasses(T, T, String) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessor
Given two comparable user versions, returns whether the new version is acceptable to replace the old version.
newWildcardQuery(Term) - Method in class org.apache.solr.parser.SolrQueryParserBase
Builds a new WildcardQuery instance
next - Variable in class org.apache.solr.parser.Token
A reference to the next regular (non-special) token from the input stream.
next - Variable in class org.apache.solr.update.processor.UpdateRequestProcessor
 
next() - Method in class org.apache.solr.response.DocsStreamer
 
next() - Method in class org.apache.solr.spelling.PossibilityIterator
 
next() - Method in class org.apache.solr.update.TransactionLog.FSReverseReader
Returns the next object from the log, or null if none available.
next() - Method in class org.apache.solr.update.TransactionLog.LogReader
Returns the next object from the log, or null if none available.
next() - Method in class org.apache.solr.update.TransactionLog.ReverseReader
Returns the next object from the log, or null if none available.
next() - Method in class org.apache.solr.update.TransactionLog.SortedLogReader
 
next() - Method in interface org.apache.solr.util.LongIterator
 
NEXT_EXECUTION_AT - Static variable in class org.apache.solr.handler.ReplicationHandler
 
nextBackupId() - Method in class org.apache.solr.core.backup.BackupId
 
nextDoc() - Method in class org.apache.solr.search.BitsFilteredPostingsEnum
 
nextDoc() - Method in interface org.apache.solr.search.DocIterator
Returns the next document id if hasNext()==true This method is equivalent to next(), but avoids the creation of an Integer Object.
nextDoc() - Method in class org.apache.solr.search.facet.FieldUtil.DVOrdValues
 
nextDoc() - Method in class org.apache.solr.search.facet.FieldUtil.FCOrdValues
 
nextDoc() - Method in class org.apache.solr.search.facet.FieldUtil.OrdValues
 
nextDoc() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
nextEvent() - Method in class org.apache.solr.util.RecordingJSONParser
 
nextToken() - Method in class org.apache.solr.internal.csv.CSVParser
Convenience method for nextToken(null).
nextToken(CSVParser.Token) - Method in class org.apache.solr.internal.csv.CSVParser
Returns the next token.
nextValue() - Method in class org.apache.solr.internal.csv.CSVParser
Parses the CSV according to the given strategy and returns the next csv-value as string.
NGRAMS - Static variable in class org.apache.solr.spelling.suggest.fst.FreeTextLookupFactory
The n-gram model to use in the underlying suggester; Default value is 2.
NIOFSDirectoryFactory - Class in org.apache.solr.core
Factory to instantiate NIOFSDirectory
NIOFSDirectoryFactory() - Constructor for class org.apache.solr.core.NIOFSDirectoryFactory
 
nl - org.apache.solr.response.transform.ExplainAugmenterFactory.Style
 
NO_CHECK_QCACHE - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
NO_CONFIG_FILE_DEFINED - org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
Missing component parameter QueryElevationComponent.CONFIG_FILE - it has to define the path to the elevation configuration file (e.g.
NO_FREQUENCY_INFO - Static variable in class org.apache.solr.spelling.SpellingResult
 
NO_INDEX_COMMIT_EXIST - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
NO_MATCHES - Static variable in class org.apache.solr.search.TopLevelJoinQuery.BitsetBounds
 
NO_OP - Static variable in class org.apache.solr.cloud.overseer.ZkStateWriter
Represents a no-op ZkWriteCommand which will result in no modification to cluster state
NO_OP - Static variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
NO_OP_ELEVATION_PROVIDER - Static variable in class org.apache.solr.handler.component.QueryElevationComponent
NO_SUB - Static variable in interface org.apache.solr.handler.tagger.TagClusterReducer
 
NO_SUB_PACKAGES - Static variable in class org.apache.solr.index.WrapperMergePolicyFactory
 
NO_VALUES - Static variable in class org.apache.solr.search.facet.HLLAgg
 
noClausesQuery() - Method in class org.apache.solr.search.join.BlockJoinChildQParser
 
noClausesQuery() - Method in class org.apache.solr.search.join.BlockJoinParentQParser
 
noClausesQuery() - Method in class org.apache.solr.search.join.FiltersQParser
 
NoConfig() - Constructor for class org.apache.solr.cluster.placement.PlacementPluginFactory.NoConfig
 
node - org.apache.solr.core.SolrInfoBean.Group
 
node - Variable in class org.apache.solr.cloud.api.collections.AddReplicaCmd.CreateReplica
 
node - Variable in class org.apache.solr.handler.ClusterAPI.RoleInfo
 
node - Variable in class org.apache.solr.update.SolrCmdDistributor.Req
 
Node - Interface in org.apache.solr.cluster
Representation of a SolrCloud node or server in the SolrCloud cluster.
Node() - Constructor for class org.apache.solr.update.SolrCmdDistributor.Node
 
NODE_IS_USER - Static variable in class org.apache.solr.security.PKIAuthenticationPlugin
 
NODE_ROLES_PROP - Static variable in class org.apache.solr.core.NodeRoles
 
NODE_TYPE_SYSPROP - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Name of the system property on a node indicating the arbitrary "node type" (for example, a node more suitable for the indexing work load could be labeled as node_type: indexing).
NodeConfig - Class in org.apache.solr.core
 
NodeConfig.NodeConfigBuilder - Class in org.apache.solr.core
 
NodeConfigBuilder(String, Path) - Constructor for class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
NodeConfigClusterPluginsSource - Class in org.apache.solr.api
Plugin configurations that are defined in solr.xml.
NodeConfigClusterPluginsSource(CoreContainer) - Constructor for class org.apache.solr.api.NodeConfigClusterPluginsSource
 
NodeHealthAPI - Class in org.apache.solr.handler.admin.api
V2 API for checking the health of the receiving node.
NodeHealthAPI(HealthCheckHandler) - Constructor for class org.apache.solr.handler.admin.api.NodeHealthAPI
 
nodeKeyPair - Variable in class org.apache.solr.core.CoreContainer
 
NodeLoggingAPI - Class in org.apache.solr.handler.admin.api
V2 APIs for getting or setting log levels on an individual node.
NodeLoggingAPI(CoreContainer) - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI
 
NodeLoggingAPI.ListLevelsResponse - Class in org.apache.solr.handler.admin.api
Response format for the 'GET /api/node/logging/levels' API.
NodeLoggingAPI.LoggingResponse - Class in org.apache.solr.handler.admin.api
Generic logging response that includes the name of the log watcher (e.g.
NodeLoggingAPI.LogLevelChange - Class in org.apache.solr.handler.admin.api
A user-requested modification in the level that a specified logger reports at.
NodeLoggingAPI.LogLevelInfo - Class in org.apache.solr.handler.admin.api
Representation of a single logger and its current state.
NodeLoggingAPI.LogMessageInfo - Class in org.apache.solr.handler.admin.api
Metadata about the log messages returned by the 'GET /api/node/logging/messages' API
NodeLoggingAPI.LogMessagesResponse - Class in org.apache.solr.handler.admin.api
Response format for the 'GET /api/node/logging/messages' API.
NodeLoggingAPI.SetThresholdRequestBody - Class in org.apache.solr.handler.admin.api
The request body for the 'PUT /api/node/logging/messages/threshold' API.
NodeMetric<T> - Interface in org.apache.solr.cluster.placement
Node metric identifier, corresponding to a node-level metric registry and the internal metric name.
NodeMetric.Registry - Enum in org.apache.solr.cluster.placement
Registry options for node metrics.
NodeMetricImpl<T> - Class in org.apache.solr.cluster.placement.impl
Node metric identifier, corresponding to a node-level metric registry and the internal metric name.
NodeMetricImpl(String) - Constructor for class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
NodeMetricImpl(String, Function<Object, T>) - Constructor for class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
NodeMetricImpl(String, NodeMetric.Registry, String) - Constructor for class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
NodeMetricImpl(String, NodeMetric.Registry, String, Function<Object, T>) - Constructor for class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
NodeMutator - Class in org.apache.solr.cloud.overseer
 
NodeMutator(SolrCloudManager) - Constructor for class org.apache.solr.cloud.overseer.NodeMutator
 
nodeName - Variable in class org.apache.solr.handler.component.ShardRequest
may be null
NodePropertiesAPI - Class in org.apache.solr.handler.admin.api
V2 API for listing system properties for each node.
NodePropertiesAPI(PropertiesRequestHandler) - Constructor for class org.apache.solr.handler.admin.api.NodePropertiesAPI
 
nodeProps - Variable in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
nodeRoles - Variable in class org.apache.solr.core.CoreContainer
 
NodeRoles - Class in org.apache.solr.core
 
NodeRoles(String) - Constructor for class org.apache.solr.core.NodeRoles
 
NodeRoles.Role - Enum in org.apache.solr.core
 
nodes - Variable in class org.apache.solr.cloud.api.collections.Assign.AssignRequest
 
nodes - Variable in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
NODES_DOWN - org.apache.solr.cluster.events.ClusterEvent.EventType
One or more nodes went down.
NODES_UP - org.apache.solr.cluster.events.ClusterEvent.EventType
One or more nodes went up.
NodesDownEvent - Interface in org.apache.solr.cluster.events
Event generated when some nodes went down.
NodesUpEvent - Interface in org.apache.solr.cluster.events
Event generated when some nodes went up.
nodesWithRole(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
nodesWithRoleMode(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
NodeSystemInfoAPI - Class in org.apache.solr.handler.admin.api
V2 API for getting "system" information from the receiving node.
NodeSystemInfoAPI(SystemInfoHandler) - Constructor for class org.apache.solr.handler.admin.api.NodeSystemInfoAPI
 
NodeThreadsAPI - Class in org.apache.solr.handler.admin.api
V2 API for triggering a thread dump on the receiving node.
NodeThreadsAPI(ThreadDumpHandler) - Constructor for class org.apache.solr.handler.admin.api.NodeThreadsAPI
 
NOFILE - org.apache.solr.filestore.FileStore.FileType
 
NoMergePolicyFactory - Class in org.apache.solr.index
 
NoMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.NoMergePolicyFactory
 
NON_FUZZY_PREFIX - Static variable in class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
Length of common (non-fuzzy) prefix for the suggestions in bytes or Unicode code points (if FuzzyLookupFactory.UNICODE_AWARE option is set to true).
NONE - org.apache.solr.search.facet.FacetRequest.RefineMethod
 
NONE - org.apache.solr.update.processor.DistributedUpdateProcessor.DistribPhase
 
NONE - org.apache.solr.update.UpdateLog.SyncLevel
 
NONE - Static variable in class org.apache.solr.handler.designer.SampleDocuments
 
NONE - Static variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
nonExistentCoreExceptionAfterUnload - Static variable in class org.apache.solr.util.TestInjection
 
nonGracefullClose - Static variable in class org.apache.solr.util.TestInjection
 
nonTaggableOffsets - Variable in class org.apache.solr.handler.tagger.OffsetCorrector
Disjoint start and end span offsets (inclusive) of non-taggable sections.
NOOP - org.apache.solr.core.SolrConfig.PluginOpts
 
NOOP_IMPL_CLASS - Static variable in class org.apache.solr.core.MetricsConfig
Symbolic name to use as plugin class name for no-op implementations.
NoOpCounterSupplier() - Constructor for class org.apache.solr.metrics.MetricSuppliers.NoOpCounterSupplier
 
NoOpDistributingUpdateProcessorFactory - Class in org.apache.solr.update.processor
A No-Op implementation of DistributingUpdateProcessorFactory that allways returns the next processor instead of inserting a new URP in front of it.
NoOpDistributingUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.NoOpDistributingUpdateProcessorFactory
 
NoopFieldTransformer() - Constructor for class org.apache.solr.response.transform.DocTransformer.NoopFieldTransformer
 
NoopFieldTransformer(String) - Constructor for class org.apache.solr.response.transform.DocTransformer.NoopFieldTransformer
 
NoOpGauge() - Constructor for class org.apache.solr.metrics.MetricSuppliers.NoOpGauge
 
NoOpHistogramSupplier() - Constructor for class org.apache.solr.metrics.MetricSuppliers.NoOpHistogramSupplier
 
NoOpMeterSupplier() - Constructor for class org.apache.solr.metrics.MetricSuppliers.NoOpMeterSupplier
 
NoOpProducer - Class in org.apache.solr.cluster.events
No-op implementation of ClusterEventProducer.
NoOpProducer(CoreContainer) - Constructor for class org.apache.solr.cluster.events.NoOpProducer
 
NoOpRegenerator - Class in org.apache.solr.search
Cache regenerator that just populates the new cache with the old items.
NoOpRegenerator() - Constructor for class org.apache.solr.search.NoOpRegenerator
 
NoOpTimerSupplier() - Constructor for class org.apache.solr.metrics.MetricSuppliers.NoOpTimerSupplier
 
normalize(String) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
normalize(String) - Method in class org.apache.solr.core.DirectoryFactory
Normalize a given path.
normalize(String) - Static method in class org.apache.solr.core.RequestHandlers
Trim the trailing '/' if it's there, and convert null to empty string.
normalize(String) - Method in class org.apache.solr.core.StandardDirectoryFactory
 
normalize(String, TokenStream) - Method in class org.apache.solr.analysis.TokenizerChain
 
normalize(NamedList<?>) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
The 'avgRequestsPerSecond' field will make everything look like it changed
normalizeDir(String) - Static method in class org.apache.solr.core.SolrPaths
Ensures a directory name always ends with a '/'.
normalizePath(String) - Static method in class org.apache.solr.handler.admin.CoreAdminHandler
 
normalizeReceivedException(SolrQueryRequest, Exception) - Static method in class org.apache.solr.handler.RequestHandlerBase
 
normalizeResourcePath(String) - Method in class org.apache.solr.security.AuditEvent
 
normalizeSolrUrl(String) - Static method in class org.apache.solr.cli.SolrCLI
Strips off the end of solrUrl any /solr when a legacy solrUrl like http://localhost:8983/solr is used, and warns those users.
normalizeUrlEnding(String) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Normalizes a URL string by removing anchor part and trailing slash
NORMS - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
noSelectorsSpecified() - Method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
 
NOT - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
NOT_EDITABLE - Static variable in class org.apache.solr.core.ConfigOverlay
 
NOT_FOUND_FLAG - Static variable in interface org.apache.solr.jersey.RequestContextKeys
A flag set by NotFoundExceptionMapper indicating that a 404 error response was suppressed.
NOT_REQUIRED_FIELD_MATCH_PREDICATE - Static variable in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
NOT_SET - org.apache.solr.search.SolrReturnFields.FIELD_SOURCES
 
notANumber() - Method in class org.apache.solr.metrics.SolrMetricManager
Return an object used for representing a "Not A Number" (NaN) value.
notANumber() - Method in class org.apache.solr.metrics.SolrMetricsContext
NotFoundExceptionMapper - Class in org.apache.solr.jersey
An ExceptionMapper for the exception produced by JAX-RS when no match could be found for an incoming request.
NotFoundExceptionMapper() - Constructor for class org.apache.solr.jersey.NotFoundExceptionMapper
 
NotFoundRequestHandler - Class in org.apache.solr.handler
Does nothing other than showing a 404 message
NotFoundRequestHandler() - Constructor for class org.apache.solr.handler.NotFoundRequestHandler
 
notifyListeners(String) - Method in class org.apache.solr.pkg.SolrPackageLoader
 
notifyObserversDuringInit(NamedList<?>, Collection<ManagedResourceObserver>) - Method in class org.apache.solr.rest.ManagedResource
Notifies all registered observers that the ManagedResource is initialized.
notifyPauseForeverDone() - Static method in class org.apache.solr.util.TestInjection
 
NotInClusterStateException(SolrException.ErrorCode, String) - Constructor for exception org.apache.solr.cloud.ZkController.NotInClusterStateException
 
NRT - org.apache.solr.cluster.Replica.ReplicaType
 
NRTCachingDirectoryFactory - Class in org.apache.solr.core
Factory to instantiate NRTCachingDirectory
NRTCachingDirectoryFactory() - Constructor for class org.apache.solr.core.NRTCachingDirectoryFactory
 
nsToMs(double) - Static method in class org.apache.solr.util.stats.MetricUtils
Converts a double representing nanoseconds to a double representing milliseconds.
NULL - Static variable in interface org.apache.solr.security.PermissionNameProvider
 
NULL_COLLAPSE - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
Deprecated.
NULL_EXPAND - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
Deprecated.
NULL_IGNORE - Static variable in class org.apache.solr.search.CollapsingQParserPlugin
Deprecated.
nullNumber() - Method in class org.apache.solr.metrics.SolrMetricManager
Return an object used for representing a null (missing) numeric value.
nullNumber() - Method in class org.apache.solr.metrics.SolrMetricsContext
nullObject() - Method in class org.apache.solr.metrics.SolrMetricManager
Return an object used for representing a null (missing) object value.
nullObject() - Method in class org.apache.solr.metrics.SolrMetricsContext
nullString() - Method in class org.apache.solr.metrics.SolrMetricManager
Return an object used for representing a null (missing) string value.
nullString() - Method in class org.apache.solr.metrics.SolrMetricsContext
NUM_CORES - Static variable in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
Number of all cores.
NUM_RESPONSES_TO_STORE - Static variable in class org.apache.solr.cloud.Overseer
 
NUM_SHARDS - Static variable in class org.apache.solr.cloud.CloudDescriptor
 
NUM_SLICES - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
numAuthenticated - Variable in class org.apache.solr.security.AuthenticationPlugin
 
NUMBER - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
NUMBER_BACKUPS_TO_KEEP_INIT_PARAM - Static variable in class org.apache.solr.handler.ReplicationHandler
 
NUMBER_BACKUPS_TO_KEEP_REQUEST_PARAM - Static variable in class org.apache.solr.handler.ReplicationHandler
 
numberToKeep - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationRequestBody
 
NumberType - Enum in org.apache.solr.schema
 
NumberUtils - Class in org.apache.solr.util
 
NumberUtils() - Constructor for class org.apache.solr.util.NumberUtils
 
numClientErrors - Variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
numCloses - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
numCloses - Static variable in class org.apache.solr.update.SolrIndexWriter
 
numDataNodes() - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the number of nodes in the trie that have non-null data.
numDataNodes(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the number of nodes in the subtrie below and including the starting node.
numDeletesByQueryToKeep - Variable in class org.apache.solr.update.UpdateLog
 
numDeletesToKeep - Variable in class org.apache.solr.update.UpdateLog
 
numDocs - Variable in class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
numDocs() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
numDocs() - Method in class org.apache.solr.search.SolrIndexSearcher
 
numDocs(Query, Query) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns the number of documents that match both a and b.
numDocs(Query, DocSet) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns the number of documents that match both a and b.
numDocs(DocSet, SolrIndexSearcher.DocsEnumState) - Method in class org.apache.solr.search.SolrIndexSearcher
 
numDocs(SolrIndexSearcher, Query, Query) - Static method in class org.apache.solr.util.SolrPluginUtils
SolrIndexSearch.numDocs(Query,Query) freaks out if the filtering query is null, so we use this workarround.
numericDocValuesRangeQuery(String, Number, Number, boolean, boolean, boolean) - Static method in class org.apache.solr.schema.NumericFieldType
 
NumericFieldType - Class in org.apache.solr.schema
 
NumericFieldType() - Constructor for class org.apache.solr.schema.NumericFieldType
 
NumericHidingLeafReader - Class in org.apache.solr.search
Deprecated.
numericPrecisionStep() - Method in class org.apache.solr.legacy.LegacyFieldType
Deprecated.
Please switch to PointValues instead
numericType() - Method in class org.apache.solr.legacy.LegacyFieldType
Deprecated.
Please switch to PointValues instead
NumericValueFieldType - Interface in org.apache.solr.schema
Marker interface for numeric-valued field types.
numErrors - Variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
numErrors - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
numErrors - Variable in class org.apache.solr.security.AuthenticationPlugin
 
numFiles() - Method in class org.apache.solr.core.backup.ShardBackupMetadata
 
numGroups - Variable in class org.apache.solr.search.Grouping.Command
 
numLogged - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
numLost - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
numMissingCredentials - Variable in class org.apache.solr.security.AuthenticationPlugin
 
numNodes() - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the total number of nodes in the trie.
numNodes(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns the total number of nodes in the subtrie below and including the starting Node.
numNrtReplicas - Variable in class org.apache.solr.cloud.api.collections.Assign.AssignRequest
 
numOldRecords - Variable in class org.apache.solr.update.UpdateLog
 
numOpens - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
numOpens - Static variable in class org.apache.solr.update.SolrIndexWriter
 
numPassThrough - Variable in class org.apache.solr.security.AuthenticationPlugin
 
numPullReplicas - Variable in class org.apache.solr.cloud.api.collections.Assign.AssignRequest
 
numRecords() - Method in class org.apache.solr.update.TransactionLog
Returns the number of records in the log (currently includes the header and an optional commit).
numRecordsToKeep - Variable in class org.apache.solr.update.UpdateLog
 
numRequests - Variable in class org.apache.solr.highlight.HighlightingPluginBase
 
numServerErrors - Variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
numTerms() - Method in class org.apache.solr.uninverting.DocTermOrds
Returns the number of terms in this field
NUMTERMS - Static variable in class org.apache.solr.handler.admin.LukeRequestHandler
 
numTermsInField - Variable in class org.apache.solr.uninverting.DocTermOrds
Number of terms in the field.
numTimeouts - Variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
numTlogReplicas - Variable in class org.apache.solr.cloud.api.collections.Assign.AssignRequest
 
numVersionBuckets - Variable in class org.apache.solr.update.UpdateLog
 
numWrongCredentials - Variable in class org.apache.solr.security.AuthenticationPlugin
 

O

objectName() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.MetricMBean
 
ObjectUtil - Class in org.apache.solr.request.json
 
ObjectUtil() - Constructor for class org.apache.solr.request.json.ObjectUtil
 
ObjectUtil.ConflictHandler - Class in org.apache.solr.request.json
 
objToInt(Object, int) - Static method in class org.apache.solr.update.UpdateLog
 
OcmhCollectionCommandContext - Class in org.apache.solr.cloud.api.collections
Context passed to Collection API commands when they execute in the Overseer.
OcmhCollectionCommandContext(OverseerCollectionMessageHandler) - Constructor for class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
of(String) - Static method in class org.apache.solr.metrics.SolrMetricInfo
 
of(String, long) - Static method in class org.apache.solr.update.PeerSync.MissedUpdatesRequest
 
offer(byte[]) - Method in class org.apache.solr.cloud.ZkDistributedQueue
Inserts data into queue.
offer(byte[], long) - Method in class org.apache.solr.cloud.OverseerTaskQueue
Offer the data and wait for the response
offerLiveDocs(Supplier<DocSet>, int) - Method in class org.apache.solr.search.SolrIndexSearcher
If some process external to SolrIndexSearcher has produced a DocSet whose cardinality matches that of `liveDocs`, this method provides such caller the ability to offer its own DocSet to be cached in the searcher.
offerStateUpdate(byte[]) - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
This method enables the commands to enqueue to the overseer cluster state update.
offerStateUpdate(byte[]) - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
offerStateUpdate(byte[]) - Method in class org.apache.solr.cloud.Overseer
 
offerStateUpdate(MapWriter) - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
 
offerStateUpdate(MapWriter) - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
offerStateUpdate(MapWriter) - Method in class org.apache.solr.cloud.Overseer
 
offset - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
offset - Variable in class org.apache.solr.search.Grouping.Command
 
offset() - Method in interface org.apache.solr.search.DocList
Returns the zero based offset of this list within the total ordered list of matches to the query.
offset() - Method in class org.apache.solr.search.DocSlice
 
OFFSET - Static variable in class org.apache.solr.handler.ReplicationHandler
 
OFFSET_END_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
OFFSET_START_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
OffsetCorrector - Class in org.apache.solr.handler.tagger
 
OffsetCorrector(String, boolean) - Constructor for class org.apache.solr.handler.tagger.OffsetCorrector
Initialize based on the document text.
offsetPair - Variable in class org.apache.solr.handler.tagger.OffsetCorrector
 
OK - Static variable in class org.apache.solr.security.AuthorizationResponse
 
OK_STATUS - Static variable in class org.apache.solr.handler.ReplicationHandler
 
oldDeletes - Variable in class org.apache.solr.update.UpdateLog
 
OMIT_NORMS - Static variable in class org.apache.solr.schema.FieldProperties
 
OMIT_POSITIONS - Static variable in class org.apache.solr.schema.FieldProperties
 
OMIT_TF_POSITIONS - Static variable in class org.apache.solr.schema.FieldProperties
 
omitNorms() - Method in class org.apache.solr.schema.SchemaField
 
omitPositions() - Method in class org.apache.solr.schema.SchemaField
 
omitTermFreqAndPositions() - Method in class org.apache.solr.schema.SchemaField
 
onChange(Map<String, Object>) - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
onChange(Map<String, Object>) - Method in class org.apache.solr.servlet.RateLimitManager
 
onCommit(List<? extends IndexCommit>) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Internal use for Lucene...
onCommit(List<? extends IndexCommit>) - Method in class org.apache.solr.core.SolrDeletionPolicy
Internal use for Lucene...
onComplete(SolrCore, IndexFetcher.IndexFetchResult) - Method in interface org.apache.solr.handler.ReplicationHandler.PollListener
 
oneOverPower - Variable in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
onePassDistributedQuery - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
onEvent(ClusterEvent) - Method in interface org.apache.solr.cluster.events.ClusterEventListener
Handle the event.
onEvent(ClusterEvent) - Method in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
onInit(List<? extends IndexCommit>) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Internal use for Lucene...
onInit(List<? extends IndexCommit>) - Method in class org.apache.solr.core.SolrDeletionPolicy
Internal use for Lucene...
ONLY_ACTIVE_NODES - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
ONLY_IF_DOWN - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
ONLY_NRT_REPLICAS - Static variable in class org.apache.solr.handler.component.HttpShardHandler
If the request context map has an entry with this key and Boolean.TRUE as value, HttpShardHandler.prepDistributed(ResponseBuilder) will only include Replica.Type.NRT replicas as possible destination of the distributed request (or a leader replica of type Replica.Type.TLOG).
onManagedDataLoadedFromStorage(NamedList<?>, Object) - Method in class org.apache.solr.rest.ManagedResource
Method called after data has been loaded from storage to give the concrete implementation a chance to post-process the data.
onManagedDataLoadedFromStorage(NamedList<?>, Object) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
onManagedDataLoadedFromStorage(NamedList<?>, Object) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
onManagedDataLoadedFromStorage(NamedList<?>, Object) - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
Invoked when loading data from storage to initialize the list of words managed by this instance.
onManagedResourceInitialized(NamedList<?>, ManagedResource) - Method in interface org.apache.solr.rest.ManagedResourceObserver
Event notification raised once during core initialization to notify listeners that a ManagedResource is fully initialized.
onManagedResourceInitialized(NamedList<?>, ManagedResource) - Method in class org.apache.solr.rest.schema.analysis.ManagedStopFilterFactory
Callback invoked by the ManagedResource instance to trigger this class to create the CharArraySet used to create the StopFilter using the wordset managed by ManagedWordSetResource.
onManagedResourceInitialized(NamedList<?>, ManagedResource) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
Called once, during core initialization, to initialize any analysis components that depend on the data managed by this resource.
onManagedResourceInitialized(NamedList<?>, ManagedResource) - Method in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
Called once, during core initialization, to initialize any analysis components that depend on the data managed by this resource.
onNodes(List<String>) - Method in class org.apache.solr.cloud.api.collections.Assign.AssignRequestBuilder
 
onRemoval(K, V, RemovalCause) - Method in class org.apache.solr.search.CaffeineCache
 
onResourceDeleted() - Method in class org.apache.solr.rest.ManagedResource
Called by the RestManager framework after this resource has been deleted to allow this resource to close and clean-up any resources used by this.
onStateChanged(Set<String>, DocCollection) - Method in class org.apache.solr.cloud.ActiveReplicaWatcher
 
onStateChanged(Set<String>, DocCollection) - Method in class org.apache.solr.cloud.api.collections.LeaderRecoveryWatcher
 
onTermChanged(ShardTerms) - Method in class org.apache.solr.cloud.RecoveringCoreTermWatcher
 
onWrite() - Method in interface org.apache.solr.cloud.overseer.ZkStateWriter.ZkWriteCallback
Called by ZkStateWriter if state is flushed to ZK
op - Variable in class org.apache.solr.handler.admin.CoreAdminHandler.CallInfo
 
OP - Static variable in class org.apache.solr.search.QueryParsing
 
open() - Method in class org.apache.solr.core.SolrCore
expert: increments the core reference count
open() - Method in class org.apache.solr.handler.CatStream
 
open() - Method in class org.apache.solr.handler.ClassifyStream
 
open() - Method in class org.apache.solr.handler.export.ExportWriterStream
 
open() - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
open() - Method in class org.apache.solr.handler.GraphHandler.TimerStream
 
open() - Method in class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
open() - Method in class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
open() - Method in class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
open() - Method in class org.apache.solr.handler.StreamHandler.TimerStream
 
open(FileChannel, long) - Method in interface org.apache.solr.update.TransactionLog.ChannelInputStreamOpener
open(FileChannel, long) - Method in interface org.apache.solr.update.TransactionLog.OutputStreamOpener
Opens an OutputStream to write in a FileChannel.
OpenExchangeRatesOrgProvider - Class in org.apache.solr.schema
Exchange Rates Provider for CurrencyField and CurrencyFieldType capable of fetching & parsing the freely available exchange rates from openexchangerates.org
OpenExchangeRatesOrgProvider() - Constructor for class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
openIndexWriter(SolrCore) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
openIndexWriter(SolrCore) - Method in class org.apache.solr.update.SolrCoreState
Expert method that opens the IndexWriter - you must call SolrCoreState.closeIndexWriter(SolrCore, boolean) first, and then call this method in a finally block.
openInput(URI, String, IOContext) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method returns a Lucene input stream reading an existing file.
openInput(URI, String, IOContext) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
openInputStream(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.FileStorageIO
 
openInputStream(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.InMemoryStorageIO
 
openInputStream(String) - Method in interface org.apache.solr.rest.ManagedResourceStorage.StorageIO
 
openInputStream(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
openNewSearcher(boolean, boolean) - Method in class org.apache.solr.core.SolrCore
Opens a new searcher and returns a RefCounted<SolrIndexSearcher> with its reference incremented.
openOutputStream(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.FileStorageIO
 
openOutputStream(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.InMemoryStorageIO
 
openOutputStream(String) - Method in interface org.apache.solr.rest.ManagedResourceStorage.StorageIO
 
openOutputStream(String) - Method in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
openRealtimeSearcher() - Method in class org.apache.solr.update.UpdateLog
Opens a new realtime searcher and clears the id caches.
openResource(String) - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
Opens any resource by its name.
openResource(String) - Method in class org.apache.solr.core.SolrResourceLoader
Opens any resource by its name.
openSearcher - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
openSearcher - Variable in class org.apache.solr.update.CommitUpdateCommand
 
OPENTIME - org.apache.solr.core.SolrConfig.HttpCachingConfig.LastModFrom
 
OperatingSystemMetricSet - Class in org.apache.solr.metrics
This is an extended replacement for FileDescriptorRatioGauge - that class uses reflection and doesn't work under Java 9.
OperatingSystemMetricSet() - Constructor for class org.apache.solr.metrics.OperatingSystemMetricSet
 
operation - Variable in class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
OPERATION_MASK - Static variable in class org.apache.solr.update.UpdateLog
 
OPERATION_RESPONSE - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler
 
operationRspInfo - Variable in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
operator - Variable in class org.apache.solr.parser.SolrQueryParserBase
The default operator that parser uses to combine query terms
opMap - Variable in class org.apache.solr.handler.admin.CoreAdminHandler
 
ops - Variable in class org.apache.solr.cloud.overseer.ZkWriteCommand
 
opt(char) - Method in class org.apache.solr.search.StrParser
 
opt(String) - Method in class org.apache.solr.search.StrParser
 
optimize - Variable in class org.apache.solr.update.CommitUpdateCommand
 
optimize() - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Does a simple optimize operation
OPTIMIZE - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
optimizeCallbacks - Variable in class org.apache.solr.update.UpdateHandler
 
optimizePreFetchDocs(ResponseBuilder, DocList, Query, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.util.SolrPluginUtils
Pre-fetch documents into the index searcher's document cache.
OPTION_RECURSE - Static variable in class org.apache.solr.cli.SolrCLI
 
OPTION_SOLRURL - Static variable in class org.apache.solr.cli.SolrCLI
 
OPTION_VERBOSE - Static variable in class org.apache.solr.cli.SolrCLI
 
OPTION_ZKHOST - Static variable in class org.apache.solr.cli.SolrCLI
 
OPTIONAL_ROUTER_PARAMS - Static variable in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
Optional parameters for creating a category routed alias excluding parameters for collection creation.
OPTIONAL_ROUTER_PARAMS - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
Optional parameters for creating a routed alias excluding parameters for collection creation.
options - Variable in class org.apache.solr.core.SolrConfig.SolrPluginInfo
 
OR - org.apache.solr.parser.QueryParser.Operator
 
OR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
OR_OPERATOR - Static variable in class org.apache.solr.parser.SolrQueryParserBase
Alternative form of QueryParser.Operator.OR
ORANGE - org.apache.solr.handler.admin.ClusterStatus.Health
Most replicas down, leader exists.
ORANGE_LEVEL - Static variable in enum org.apache.solr.handler.admin.ClusterStatus.Health
 
ordBase - Variable in class org.apache.solr.uninverting.DocTermOrds
Ordinal of the first term in the field, or 0 if the PostingsFormat does not implement TermsEnum.ord().
OrderedExecutor - Class in org.apache.solr.util
 
OrderedExecutor(int, ExecutorService) - Constructor for class org.apache.solr.util.OrderedExecutor
 
OrderedNodePlacementPlugin - Class in org.apache.solr.cluster.placement.plugins
 
OrderedNodePlacementPlugin() - Constructor for class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
OrderedNodePlacementPlugin.WeightedNode - Class in org.apache.solr.cluster.placement.plugins
A class that determines the weight of a given node and the replicas that reside on it.
orderInShard - Variable in class org.apache.solr.handler.component.ShardDoc
 
OrdFieldSource - Class in org.apache.solr.search.function
Obtains the ordinal of the field value from LeafReader.getSortedDocValues(java.lang.String).
OrdFieldSource(String) - Constructor for class org.apache.solr.search.function.OrdFieldSource
 
ordValue() - Method in class org.apache.solr.search.facet.FieldUtil.DVOrdValues
 
ordValue() - Method in class org.apache.solr.search.facet.FieldUtil.FCOrdValues
 
ordValue() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl.Iter
 
OrdValues() - Constructor for class org.apache.solr.search.facet.FieldUtil.OrdValues
 
OrFilter(MetricFilter...) - Constructor for class org.apache.solr.metrics.SolrMetricManager.OrFilter
 
OrFilter(Collection<MetricFilter>) - Constructor for class org.apache.solr.metrics.SolrMetricManager.OrFilter
 
org.apache.solr - package org.apache.solr
Commonly reused classes and interfaces (deprecated package, do not add new classes)
org.apache.solr.analysis - package org.apache.solr.analysis
Factories and classes specific to text analysis and the creation of TokenStreams
org.apache.solr.api - package org.apache.solr.api
Commonly used classes for Solr V2 API.
org.apache.solr.cli - package org.apache.solr.cli
Solr Command Line Interface classes
org.apache.solr.client.solrj.embedded - package org.apache.solr.client.solrj.embedded
SolrJ client implementations for embedded solr access.
org.apache.solr.cloud - package org.apache.solr.cloud
Classes for dealing with ZooKeeper when operating in SolrCloud mode.
org.apache.solr.cloud.api.collections - package org.apache.solr.cloud.api.collections
Package related to internal implementations of the SolrCloud collections api
org.apache.solr.cloud.overseer - package org.apache.solr.cloud.overseer
Classes for updating cluster state in SolrCloud mode.
org.apache.solr.cluster - package org.apache.solr.cluster
This package contains the interfaces giving access to cluster state, including nodes, collections and the structure of the collections (shards and replicas).
org.apache.solr.cluster.events - package org.apache.solr.cluster.events
Interfaces defining support for cluster-level event generation and processing.
org.apache.solr.cluster.events.impl - package org.apache.solr.cluster.events.impl
Default implementation of ClusterEventProducer.
org.apache.solr.cluster.placement - package org.apache.solr.cluster.placement
This package contains interfaces visible by plugins (i.e.
org.apache.solr.cluster.placement.impl - package org.apache.solr.cluster.placement.impl
Implementation classes (not visible to plugins, subject to change at any time) for the interfaces in org.apache.solr.cluster.placement and to make them work with the rest of Solr.
org.apache.solr.cluster.placement.plugins - package org.apache.solr.cluster.placement.plugins
Sample plugin implementations.
org.apache.solr.core - package org.apache.solr.core
Core classes implementing Solr internals and the management of SolrCores
org.apache.solr.core.backup - package org.apache.solr.core.backup
Core classes for Solr's Backup/Restore functionality
org.apache.solr.core.backup.repository - package org.apache.solr.core.backup.repository
BackupRepository Providing backup/restore repository interfaces to plug different storage systems
org.apache.solr.core.snapshots - package org.apache.solr.core.snapshots
Core classes for Solr's persistent snapshots functionality
org.apache.solr.filestore - package org.apache.solr.filestore
Implementation of File Store.
org.apache.solr.handler - package org.apache.solr.handler
Concrete implementations of SolrRequestHandler
org.apache.solr.handler.admin - package org.apache.solr.handler.admin
SolrRequestHandler implementations for powering he Solr Admin UI
org.apache.solr.handler.admin.api - package org.apache.solr.handler.admin.api
V2 API implementations for "admin" APIs.
org.apache.solr.handler.api - package org.apache.solr.handler.api
V2 utilities useful for all API implementations.
org.apache.solr.handler.component - package org.apache.solr.handler.component
SearchComponent implementations for use in SearchHandler
org.apache.solr.handler.configsets - package org.apache.solr.handler.configsets
V2 API classes for performing CRUD operations on configsets.
org.apache.solr.handler.designer - package org.apache.solr.handler.designer
The SchemaDesignerAPI and supporting classes.
org.apache.solr.handler.export - package org.apache.solr.handler.export
Solr's Export Handler Functionality
org.apache.solr.handler.loader - package org.apache.solr.handler.loader
ContentStreamLoader implementations for use in ContentStreamHandlerBase implementations
org.apache.solr.handler.tagger - package org.apache.solr.handler.tagger
The TaggerRequestHandler and supporting classes.
org.apache.solr.highlight - package org.apache.solr.highlight
SolrHighlighter API and related implementations and utilities
org.apache.solr.index - package org.apache.solr.index
Indexing related classes.
org.apache.solr.internal.csv - package org.apache.solr.internal.csv
Internal classes used for reading/writing CSV
org.apache.solr.jersey - package org.apache.solr.jersey
Jersey integration code
org.apache.solr.jersey.container - package org.apache.solr.jersey.container
Adapter code used to convert the native Jetty request/response abstractions into the objects required by Jersey
org.apache.solr.legacy - package org.apache.solr.legacy
Deprecated stuff!
org.apache.solr.logging - package org.apache.solr.logging
APIs related to capturing log event info in the LoggingHandler
org.apache.solr.logging.jul - package org.apache.solr.logging.jul
JUL based implementation of LogWatcher
org.apache.solr.logging.log4j2 - package org.apache.solr.logging.log4j2
LOG4J2 based implementation of LogWatcher
org.apache.solr.metrics - package org.apache.solr.metrics
The SolrCoreMetricManager is responsible for collecting metrics from SolrMetricProducer's and exposing metrics to SolrMetricReporter's.
org.apache.solr.metrics.reporters - package org.apache.solr.metrics.reporters
This package houses 'pluggable' metric reporters that inherit from the SolrMetricReporter class.
org.apache.solr.metrics.reporters.jmx - package org.apache.solr.metrics.reporters.jmx
This package contains components that support SolrJmxReporter.
org.apache.solr.metrics.reporters.solr - package org.apache.solr.metrics.reporters.solr
This package contains SolrMetricReporter implementations specific to SolrCloud reporting.
org.apache.solr.packagemanager - package org.apache.solr.packagemanager
This package contains Package Manager (CLI) implementation
org.apache.solr.parser - package org.apache.solr.parser
Solr native variant of the Lucene Classic QueryParser
org.apache.solr.pkg - package org.apache.solr.pkg
Package management implementation
org.apache.solr.query - package org.apache.solr.query
Solr Queries
org.apache.solr.request - package org.apache.solr.request
APIs and classes for dealing with Solr requests
org.apache.solr.request.json - package org.apache.solr.request.json
JSON related classes
org.apache.solr.request.macro - package org.apache.solr.request.macro
Parameter substitution / macro expansion.
org.apache.solr.response - package org.apache.solr.response
API and implementations of QueryResponseWriter for formatting Solr request responses
org.apache.solr.response.transform - package org.apache.solr.response.transform
APIs and implementations of DocTransformer for modifying documents in Solr request responses
org.apache.solr.rest - package org.apache.solr.rest
Solr RESTful APIs.
org.apache.solr.rest.schema - package org.apache.solr.rest.schema
Provides RESTful API access to managed resources in the Solr Schema.
org.apache.solr.rest.schema.analysis - package org.apache.solr.rest.schema.analysis
Analysis-related functionality for RESTful API access to managed resources related to the schema, such as stopwords, protected words, and synonyms.
org.apache.solr.schema - package org.apache.solr.schema
IndexSchema and FieldType implementations for powering schema.xml
org.apache.solr.search - package org.apache.solr.search
APIs and classes for parsing and processing search requests
org.apache.solr.search.facet - package org.apache.solr.search.facet
APIs and classes for the JSON Facet API.
org.apache.solr.search.function - package org.apache.solr.search.function
Solr implementations of ValueSource for function queries.
org.apache.solr.search.function.distance - package org.apache.solr.search.function.distance
Solr implementations of ValueSource for distance based function queries.
org.apache.solr.search.grouping - package org.apache.solr.search.grouping
APIs and classes for implementing result grouping
org.apache.solr.search.grouping.collector - package org.apache.solr.search.grouping.collector
Grouping related Collectors
org.apache.solr.search.grouping.distributed - package org.apache.solr.search.grouping.distributed
Internal classes used to implement distributed result grouping
org.apache.solr.search.grouping.distributed.command - package org.apache.solr.search.grouping.distributed.command
Internal classes used to implement distributed result grouping
org.apache.solr.search.grouping.distributed.requestfactory - package org.apache.solr.search.grouping.distributed.requestfactory
Internal classes used to implement distributed result grouping
org.apache.solr.search.grouping.distributed.responseprocessor - package org.apache.solr.search.grouping.distributed.responseprocessor
Internal classes used to implement distributed result grouping
org.apache.solr.search.grouping.distributed.shardresultserializer - package org.apache.solr.search.grouping.distributed.shardresultserializer
Internal classes used to implement distributed result grouping
org.apache.solr.search.grouping.endresulttransformer - package org.apache.solr.search.grouping.endresulttransformer
APIs and classes for transforming result grouping results into the appropriate response format
org.apache.solr.search.join - package org.apache.solr.search.join
Classes related to joins.
org.apache.solr.search.mlt - package org.apache.solr.search.mlt
APIs and classes for implementing MoreLikeThis (mlt) QueryParser.
org.apache.solr.search.neural - package org.apache.solr.search.neural
APIs and classes for implementing Neural (Dense Retrieval) QueryParsers.
org.apache.solr.search.similarities - package org.apache.solr.search.similarities
Factories for various built-in Lucene ranking models.
org.apache.solr.search.stats - package org.apache.solr.search.stats
APIs and Classes implementing the Stats component used for document frequency calculations.
org.apache.solr.security - package org.apache.solr.security
Commonly used classes for Solr security framework.
org.apache.solr.servlet - package org.apache.solr.servlet
Servlet related classes for powering the Solr HTTP API
org.apache.solr.servlet.cache - package org.apache.solr.servlet.cache
Caching related classes used in the Solr HTTP API
org.apache.solr.spelling - package org.apache.solr.spelling
APIs and classes used by the SpellCheckComponent
org.apache.solr.spelling.suggest - package org.apache.solr.spelling.suggest
APIs and classes used by the SpellCheckComponent
org.apache.solr.spelling.suggest.fst - package org.apache.solr.spelling.suggest.fst
Factories for FST and Analyzing based Suggesters
org.apache.solr.spelling.suggest.jaspell - package org.apache.solr.spelling.suggest.jaspell
Factories for JaSpell based Suggesters
org.apache.solr.spelling.suggest.tst - package org.apache.solr.spelling.suggest.tst
Factories for TST based Suggesters
org.apache.solr.uninverting - package org.apache.solr.uninverting
Support for creating docvalues on-the-fly from the inverted index at runtime.
org.apache.solr.update - package org.apache.solr.update
APIs and classes for managing index updates
org.apache.solr.update.processor - package org.apache.solr.update.processor
UpdateRequestProcessorFactory APIs and implementations for use in UpdateRequestProcessorChains
org.apache.solr.util - package org.apache.solr.util
Common utility classes used throughout Solr
org.apache.solr.util.circuitbreaker - package org.apache.solr.util.circuitbreaker
Support for triggering exceptions on excessive resource usage
org.apache.solr.util.configuration - package org.apache.solr.util.configuration
Common Util APIs related to Solr configuration.
org.apache.solr.util.configuration.providers - package org.apache.solr.util.configuration.providers
TODO
org.apache.solr.util.hll - package org.apache.solr.util.hll
A fork of Java-HyperLogLog package tweaked not to depend on fastutil and with cleanups to make it lean and clean.
org.apache.solr.util.plugin - package org.apache.solr.util.plugin
Common APIs related to implementing Solr plugins
org.apache.solr.util.stats - package org.apache.solr.util.stats
Utilities for collecting statistics
org.apache.solr.util.tracing - package org.apache.solr.util.tracing
Tracing related utilities
org.apache.solr.util.vector - package org.apache.solr.util.vector
Utilities for dense vector search
origCorename - Variable in class org.apache.solr.servlet.HttpSolrCall
 
original - Variable in class org.apache.solr.core.PluginInfo.ClassName
 
ORIGINAL - org.apache.solr.handler.component.HighlightComponent.HighlightMethod
 
ORIGINAL_USER_PRINCIPAL_HEADER - Static variable in class org.apache.solr.servlet.HttpSolrCall
 
originalCoreProperties - Variable in class org.apache.solr.core.CoreDescriptor
The original standard core properties, before substitution
originalExtraProperties - Variable in class org.apache.solr.core.CoreDescriptor
The original extra core properties, before substitution
originalFileName - Variable in class org.apache.solr.core.backup.ShardBackupMetadata.BackedFile
 
originalTerms - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
origParams - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
origVsFreq - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
origVsShards - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
origVsSuggested - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
origVsSuggestion - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
os - Variable in class org.apache.solr.update.TransactionLog
 
OS_MXBEAN_CLASSES - Static variable in class org.apache.solr.util.stats.MetricUtils
These are well-known implementations of OperatingSystemMXBean.
other - Variable in class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
 
OTHER - org.apache.solr.core.SolrInfoBean.Category
 
OTHER - org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
Unclassified exception cause.
OTHER - org.apache.solr.servlet.cache.Method
 
otherParams - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
otherParamsString - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
others - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
out - Variable in class org.apache.solr.internal.csv.CSVPrinter
The place that the values get written.
out - Variable in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
out(String) - Static method in interface org.apache.solr.cli.CLIO
 
outgoing - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
output - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.ZooKeeperFileResponse
 
OUTPUT_STREAM_OPENER - Static variable in class org.apache.solr.update.TransactionLog
 
overlaps(TagLL) - Method in class org.apache.solr.handler.tagger.TagLL
 
OVERLAPS - Static variable in class org.apache.solr.handler.tagger.TaggerRequestHandler
Request parameter.
overrequestCount - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
overrequestRatio - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
overseer - org.apache.solr.core.SolrInfoBean.Group
 
overseer - Variable in class org.apache.solr.cloud.ZkController
 
Overseer - Class in org.apache.solr.cloud
Cluster leader.
Overseer(HttpShardHandler, UpdateShardHandler, String, ZkStateReader, ZkController, CloudConfig) - Constructor for class org.apache.solr.cloud.Overseer
 
OVERSEER - org.apache.solr.core.NodeRoles.Role
 
OVERSEER_ELECT - Static variable in class org.apache.solr.cloud.Overseer
 
OVERSEER_OP_CMD - Static variable in class org.apache.solr.handler.admin.api.OverseerOperationAPI
 
Overseer.Message - Interface in org.apache.solr.cloud
 
Overseer.OverseerThread - Class in org.apache.solr.cloud
 
OverseerAction - Enum in org.apache.solr.cloud.overseer
Enum of actions supported by the overseer only.
OverseerCollectionConfigSetProcessor - Class in org.apache.solr.cloud
An OverseerTaskProcessor that handles: 1) collection-related Overseer messages 2) configset-related Overseer messages
OverseerCollectionConfigSetProcessor(ZkStateReader, String, HttpShardHandlerFactory, String, Stats, Overseer, OverseerNodePrioritizer, OverseerTaskQueue, DistributedMap, DistributedMap, DistributedMap, SolrMetricsContext) - Constructor for class org.apache.solr.cloud.OverseerCollectionConfigSetProcessor
 
OverseerCollectionConfigSetProcessor(ZkStateReader, String, HttpShardHandler, String, Stats, Overseer, OverseerNodePrioritizer, SolrMetricsContext) - Constructor for class org.apache.solr.cloud.OverseerCollectionConfigSetProcessor
 
OverseerCollectionMessageHandler - Class in org.apache.solr.cloud.api.collections
A OverseerMessageHandler that handles Collections API related overseer messages.
OverseerCollectionMessageHandler(ZkStateReader, String, HttpShardHandlerFactory, String, Stats, Overseer, OverseerNodePrioritizer) - Constructor for class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
 
OverseerConfigSetMessageHandler - Class in org.apache.solr.cloud
A OverseerMessageHandler that handles ConfigSets API related overseer messages.
OverseerConfigSetMessageHandler(ZkStateReader, CoreContainer) - Constructor for class org.apache.solr.cloud.OverseerConfigSetMessageHandler
 
OverseerMessageHandler - Interface in org.apache.solr.cloud
Interface for processing messages received by an OverseerTaskProcessor
OverseerMessageHandler.Lock - Interface in org.apache.solr.cloud
 
OverseerNodePrioritizer - Class in org.apache.solr.cloud
Responsible for prioritization of Overseer nodes, for example with the ADDROLE collection command.
OverseerNodePrioritizer(ZkStateReader, Overseer, String, ShardHandlerFactory) - Constructor for class org.apache.solr.cloud.OverseerNodePrioritizer
 
OVERSEEROP_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
OverseerOperationAPI - Class in org.apache.solr.handler.admin.api
V2 API for triggering a node to rejoin leader election for the 'overseer' role.
OverseerOperationAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.OverseerOperationAPI
 
OverseerRoleCmd - Class in org.apache.solr.cloud.api.collections
 
OverseerRoleCmd(CollectionCommandContext, CollectionParams.CollectionAction, OverseerNodePrioritizer) - Constructor for class org.apache.solr.cloud.api.collections.OverseerRoleCmd
 
OverseerSolrResponse - Class in org.apache.solr.cloud
 
OverseerSolrResponse(NamedList<Object>) - Constructor for class org.apache.solr.cloud.OverseerSolrResponse
 
OverseerSolrResponseSerializer - Class in org.apache.solr.cloud
 
OverseerSolrResponseSerializer() - Constructor for class org.apache.solr.cloud.OverseerSolrResponseSerializer
 
OVERSEERSTATUS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
OverseerStatusCmd - Class in org.apache.solr.cloud.api.collections
This command returns stats about the Overseer, the cluster state updater and collection API activity occurring within the current Overseer node (this is important because distributed operations occurring on other nodes are not included in these stats, for example distributed cluster state updates or Per Replica States updates).
OverseerStatusCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.OverseerStatusCmd
 
OverseerTaskProcessor - Class in org.apache.solr.cloud
A generic processor run in the Overseer, used for handling items added to a distributed work queue.
OverseerTaskProcessor(ZkStateReader, String, Stats, OverseerTaskProcessor.OverseerMessageHandlerSelector, OverseerNodePrioritizer, OverseerTaskQueue, DistributedMap, DistributedMap, DistributedMap, SolrMetricsContext) - Constructor for class org.apache.solr.cloud.OverseerTaskProcessor
 
OverseerTaskProcessor.OverseerMessageHandlerSelector - Interface in org.apache.solr.cloud
An interface to determine which OverseerMessageHandler handles a given message.
OverseerTaskProcessor.Runner - Class in org.apache.solr.cloud
 
OverseerTaskQueue - Class in org.apache.solr.cloud
A ZkDistributedQueue augmented with helper methods specific to the overseer task queues.
OverseerTaskQueue(SolrZkClient, String) - Constructor for class org.apache.solr.cloud.OverseerTaskQueue
 
OverseerTaskQueue(SolrZkClient, String, Stats) - Constructor for class org.apache.solr.cloud.OverseerTaskQueue
 
OverseerTaskQueue.QueueEvent - Class in org.apache.solr.cloud
 
OverseerThread(ThreadGroup, T, String) - Constructor for class org.apache.solr.cloud.Overseer.OverseerThread
 
overwrite - Variable in class org.apache.solr.update.AddUpdateCommand
 
OVERWRITE - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
OVERWRITE - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 

P

PACKAGE_EDIT_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
PACKAGE_PATH - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
PACKAGE_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
PACKAGE_VERSIONS - Static variable in class org.apache.solr.pkg.PackageListeners
 
PackageAPI - Class in org.apache.solr.pkg
This implements the public end points (/api/cluster/package) of package API.
PackageAPI(CoreContainer, SolrPackageLoader) - Constructor for class org.apache.solr.pkg.PackageAPI
 
PackageAPI.Edit - Class in org.apache.solr.pkg
 
PackageAPI.Packages - Class in org.apache.solr.pkg
 
PackageAPI.PkgVersion - Class in org.apache.solr.pkg
 
PackageAPI.Read - Class in org.apache.solr.pkg
 
packageDetails() - Method in interface org.apache.solr.pkg.PackageListeners.Listener
fetch the package versions of class names
packageDetails() - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
PackageListeners - Class in org.apache.solr.pkg
 
PackageListeners(SolrCore) - Constructor for class org.apache.solr.pkg.PackageListeners
 
PackageListeners.Listener - Interface in org.apache.solr.pkg
 
PackageListeners.Listener.Ctx - Class in org.apache.solr.pkg
 
PackageListeningClassLoader - Class in org.apache.solr.pkg
A SolrClassLoader that is designed to listen to a set of packages.
PackageListeningClassLoader(CoreContainer, SolrClassLoader, Function<String, String>, Runnable) - Constructor for class org.apache.solr.pkg.PackageListeningClassLoader
 
packageManager - Variable in class org.apache.solr.cli.PackageTool
 
PackageManager - Class in org.apache.solr.packagemanager
Handles most of the management of packages that are already installed in Solr.
PackageManager(SolrClient, String, String) - Constructor for class org.apache.solr.packagemanager.PackageManager
 
packageName() - Method in interface org.apache.solr.pkg.PackageListeners.Listener
Name of the package or null to listen to all package changes
packageName() - Method in class org.apache.solr.pkg.PackageListeningClassLoader
 
PackagePluginHolder<T> - Class in org.apache.solr.pkg
 
PackagePluginHolder(PluginInfo, SolrCore, SolrConfig.SolrPluginInfo) - Constructor for class org.apache.solr.pkg.PackagePluginHolder
 
PackageRepository - Class in org.apache.solr.packagemanager
Abstract class for a repository, holding SolrPackage items.
PackageRepository() - Constructor for class org.apache.solr.packagemanager.PackageRepository
 
packages - Variable in class org.apache.solr.pkg.PackageAPI.Packages
 
Packages() - Constructor for class org.apache.solr.pkg.PackageAPI.Packages
 
PackageTool - Class in org.apache.solr.cli
 
PackageTool() - Constructor for class org.apache.solr.cli.PackageTool
 
PackageUtils - Class in org.apache.solr.packagemanager
 
PackageUtils() - Constructor for class org.apache.solr.packagemanager.PackageUtils
 
PACKET_SZ - Static variable in class org.apache.solr.handler.ReplicationHandler
 
paddingBytes(HLLType) - Method in interface org.apache.solr.util.hll.ISchemaVersion
The number of metadata bytes required for a serialized HLL of the specified type.
PageFetcherResult() - Constructor for class org.apache.solr.cli.SimplePostTool.PageFetcherResult
Deprecated.
 
PARAM_BREAK_SUGGESTION_TIE_BREAKER - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
PARAM_BREAK_WORDS - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
Try to break words into multiples? [true|false]
PARAM_COMBINE_WORDS - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
Try to combine multiple words into one? [true|false]
PARAM_CURRENCY_CONFIG - Static variable in class org.apache.solr.schema.FileExchangeRateProvider
 
PARAM_DEFAULT_CURRENCY - Static variable in class org.apache.solr.schema.CurrencyFieldType
 
PARAM_ENUM_NAME - Static variable in class org.apache.solr.schema.AbstractEnumField.EnumMapping
 
PARAM_ENUMS_CONFIG - Static variable in class org.apache.solr.schema.AbstractEnumField.EnumMapping
 
PARAM_FIELD_SUFFIX_AMOUNT_RAW - Static variable in class org.apache.solr.schema.CurrencyFieldType
 
PARAM_FIELD_SUFFIX_CURRENCY - Static variable in class org.apache.solr.schema.CurrencyFieldType
 
PARAM_MAX_CHANGES - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
See WordBreakSpellChecker.setMaxChanges(int)
PARAM_MAX_COMBINE_WORD_LENGTH - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
See WordBreakSpellChecker.setMaxCombineWordLength(int)
PARAM_MAX_EVALUATIONS - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
See WordBreakSpellChecker.setMaxEvaluations(int)
PARAM_MIN_BREAK_WORD_LENGTH - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
See WordBreakSpellChecker.setMinBreakWordLength(int)
PARAM_MIN_SUGGESTION_FREQUENCY - Static variable in class org.apache.solr.spelling.WordBreakSolrSpellChecker
See WordBreakSpellChecker.setMinSuggestionFrequency(int)
PARAM_PRECISION_STEP - Static variable in class org.apache.solr.schema.CurrencyField
Deprecated.
 
PARAM_RATE_PROVIDER_CLASS - Static variable in class org.apache.solr.schema.CurrencyFieldType
 
PARAM_RATES_FILE_LOCATION - Static variable in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
PARAM_REFRESH_INTERVAL - Static variable in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
parameterDefaults - Variable in class org.apache.solr.packagemanager.SolrPackage.Manifest
 
parameterDefaults - Variable in class org.apache.solr.packagemanager.SolrPackageInstance
 
params - Variable in class org.apache.solr.handler.component.PivotFacetProcessor
 
params - Variable in class org.apache.solr.handler.component.ShardRequest
 
params - Variable in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
params - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
params - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
params - Variable in class org.apache.solr.schema.SimilarityFactory
 
params - Variable in class org.apache.solr.search.QParser
 
params - Variable in class org.apache.solr.spelling.suggest.DictionaryFactory
 
params(String...) - Static method in class org.apache.solr.cloud.SyncStrategy
 
params(String...) - Static method in class org.apache.solr.handler.admin.CollectionsHandler
 
params(String...) - Static method in class org.apache.solr.handler.admin.CoreAdminHandler
 
paramToProp - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler
 
parentChangeIds - Variable in class org.apache.solr.handler.tagger.OffsetCorrector
tag id; parallel array to parentChangeOffsets
parentChangeOffsets - Variable in class org.apache.solr.handler.tagger.OffsetCorrector
offsets of parent tag id change (ascending order)
parentKey - Variable in class org.apache.solr.search.facet.LegacyFacet.Subfacet
 
parentLoader - Variable in class org.apache.solr.core.ConfigSetService
 
parents - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
 
parentValue - Variable in class org.apache.solr.handler.component.PivotFacetField
 
parse() - Method in class org.apache.solr.search.DisMaxQParser
 
parse() - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQParser
 
parse() - Method in class org.apache.solr.search.ExtendedDismaxQParser
 
parse() - Method in class org.apache.solr.search.FunctionQParser
 
parse() - Method in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
parse() - Method in class org.apache.solr.search.join.FiltersQParser
 
parse() - Method in class org.apache.solr.search.join.GraphQueryParser
 
parse() - Method in class org.apache.solr.search.join.HashRangeQParser
 
parse() - Method in class org.apache.solr.search.LuceneQParser
 
parse() - Method in class org.apache.solr.search.MaxScoreQParser
Parses the query exactly like the Lucene parser does, but delegates all SHOULD clauses to DisjunctionMaxQuery with meaning only the clause with the max score will contribute to the overall score, unless the tie parameter is specified.
parse() - Method in class org.apache.solr.search.MinHashQParser
 
parse() - Method in class org.apache.solr.search.mlt.CloudMLTQParser
 
parse() - Method in class org.apache.solr.search.mlt.SimpleMLTQParser
 
parse() - Method in class org.apache.solr.search.neural.KnnQParser
 
parse() - Method in class org.apache.solr.search.QParser
Create and return the Query object represented by qstr.
parse() - Method in class org.apache.solr.search.RankQParserPlugin.RankQParser
 
parse() - Method in class org.apache.solr.search.SpatialFilterQParser
 
parse(Reader, AttributeSource) - Method in class org.apache.solr.schema.JsonPreAnalyzedParser
 
parse(Reader, AttributeSource) - Method in interface org.apache.solr.schema.PreAnalyzedField.PreAnalyzedParser
Parse input.
parse(Reader, AttributeSource) - Method in class org.apache.solr.schema.SimplePreAnalyzedParser
 
parse(String) - Static method in enum org.apache.solr.core.SolrConfig.HttpCachingConfig.LastModFrom
Input must not be null
parse(String) - Static method in class org.apache.solr.handler.admin.SolrEnvironment
Parse an environment string of format <prod|stage|test|dev> with an optional label and color as arguments
parse(String) - Static method in enum org.apache.solr.handler.component.HighlightComponent.HighlightMethod
 
parse(String) - Static method in class org.apache.solr.internal.csv.CSVUtils
Parses the given String according to the default CSVStrategy.
parse(String) - Method in class org.apache.solr.parser.SolrQueryParserBase
Parses a query string, returning a Query.
parse(String, String) - Static method in class org.apache.solr.schema.CurrencyValue
Constructs a new currency value by parsing the specific input.
parse(NamedList<NamedList<Object>>) - Method in class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
parse(SolrCore, String, HttpServletRequest) - Method in class org.apache.solr.servlet.SolrRequestParsers
 
parse(SolrQueryRequest, Map<String, Object>) - Static method in class org.apache.solr.search.facet.FacetRequest
Factory method to parse a facet request tree.
parse(FunctionQParser) - Method in class org.apache.solr.search.facet.PercentileAgg.Parser
 
parse(FunctionQParser) - Method in class org.apache.solr.search.function.distance.GeoDistValueSourceParser
 
parse(FunctionQParser) - Method in class org.apache.solr.search.join.ChildFieldValueSourceParser
 
parse(FunctionQParser) - Method in class org.apache.solr.search.ValueSourceParser
Parse the user input into a ValueSource.
parseAgg(int) - Method in class org.apache.solr.search.FunctionQParser
 
parseAndValidateRequest(SolrQueryRequest) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
Parses the params included in this request, throwing appropriate user level Exceptions for invalid input, and returning a PhrasesContextData suitable for use in this request.
parseArg() - Method in class org.apache.solr.search.FunctionQParser
 
parseArgsAndInit(String[]) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Parses incoming arguments and system params and initializes the tool
parseBiSepChar(String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
parse custom separator char for CustomSeparatorBreakIterator
ParseBooleanFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Attempts to mutate selected fields that have only CharSequence-typed values into Boolean values.
ParseBooleanFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ParseBooleanFieldUpdateProcessorFactory
 
parseBreakIterator(String, Locale) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
parse a break iterator type for the specified locale
parseClassName(String) - Static method in class org.apache.solr.core.PluginInfo
class names can be prefixed with package name e.g: my_package:my.pkg.Class This checks if it is a package name prefixed classname.
parseCmdLine(String, String[], List<Option>) - Static method in class org.apache.solr.cli.SolrCLI
 
parseCommaSeparatedList(String, int) - Static method in class org.apache.solr.schema.PointType
Given a string containing dimension values encoded in it, separated by commas, return a String array of length dimension containing the values.
parseConfig() - Method in class org.apache.solr.cloud.SolrZkServer
 
parseConfigXML(Logger, ResourceLoader, String) - Static method in class org.apache.solr.util.SafeXMLParsing
Parses a config file from a Solr config based on ResourceLoader.
parseConfigXML(Logger, ResourceLoader, InputSource) - Static method in class org.apache.solr.util.SafeXMLParsing
Parses a config file from a Solr config based on InputSource.
parseConstVector(int) - Method in class org.apache.solr.search.FunctionQParser
 
parsed - Variable in class org.apache.solr.handler.designer.SampleDocuments
 
ParseDateFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Attempts to mutate selected fields that have only CharSequence-typed values into Date values.
ParseDateFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ParseDateFieldUpdateProcessorFactory
 
parseDistanceUnits(String) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
if str is non-null, returns DistanceUnits.valueOf(String) (which will return null if not found), else returns AbstractSpatialFieldType.distanceUnits (only null before initialized in init().
parseDocsFromStream(SolrParams, ContentStream, int) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
parseDocsFromStream(SolrParams, ContentStream, int) - Method in interface org.apache.solr.handler.designer.SampleDocumentsLoader
 
parseDouble() - Method in class org.apache.solr.search.FunctionQParser
Parse a Double
ParseDoubleFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Attempts to mutate selected fields that have only CharSequence-typed values into Double values.
ParseDoubleFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ParseDoubleFieldUpdateProcessorFactory
 
ParsedParams(SolrParams, SolrParams, SolrParams, String, DocSet, String, List<String>, int) - Constructor for class org.apache.solr.request.SimpleFacets.ParsedParams
 
parsedUserQuery - Variable in class org.apache.solr.search.DisMaxQParser
 
parseEscapedQuery(ExtendedDismaxQParser.ExtendedSolrQueryParser, String, ExtendedDismaxQParser.ExtendedDismaxConfiguration) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Parses an escaped version of the user's query.
ParseException - Exception in org.apache.solr.parser
This exception is thrown when parse errors are encountered.
ParseException() - Constructor for exception org.apache.solr.parser.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.apache.solr.parser.ParseException
Constructor with message.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.solr.parser.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
parseFieldBoosts(String) - Static method in class org.apache.solr.util.SolrPluginUtils
Given a string containing fieldNames and boost info, converts it to a Map from field name to boost info.
parseFieldBoosts(String[]) - Static method in class org.apache.solr.util.SolrPluginUtils
Like parseFieldBoosts(String), but parses all the strings in the provided array (which may be null).
parseFieldBoostsAndSlop(String[], int, int) - Static method in class org.apache.solr.util.SolrPluginUtils
/** Like SolrPluginUtils.parseFieldBoosts(java.lang.String), but allows for an optional slop value prefixed by "~".
parseFilterQueries(SolrQueryRequest) - Static method in class org.apache.solr.search.QueryUtils
Parse the filter queries in Solr request
parseFloat() - Method in class org.apache.solr.search.FunctionQParser
Parse a float.
ParseFloatFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Attempts to mutate selected fields that have only CharSequence-typed values into Float values.
ParseFloatFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ParseFloatFieldUpdateProcessorFactory
 
parseGeomSolrException(String, SpatialContext) - Static method in class org.apache.solr.util.SpatialUtils
Parses a 'geom' parameter (might also be used to parse shapes for indexing).
parseHllOptions(SolrParams, SchemaField) - Static method in class org.apache.solr.handler.component.StatsField.HllOptions
Creates an HllOptions based on the (local) params specified (if appropriate).
parseId() - Method in class org.apache.solr.search.FunctionQParser
 
parseImpl() - Method in class org.apache.solr.search.join.FiltersQParser
 
parseIndexVector() - Method in class org.apache.solr.util.vector.DenseVectorParser
 
parseInstantFromCollectionName(String, String) - Static method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
parseInt() - Method in class org.apache.solr.search.FunctionQParser
Parse an integer
ParseIntFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Attempts to mutate selected fields that have only CharSequence-typed values into Integer values.
ParseIntFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ParseIntFieldUpdateProcessorFactory
 
parseJsonFromRequestBody(SolrQueryRequest) - Method in class org.apache.solr.rest.RestManager.ManagedEndpoint
 
parseLine(String) - Static method in class org.apache.solr.internal.csv.CSVUtils
Parses the first line only according to the default CSVStrategy.
parseLocale(String, String, String) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
parse a locale from a language+country+variant spec
parseLocalParams(String, int, ModifiableSolrParams, SolrParams) - Static method in class org.apache.solr.search.QueryParsing
 
parseLocalParams(String, int, ModifiableSolrParams, SolrParams, String, char) - Static method in class org.apache.solr.search.QueryParsing
 
ParseLongFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Attempts to mutate selected fields that have only CharSequence-typed values into Long values.
ParseLongFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ParseLongFieldUpdateProcessorFactory
 
parseLuceneVersionString(String) - Static method in class org.apache.solr.core.SolrConfig
 
parseMath(String) - Method in class org.apache.solr.util.DateMathParser
Parses a string of commands relative "now" are returns the resulting Date.
parseMath(Date, String) - Method in class org.apache.solr.schema.DateRangeField
For easy compatibility with DateMathParser.parseMath(Date, String).
parseMath(Date, String) - Static method in class org.apache.solr.util.DateMathParser
Parses a String which may be a date (in the standard ISO-8601 format) followed by an optional math expression.
parseMath(Date, String, TimeZone) - Static method in class org.apache.solr.util.DateMathParser
Parses a String which may be a date (in the standard ISO-8601 format) followed by an optional math expression.
parseMinShouldMatch(IndexSchema, SolrParams) - Static method in class org.apache.solr.search.DisMaxQParser
Applies the appropriate default rules for the "mm" param based on the effective value of the "q.op" param
parseNestedQuery() - Method in class org.apache.solr.search.FunctionQParser
 
ParseNumericFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Abstract base class for numeric parsing update processor factories.
ParseNumericFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.ParseNumericFieldUpdateProcessorFactory
 
parseOneFacetReq(SolrQueryRequest, Map<String, Object>) - Static method in class org.apache.solr.search.facet.FacetRequest
Factory method to parse out a rooted facet request tree that would normally go one level below a label.
parseOP(String) - Static method in class org.apache.solr.search.QueryParsing
Parses default operator string into Operator object
parseOriginalQuery(ExtendedDismaxQParser.ExtendedSolrQueryParser, String, List<ExtendedDismaxQParser.Clause>, ExtendedDismaxQParser.ExtendedDismaxConfiguration) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Parses the user's original query.
parseParam(String) - Static method in enum org.apache.solr.update.processor.DistributedUpdateProcessor.DistribPhase
 
parseParams(String, String) - Method in class org.apache.solr.request.SimpleFacets
 
parseParams(String, String) - Method in class org.apache.solr.search.facet.LegacyFacet
 
parseParentFilter() - Method in class org.apache.solr.search.join.BlockJoinParentQParser
 
parsePoint(String, SpatialContext) - Static method in class org.apache.solr.util.SpatialUtils
Parses either "lat, lon" (spaces optional on either comma side) or "x y" style formats.
parsePointSolrException(String, SpatialContext) - Static method in class org.apache.solr.util.SpatialUtils
Calls SpatialUtils.parsePoint(String, org.locationtech.spatial4j.context.SpatialContext) and wraps the exception with SolrException with a helpful message.
parsePossibleBoolean(Object, boolean, Set<String>, Set<String>) - Static method in class org.apache.solr.update.processor.ParseBooleanFieldUpdateProcessorFactory
 
parsePossibleDate(Object, Collection<DateTimeFormatter>, ParsePosition) - Static method in class org.apache.solr.update.processor.ParseDateFieldUpdateProcessorFactory
 
parsePossibleDouble(Object, NumberFormat) - Static method in class org.apache.solr.update.processor.ParseDoubleFieldUpdateProcessorFactory
 
parsePossibleLong(Object, NumberFormat) - Static method in class org.apache.solr.update.processor.ParseLongFieldUpdateProcessorFactory
 
parseQueryFields(IndexSchema, SolrParams) - Static method in class org.apache.solr.search.DisMaxQParser
Uses SolrPluginUtils.parseFieldBoosts(String) with the 'qf' parameter.
parseQueryString(String) - Static method in class org.apache.solr.servlet.SolrRequestParsers
Given a url-encoded query string (UTF-8), map it into solr params
parseQueryStrings(SolrQueryRequest, String[]) - Static method in class org.apache.solr.util.SolrPluginUtils
Turns an array of query strings into a List of Query objects.
parseQueryVector() - Method in class org.apache.solr.util.vector.DenseVectorParser
 
parser - Variable in class org.apache.solr.parser.SolrQueryParserBase
 
parser - Variable in class org.apache.solr.servlet.DirectSolrConnection
 
Parser() - Constructor for class org.apache.solr.search.facet.PercentileAgg.Parser
 
PARSER - Static variable in class org.apache.solr.util.DateMathParser
Differs by DateTimeFormatter.ISO_INSTANT in that it's lenient.
PARSER_IMPL - Static variable in class org.apache.solr.schema.PreAnalyzedField
Init argument name.
parseRectangeSolrException(String, SpatialContext) - Static method in class org.apache.solr.util.SpatialUtils
Calls SpatialUtils.parseRectangle(String, org.locationtech.spatial4j.context.SpatialContext) and wraps the exception with SolrException with a helpful message.
parseRectangle(String, SpatialContext) - Static method in class org.apache.solr.util.SpatialUtils
Parses str in the format of '[minPoint TO maxPoint]' where minPoint is the lower left corner and maxPoint is the upper-right corner of the bounding box.
parseRegistries(String[], String[]) - Method in class org.apache.solr.handler.admin.MetricsHandler
 
parseRequest() - Method in class org.apache.solr.api.V2HttpCall
 
ParseResult() - Constructor for class org.apache.solr.schema.PreAnalyzedField.ParseResult
 
parseSelectorExclusionParams(NamedList<?>) - Static method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
 
parseSelectorParams(NamedList<?>) - Static method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
 
parseSerializedTotem(String) - Method in class org.apache.solr.search.CursorMark
Parses the serialized version of a CursorMark from a client (which must conform to the existing sortSpec) and populates this object.
parseShape(String) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
Create a Shape from the input string
parseShape(String) - Method in class org.apache.solr.schema.DateRangeField
 
parseSortSpec(String, SolrQueryRequest) - Static method in class org.apache.solr.search.SortSpecParsing
The form of the sort specification string currently parsed is:
parseSortSpec(String, IndexSchema) - Static method in class org.apache.solr.search.SortSpecParsing
The form of the (function free) sort specification string currently parsed is:
parseSpatialArgs(QParser, String) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
parseSpatialArgs(QParser, String) - Method in class org.apache.solr.schema.DateRangeField
 
parseStringAsInstant(String, TimeZone) - Static method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
parseSubFacets(SolrParams) - Static method in class org.apache.solr.search.facet.LegacyFacet
 
parseText(Reader, String) - Method in class org.apache.solr.rest.ManagedResourceStorage.JsonStorage
 
parseText(Reader, String) - Method in class org.apache.solr.rest.ManagedResourceStorage
Called by ManagedResourceStorage.load(String) to convert the serialized resource into its in-memory representation.
parseTimezone(String) - Static method in class org.apache.solr.util.TimeZoneUtils
Parse the specified timezone ID.
parseUntrustedXML(Logger, InputStream) - Static method in class org.apache.solr.util.SafeXMLParsing
Parses non-Solr configs as XML based on the given InputStream, disabling any external entities with secure processing enabled.
parseUntrustedXML(Logger, Reader) - Static method in class org.apache.solr.util.SafeXMLParsing
Parses the given InputStream as XML, disabling any external entities with secure processing enabled.
parseUntrustedXML(Logger, String) - Static method in class org.apache.solr.util.SafeXMLParsing
 
parseValue(BytesRef) - Method in interface org.apache.solr.uninverting.FieldCache.Parser
Parse's this field's value
parseValueSource() - Method in class org.apache.solr.search.FunctionQParser
Parse an individual ValueSource.
parseValueSource(boolean) - Method in class org.apache.solr.search.FunctionQParser
Parse an individual value source.
parseValueSource(int) - Method in class org.apache.solr.search.FunctionQParser
 
parseValueSourceList() - Method in class org.apache.solr.search.FunctionQParser
Parse a list of ValueSource.
parseValueSourceList(int) - Method in class org.apache.solr.search.FunctionQParser
Parse a list of ValueSource.
parseVector() - Method in class org.apache.solr.util.vector.DenseVectorParser
 
parseVector(VectorEncoding) - Method in class org.apache.solr.search.FunctionQParser
 
parseX509Certs(InputStream) - Static method in class org.apache.solr.util.CryptoKeys
Tries for find X509 certificates in the input stream in DER or PEM format.
parseXmlDocs(XMLStreamReader, int) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
PARTIAL - org.apache.solr.handler.component.RealTimeGetComponent.Resolution
A partial update document.
partialEscape(CharSequence) - Static method in class org.apache.solr.util.SolrPluginUtils
Escapes all special characters except '"', '-', and '+'
PASSTHROUGH - org.apache.solr.servlet.SolrDispatchFilter.Action
 
path - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
path - Variable in class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
path - Variable in class org.apache.solr.packagemanager.SolrPackage.Command
 
path - Variable in class org.apache.solr.servlet.HttpSolrCall
 
path() - Method in annotation type org.apache.solr.api.EndPoint
 
PATH - Static variable in class org.apache.solr.handler.ReplicationHandler
 
PATH - Static variable in class org.apache.solr.security.PublicKeyHandler
 
PathExcluder - Interface in org.apache.solr.servlet
Denotes an object, usually a servlet that denies access to some paths based on the supplied patterns.
pathExists(String) - Method in class org.apache.solr.cloud.ZkController
Returns true if the path exists
paths - Variable in class org.apache.solr.core.InitParams
 
paths - Variable in class org.apache.solr.update.SplitIndexCommand
 
pattern - Variable in class org.apache.solr.schema.IndexSchema.DynamicReplacement
 
PATTERN_PARAM - Static variable in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
pause() - Method in class org.apache.solr.util.RTimer
 
PAUSED - Static variable in class org.apache.solr.util.RTimer
 
pauseUpdatesAndAwaitInflightRequests() - Method in class org.apache.solr.update.SolrCoreState
Pauses all update requests to this core and waits (indefinitely) for all in-flight update requests to finish
payload - Variable in class org.apache.solr.packagemanager.SolrPackage.Command
 
PAYLOAD_FIELD - Static variable in class org.apache.solr.spelling.suggest.DocumentDictionaryFactory
 
PAYLOAD_FIELD - Static variable in class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
Label for defining payloadField to use for terms (optional)
PAYLOAD_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
PayloadCheckQParserPlugin - Class in org.apache.solr.search
 
PayloadCheckQParserPlugin() - Constructor for class org.apache.solr.search.PayloadCheckQParserPlugin
 
payloadFunction - Variable in class org.apache.solr.search.FloatPayloadValueSource
 
PayloadObj<T> - Class in org.apache.solr.api
Holds the deserialized object for each command and also holds request , response objects
PayloadObj(String, Object, T, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.api.PayloadObj
 
PayloadScoreQParserPlugin - Class in org.apache.solr.search
Creates a PayloadScoreQuery wrapping a SpanQuery created from the input value, applying text analysis and constructing SpanTermQuery or SpanNearQuery based on number of terms.
PayloadScoreQParserPlugin() - Constructor for class org.apache.solr.search.PayloadScoreQParserPlugin
 
PayloadUtils - Class in org.apache.solr.util
 
PayloadUtils() - Constructor for class org.apache.solr.util.PayloadUtils
 
peek() - Method in class org.apache.solr.cloud.ZkDistributedQueue
Returns the data at the first element of the queue, or null if the queue is empty.
peek() - Method in class org.apache.solr.search.StrParser
 
peek(boolean) - Method in class org.apache.solr.cloud.ZkDistributedQueue
Returns the data at the first element of the queue, or null if the queue is empty and block is false.
peek(long) - Method in class org.apache.solr.cloud.ZkDistributedQueue
Returns the data at the first element of the queue, or null if the queue is empty after wait ms.
peekChar() - Method in class org.apache.solr.search.StrParser
 
peekElements(int, long, Predicate<String>) - Method in class org.apache.solr.cloud.ZkDistributedQueue
Return the currently-known set of elements, using child names from memory.
peekTopN(int, Predicate<String>, long) - Method in class org.apache.solr.cloud.OverseerTaskQueue
 
PEER_INDEX_COMMIT_DELETED - Static variable in class org.apache.solr.handler.IndexFetcher.IndexFetchResult
 
PEER_SYNC - Static variable in class org.apache.solr.update.UpdateCommand
 
PeerSync - Class in org.apache.solr.update
This class is useful for performing peer to peer synchronization of recently indexed update commands during recovery process.
PeerSync(SolrCore, List<String>, int, boolean) - Constructor for class org.apache.solr.update.PeerSync
 
PeerSync(SolrCore, List<String>, int, boolean, boolean, boolean) - Constructor for class org.apache.solr.update.PeerSync
 
PeerSync.MissedUpdatesFinder - Class in org.apache.solr.update
Helper class for doing comparison ourUpdates and other replicas's updates to find the updates that we missed
PeerSync.MissedUpdatesRequest - Class in org.apache.solr.update
PeerSync.PeerSyncResult - Class in org.apache.solr.update
 
PeerSyncWithLeader - Class in org.apache.solr.update
 
PeerSyncWithLeader(SolrCore, String, int) - Constructor for class org.apache.solr.update.PeerSyncWithLeader
 
PeerSyncWithLeader.MissedUpdatesFinder - Class in org.apache.solr.update
Helper class for doing comparison ourUpdates and other replicas's updates to find the updates that we missed
percentile(List<Long>, float) - Static method in class org.apache.solr.update.PeerSync
 
PercentileAgg - Class in org.apache.solr.search.facet
 
PercentileAgg(ValueSource, List<Double>) - Constructor for class org.apache.solr.search.facet.PercentileAgg
 
PercentileAgg.Parser - Class in org.apache.solr.search.facet
 
percentiles - org.apache.solr.handler.component.StatsField.Stat
 
perform(CommandOperation, SchemaManager) - Method in enum org.apache.solr.schema.SchemaManager.OpType
 
performOperations() - Method in class org.apache.solr.schema.SchemaManager
Take in a JSON command set and execute them.
period - Variable in class org.apache.solr.metrics.SolrMetricReporter
 
permission() - Method in annotation type org.apache.solr.api.EndPoint
 
PermissionName - Annotation Type in org.apache.solr.jersey
Associates the resource method with a particular PermissionNameProvider value.
PermissionNameProvider - Interface in org.apache.solr.security
A requestHandler should implement this interface to provide the well known permission at request time
PermissionNameProvider.Name - Enum in org.apache.solr.security
 
PERMISSIVE_MODE_PARAM - Static variable in class org.apache.solr.update.processor.IgnoreLargeDocumentProcessorFactory
 
persist(CoreContainer, CoreDescriptor...) - Method in class org.apache.solr.core.CorePropertiesLocator
 
persist(CoreContainer, CoreDescriptor...) - Method in interface org.apache.solr.core.CoresLocator
Ensure that the core definitions from the passed in CoreDescriptors will persist across container restarts.
persistConf(SecurityConfHandler.SecurityConfig) - Method in class org.apache.solr.handler.admin.SecurityConfHandler
Persist security.json to the source, optionally with a version
persistConf(SecurityConfHandler.SecurityConfig) - Method in class org.apache.solr.handler.admin.SecurityConfHandlerLocal
 
persistConf(SecurityConfHandler.SecurityConfig) - Method in class org.apache.solr.handler.admin.SecurityConfHandlerZk
 
persistConfigResourceToZooKeeper(ZkSolrResourceLoader, int, String, byte[], boolean) - Static method in class org.apache.solr.cloud.ZkController
Persists a config file to ZooKeeper using optimistic concurrency.
persistConfLocally(SolrResourceLoader, String, byte[]) - Static method in class org.apache.solr.core.SolrResourceLoader
 
persistJsonState - Variable in class org.apache.solr.cloud.overseer.ZkWriteCommand
 
persistManagedSchema(boolean) - Method in class org.apache.solr.schema.ManagedIndexSchema
Persist the schema to local storage or to ZooKeeper
persistPlugins(Function<Map<String, Object>, Map<String, Object>>) - Method in interface org.apache.solr.api.ClusterPluginsSource
Persist the updated set of plugin configs
persistPlugins(Function<Map<String, Object>, Map<String, Object>>) - Method in class org.apache.solr.api.NodeConfigClusterPluginsSource
This method should never be invoked because the Edit Apis are not made available by the plugin
persistPlugins(Function<Map<String, Object>, Map<String, Object>>) - Method in class org.apache.solr.api.ZkClusterPluginsSource
 
PHASE - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
phase1_time - Variable in class org.apache.solr.uninverting.DocTermOrds
Time for phase1 of the uninvert process.
PHPResponseWriter - Class in org.apache.solr.response
 
PHPResponseWriter() - Constructor for class org.apache.solr.response.PHPResponseWriter
 
PHPSerializedResponseWriter - Class in org.apache.solr.response
A description of the PHP serialization format can be found here: http://www.hurring.com/scott/code/perl/serialize/
PHPSerializedResponseWriter() - Constructor for class org.apache.solr.response.PHPSerializedResponseWriter
 
PHRASE_ANALYSIS_FIELD - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PHRASE_FIELDS - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PHRASE_INDEX_MAXLEN - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PHRASE_INPUT - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PHRASE_QUERY_MAXLEN - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PHRASE_SUMMARY_POST - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PHRASE_SUMMARY_PRE - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PhrasesIdentificationComponent - Class in org.apache.solr.handler.component
A component that can be used in isolation, or in conjunction with QueryComponent to identify & score "phrases" found in the input string, based on shingles in indexed fields.
PhrasesIdentificationComponent() - Constructor for class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
PhrasesIdentificationComponent.Phrase - Class in org.apache.solr.handler.component
Model the data known about a single (candidate) Phrase -- which may or may not be indexed
PhrasesIdentificationComponent.PhrasesContextData - Class in org.apache.solr.handler.component
Simple container for all request options and data this component needs to store in the Request Context
PICK_BEST - org.apache.solr.parser.SolrQueryParserBase.SynonymQueryStyle
highest scoring term match chosen (ie dismax) so if "pants" has df 500, and "khakis" a df of 50, khakis matches are scored higher appropriate when more specific synonyms should score higher
pickSubset(Collection<T>) - Method in class org.apache.solr.update.processor.FieldValueSubsetUpdateProcessorFactory
Method subclasses must override to specify which values should be kept.
pickSubset(Collection<T>) - Method in class org.apache.solr.update.processor.FirstFieldValueUpdateProcessorFactory
 
pickSubset(Collection<T>) - Method in class org.apache.solr.update.processor.LastFieldValueUpdateProcessorFactory
 
pickSubset(Collection<T>) - Method in class org.apache.solr.update.processor.MaxFieldValueUpdateProcessorFactory
 
pickSubset(Collection<T>) - Method in class org.apache.solr.update.processor.MinFieldValueUpdateProcessorFactory
 
pickSubset(Collection<T>) - Method in class org.apache.solr.update.processor.UniqFieldsUpdateProcessorFactory
 
PING - org.apache.solr.handler.PingRequestHandler.ACTIONS
 
PingRequestHandler - Class in org.apache.solr.handler
Ping Request Handler for reporting SolrCore health to a Load Balancer.
PingRequestHandler() - Constructor for class org.apache.solr.handler.PingRequestHandler
 
PingRequestHandler.ACTIONS - Enum in org.apache.solr.handler
 
PIVOT - org.apache.solr.util.PivotListEntry
 
PIVOT - Static variable in class org.apache.solr.search.RankQParserPlugin
 
PivotFacet - Class in org.apache.solr.handler.component
Models a single instance of a "pivot" specified by a FacetParams.FACET_PIVOT param, which may contain multiple nested fields.
PivotFacet(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.PivotFacet
 
PivotFacetCountComparator() - Constructor for class org.apache.solr.handler.component.PivotFacetFieldValueCollection.PivotFacetCountComparator
 
PivotFacetField - Class in org.apache.solr.handler.component
Models a single field somewhere in a hierarchy of fields as part of a pivot facet.
PivotFacetFieldValueCollection - Class in org.apache.solr.handler.component
Emcapsulates a collection of PivotFacetValues associated with a PivotFacetField withs pecial tracking of a PivotFacetValue corrisponding to the null value when FacetParams.FACET_MISSING is used.
PivotFacetFieldValueCollection(int, int, int, String) - Constructor for class org.apache.solr.handler.component.PivotFacetFieldValueCollection
 
PivotFacetFieldValueCollection.PivotFacetCountComparator - Class in org.apache.solr.handler.component
Sorts PivotFacetValue instances by their count
PivotFacetFieldValueCollection.PivotFacetValueComparator - Class in org.apache.solr.handler.component
Sorts PivotFacetValue instances by their value
PivotFacetHelper - Class in org.apache.solr.handler.component
 
PivotFacetHelper() - Constructor for class org.apache.solr.handler.component.PivotFacetHelper
 
PivotFacetProcessor - Class in org.apache.solr.handler.component
Processes all Pivot facet logic for a single node -- both non-distrib, and per-shard
PivotFacetProcessor(SolrQueryRequest, DocSet, SolrParams, ResponseBuilder) - Constructor for class org.apache.solr.handler.component.PivotFacetProcessor
 
pivotFacets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
PivotFacetValue - Class in org.apache.solr.handler.component
Models a single (value, count) pair that will exist in the collection of values for a PivotFacetField parent.
PivotFacetValueComparator() - Constructor for class org.apache.solr.handler.component.PivotFacetFieldValueCollection.PivotFacetValueComparator
 
PivotListEntry - Enum in org.apache.solr.util
Enum for modeling the elements of a (nested) pivot entry as expressed in a NamedList
pkg - Variable in class org.apache.solr.api.ContainerPluginsRegistry.ApiInfo
 
pkg - Variable in class org.apache.solr.core.PluginInfo.ClassName
 
pkg - Variable in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
pkgName - Variable in class org.apache.solr.core.PluginInfo
 
PkgVersion() - Constructor for class org.apache.solr.pkg.PackageAPI.PkgVersion
 
PkgVersion(PackagePayload.AddVersion) - Constructor for class org.apache.solr.pkg.PackageAPI.PkgVersion
 
PKIAuthenticationPlugin - Class in org.apache.solr.security
 
PKIAuthenticationPlugin(CoreContainer, String, PublicKeyHandler) - Constructor for class org.apache.solr.security.PKIAuthenticationPlugin
 
PKIAuthenticationPlugin.PKIHeaderData - Class in org.apache.solr.security
 
PKIHeaderData() - Constructor for class org.apache.solr.security.PKIAuthenticationPlugin.PKIHeaderData
 
PlacementContext - Interface in org.apache.solr.cluster.placement
Placement context makes it easier to pass around and access main placement-related components.
PlacementException - Exception in org.apache.solr.cluster.placement
Exception thrown by a PlacementPlugin when it is unable to compute placement for whatever reason (except an InterruptedException that PlacementPlugin.computePlacement(org.apache.solr.cluster.placement.PlacementRequest, org.apache.solr.cluster.placement.PlacementContext) is also allowed to throw).
PlacementException() - Constructor for exception org.apache.solr.cluster.placement.PlacementException
 
PlacementException(String) - Constructor for exception org.apache.solr.cluster.placement.PlacementException
 
PlacementException(String, Throwable) - Constructor for exception org.apache.solr.cluster.placement.PlacementException
 
PlacementException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.solr.cluster.placement.PlacementException
 
PlacementException(Throwable) - Constructor for exception org.apache.solr.cluster.placement.PlacementException
 
PlacementModificationException - Exception in org.apache.solr.cluster.placement
Exception thrown when a placement modification is rejected by the placement plugin.
PlacementModificationException() - Constructor for exception org.apache.solr.cluster.placement.PlacementModificationException
 
PlacementModificationException(String) - Constructor for exception org.apache.solr.cluster.placement.PlacementModificationException
 
PlacementModificationException(String, Throwable) - Constructor for exception org.apache.solr.cluster.placement.PlacementModificationException
 
PlacementModificationException(Throwable) - Constructor for exception org.apache.solr.cluster.placement.PlacementModificationException
 
PlacementPlan - Interface in org.apache.solr.cluster.placement
A fully specified plan or instructions for placement, deletion or move to be applied to the cluster.
PlacementPlanFactory - Interface in org.apache.solr.cluster.placement
Allows plugins to create PlacementPlans telling the Solr layer where to create replicas following the processing of a PlacementRequest.
PlacementPlanFactoryImpl - Class in org.apache.solr.cluster.placement.impl
Simple implementation of PlacementPlanFactory.
PlacementPlanFactoryImpl() - Constructor for class org.apache.solr.cluster.placement.impl.PlacementPlanFactoryImpl
 
PlacementPlugin - Interface in org.apache.solr.cluster.placement
Implemented by external plugins to control replica placement and movement on the search cluster (as well as other things such as cluster elasticity?) when cluster changes are required (initiated elsewhere, most likely following a Collection API call).
PLACEMENTPLUGIN_DEFAULT_SYSPROP - Static variable in class org.apache.solr.cloud.api.collections.Assign
 
PlacementPluginAssignStrategy - Class in org.apache.solr.cluster.placement.impl
This assign strategy delegates placement computation to "plugin" code.
PlacementPluginAssignStrategy(PlacementPlugin) - Constructor for class org.apache.solr.cluster.placement.impl.PlacementPluginAssignStrategy
 
PlacementPluginConfig - Interface in org.apache.solr.cluster.placement
Configuration beans should use this interface to define public (mutable) configuration properties.
PlacementPluginFactory<T extends PlacementPluginConfig> - Interface in org.apache.solr.cluster.placement
Factory implemented by client code and configured in container plugins (see ContainerPluginsApi.editAPI) allowing the creation of instances of PlacementPlugin to be used for replica placement computation.
PlacementPluginFactory.NoConfig - Class in org.apache.solr.cluster.placement
Useful type for plugins that don't use any configuration.
PlacementPluginFactoryLoader - Class in org.apache.solr.cluster.placement.impl
Utility class to work with PlacementPluginFactory plugins.
PlacementPluginFactoryLoader() - Constructor for class org.apache.solr.cluster.placement.impl.PlacementPluginFactoryLoader
 
PlacementRequest - Interface in org.apache.solr.cluster.placement
A cluster related placement request that Solr asks a PlacementPlugin plugin to resolve and compute a PlacementPlan placing one or more Replica's of one or more Shard's of an existing SolrCollection.
PlacementRequestImpl - Class in org.apache.solr.cluster.placement.impl
 
PlacementRequestImpl(SolrCollection, Set<String>, Set<Node>, int, int, int) - Constructor for class org.apache.solr.cluster.placement.impl.PlacementRequestImpl
 
plugin - Variable in class org.apache.solr.security.SecurityPluginHolder
 
Plugin() - Constructor for class org.apache.solr.packagemanager.SolrPackage.Plugin
 
PLUGIN - Static variable in class org.apache.solr.handler.admin.ContainerPluginsApi
 
PLUGIN_NAME - Static variable in interface org.apache.solr.cluster.events.ClusterEventProducer
Unique name for the registration of a plugin-based implementation.
PLUGIN_NAME - Static variable in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
PLUGIN_NAME - Static variable in interface org.apache.solr.cluster.placement.PlacementPluginFactory
The key in the plugins registry under which this plugin and its configuration are defined.
PluginBag<T> - Class in org.apache.solr.core
This manages the lifecycle of a set of plugin of the same type .
PluginBag(Class<T>, SolrCore) - Constructor for class org.apache.solr.core.PluginBag
Constructs a non-threadsafe plugin registry
PluginBag(Class<T>, SolrCore, boolean) - Constructor for class org.apache.solr.core.PluginBag
Pass needThreadSafety=true if plugins can be added and removed concurrently with lookups.
PluginBag.JaxrsResourceToHandlerMappings - Class in org.apache.solr.core
Allows JAX-RS 'filters' to find the requestHandler (if any) associated particular JAX-RS resource classes
PluginBag.LazyPluginHolder<T> - Class in org.apache.solr.core
A class that loads plugins Lazily.
PluginBag.PluginHolder<T> - Class in org.apache.solr.core
An indirect reference to a plugin.
PluginHolder(PluginInfo) - Constructor for class org.apache.solr.core.PluginBag.PluginHolder
 
PluginHolder(PluginInfo, T) - Constructor for class org.apache.solr.core.PluginBag.PluginHolder
 
PluginHolder(T, SolrConfig.SolrPluginInfo) - Constructor for class org.apache.solr.core.PluginBag.PluginHolder
 
pluginInfo - Variable in class org.apache.solr.core.PluginBag.PluginHolder
 
pluginInfo - Variable in class org.apache.solr.metrics.SolrMetricReporter
 
pluginInfo - Variable in class org.apache.solr.search.stats.StatsCache
 
PluginInfo - Class in org.apache.solr.core
An Object which represents a Plugin of any type
PluginInfo(String, Map<String, Object>) - Constructor for class org.apache.solr.core.PluginInfo
 
PluginInfo(String, Map<String, String>, NamedList<?>, List<PluginInfo>) - Constructor for class org.apache.solr.core.PluginInfo
 
PluginInfo(ConfigNode, String, boolean, boolean) - Constructor for class org.apache.solr.core.PluginInfo
 
PluginInfo(Node, String, boolean, boolean) - Constructor for class org.apache.solr.core.PluginInfo
 
PluginInfo.ClassName - Class in org.apache.solr.core
 
PluginInfoHandler - Class in org.apache.solr.handler.admin
 
PluginInfoHandler() - Constructor for class org.apache.solr.handler.admin.PluginInfoHandler
 
PluginInfoInitialized - Interface in org.apache.solr.util.plugin
A plugin that can be initialized with a PluginInfo
plugins - Static variable in class org.apache.solr.core.SolrConfig
 
plugins - Variable in class org.apache.solr.packagemanager.SolrPackage.Manifest
 
plugins - Variable in class org.apache.solr.packagemanager.SolrPackageInstance
 
plugins() - Method in interface org.apache.solr.api.ClusterPluginsSource
Get a map of cluster plugin configurations from this source, where keys are plugin names and values are PluginMeta plugin metadata.
plugins() - Method in class org.apache.solr.api.NodeConfigClusterPluginsSource
 
plugins() - Method in class org.apache.solr.api.ZkClusterPluginsSource
Retrieve the current plugin configurations.
PLUS - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
pointDimensionCount() - Method in class org.apache.solr.schema.SchemaField
 
pointer - Variable in class org.apache.solr.update.UpdateLog.Update
 
PointField - Class in org.apache.solr.schema
Provides field types to support for Lucene's IntPoint, LongPoint, FloatPoint and DoublePoint.
PointField() - Constructor for class org.apache.solr.schema.PointField
 
pointIndexDimensionCount() - Method in class org.apache.solr.schema.SchemaField
 
PointMerger - Class in org.apache.solr.search
Merge multiple numeric point fields (segments) together.
PointMerger() - Constructor for class org.apache.solr.search.PointMerger
 
PointMerger.ValueIterator - Class in org.apache.solr.search
 
pointNumBytes() - Method in class org.apache.solr.schema.SchemaField
 
PointParser() - Constructor for class org.apache.solr.uninverting.FieldCache.PointParser
 
POINTS - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
pointStr - Variable in class org.apache.solr.search.SpatialOptions
 
PointType - Class in org.apache.solr.schema
A point type that indexes a point in an n-dimensional space as separate fields and supports range queries.
PointType() - Constructor for class org.apache.solr.schema.PointType
 
poll() - Method in class org.apache.solr.cloud.ZkDistributedQueue
Attempts to remove the head of the queue and return it.
POLL_INTERVAL - Static variable in class org.apache.solr.handler.ReplicationHandler
 
POLY_FIELD_SEPARATOR - Static variable in class org.apache.solr.schema.FieldType
The default poly field separator.
pop() - Method in class org.apache.solr.util.LongPriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.
populateDefaultsIfNecessary(CoreContainer, CreateCollectionRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateCollection
 
populateNextCursorMarkFromMergedShards(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
Inspects the state of the ResponseBuilder and populates the next ResponseBuilder.setNextCursorMark(org.apache.solr.search.CursorMark) as appropriate based on the merged sort values from individual shards
populateScores(List<PhrasesIdentificationComponent.Phrase>, Map<String, Double>, int, int) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Public for testing purposes
populateScores(PhrasesIdentificationComponent.PhrasesContextData) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Uses the previously popuated stats to populate each Phrase with it's scores for the specified fields, and it's over all (weighted) total score.
populateScoresIfNecessary() - Method in class org.apache.solr.search.Grouping.Command
 
populateShardNames(ZkNodeProps, String) - Static method in class org.apache.solr.cloud.api.collections.CreateCollectionCmd
 
populateStats(List<PhrasesIdentificationComponent.Phrase>, Collection<String>, SolrIndexSearcher) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Populates the phrases with stats from the local index for the specified fields
populateStats(List<PhrasesIdentificationComponent.Phrase>, List<NamedList<Object>>) - Static method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
Populates the phrases with (merged) stats from a remote shard
populateTracingSpan(Span) - Method in class org.apache.solr.api.V2HttpCall
 
populateTracingSpan(Span) - Method in class org.apache.solr.servlet.HttpSolrCall
 
pos - Variable in class org.apache.solr.search.StrParser
 
POSINCR_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
position() - Method in class org.apache.solr.update.TransactionLog.FSReverseReader
 
position() - Method in class org.apache.solr.update.TransactionLog
returns the current position in the log file
position() - Method in class org.apache.solr.update.TransactionLog.ReverseReader
 
positionInResponse - Variable in class org.apache.solr.handler.component.ShardDoc
 
positionOfStart - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
 
PossibilityIterator - Class in org.apache.solr.spelling
Given a list of possible Spelling Corrections for multiple mis-spelled words in a query, This iterator returns Possible Correction combinations ordered by reasonable probability that such a combination will return actual hits if re-queried.
PossibilityIterator(Map<Token, LinkedHashMap<String, Integer>>, int, int, boolean) - Constructor for class org.apache.solr.spelling.PossibilityIterator
We assume here that the passed-in inner LinkedHashMaps are already sorted in order of "Best Possible Correction".
PossibilityIterator.RankedSpellPossibility - Class in org.apache.solr.spelling
 
POST - org.apache.solr.servlet.cache.Method
 
postClose() - Method in interface org.apache.solr.core.CachingDirectoryFactory.CloseListener
 
postClose(SolrCore) - Method in interface org.apache.solr.core.CloseHook
Method called when the given SolrCore object has been shut down and update handlers and searchers are closed
Use this method for post-close clean up operations e.g.
postCollect(IndexSearcher) - Method in interface org.apache.solr.search.grouping.Command
Run post-collection steps.
postCollect(IndexSearcher) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand
 
postCollect(IndexSearcher) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand
 
postCommit() - Method in class org.apache.solr.core.AbstractSolrEventListener
 
postCommit() - Method in class org.apache.solr.core.DelegatingEventListener
 
postCommit() - Method in interface org.apache.solr.core.SolrEventListener
 
postCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
 
postData(InputStream, Long, OutputStream, String, URL) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Reads data from the data stream and posts it to solr, writes to the response to output
postDecorateResponse(SolrRequestHandler, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.core.SolrCore
Put status, QTime, and possibly request handler and params, in the response header
postFile(File, OutputStream, String) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Opens the file and posts its contents to the solrUrl, writes to response to output.
postFile(SolrClient, ByteBuffer, String, String) - Static method in class org.apache.solr.packagemanager.PackageUtils
Uploads a file to the package store / file store of Solr.
postFiles(File[], int, OutputStream, String) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Post all filenames provided in args
postFiles(String[], int, OutputStream, String) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Post all filenames provided in args
postFilter - Variable in class org.apache.solr.search.SolrIndexSearcher.ProcessedFilter
 
PostFilter - Interface in org.apache.solr.search
The PostFilter interface provides a mechanism to further filter documents after they have already gone through the main query and other filters.
postingsEnum - Variable in class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
 
postingsEnum - Variable in class org.apache.solr.uninverting.DocTermOrds
Used while uninverting.
postingsFormat - Variable in class org.apache.solr.schema.FieldType
The postings format used for this field type
postJsonToSolr(SolrClient, String, String) - Static method in class org.apache.solr.cli.SolrCLI
 
PostLogsTool - Class in org.apache.solr.cli
A command line tool for indexing Solr logs in the out-of-the-box log format.
PostLogsTool() - Constructor for class org.apache.solr.cli.PostLogsTool
 
PostLogsTool(PrintStream) - Constructor for class org.apache.solr.cli.PostLogsTool
 
PostLogsTool.LogRecordReader - Class in org.apache.solr.cli
 
postProcessCollectionJSON(Map<String, Object>) - Static method in class org.apache.solr.handler.admin.ClusterStatus
 
postProcessor - Variable in class org.apache.solr.update.processor.UpdateRequestProcessorChain.ProcessorInfo
 
postReadInform() - Method in class org.apache.solr.schema.IndexSchema
 
PostRequestDecorationFilter - Class in org.apache.solr.jersey
Applies standard post-processing decorations to a SolrJerseyResponse that are needed on all responses.
PostRequestDecorationFilter() - Constructor for class org.apache.solr.jersey.PostRequestDecorationFilter
 
PostRequestLoggingFilter - Class in org.apache.solr.jersey
 
PostRequestLoggingFilter() - Constructor for class org.apache.solr.jersey.PostRequestLoggingFilter
 
PostRequestMetricsFilter() - Constructor for class org.apache.solr.jersey.RequestMetricHandling.PostRequestMetricsFilter
 
postSoftCommit() - Method in class org.apache.solr.core.AbstractSolrEventListener
 
postSoftCommit() - Method in class org.apache.solr.core.DelegatingEventListener
 
postSoftCommit() - Method in interface org.apache.solr.core.SolrEventListener
 
postSoftCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
 
PostTool - Class in org.apache.solr.cli
 
PostTool() - Constructor for class org.apache.solr.cli.PostTool
 
PostTool(PrintStream) - Constructor for class org.apache.solr.cli.PostTool
 
postWebPages(String[], int, OutputStream) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
This method takes as input a list of start URL strings for crawling, converts the URL strings to URI strings and adds each one to a backlog and then starts crawling
power - Variable in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
PRE_RUN_CHAIN_NAME - Static variable in class org.apache.solr.update.processor.RunUpdateProcessorFactory
 
PreAnalyzedField - Class in org.apache.solr.schema
Pre-analyzed field type provides a way to index a serialized token stream, optionally with an independent stored value of a field.
PreAnalyzedField() - Constructor for class org.apache.solr.schema.PreAnalyzedField
 
PreAnalyzedField.ParseResult - Class in org.apache.solr.schema
This is a simple holder of a stored part and the collected states (tokens with attributes).
PreAnalyzedField.PreAnalyzedParser - Interface in org.apache.solr.schema
Parse the input and return the stored part and the tokens with attributes.
PreAnalyzedUpdateProcessorFactory - Class in org.apache.solr.update.processor
An update processor that parses configured fields of any document being added using PreAnalyzedField with the configured format parser.
PreAnalyzedUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.PreAnalyzedUpdateProcessorFactory
 
PRECISION_STEP_DEFAULT - Static variable in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
PRECISION_STEP_DEFAULT_32 - Static variable in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
The default precision step used by LegacyIntField and LegacyFloatField.
precisionStep - Variable in class org.apache.solr.schema.TrieField
Deprecated.
 
precisionStepArg - Variable in class org.apache.solr.schema.TrieField
Deprecated.
 
preClose() - Method in class org.apache.solr.cloud.ZkController
 
preClose() - Method in interface org.apache.solr.core.CachingDirectoryFactory.CloseListener
 
preClose(SolrCore) - Method in interface org.apache.solr.core.CloseHook
Method called when the given SolrCore object is closing / shutting down but before the update handler and searcher(s) are actually closed
Important: Keep the method implementation as short as possible.
preCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
 
preDecorateResponse(SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.core.SolrCore
 
preemptiveCreateMath - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
PREFERRED_LEADER_PROP - Static variable in class org.apache.solr.cloud.overseer.SliceMutator
 
prefix - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
prefix - Variable in class org.apache.solr.uninverting.DocTermOrds
If non-null, only terms matching this prefix were indexed.
PREFIX - Static variable in class org.apache.solr.cloud.DistributedMap
 
PREFIX_GRID_SCAN_LEVEL - Static variable in class org.apache.solr.schema.SpatialRecursivePrefixTreeFieldType
 
PREFIX_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
prefixCodedToInt(BytesRef) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns an int from prefixCoded bytes.
prefixCodedToLong(BytesRef) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Returns a long from prefixCoded bytes.
PrefixFilter(String...) - Constructor for class org.apache.solr.metrics.SolrMetricManager.PrefixFilter
Create a filter that uses the provided prefixes.
PrefixFilter(Collection<String>) - Constructor for class org.apache.solr.metrics.SolrMetricManager.PrefixFilter
 
PrefixQParserPlugin - Class in org.apache.solr.search
Create a prefix query from the input value.
PrefixQParserPlugin() - Constructor for class org.apache.solr.search.PrefixQParserPlugin
 
PREFIXTERM - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
prepare() - Method in class org.apache.solr.search.Grouping.Command
Prepare this Command for execution.
prepare() - Method in class org.apache.solr.search.Grouping.CommandField
 
prepare() - Method in class org.apache.solr.search.Grouping.CommandFunc
 
prepare() - Method in class org.apache.solr.search.Grouping.CommandQuery
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.ActiveTasksListComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.DebugComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.ExpandComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.FacetComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.HighlightComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryCancellationComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryElevationComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.ResponseLogComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.SearchComponent
Prepare the response.
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.StatsComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.SuggestComponent
Responsible for issuing build and rebuild command to the specified SolrSuggester
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.TermsComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.handler.component.TermVectorComponent
 
prepare(ResponseBuilder) - Method in class org.apache.solr.search.facet.FacetModule
 
prepareCommit - Variable in class org.apache.solr.update.CommitUpdateCommand
 
prepareCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
prepareCoreForRecovery(PayloadObj<PrepareCoreRecoveryPayload>) - Method in class org.apache.solr.handler.admin.api.PrepareCoreRecoveryAPI
 
PrepareCoreRecoveryAPI - Class in org.apache.solr.handler.admin.api
Internal V2 API used to prepare a core for recovery.
PrepareCoreRecoveryAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.PrepareCoreRecoveryAPI
 
prepareGrouping(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
prepDistributed(ResponseBuilder) - Method in class org.apache.solr.handler.component.HttpShardHandler
 
prepDistributed(ResponseBuilder) - Method in class org.apache.solr.handler.component.ShardHandler
 
prepNewSchema(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
PREPRECOVERY_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
prepRecoveryOpPauseForever - Static variable in class org.apache.solr.util.TestInjection
 
preRegister(CoreDescriptor, boolean) - Method in class org.apache.solr.cloud.ZkController
 
PreRequestMetricsFilter() - Constructor for class org.apache.solr.jersey.RequestMetricHandling.PreRequestMetricsFilter
 
present - Variable in class org.apache.solr.handler.export.IntValue
 
PRESERVE_POSITION_INCREMENTS - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
Whether position holes should appear in the automaton.
PRESERVE_SEP - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
If true, then a separator between tokens is preserved.
preSoftCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
 
pretty - Static variable in class org.apache.solr.response.JacksonJsonWriter
 
PREV_POINTER_IDX - Static variable in class org.apache.solr.update.UpdateLog
The index of the previous pointer in an entry from the transaction log.
PREV_VERSION_IDX - Static variable in class org.apache.solr.update.UpdateLog
The index of the previous version in an entry from the transaction log.
prevMap - Variable in class org.apache.solr.update.UpdateLog
 
prevMap2 - Variable in class org.apache.solr.update.UpdateLog
 
prevMapLog - Variable in class org.apache.solr.update.UpdateLog
 
prevMapLog2 - Variable in class org.apache.solr.update.UpdateLog
 
prevTlog - Variable in class org.apache.solr.update.UpdateLog
 
prevTlogOnPrecommit - Variable in class org.apache.solr.update.UpdateLog
 
prevVersion - Variable in class org.apache.solr.update.AddUpdateCommand
This is the version of a document, previously indexed, on which the current update depends on.
PrimitiveFieldType - Class in org.apache.solr.schema
Abstract class defining shared behavior for primitive types Intended to be used as base class for non-analyzed fields like int, float, string, date etc, and set proper defaults for them
PrimitiveFieldType() - Constructor for class org.apache.solr.schema.PrimitiveFieldType
 
PrimUtils - Class in org.apache.solr.util
Utilities for primitive Java data types.
PrimUtils() - Constructor for class org.apache.solr.util.PrimUtils
 
PrimUtils.IntComparator - Class in org.apache.solr.util
 
print(boolean) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(boolean) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
print(char) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(char) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
print(char[]) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(char[], int, int, boolean) - Method in class org.apache.solr.internal.csv.CSVPrinter
 
print(double) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(double) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
print(float) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(float) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
print(int) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(int) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
print(long) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(long) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
print(Object) - Static method in class org.apache.solr.packagemanager.PackageUtils
 
print(Object) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(String) - Method in class org.apache.solr.internal.csv.CSVPrinter
Print the string as the next value on the line.
print(String) - Method in class org.apache.solr.security.PrintWriterWrapper
 
print(String) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
print(String, boolean) - Method in class org.apache.solr.internal.csv.CSVPrinter
Print the string as the next value on the line.
print(String, Object) - Static method in class org.apache.solr.packagemanager.PackageUtils
 
printableUniqueKey(Document) - Method in class org.apache.solr.schema.IndexSchema
The printable value of the Unique Key field for the specified Document
printableUniqueKey(BytesRef) - Method in class org.apache.solr.schema.IndexSchema
Given an indexable uniqueKey value, return the readable/printable version
printableUniqueKey(SolrDocument) - Method in class org.apache.solr.schema.IndexSchema
printableUniqueKey(SolrInputDocument) - Method in class org.apache.solr.schema.IndexSchema
printf(String, Object...) - Method in class org.apache.solr.security.PrintWriterWrapper
 
printf(Locale, String, Object...) - Method in class org.apache.solr.security.PrintWriterWrapper
 
printGreen(Object) - Static method in class org.apache.solr.packagemanager.PackageUtils
Console print using green color
printLine(String[], CSVStrategy) - Static method in class org.apache.solr.internal.csv.CSVUtils
Converts an array of string values into a single CSV line.
println() - Method in class org.apache.solr.internal.csv.CSVPrinter
Output a blank line
println() - Method in class org.apache.solr.security.PrintWriterWrapper
 
println() - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(boolean) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(boolean) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(char) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(char) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(char[]) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(double) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(double) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(float) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(float) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(int) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(int) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(long) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(long) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(Object) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(String) - Method in class org.apache.solr.security.PrintWriterWrapper
 
println(String) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
println(String[]) - Method in class org.apache.solr.internal.csv.CSVPrinter
Print a single line of comma separated values.
printlnComment(String) - Method in class org.apache.solr.internal.csv.CSVPrinter
Put a comment among the comma separated values.
printRed(Object) - Static method in class org.apache.solr.packagemanager.PackageUtils
Console print using red color
printStackTrace(PrintWriter) - Method in exception org.apache.solr.handler.export.ExportWriter.IgnoreException
 
printStats(SolrQueryRequest) - Method in class org.apache.solr.search.stats.ExactSharedStatsCache
 
printStats(SolrQueryRequest) - Method in class org.apache.solr.search.stats.ExactStatsCache
 
printStats(SolrQueryRequest) - Method in class org.apache.solr.search.stats.LRUStatsCache
 
PrintWriterWrapper - Class in org.apache.solr.security
Wrapper for PrintWriter that delegates to constructor arg
PrintWriterWrapper(PrintWriter) - Constructor for class org.apache.solr.security.PrintWriterWrapper
 
prioritizedFreeDiskGB - Variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Replica allocation will assign replicas to nodes with at least this number of GB of free disk space regardless of the number of cores on these nodes rather than assigning replicas to nodes with less than this amount of free disk space if that's an option (if that's not an option, replicas can still be assigned to nodes with less than this amount of free space).
prioritizeOverseerNodes(String) - Method in class org.apache.solr.cloud.OverseerNodePrioritizer
 
PRIORITY - Static variable in class org.apache.solr.jersey.PostRequestDecorationFilter
 
PRIORITY - Static variable in class org.apache.solr.jersey.PostRequestLoggingFilter
 
process() - Method in class org.apache.solr.handler.tagger.Tagger
 
process() - Method in class org.apache.solr.search.facet.FacetProcessor
 
process(String[]) - Method in class org.apache.solr.handler.component.PivotFacetProcessor
Processes all of the specified FacetParams.FACET_PIVOT strings, generating a complete response tree for each pivot.
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.ActiveTasksListComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.DebugComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.ExpandComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.FacetComponent
Actually run the query
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.HighlightComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryCancellationComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
Actually run the query
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryElevationComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.ResponseLogComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.SearchComponent
Process the request for this component
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.StatsComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.SuggestComponent
Responsible for using the specified suggester to get the suggestions for the query and write the results
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.TermsComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.handler.component.TermVectorComponent
 
process(ResponseBuilder) - Method in class org.apache.solr.search.facet.FacetModule
 
process(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.IterativeMergeStrategy
 
process(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.grouping.distributed.responseprocessor.SearchGroupShardResponseProcessor
 
process(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.grouping.distributed.responseprocessor.StoredFieldsShardResponseProcessor
 
process(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.grouping.distributed.responseprocessor.TopGroupsShardResponseProcessor
 
process(ResponseBuilder, ShardRequest) - Method in interface org.apache.solr.search.grouping.distributed.ShardResponseProcessor
Processes the responses from the specified shardRequest.
process(SolrQueryRequest, DocSet) - Method in class org.apache.solr.search.facet.FacetRequest
Process this facet request against the given domain of docs.
process(AddUpdateCommand, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
This object is reused across requests.
process(AddUpdateCommand, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
process(WatchedEvent) - Method in class org.apache.solr.schema.ZkIndexSchemaReader.SchemaWatcher
 
PROCESS - org.apache.solr.servlet.SolrDispatchFilter.Action
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessor
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
Calls mutate on any fields identified by the selector before forwarding the command down the chain.
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.RegexpBoostProcessor
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.RoutedAliasUpdateProcessor
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessor
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
 
processAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
 
processAndRespondToException(Exception, SolrQueryRequest, ContainerRequestContext) - Static method in class org.apache.solr.jersey.CatchAllExceptionMapper
 
processBoost(AddUpdateCommand) - Method in class org.apache.solr.update.processor.RegexpBoostProcessor
 
processCommandLineArgs(String, List<Option>, String[]) - Static method in class org.apache.solr.cli.SolrCLI
Parses the command-line arguments passed by the user.
processCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
processCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
processCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.processor.RoutedAliasUpdateProcessor
 
processCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessor
 
processCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
 
processConfigChange(Map<String, Object>) - Method in class org.apache.solr.servlet.QueryRateLimiter
 
processDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
processDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
processDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessor
 
processDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.RoutedAliasUpdateProcessor
 
processDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessor
 
processDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
 
ProcessedFilter() - Constructor for class org.apache.solr.search.SolrIndexSearcher.ProcessedFilter
 
processEmpty - Variable in class org.apache.solr.search.facet.FacetRequest
 
processErrorMetricsOnException(Exception, RequestHandlerBase.HandlerMetrics) - Static method in class org.apache.solr.handler.RequestHandlerBase
 
processGetFingeprint(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
processGetUpdates(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
processGetVersions(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
processIds(ResponseBuilder, DocList, IndexSchema, SolrIndexSearcher) - Method in class org.apache.solr.handler.component.ResponseLogComponent
 
processMergeIndexes(MergeIndexesCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
processMergeIndexes(MergeIndexesCommand) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessor
 
processMergeIndexes(MergeIndexesCommand) - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
 
processMessage(ZkNodeProps, String) - Method in class org.apache.solr.cloud.api.collections.OverseerCollectionMessageHandler
 
processMessage(ZkNodeProps, String) - Method in class org.apache.solr.cloud.OverseerConfigSetMessageHandler
 
processMessage(ZkNodeProps, String) - Method in interface org.apache.solr.cloud.OverseerMessageHandler
 
processor - Variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
processor - Variable in class org.apache.solr.update.processor.UpdateRequestProcessorChain.ProcessorInfo
 
ProcessorInfo(SolrParams) - Constructor for class org.apache.solr.update.processor.UpdateRequestProcessorChain.ProcessorInfo
 
processParams(SolrRequestHandler, SolrQueryRequest, SolrParams, SolrParams, SolrParams) - Static method in class org.apache.solr.request.json.RequestUtil
Set default-ish params on a SolrQueryRequest as well as do standard macro processing and JSON request parsing.
processPathHierarchyQueryString(String) - Static method in class org.apache.solr.response.transform.ChildDocTransformerFactory
 
processRequest(SolrQueryRequest, ResponseBuilder, Map<String, String>) - Method in class org.apache.solr.handler.component.TaskManagementHandler
Process the actual request.
processResult(QueryResult, ShardResultTransformer<List<Command<?>>, ?>) - Method in class org.apache.solr.search.grouping.CommandHandler
 
processRollback(RollbackUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
processRollback(RollbackUpdateCommand) - Method in class org.apache.solr.update.processor.TolerantUpdateProcessor
 
processRollback(RollbackUpdateCommand) - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
 
processScores(ResponseBuilder, DocList, IndexSchema, SolrIndexSearcher) - Method in class org.apache.solr.handler.component.ResponseLogComponent
 
processStats(SimpleOrderedMap<Object>, Query, DocSet, long) - Method in class org.apache.solr.search.facet.FacetProcessor
 
processStoredData(Object) - Method in class org.apache.solr.rest.ManagedResource
Processes the stored data.
processSync(ResponseBuilder, int, String) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
processSyncWithLeader(ResponseBuilder, int, String, List<Long>) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
 
processUpdate(SolrQueryRequest, UpdateRequestProcessor, XMLStreamReader) - Method in class org.apache.solr.handler.loader.XMLLoader
 
PROHIBITED_TERM_FLAG - Static variable in class org.apache.solr.spelling.QueryConverter
This term is marked prohibited in the query with the minus sign.
prompt(Scanner, String) - Method in class org.apache.solr.cli.RunExampleTool
 
prompt(Scanner, String, String) - Method in class org.apache.solr.cli.RunExampleTool
 
PROMPT - Static variable in class org.apache.solr.security.AuthorizationResponse
 
promptForInt(Scanner, String, String, Integer, Integer, Integer) - Method in class org.apache.solr.cli.RunExampleTool
 
promptForPort(Scanner, int, String, Integer) - Method in class org.apache.solr.cli.RunExampleTool
 
properties - Variable in class org.apache.solr.schema.FieldType
 
PROPERTIES - Static variable in class org.apache.solr.cloud.api.collections.SetAliasPropCmd
 
PROPERTIES_ATTRIBUTE - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
PROPERTIES_FILENAME - Static variable in class org.apache.solr.core.CorePropertiesLocator
 
PropertiesInputStream - Class in org.apache.solr.util
 
PropertiesInputStream(IndexInput) - Constructor for class org.apache.solr.util.PropertiesInputStream
 
PropertiesOutputStream - Class in org.apache.solr.util
 
PropertiesOutputStream(IndexOutput) - Constructor for class org.apache.solr.util.PropertiesOutputStream
 
PropertiesRequestHandler - Class in org.apache.solr.handler.admin
 
PropertiesRequestHandler() - Constructor for class org.apache.solr.handler.admin.PropertiesRequestHandler
 
PropertiesRequestHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.PropertiesRequestHandler
 
PROPERTY_BLOCK_UNKNOWN - Static variable in class org.apache.solr.security.BasicAuthPlugin
 
PROPERTY_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
PROPERTY_REALM - Static variable in class org.apache.solr.security.BasicAuthPlugin
 
PROPERTY_SCHEME - Static variable in class org.apache.solr.security.MultiAuthPlugin
 
PROPERTY_SCHEMES - Static variable in class org.apache.solr.security.MultiAuthPlugin
 
provide() - Method in class org.apache.solr.handler.ReplicationHandler
 
provide() - Method in interface org.apache.solr.jersey.APIConfigProvider
 
provide() - Method in class org.apache.solr.jersey.InjectionFactories.ReuseFromContextIndexSchemaFactory
 
provide() - Method in class org.apache.solr.jersey.InjectionFactories.ReuseFromContextSolrCoreFactory
 
provide() - Method in class org.apache.solr.jersey.InjectionFactories.ReuseFromContextSolrParamsFactory
 
provide() - Method in class org.apache.solr.jersey.InjectionFactories.SingletonFactory
 
provide() - Method in class org.apache.solr.jersey.InjectionFactories.SolrQueryRequestFactory
 
provide() - Method in class org.apache.solr.jersey.InjectionFactories.SolrQueryResponseFactory
 
provideCapacity(int) - Method in class org.apache.solr.internal.csv.CharBuffer
Copies the data into a new array of at least capacity size.
Provider(CoreContainer, String, UUID) - Constructor for class org.apache.solr.core.SolrCore.Provider
 
PROVIDER_CHAIN_KEY - Static variable in class org.apache.solr.util.configuration.SSLCredentialProviderFactory
 
PublicKeyHandler - Class in org.apache.solr.security
 
PublicKeyHandler() - Constructor for class org.apache.solr.security.PublicKeyHandler
 
PublicKeyHandler(SolrNodeKeyPair) - Constructor for class org.apache.solr.security.PublicKeyHandler
 
publish(LogRecord) - Method in class org.apache.solr.logging.jul.RecordHandler
 
publish(CoreDescriptor, Replica.State) - Method in class org.apache.solr.cloud.ZkController
 
publish(CoreDescriptor, Replica.State, boolean, boolean) - Method in class org.apache.solr.cloud.ZkController
Publish core state to overseer.
publish(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
publishAndWaitForDownStates() - Method in class org.apache.solr.cloud.ZkController
 
publishAndWaitForDownStates(int) - Method in class org.apache.solr.cloud.ZkController
 
PUBLISHED_VERSION - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
publishNodeAsDown(String) - Method in class org.apache.solr.cloud.ZkController
Best effort to set DOWN state for all replicas on node.
PULL - org.apache.solr.cluster.Replica.ReplicaType
 
purgeAllCaches() - Method in interface org.apache.solr.uninverting.FieldCache
EXPERT: Instructs the FieldCache to forcibly expunge all entries from the underlying caches.
purgeAllCaches() - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
purgeByCacheKey(IndexReader.CacheKey) - Method in interface org.apache.solr.uninverting.FieldCache
Expert: drops all cache entries associated with this reader IndexReader.CacheHelper.getKey().
purgeByCacheKey(IndexReader.CacheKey) - Method in class org.apache.solr.uninverting.FieldCacheImpl
 
PURPLE - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
purpose - Variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_DEBUG - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_FACETS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_FIELDS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_HIGHLIGHTS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_JSON_FACETS - Static variable in class org.apache.solr.search.facet.FacetModule
 
PURPOSE_GET_MLT_RESULTS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_STATS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_TERM_DFS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_TERM_STATS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_TERMS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_TOP_GROUPS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_GET_TOP_IDS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_PRIVATE - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_REFINE_FACETS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_REFINE_JSON_FACETS - Static variable in class org.apache.solr.search.facet.FacetModule
 
PURPOSE_REFINE_PIVOT_FACETS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_REFINE_TOP_IDS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
PURPOSE_SET_TERM_STATS - Static variable in class org.apache.solr.handler.component.ShardRequest
 
put(int, float) - Method in class org.apache.solr.util.IntFloatDynamicMap
 
put(int, int) - Method in class org.apache.solr.util.IntIntDynamicMap
 
put(int, long) - Method in class org.apache.solr.util.IntLongDynamicMap
 
put(CharSequence, Object) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Stores a value in the trie.
put(String, byte[]) - Method in class org.apache.solr.cloud.DistributedMap
 
put(String, byte[]) - Method in class org.apache.solr.cloud.SizeLimitedDistributedMap
 
put(String, String) - Method in class org.apache.solr.util.tracing.HttpServletCarrier
 
put(String, String) - Method in class org.apache.solr.util.tracing.SolrApacheHttpRequestCarrier
 
put(String, String) - Method in class org.apache.solr.util.tracing.SolrJettyRequestCarrier
 
put(String, PluginBag.PluginHolder<T>) - Method in class org.apache.solr.core.PluginBag
 
put(String, T) - Method in class org.apache.solr.core.PluginBag
register a plugin by a name
put(K, V) - Method in class org.apache.solr.search.CaffeineCache
 
put(K, V) - Method in interface org.apache.solr.search.SolrCache
:TODO: copy from Map
put(K, V) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
put(K, V) - Method in class org.apache.solr.util.MapListener
 
put(FileStore.FileEntry) - Method in class org.apache.solr.filestore.DistribFileStore
 
put(FileStore.FileEntry) - Method in interface org.apache.solr.filestore.FileStore
Store a file into the filestore.
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.solr.util.MapListener
 
putAndGetShardBackupIdFor(String, int) - Method in class org.apache.solr.core.backup.BackupProperties
 
putCacheEntry(ConcurrentLRUCache.CacheEntry<K, V>) - Method in class org.apache.solr.util.ConcurrentLRUCache
Visible for testing to create synthetic cache entries.
putCore(CoreDescriptor, SolrCore) - Method in class org.apache.solr.core.SolrCores
 
putCore(CoreDescriptor, SolrCore) - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
putIfAbsent(String, byte[]) - Method in class org.apache.solr.cloud.DistributedMap
Puts an element in the map only if there isn't one with the same trackingId already
putIfAbsent(String, byte[]) - Method in class org.apache.solr.cloud.SizeLimitedDistributedMap
 
putInfoItem(String, Object) - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
PythonResponseWriter - Class in org.apache.solr.response
 
PythonResponseWriter() - Constructor for class org.apache.solr.response.PythonResponseWriter
 
pzxid - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 

Q

q - Variable in class org.apache.solr.query.FilterQuery
 
q - Variable in class org.apache.solr.update.UpdateLog.DBQ
 
qparser - Variable in class org.apache.solr.response.transform.ValueSourceAugmenter
 
QParser - Class in org.apache.solr.search
Note: This API is experimental and may change in non backward-compatible ways in the future
QParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.QParser
Constructor for the QParser
QParserPlugin - Class in org.apache.solr.search
 
QParserPlugin() - Constructor for class org.apache.solr.search.QParserPlugin
 
qslop - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
qstr - Variable in class org.apache.solr.search.QParser
 
QUERIES - org.apache.solr.util.PivotListEntry
 
query - Variable in class org.apache.solr.search.Grouping.CommandQuery
 
query - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
query - Variable in class org.apache.solr.search.QParser
 
query - Variable in class org.apache.solr.update.DeleteUpdateCommand
 
query(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
Query(String) - Method in class org.apache.solr.parser.QueryParser
 
QUERY - org.apache.solr.core.SolrInfoBean.Category
 
QUERY - org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
 
QUERY - org.apache.solr.util.vector.DenseVectorParser.BuilderPhase
 
QUERY - Static variable in class org.apache.solr.handler.component.PivotFacetProcessor
 
QUERY - Static variable in class org.apache.solr.schema.FieldType
 
QUERY_ANALYZER - Static variable in class org.apache.solr.schema.FieldType
 
QUERY_ANALYZER - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
The analyzer used at "query-time" and "build-time" to analyze suggestions.
QUERY_ANALYZER - Static variable in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
The analyzer used at "query-time" and "build-time" to analyze suggestions.
QUERY_ANALYZER - Static variable in class org.apache.solr.spelling.suggest.fst.FreeTextLookupFactory
The analyzer used at "query-time" and "build-time" to analyze suggestions.
QUERY_RATE_1MIN - Static variable in class org.apache.solr.cluster.placement.impl.ReplicaMetricImpl
1-min query rate of the /select handler.
QUERY_REGEX - Variable in class org.apache.solr.spelling.SpellingQueryConverter
 
queryAnalyzer - Variable in class org.apache.solr.handler.component.QueryElevationComponent
 
QueryCancellationComponent - Class in org.apache.solr.handler.component
Responsible for handling query cancellation requests
QueryCancellationComponent() - Constructor for class org.apache.solr.handler.component.QueryCancellationComponent
 
QueryCancellationHandler - Class in org.apache.solr.handler.component
Handles requests for query cancellation for cancellable queries
QueryCancellationHandler() - Constructor for class org.apache.solr.handler.component.QueryCancellationHandler
 
QueryCancelledException() - Constructor for exception org.apache.solr.search.CancellableCollector.QueryCancelledException
 
QueryCommand - Class in org.apache.solr.search.grouping.distributed.command
 
QueryCommand - Class in org.apache.solr.search
A query request command to avoid having to change the method signatures if we want to pass additional information to the searcher.
QueryCommand() - Constructor for class org.apache.solr.search.QueryCommand
 
QueryCommand.Builder - Class in org.apache.solr.search.grouping.distributed.command
 
QueryCommandResult - Class in org.apache.solr.search.grouping.distributed.command
Encapsulates TopDocs and the number of matches.
QueryCommandResult(TopDocs, int, float) - Constructor for class org.apache.solr.search.grouping.distributed.command.QueryCommandResult
 
QueryComponent - Class in org.apache.solr.handler.component
TODO!
QueryComponent() - Constructor for class org.apache.solr.handler.component.QueryComponent
 
QueryComponent.ScoreAndDoc - Class in org.apache.solr.handler.component
Fake scorer for a single document
QueryContext - Class in org.apache.solr.search
 
QueryContext(IndexSearcher) - Constructor for class org.apache.solr.search.QueryContext
 
queryConverter - Variable in class org.apache.solr.handler.component.SpellCheckComponent
 
QueryConverter - Class in org.apache.solr.spelling
The QueryConverter is an abstract base class defining a method for converting input "raw" queries into a set of tokens for spell checking.
QueryConverter() - Constructor for class org.apache.solr.spelling.QueryConverter
 
QueryElevationComponent - Class in org.apache.solr.handler.component
A component to elevate some documents to the top of the result set.
QueryElevationComponent() - Constructor for class org.apache.solr.handler.component.QueryElevationComponent
 
QueryElevationComponent.DefaultElevationProvider - Class in org.apache.solr.handler.component
Provides elevations with either: subset match - all the elevating terms are matched in the search query, in any order.
QueryElevationComponent.ElevatingQuery - Class in org.apache.solr.handler.component
Query triggering elevation.
QueryElevationComponent.Elevation - Class in org.apache.solr.handler.component
Elevation of some documents in search results, with potential exclusion of others.
QueryElevationComponent.ElevationBuilder - Class in org.apache.solr.handler.component
QueryElevationComponent.ElevationProvider - Interface in org.apache.solr.handler.component
Provides the elevations defined for queries.
QueryElevationComponent.InitializationExceptionCause - Enum in org.apache.solr.handler.component
 
QueryElevationComponent.TrieSubsetMatcher<E extends Comparable<? super E>,​M> - Class in org.apache.solr.handler.component
Matches a potentially large collection of subsets with a trie implementation.
QueryElevationComponent.TrieSubsetMatcher.Builder<E extends Comparable<? super E>,​M> - Class in org.apache.solr.handler.component
 
QueryFacet(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.FacetComponent.QueryFacet
 
queryFacets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
queryFactory - Variable in class org.apache.solr.search.SolrQueryBuilder
 
queryFields - Variable in class org.apache.solr.search.DisMaxQParser
 
queryFields - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
The field names specified by 'qf' that (most) clauses will be queried against
queryID - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
QUERYLESS_URL_AND_METHOD - Static variable in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
queryParams - Variable in class org.apache.solr.servlet.HttpSolrCall
 
QueryParser - Class in org.apache.solr.parser
 
QueryParser(String, QParser) - Constructor for class org.apache.solr.parser.QueryParser
 
QueryParser(CharStream) - Constructor for class org.apache.solr.parser.QueryParser
Constructor with user supplied CharStream.
QueryParser(QueryParserTokenManager) - Constructor for class org.apache.solr.parser.QueryParser
Constructor with generated Token Manager.
QUERYPARSER - org.apache.solr.core.SolrInfoBean.Category
 
QueryParser.Operator - Enum in org.apache.solr.parser
The default operator for parsing queries.
QueryParserConstants - Interface in org.apache.solr.parser
Token literal values and constants.
QueryParserTokenManager - Class in org.apache.solr.parser
Token Manager.
QueryParserTokenManager(CharStream) - Constructor for class org.apache.solr.parser.QueryParserTokenManager
Constructor.
QueryParserTokenManager(CharStream, int) - Constructor for class org.apache.solr.parser.QueryParserTokenManager
Constructor.
QueryParsing - Class in org.apache.solr.search
Collection of static utilities useful for query parsing.
QueryParsing() - Constructor for class org.apache.solr.search.QueryParsing
 
QueryRateLimiter - Class in org.apache.solr.servlet
Implementation of RequestRateLimiter specific to query request types.
QueryRateLimiter(SolrZkClient) - Constructor for class org.apache.solr.servlet.QueryRateLimiter
 
QueryResponseWriter - Interface in org.apache.solr.response
Implementations of QueryResponseWriter are used to format responses to query requests.
QueryResponseWriterUtil - Class in org.apache.solr.response
Static utility methods relating to QueryResponseWriters
QueryResult - Class in org.apache.solr.search
The result of a search.
QueryResult() - Constructor for class org.apache.solr.search.QueryResult
 
queryResultCacheConfig - Variable in class org.apache.solr.core.SolrConfig
 
QueryResultKey - Class in org.apache.solr.search
A hash key encapsulating a query, a list of filters, and a sort
QueryResultKey(Query, List<Query>, Sort, int) - Constructor for class org.apache.solr.search.QueryResultKey
 
QueryResultKey(Query, List<Query>, Sort, int, int) - Constructor for class org.apache.solr.search.QueryResultKey
 
queryResultMaxDocsCached - Variable in class org.apache.solr.core.SolrConfig
 
queryResultWindowSize - Variable in class org.apache.solr.core.SolrConfig
 
QuerySenderListener - Class in org.apache.solr.core
 
QuerySenderListener(SolrCore) - Constructor for class org.apache.solr.core.QuerySenderListener
 
queryString - Variable in class org.apache.solr.handler.component.QueryElevationComponent.ElevatingQuery
 
QueryUtils - Class in org.apache.solr.search
 
QueryUtils() - Constructor for class org.apache.solr.search.QueryUtils
 
QUEUE_OPERATION - Static variable in class org.apache.solr.cloud.Overseer
 
QUEUE_SIZE_PARAM - Static variable in class org.apache.solr.handler.export.ExportWriter
 
queueCoreToClose(SolrCore) - Method in class org.apache.solr.core.SolrCores
 
queuedTime - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
queuePivotRefinementRequests() - Method in class org.apache.solr.handler.component.PivotFacet
A recursive method for determining which PivotFacetValues need to be refined for this pivot.
queuePivotRefinementRequests(PivotFacet) - Method in class org.apache.solr.handler.component.PivotFacetField
A recursive method for determining which PivotFacetValues need to be refined for this pivot.
QUIT - org.apache.solr.cloud.overseer.OverseerAction
 
QUOTED - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.

R

r - Variable in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
radius - Variable in class org.apache.solr.search.SpatialOptions
 
raiseLogLevelUnlessVerbose(CommandLine) - Static method in class org.apache.solr.cli.SolrCLI
 
RAM_BYTES_USED_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
ramBufferSizeMB - Variable in class org.apache.solr.update.SolrIndexConfig
 
ramBytesUsed() - Method in class org.apache.solr.handler.component.SuggestComponent
 
ramBytesUsed() - Method in class org.apache.solr.search.BitDocSet
 
ramBytesUsed() - Method in class org.apache.solr.search.CaffeineCache
 
ramBytesUsed() - Method in class org.apache.solr.search.DocSlice
WARNING: this can over-estimate real memory use since backing arrays are shared with other DocSlice instances
ramBytesUsed() - Method in class org.apache.solr.search.FilteredDocIdSet
 
ramBytesUsed() - Method in class org.apache.solr.search.QueryResultKey
 
ramBytesUsed() - Method in class org.apache.solr.search.SortedIntDocSet
 
ramBytesUsed() - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
 
ramBytesUsed() - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
 
ramBytesUsed() - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
Deprecated.
 
ramBytesUsed() - Method in class org.apache.solr.spelling.suggest.SolrSuggester
 
ramBytesUsed() - Method in class org.apache.solr.uninverting.DocTermOrds
Returns total bytes used.
ramBytesUsed() - Method in class org.apache.solr.uninverting.FieldCache.CreationPlaceholder
 
ramBytesUsed() - Method in class org.apache.solr.uninverting.FieldCacheImpl.BinaryDocValuesImpl
 
ramBytesUsed() - Method in class org.apache.solr.uninverting.FieldCacheImpl.LongsFromArray
 
ramBytesUsed() - Method in class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl
 
ramBytesUsed() - Method in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
ramBytesUsed() - Method in class org.apache.solr.util.ConcurrentLRUCache
 
ramBytesUsed() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
 
RAMDirectoryFactory - Class in org.apache.solr.core
Factory to instantiate RAM-resident directory implementation.
RAMDirectoryFactory() - Constructor for class org.apache.solr.core.RAMDirectoryFactory
 
ramPerThreadHardLimitMB - Variable in class org.apache.solr.update.SolrIndexConfig
 
random - Static variable in class org.apache.solr.servlet.HttpSolrCall
 
RANDOM - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
RANDOM - Static variable in class org.apache.solr.core.BlobRepository
 
randomDelayInCoreCreation - Static variable in class org.apache.solr.util.TestInjection
 
randomDelayMaxInCoreCreationInSec - Static variable in class org.apache.solr.util.TestInjection
 
randomId() - Static method in class org.apache.solr.util.IdUtils
Generate a short random id (see StringHelper.randomId()).
RandomPlacementFactory - Class in org.apache.solr.cluster.placement.plugins
Factory for creating RandomPlacementFactory.RandomPlacementPlugin, a placement plugin implementing random placement for new collection creation while preventing two replicas of same shard from being placed on same node..
RandomPlacementFactory() - Constructor for class org.apache.solr.cluster.placement.plugins.RandomPlacementFactory
 
RandomPlacementFactory.RandomPlacementPlugin - Class in org.apache.solr.cluster.placement.plugins
 
RandomSortField - Class in org.apache.solr.schema
Utility Field used for random sorting.
RandomSortField() - Constructor for class org.apache.solr.schema.RandomSortField
 
RandomSortField.RandomValueSource - Class in org.apache.solr.schema
 
RandomValueSource(String) - Constructor for class org.apache.solr.schema.RandomSortField.RandomValueSource
 
Range - Static variable in interface org.apache.solr.parser.QueryParserConstants
Lexical state.
RANGE - Static variable in class org.apache.solr.handler.component.PivotFacetProcessor
 
RANGE_GOOP - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
RANGE_QUOTED - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
RANGE_TO - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
rangeCount(DocSet, RangeFacetRequest, RangeFacetRequest.FacetRange) - Method in class org.apache.solr.handler.component.RangeFacetProcessor
Macro for getting the numDocs of range over docs
RANGEEX_END - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
RANGEEX_START - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
RangeFacetProcessor - Class in org.apache.solr.handler.component
Processor for Range Facets
RangeFacetProcessor(SolrQueryRequest, DocSet, SolrParams, ResponseBuilder) - Constructor for class org.apache.solr.handler.component.RangeFacetProcessor
 
RangeFacetRequest - Class in org.apache.solr.handler.component
Encapsulates a single facet.range request along with all its parameters.
RangeFacetRequest(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.RangeFacetRequest
 
RangeFacetRequest.FacetRange - Class in org.apache.solr.handler.component
Represents a single facet range (or gap) for which the count is to be calculated
rangeFacets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
 
RANGEIN_END - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
RANGEIN_START - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
ranges - Variable in class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
ranges - Variable in class org.apache.solr.update.SplitIndexCommand
 
RANGES - org.apache.solr.util.PivotListEntry
 
rank - Variable in class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
 
RankedSpellPossibility() - Constructor for class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
 
RankField - Class in org.apache.solr.schema
RankFields can be used to store scoring factors to improve document ranking.
RankField() - Constructor for class org.apache.solr.schema.RankField
 
RankQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.RankQParserPlugin.RankQParser
 
RankQParserPlugin - Class in org.apache.solr.search
RankQParserPlugin can be used to introduce document-depending scoring factors to ranking.
RankQParserPlugin() - Constructor for class org.apache.solr.search.RankQParserPlugin
 
RankQParserPlugin.RankQParser - Class in org.apache.solr.search
 
RankQuery - Class in org.apache.solr.search
Note: This API is experimental and may change in non backward-compatible ways in the future
RankQuery() - Constructor for class org.apache.solr.search.RankQuery
 
RateLimiterConfig - Class in org.apache.solr.core
 
RateLimiterConfig(SolrRequest.SolrRequestType) - Constructor for class org.apache.solr.core.RateLimiterConfig
 
RateLimiterConfig(SolrRequest.SolrRequestType, boolean, int, long, int, boolean) - Constructor for class org.apache.solr.core.RateLimiterConfig
 
RateLimitManager - Class in org.apache.solr.servlet
This class is responsible for managing rate limiting per request type.
RateLimitManager() - Constructor for class org.apache.solr.servlet.RateLimitManager
 
RateLimitManager.Builder - Class in org.apache.solr.servlet
 
rates - Variable in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
ratesFileLocation - Variable in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
raw - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
RAW - Static variable in class org.apache.solr.servlet.SolrRequestParsers
 
RAW_SIZE_DETAILS_PARAM - Static variable in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
RAW_SIZE_DETAILS_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
RAW_SIZE_PARAM - Static variable in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
RAW_SIZE_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
RAW_SIZE_SAMPLING_PERCENT_PARAM - Static variable in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
RAW_SIZE_SAMPLING_PERCENT_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
RAW_SIZE_SUMMARY_PARAM - Static variable in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
RAW_SIZE_SUMMARY_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
rawField - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
rawInput - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
RawMessageBodyWriter() - Constructor for class org.apache.solr.jersey.MessageBodyWriters.RawMessageBodyWriter
 
RawQParserPlugin - Class in org.apache.solr.search
Create a term query from the input value without any text analysis or transformation whatsoever.
RawQParserPlugin() - Constructor for class org.apache.solr.search.RawQParserPlugin
 
RawQuery(SchemaField, String) - Constructor for class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
RawQuery(SchemaField, List<String>) - Constructor for class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
RawResponseWriter - Class in org.apache.solr.response
Writes a ContentStream directly to the output.
RawResponseWriter() - Constructor for class org.apache.solr.response.RawResponseWriter
 
RawValueTransformerFactory - Class in org.apache.solr.response.transform
 
RawValueTransformerFactory() - Constructor for class org.apache.solr.response.transform.RawValueTransformerFactory
 
RawValueTransformerFactory(String) - Constructor for class org.apache.solr.response.transform.RawValueTransformerFactory
 
rb - Variable in class org.apache.solr.request.SimpleFacets
 
read() - Method in class org.apache.solr.handler.CatStream
 
read() - Method in class org.apache.solr.handler.ClassifyStream
 
read() - Method in class org.apache.solr.handler.export.ExportWriterStream
 
read() - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
read() - Method in class org.apache.solr.handler.GraphHandler.TimerStream
 
read() - Method in class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
read() - Method in class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
read() - Method in class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
read() - Method in class org.apache.solr.handler.StreamHandler.TimerStream
 
read() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
read() - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletInputStream
 
read() - Method in class org.apache.solr.util.PropertiesInputStream
 
read(byte[]) - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
read(byte[], int, int) - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
read(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.filestore.FileStoreAPI.FSRead
 
Read() - Constructor for class org.apache.solr.handler.admin.ContainerPluginsApi.Read
 
Read() - Constructor for class org.apache.solr.pkg.PackageAPI.Read
 
READ - org.apache.solr.security.AuthorizationContext.RequestType
 
READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
readableSize(long) - Static method in class org.apache.solr.util.NumberUtils
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.DatePointField
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.DoublePointField
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.EnumFieldType
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.FieldType
Given the readable value, return the term value that will match it.
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.FloatPointField
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.IntPointField
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.LongPointField
 
readableToIndexed(CharSequence, BytesRefBuilder) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
readableToIndexed(String) - Method in class org.apache.solr.schema.AbstractEnumField
 
readableToIndexed(String) - Method in class org.apache.solr.schema.FieldType
Given the readable value, return the term value that will match it.
readableToIndexed(String) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
readAPI - Variable in class org.apache.solr.filestore.FileStoreAPI
 
readAPI - Variable in class org.apache.solr.handler.admin.ContainerPluginsApi
 
readAPI - Variable in class org.apache.solr.pkg.PackageAPI
 
READASBYTES - Static variable in class org.apache.solr.response.ResultContext
 
readBackupProperties() - Method in class org.apache.solr.core.backup.BackupManager
This method returns the configuration parameters for the specified backup.
readCollectionState(String) - Method in class org.apache.solr.core.backup.BackupManager
This method reads the meta-data information for the backed-up collection.
readDoc(XMLStreamReader) - Method in class org.apache.solr.handler.loader.XMLLoader
Given the input stream, read a document
readDoc(XMLStreamReader, boolean) - Method in class org.apache.solr.handler.loader.XMLLoader
 
reader - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
 
reader - Variable in class org.apache.solr.spelling.IndexBasedSpellChecker
 
reader - Variable in class org.apache.solr.spelling.SpellingOptions
An optional IndexReader
reader - Variable in class org.apache.solr.spelling.suggest.Suggester
 
readers - Variable in class org.apache.solr.update.MergeIndexesCommand
 
readExternString(DataInputInputStream) - Method in class org.apache.solr.update.TransactionLog.LogCodec
 
readExtraArgs(String[]) - Method in class org.apache.solr.cli.RunExampleTool
 
readFrom(Class<Object>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.solr.jersey.MessageBodyReaders.CachingDelegatingMessageBodyReader
 
readFrom(BackupRepository, URI, String) - Static method in class org.apache.solr.core.backup.BackupProperties
 
readFromInputStream(InputStreamReader) - Static method in class org.apache.solr.core.ConfigSetProperties
 
readFromLatest(BackupRepository, URI) - Static method in class org.apache.solr.core.backup.BackupProperties
 
readFromResourceLoader(SolrResourceLoader, String) - Static method in class org.apache.solr.core.ConfigSetProperties
Return the properties associated with the ConfigSet (e.g.
readFromResourceLoader(SolrResourceLoader, String, boolean, Properties) - Static method in class org.apache.solr.core.SolrConfig
 
readInputAsString(InputStream) - Method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
readJsonFromRequest(SolrQueryRequest) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
readLine(byte[], int, int) - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
readMetadata(byte[]) - Method in interface org.apache.solr.util.hll.ISchemaVersion
Reads the metadata bytes of the serialized HLL.
readNode(String) - Method in class org.apache.solr.handler.admin.ZookeeperReadAPI
Request contents of a znode, except security.json
readObject(DataInputInputStream) - Method in class org.apache.solr.update.TransactionLog.LogCodec
 
readOnly - Variable in class org.apache.solr.core.SolrCore
 
readPluginInfos(SolrConfig.SolrPluginInfo, boolean, boolean) - Method in class org.apache.solr.core.SolrConfig
 
readRecord() - Method in class org.apache.solr.cli.PostLogsTool.LogRecordReader
 
readSchema(ConfigSetService.ConfigResource) - Method in class org.apache.solr.schema.IndexSchema
 
readSecurityJsonNode() - Method in class org.apache.solr.handler.admin.ZookeeperReadAPI
Request contents of the security.json node
readWord() - Method in interface org.apache.solr.util.hll.IWordDeserializer
 
readWrappedStream(byte[], int, int) - Method in class org.apache.solr.update.TransactionLog.ChannelFastInputStream
 
realName - Variable in enum org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
RealTimeGetAPI - Class in org.apache.solr.handler.admin.api
V2 API for fetching the latest (possibly uncommitted) version of one or more documents.
RealTimeGetAPI(RealTimeGetHandler) - Constructor for class org.apache.solr.handler.admin.api.RealTimeGetAPI
 
RealTimeGetComponent - Class in org.apache.solr.handler.component
 
RealTimeGetComponent() - Constructor for class org.apache.solr.handler.component.RealTimeGetComponent
 
RealTimeGetComponent.Resolution - Enum in org.apache.solr.handler.component
Lookup strategy for some methods on this class.
RealTimeGetHandler - Class in org.apache.solr.handler
 
RealTimeGetHandler() - Constructor for class org.apache.solr.handler.RealTimeGetHandler
 
rebalanceLeaders(PayloadObj<RebalanceLeadersPayload>) - Method in class org.apache.solr.handler.admin.api.RebalanceLeadersAPI
 
REBALANCELEADERS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
RebalanceLeadersAPI - Class in org.apache.solr.handler.admin.api
V2 API for balancing shard leaders in a collection across nodes.
RebalanceLeadersAPI(CollectionsHandler) - Constructor for class org.apache.solr.handler.admin.api.RebalanceLeadersAPI
 
RebalanceLeadersCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.RebalanceLeadersCmd
 
rebuildUserQuery(List<ExtendedDismaxQParser.Clause>, boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Generates a query string from the raw clauses, uppercasing 'and' and 'or' as needed.
receiveGlobalStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
receiveGlobalStats(SolrQueryRequest) - Method in class org.apache.solr.search.stats.StatsCache
Receive global stats data from the leader and update a local cache of global stats with this global data.
RecentUpdates(Deque<TransactionLog>) - Constructor for class org.apache.solr.update.UpdateLog.RecentUpdates
 
RECIP_DISTANCE - Static variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
record(DistributedClusterStateUpdater.MutatingCommand, ZkNodeProps) - Method in class org.apache.solr.cloud.DistributedClusterStateUpdater.StateChangeRecorder
Records a mutation method and its parameters so that it can be executed later to modify the corresponding Zookeeper state.
recordCollectionForLogAndTracing(String, SolrQueryRequest) - Static method in class org.apache.solr.handler.admin.api.AdminAPIBase
TODO Taken from CollectionsHandler.handleRequestBody, but its unclear where (if ever) this gets cleared.
RecordHandler - Class in org.apache.solr.logging.jul
 
RecordHandler(LogWatcher<LogRecord>) - Constructor for class org.apache.solr.logging.jul.RecordHandler
 
RecordingJSONParser - Class in org.apache.solr.util
 
RecordingJSONParser(Reader) - Constructor for class org.apache.solr.util.RecordingJSONParser
 
recovered() - Method in interface org.apache.solr.cloud.RecoveryStrategy.RecoveryListener
 
recovered() - Method in class org.apache.solr.update.DefaultSolrCoreState
called from recoveryStrat on a successful recovery
recoverFromCurrentLog() - Method in class org.apache.solr.update.UpdateLog
Replay current tlog, so all updates will be written to index.
recoverFromLog() - Method in class org.apache.solr.update.UpdateLog
 
RECOVERING - org.apache.solr.cluster.Replica.ReplicaState
 
RecoveringCoreTermWatcher - Class in org.apache.solr.cloud
Start recovery of a core if its term is less than leader's term
RECOVERY - org.apache.solr.cluster.Shard.ShardState
 
RECOVERY_FAILED - org.apache.solr.cluster.Replica.ReplicaState
 
RECOVERY_FAILED - org.apache.solr.cluster.Shard.ShardState
 
recoveryInfo - Variable in class org.apache.solr.update.UpdateLog
 
RecoveryInfo() - Constructor for class org.apache.solr.update.UpdateLog.RecoveryInfo
 
RecoveryStrategy - Class in org.apache.solr.cloud
This class may change in future and customisations are not supported between versions in terms of API or back compat behaviour.
RecoveryStrategy(CoreContainer, CoreDescriptor, RecoveryStrategy.RecoveryListener) - Constructor for class org.apache.solr.cloud.RecoveryStrategy
 
RecoveryStrategy.Builder - Class in org.apache.solr.cloud
 
RecoveryStrategy.RecoveryListener - Interface in org.apache.solr.cloud
 
recurseCount - Variable in class org.apache.solr.search.QParser
 
RED - org.apache.solr.handler.admin.ClusterStatus.Health
No leader or all replicas down.
RED - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
RED_LEVEL - Static variable in enum org.apache.solr.handler.admin.ClusterStatus.Health
 
REDACTED_SYS_PROP_VALUE - Static variable in class org.apache.solr.core.NodeConfig
 
RedirectServlet - Class in org.apache.solr.servlet
A Simple redirection servlet to help us deprecate old UI elements
RedirectServlet() - Constructor for class org.apache.solr.servlet.RedirectServlet
 
reduce(TagLL[]) - Method in interface org.apache.solr.handler.tagger.TagClusterReducer
Reduces the linked-list to only those tags that should be emitted
reduce(IndexFingerprint, IndexFingerprint) - Static method in class org.apache.solr.update.IndexFingerprint
 
refCnt - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
refcount - Variable in class org.apache.solr.update.TransactionLog
 
refcount - Variable in class org.apache.solr.util.RefCounted
 
RefCounted<Type> - Class in org.apache.solr.util
Keep track of a reference count on a resource and close it when the count hits zero.
RefCounted(Type) - Constructor for class org.apache.solr.util.RefCounted
 
referencedByAlias(String, Aliases, boolean) - Static method in class org.apache.solr.cloud.api.collections.DeleteCollectionCmd
 
REFINE_PARAM - Static variable in class org.apache.solr.handler.component.PivotFacet
Local param used to indicate that refinements are required on a pivot.
reflectWith(AttributeReflector) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.solr.handler.tagger.TaggingAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
reflectWith(AttributeReflector) - Method in class org.apache.solr.spelling.Token
Deprecated.
 
refresh() - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
refresh() - Method in class org.apache.solr.packagemanager.DefaultPackageRepository
 
refresh() - Method in class org.apache.solr.packagemanager.PackageRepository
 
refresh(String) - Method in class org.apache.solr.filestore.DistribFileStore
 
refresh(String) - Method in interface org.apache.solr.filestore.FileStore
Refresh the files in a path.
refresh(PayloadObj<String>) - Method in class org.apache.solr.pkg.PackageAPI.Edit
 
refreshAnalyzers() - Method in class org.apache.solr.schema.IndexSchema
This will re-create the Analyzers.
refreshCache(IndexReader) - Method in class org.apache.solr.search.function.FileFloatSource
Refresh the cache for an IndexReader.
RefreshCollectionMessage - Class in org.apache.solr.cloud
Refresh the ClusterState for a given collection.
RefreshCollectionMessage(String) - Constructor for class org.apache.solr.cloud.RefreshCollectionMessage
 
refreshIntervalSeconds - Variable in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
refreshPackageConf() - Method in class org.apache.solr.pkg.SolrPackageLoader
 
refreshPackages(Watcher) - Method in class org.apache.solr.pkg.PackageAPI
 
refreshRequestParams() - Method in class org.apache.solr.core.SolrConfig
 
refreshSchemaFromZk(int) - Method in class org.apache.solr.schema.ZkIndexSchemaReader
 
refreshTerms() - Method in class org.apache.solr.cloud.ZkShardTerms
Fetch latest terms from ZK
regenerateItem(SolrIndexSearcher, SolrCache<K, V>, SolrCache<K, V>, K, V) - Method in interface org.apache.solr.search.CacheRegenerator
Regenerate an old cache item and insert it into newCache
regenerateItem(SolrIndexSearcher, SolrCache<K, V>, SolrCache<K, V>, K, V) - Method in class org.apache.solr.search.NoOpRegenerator
 
regenerator - Variable in class org.apache.solr.search.SolrCacheBase
 
regex - Variable in class org.apache.solr.schema.IndexSchema.DynamicReplacement.DynamicPattern
 
REGEX_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
RegexBytesRefFilter - Class in org.apache.solr.request
An implementation of Predicate which returns true if the BytesRef matches the supplied regular expression.
RegexBytesRefFilter(String) - Constructor for class org.apache.solr.request.RegexBytesRefFilter
 
RegexFileFilter - Class in org.apache.solr.util
Accepts any file whose name matches the pattern
RegexFileFilter(String) - Constructor for class org.apache.solr.util.RegexFileFilter
 
RegexFileFilter(Pattern) - Constructor for class org.apache.solr.util.RegexFileFilter
 
RegexFilter(String...) - Constructor for class org.apache.solr.metrics.SolrMetricManager.RegexFilter
Create a filter that uses the provided prefix.
RegexFilter(Collection<String>) - Constructor for class org.apache.solr.metrics.SolrMetricManager.RegexFilter
 
RegexFragmenter - Class in org.apache.solr.highlight
Fragmenter that tries to produce snippets that "look" like a regular expression.
RegexFragmenter() - Constructor for class org.apache.solr.highlight.RegexFragmenter
 
RegexpBoostProcessor - Class in org.apache.solr.update.processor
A processor which will match content of "inputField" against regular expressions found in "boostFilename", and if it matches will return the corresponding boost value from the file and output this to "boostField" as a double value.
RegexpBoostProcessorFactory - Class in org.apache.solr.update.processor
Factory which creates RegexBoostProcessors
RegexpBoostProcessorFactory() - Constructor for class org.apache.solr.update.processor.RegexpBoostProcessorFactory
 
REGEXPTERM - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
RegexReplaceProcessorFactory - Class in org.apache.solr.update.processor
An updated processor that applies a configured regex to any CharSequence values found in the selected fields, and replaces any matches with the configured replacement string.
RegexReplaceProcessorFactory() - Constructor for class org.apache.solr.update.processor.RegexReplaceProcessorFactory
 
register() - Method in class org.apache.solr.search.SolrIndexSearcher
Register sub-objects such as caches and our own metrics
register(String, CoreDescriptor, boolean) - Method in class org.apache.solr.cloud.ZkController
Register shard with ZooKeeper.
register(String, CoreDescriptor, boolean, boolean, boolean) - Method in class org.apache.solr.cloud.ZkController
Register shard with ZooKeeper.
register(String, SolrRequestHandler) - Method in class org.apache.solr.core.RequestHandlers
Handlers must be initialized before calling this function.
register(String, FieldType) - Method in class org.apache.solr.schema.FieldTypePluginLoader
 
register(String, T) - Method in class org.apache.solr.util.plugin.AbstractPluginLoader
Register a plugin with a given name.
register(String, T) - Method in class org.apache.solr.util.plugin.MapPluginLoader
 
register(String, T) - Method in class org.apache.solr.util.plugin.NamedListPluginLoader
 
register(Api) - Method in class org.apache.solr.api.ApiBag
 
register(Api, Map<String, String>) - Method in class org.apache.solr.api.ApiBag
 
register(CircuitBreaker) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
Register a circuit breaker for a core
registerAll(String, MetricSet, SolrMetricManager.ResolutionStrategy, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Register all metrics in the provided MetricSet, optionally skipping those that already exist.
registerCommitCallback(SolrEventListener) - Method in class org.apache.solr.update.UpdateHandler
NOTE: this function is not thread safe.
registerConfListenerForCore(String, SolrCore, Runnable) - Method in class org.apache.solr.cloud.ZkController
This will give a callback to the listener whenever a child is modified in the conf directory.
registerCopyField(String, String) - Method in class org.apache.solr.schema.IndexSchema
 
registerCopyField(String, String, int) - Method in class org.apache.solr.schema.IndexSchema
NOTE: this function is not thread safe.
registerCore(CoreDescriptor, SolrCore, boolean, boolean) - Method in class org.apache.solr.core.CoreContainer
 
registerCustomActions(Map<String, CoreAdminHandler.CoreAdminOp>) - Method in class org.apache.solr.handler.admin.CoreAdminHandler
Registers custom actions defined in solr.xml.
registerDynamicFields(SchemaField...) - Method in class org.apache.solr.schema.IndexSchema
Register one or more new Dynamic Fields with the Schema.
registered(String) - Method in class org.apache.solr.cloud.ZkShardTerms
Did this replica registered its term? This is a sign to check f
registerExplicitSrcAndDestFields(String, int, SchemaField, SchemaField) - Method in class org.apache.solr.schema.IndexSchema
 
registerFirstSearcherListener(SolrEventListener) - Method in class org.apache.solr.core.SolrCore
NOTE: this function is not thread safe.
registerGauge(SolrMetricsContext, String, Gauge<?>, String, boolean, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
registerGauge(SolrMetricsContext, String, Gauge<T>, String, SolrMetricManager.ResolutionStrategy, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
 
registerGlobal(CircuitBreaker) - Static method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
Register a global circuit breaker
registerInFlightUpdate() - Method in class org.apache.solr.update.SolrCoreState
Registers in-flight update requests to this core.
registerInfoBean(String, SolrInfoBean) - Method in class org.apache.solr.core.SolrCore
 
registerIntrospect(Map<String, String>, PathTrie<Api>, String, Api) - Static method in class org.apache.solr.api.ApiBag
 
registerInZk(SolrCore, boolean, boolean) - Method in class org.apache.solr.core.ZkContainer
 
registerLazy(PluginBag.PluginHolder<SolrRequestHandler>, PluginInfo) - Method in class org.apache.solr.api.ApiBag
 
registerListener(ContainerPluginsRegistry.PluginRegistryListener) - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
registerListener(ClusterEventListener, ClusterEvent.EventType...) - Method in interface org.apache.solr.cluster.events.ClusterEventProducer
Register an event listener for processing the specified event types.
registerListener(ClusterEventListener, ClusterEvent.EventType...) - Method in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
registerListener(ClusterEventListener, ClusterEvent.EventType...) - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
registerListener(ListenerConfig) - Method in class org.apache.solr.logging.jul.JulWatcher
 
registerListener(ListenerConfig) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
registerListener(ListenerConfig) - Method in class org.apache.solr.logging.LogWatcher
 
registerManagedResource(String, Class<? extends ManagedResource>, ManagedResourceObserver) - Method in class org.apache.solr.rest.RestManager.Registry
Register the need to use a ManagedResource; this method is typically called by a Solr component during core initialization to register itself as an observer of a specific type of ManagedResource.
registerMetric(SolrMetricsContext, String, Metric, boolean, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
registerMetric(SolrMetricsContext, String, Metric, SolrMetricManager.ResolutionStrategy, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Register an instance of Metric.
registerMetricName(String) - Method in class org.apache.solr.metrics.SolrMetricsContext
Register a metric name that this component reports.
registerMetricProducer(String, SolrMetricProducer) - Method in class org.apache.solr.metrics.SolrCoreMetricManager
Registers a mapping of name/metric's with the manager's metric registry.
registerNewSearcherListener(SolrEventListener) - Method in class org.apache.solr.core.SolrCore
NOTE: this function is not thread safe.
registerObject(Object) - Method in class org.apache.solr.api.ApiBag
Register a POJO annotated with EndPoint
registerOptimizeCallback(SolrEventListener) - Method in class org.apache.solr.update.UpdateHandler
NOTE: this function is not thread safe.
registerRequestHandler(String, SolrRequestHandler) - Method in class org.apache.solr.core.SolrCore
Registers a handler at the specified location.
registerRequestRateLimiter(RequestRateLimiter, SolrRequest.SolrRequestType) - Method in class org.apache.solr.servlet.RateLimitManager
 
registerResponseWriter(String, QueryResponseWriter) - Method in class org.apache.solr.core.SolrCore
NOTE: this function is not thread safe.
registerSoftCommitCallback(SolrEventListener) - Method in class org.apache.solr.update.UpdateHandler
NOTE: this function is not thread safe.
registerV1() - Method in interface org.apache.solr.api.ApiSupport
Whether this should be made available at the regular legacy path
registerV1() - Method in class org.apache.solr.handler.V2UpdateRequestHandler
 
registerV2() - Method in interface org.apache.solr.api.ApiSupport
Whether this request handler must be made available at the /v2/ path
registerV2() - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.ConfigSetsHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.HealthCheckHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.InfoHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.LoggingHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.PropertiesRequestHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.SecurityConfHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.SystemInfoHandler
 
registerV2() - Method in class org.apache.solr.handler.admin.ThreadDumpHandler
 
registerV2() - Method in class org.apache.solr.handler.BlobHandler
 
registerV2() - Method in class org.apache.solr.handler.component.ActiveTasksListHandler
 
registerV2() - Method in class org.apache.solr.handler.component.QueryCancellationHandler
 
registerV2() - Method in class org.apache.solr.handler.component.SearchHandler
 
registerV2() - Method in class org.apache.solr.handler.MoreLikeThisHandler
 
registerV2() - Method in class org.apache.solr.handler.PingRequestHandler
 
registerV2() - Method in class org.apache.solr.handler.RealTimeGetHandler
 
registerV2() - Method in class org.apache.solr.handler.ReplicationHandler
 
registerV2() - Method in class org.apache.solr.handler.SchemaHandler
 
registerV2() - Method in class org.apache.solr.handler.SolrConfigHandler
 
registerV2() - Method in class org.apache.solr.handler.V2UpdateRequestHandler
 
registerV2() - Method in class org.apache.solr.security.PublicKeyHandler
 
registerWith(MBeanServer) - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
Register MBeans with the given MBeanServer.
registry - Variable in class org.apache.solr.rest.RestManager
 
registry(String) - Method in class org.apache.solr.metrics.SolrMetricManager
Get (or create if not present) a named registry
Registry() - Constructor for class org.apache.solr.rest.RestManager.Registry
 
REGISTRY_ID - Static variable in class org.apache.solr.metrics.reporters.solr.SolrReporter
 
REGISTRY_NAME_PREFIX - Static variable in class org.apache.solr.metrics.SolrMetricManager
Common prefix for all registry names that Solr uses.
REGISTRY_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
registryName - Variable in class org.apache.solr.metrics.SolrMetricReporter
 
registryNames() - Method in class org.apache.solr.metrics.SolrMetricManager
Return a set of existing registry names.
registryNames(String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Return set of existing registry names that match a regex pattern
registryNames(Pattern...) - Method in class org.apache.solr.metrics.SolrMetricManager
 
registryPattern - Variable in class org.apache.solr.metrics.reporters.solr.SolrReporter.Report
 
regularDistributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
regularFinishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
 
REINDEX_STATUS - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
REINDEXCOLLECTION_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
ReindexCollectionCmd - Class in org.apache.solr.cloud.api.collections
Reindex a collection, usually in order to change the index schema.
ReindexCollectionCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
ReindexCollectionCmd.Cmd - Enum in org.apache.solr.cloud.api.collections
 
ReindexCollectionCmd.State - Enum in org.apache.solr.cloud.api.collections
 
reindexFailure - Static variable in class org.apache.solr.util.TestInjection
 
REINDEXING_STATE - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
reindexLatch - Static variable in class org.apache.solr.util.TestInjection
 
ReInit(CharStream) - Method in class org.apache.solr.parser.QueryParser
Reinitialise.
ReInit(CharStream) - Method in class org.apache.solr.parser.QueryParserTokenManager
Reinitialise parser.
ReInit(CharStream) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
ReInit(CharStream, int) - Method in class org.apache.solr.parser.QueryParserTokenManager
Reinitialise parser.
ReInit(QueryParserTokenManager) - Method in class org.apache.solr.parser.QueryParser
Reinitialise.
REJECTED - org.apache.solr.security.AuditEvent.EventType
 
REJOIN_LEADER_ELECTION_CMD - Static variable in class org.apache.solr.handler.admin.api.RejoinLeaderElectionAPI
 
rejoinLeaderElection(PayloadObj<RejoinLeaderElectionPayload>) - Method in class org.apache.solr.handler.admin.api.RejoinLeaderElectionAPI
 
REJOINLEADERELECTION_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
RejoinLeaderElectionAPI - Class in org.apache.solr.handler.admin.api
V2 API for triggering a core to rejoin leader election for the shard it constitutes.
RejoinLeaderElectionAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.RejoinLeaderElectionAPI
 
rejoinOverseerElection(String, boolean) - Method in class org.apache.solr.cloud.ZkController
 
rejoinShardLeaderElection(SolrParams) - Method in class org.apache.solr.cloud.ZkController
 
RelatednessAgg - Class in org.apache.solr.search.facet
An aggregation function designed to be nested under other (possibly deeply nested) facets for the purposes of computing the "relatedness" of facet buckets relative to "foreground" and "background" sets -- primarily for the purpose of building "Semantic Knowledge Graphs"
RelatednessAgg(Query, Query) - Constructor for class org.apache.solr.search.facet.RelatednessAgg
 
release() - Method in interface org.apache.solr.cloud.DistributedLock
 
release() - Method in class org.apache.solr.cloud.DistributedMultiLock
 
release() - Method in class org.apache.solr.util.AdjustableSemaphore
 
release(int) - Method in class org.apache.solr.util.AdjustableSemaphore
 
release(String) - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
This method deletes a previously created snapshot (if any).
release(Directory) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
release(Directory) - Method in class org.apache.solr.core.DirectoryFactory
Releases the Directory so that it may be closed when it is no longer referenced.
releaseCommitPoint(Long) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Release a previously saved commit point.
releaseCommitPoint(IndexCommit) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Release a previously saved commit point.
releaseQueryID(String) - Method in class org.apache.solr.core.CancellableQueryTracker
 
reload() - Method in class org.apache.solr.core.SolrCore.Provider
 
reload() - Method in interface org.apache.solr.schema.ExchangeRateProvider
Ask the currency provider to explicitly reload/refresh its configuration.
reload() - Method in class org.apache.solr.schema.FileExchangeRateProvider
 
reload() - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
reload() - Method in class org.apache.solr.spelling.suggest.SolrSuggester
Reloads the underlying Lucene Suggester
reload() - Method in class org.apache.solr.update.VersionInfo
 
reload(String) - Method in class org.apache.solr.core.CoreContainer
reloads a core refer CoreContainer.reload(String, UUID) for details
reload(String, UUID) - Method in class org.apache.solr.core.CoreContainer
Recreates a SolrCore.
reload(CloudDescriptor) - Method in class org.apache.solr.cloud.CloudDescriptor
 
reload(ConfigSet) - Method in class org.apache.solr.core.SolrCore
 
reload(CoreDescriptor, CoreContainer) - Method in class org.apache.solr.core.CorePropertiesLocator
 
reload(CoreDescriptor, CoreContainer) - Method in interface org.apache.solr.core.CoresLocator
Reload a core descriptor.
reload(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
reload(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
 
reload(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.DirectSolrSpellChecker
 
reload(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.IndexBasedSpellChecker
 
reload(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.SolrSpellChecker
Reloads the index.
reload(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.Suggester
 
reload(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.WordBreakSolrSpellChecker
 
RELOAD_COLLECTIONS_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
RELOAD_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
RELOAD_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
ReloadCacheRequestHandler() - Constructor for class org.apache.solr.search.function.FileFloatSource.ReloadCacheRequestHandler
 
reloadCollection(String, ReloadCollectionRequestBody) - Method in class org.apache.solr.handler.admin.api.ReloadCollectionAPI
 
ReloadCollectionAPI - Class in org.apache.solr.handler.admin.api
V2 API implementation for reloading collections.
ReloadCollectionAPI(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ReloadCollectionAPI
 
ReloadCollectionCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.ReloadCollectionCmd
 
reloadCore(String, ReloadCoreRequestBody) - Method in class org.apache.solr.handler.admin.api.ReloadCore
 
ReloadCore - Class in org.apache.solr.handler.admin.api
V2 API implementation for reloading an individual core.
ReloadCore(SolrQueryRequest, SolrQueryResponse, CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker) - Constructor for class org.apache.solr.handler.admin.api.ReloadCore
 
reloadFromStorage() - Method in class org.apache.solr.rest.ManagedResource
Invoked when this object determines it needs to reload the stored data.
RemoteMessage() - Constructor for class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
REMOTEQUERY - org.apache.solr.servlet.SolrDispatchFilter.Action
 
remove() - Method in class org.apache.solr.cloud.ZkDistributedQueue
Attempts to remove the head of the queue and return it.
remove() - Method in class org.apache.solr.response.DocsStreamer
 
remove() - Method in class org.apache.solr.spelling.PossibilityIterator
 
remove(int) - Method in class org.apache.solr.util.IntFloatDynamicMap
 
remove(int) - Method in class org.apache.solr.util.IntIntDynamicMap
 
remove(int) - Method in class org.apache.solr.util.IntLongDynamicMap
 
remove(Object) - Method in class org.apache.solr.util.MapListener
 
remove(String) - Method in class org.apache.solr.cloud.DistributedMap
return true if the znode was successfully deleted false if the node didn't exist and therefore not deleted exception an exception occurred while deleting
remove(String) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
remove(String) - Method in class org.apache.solr.core.DirectoryFactory
This remove is special in that it may be called even after the factory has been closed.
remove(String) - Method in class org.apache.solr.core.EphemeralDirectoryFactory
 
remove(String) - Method in class org.apache.solr.core.SolrCores
 
remove(String) - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
remove(String) - Method in class org.apache.solr.index.MergePolicyFactoryArgs
 
remove(String) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Removes the value indexed by key.
remove(String, boolean) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
remove(String, boolean) - Method in class org.apache.solr.core.DirectoryFactory
This remove is special in that it may be called even after the factory has been closed.
remove(Collection<String>) - Method in class org.apache.solr.cloud.ZkDistributedQueue
 
remove(K) - Method in class org.apache.solr.search.CaffeineCache
 
remove(K) - Method in interface org.apache.solr.search.SolrCache
 
remove(K) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
remove(Directory) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
remove(Directory) - Method in class org.apache.solr.core.DirectoryFactory
Removes the Directory's persistent storage.
remove(Directory) - Method in class org.apache.solr.core.EphemeralDirectoryFactory
 
remove(Directory, boolean) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
remove(Directory, boolean) - Method in class org.apache.solr.core.DirectoryFactory
Removes the Directory's persistent storage.
remove(PayloadObj<String>) - Method in class org.apache.solr.handler.admin.ContainerPluginsApi.Edit
 
remove(OverseerTaskQueue.QueueEvent) - Method in class org.apache.solr.cloud.OverseerTaskQueue
Remove the event and save the response into the other path.
REMOVE_SOURCE - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
removeAllRefinementsForShard(int) - Method in class org.apache.solr.handler.component.PivotFacet
Clears the list of queued refinements for the specified shard
RemoveBlankFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Removes any values found which are CharSequence with a length of 0.
RemoveBlankFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.RemoveBlankFieldUpdateProcessorFactory
 
removeCancellableQuery(String) - Method in class org.apache.solr.core.CancellableQueryTracker
 
removeCloseHook(Closeable) - Method in class org.apache.solr.search.QueryContext
 
removeCloseHook(CloseHook) - Method in class org.apache.solr.core.SolrCore
Remove a close callback hook
removeConfListener(Runnable) - Method in class org.apache.solr.core.SolrCore
Remove a listener
removeCore(String) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Removes a core from the internal structures, presumably it being closed.
removeCore(String) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
removeCoreDescriptor(CoreDescriptor) - Method in class org.apache.solr.core.SolrCores
 
removeCoreDescriptor(CoreDescriptor) - Method in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
REMOVED - org.apache.solr.api.ContainerPluginsRegistry.Diff
 
removeDirectory(CachingDirectoryFactory.CacheValue) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
removeDirectory(CachingDirectoryFactory.CacheValue) - Method in class org.apache.solr.core.StandardDirectoryFactory
 
removeEntries - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
removeEntries - Variable in class org.apache.solr.core.CachingDirectoryFactory
 
removeEphemeralLiveNode() - Method in class org.apache.solr.cloud.ZkController
 
removeFromPendingOps(String) - Method in class org.apache.solr.core.SolrCores
 
removeHttpHeader(String) - Method in class org.apache.solr.response.SolrQueryResponse
Removes a previously added header with the given name (only the first one if multiple are present for the same name)
removeHttpHeaders(String) - Method in class org.apache.solr.response.SolrQueryResponse
Removes all previously added headers with the given name.
removeListener(PackageListeners.Listener) - Method in class org.apache.solr.pkg.PackageListeners
 
removeLL() - Method in class org.apache.solr.handler.tagger.TagLL
Removes this tag from the chain, connecting prevTag and nextTag.
removeNulls(Map.Entry<String, T>[], NamedList<T>) - Static method in class org.apache.solr.util.SolrPluginUtils
Adds to dest all the not-null elements of entries that have non-null names
removeOnReconnectListener(OnReconnect) - Method in class org.apache.solr.cloud.ZkController
Removed a previously registered OnReconnect listener, such as when a core is removed or reloaded.
removeOriginal(String) - Method in class org.apache.solr.handler.component.SpellCheckMergeData
Removes the original word from all maps where original words are used as keys, as well as any collations that contain this original word as a misspelling
removeProjectedReplicaWeights(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
removeRegistry(String) - Method in class org.apache.solr.metrics.SolrMetricManager
Remove a named registry.
removeReplica(Replica) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
removeReplica(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.SliceMutator
 
removeResponseHeader() - Method in class org.apache.solr.response.SolrQueryResponse
Clear response header
removeRole(PayloadObj<ClusterAPI.RoleInfo>) - Method in class org.apache.solr.handler.ClusterAPI.Commands
 
REMOVEROLE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
removeRoutingRule(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.SliceMutator
 
REMOVEROUTINGRULE - org.apache.solr.cloud.overseer.OverseerAction
 
removeTransientDescriptor(String) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Removes a CoreDescriptor from the list of transient cores descriptors.
removeTransientDescriptor(String) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
rename(String, String) - Method in class org.apache.solr.core.CoreContainer
 
rename(CoreContainer, CoreDescriptor, CoreDescriptor) - Method in class org.apache.solr.core.CorePropertiesLocator
 
rename(CoreContainer, CoreDescriptor, CoreDescriptor) - Method in interface org.apache.solr.core.CoresLocator
Persist the new name of a renamed core
RENAME_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
RENAME_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
RenameCmd - Class in org.apache.solr.cloud.api.collections
 
RenameCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.RenameCmd
 
renameCollection(String, RenameCollectionRequestBody) - Method in class org.apache.solr.handler.admin.api.RenameCollection
 
RenameCollection - Class in org.apache.solr.handler.admin.api
V2 API implementation to "rename" an existing collection
RenameCollection(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.RenameCollection
 
renameCore(String, RenameCoreRequestBody) - Method in class org.apache.solr.handler.admin.api.RenameCore
 
renameCore(PayloadObj<RenameCoreAPI.RenameCorePayload>) - Method in class org.apache.solr.handler.admin.api.RenameCoreAPI
 
RenameCore - Class in org.apache.solr.handler.admin.api
V2 API for renaming an existing Solr core.
RenameCore(CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.RenameCore
 
RenameCoreAPI - Class in org.apache.solr.handler.admin.api
V2 API for renaming an existing Solr core.
RenameCoreAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.RenameCoreAPI
 
RenameCoreAPI.RenameCorePayload - Class in org.apache.solr.handler.admin.api
 
RenameCorePayload() - Constructor for class org.apache.solr.handler.admin.api.RenameCoreAPI.RenameCorePayload
 
renameFields - Variable in class org.apache.solr.search.SolrReturnFields
 
RenameFieldTransformer - Class in org.apache.solr.response.transform
Return a field with a name that is different that what is indexed
RenameFieldTransformer(String, String, boolean) - Constructor for class org.apache.solr.response.transform.RenameFieldTransformer
 
renameWithOverwrite(Directory, String, String) - Method in class org.apache.solr.core.DirectoryFactory
 
renameWithOverwrite(Directory, String, String) - Method in class org.apache.solr.core.StandardDirectoryFactory
 
REPLACE - org.apache.solr.metrics.SolrMetricManager.ResolutionStrategy
The existing metric will be removed and replaced with the new metric
REPLACE - org.apache.solr.search.ReRankOperator
 
REPLACE_DYNAMIC_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
REPLACE_FIELD - org.apache.solr.schema.SchemaManager.OpType
 
REPLACE_FIELD_TYPE - org.apache.solr.schema.SchemaManager.OpType
 
replaceDynamicField(String, FieldType, Map<String, ?>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, deletes the named dynamic field from the copy, creates a new dynamic field with the same field name pattern using the given args, then rebinds any referring dynamic copy fields to the replacement dynamic field.
replaceDynamicField(String, FieldType, Map<String, ?>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
replaceField(String, FieldType, Map<String, ?>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, deletes the named field from the copy, creates a new field with the same name using the given args, then rebinds any referring copy fields to the replacement field.
replaceField(String, FieldType, Map<String, ?>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
replaceFieldType(String, String, Map<String, Object>) - Method in class org.apache.solr.schema.IndexSchema
Copies this schema, deletes the named field type from the copy, creates a new field type with the same name using the given args, rebuilds fields and dynamic fields of the given type, then rebinds any referring copy fields to the rebuilt fields.
replaceFieldType(String, String, Map<String, Object>) - Method in class org.apache.solr.schema.ManagedIndexSchema
 
replaceFlags(int) - Method in class org.apache.solr.search.QueryCommand
 
REPLACEMENT_PARAM - Static variable in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
replaceNode(String, ReplaceNodeRequestBody) - Method in class org.apache.solr.handler.admin.api.ReplaceNode
 
ReplaceNode - Class in org.apache.solr.handler.admin.api
V2 API for recreating replicas in one node (the source) on another node(s) (the target).
ReplaceNode(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ReplaceNode
 
REPLACENODE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
ReplaceNodeCmd - Class in org.apache.solr.cloud.api.collections
 
ReplaceNodeCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.ReplaceNodeCmd
 
replaceTokens(String, Cache<String, TemplateUpdateProcessorFactory.Resolved>, Function<String, Object>, Pattern) - Static method in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
REPLAY - Static variable in class org.apache.solr.update.UpdateCommand
 
REPLAYING - org.apache.solr.update.UpdateLog.State
 
replayOpsMeter - Variable in class org.apache.solr.update.UpdateLog
 
Replica - Interface in org.apache.solr.cluster
An instantiation (or one of the copies) of a given Shard of a given SolrCollection.
REPLICA_TYPE - Static variable in class org.apache.solr.cloud.CloudDescriptor
 
REPLICA_TYPE_SYSPROP - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Name of the system property on a node indicating the type of replicas allowed on that node.
Replica.ReplicaState - Enum in org.apache.solr.cluster
 
Replica.ReplicaType - Enum in org.apache.solr.cluster
The order of this enum is important from the most to least "important" replica type.
ReplicaAddReplicaProperty - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
ReplicaDeleteReplicaProperty - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
replicaExists(ClusterState, String, String, String) - Static method in class org.apache.solr.cloud.CloudUtil
 
ReplicaMetric<T> - Interface in org.apache.solr.cluster.placement
Replica metric identifier, corresponding to one of the internal replica-level metric names (as reported in solr.core.[collection].[replica] registry)
ReplicaMetricImpl<T> - Class in org.apache.solr.cluster.placement.impl
Replica metric identifier, corresponding to one of the internal replica-level metric names (as reported in solr.core.[collection].[replica] registry)
ReplicaMetricImpl(String, String) - Constructor for class org.apache.solr.cluster.placement.impl.ReplicaMetricImpl
 
ReplicaMetricImpl(String, String, Function<Object, T>) - Constructor for class org.apache.solr.cluster.placement.impl.ReplicaMetricImpl
 
ReplicaMetrics - Interface in org.apache.solr.cluster.placement
Strongly-typed replica-level metrics.
ReplicaMetricsBuilder(String) - Constructor for class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ReplicaMetricsBuilder
 
ReplicaMigrationUtils - Class in org.apache.solr.cloud.api.collections
 
ReplicaMigrationUtils() - Constructor for class org.apache.solr.cloud.api.collections.ReplicaMigrationUtils
 
ReplicaMutator - Class in org.apache.solr.cloud.overseer
 
ReplicaMutator(SolrCloudManager) - Constructor for class org.apache.solr.cloud.overseer.ReplicaMutator
 
ReplicaPlacement - Interface in org.apache.solr.cluster.placement
Placement decision for a single Replica.
replicas() - Method in interface org.apache.solr.cluster.Shard
Allow foreach iteration on replicas such as: for (Replica r : shard.replicas()) {...}.
ReplicaSetState - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
REPLICATE_AFTER - Static variable in class org.apache.solr.handler.ReplicationHandler
 
ReplicateFromLeader - Class in org.apache.solr.cloud
 
ReplicateFromLeader(CoreContainer, String) - Constructor for class org.apache.solr.cloud.ReplicateFromLeader
 
REPLICATION - org.apache.solr.core.SolrInfoBean.Category
 
REPLICATION_PROPERTIES - Static variable in class org.apache.solr.handler.IndexFetcher
 
ReplicationAPIBase - Class in org.apache.solr.handler.admin.api
A common parent for "replication" (i.e.
ReplicationAPIBase(SolrCore, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.ReplicationAPIBase
 
ReplicationHandler - Class in org.apache.solr.handler
A Handler which provides a REST API for replication and serves replication requests from Followers.
ReplicationHandler() - Constructor for class org.apache.solr.handler.ReplicationHandler
 
ReplicationHandler.PollListener - Interface in org.apache.solr.handler
 
ReplicationHandler.ReplicationHandlerConfig - Class in org.apache.solr.handler
 
ReplicationHandlerConfig() - Constructor for class org.apache.solr.handler.ReplicationHandler.ReplicationHandlerConfig
 
replicaType - Variable in class org.apache.solr.cloud.api.collections.AddReplicaCmd.CreateReplica
 
replicaType - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
report() - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter
 
report(SortedMap<String, Gauge>, SortedMap<String, Counter>, SortedMap<String, Histogram>, SortedMap<String, Meter>, SortedMap<String, Timer>) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter
 
Report(String, String, String, Collection<String>) - Constructor for class org.apache.solr.metrics.reporters.solr.SolrReporter.Report
Create a report specification
REPORTER_ID - Static variable in class org.apache.solr.metrics.reporters.solr.SolrReporter
 
ReporterClientCache<T> - Class in org.apache.solr.metrics.reporters
Simple cache for reusable service clients used by some implementations of SolrMetricReporter.
ReporterClientCache() - Constructor for class org.apache.solr.metrics.reporters.ReporterClientCache
 
ReporterClientCache.ClientProvider<T> - Interface in org.apache.solr.metrics.reporters
Provide an instance of service client.
reportStatus(NamedList<Object>, SolrClient) - Method in class org.apache.solr.cli.StatusTool
 
REPOSITORIES_ZK_PATH - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
repository - Variable in class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
repository - Variable in class org.apache.solr.core.backup.BackupManager
 
repository - Variable in class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
repository - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationRequestBody
 
repositoryManager - Variable in class org.apache.solr.cli.PackageTool
 
RepositoryManager - Class in org.apache.solr.packagemanager
Handles most of the management of repositories and packages present in external repositories.
RepositoryManager(SolrClient, PackageManager) - Constructor for class org.apache.solr.packagemanager.RepositoryManager
 
repositoryURL - Variable in class org.apache.solr.packagemanager.PackageRepository
 
req - Variable in class org.apache.solr.cloud.Stats.FailedOp
 
req - Variable in class org.apache.solr.handler.admin.api.CoreAdminAPIBase
 
req - Variable in class org.apache.solr.handler.admin.CoreAdminHandler.CallInfo
 
req - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
req - Variable in class org.apache.solr.request.SimpleFacets
 
req - Variable in class org.apache.solr.response.TextResponseWriter
 
req - Variable in class org.apache.solr.search.QParser
 
req - Variable in class org.apache.solr.search.SolrCoreParser
 
req - Variable in class org.apache.solr.search.SolrQueryBuilder
 
req - Variable in class org.apache.solr.servlet.HttpSolrCall
 
req - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
req - Variable in class org.apache.solr.update.SolrCmdDistributor.SolrError
NOTE: This is the request that happened to be executed when this error was triggered the error, but because of how StreamingSolrClients uses ConcurrentUpdateSolrClient it might not actaully be the request that caused the error -- multiple requests are merged & processed as a sequential batch.
req - Variable in class org.apache.solr.update.UpdateCommand
 
Req(UpdateCommand, SolrCmdDistributor.Node, UpdateRequest, boolean) - Constructor for class org.apache.solr.update.SolrCmdDistributor.Req
 
Req(UpdateCommand, SolrCmdDistributor.Node, UpdateRequest, boolean, DistributedUpdateProcessor.RollupRequestReplicationTracker, DistributedUpdateProcessor.LeaderRequestReplicationTracker) - Constructor for class org.apache.solr.update.SolrCmdDistributor.Req
 
ReqHandlerToApi(SolrRequestHandler, SpecProvider) - Constructor for class org.apache.solr.api.ApiBag.ReqHandlerToApi
 
request(String, String) - Method in class org.apache.solr.servlet.DirectSolrConnection
For example:
request(String, SolrParams, String) - Method in class org.apache.solr.servlet.DirectSolrConnection
 
request(SolrRequest<?>, String) - Method in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
 
request(SolrRequest<?>, String) - Method in class org.apache.solr.util.MockSearchableSolrClient
 
request(SolrRequestHandler, SolrParams, String) - Method in class org.apache.solr.servlet.DirectSolrConnection
 
REQUEST_TIMER_SERVLET_ATTRIBUTE - Static variable in class org.apache.solr.servlet.SolrRequestParsers
 
REQUEST_TYPE - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
requestApplyCoreUpdates(PayloadObj<RequestApplyCoreUpdatesPayload>) - Method in class org.apache.solr.handler.admin.api.RequestApplyCoreUpdatesAPI
 
RequestApplyCoreUpdatesAPI - Class in org.apache.solr.handler.admin.api
Internal V2 API used to apply updates to a core.
RequestApplyCoreUpdatesAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.RequestApplyCoreUpdatesAPI
 
REQUESTAPPLYUPDATES_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
requestBufferUpdates(PayloadObj<RequestBufferUpdatesPayload>) - Method in class org.apache.solr.handler.admin.api.RequestBufferUpdatesAPI
 
REQUESTBUFFERUPDATES_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
RequestBufferUpdatesAPI - Class in org.apache.solr.handler.admin.api
Internal V2 API used to start update-buffering on the specified core.
RequestBufferUpdatesAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.RequestBufferUpdatesAPI
 
requestCollectionMetrics(SolrCollection, Set<ReplicaMetric<?>>) - Method in interface org.apache.solr.cluster.placement.AttributeFetcher
Request collection-level metrics.
requestCollectionMetrics(SolrCollection, Set<ReplicaMetric<?>>) - Method in class org.apache.solr.cluster.placement.impl.AttributeFetcherImpl
 
RequestContextBasedFactory() - Constructor for class org.apache.solr.jersey.InjectionFactories.RequestContextBasedFactory
 
RequestContextKeys - Interface in org.apache.solr.jersey
Keys used to store and retrieve values from the Jersey request context.
requestCoreRecovery(PayloadObj<RequestCoreRecoveryPayload>) - Method in class org.apache.solr.handler.admin.api.RequestCoreRecoveryAPI
 
RequestCoreRecoveryAPI - Class in org.apache.solr.handler.admin.api
Internal V2 API triggering recovery on a core.
RequestCoreRecoveryAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.RequestCoreRecoveryAPI
 
RequestHandlerBase - Class in org.apache.solr.handler
Base class for all request handlers.
RequestHandlerBase() - Constructor for class org.apache.solr.handler.RequestHandlerBase
 
RequestHandlerBase.HandlerMetrics - Class in org.apache.solr.handler
Metrics for this handler.
RequestHandlers - Class in org.apache.solr.core
 
RequestHandlers(SolrCore) - Constructor for class org.apache.solr.core.RequestHandlers
 
RequestHandlerUtils - Class in org.apache.solr.handler
Common helper functions for RequestHandlers
RequestHandlerUtils() - Constructor for class org.apache.solr.handler.RequestHandlerUtils
 
REQUESTID - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
RequestMetricHandling - Class in org.apache.solr.jersey
A request and response filter used to initialize and report per-request metrics.
RequestMetricHandling() - Constructor for class org.apache.solr.jersey.RequestMetricHandling
 
RequestMetricHandling.PostRequestMetricsFilter - Class in org.apache.solr.jersey
Adjusts post-request metrics (timing, etc.)for individual Jersey requests.
RequestMetricHandling.PreRequestMetricsFilter - Class in org.apache.solr.jersey
Sets up the metrics-context for individual requests
requestNodeMetric(NodeMetric<?>) - Method in interface org.apache.solr.cluster.placement.AttributeFetcher
Request a node metric from each node.
requestNodeMetric(NodeMetric<?>) - Method in class org.apache.solr.cluster.placement.impl.AttributeFetcherImpl
 
requestNodeSystemProperty(String) - Method in interface org.apache.solr.cluster.placement.AttributeFetcher
Request a given system property on each node.
requestNodeSystemProperty(String) - Method in class org.apache.solr.cluster.placement.impl.AttributeFetcherImpl
 
RequestParams - Class in org.apache.solr.core
The class encapsulates the request time parameters .
RequestParams(Map<String, Object>, int) - Constructor for class org.apache.solr.core.RequestParams
 
RequestParams.ParamSet - Class in org.apache.solr.core
 
RequestParams.VersionedParams - Class in org.apache.solr.core
 
RequestRateLimiter - Class in org.apache.solr.servlet
Handles rate limiting for a specific request type.
RequestRateLimiter(RateLimiterConfig) - Constructor for class org.apache.solr.servlet.RequestRateLimiter
 
requestRecoveries() - Method in class org.apache.solr.cloud.SyncStrategy
 
REQUESTRECOVERY_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
requests - Variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
requests - Variable in class org.apache.solr.security.AuthenticationPlugin
 
REQUESTSTATUS_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
REQUESTSTATUS_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
requestStatusMap - Variable in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
requestSyncShard(PayloadObj<RequestSyncShardPayload>) - Method in class org.apache.solr.handler.admin.api.RequestSyncShardAPI
 
REQUESTSYNCSHARD_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
RequestSyncShardAPI - Class in org.apache.solr.handler.admin.api
Internal V2 API used to request a core sync with its shard leader.
RequestSyncShardAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.RequestSyncShardAPI
 
requestTime - Variable in class org.apache.solr.cloud.Stats.Stat
 
requestTimes - Variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
requestTimes - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
requestTimes - Variable in class org.apache.solr.security.AuthenticationPlugin
 
requestType - Variable in class org.apache.solr.core.RateLimiterConfig
 
requestType - Variable in class org.apache.solr.servlet.HttpSolrCall
 
RequestUtil - Class in org.apache.solr.request.json
 
RequestUtil() - Constructor for class org.apache.solr.request.json.RequestUtil
 
REQUIRE_CLASS - org.apache.solr.core.SolrConfig.PluginOpts
 
REQUIRE_NAME - org.apache.solr.core.SolrConfig.PluginOpts
 
REQUIRE_NAME_IN_OVERLAY - org.apache.solr.core.SolrConfig.PluginOpts
 
required - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
REQUIRED - Static variable in class org.apache.solr.schema.FieldProperties
 
REQUIRED - Static variable in class org.apache.solr.schema.IndexSchema
 
REQUIRED_ROUTER_PARAMS - Static variable in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
Parameters required for creating a category routed alias
REQUIRED_ROUTER_PARAMS - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
Parameters required for creating a routed alias
REQUIRED_TERM_FLAG - Static variable in class org.apache.solr.spelling.QueryConverter
This term is marked required in the query with the plus sign.
requiredFields - Variable in class org.apache.solr.schema.IndexSchema
 
requireSchemaVersionFromClient(SolrQueryRequest) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
requiresTransactionLog() - Method in class org.apache.solr.cloud.CloudDescriptor
 
RERANK_DOCS - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_DOCS_DEFAULT - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_MAIN_SCALE - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_OPERATOR - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_OPERATOR_DEFAULT - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_QUERY - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_SCALE - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_WEIGHT - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
RERANK_WEIGHT_DEFAULT - Static variable in class org.apache.solr.search.ReRankQParserPlugin
 
ReRankCollector - Class in org.apache.solr.search
 
ReRankCollector(int, int, Rescorer, QueryCommand, IndexSearcher, Set<BytesRef>) - Constructor for class org.apache.solr.search.ReRankCollector
 
ReRankCollector(int, int, Rescorer, QueryCommand, IndexSearcher, Set<BytesRef>, ReRankScaler, ReRankOperator) - Constructor for class org.apache.solr.search.ReRankCollector
 
ReRankCollector.BoostedComp - Class in org.apache.solr.search
 
reRankDocs - Variable in class org.apache.solr.search.AbstractReRankQuery
 
reRankOperator - Variable in class org.apache.solr.search.AbstractReRankQuery
 
reRankOperator - Variable in class org.apache.solr.search.ReRankScaler
 
ReRankOperator - Enum in org.apache.solr.search
 
ReRankQParserPlugin - Class in org.apache.solr.search
 
ReRankQParserPlugin() - Constructor for class org.apache.solr.search.ReRankQParserPlugin
 
reRankQueryMax - Variable in class org.apache.solr.search.ReRankScaler
 
reRankQueryMin - Variable in class org.apache.solr.search.ReRankScaler
 
reRankQueryRescorer - Variable in class org.apache.solr.search.AbstractReRankQuery
 
reRankScale() - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
reRankScaler - Variable in class org.apache.solr.search.AbstractReRankQuery
 
ReRankScaler - Class in org.apache.solr.search
 
ReRankScaler(String, String, double, ReRankOperator, QueryRescorer, boolean) - Constructor for class org.apache.solr.search.ReRankScaler
 
ReRankScaler.MinMaxExplain - Class in org.apache.solr.search
 
ReRankScaler.ReRankScalerExplain - Class in org.apache.solr.search
 
reRankScalerExplain - Variable in class org.apache.solr.search.ReRankScaler
 
ReRankScalerExplain(String, String) - Constructor for class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
ReRankWeight - Class in org.apache.solr.search
A Weight used by reranking queries.
ReRankWeight(Query, Rescorer, IndexSearcher, Weight, ReRankScaler, ReRankOperator) - Constructor for class org.apache.solr.search.ReRankWeight
 
RESERVE - Static variable in class org.apache.solr.handler.ReplicationHandler
 
RESERVOIR - Static variable in class org.apache.solr.metrics.MetricSuppliers
Implementation class, must implement Reservoir.
RESERVOIR_EDR_ALPHA - Static variable in class org.apache.solr.metrics.MetricSuppliers
Alpha parameter of ExponentiallyDecayingReservoir.
RESERVOIR_SIZE - Static variable in class org.apache.solr.metrics.MetricSuppliers
Size of reservoir.
RESERVOIR_WINDOW - Static variable in class org.apache.solr.metrics.MetricSuppliers
Time window in seconds of SlidingTimeWindowReservoir.
reset() - Method in class org.apache.solr.analysis.LowerCaseTokenizer
Deprecated.
 
reset() - Method in class org.apache.solr.analysis.ReversedWildcardFilter
 
reset() - Method in class org.apache.solr.cloud.ActionThrottle
 
reset() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.ListBasedTokenStream
 
reset() - Method in class org.apache.solr.handler.export.IntValue
 
reset() - Method in class org.apache.solr.handler.export.LongValue
 
reset() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
 
reset() - Method in class org.apache.solr.logging.LogWatcher
 
reset() - Static method in class org.apache.solr.logging.MDCLoggingContext
Resets to a cleared state.
reset() - Method in class org.apache.solr.metrics.SolrMetricManager.PrefixFilter
Clear the set of names that matched.
reset() - Method in class org.apache.solr.metrics.SolrMetricManager.RegexFilter
Clear the set of names that matched.
reset() - Static method in class org.apache.solr.request.SolrRequestInfo
This reset method is more of a protection mechanism as we expect it to be empty by now because all "set" calls need to be balanced with a "clear".
reset() - Method in class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
reset() - Method in class org.apache.solr.search.facet.SlotAcc.IntSlotAcc
 
reset() - Method in class org.apache.solr.search.facet.SlotAcc.LongFuncSlotAcc
 
reset() - Method in class org.apache.solr.search.facet.SlotAcc
Called to reset the acc to a fresh state, ready for reuse
reset() - Method in class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
reset() - Static method in class org.apache.solr.search.SolrQueryTimeoutImpl
Cleanup the ThreadLocal timeout value.
reset() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
reset() - Static method in class org.apache.solr.util.TestInjection
 
reset(int[], int) - Method in interface org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttribute
 
reset(int[], int) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
resetBuf() - Method in class org.apache.solr.util.RecordingJSONParser
 
resetCache() - Static method in class org.apache.solr.search.function.FileFloatSource
Remove all cached entries.
resetIterators() - Method in class org.apache.solr.search.facet.SlotAcc
Typically called from setNextReader to reset docValue iterators
resetPendingUpdateCounters() - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
 
resetValue() - Method in class org.apache.solr.handler.export.IntComp.IntAsc
 
resetValue() - Method in class org.apache.solr.handler.export.IntComp.IntDesc
 
resetValue() - Method in interface org.apache.solr.handler.export.IntComp
 
resize(double[], double) - Method in class org.apache.solr.search.facet.SlotAcc.Resizer
 
resize(int) - Method in class org.apache.solr.logging.CircularList
 
resize(int) - Method in class org.apache.solr.util.LongPriorityQueue
 
resize(int[], int) - Method in class org.apache.solr.search.facet.SlotAcc.Resizer
 
resize(long[], long) - Method in class org.apache.solr.search.facet.SlotAcc.Resizer
 
resize(FixedBitSet) - Method in class org.apache.solr.search.facet.SlotAcc.Resizer
 
resize(SlotAcc.Resizer) - Method in class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
resize(SlotAcc.Resizer) - Method in class org.apache.solr.search.facet.SlotAcc.IntSlotAcc
 
resize(SlotAcc.Resizer) - Method in class org.apache.solr.search.facet.SlotAcc.LongFuncSlotAcc
 
resize(SlotAcc.Resizer) - Method in class org.apache.solr.search.facet.SlotAcc
 
resize(SlotAcc.Resizer) - Method in class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
resize(T[], T) - Method in class org.apache.solr.search.facet.SlotAcc.Resizer
 
Resizer() - Constructor for class org.apache.solr.search.facet.SlotAcc.Resizer
 
resolve(Object, JavaBinCodec) - Method in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
resolve(String, Map<String, String>, Map<String, String>, Map<String, String>) - Static method in class org.apache.solr.packagemanager.PackageUtils
Replace a templatized string with parameter substituted string.
resolve(URI, String...) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method resolves a URI using the specified path components (as method arguments).
resolve(URI, String...) - Method in class org.apache.solr.core.backup.repository.LocalFileSystemRepository
 
resolveAndValidateAliasIfEnabled(String, boolean) - Method in class org.apache.solr.handler.admin.api.AdminAPIBase
 
resolveClassName() - Static method in interface org.apache.solr.api.ClusterPluginsSource
Resolves the name of the class that will be used to provide cluster plugins.
resolveCollectionListOrAlias(String) - Method in class org.apache.solr.servlet.HttpSolrCall
Resolves the parameter as a potential comma delimited list of collections, and resolves aliases too.
resolveCollectionName(String, boolean) - Method in class org.apache.solr.handler.admin.api.AdminAPIBase
 
Resolved() - Constructor for class org.apache.solr.update.processor.TemplateUpdateProcessorFactory.Resolved
 
resolveDirectory(URI, String...) - Method in interface org.apache.solr.core.backup.repository.BackupRepository
This method resolves a directory URI using the specified path components (as method arguments).
resolveDocCollection(String) - Method in class org.apache.solr.api.V2HttpCall
Lookup the collection from the collection string (maybe comma delimited).
resolveEntity(String, String) - Method in class org.apache.solr.util.SystemIdResolver
 
resolveEntity(String, String, String, String) - Method in class org.apache.solr.util.SystemIdResolver
 
resolveModulesFromStringOrSyspropOrEnv(String) - Static method in class org.apache.solr.util.ModuleUtils
Parses comma separated string of module names, in practice found in solr.xml.
resolvePath(File, String) - Static method in class org.apache.solr.util.FileUtils
Resolves a path relative a base directory.
resolver - Static variable in class org.apache.solr.update.TransactionLog
 
Resolver(SolrQueryRequest, ReturnFields) - Constructor for class org.apache.solr.response.BinaryResponseWriter.Resolver
 
resolveResourceId(String) - Static method in class org.apache.solr.rest.RestManager.ManagedEndpoint
Determines the ManagedResource resourceId from the request path.
resolveSolrUrl(CommandLine) - Static method in class org.apache.solr.cli.SolrCLI
Get the base URL of a live Solr instance from either the solrUrl command-line option or from ZooKeeper.
resource - Variable in class org.apache.solr.util.RefCounted
 
RESOURCE - Static variable in class org.apache.solr.core.RequestParams
 
RESOURCE_LOADER_AUTHORITY_ABSOLUTE - Static variable in class org.apache.solr.util.SystemIdResolver
 
RESOURCE_LOADER_URI_SCHEME - Static variable in class org.apache.solr.util.SystemIdResolver
 
RESOURCE_NAME - Static variable in class org.apache.solr.core.ConfigOverlay
 
RESOURCE_TO_RH_MAPPING - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
resourceContext - Variable in class org.apache.solr.jersey.CatchAllExceptionMapper
 
resourceContext - Variable in class org.apache.solr.jersey.MessageBodyWriters.BaseMessageBodyWriter
 
resourceContext - Variable in class org.apache.solr.jersey.NotFoundExceptionMapper
 
resourceLoader - Variable in class org.apache.solr.core.PluginBag.LazyPluginHolder
 
resourceLoader - Variable in class org.apache.solr.index.MergePolicyFactory
 
resourceLoader - Variable in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
resourceLocation(String) - Method in class org.apache.solr.core.SolrResourceLoader
Report the location of a resource found by the resource loader
ResourceModifiedInZkException(SolrException.ErrorCode, String) - Constructor for exception org.apache.solr.cloud.ZkController.ResourceModifiedInZkException
 
resourceName - Variable in class org.apache.solr.schema.IndexSchema
 
resp - Variable in class org.apache.solr.cloud.Stats.FailedOp
 
respectMinCount(long) - Method in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
response - Variable in class org.apache.solr.servlet.HttpSolrCall
 
Response() - Constructor for class org.apache.solr.update.SolrCmdDistributor.Response
 
RESPONSE_HEADER_KEY - Static variable in class org.apache.solr.response.SolrQueryResponse
 
RESPONSE_HEADER_PARTIAL_RESULTS_KEY - Static variable in class org.apache.solr.response.SolrQueryResponse
 
RESPONSE_HEADER_SEGMENT_TERMINATED_EARLY_KEY - Static variable in class org.apache.solr.response.SolrQueryResponse
 
RESPONSE_KEY - Static variable in class org.apache.solr.handler.component.SpatialHeatmapFacets
 
RESPONSE_MESSAGE - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler
 
RESPONSE_STATUS - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler
 
ResponseBuilder - Class in org.apache.solr.handler.component
This class is experimental and will be changing in the future.
ResponseBuilder(SolrQueryRequest, SolrQueryResponse, List<SearchComponent>) - Constructor for class org.apache.solr.handler.component.ResponseBuilder
 
ResponseLogComponent - Class in org.apache.solr.handler.component
Adds to the log file the document IDs that are sent in the query response.
ResponseLogComponent() - Constructor for class org.apache.solr.handler.component.ResponseLogComponent
 
responseMsg - Variable in class org.apache.solr.update.processor.IgnoreCommitOptimizeUpdateProcessorFactory
 
responses - Variable in class org.apache.solr.handler.component.ShardRequest
list of responses...
ResponseUtils - Class in org.apache.solr.servlet
Response helper methods.
RestManager - Class in org.apache.solr.rest
Supports runtime mapping of REST API endpoints to ManagedResource implementations; endpoints can be registered at either the /schema or /config base paths, depending on which base path is more appropriate for the type of managed resource.
RestManager() - Constructor for class org.apache.solr.rest.RestManager
 
RestManager.ManagedEndpoint - Class in org.apache.solr.rest
Request handling needs a lightweight object to delegate a request to.
RestManager.Registry - Class in org.apache.solr.rest
Per-core registry of ManagedResources found during core initialization.
RESTORE_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
RestoreCmd - Class in org.apache.solr.cloud.api.collections
 
RestoreCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.RestoreCmd
 
restoreCollection(String, RestoreCollectionAPI.RestoreCollectionRequestBody) - Method in class org.apache.solr.handler.admin.api.RestoreCollectionAPI
 
RestoreCollectionAPI - Class in org.apache.solr.handler.admin.api
V2 API for restoring data into a collection
RestoreCollectionAPI(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.RestoreCollectionAPI
 
RestoreCollectionAPI.RestoreCollectionRequestBody - Class in org.apache.solr.handler.admin.api
Request body for the v2 "restore collection" API.
RestoreCollectionRequestBody() - Constructor for class org.apache.solr.handler.admin.api.RestoreCollectionAPI.RestoreCollectionRequestBody
 
restoreCore(String, RestoreCoreRequestBody) - Method in class org.apache.solr.handler.admin.api.RestoreCore
 
RestoreCore - Class in org.apache.solr.handler.admin.api
V2 API implementation for restoring a previously taken backup to a core
RestoreCore - Class in org.apache.solr.handler
 
RestoreCore(CoreContainer, SolrQueryRequest, SolrQueryResponse, CoreAdminHandler.CoreAdminAsyncTracker) - Constructor for class org.apache.solr.handler.admin.api.RestoreCore
 
RESTORECORE_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
restrictProps(int) - Method in class org.apache.solr.schema.FieldType
:TODO: document this method
result - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationResponse
 
result - Variable in class org.apache.solr.search.facet.SlotAcc.DoubleFuncSlotAcc
 
result - Variable in class org.apache.solr.search.facet.SlotAcc.IntSlotAcc
 
result - Variable in class org.apache.solr.search.facet.SlotAcc.LongFuncSlotAcc
 
result() - Method in interface org.apache.solr.search.grouping.Command
Returns the results that the collectors created by Command.create() contain after a search has been executed.
result() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand
 
result() - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand
 
result() - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand
 
ResultContext - Class in org.apache.solr.response
A class to hold the QueryResult and the Query
ResultContext() - Constructor for class org.apache.solr.response.ResultContext
 
ResultEntry - Class in org.apache.solr.spelling
 
resultIds - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
resume() - Method in class org.apache.solr.util.RTimer
 
retries - Variable in class org.apache.solr.update.SolrCmdDistributor.Req
 
retrieve(ScoreDoc) - Method in interface org.apache.solr.search.grouping.endresulttransformer.EndResultTransformer.SolrDocumentSource
 
retrievedDocuments - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
retrieveStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
retrieveStatsRequest(ResponseBuilder) - Method in class org.apache.solr.search.stats.StatsCache
Creates a ShardRequest to retrieve per-shard stats related to the current query and the current state of the requester's StatsCache.
retry - Variable in class org.apache.solr.servlet.HttpSolrCall
 
RETRY - org.apache.solr.servlet.SolrDispatchFilter.Action
 
retryOnConnLoss - Variable in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
RETURN - org.apache.solr.servlet.SolrDispatchFilter.Action
 
returnFields - Variable in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
returnFields - Variable in class org.apache.solr.response.SolrQueryResponse
 
returnFields - Variable in class org.apache.solr.response.TextResponseWriter
 
returnFields(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.QueryComponent
 
ReturnFields - Class in org.apache.solr.search
A class representing the return fields
ReturnFields() - Constructor for class org.apache.solr.search.ReturnFields
 
returnLocalStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
returnLocalStats(ResponseBuilder, SolrIndexSearcher) - Method in class org.apache.solr.search.stats.StatsCache
Prepare a local (from the local shard) response to a "retrieve stats" shard request.
returnsPartial() - Method in class org.apache.solr.search.facet.FacetRequest
Returns true if this facet can return just some of the facet buckets that match all the criteria.
ReuseFromContextIndexSchemaFactory() - Constructor for class org.apache.solr.jersey.InjectionFactories.ReuseFromContextIndexSchemaFactory
 
ReuseFromContextSolrCoreFactory() - Constructor for class org.apache.solr.jersey.InjectionFactories.ReuseFromContextSolrCoreFactory
 
ReuseFromContextSolrParamsFactory() - Constructor for class org.apache.solr.jersey.InjectionFactories.ReuseFromContextSolrParamsFactory
 
reverse(char[], int, int) - Static method in class org.apache.solr.analysis.ReversedWildcardFilter
Partially reverses the given input buffer in-place from the given offset up to the given length, keeping surrogate pairs in the correct (non-reversed) order.
REVERSE_WILDCARD_LOWER_BOUND - Static variable in class org.apache.solr.parser.SolrQueryParserBase
 
ReversedWildcardFilter - Class in org.apache.solr.analysis
This class produces a special form of reversed tokens, suitable for better handling of leading wildcards.
ReversedWildcardFilterFactory - Class in org.apache.solr.analysis
Factory for ReversedWildcardFilter-s.
ReversedWildcardFilterFactory() - Constructor for class org.apache.solr.analysis.ReversedWildcardFilterFactory
Default ctor for compatibility with SPI
ReversedWildcardFilterFactory(Map<String, String>) - Constructor for class org.apache.solr.analysis.ReversedWildcardFilterFactory
Creates a new ReversedWildcardFilterFactory
ReverseOrdFieldSource - Class in org.apache.solr.search.function
Obtains the ordinal of the field value from LeafReader.getSortedDocValues(java.lang.String) and reverses the order.
ReverseOrdFieldSource(String) - Constructor for class org.apache.solr.search.function.ReverseOrdFieldSource
 
ReverseReader() - Constructor for class org.apache.solr.update.TransactionLog.ReverseReader
 
rewrite(IndexReader) - Method in class org.apache.solr.query.FilterQuery
 
rewrite(IndexReader) - Method in class org.apache.solr.query.SolrRangeQuery
 
rewrite(IndexReader) - Method in class org.apache.solr.search.AbstractReRankQuery
 
rewrite(IndexReader) - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
rewrite(IndexReader) - Method in class org.apache.solr.search.MatchCostQuery
 
rewrite(IndexReader) - Method in class org.apache.solr.search.WrappedQuery
 
rewrite(Query) - Method in class org.apache.solr.search.AbstractReRankQuery
 
REWRITE - org.apache.solr.update.SolrIndexSplitter.SplitMethod
 
rewriteSort(SortSpec, IndexSearcher) - Static method in class org.apache.solr.search.CollapsingQParserPlugin
Helper method for rewriting the Sort associated with a SortSpec.
RL_CONFIG_KEY - Static variable in class org.apache.solr.core.RateLimiterConfig
 
role - Variable in class org.apache.solr.handler.ClusterAPI.RoleInfo
 
RoleInfo() - Constructor for class org.apache.solr.handler.ClusterAPI.RoleInfo
 
roleName - Variable in enum org.apache.solr.core.NodeRoles.Role
 
roles(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
rolesForNode(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
rollback() - Method in class org.apache.solr.update.SolrIndexWriter
 
rollback(RollbackUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
rollback(RollbackUpdateCommand) - Method in class org.apache.solr.update.UpdateHandler
 
ROLLBACK - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
rollbackIndexWriter(SolrCore) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
rollbackIndexWriter(SolrCore) - Method in class org.apache.solr.update.SolrCoreState
Rollback the current IndexWriter.
RollbackUpdateCommand - Class in org.apache.solr.update
 
RollbackUpdateCommand(SolrQueryRequest) - Constructor for class org.apache.solr.update.RollbackUpdateCommand
 
rollbackWriter() - Method in class org.apache.solr.update.DirectUpdateHandler2
 
RollupRequestReplicationTracker() - Constructor for class org.apache.solr.update.processor.DistributedUpdateProcessor.RollupRequestReplicationTracker
 
ROOT_FIELD_NAME - Static variable in class org.apache.solr.schema.IndexSchema
 
ROOT_NAME - Static variable in class org.apache.solr.logging.LoggerInfo
 
ROOT_WITH_CHILDREN - org.apache.solr.handler.component.RealTimeGetComponent.Resolution
Resolves the whole nested hierarchy (look up root doc).
roundTo5Digits(double) - Static method in class org.apache.solr.search.facet.RelatednessAgg
Helper function for rounding/truncating relatedness & popularity values to 5 decimal digits, since these values are all probabilistic more then 5 digits aren't really relevant and may give a missleading impression of added precision.
route - Variable in class org.apache.solr.update.UpdateCommand
 
ROUTED_ALIAS_NAME_CORE_PROP - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
ROUTED_BY_JOIN_KEY - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
RoutedAlias - Class in org.apache.solr.cloud.api.collections
 
RoutedAlias() - Constructor for class org.apache.solr.cloud.api.collections.RoutedAlias
 
RoutedAlias.Action - Class in org.apache.solr.cloud.api.collections
 
RoutedAliasProperties() - Constructor for class org.apache.solr.handler.admin.api.CreateAliasAPI.RoutedAliasProperties
 
RoutedAliasUpdateProcessor - Class in org.apache.solr.update.processor
Distributes update requests to a series of collections partitioned by a "routing" field.
routedByJoinKey - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
routeFieldName - Variable in class org.apache.solr.update.SplitIndexCommand
 
router - Variable in class org.apache.solr.update.SplitIndexCommand
 
ROUTER_AUTO_DELETE_AGE - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
ROUTER_FIELD - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
ROUTER_INTERVAL - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
ROUTER_MAX_CARDINALITY - Static variable in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
ROUTER_MAX_FUTURE - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
ROUTER_MUST_MATCH - Static variable in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
ROUTER_PREEMPTIVE_CREATE_MATH - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
ROUTER_START - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
ROUTER_TYPE_NAME - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
routers - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.CreateAliasRequestBody
 
ROW_ID - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
ROW_ID_OFFSET - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
RPAREN - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
RptWithGeometrySpatialField - Class in org.apache.solr.schema
A Solr Spatial FieldType based on CompositeSpatialStrategy.
RptWithGeometrySpatialField() - Constructor for class org.apache.solr.schema.RptWithGeometrySpatialField
 
RSAKeyPair() - Constructor for class org.apache.solr.util.CryptoKeys.RSAKeyPair
Create an RSA key pair with newly generated keys.
RSAKeyPair(URL, URL) - Constructor for class org.apache.solr.util.CryptoKeys.RSAKeyPair
Initialize an RSA key pair from previously saved keys.
rsp - Variable in class org.apache.solr.handler.admin.api.CoreAdminAPIBase
 
rsp - Variable in class org.apache.solr.handler.admin.CoreAdminHandler.CallInfo
 
rsp - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
rsp - Variable in class org.apache.solr.response.TextResponseWriter
 
rsp - Variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
rsp - Variable in class org.apache.solr.update.SplitIndexCommand
 
rspInfo - Variable in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
RTimer - Class in org.apache.solr.util
A simple timer.
RTimer() - Constructor for class org.apache.solr.util.RTimer
 
RTimer.TimerImpl - Interface in org.apache.solr.util
 
RTimerTree - Class in org.apache.solr.util
A recursive timer.
RTimerTree() - Constructor for class org.apache.solr.util.RTimerTree
 
RubyResponseWriter - Class in org.apache.solr.response
 
RubyResponseWriter() - Constructor for class org.apache.solr.response.RubyResponseWriter
 
RuleBasedAuthorizationPlugin - Class in org.apache.solr.security
Original implementation of Rule Based Authz plugin which configures user/role mapping in the security.json configuration
RuleBasedAuthorizationPlugin() - Constructor for class org.apache.solr.security.RuleBasedAuthorizationPlugin
 
RuleBasedAuthorizationPluginBase - Class in org.apache.solr.security
Base class for rule based authorization plugins
RuleBasedAuthorizationPluginBase() - Constructor for class org.apache.solr.security.RuleBasedAuthorizationPluginBase
 
run() - Method in class org.apache.solr.cloud.OverseerTaskProcessor
 
run() - Method in class org.apache.solr.cloud.OverseerTaskProcessor.Runner
 
run() - Method in class org.apache.solr.cloud.RecoveryStrategy
 
run() - Method in class org.apache.solr.security.AuditLoggerPlugin
Pick next event from async queue and call AuditLoggerPlugin.audit(AuditEvent)
run() - Method in class org.apache.solr.update.CommitTracker
This is the worker part for the ScheduledFuture *
run(ClusterState, Overseer, ZkStateWriter) - Method in interface org.apache.solr.cloud.Overseer.Message
 
run(ClusterState, Overseer, ZkStateWriter) - Method in class org.apache.solr.cloud.RefreshCollectionMessage
 
runAssert(CommandLine) - Method in class org.apache.solr.cli.AssertTool
Custom run method which may return exit code
runAsync(Runnable) - Method in class org.apache.solr.core.CoreContainer
Run an arbitrary task in its own thread.
runAsync(Runnable) - Method in class org.apache.solr.core.SolrCore
Run an arbitrary task in its own thread.
runCloudExample(CommandLine) - Method in class org.apache.solr.cli.RunExampleTool
 
runCloudTool(CloudSolrClient, CommandLine) - Method in class org.apache.solr.cli.CreateCollectionTool
 
runCloudTool(CloudSolrClient, CommandLine) - Method in class org.apache.solr.cli.HealthcheckTool
 
runCollectionCommand(ZkNodeProps, CollectionParams.CollectionAction, long) - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
runCommand(String, String) - Method in class org.apache.solr.cli.PostLogsTool
 
runConfigSetCommand(SolrQueryResponse, ConfigSetParams.ConfigSetAction, Map<String, Object>) - Method in class org.apache.solr.handler.configsets.ConfigSetAPIBase
 
runConfigSetCommand(SolrQueryResponse, ConfigSetParams.ConfigSetAction, Map<String, Object>, long) - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
runExample(CommandLine, String) - Method in class org.apache.solr.cli.RunExampleTool
 
RunExampleTool - Class in org.apache.solr.cli
Supports an interactive session with the user to launch (or relaunch the -e cloud example)
RunExampleTool() - Constructor for class org.apache.solr.cli.RunExampleTool
Default constructor used by the framework when running as a command-line application.
RunExampleTool(Executor, InputStream, PrintStream) - Constructor for class org.apache.solr.cli.RunExampleTool
 
runIamLeaderProcess(ElectionContext, boolean) - Method in class org.apache.solr.cloud.LeaderElector
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ApiTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.AssertTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.AuthTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ConfigSetDownloadTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ConfigSetUploadTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ConfigTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.CreateCollectionTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.CreateCoreTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.CreateTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.DeleteTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ExportTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.HealthcheckTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.PackageTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.PostLogsTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.PostTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.RunExampleTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.StatusTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ToolBase
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.VersionTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ZkCpTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ZkLsTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ZkMkrootTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ZkMvTool
 
runImpl(CommandLine) - Method in class org.apache.solr.cli.ZkRmTool
 
runLater(String, Runnable) - Method in class org.apache.solr.pkg.PackageListeners.Listener.Ctx
If there are multiple packages to be updated and there are multiple listeners, This is executed after all of the PackageListeners.Listener.changed(SolrPackageLoader.SolrPackage, Ctx) calls are invoked.
Runner(OverseerMessageHandler, ZkNodeProps, String, OverseerTaskQueue.QueueEvent, OverseerMessageHandler.Lock) - Constructor for class org.apache.solr.cloud.OverseerTaskProcessor.Runner
 
RUNNING - org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
 
RUNNING - org.apache.solr.cloud.ClusterSingleton.State
Component is active.
RUNNING - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
runTool(CommandLine) - Method in class org.apache.solr.cli.AssertTool
 
runTool(CommandLine) - Method in class org.apache.solr.cli.AuthTool
 
runTool(CommandLine) - Method in interface org.apache.solr.cli.Tool
 
runTool(CommandLine) - Method in class org.apache.solr.cli.ToolBase
 
RunUpdateProcessorFactory - Class in org.apache.solr.update.processor
Executes the update commands using the underlying UpdateHandler.
RunUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.RunUpdateProcessorFactory
 
runWithLock(int, VersionBucket.CheckedFunction<T, R>) - Method in class org.apache.solr.update.TimedVersionBucket
This will run the function with the lock.
runWithLock(int, VersionBucket.CheckedFunction<T, R>) - Method in class org.apache.solr.update.VersionBucket
This will run the function with the intrinsic object monitor.

S

safeCheckCollectionExists(String, String) - Static method in class org.apache.solr.cli.SolrCLI
 
safeCheckCoreExists(String, String) - Static method in class org.apache.solr.cli.SolrCLI
 
SafeXMLParsing - Class in org.apache.solr.util
Some utility methods for parsing XML in a safe way.
sameUser(String) - Static method in class org.apache.solr.cli.AssertTool
 
SampleDocuments - Class in org.apache.solr.handler.designer
 
SampleDocuments(List<SolrInputDocument>, String, String) - Constructor for class org.apache.solr.handler.designer.SampleDocuments
 
SampleDocumentsLoader - Interface in org.apache.solr.handler.designer
 
saveCommitPoint(Long) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Permanently prevent this commit point from being deleted (if it has not already) using a reference count.
saxFactory - Variable in class org.apache.solr.handler.loader.XMLLoader
 
scale(float) - Method in class org.apache.solr.search.ReRankScaler.MinMaxExplain
 
scaleMainScores() - Method in class org.apache.solr.search.ReRankScaler
 
scaleMax - Variable in class org.apache.solr.search.ReRankScaler.MinMaxExplain
 
scaleMin - Variable in class org.apache.solr.search.ReRankScaler.MinMaxExplain
 
scaleReRankScores() - Method in class org.apache.solr.search.ReRankScaler
 
scaleScores() - Method in class org.apache.solr.search.ReRankScaler
 
scaleScores(ScoreDoc[], ScoreDoc[], int) - Method in class org.apache.solr.search.ReRankScaler
 
SCALING_FACTOR - Static variable in class org.apache.solr.search.RankQParserPlugin
 
scheduleCommitWithin(long) - Method in class org.apache.solr.update.CommitTracker
schedule individual commits
scheduleMaxSizeTriggeredCommitIfNeeded(LongSupplier) - Method in class org.apache.solr.update.CommitTracker
If the given current tlog size is greater than the file size upper bound, then schedule a commit
schema - Variable in class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
schema - Variable in class org.apache.solr.index.MergePolicyFactory
 
schema - Variable in class org.apache.solr.parser.SolrQueryParserBase
 
schema - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
schema - Variable in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
schema - Variable in class org.apache.solr.response.TextResponseWriter
 
schema - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
schema - Variable in class org.apache.solr.schema.CurrencyFieldType
 
schema - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
schema - Variable in class org.apache.solr.update.processor.AtomicUpdateDocumentMerger
 
SCHEMA - Static variable in class org.apache.solr.schema.IndexSchema
 
SCHEMA_BASE_PATH - Static variable in class org.apache.solr.rest.RestManager
 
SCHEMA_EDIT_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
SCHEMA_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
SCHEMA_VERSION_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
schemaAware - Variable in class org.apache.solr.schema.IndexSchema
 
SchemaAware - Interface in org.apache.solr.schema
An interface that can be extended to provide a callback mechanism for informing an IndexSchema instance of changes to it, dynamically performed at runtime.
SchemaBulkModifyAPI - Class in org.apache.solr.handler.admin.api
V2 APIs for creating, updating, or deleting individual components in a collection's schema.
SchemaBulkModifyAPI(SchemaHandler) - Constructor for class org.apache.solr.handler.admin.api.SchemaBulkModifyAPI
 
SchemaChangedInZkException(SolrException.ErrorCode, String) - Constructor for exception org.apache.solr.schema.ManagedIndexSchema.SchemaChangedInZkException
 
SchemaCodecFactory - Class in org.apache.solr.core
Per-field CodecFactory implementation, extends Lucene's and returns postings format implementations according to the schema configuration.
SchemaCodecFactory() - Constructor for class org.apache.solr.core.SchemaCodecFactory
 
SchemaDesignerAPI - Class in org.apache.solr.handler.designer
All V2 APIs that have a prefix of /api/schema-designer/
SchemaDesignerAPI(CoreContainer) - Constructor for class org.apache.solr.handler.designer.SchemaDesignerAPI
 
SchemaDesignerConstants - Interface in org.apache.solr.handler.designer
 
schemaField - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
schemaField - Variable in class org.apache.solr.search.DocValuesIteratorCache.FieldDocValuesSupplier
 
SchemaField - Class in org.apache.solr.schema
Encapsulates all information about a Field in a Solr Schema
SchemaField(String, FieldType) - Constructor for class org.apache.solr.schema.SchemaField
Create a new SchemaField with the given name and type, using all the default properties from the type.
SchemaField(String, FieldType, int, String) - Constructor for class org.apache.solr.schema.SchemaField
Create a new SchemaField with the given name and type, and with the specified properties.
SchemaField(SchemaField, String) - Constructor for class org.apache.solr.schema.SchemaField
Create a new SchemaField from an existing one by using all of the properties of the prototype except the field name.
SchemaGetDynamicFieldInfoResponse() - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaGetDynamicFieldInfoResponse
 
SchemaGetFieldInfoResponse() - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaGetFieldInfoResponse
 
SchemaGetFieldTypeInfoResponse() - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaGetFieldTypeInfoResponse
 
SchemaHandler - Class in org.apache.solr.handler
 
SchemaHandler() - Constructor for class org.apache.solr.handler.SchemaHandler
 
SchemaListCopyFieldsResponse() - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListCopyFieldsResponse
 
SchemaListDynamicFieldsResponse() - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListDynamicFieldsResponse
 
SchemaListFieldsResponse() - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListFieldsResponse
 
SchemaListFieldTypesResponse() - Constructor for class org.apache.solr.handler.admin.api.GetSchemaFieldAPI.SchemaListFieldTypesResponse
 
SchemaManager - Class in org.apache.solr.schema
A utility class to manipulate schema using the bulk mode.
SchemaManager(SolrQueryRequest) - Constructor for class org.apache.solr.schema.SchemaManager
 
SchemaManager.OpType - Enum in org.apache.solr.schema
 
SchemaSimilarityFactory - Class in org.apache.solr.search.similarities
SimilarityFactory that returns a global PerFieldSimilarityWrapper that delegates to the field type, if it's configured.
SchemaSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.SchemaSimilarityFactory
 
SchemaSuggester - Interface in org.apache.solr.handler.designer
 
schemaVersionNumber() - Method in interface org.apache.solr.util.hll.ISchemaVersion
 
SchemaWatcher(ZkIndexSchemaReader) - Constructor for class org.apache.solr.schema.ZkIndexSchemaReader.SchemaWatcher
 
SchemaXmlResponseWriter - Class in org.apache.solr.response
 
SchemaXmlResponseWriter() - Constructor for class org.apache.solr.response.SchemaXmlResponseWriter
 
SchemaXmlWriter - Class in org.apache.solr.response
 
SchemaXmlWriter(Writer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.response.SchemaXmlWriter
 
scope - Variable in class org.apache.solr.metrics.SolrMetricInfo
 
scope - Variable in class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
scope - Variable in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
score - Variable in class org.apache.solr.search.CollapsingQParserPlugin.CollapseScore
 
score() - Method in class org.apache.solr.handler.component.QueryComponent.ScoreAndDoc
 
score() - Method in interface org.apache.solr.search.DocIterator
Returns the score for the document just returned by nextDoc()
SCORE - org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelectorType
 
SCORE - Static variable in class org.apache.solr.search.join.ScoreJoinQParserPlugin
 
SCORE - Static variable in class org.apache.solr.search.SolrReturnFields
 
SCORE - Static variable in class org.apache.solr.search.SortSpecParsing
 
SCORE_COMP - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
SCORE_COMP - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
SCORE_PARAM - Static variable in class org.apache.solr.schema.AbstractSpatialFieldType
A local-param with one of "none" (default), "distance", "recipDistance" or supported values in (DistanceUnits.getSupportedUnits().
ScoreAugmenter - Class in org.apache.solr.response.transform
Simple Augmenter that adds the score
ScoreAugmenter(String) - Constructor for class org.apache.solr.response.transform.ScoreAugmenter
 
ScoreJoinQParserPlugin - Class in org.apache.solr.search.join
Create a query-time join query with scoring.
ScoreJoinQParserPlugin() - Constructor for class org.apache.solr.search.join.ScoreJoinQParserPlugin
 
scoreMode() - Method in class org.apache.solr.search.CancellableCollector
 
scoreMode() - Method in class org.apache.solr.search.DelegatingCollector
 
scoreMode() - Method in class org.apache.solr.search.DocSetCollector
 
scoreMode() - Method in class org.apache.solr.search.join.MultiValueTermOrdinalCollector
 
scoreMode() - Method in class org.apache.solr.search.MaxScoreCollector
 
scoreMode() - Method in class org.apache.solr.search.ReRankCollector
 
ScoreOrderFragmentsBuilder - Class in org.apache.solr.highlight
 
ScoreOrderFragmentsBuilder() - Constructor for class org.apache.solr.highlight.ScoreOrderFragmentsBuilder
 
scorer - Variable in class org.apache.solr.search.DelegatingCollector
 
scorer(LeafReaderContext) - Method in class org.apache.solr.search.join.GraphQuery.GraphQueryWeight
 
scratch - Variable in class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
 
script - Variable in class org.apache.solr.cli.RunExampleTool
 
sd - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
search(List<LeafReaderContext>, Weight, Collector) - Method in class org.apache.solr.search.SolrIndexSearcher
 
search(QueryResult, QueryCommand) - Method in class org.apache.solr.search.SolrIndexSearcher
 
SEARCH - org.apache.solr.security.AuditEvent.RequestType
 
SearchComponent - Class in org.apache.solr.handler.component
TODO!
SearchComponent() - Constructor for class org.apache.solr.handler.component.SearchComponent
 
searchEnabled - Variable in class org.apache.solr.core.SolrCore
 
searcher - Variable in class org.apache.solr.request.SimpleFacets
Searcher to use for all calculations
searcher() - Method in class org.apache.solr.search.QueryContext
 
SEARCHER - org.apache.solr.core.SolrInfoBean.Category
 
searcherHolder - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
searchersReserveCommitPoints() - Method in class org.apache.solr.core.DirectoryFactory
If your implementation can count on delete-on-last-close semantics or throws an exception when trying to remove a file in use, return false (eg NFS).
SearchGroupsFieldCommand - Class in org.apache.solr.search.grouping.distributed.command
Creates all the collectors needed for the first phase and how to handle the results.
SearchGroupsFieldCommand.Builder - Class in org.apache.solr.search.grouping.distributed.command
 
SearchGroupsFieldCommandResult - Class in org.apache.solr.search.grouping.distributed.command
Encapsulates the result of a SearchGroupsFieldCommand command
SearchGroupsFieldCommandResult(Integer, Collection<SearchGroup<BytesRef>>) - Constructor for class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommandResult
 
SearchGroupShardResponseProcessor - Class in org.apache.solr.search.grouping.distributed.responseprocessor
Concrete implementation for merging SearchGroup instances from shard responses.
SearchGroupShardResponseProcessor() - Constructor for class org.apache.solr.search.grouping.distributed.responseprocessor.SearchGroupShardResponseProcessor
 
SearchGroupsRequestFactory - Class in org.apache.solr.search.grouping.distributed.requestfactory
Concrete implementation of ShardRequestFactory that creates ShardRequest instances for getting the search groups from all shards.
SearchGroupsRequestFactory() - Constructor for class org.apache.solr.search.grouping.distributed.requestfactory.SearchGroupsRequestFactory
 
SearchGroupsResultTransformer - Class in org.apache.solr.search.grouping.distributed.shardresultserializer
Implementation for transforming SearchGroup into a NamedList structure and visa versa.
SearchGroupsResultTransformer(SolrIndexSearcher) - Constructor for class org.apache.solr.search.grouping.distributed.shardresultserializer.SearchGroupsResultTransformer
 
searchGroupToShards - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
SearchHandler - Class in org.apache.solr.handler.component
Refer SOLR-281
SearchHandler() - Constructor for class org.apache.solr.handler.component.SearchHandler
 
searchNearestVectors(String, byte[], KnnCollector, Bits) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
searchNearestVectors(String, float[], KnnCollector, Bits) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
SECURITY - org.apache.solr.core.SolrInfoBean.Category
 
SECURITY_EDIT_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
SECURITY_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
securityConfEdited() - Method in class org.apache.solr.handler.admin.SecurityConfHandler
Hook where you can do stuff after a config has been edited.
securityConfEdited() - Method in class org.apache.solr.handler.admin.SecurityConfHandlerLocal
 
securityConfHandler - Variable in class org.apache.solr.core.CoreContainer
 
SecurityConfHandler - Class in org.apache.solr.handler.admin
 
SecurityConfHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.SecurityConfHandler
 
SecurityConfHandler.SecurityConfig - Class in org.apache.solr.handler.admin
Object to hold security.json as nested Map<String,Object> and optionally its version.
SecurityConfHandlerLocal - Class in org.apache.solr.handler.admin
Security Configuration Handler which works on standalone local files
SecurityConfHandlerLocal(CoreContainer) - Constructor for class org.apache.solr.handler.admin.SecurityConfHandlerLocal
 
SecurityConfHandlerZk - Class in org.apache.solr.handler.admin
Security Configuration Handler which works with Zookeeper
SecurityConfHandlerZk(CoreContainer) - Constructor for class org.apache.solr.handler.admin.SecurityConfHandlerZk
 
SecurityConfig() - Constructor for class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
 
securityJsonPath - Variable in class org.apache.solr.handler.admin.SecurityConfHandlerLocal
 
securityNodeChanged() - Method in class org.apache.solr.core.CoreContainer
 
SecurityPluginHolder<T> - Class in org.apache.solr.security
 
SecurityPluginHolder(int, T) - Constructor for class org.apache.solr.security.SecurityPluginHolder
 
seek(long) - Method in class org.apache.solr.update.TransactionLog.ChannelFastInputStream
 
SEGMENTS_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
SegmentsInfoRequestHandler - Class in org.apache.solr.handler.admin
This handler exposes information about last commit generation segments
SegmentsInfoRequestHandler() - Constructor for class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
SELECT_ALL_FIELDS - Static variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
Singleton indicating all fields should be mutated
SELECT_NO_FIELDS - Static variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
Singleton indicating no fields should be mutated
selector - Variable in class org.apache.solr.cloud.OverseerTaskProcessor
 
SelectorParams() - Constructor for class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
 
selectorText - Variable in class org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelector
The param value for this selector whose meaning depends on type.
selectOverseerMessageHandler(ZkNodeProps) - Method in interface org.apache.solr.cloud.OverseerTaskProcessor.OverseerMessageHandlerSelector
 
SEND_VERSION - Static variable in class org.apache.solr.security.PKIAuthenticationPlugin
 
sendError(int, String) - Method in class org.apache.solr.servlet.HttpSolrCall
 
sendError(Throwable) - Method in class org.apache.solr.servlet.HttpSolrCall
 
sendGlobalStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
sendGlobalStats(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.search.stats.StatsCache
Prepare global stats data to be sent out to shards in this request.
sendNotModified(HttpServletResponse) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
 
sendPreconditionFailed(HttpServletResponse) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
 
sendQuitToOverseer(String) - Method in class org.apache.solr.cloud.Overseer
This method enqueues a QUIT message to the overseer of given id.
sendRemoteQuery() - Method in class org.apache.solr.servlet.HttpSolrCall
 
sendShardRequest(String, ModifiableSolrParams, ShardHandler) - Method in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils.ShardRequestTracker
 
sendShardRequest(String, ModifiableSolrParams, ShardHandler, String, ZkStateReader) - Method in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils.ShardRequestTracker
 
sentinel - Variable in class org.apache.solr.util.LongPriorityQueue
 
SEPARATOR - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
SEPARATOR - Static variable in class org.apache.solr.search.TermsQParserPlugin
The separator to use in the underlying suggester
SEPARATOR - Static variable in class org.apache.solr.spelling.suggest.fst.FreeTextLookupFactory
The separator to use in the underlying suggester;
serialize(OverseerSolrResponse) - Static method in class org.apache.solr.cloud.OverseerSolrResponseSerializer
This method serializes the content of an OverseerSolrResponse.
serialize(NamedList, JsonGenerator, SerializerProvider) - Method in class org.apache.solr.jersey.SolrJacksonMapper.NamedListSerializer
 
serializeResponse(SolrQueryRequest, SolrQueryResponse) - Method in interface org.apache.solr.response.BinaryQueryResponseWriter
 
serializeTopDocs(QueryCommandResult) - Method in class org.apache.solr.search.grouping.distributed.shardresultserializer.TopGroupsResultTransformer
 
serializeTopGroups(TopGroups<BytesRef>, SchemaField) - Method in class org.apache.solr.search.grouping.distributed.shardresultserializer.TopGroupsResultTransformer
 
serialVersionUID - Static variable in class org.apache.solr.handler.HaversineMetersEvaluator
 
serverDir - Variable in class org.apache.solr.cli.RunExampleTool
 
serviceForContext(ServletContext) - Static method in class org.apache.solr.servlet.CoreContainerProvider
 
ServletInputStreamWrapper - Class in org.apache.solr.servlet
Provides a convenient extension of the ServletInputStream class that can be subclassed by developers wishing to adapt the behavior of a Stream.
ServletInputStreamWrapper(ServletInputStream) - Constructor for class org.apache.solr.servlet.ServletInputStreamWrapper
 
ServletOutputStreamWrapper - Class in org.apache.solr.servlet
Provides a convenient extension of the ServletOutputStream class that can be subclassed by developers wishing to adapt the behavior of a Stream.
ServletOutputStreamWrapper(ServletOutputStream) - Constructor for class org.apache.solr.servlet.ServletOutputStreamWrapper
 
ServletUtils - Class in org.apache.solr.servlet
Various Util methods for interaction on servlet level, i.e.
ServletUtils.ClosedServletInputStream - Class in org.apache.solr.servlet
 
ServletUtils.ClosedServletOutputStream - Class in org.apache.solr.servlet
 
Session() - Constructor for class org.apache.solr.cloud.LockTree.Session
 
set - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogLevelInfo
 
set(long) - Static method in class org.apache.solr.search.SolrQueryTimeoutImpl
Sets the time allowed (milliseconds), assuming we start a timer immediately.
set(String, Object) - Method in class org.apache.solr.metrics.AggregateMetric
 
set(SolrQueryRequest) - Static method in class org.apache.solr.search.SolrQueryTimeoutImpl
Sets or clears the time allowed based on how much time remains from the start of the request plus the configured CommonParams.TIME_ALLOWED.
SET - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
SET_PROPERTY - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
SET_SOLR_DISABLE_URL_ALLOW_LIST_CLUE - Static variable in class org.apache.solr.security.AllowListUrlChecker
Clue given in URL-forbidden exceptions messages.
SET_USER_PROPERTY - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
setAcceptableWaterMark(int) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setAction(SolrDispatchFilter.Action) - Method in class org.apache.solr.request.SolrRequestInfo
 
setActPosition(int) - Method in interface org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttribute
 
setActPosition(int) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
setActualDocFreq(int, int) - Method in class org.apache.solr.search.facet.UnInvertedField
 
setActualDocFreq(int, int) - Method in class org.apache.solr.uninverting.DocTermOrds
Invoked during DocTermOrds.uninvert(org.apache.lucene.index.LeafReader,Bits,BytesRef) to record the document frequency for each uninverted term.
setAddRequestHeadersToContext(boolean) - Method in class org.apache.solr.servlet.SolrRequestParsers
 
setAgentId(String) - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Sets the agent id for a JMX server.
setAlgorithm(ClassificationUpdateProcessorFactory.Algorithm) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
SetAliasPropCmd - Class in org.apache.solr.cloud.api.collections
 
SetAliasPropCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.SetAliasPropCmd
 
setAlive(boolean) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setAllowLeadingWildcard(boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
Set to true to allow leading wildcard characters.
setAllowPaths(Set<Path>) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setAllowSubQueryParsing(boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
Set to enable subqueries to be parsed.
setAllowUrls(List<String>) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setAllValues(NamedList<Object>) - Method in class org.apache.solr.response.SolrQueryResponse
Sets data to be returned in this response
setAnalytics(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setAnalyticsRequestManager(Object) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setAnalyzer(Analyzer) - Method in class org.apache.solr.spelling.QueryConverter
Set the analyzer to use.
setArgs(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
 
setArgs(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.FieldType
Initializes the field type.
setArgs(IndexSchema, Map<String, String>) - Method in class org.apache.solr.schema.NestPathField
 
setAssumeContentType(String) - Method in class org.apache.solr.handler.UpdateRequestHandler
 
setAttribute(Attribute) - Method in class org.apache.solr.metrics.MetricsMap
 
setAttributes(AttributeList) - Method in class org.apache.solr.metrics.MetricsMap
 
setAutoGeneratePhraseQueries(boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
Set to true if phrase queries will be automatically generated when the analyzer returns more than one term from whitespace delimited text.
setAutResponse(AuthorizationResponse) - Method in class org.apache.solr.security.AuditEvent
 
setBackupRepositoryPlugins(PluginInfo[]) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setBaseUrl(String) - Method in class org.apache.solr.security.AuditEvent
 
setBooleanQueryMaxClauseCount(Integer) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setBucketWasMissing(boolean) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
setBytes(byte[]) - Method in class org.apache.solr.cloud.OverseerTaskQueue.QueueEvent
 
setCache(boolean) - Method in class org.apache.solr.query.FilterQuery
 
setCache(boolean) - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
setCache(boolean) - Method in interface org.apache.solr.search.ExtendedQuery
 
setCache(boolean) - Method in class org.apache.solr.search.ExtendedQueryBase
 
setCacheConfig(MetricsConfig.CacheConfig) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setCacheControlHeader(SolrConfig, HttpServletResponse, Method) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
Set the Cache-Control HTTP header (and Expires if needed) based on the SolrConfig.
setCachesConfig(Map<String, CacheConfig>) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCancellation(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setCancellationUUID(String) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setClassificationParams(ClassificationUpdateProcessorParams) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorFactory
 
setClientIp(String) - Method in class org.apache.solr.security.AuditEvent
 
setCloudConfig(CloudConfig) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setClusterPlugins(PluginInfo[]) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCollationQuery(String) - Method in class org.apache.solr.spelling.SpellCheckCollation
 
setCollection(String) - Static method in class org.apache.solr.logging.MDCLoggingContext
 
setCollectionName(String) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setCollections(List<String>) - Method in class org.apache.solr.security.AuditEvent
 
setCollectionsAdminHandlerClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCommitData(IndexWriter, long, Map<String, String>) - Static method in class org.apache.solr.update.SolrIndexWriter
 
setCompact(boolean) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
If true then use "compact" data representation.
setConfigMetadata(String, Map<String, Object>) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
setConfigMetadata(String, Map<String, Object>) - Method in class org.apache.solr.core.ConfigSetService
Set the config metadata If config does not exist, it will be created and set metadata on it Else metadata will be replaced with the provided metadata
setConfigMetadata(String, Map<String, Object>) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
setConfigSet(String) - Method in class org.apache.solr.core.CoreDescriptor
TODO remove mutability or at least make this non-public?
setConfigSetBaseDirectory(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setConfigSetServiceClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setConfigSetsHandlerClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setConfigSetTrusted(boolean) - Method in class org.apache.solr.core.CoreDescriptor
TODO remove mutability
setContentStreams(Iterable<ContentStream>) - Method in class org.apache.solr.request.SolrQueryRequestBase
 
setContext(Map<String, Object>) - Method in class org.apache.solr.security.AuditEvent
 
setContext(ResultContext) - Method in class org.apache.solr.response.transform.DocTransformer
This is called before DocTransformer.transform(org.apache.solr.common.SolrDocument, int, float) to provide context for any subsequent transformations.
setContext(ResultContext) - Method in class org.apache.solr.response.transform.DocTransformers
 
setContext(ResultContext) - Method in class org.apache.solr.response.transform.ValueSourceAugmenter
 
setContextEntry(String, Object) - Method in class org.apache.solr.security.AuditEvent
 
setCore(SolrCore) - Static method in class org.apache.solr.logging.MDCLoggingContext
Sets multiple information from the params.
setCoreAdminHandlerActions(Map<String, String>) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCoreAdminHandlerClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCoreConfigService(ConfigSetService) - Method in class org.apache.solr.core.CoreContainer
 
setCoreDescriptor(CoreContainer, CoreDescriptor) - Static method in class org.apache.solr.logging.MDCLoggingContext
Sets multiple information from the params.
setCoreLoadThreads(int) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCoreName(String) - Static method in class org.apache.solr.logging.MDCLoggingContext
 
setCoreNodeName(String) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setCoreRootDirectory(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCoresLocatorClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCoreSorterClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setCorrection(String) - Method in class org.apache.solr.spelling.SpellCheckCorrection
 
setCost(int) - Method in interface org.apache.solr.search.ExtendedQuery
 
setCost(int) - Method in class org.apache.solr.search.ExtendedQueryBase
 
setCount(int) - Method in class org.apache.solr.search.SortSpec
 
setCounterSupplier(PluginInfo) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setCpuEnabled(String) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
setCpuThreshold(int) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
setCpuThreshold(String) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
setCreateCollectionCheckLeaderActive(boolean) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setCreateCollectionWaitTimeTillActive(int) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setCurrent(SSLConfigurations) - Static method in class org.apache.solr.util.configuration.SSLConfigurationsFactory
 
setCurrentValue(int) - Method in class org.apache.solr.handler.export.IntValue
 
setCurrentValue(int) - Method in class org.apache.solr.handler.export.LongValue
 
setCurrentValue(SortValue) - Method in class org.apache.solr.handler.export.IntValue
 
setCurrentValue(SortValue) - Method in class org.apache.solr.handler.export.LongValue
 
setCursorMark(CursorMark) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setCursorMark(CursorMark) - Method in class org.apache.solr.search.QueryCommand
 
setCustomData(Object) - Method in class org.apache.solr.packagemanager.SolrPackageInstance
 
setData(InputStream) - Method in class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
Set data from input stream
setData(Object) - Method in class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
Sets the data as an Object, but the object needs to be of type Map
setData(Map<String, Object>) - Method in class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
Sets the data as a Map
setDate(Date) - Method in class org.apache.solr.security.AuditEvent
 
setDbInstance(SolrQueryRequest, String) - Static method in class org.apache.solr.util.tracing.TraceUtils
 
setDebug(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setDebugInfo(NamedList<Object>) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setDebugInfo(FacetDebugInfo) - Method in class org.apache.solr.search.facet.FacetContext
 
setDebugQuery(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setDebugResults(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setDebugTimings(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setDebugTrack(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setDefaultFormat(Grouping.Format) - Method in class org.apache.solr.search.Grouping
 
setDefaultOperator(QueryParser.Operator) - Method in class org.apache.solr.parser.SolrQueryParserBase
Sets the boolean operator of the QueryParser.
setDefaults(SolrQueryRequest, SolrParams, SolrParams, SolrParams) - Static method in class org.apache.solr.util.SolrPluginUtils
Set default-ish params on a SolrQueryRequest.
setDefaults(SolrRequestHandler, SolrQueryRequest, SolrParams, SolrParams, SolrParams) - Static method in class org.apache.solr.util.SolrPluginUtils
 
setDefaultTotalCount(Grouping.TotalCount) - Method in class org.apache.solr.search.Grouping
 
setDefaultZkHost(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setDelegate(Collector) - Method in class org.apache.solr.search.DelegatingCollector
 
setDelegate(ClusterEventProducer) - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
setDelegate(PlacementPluginFactory<? extends PlacementPluginConfig>) - Method in class org.apache.solr.cluster.placement.impl.DelegatingPlacementPluginFactory
 
setDelegationPhaser(Phaser) - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
A phaser that will advance phases every time DelegatingClusterEventProducer.setDelegate(ClusterEventProducer) is called.
setDelegationPhaser(Phaser) - Method in class org.apache.solr.cluster.placement.impl.DelegatingPlacementPluginFactory
A phaser that will advance phases every time DelegatingPlacementPluginFactory.setDelegate(PlacementPluginFactory) is called.
setDeleteOnClose(boolean, boolean) - Method in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
setDocCollectionLimit(int) - Method in class org.apache.solr.spelling.SpellCheckCollator
 
setDocList(DocList) - Method in class org.apache.solr.search.QueryResult
 
setDocListAndSet(DocListAndSet) - Method in class org.apache.solr.search.QueryResult
 
setDocSet(DocSet) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
 
setDocSet(DocSet) - Method in class org.apache.solr.search.QueryResult
 
setDocSet(SolrIndexSearcher) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
Sets the docSet based on the created DocSet
setDocsPerGroupDefault(int) - Method in class org.apache.solr.search.Grouping
 
setDocsToCollect(int) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
 
setDomain(String) - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Sets the domain with which MBeans are published.
setDoubleValue(double) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Initializes the token stream with the supplied double value.
setElapse(long) - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
setElapsedTime(long) - Method in class org.apache.solr.cloud.OverseerSolrResponse
 
setEmitManagedSchemaDoNotEditWarning(boolean) - Method in class org.apache.solr.response.SchemaXmlWriter
 
setEnabled(boolean) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setEnabled(boolean) - Method in class org.apache.solr.update.processor.RegexpBoostProcessor
 
setEnabled(boolean) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
 
setEnabled(Boolean) - Method in class org.apache.solr.metrics.SolrMetricReporter
Enable reporting, defaults to true.
setEnvVars(Map<String, String>) - Method in class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider
 
setError() - Method in class org.apache.solr.security.PrintWriterWrapper
 
setException(Exception) - Method in class org.apache.solr.response.SolrQueryResponse
Causes an error to be returned instead of the results.
setException(Throwable) - Method in class org.apache.solr.security.AuditEvent
 
setExcludePatterns(List<Pattern>) - Method in interface org.apache.solr.servlet.PathExcluder
 
setExcludePatterns(List<Pattern>) - Method in class org.apache.solr.servlet.SolrDispatchFilter
 
setFacetDebugInfo(FacetDebugInfo) - Method in class org.apache.solr.request.SimpleFacets
 
setField(SchemaField) - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand.Builder
 
setField(SchemaField) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setFieldFlags(int) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setFields(String[]) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setFieldSources(SolrReturnFields.FIELD_SOURCES) - Method in class org.apache.solr.search.SolrReturnFields
 
setFilter(String) - Method in class org.apache.solr.metrics.FilteringSolrMetricReporter
 
setFilter(String) - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
setFilter(List<String>) - Method in class org.apache.solr.metrics.FilteringSolrMetricReporter
 
setFilter(DocSet) - Method in class org.apache.solr.search.QueryCommand
 
setFilterList(List<Query>) - Method in class org.apache.solr.search.QueryCommand
 
setFilterList(Query) - Method in class org.apache.solr.search.QueryCommand
A simple setter to build a filterList from a query
setFilters(List<Query>) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setFirstPhaseGroups(Collection<SearchGroup<BytesRef>>) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setFlags(int) - Method in class org.apache.solr.search.QParser
 
setFlags(int) - Method in class org.apache.solr.search.QueryCommand
 
setFlags(int) - Method in class org.apache.solr.spelling.Token
Deprecated.
setFlags(int) - Method in class org.apache.solr.update.UpdateCommand
 
setFloatValue(float) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Initializes the token stream with the supplied float value.
setFormatter(AuditLoggerPlugin.AuditEventFormatter) - Method in class org.apache.solr.security.AuditLoggerPlugin
 
setFromField(String) - Method in class org.apache.solr.search.join.GraphQuery
 
setFromZookeeper(boolean) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setFunctions(String[]) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setFuzzyMinSim(float) - Method in class org.apache.solr.parser.SolrQueryParserBase
Set the minimum similarity for fuzzy queries.
setFuzzyPrefixLength(int) - Method in class org.apache.solr.parser.SolrQueryParserBase
Set the prefix length for fuzzy queries.
setGetGroupedDocSet(boolean) - Method in class org.apache.solr.search.Grouping
 
setGroupingSpec(GroupingSpecification) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setGroupOffsetDefault(int) - Method in class org.apache.solr.search.Grouping
 
setGroupSort(Sort) - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand.Builder
 
setGroupSort(Sort) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setGroupSort(Sort) - Method in class org.apache.solr.search.Grouping
 
setGroupSortSpec(SortSpec) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setHandleSelect(boolean) - Method in class org.apache.solr.servlet.SolrRequestParsers
 
setHasRegistered(boolean) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setHeaders(Map<String, String>) - Method in class org.apache.solr.security.AuditEvent
 
setHealthCheckHandler(HealthCheckHandler) - Method in class org.apache.solr.handler.admin.InfoHandler
 
setHealthCheckHandlerClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setHiddenSysProps(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setHideStackTrace(boolean) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setHighlightQuery(Query) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setHistogramSupplier(PluginInfo) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setHits(long) - Method in class org.apache.solr.spelling.SpellCheckCollation
 
setHost(String) - Method in class org.apache.solr.metrics.reporters.SolrGraphiteReporter
 
setHttpCaching(boolean) - Method in class org.apache.solr.response.SolrQueryResponse
Enables or disables the emission of HTTP caching headers for this response.
setHttpHeader(String, String) - Method in class org.apache.solr.response.SolrQueryResponse
Sets a response header with the given name and value.
setHttpMethod(String) - Method in class org.apache.solr.security.AuditEvent
 
setHttpQueryString(String) - Method in class org.apache.solr.security.AuditEvent
 
setId(String) - Method in class org.apache.solr.cloud.OverseerTaskQueue.QueueEvent
 
setId(String) - Method in class org.apache.solr.update.DeleteUpdateCommand
 
setIncludeGroupCount(boolean) - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand.Builder
 
setIncludeGroupCount(boolean) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setIncludeHitCount(boolean) - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
 
setIndent(boolean) - Method in class org.apache.solr.response.TextResponseWriter
 
setIndexAnalyzer(Analyzer) - Method in class org.apache.solr.schema.FieldType
Sets the Analyzer to be used when indexing fields of this type.
setIndexedId(BytesRef) - Method in class org.apache.solr.update.AddUpdateCommand
 
setIndexedId(BytesRef) - Method in class org.apache.solr.update.DeleteUpdateCommand
 
setInfoHandlerClass(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setInputFieldNames(String[]) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setInternalRank(int) - Method in class org.apache.solr.spelling.SpellCheckCollation
 
setIntValue(int) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Initializes the token stream with the supplied int value.
setIsExplicitAnalyzer(boolean) - Method in class org.apache.solr.schema.FieldType
 
setIsExplicitMultiTermAnalyzer(boolean) - Method in class org.apache.solr.schema.TextField
 
setIsExplicitQueryAnalyzer(boolean) - Method in class org.apache.solr.schema.FieldType
 
setIsFilter(boolean) - Method in class org.apache.solr.search.QParser
 
setIsTaskListRequest(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setJSON(Map<String, Object>) - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
setJSON(Map<String, Object>) - Method in interface org.apache.solr.request.SolrQueryRequest
 
setJSON(Map<String, Object>) - Method in class org.apache.solr.request.SolrQueryRequestBase
 
setK(int) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setLastAccessed(long) - Method in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
setLastDelegate(Collector) - Method in class org.apache.solr.search.DelegatingCollector
Sets the last delegate in a chain of DelegatingCollectors
setLastDelegateCount - Static variable in class org.apache.solr.search.DelegatingCollector
 
setLastPublished(Replica.State) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setLastReplicateIndexSuccess(boolean) - Method in class org.apache.solr.update.DefaultSolrCoreState
 
setLastReplicateIndexSuccess(boolean) - Method in class org.apache.solr.update.SolrCoreState
 
setLatestSchema(IndexSchema) - Method in class org.apache.solr.core.SolrCore
Sets the latest schema snapshot to be used by this core instance.
setLeader(boolean) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setLeader(boolean) - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ReplicaMetricsBuilder
 
setLeaderConflictResolveWait(int) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setLeaderMetrics(CollectionMetricsBuilder.ReplicaMetricsBuilder) - Method in class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ShardMetricsBuilder
 
setLeaderVoteWait(int) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setLen(int) - Method in class org.apache.solr.search.QueryCommand
 
setLevel(int) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
setLevel(int) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
setLevel(int) - Method in class org.apache.solr.response.TextResponseWriter
 
setLevel(AuditEvent.Level) - Method in class org.apache.solr.security.AuditEvent
 
setLimit(String) - Method in class org.apache.solr.cli.ExportTool.Info
 
setLimitDefault(int) - Method in class org.apache.solr.search.Grouping
 
setLocalParams(SolrParams) - Method in class org.apache.solr.search.QParser
 
setLogger(String) - Method in class org.apache.solr.metrics.reporters.SolrSlf4jReporter
 
setLoggingHandler(LoggingHandler) - Method in class org.apache.solr.handler.admin.InfoHandler
 
setLogLevel(String, String) - Method in class org.apache.solr.logging.jul.JulWatcher
 
setLogLevel(String, String) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
setLogLevel(String, String) - Method in class org.apache.solr.logging.LogWatcher
Sets the log level within this framework
setLogWatcherConfig(LogWatcherConfig) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setLongValue(long) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
Initializes the token stream with the supplied long value.
setLowerWaterMark(int) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setMain(boolean) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setMainQuery(Query) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
Sets the main query used for fetching results.
setMainScaleExplain(ReRankScaler.MinMaxExplain) - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
setManagementPath(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setMatchAlmostDiff(int) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Sets the number of characters by which words can differ from target word when calling the matchAlmost method.
setMaxCollationEvaluations(int) - Method in class org.apache.solr.spelling.SpellCheckCollator
 
setMaxCollations(int) - Method in class org.apache.solr.spelling.SpellCheckCollator
 
setMaxCollationTries(int) - Method in class org.apache.solr.spelling.SpellCheckCollator
 
setMaxCommitsToKeep(int) - Method in class org.apache.solr.core.SolrDeletionPolicy
 
setMaxDepth(int) - Method in class org.apache.solr.search.join.GraphQuery
 
setMaxDocPerGroup(int) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setMaxIdleTime(int) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setMaxOptimizedCommitsToKeep(int) - Method in class org.apache.solr.core.SolrDeletionPolicy
 
setMaxPermits(int) - Method in class org.apache.solr.util.AdjustableSemaphore
 
setMaxPredictedClasses(int) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setMaxRamMB(int) - Method in class org.apache.solr.search.CaffeineCache
 
setMaxRamMB(int) - Method in interface org.apache.solr.search.SolrCache
Set maximum size limit (in MB), or -1 for unlimited.
setMaxRetries(int) - Method in class org.apache.solr.cloud.RecoveryStrategy
 
setMaxSize(int) - Method in class org.apache.solr.search.CaffeineCache
 
setMaxSize(int) - Method in interface org.apache.solr.search.SolrCache
Set maximum size limit (number of items), or -1 for unlimited.
setMaxSize(int) - Method in class org.apache.solr.util.BoundedTreeSet
 
setMemEnabled(String) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
setMemThreshold(int) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
setMemThreshold(String) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreakerManager
Deprecated.
 
setMessage(String) - Method in class org.apache.solr.security.AuditEvent
 
setMessage(String) - Method in class org.apache.solr.security.AuthorizationResponse
 
setMessageThreshold(NodeLoggingAPI.SetThresholdRequestBody) - Method in class org.apache.solr.handler.admin.api.NodeLoggingAPI
 
setMeterSupplier(PluginInfo) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setMetricReporterPlugins(PluginInfo[]) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setMetricsConfig(MetricsConfig) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setMinDf(int) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setMinExactCount(int) - Method in class org.apache.solr.search.QueryCommand
 
setMinShouldMatch(BooleanQuery.Builder, String) - Static method in class org.apache.solr.util.SolrPluginUtils
 
setMinShouldMatch(BooleanQuery.Builder, String, boolean) - Static method in class org.apache.solr.util.SolrPluginUtils
Checks the number of optional clauses in the query, and compares it with the specification string to determine the proper value to use.
setMinShouldMatch(BooleanQuery, String) - Static method in class org.apache.solr.util.SolrPluginUtils
 
setMinShouldMatch(BooleanQuery, String, boolean) - Static method in class org.apache.solr.util.SolrPluginUtils
 
setMinStateByteLenForCompression(int) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setMinTf(int) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setMisspellingsAndCorrections(NamedList<String>) - Method in class org.apache.solr.spelling.SpellCheckCollation
 
setModules(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
Set list of modules to add to class path
setMultiTermAnalyzer(Analyzer) - Method in class org.apache.solr.schema.TextField
 
setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.solr.parser.SolrQueryParserBase
By default QueryParser uses MultiTermQuery.CONSTANT_SCORE_REWRITE when creating a PrefixQuery, WildcardQuery or RangeQuery.
setName(String) - Method in class org.apache.solr.core.SolrCore
Called to rename a core.
setName(String) - Method in class org.apache.solr.handler.component.SearchComponent
Sets the name of the SearchComponent.
setNeedDocList(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setNeedDocSet(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setNeedDocSet(boolean) - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
Sets whether to compute a DocSet.
setNeedDocSet(boolean) - Method in class org.apache.solr.search.QueryCommand
 
setNeedMaxScore(Boolean) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setNeedScore(boolean) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setNeedScores(boolean) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
 
setNeedScores(Boolean) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setNextCursorMark(CursorMark) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setNextCursorMark(CursorMark) - Method in class org.apache.solr.search.QueryResult
 
setNextReader(LeafReaderContext) - Method in class org.apache.solr.handler.component.FieldFacetStats
 
setNextReader(LeafReaderContext) - Method in class org.apache.solr.handler.component.SortedDateStatsValues
 
setNextReader(LeafReaderContext) - Method in class org.apache.solr.handler.component.SortedNumericStatsValues
 
setNextReader(LeafReaderContext) - Method in interface org.apache.solr.handler.component.StatsValues
Set the context for StatsValues.accumulate(int).
setNextReader(LeafReaderContext) - Method in class org.apache.solr.handler.export.IntValue
 
setNextReader(LeafReaderContext) - Method in class org.apache.solr.handler.export.LongValue
 
setNextReader(LeafReaderContext) - Method in class org.apache.solr.search.facet.SlotAcc.FuncSlotAcc
 
setNextReader(LeafReaderContext) - Method in class org.apache.solr.search.facet.SlotAcc
NOTE: this currently detects when it is being reused and calls resetIterators by comparing reader ords with previous calls to setNextReader.
setNode(String) - Static method in class org.apache.solr.logging.MDCLoggingContext
 
setNode(CoreContainer) - Static method in class org.apache.solr.logging.MDCLoggingContext
 
setNotANumber(Object) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setNow(Date) - Method in class org.apache.solr.util.DateMathParser
Defines this instance's concept of "now".
setNullNumber(Object) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setNullObject(Object) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setNullString(Object) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setNumberOfOccurences(int) - Method in class org.apache.solr.spelling.SpellCheckCorrection
 
setNumericPrecisionStep(int) - Method in class org.apache.solr.legacy.LegacyFieldType
Deprecated.
Please switch to PointValues instead
setNumericType(LegacyNumericType) - Method in class org.apache.solr.legacy.LegacyFieldType
Deprecated.
Please switch to PointValues instead
setNumReturnValues(int) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Sets the default maximum number of values returned from the matchPrefix and matchAlmost methods.
setNumShards(int) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setObjProperty(PayloadObj<ClusterPropPayload>) - Method in class org.apache.solr.handler.ClusterAPI.Commands
 
setOffset(int) - Method in class org.apache.solr.search.QueryCommand
 
setOffset(int) - Method in class org.apache.solr.search.SortSpec
 
setOlapAnalytics(boolean) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setOnlyLeafNodes(boolean) - Method in class org.apache.solr.search.join.GraphQuery
 
setOpenSearcher(boolean) - Method in class org.apache.solr.update.CommitTracker
 
setOperationRspObject(SolrQueryResponse) - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
setOperations(SolrQueryRequest, String, List<String>) - Static method in class org.apache.solr.util.tracing.TraceUtils
 
setOpts(QParser) - Method in class org.apache.solr.search.facet.RelatednessAgg
 
setOriginal(Token) - Method in class org.apache.solr.spelling.SpellCheckCorrection
 
setOutFormat(String, String, boolean) - Method in class org.apache.solr.cli.ExportTool.Info
 
setParams(String, RequestParams.ParamSet) - Method in class org.apache.solr.core.RequestParams
 
setParams(SolrParams) - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
setParams(SolrParams) - Method in interface org.apache.solr.request.SolrQueryRequest
Change the parameters for this request.
setParams(SolrParams) - Method in class org.apache.solr.request.SolrQueryRequestBase
 
setParams(SolrParams) - Method in class org.apache.solr.search.QParser
 
setParams(NamedList<?>) - Method in class org.apache.solr.spelling.suggest.DictionaryFactory
Sets the parameters available to SolrSuggester for use in Dictionary creation
setParseMultipleSources(boolean) - Method in class org.apache.solr.search.FunctionQParser
 
setParseToEnd(boolean) - Method in class org.apache.solr.search.FunctionQParser
 
setPartialResults(boolean) - Method in class org.apache.solr.search.QueryResult
 
setPayload(BytesRef) - Method in class org.apache.solr.spelling.Token
Deprecated.
setPeriod(int) - Method in class org.apache.solr.metrics.SolrMetricReporter
 
setPermission(PayloadObj<SetRuleBasedAuthPermissionPayload>) - Method in class org.apache.solr.handler.admin.api.ModifyRuleBasedAuthConfigAPI
 
setPhaser(Phaser) - Method in class org.apache.solr.api.ContainerPluginsRegistry
A phaser that will advance phases every time ContainerPluginsRegistry.onChange(Map) is called.
setPhraseSlop(int) - Method in class org.apache.solr.parser.SolrQueryParserBase
Sets the default slop for phrases.
setPickled(boolean) - Method in class org.apache.solr.metrics.reporters.SolrGraphiteReporter
 
setPkiHandlerPrivateKeyPath(String) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setPkiHandlerPublicKeyPath(String) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setPluginInfo(PluginInfo) - Method in class org.apache.solr.handler.RequestHandlerBase
 
setPollListener(ReplicationHandler.PollListener) - Method in class org.apache.solr.handler.ReplicationHandler
 
setPort(int) - Method in class org.apache.solr.metrics.reporters.SolrGraphiteReporter
 
setPositionIncrementGap(int) - Method in class org.apache.solr.analysis.SolrAnalyzer
 
setPredictedClassField(String) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setPreferredOverseer() - Method in class org.apache.solr.cloud.ZkController
 
setPrefix(String) - Method in class org.apache.solr.metrics.reporters.SolrGraphiteReporter
 
setPrefix(String) - Method in class org.apache.solr.metrics.reporters.SolrSlf4jReporter
 
setProcessor(String) - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
setProperties(PayloadObj<Map<String, Object>>) - Method in class org.apache.solr.handler.admin.api.ModifyMultiPluginAuthConfigAPI
 
setPropertiesHandler(PropertiesRequestHandler) - Method in class org.apache.solr.handler.admin.InfoHandler
 
setProperty(String, Object) - Method in class org.apache.solr.core.ConfigOverlay
 
setProperty(PayloadObj<Map<String, String>>) - Method in class org.apache.solr.handler.ClusterAPI.Commands
 
setQ(Query) - Method in class org.apache.solr.search.join.GraphQuery
 
setQparser(QParser) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setQTime(double) - Method in class org.apache.solr.security.AuditEvent
 
setQueries(String[]) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setQuery(String) - Method in class org.apache.solr.update.DeleteUpdateCommand
 
setQuery(String, SolrQueryRequest) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
Sets the group query from the specified groupQueryString.
setQuery(Query) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setQuery(Query) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
Sets the group query.
setQuery(Query) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setQuery(Query) - Method in class org.apache.solr.search.QueryCommand
 
setQueryAnalyzer(Analyzer) - Method in class org.apache.solr.schema.FieldType
Sets the Analyzer to be used when querying fields of this type.
setQueryCancellable(boolean) - Method in class org.apache.solr.search.QueryCommand
 
setQueryCommand(QueryCommand) - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
 
setQueryID(String) - Method in class org.apache.solr.search.QueryCommand
 
setQueryString(String) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setQueueLength(int) - Method in class org.apache.solr.cloud.Stats
 
setRamLowerWatermark(long) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setRamUpperWatermark(long) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setRankQuery(RankQuery) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setRateLimiters(PayloadObj<RateLimiterPayload>) - Method in class org.apache.solr.handler.ClusterAPI.Commands
 
setReadListener(ReadListener) - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
setReadListener(ReadListener) - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletInputStream
 
setReady() - Method in class org.apache.solr.core.ClusterSingletons
Mark this helper as ready to be used for singleton management.
setRecoveringAfterStartup(boolean) - Method in class org.apache.solr.cloud.RecoveryStrategy
 
setRegenerator(CacheRegenerator) - Method in class org.apache.solr.search.CacheConfig
 
setRemoveStopFilter(boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
 
setReplayUpdatesThreads(int) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setReplica(String) - Static method in class org.apache.solr.logging.MDCLoggingContext
 
setRepository(String) - Method in class org.apache.solr.packagemanager.SolrPackage
 
setReq(SolrQueryRequest) - Method in class org.apache.solr.search.QParser
 
setReq(SolrQueryRequest) - Method in class org.apache.solr.update.UpdateCommand
 
setReqDescription(Map<String, Object>) - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
setRequestInfo(SolrRequestInfo) - Static method in class org.apache.solr.request.SolrRequestInfo
Adds the SolrRequestInfo onto a stack held in a ThreadLocal.
setRequestType(AuditEvent.RequestType) - Method in class org.apache.solr.security.AuditEvent
 
setRequestTypes(List<String>) - Method in class org.apache.solr.util.circuitbreaker.CircuitBreaker
Set the request types for which this circuit breaker should be checked.
setReRankScaleExplain(ReRankScaler.MinMaxExplain) - Method in class org.apache.solr.search.ReRankScaler.ReRankScalerExplain
 
setReserveDuration(Long, long) - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
Set the duration for which commit point is to be reserved by the deletion policy.
setResource(String) - Method in class org.apache.solr.security.AuditEvent
 
setResourceName(String) - Method in class org.apache.solr.schema.IndexSchema
Sets the name of the resource used to instantiate this schema.
setResponse(NamedList<Object>) - Method in class org.apache.solr.cloud.OverseerSolrResponse
 
setResponseBuilder(ResponseBuilder) - Method in class org.apache.solr.request.SolrRequestInfo
 
setResponseDocs(SolrDocumentList) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setResponseFormat(Grouping.Format) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setResult(QueryResult) - Method in class org.apache.solr.handler.component.ResponseBuilder
Sets results from a SolrIndexSearcher.QueryResult.
setResults(DocListAndSet) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setReturnFields(ReturnFields) - Method in class org.apache.solr.response.SolrQueryResponse
Sets the document field names of fields to return by default when returning DocLists
setReturnRoot(boolean) - Method in class org.apache.solr.search.join.GraphQuery
 
setRoles(String) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setRootName(String) - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Set root name of the JMX hierarchy for this reporter.
setRoute(String) - Method in class org.apache.solr.update.UpdateCommand
 
setRspObject(SolrQueryResponse) - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
setRspObjectFromException(Exception) - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
setRunCleanupThread(boolean) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setSamplingPercent(float) - Method in class org.apache.solr.handler.admin.IndexSizeEstimator
Sampling percent (a number greater than 0 and less or equal to 100).
setSamplingThreshold(int) - Method in class org.apache.solr.handler.admin.IndexSizeEstimator
Set the sampling threshold.
setSchema(ManagedIndexSchema) - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
setScorer(Scorable) - Method in class org.apache.solr.search.DelegatingCollector
 
setScorer(Scorable) - Method in class org.apache.solr.search.DocSetCollector
 
setScorer(Scorable) - Method in class org.apache.solr.search.MaxScoreCollector
 
setSearcher(SolrIndexSearcher) - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
 
setSecurityBuilder(HttpClientBuilderPlugin) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
 
setSecurityBuilder(HttpClientBuilderPlugin) - Method in class org.apache.solr.handler.component.ShardHandlerFactory
 
setSecurityBuilder(HttpClientBuilderPlugin) - Method in class org.apache.solr.update.UpdateShardHandler
 
setSegmentTerminatedEarly(Boolean) - Method in class org.apache.solr.search.QueryResult
 
setSegmentTerminateEarly(boolean) - Method in class org.apache.solr.search.QueryCommand
 
setServiceUrl(String) - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Sets the service url for a JMX server.
setSession(String) - Method in class org.apache.solr.security.AuditEvent
 
setShard(String) - Static method in class org.apache.solr.logging.MDCLoggingContext
 
setShard(String) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
setShardFlag(int) - Method in class org.apache.solr.search.facet.FacetMerger.Context
 
setShardHandlerFactoryConfig(PluginInfo) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setShardId(String) - Method in class org.apache.solr.cloud.CloudDescriptor
 
setShardLeader(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.SliceMutator
 
setShardRequest(ShardRequest) - Method in class org.apache.solr.handler.component.ShardResponse
 
setSharedLibDirectory(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setShift(int) - Method in interface org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttribute
Deprecated.
Don't call this method!
setShift(int) - Method in class org.apache.solr.legacy.LegacyNumericTokenStream.LegacyNumericTermAttributeImpl
Deprecated.
 
setSimilarity(SimilarityFactory) - Method in class org.apache.solr.schema.FieldType
Sets the Similarity used when scoring fields of this type
setSolrDataHome(String) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setSolrHost(String) - Method in class org.apache.solr.security.AuditEvent
 
setSolrIp(String) - Method in class org.apache.solr.security.AuditEvent
 
setSolrParams(Map<String, List<String>>) - Method in class org.apache.solr.security.AuditEvent
 
setSolrPort(int) - Method in class org.apache.solr.security.AuditEvent
 
setSolrProperties(Properties) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setSolrResourceLoader(SolrResourceLoader) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setSolrResourceLoader(SolrResourceLoader) - Method in class org.apache.solr.handler.SolrDefaultStreamFactory
 
setSolrResponse(SolrResponse) - Method in class org.apache.solr.handler.component.ShardResponse
 
setSort(Sort) - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommand.Builder
 
setSort(Sort) - Method in class org.apache.solr.search.QueryCommand
 
setSortAndFields(Sort, List<SchemaField>) - Method in class org.apache.solr.search.SortSpec
the specified SchemaFields must correspond one to one with the Sort's SortFields, using null where appropriate.
setSortSpec(SortSpec) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setSortValues(List<Object>) - Method in class org.apache.solr.search.CursorMark
Sets the (raw, unmarshalled) sort values (which must conform to the existing sortSpec) to populate this object.
setSortWithinGroup(Sort) - Method in class org.apache.solr.search.grouping.distributed.command.TopGroupsFieldCommand.Builder
 
setSplitOnWhitespace(boolean) - Method in class org.apache.solr.parser.QueryParser
Whether query text should be split on whitespace prior to analysis.
setStartingRecoveryDelayMilliSeconds(int) - Method in class org.apache.solr.cloud.RecoveryStrategy
 
setState(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.ReplicaMutator
Handles state updates
setState(SolrCache.State) - Method in interface org.apache.solr.search.SolrCache
Set different cache states.
setState(SolrCache.State) - Method in class org.apache.solr.search.SolrCacheBase
 
setStateCompressorClass(String) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setStatus(int) - Method in class org.apache.solr.security.AuditEvent
 
setStatus(String, int) - Method in class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
Sets a custom status for the given core name.
setStatus(String, int) - Method in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
setStdout(PrintStream) - Static method in class org.apache.solr.cloud.ZkCLI
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.AnalyzeEvaluator
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.CatStream
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.ClassifyStream
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.export.ExportWriterStream
NOTE: this context must contain an instance of ExportBuffers under the ExportBuffers.EXPORT_BUFFERS_KEY key.
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.GraphHandler.TimerStream
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
setStreamContext(StreamContext) - Method in class org.apache.solr.handler.StreamHandler.TimerStream
 
setString(String) - Method in class org.apache.solr.search.FunctionQParser
 
setString(String) - Method in class org.apache.solr.search.QParser
 
setSuggestionsMayOverlap(boolean) - Method in class org.apache.solr.spelling.SpellCheckCollator
 
setSupersetMaxDoc(int) - Method in class org.apache.solr.search.QueryCommand
 
setSuspendTimeout(long, TimeUnit) - Method in class org.apache.solr.jersey.container.JettyBridgeResponseWriter
 
setSynonymQueryStyle(SolrQueryParserBase.SynonymQueryStyle) - Method in class org.apache.solr.parser.SolrQueryParserBase
Set how overlapping query terms (ie synonyms) should be scored, as if they're the same term, picking highest scoring term, or OR'ing them together
setSystemInfoHandler(SystemInfoHandler) - Method in class org.apache.solr.handler.admin.InfoHandler
 
setTaggable(boolean) - Method in interface org.apache.solr.handler.tagger.TaggingAttribute
Setter for the taggable state.
setTaggable(boolean) - Method in class org.apache.solr.handler.tagger.TaggingAttributeImpl
 
setTaskCompleted(String, OverseerSolrResponse) - Method in class org.apache.solr.cloud.DistributedApiAsyncTracker
Mark the completion (success or error) of an async task.
setTaskRunning(String) - Method in class org.apache.solr.cloud.DistributedApiAsyncTracker
Initially an async task is submitted.
setTaskStatusCheckUUID(String) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setTermEqualsToLeader(String) - Method in class org.apache.solr.cloud.ZkShardTerms
Set a replica's term equals to leader's term, and remove recovering flag of a replica.
setTerminateEarly(boolean) - Method in class org.apache.solr.search.QueryCommand
 
setTermToZero(String) - Method in class org.apache.solr.cloud.ZkShardTerms
Set a replica's term to 0.
setThreadDumpHandler(ThreadDumpHandler) - Method in class org.apache.solr.handler.admin.InfoHandler
 
setThreshold(double) - Method in class org.apache.solr.util.circuitbreaker.CPUCircuitBreaker
 
setThreshold(double) - Method in class org.apache.solr.util.circuitbreaker.LoadAverageCircuitBreaker
 
setThreshold(double) - Method in class org.apache.solr.util.circuitbreaker.MemoryCircuitBreaker
 
setThreshold(String) - Method in class org.apache.solr.logging.jul.JulWatcher
 
setThreshold(String) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
setThreshold(String) - Method in class org.apache.solr.logging.LogWatcher
 
setThreshold(Level) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher.Log4j2Appender
 
SetThresholdRequestBody() - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.SetThresholdRequestBody
 
SetThresholdRequestBody(String) - Constructor for class org.apache.solr.handler.admin.api.NodeLoggingAPI.SetThresholdRequestBody
 
setTimeAllowed(long) - Method in class org.apache.solr.search.QueryCommand
 
setTimer(RTimer) - Method in class org.apache.solr.handler.component.ResponseBuilder
 
setTimerSupplier(PluginInfo) - Method in class org.apache.solr.core.MetricsConfig.MetricsConfigBuilder
 
setTimeUpperBound(long) - Method in class org.apache.solr.update.CommitTracker
 
setTLogFileSizeUpperBound(int) - Method in class org.apache.solr.update.CommitTracker
 
setToField(String) - Method in class org.apache.solr.search.join.GraphQuery
 
setTokens(Collection<Token>) - Method in class org.apache.solr.spelling.SpellingResult
 
setTokenStream(TokenStream) - Method in class org.apache.solr.legacy.LegacyField
Deprecated.
 
setTopNGroups(int) - Method in class org.apache.solr.search.grouping.distributed.command.SearchGroupsFieldCommand.Builder
 
setTracerConfig(PluginInfo) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setTracerId(String) - Static method in class org.apache.solr.logging.MDCLoggingContext
 
setTrainingClassField(String) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setTrainingFilterQuery(Query) - Method in class org.apache.solr.update.processor.ClassificationUpdateProcessorParams
 
setTransientCacheSize(int) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
Deprecated.
setTraversalFilter(Query) - Method in class org.apache.solr.search.join.GraphQuery
 
setTruncateGroups(boolean) - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
 
setTruncateGroups(boolean) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setUnknownProperty(String, Map<String, ZookeeperReadAPI.AnnotatedStat>) - Method in class org.apache.solr.handler.admin.ZookeeperReadAPI.ListZkChildrenResponse
 
setup(Http2SolrClient) - Method in interface org.apache.solr.security.HttpClientBuilderPlugin
 
setup(Http2SolrClient) - Method in class org.apache.solr.security.PKIAuthenticationPlugin
 
setup(ElectionContext) - Method in class org.apache.solr.cloud.LeaderElector
Set up any ZooKeeper nodes needed for leader election.
setupCommand - Variable in class org.apache.solr.packagemanager.SolrPackage.Plugin
 
setUpdateShardHandlerConfig(UpdateShardHandlerConfig) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setupExampleDir(File, File, String) - Method in class org.apache.solr.cli.RunExampleTool
 
setupIfNeeded(CollapsingQParserPlugin.GroupHeadSelector, Map<? super String, ? super CollapsingQParserPlugin.CollapseScore>) - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapseScore
Inspects the GroupHeadSelector to determine if this CollapseScore is needed.
setUpperWaterMark(int) - Method in class org.apache.solr.util.ConcurrentLRUCache
 
setupRequest(String, SolrInputDocument, String, UpdateCommand) - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
setUrl(String) - Method in class org.apache.solr.cli.ExportTool.Info
 
setUseAutn(boolean) - Method in class org.apache.solr.search.join.GraphQuery
 
setUseDistributedClusterStateUpdates(boolean) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setUseDistributedCollectionConfigSetExecution(boolean) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setUseGenericCoreNames(boolean) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setUsername(String) - Method in class org.apache.solr.security.AuditEvent
 
setUserPrincipalName(String) - Method in class org.apache.solr.request.LocalSolrQueryRequest
Allows setting the 'name' of the User Principal for the purposes of creating local requests in a solr node when security is enabled.
setUserProperty(String, Object) - Method in class org.apache.solr.core.ConfigOverlay
 
setUserRole(PayloadObj<Map<String, Object>>) - Method in class org.apache.solr.handler.admin.api.ModifyRuleBasedAuthConfigAPI
 
setUseSchemaCache(boolean) - Method in class org.apache.solr.core.NodeConfig.NodeConfigBuilder
 
setUseServerToken(boolean) - Method in class org.apache.solr.request.SolrRequestInfo
 
setValue(SolrDocument, Object) - Method in class org.apache.solr.response.transform.ValueSourceAugmenter
 
setValues(SimpleOrderedMap<Object>, int) - Method in class org.apache.solr.search.facet.SlotAcc
 
setVersion(int) - Method in class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
Sets version
setVersion(long) - Method in class org.apache.solr.update.UpdateCommand
 
setWaitForSecond(int) - Method in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
setWaitForUpdatesWithStaleStatePauseMilliSeconds(int) - Method in class org.apache.solr.cloud.RecoveryStrategy
 
setWeakStringInterner() - Static method in class org.apache.solr.core.CoreContainer
 
setWithinGroupSort(Sort) - Method in class org.apache.solr.search.Grouping
 
setWithinGroupSortSpec(SortSpec) - Method in class org.apache.solr.search.grouping.GroupingSpecification
 
setWrappedQuery(Query) - Method in class org.apache.solr.search.WrappedQuery
 
setWriteListener(WriteListener) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
setWriteListener(WriteListener) - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletOutputStream
 
setWrittenCount(long) - Method in class org.apache.solr.update.TransactionLog
Sets the counter of written data in the FastOutputStream view of the log file, to reflect that we aren't starting at the beginning.
setWt(SolrQueryRequest, String) - Static method in class org.apache.solr.handler.RequestHandlerUtils
 
setZkACLProviderClass(String) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setZkClientTimeout(int) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setZkCredentialsInjectorClass(String) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setZkCredentialsProviderClass(String) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setZkHost(String) - Method in class org.apache.solr.core.CloudConfig.CloudConfigBuilder
 
setZkIndexSchemaReader(ZkIndexSchemaReader) - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
 
sha256(String, String) - Static method in class org.apache.solr.security.Sha256AuthenticationProvider
 
Sha256AuthenticationProvider - Class in org.apache.solr.security
 
Sha256AuthenticationProvider() - Constructor for class org.apache.solr.security.Sha256AuthenticationProvider
 
SHA512 - Static variable in class org.apache.solr.filestore.FileStoreAPI.MetaData
 
sha512Digest(ByteBuffer) - Static method in class org.apache.solr.core.BlobRepository
 
shapeReader - Variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
shapeToString(Shape) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
Returns a String version of a shape to be used for the stored value.
shapeToString(Shape) - Method in class org.apache.solr.schema.DateRangeField
 
shapeWriter - Variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
shard - org.apache.solr.core.SolrInfoBean.Group
 
shard - Variable in class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
shard - Variable in class org.apache.solr.handler.component.ShardDoc
 
shard - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
Shard - Interface in org.apache.solr.cluster
Shard in a SolrCollection, i.e.
SHARD_HANDLER_SUFFIX - Static variable in class org.apache.solr.handler.component.SearchHandler
 
SHARD_ID - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
SHARD_PURPOSE - Static variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent
The only shard purpose that will cause this component to do work & return data during shard req
SHARD_UNIQUE - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
Shard.ShardState - Enum in org.apache.solr.cluster
 
shardAddress - Variable in class org.apache.solr.handler.component.ShardDoc
 
ShardAugmenterFactory - Class in org.apache.solr.response.transform
 
ShardAugmenterFactory() - Constructor for class org.apache.solr.response.transform.ShardAugmenterFactory
 
ShardAugmenterFactory.Style - Enum in org.apache.solr.response.transform
 
shardBackupId - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
ShardBackupId - Class in org.apache.solr.core.backup
Represents the ID of a particular backup point for a particular shard.
ShardBackupId(String, BackupId) - Constructor for class org.apache.solr.core.backup.ShardBackupId
 
ShardBackupMetadata - Class in org.apache.solr.core.backup
Represents the shard-backup metadata file.
ShardBackupMetadata() - Constructor for class org.apache.solr.core.backup.ShardBackupMetadata
 
ShardBackupMetadata.BackedFile - Class in org.apache.solr.core.backup
 
ShardDoc - Class in org.apache.solr.handler.component
 
ShardDoc() - Constructor for class org.apache.solr.handler.component.ShardDoc
 
ShardDoc(float, Object[], Object, String) - Constructor for class org.apache.solr.handler.component.ShardDoc
 
ShardFacetCount() - Constructor for class org.apache.solr.handler.component.FacetComponent.ShardFacetCount
 
ShardFieldSortedHitQueue - Class in org.apache.solr.handler.component
 
ShardFieldSortedHitQueue(SortField[], int, IndexSearcher) - Constructor for class org.apache.solr.handler.component.ShardFieldSortedHitQueue
 
ShardHandler - Class in org.apache.solr.handler.component
 
ShardHandler() - Constructor for class org.apache.solr.handler.component.ShardHandler
 
shardHandlerFactory - Variable in class org.apache.solr.core.CoreContainer
 
ShardHandlerFactory - Class in org.apache.solr.handler.component
 
ShardHandlerFactory() - Constructor for class org.apache.solr.handler.component.ShardHandlerFactory
 
shardHasContributed(int) - Method in class org.apache.solr.handler.component.PivotFacetValue
A NON-Recursive method indicating if the specified shard has already contributed to the count for this value.
shardId - Variable in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
ShardMetrics - Interface in org.apache.solr.cluster.placement
Shard-level metrics.
ShardMetricsBuilder(String) - Constructor for class org.apache.solr.cluster.placement.impl.CollectionMetricsBuilder.ShardMetricsBuilder
 
shardNames - Variable in class org.apache.solr.cloud.api.collections.Assign.AssignRequest
 
ShardRequest - Class in org.apache.solr.handler.component
 
ShardRequest() - Constructor for class org.apache.solr.handler.component.ShardRequest
 
ShardRequestFactory - Interface in org.apache.solr.search.grouping.distributed
Responsible for creating shard requests to the shards in the cluster to perform distributed grouping.
ShardRequestTracker(String, String, ZkStateReader, ShardHandlerFactory) - Constructor for class org.apache.solr.cloud.api.collections.CollectionHandlingUtils.ShardRequestTracker
 
ShardResponse - Class in org.apache.solr.handler.component
 
ShardResponse() - Constructor for class org.apache.solr.handler.component.ShardResponse
 
ShardResponseProcessor - Interface in org.apache.solr.search.grouping.distributed
Responsible for processing shard responses.
ShardResultTransformer<T,​R> - Interface in org.apache.solr.search.grouping.distributed.shardresultserializer
A ShardResultTransformer is responsible for transforming a grouped shard result into group related structures (such as TopGroups and SearchGroup) and visa versa.
shards - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
shards - Variable in class org.apache.solr.handler.component.ShardRequest
 
shards() - Method in interface org.apache.solr.cluster.SolrCollection
Allow foreach iteration on shards such as: for (Shard s : solrCollection.shards()) {...}.
SHARDS - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
SHARDS_PROP - Static variable in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
shards_rows - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
shards_start - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
SHARDSPLIT_CHECKDISKSPACE_ENABLED - Static variable in class org.apache.solr.cloud.api.collections.SplitShardCmd
 
shardUrlToShard(String, String) - Static method in class org.apache.solr.search.stats.StatsUtil
Parse a list of urls separated by "|" in order to retrieve a shard name.
SHIFT_START_INT - Static variable in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Integers are stored at lower precision by shifting off lower bits.
SHIFT_START_LONG - Static variable in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Longs are stored at lower precision by shifting off lower bits.
shortCircuitedURL - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
shouldAudit() - Method in class org.apache.solr.servlet.HttpSolrCall
 
shouldAudit(CoreContainer) - Static method in class org.apache.solr.servlet.HttpSolrCall
 
shouldAudit(CoreContainer, AuditEvent.EventType) - Static method in class org.apache.solr.servlet.HttpSolrCall
 
shouldAudit(AuditEvent.EventType) - Method in class org.apache.solr.servlet.HttpSolrCall
 
shouldCloneCmdDoc() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
shouldCloneCmdDoc() - Method in class org.apache.solr.update.processor.DistributedZkUpdateProcessor
 
shouldCommit(CommitUpdateCommand, IndexWriter) - Method in class org.apache.solr.update.DirectUpdateHandler2
Determines whether the commit command should effectively trigger a commit on the index writer.
shouldExit() - Method in class org.apache.solr.search.SolrQueryTimeoutImpl
Return true if a timeoutAt value is set and the current time has exceeded the set timeOut.
shouldLog(AuditEvent.EventType) - Method in class org.apache.solr.security.AuditLoggerPlugin
Checks whether this event type should be logged based on "eventTypes" config parameter.
shouldLog(AuditEvent.EventType) - Method in class org.apache.solr.security.MultiDestinationAuditLogger
 
shouldMutate(String) - Method in interface org.apache.solr.update.processor.FieldMutatingUpdateProcessor.FieldNameSelector
 
shouldMute(AuditEvent) - Method in interface org.apache.solr.security.AuditLoggerPlugin.MuteRule
 
shouldMute(AuditEvent) - Method in class org.apache.solr.security.AuditLoggerPlugin
Returns true if any of the configured mute rules matches.
shouldRemoveStopFilter(ExtendedDismaxQParser.ExtendedDismaxConfiguration, Query) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Determines if query should be re-parsed removing the stop filter.
shouldRetry(SolrCmdDistributor.SolrError) - Method in class org.apache.solr.update.SolrCmdDistributor.Req
 
shouldReverse(String) - Method in class org.apache.solr.analysis.ReversedWildcardFilterFactory
This method encapsulates the logic that determines whether a query token should be reversed in order to use the reversed terms in the index.
shouldSkipField(String) - Method in class org.apache.solr.response.TabularResponseWriter
Returns true if field needs to be skipped else false
shouldWriteRaw(String, ReturnFields) - Method in class org.apache.solr.response.TextResponseWriter
NOTE: strict object equality check against TextResponseWriter.rawReturnFields; see javadocs for TextResponseWriter.NO_RAW_FIELDS
SHOW_DEFAULTS - Static variable in class org.apache.solr.rest.BaseSolrResource
 
ShowFileRequestHandler - Class in org.apache.solr.handler.admin
This handler uses the RawResponseWriter to give client access to files inside ${solr.home}/conf
ShowFileRequestHandler() - Constructor for class org.apache.solr.handler.admin.ShowFileRequestHandler
 
shrink() - Method in class org.apache.solr.internal.csv.CharBuffer
Shrinks the capacity of the buffer to the current length if necessary.
shrink(int[], int) - Static method in class org.apache.solr.search.SortedIntDocSet
 
shuffledNodes() - Method in class org.apache.solr.filestore.FileStoreAPI
get a list of nodes randomly shuffled * @lucene.internal
shutdown() - Method in class org.apache.solr.core.CoreContainer
 
shutdown() - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
shutdown() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
Method to ensure shutting down of the ThreadPool Executor.
shutdown() - Method in class org.apache.solr.handler.ReplicationHandler
 
shutdown() - Method in class org.apache.solr.update.StreamingSolrClients
 
shutdown() - Static method in class org.apache.solr.util.StartupLoggingUtils
Perhaps odd to put in startup utils, but this is where the logging-init code is so it seems logical to put the shutdown here too.
shutdownAndAwaitTermination() - Method in class org.apache.solr.util.OrderedExecutor
 
ShutdownAwareDirectory - Interface in org.apache.solr.core
CachingDirectoryFactory will call this method rather than Directory.close() on shutdown if a Directory implements this interface.
sig - Variable in class org.apache.solr.packagemanager.SolrPackage.Artifact
 
signalAll() - Method in class org.apache.solr.update.TimedVersionBucket
 
signalAll() - Method in class org.apache.solr.update.VersionBucket
 
Signature - Class in org.apache.solr.update.processor
 
Signature() - Constructor for class org.apache.solr.update.processor.Signature
 
SignatureUpdateProcessorFactory - Class in org.apache.solr.update.processor
 
SignatureUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
 
SignificantTermsQParserPlugin - Class in org.apache.solr.search
 
SignificantTermsQParserPlugin() - Constructor for class org.apache.solr.search.SignificantTermsQParserPlugin
 
signSha256(byte[]) - Method in class org.apache.solr.util.CryptoKeys.RSAKeyPair
 
similarity - Variable in class org.apache.solr.schema.FieldType
 
similarity - Variable in class org.apache.solr.schema.IndexSchema
 
SIMILARITY - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
SIMILARITY - Static variable in class org.apache.solr.schema.FieldType
 
SIMILARITY - Static variable in class org.apache.solr.schema.IndexSchema
 
similarityFactory - Variable in class org.apache.solr.schema.FieldType
 
similarityFactory - Variable in class org.apache.solr.schema.IndexSchema
 
SimilarityFactory - Class in org.apache.solr.schema
A factory interface for configuring a Similarity in the Solr schema.xml.
SimilarityFactory() - Constructor for class org.apache.solr.schema.SimilarityFactory
 
simple - org.apache.solr.search.Grouping.Format
Flat result.
SIMPLE - org.apache.solr.search.facet.FacetRequest.RefineMethod
 
SIMPLE - Static variable in class org.apache.solr.servlet.SolrRequestParsers
 
SIMPLE_END_RESULT_TRANSFORMER - Static variable in class org.apache.solr.handler.component.QueryComponent
 
SimpleAggValueSource - Class in org.apache.solr.search.facet
 
SimpleAggValueSource(String, ValueSource) - Constructor for class org.apache.solr.search.facet.SimpleAggValueSource
 
SimpleBoundaryScanner - Class in org.apache.solr.highlight
 
SimpleBoundaryScanner() - Constructor for class org.apache.solr.highlight.SimpleBoundaryScanner
 
SimpleEndResultTransformer - Class in org.apache.solr.search.grouping.endresulttransformer
Implementation of EndResultTransformer that transforms the grouped result into a single flat list.
SimpleEndResultTransformer() - Constructor for class org.apache.solr.search.grouping.endresulttransformer.SimpleEndResultTransformer
 
SimpleFacets - Class in org.apache.solr.request
A class that generates simple Facet information for a request.
SimpleFacets(SolrQueryRequest, DocSet, SolrParams) - Constructor for class org.apache.solr.request.SimpleFacets
 
SimpleFacets(SolrQueryRequest, DocSet, SolrParams, ResponseBuilder) - Constructor for class org.apache.solr.request.SimpleFacets
 
SimpleFacets.CountPair<K extends Comparable<? super K>,​V extends Comparable<? super V>> - Class in org.apache.solr.request
A simple key=>val pair whose natural order is such that higher vals come before lower vals.
SimpleFacets.ParsedParams - Class in org.apache.solr.request
 
SimpleFragListBuilder - Class in org.apache.solr.highlight
 
SimpleFragListBuilder() - Constructor for class org.apache.solr.highlight.SimpleFragListBuilder
 
SimpleFragmentsBuilder - Class in org.apache.solr.highlight
 
SimpleFragmentsBuilder() - Constructor for class org.apache.solr.highlight.SimpleFragmentsBuilder
 
SimpleMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for simple MergePolicy objects.
SimpleMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.SimpleMergePolicyFactory
 
SimpleMLTQParser - Class in org.apache.solr.search.mlt
 
SimpleMLTQParser(String, SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.mlt.SimpleMLTQParser
 
SimplePlacementContextImpl - Class in org.apache.solr.cluster.placement.impl
Implementation of PlacementContext that uses SimpleClusterAbstractionsImpl to create components necessary for the placement plugins to use.
SimplePlacementContextImpl(SolrCloudManager) - Constructor for class org.apache.solr.cluster.placement.impl.SimplePlacementContextImpl
 
SimplePlacementFactory - Class in org.apache.solr.cluster.placement.plugins
Factory for creating SimplePlacementFactory.SimplePlacementPlugin, a placement plugin implementing the logic from the old LegacyAssignStrategy.
SimplePlacementFactory() - Constructor for class org.apache.solr.cluster.placement.plugins.SimplePlacementFactory
 
SimplePlacementFactory.SimplePlacementPlugin - Class in org.apache.solr.cluster.placement.plugins
 
SimplePlacementPlugin() - Constructor for class org.apache.solr.cluster.placement.plugins.SimplePlacementFactory.SimplePlacementPlugin
 
SimplePostTool - Class in org.apache.solr.cli
Deprecated.
This class is being replaced with bin/solr tool. Please use PostTool instead.
SimplePostTool() - Constructor for class org.apache.solr.cli.SimplePostTool
Deprecated.
 
SimplePostTool(String, URL, boolean, String, String, int, int, String, OutputStream, boolean, boolean, String[]) - Constructor for class org.apache.solr.cli.SimplePostTool
Deprecated.
Constructor which takes in all mandatory input for the tool to work.
SimplePostTool.PageFetcherResult - Class in org.apache.solr.cli
Deprecated.
Utility class to hold the result form a page fetch
SimplePreAnalyzedParser - Class in org.apache.solr.schema
Simple plain text format parser for PreAnalyzedField.
SimplePreAnalyzedParser() - Constructor for class org.apache.solr.schema.SimplePreAnalyzedParser
 
SimplePropagator - Class in org.apache.solr.util.tracing
 
SimplePropagator() - Constructor for class org.apache.solr.util.tracing.SimplePropagator
 
SimpleQParserPlugin - Class in org.apache.solr.search
Create a query from the input value that will be parsed by Lucene's SimpleQueryParser.
SimpleQParserPlugin() - Constructor for class org.apache.solr.search.SimpleQParserPlugin
 
SimpleTextCodecFactory - Class in org.apache.solr.core
 
SimpleTextCodecFactory() - Constructor for class org.apache.solr.core.SimpleTextCodecFactory
 
SimpleUpdateProcessorFactory - Class in org.apache.solr.update.processor
A base class for writing a very simple UpdateProcessor without worrying too much about the API.
SimpleUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.SimpleUpdateProcessorFactory
 
SingleCoreStatusAPI - Class in org.apache.solr.handler.admin.api
V2 API for checking the status of a specific core.
SingleCoreStatusAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.SingleCoreStatusAPI
 
SingleFragListBuilder - Class in org.apache.solr.highlight
 
SingleFragListBuilder() - Constructor for class org.apache.solr.highlight.SingleFragListBuilder
 
SingletonFactory(T) - Constructor for class org.apache.solr.jersey.InjectionFactories.SingletonFactory
 
size - Variable in class org.apache.solr.core.backup.Checksum
 
size - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileMetaData
 
size - Variable in class org.apache.solr.logging.ListenerConfig
 
size - Variable in class org.apache.solr.util.LongPriorityQueue
 
size() - Method in class org.apache.solr.cloud.DistributedMap
 
size() - Method in interface org.apache.solr.filestore.FileStore.FileDetails
 
size() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Total number of PivotFacetValues, including the "missing" value if used.
size() - Method in class org.apache.solr.handler.component.QueryElevationComponent.DefaultElevationProvider
 
size() - Method in interface org.apache.solr.handler.component.QueryElevationComponent.ElevationProvider
Gets the number of query elevations in this QueryElevationComponent.ElevationProvider.
size() - Method in class org.apache.solr.jersey.JerseyAppHandlerCache
 
size() - Method in class org.apache.solr.logging.CircularList
 
size() - Method in class org.apache.solr.metrics.AggregateMetric
 
size() - Method in class org.apache.solr.response.transform.DocTransformers
 
size() - Method in class org.apache.solr.search.BitDocSet
 
size() - Method in class org.apache.solr.search.CaffeineCache
 
size() - Method in interface org.apache.solr.search.DocList
Returns the number of ids in this list.
size() - Method in class org.apache.solr.search.DocSet
Returns the number of documents in the set.
size() - Method in class org.apache.solr.search.DocSetCollector.ExpandingIntArray
 
size() - Method in class org.apache.solr.search.DocSetCollector
The number of documents that have been collected
size() - Method in class org.apache.solr.search.DocSlice
 
size() - Method in interface org.apache.solr.search.SolrCache
:TODO: copy from Map
size() - Method in class org.apache.solr.search.SortedIntDocSet
 
size() - Method in class org.apache.solr.util.ConcurrentLRUCache
 
size() - Method in class org.apache.solr.util.LongPriorityQueue
Returns the number of elements currently stored in the PriorityQueue.
size() - Method in class org.apache.solr.util.MapListener
 
size(String) - Method in class org.apache.solr.core.DirectoryFactory
 
size(Directory) - Method in class org.apache.solr.core.DirectoryFactory
 
SIZE - Static variable in class org.apache.solr.handler.ReplicationHandler
 
SIZE_COMMIT_DELAY_MS - Static variable in class org.apache.solr.update.CommitTracker
 
SIZE_INFO_PARAM - Static variable in class org.apache.solr.handler.admin.SegmentsInfoRequestHandler
 
SIZE_INFO_PROP - Static variable in class org.apache.solr.handler.admin.ColStatus
 
SIZE_PARAM - Static variable in interface org.apache.solr.search.SolrCache
 
SizeLimitedDistributedMap - Class in org.apache.solr.cloud
A size limited distributed map maintained in zk.
SizeLimitedDistributedMap(SolrZkClient, String, int) - Constructor for class org.apache.solr.cloud.SizeLimitedDistributedMap
 
SizeLimitedDistributedMap(SolrZkClient, String, int, SizeLimitedDistributedMap.OnOverflowObserver) - Constructor for class org.apache.solr.cloud.SizeLimitedDistributedMap
 
sizeOf(Directory, String) - Static method in class org.apache.solr.core.DirectoryFactory
 
sizeOfDirectory(Directory) - Static method in class org.apache.solr.core.DirectoryFactory
 
sizeOfIndexedStrings - Variable in class org.apache.solr.uninverting.DocTermOrds
Total bytes (sum of term lengths) for all indexed terms.
skip(int) - Method in class org.apache.solr.search.StrParser
 
skip(long) - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
SKIP - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
SKIP_ALT_TOKENS - Static variable in class org.apache.solr.handler.tagger.TaggerRequestHandler
Request parameter.
SKIP_COMMIT_ON_LEADER_VERSION_ZERO - Static variable in class org.apache.solr.handler.ReplicationHandler
 
SKIP_FACET - Static variable in class org.apache.solr.search.facet.FacetContext
 
SKIP_FIELD_VALUE_LIST_SINGLETON - Static variable in class org.apache.solr.update.processor.AllValuesOrNoneFieldMutatingUpdateProcessor
 
skipAggregateValues(boolean) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Individual values from AggregateMetric may not be worth to report.
skipArray(JSONParser, String, boolean) - Static method in class org.apache.solr.request.json.JSONUtil
 
SkipExistingDocumentsProcessorFactory - Class in org.apache.solr.update.processor
This Factory generates an UpdateProcessor that will (by default) skip inserting new documents if there already exists a document with the same uniqueKey value in the index.
SkipExistingDocumentsProcessorFactory() - Constructor for class org.apache.solr.update.processor.SkipExistingDocumentsProcessorFactory
 
skipHistograms(boolean) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Histograms are difficult / impossible to aggregate, so it may not be worth to report them.
skipIndexWriterCommitOnClose - Static variable in class org.apache.solr.util.TestInjection
Defaults to false, If set to true, then TestInjection.injectSkipIndexWriterCommitOnClose(java.lang.Object) will return true
SKIPLINES - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
skipSendingUpdatesTo(String) - Method in class org.apache.solr.cloud.ZkShardTerms
Should leader skip sending updates to this replica?
sleep(long) - Method in class org.apache.solr.util.TimeOut
 
SLICE_UNIQUE_BOOLEAN_PROPERTIES - Static variable in class org.apache.solr.cloud.overseer.SliceMutator
 
SliceAddReplica - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
SliceAddRoutingRule - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
sliceCmd(ClusterState, ModifiableSolrParams, Replica.State, Slice, ShardHandler) - Method in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils.ShardRequestTracker
Send request to all replicas of a slice
SliceMutator - Class in org.apache.solr.cloud.overseer
 
SliceMutator(SolrCloudManager) - Constructor for class org.apache.solr.cloud.overseer.SliceMutator
 
sliceName - Variable in class org.apache.solr.cloud.api.collections.AddReplicaCmd.CreateReplica
 
SliceRemoveReplica - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
SliceRemoveRoutingRule - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
slices - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
SliceSetShardLeader - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
SliceUpdateShardState - org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
 
SlotAcc - Class in org.apache.solr.search.facet
Accumulates statistics separated by a slot number.
SlotAcc(FacetContext) - Constructor for class org.apache.solr.search.facet.SlotAcc
 
SlotAcc.DoubleFuncSlotAcc - Class in org.apache.solr.search.facet
 
SlotAcc.FuncSlotAcc - Class in org.apache.solr.search.facet
 
SlotAcc.IntSlotAcc - Class in org.apache.solr.search.facet
 
SlotAcc.LongFuncSlotAcc - Class in org.apache.solr.search.facet
 
SlotAcc.Resizer - Class in org.apache.solr.search.facet
 
SlotAcc.SlotContext - Class in org.apache.solr.search.facet
Incapsulates information about the current slot, for Accumulators that may want additional info during collection.
SlotContext(Query) - Constructor for class org.apache.solr.search.facet.SlotAcc.SlotContext
 
SlowCompositeReaderWrapper - Class in org.apache.solr.index
This class forces a composite reader (eg a MultiReader or DirectoryReader) to emulate a LeafReader.
slowQueryThresholdMillis - Variable in class org.apache.solr.core.SolrConfig
 
smallSetSize(int) - Static method in class org.apache.solr.search.DocSetUtil
The cut-off point for small sets (SortedIntDocSet) vs large sets (BitDocSet)
SMART - org.apache.solr.search.facet.FacetField.FacetMethod
 
SmileResponseWriter - Class in org.apache.solr.response
 
SmileResponseWriter() - Constructor for class org.apache.solr.response.SmileResponseWriter
 
SmileResponseWriter.SmileWriter - Class in org.apache.solr.response
 
SmileWriter(OutputStream, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
SnapShooter - Class in org.apache.solr.handler
Provides functionality equivalent to the snapshooter script This is no longer used in standard replication.
SnapShooter(BackupRepository, SolrCore, URI, String, String) - Constructor for class org.apache.solr.handler.SnapShooter
 
SnapShooter(SolrCore, String, String) - Constructor for class org.apache.solr.handler.SnapShooter
Deprecated.
SnapShooter.CoreSnapshotResponse - Class in org.apache.solr.handler
 
snapshot(String, String, long) - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
This method creates a new snapshot meta-data entry.
SNAPSHOT_METADATA_DIR - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
 
SNAPSHOT_REPLICAS - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
SNAPSHOT_STATUS - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
SnapshotBackupAPI - Class in org.apache.solr.handler.admin.api
V2 endpoint for Backup API used for User-Managed clusters and Single-Node Installation.
SnapshotBackupAPI(SolrCore, ReplicationHandler.ReplicationHandlerConfig) - Constructor for class org.apache.solr.handler.admin.api.SnapshotBackupAPI
 
SnapshotBackupAPI.BackupReplicationRequestBody - Class in org.apache.solr.handler.admin.api
 
SnapshotBackupAPI.BackupReplicationResponse - Class in org.apache.solr.handler.admin.api
snapshotCompletedAt - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
snapshotExists(SolrZkClient, String, String) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method returns if a named snapshot exists for the specified collection.
SnapshotMetaData(String, String, long) - Constructor for class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager.SnapshotMetaData
 
snapshotName - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
snapshots - Variable in class org.apache.solr.handler.admin.api.ListCollectionSnapshotsAPI.ListSnapshotsResponse
 
SNAPSHOTS_INFO - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotManager
 
SNAPSHOTS_PREFIX - Static variable in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
Prefix used for the save file.
SNIPPET_SEPARATOR - Static variable in class org.apache.solr.highlight.UnifiedSolrHighlighter
 
SOFT_COMMIT - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
softCommit - Variable in class org.apache.solr.update.CommitUpdateCommand
 
softCommitCallbacks - Variable in class org.apache.solr.update.UpdateHandler
 
softCommitTracker - Variable in class org.apache.solr.update.DirectUpdateHandler2
 
SOLR_ALLOW_UNSAFE_RESOURCELOADING_PARAM - Static variable in class org.apache.solr.core.SolrResourceLoader
 
SOLR_CONFIG_XML - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
SOLR_CORE - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
SOLR_CORE_PROP_PREFIX - Static variable in class org.apache.solr.core.CoreDescriptor
 
SOLR_DATA_HOME - Static variable in class org.apache.solr.core.SolrXmlConfig
 
SOLR_DEFAULT_COMPRESSION_MODE - Static variable in class org.apache.solr.core.SchemaCodecFactory
 
SOLR_DEFAULT_CONFDIR_ATTRIBUTE - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
SOLR_INSTALL_DIR_ATTRIBUTE - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
SOLR_JERSEY_RESPONSE - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
SOLR_JETTY - org.apache.solr.cluster.placement.NodeMetric.Registry
corresponds to solr.jetty
SOLR_JVM - org.apache.solr.cluster.placement.NodeMetric.Registry
corresponds to solr.jvm
SOLR_LOG_LEVEL - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
SOLR_LOG_MUTECONSOLE - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
SOLR_NODE - org.apache.solr.cluster.placement.NodeMetric.Registry
corresponds to solr.node
SOLR_PARAMS - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
SOLR_QUERY_REQUEST - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
SOLR_QUERY_RESPONSE - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
SOLR_SSL_CLIENT_KEY_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider.EnvVars
 
SOLR_SSL_CLIENT_TRUST_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider.EnvVars
 
SOLR_SSL_KEY_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider.EnvVars
 
SOLR_SSL_TRUST_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.providers.EnvSSLCredentialProvider.EnvVars
 
SOLR_URL - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
SOLR_XML_FILE - Static variable in class org.apache.solr.core.SolrXmlConfig
 
SolrAnalyzer - Class in org.apache.solr.analysis
 
SolrAnalyzer() - Constructor for class org.apache.solr.analysis.SolrAnalyzer
 
SolrApacheHttpRequestCarrier - Class in org.apache.solr.util.tracing
An OpenTracing Carrier for injecting Span context through an Apache HttpRequest
SolrApacheHttpRequestCarrier(HttpRequest) - Constructor for class org.apache.solr.util.tracing.SolrApacheHttpRequestCarrier
 
SolrAuthenticationException - Exception in org.apache.solr.servlet
 
SolrAuthenticationException() - Constructor for exception org.apache.solr.servlet.SolrAuthenticationException
 
solrBaseUrl - Static variable in class org.apache.solr.cli.PackageTool
 
SolrBoundaryScanner - Class in org.apache.solr.highlight
 
SolrBoundaryScanner() - Constructor for class org.apache.solr.highlight.SolrBoundaryScanner
 
SolrCache<K,​V> - Interface in org.apache.solr.search
Primary API for dealing with Solr's internal caches.
SolrCache.State - Enum in org.apache.solr.search
Enumeration of possible States for cache instances.
SolrCacheBase - Class in org.apache.solr.search
Common base class of reusable functionality for SolrCaches
SolrCacheBase() - Constructor for class org.apache.solr.search.SolrCacheBase
 
SolrCacheBase.AutoWarmCountRef - Class in org.apache.solr.search
Decides how many things to autowarm based on the size of another cache
solrClassLoader - Variable in class org.apache.solr.schema.IndexSchema
 
SolrCLI - Class in org.apache.solr.cli
Command-line utility for working with Solr.
SolrCLI() - Constructor for class org.apache.solr.cli.SolrCLI
 
SolrCLI.AssertionFailureException - Exception in org.apache.solr.cli
 
SolrCmdDistributor - Class in org.apache.solr.update
Used for distributing commands from a shard leader to its replicas.
SolrCmdDistributor(UpdateShardHandler) - Constructor for class org.apache.solr.update.SolrCmdDistributor
 
SolrCmdDistributor.ForwardNode - Class in org.apache.solr.update
 
SolrCmdDistributor.Node - Class in org.apache.solr.update
 
SolrCmdDistributor.Req - Class in org.apache.solr.update
 
SolrCmdDistributor.Response - Class in org.apache.solr.update
 
SolrCmdDistributor.SolrError - Class in org.apache.solr.update
 
SolrCmdDistributor.StdNode - Class in org.apache.solr.update
 
SolrCollection - Interface in org.apache.solr.cluster
Represents a Collection in SolrCloud (unrelated to Collection that uses the nicer name).
SolrComparisonBoolFunction - Class in org.apache.solr.search.function
Refines ComparisonBoolFunction to compare based on a 'long' or 'double' depending on if the any of the FunctionValues are LongDocValues.
SolrComparisonBoolFunction(ValueSource, ValueSource, String, SolrComparisonBoolFunction.Compare) - Constructor for class org.apache.solr.search.function.SolrComparisonBoolFunction
 
SolrComparisonBoolFunction.Compare - Interface in org.apache.solr.search.function
 
SolrConfig - Class in org.apache.solr.core
Provides a static reference to a Config object modeling the main configuration data for a Solr instance -- typically found in "solrconfig.xml".
SolrConfig(Path, String) - Constructor for class org.apache.solr.core.SolrConfig
TEST-ONLY: Creates a configuration instance from an instance directory and file name
SolrConfig.HttpCachingConfig - Class in org.apache.solr.core
 
SolrConfig.HttpCachingConfig.LastModFrom - Enum in org.apache.solr.core
 
SolrConfig.PluginOpts - Enum in org.apache.solr.core
 
SolrConfig.SolrPluginInfo - Class in org.apache.solr.core
 
SolrConfig.UpdateHandlerInfo - Class in org.apache.solr.core
 
SolrConfigHandler - Class in org.apache.solr.handler
 
SolrConfigHandler() - Constructor for class org.apache.solr.handler.SolrConfigHandler
 
solrConfigHighlighter - Variable in class org.apache.solr.handler.component.HighlightComponent
 
solrCore - Variable in class org.apache.solr.handler.admin.api.GetSchema
 
solrCore - Variable in class org.apache.solr.handler.admin.api.ReplicationAPIBase
 
solrCore - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
 
SolrCore - Class in org.apache.solr.core
SolrCore got its name because it represents the "core" of Solr -- one index and everything needed to make it work.
SolrCore.Provider - Class in org.apache.solr.core
Provides the core instance if the core instance is still alive.
SolrCore.RawWriter - Interface in org.apache.solr.core
 
SolrCoreApp() - Constructor for class org.apache.solr.jersey.JerseyApplications.SolrCoreApp
 
SolrCoreAware - Interface in org.apache.solr.util.plugin
 
SolrCoreContainerReporter - Class in org.apache.solr.metrics
A SolrMetricReporter that has access to its CoreContainer.
SolrCoreContainerReporter(SolrMetricManager, String) - Constructor for class org.apache.solr.metrics.SolrCoreContainerReporter
 
SolrCoreInitializationException - Exception in org.apache.solr.core
 
SolrCoreInitializationException(String, Exception) - Constructor for exception org.apache.solr.core.SolrCoreInitializationException
 
SolrCoreInitializationException(SolrException.ErrorCode, String) - Constructor for exception org.apache.solr.core.SolrCoreInitializationException
 
SolrCoreMetricManager - Class in org.apache.solr.metrics
Helper class for managing registration of SolrMetricProducer's and SolrMetricReporter's specific to a SolrCore instance.
SolrCoreMetricManager(SolrCore) - Constructor for class org.apache.solr.metrics.SolrCoreMetricManager
Constructs a metric manager.
SolrCoreParser - Class in org.apache.solr.search
Assembles a QueryBuilder which uses Query objects from Solr's search module in addition to Query objects supported by the Lucene CoreParser.
SolrCoreParser(String, Analyzer, SolrQueryRequest) - Constructor for class org.apache.solr.search.SolrCoreParser
 
SolrCoreReporter - Class in org.apache.solr.metrics
A FilteringSolrMetricReporter that has access to its SolrCore.
SolrCoreReporter(SolrMetricManager, String) - Constructor for class org.apache.solr.metrics.SolrCoreReporter
 
SolrCores - Class in org.apache.solr.core
AKA CoreManager: Holds/manages SolrCores within CoreContainer.
solrCoreState - Variable in class org.apache.solr.update.DirectUpdateHandler2
 
SolrCoreState - Class in org.apache.solr.update
The state in this class can be easily shared between SolrCores across SolrCore reloads.
SolrCoreState() - Constructor for class org.apache.solr.update.SolrCoreState
 
SolrCoreState.CoreIsClosedException - Exception in org.apache.solr.update
 
SolrCoreState.IndexWriterCloser - Interface in org.apache.solr.update
 
SolrDefaultStreamFactory - Class in org.apache.solr.handler
A default collection of mappings, used to convert strings into stream expressions.
SolrDefaultStreamFactory() - Constructor for class org.apache.solr.handler.SolrDefaultStreamFactory
 
SolrDelegateRegistryMetricsContext - Class in org.apache.solr.metrics
This class represents a metrics context that is delegate aware in that it is aware of multiple metric registries, a primary and a delegate.
SolrDelegateRegistryMetricsContext(SolrMetricManager, String, String, String) - Constructor for class org.apache.solr.metrics.SolrDelegateRegistryMetricsContext
 
SolrDeletionPolicy - Class in org.apache.solr.core
Standard Solr deletion policy that allows reserving index commit points for certain amounts of time to support features such as index replication or snapshotting directly out of a live index directory.
SolrDeletionPolicy() - Constructor for class org.apache.solr.core.SolrDeletionPolicy
 
solrDispatchFilter - Variable in class org.apache.solr.servlet.HttpSolrCall
 
SolrDispatchFilter - Class in org.apache.solr.servlet
This filter looks at the incoming URL maps them to handlers defined in solrconfig.xml
SolrDispatchFilter() - Constructor for class org.apache.solr.servlet.SolrDispatchFilter
 
SolrDispatchFilter.Action - Enum in org.apache.solr.servlet
Enum to define action that needs to be processed.
SolrDispatchFilter.HttpSolrCallFactory - Interface in org.apache.solr.servlet
internal API
solrDoc - Variable in class org.apache.solr.update.AddUpdateCommand
Higher level SolrInputDocument, normally used to construct the Lucene Document(s) to index.
solrDoc(int, SolrReturnFields) - Method in class org.apache.solr.search.SolrDocumentFetcher
This is an optimized version for populating a SolrDocument that:
SolrDocumentFetcher - Class in org.apache.solr.search
A helper class of SolrIndexSearcher for stored Document related matters including DocValue substitutions.
SolrEncoder - Interface in org.apache.solr.highlight
 
SolrEnvironment - Class in org.apache.solr.handler.admin
It is possible to define an environment code when starting Solr, through -Dsolr.environment=prod|stage|test|dev or by setting the cluster property "environment".
SolrEnvironment() - Constructor for class org.apache.solr.handler.admin.SolrEnvironment
 
SolrError() - Constructor for class org.apache.solr.update.SolrCmdDistributor.SolrError
 
SolrEventListener - Interface in org.apache.solr.core
 
solrException - Variable in class org.apache.solr.core.PluginBag.LazyPluginHolder
 
SolrExtendedUnifiedHighlighter(SolrQueryRequest) - Constructor for class org.apache.solr.highlight.UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter
 
SolrFieldCacheBean - Class in org.apache.solr.search
A SolrInfoBean that provides introspection of the Solr FieldCache
SolrFieldCacheBean() - Constructor for class org.apache.solr.search.SolrFieldCacheBean
 
SolrFileInputStream(InputStream, long) - Constructor for class org.apache.solr.core.SolrResourceLoader.SolrFileInputStream
 
SolrFileInputStream(Path) - Constructor for class org.apache.solr.core.SolrResourceLoader.SolrFileInputStream
 
SolrFormatter - Interface in org.apache.solr.highlight
 
SolrFragListBuilder - Interface in org.apache.solr.highlight
 
SolrFragmenter - Interface in org.apache.solr.highlight
 
SolrFragmentsBuilder - Class in org.apache.solr.highlight
 
SolrFragmentsBuilder() - Constructor for class org.apache.solr.highlight.SolrFragmentsBuilder
 
SolrGraphiteReporter - Class in org.apache.solr.metrics.reporters
Metrics reporter that wraps GraphiteReporter.
SolrGraphiteReporter(SolrMetricManager, String) - Constructor for class org.apache.solr.metrics.reporters.SolrGraphiteReporter
Create a Graphite reporter for metrics managed in a named registry.
SolrHighlighter - Class in org.apache.solr.highlight
 
SolrHighlighter() - Constructor for class org.apache.solr.highlight.SolrHighlighter
 
solrHome - Variable in class org.apache.solr.core.CoreContainer
 
solrHome - Variable in class org.apache.solr.core.NodeConfig
 
SOLRHOME_ATTRIBUTE - Static variable in class org.apache.solr.servlet.SolrDispatchFilter
 
SolrIndexConfig - Class in org.apache.solr.update
This config object encapsulates IndexWriter config params, defined in the <indexConfig> section of solrconfig.xml
SolrIndexConfig(ConfigNode, SolrIndexConfig) - Constructor for class org.apache.solr.update.SolrIndexConfig
Constructs a SolrIndexConfig which parses the Lucene related config params in solrconfig.xml
SolrIndexConfig(SolrConfig, SolrIndexConfig) - Constructor for class org.apache.solr.update.SolrIndexConfig
 
SolrIndexSearcher - Class in org.apache.solr.search
SolrIndexSearcher adds schema awareness and caching functionality over IndexSearcher.
SolrIndexSearcher(SolrCore, String, IndexSchema, String, DirectoryReader, boolean, boolean, boolean, DirectoryFactory) - Constructor for class org.apache.solr.search.SolrIndexSearcher
 
SolrIndexSearcher(SolrCore, String, IndexSchema, SolrIndexConfig, String, boolean, DirectoryFactory) - Constructor for class org.apache.solr.search.SolrIndexSearcher
 
SolrIndexSearcher.DocsEnumState - Class in org.apache.solr.search
 
SolrIndexSearcher.ProcessedFilter - Class in org.apache.solr.search
INTERNAL: The response object from SolrIndexSearcher.getProcessedFilter(DocSet, List).
SolrIndexSearcher.TimeAllowedExceededFromScorerException - Exception in org.apache.solr.search
Thrown when CommonParams.TIME_ALLOWED is exceeded.
SolrIndexSplitter - Class in org.apache.solr.update
 
SolrIndexSplitter(SplitIndexCommand) - Constructor for class org.apache.solr.update.SolrIndexSplitter
 
SolrIndexSplitter.SplitMethod - Enum in org.apache.solr.update
 
SolrIndexWriter - Class in org.apache.solr.update
An IndexWriter that is configured via Solr config mechanisms.
SolrIndexWriter(String, Directory, IndexWriterConfig) - Constructor for class org.apache.solr.update.SolrIndexWriter
 
SolrInfoBean - Interface in org.apache.solr.core
Interface for getting various ui friendly strings for use by objects which are 'pluggable' to make server administration easier.
SolrInfoBean.Category - Enum in org.apache.solr.core
Category of Solr component.
SolrInfoBean.Group - Enum in org.apache.solr.core
Top-level group of beans or metrics for a subsystem.
SolrInfoMBeanHandler - Class in org.apache.solr.handler.admin
A request handler that provides info about all registered SolrInfoMBeans.
SolrInfoMBeanHandler() - Constructor for class org.apache.solr.handler.admin.SolrInfoMBeanHandler
 
SolrJacksonAnnotationInspector - Class in org.apache.solr.util
this class provides a mapping between Solr's JsonProperty annotation to a corresponding annotation in jackson see SOLR-13841 for more details
SolrJacksonAnnotationInspector() - Constructor for class org.apache.solr.util.SolrJacksonAnnotationInspector
 
SolrJacksonMapper - Class in org.apache.solr.jersey
Customizes the ObjectMapper settings used for serialization/deserialization in Jersey
SolrJacksonMapper() - Constructor for class org.apache.solr.jersey.SolrJacksonMapper
 
SolrJacksonMapper.NamedListSerializer - Class in org.apache.solr.jersey
 
SolrJettyRequestCarrier - Class in org.apache.solr.util.tracing
An OpenTracing Carrier for injecting Span context through a Jetty Request
SolrJettyRequestCarrier(Request) - Constructor for class org.apache.solr.util.tracing.SolrJettyRequestCarrier
 
SolrJmxReporter - Class in org.apache.solr.metrics.reporters
A SolrMetricReporter that finds (or creates) a MBeanServer from the given configuration and registers metrics to it with JMX.
SolrJmxReporter(SolrMetricManager, String) - Constructor for class org.apache.solr.metrics.reporters.SolrJmxReporter
Creates a new instance of SolrJmxReporter.
SolrLogAuditLoggerPlugin - Class in org.apache.solr.security
Audit logger that writes to the Solr log.
SolrLogAuditLoggerPlugin() - Constructor for class org.apache.solr.security.SolrLogAuditLoggerPlugin
 
SolrLogPostTool - Class in org.apache.solr.cli
Deprecated.
Please use PostLogsTool that is exposed as 'bin/solr postlogs'.
SolrLogPostTool() - Constructor for class org.apache.solr.cli.SolrLogPostTool
Deprecated.
 
SolrMetricInfo - Class in org.apache.solr.metrics
Wraps meta-data for a metric.
SolrMetricInfo(SolrInfoBean.Category, String, String) - Constructor for class org.apache.solr.metrics.SolrMetricInfo
Creates a new instance of SolrMetricInfo.
SolrMetricManager - Class in org.apache.solr.metrics
This class maintains a repository of named MetricRegistry instances, and provides several helper methods for managing various aspects of metrics reporting: registry creation, clearing and removal, creation of most common metric implementations, management of SolrMetricReporter-s specific to a named registry.
SolrMetricManager() - Constructor for class org.apache.solr.metrics.SolrMetricManager
 
SolrMetricManager(SolrResourceLoader, MetricsConfig) - Constructor for class org.apache.solr.metrics.SolrMetricManager
 
SolrMetricManager.AndFilter - Class in org.apache.solr.metrics
An implementation of MetricFilter that selects metrics that match all filters in a list of filters.
SolrMetricManager.GaugeWrapper<T> - Class in org.apache.solr.metrics
This is a wrapper for Gauge metrics, which are usually implemented as lambdas that often keep a reference to their parent instance.
SolrMetricManager.OrFilter - Class in org.apache.solr.metrics
An implementation of MetricFilter that selects metrics that match any filter in a list of filters.
SolrMetricManager.PrefixFilter - Class in org.apache.solr.metrics
An implementation of MetricFilter that selects metrics with names that start with one of prefixes.
SolrMetricManager.RegexFilter - Class in org.apache.solr.metrics
An implementation of MetricFilter that selects metrics with names that match regular expression patterns.
SolrMetricManager.ResolutionStrategy - Enum in org.apache.solr.metrics
Potential conflict resolution strategies when attempting to register a new metric that already exists
SolrMetricProducer - Interface in org.apache.solr.metrics
Used by objects that expose metrics through SolrMetricManager.
SolrMetricReporter - Class in org.apache.solr.metrics
Interface for 'pluggable' metric reporters.
SolrMetricReporter(SolrMetricManager, String) - Constructor for class org.apache.solr.metrics.SolrMetricReporter
Create a reporter for metrics managed in a named registry.
solrMetricsContext - Variable in class org.apache.solr.core.CoreContainer
 
solrMetricsContext - Variable in class org.apache.solr.handler.component.SearchComponent
 
solrMetricsContext - Variable in class org.apache.solr.handler.RequestHandlerBase
 
solrMetricsContext - Variable in class org.apache.solr.highlight.HighlightingPluginBase
 
solrMetricsContext - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
solrMetricsContext - Variable in class org.apache.solr.security.AuthenticationPlugin
 
solrMetricsContext - Variable in class org.apache.solr.update.UpdateHandler
 
solrMetricsContext - Variable in class org.apache.solr.update.UpdateLog
 
solrMetricsContext - Variable in class org.apache.solr.util.stats.InstrumentedHttpListenerFactory
 
solrMetricsContext - Variable in class org.apache.solr.util.stats.InstrumentedHttpRequestExecutor
 
SolrMetricsContext - Class in org.apache.solr.metrics
This class represents a metrics context that ties together components with the same life-cycle and provides convenient access to the metric registry.
SolrMetricsContext(SolrMetricManager, String, String) - Constructor for class org.apache.solr.metrics.SolrMetricsContext
 
SolrNodeKeyPair - Class in org.apache.solr.security
Creates and mediates access to the CryptoKeys.RSAKeyPair used by this Solr node.
SolrNodeKeyPair(CloudConfig) - Constructor for class org.apache.solr.security.SolrNodeKeyPair
 
SolrPackage - Class in org.apache.solr.packagemanager
Describes a package (along with all released versions) as it appears in a repository.
SolrPackage() - Constructor for class org.apache.solr.packagemanager.SolrPackage
 
SolrPackage.Artifact - Class in org.apache.solr.packagemanager
 
SolrPackage.Command - Class in org.apache.solr.packagemanager
 
SolrPackage.Manifest - Class in org.apache.solr.packagemanager
 
SolrPackage.Plugin - Class in org.apache.solr.packagemanager
 
SolrPackage.SolrPackageRelease - Class in org.apache.solr.packagemanager
 
SolrPackageInstance - Class in org.apache.solr.packagemanager
Describes one instance of a package as it exists in Solr when installed.
SolrPackageInstance(String, String, String, SolrPackage.Manifest, List<SolrPackage.Plugin>, Map<String, String>) - Constructor for class org.apache.solr.packagemanager.SolrPackageInstance
 
SolrPackageLoader - Class in org.apache.solr.pkg
The class that holds a mapping of various packages and classloaders
SolrPackageLoader(CoreContainer) - Constructor for class org.apache.solr.pkg.SolrPackageLoader
 
SolrPackageLoader.SolrPackage - Class in org.apache.solr.pkg
represents a package definition in the packages.json
SolrPackageLoader.SolrPackage.Version - Class in org.apache.solr.pkg
 
SolrPackageRelease() - Constructor for class org.apache.solr.packagemanager.SolrPackage.SolrPackageRelease
 
solrParams - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
SolrPaths - Class in org.apache.solr.core
Utility methods about paths in Solr.
SolrPaths.AllowPathBuilder - Class in org.apache.solr.core
Builds a set of allowed Path.
SolrPluginUtils - Class in org.apache.solr.util
Utilities that may be of use to RequestHandlers.
SolrPluginUtils() - Constructor for class org.apache.solr.util.SolrPluginUtils
 
SolrPluginUtils.DisjunctionMaxQueryParser - Class in org.apache.solr.util
A subclass of SolrQueryParser that supports aliasing fields for constructing DisjunctionMaxQueries.
SolrPluginUtils.DisjunctionMaxQueryParser.Alias - Class in org.apache.solr.util
A simple container for storing alias info
solrProperties - Variable in class org.apache.solr.core.NodeConfig
 
SolrQueryBuilder - Class in org.apache.solr.search
 
SolrQueryBuilder(String, Analyzer, SolrQueryRequest, QueryBuilder) - Constructor for class org.apache.solr.search.SolrQueryBuilder
 
SolrQueryParser - Class in org.apache.solr.search
Solr's default query parser, a schema-driven superset of the classic lucene query parser.
SolrQueryParser(QParser, String) - Constructor for class org.apache.solr.search.SolrQueryParser
 
SolrQueryParserBase - Class in org.apache.solr.parser
This class is overridden by QueryParser in QueryParser.jj and acts to separate the majority of the Java code from the .jj grammar file.
SolrQueryParserBase() - Constructor for class org.apache.solr.parser.SolrQueryParserBase
 
SolrQueryParserBase.MagicFieldName - Enum in org.apache.solr.parser
Identifies the list of all known "magic fields" that trigger special parsing behavior
SolrQueryParserBase.RawQuery - Class in org.apache.solr.parser
 
SolrQueryParserBase.SynonymQueryStyle - Enum in org.apache.solr.parser
Query strategy when analyzed query terms overlap the same position (ie synonyms) consider if pants and khakis are query time synonyms
solrQueryRequest - Variable in class org.apache.solr.handler.admin.api.AdminAPIBase
 
solrQueryRequest - Variable in class org.apache.solr.handler.admin.api.ReplicationAPIBase
 
solrQueryRequest - Variable in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
SolrQueryRequest - Interface in org.apache.solr.request
Container for a request to execute a query.
SolrQueryRequestBase - Class in org.apache.solr.request
Base implementation of SolrQueryRequest that provides some convenience methods for accessing parameters, and manages an IndexSearcher reference.
SolrQueryRequestBase(SolrCore, SolrParams) - Constructor for class org.apache.solr.request.SolrQueryRequestBase
 
SolrQueryRequestBase(SolrCore, SolrParams, RTimerTree) - Constructor for class org.apache.solr.request.SolrQueryRequestBase
 
SolrQueryRequestFactory() - Constructor for class org.apache.solr.jersey.InjectionFactories.SolrQueryRequestFactory
 
solrQueryResponse - Variable in class org.apache.solr.handler.admin.api.AdminAPIBase
 
solrQueryResponse - Variable in class org.apache.solr.handler.admin.api.ReplicationAPIBase
 
SolrQueryResponse - Class in org.apache.solr.response
SolrQueryResponse is used by a query handler to return the response to a query request.
SolrQueryResponse() - Constructor for class org.apache.solr.response.SolrQueryResponse
 
SolrQueryResponseFactory() - Constructor for class org.apache.solr.jersey.InjectionFactories.SolrQueryResponseFactory
 
SolrQueryTimeoutImpl - Class in org.apache.solr.search
Implementation of QueryTimeout that is used by Solr.
SolrRangeQuery - Class in org.apache.solr.query
 
SolrRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Constructor for class org.apache.solr.query.SolrRangeQuery
 
SolrReporter - Class in org.apache.solr.metrics.reporters.solr
Implementation of ScheduledReporter that reports metrics from selected registries and sends them periodically as update requests to a selected Solr collection and to a configured handler.
SolrReporter(HttpClient, Supplier<String>, SolrMetricManager, List<SolrReporter.Report>, String, String, TimeUnit, TimeUnit, SolrParams, boolean, boolean, boolean, boolean) - Constructor for class org.apache.solr.metrics.reporters.solr.SolrReporter
SolrReporter(SolrClientCache, boolean, Supplier<String>, SolrMetricManager, List<SolrReporter.Report>, String, String, TimeUnit, TimeUnit, SolrParams, boolean, boolean, boolean, boolean) - Constructor for class org.apache.solr.metrics.reporters.solr.SolrReporter
Create a SolrReporter instance.
SolrReporter.Builder - Class in org.apache.solr.metrics.reporters.solr
Builder for the SolrReporter class.
SolrReporter.Report - Class in org.apache.solr.metrics.reporters.solr
Specification of what registries and what metrics to send.
solrReq - Variable in class org.apache.solr.servlet.HttpSolrCall
 
SolrRequestAuthorizer - Class in org.apache.solr.jersey
A JAX-RS request filter that blocks or allows requests based on the authorization plugin configured in security.json.
SolrRequestAuthorizer() - Constructor for class org.apache.solr.jersey.SolrRequestAuthorizer
 
SolrRequestHandler - Interface in org.apache.solr.request
Implementations of SolrRequestHandler are called to handle query requests.
SolrRequestInfo - Class in org.apache.solr.request
Information about the Solr request/response held in a ThreadLocal.
SolrRequestInfo(HttpServletRequest, SolrQueryResponse) - Constructor for class org.apache.solr.request.SolrRequestInfo
 
SolrRequestInfo(HttpServletRequest, SolrQueryResponse, SolrDispatchFilter.Action) - Constructor for class org.apache.solr.request.SolrRequestInfo
 
SolrRequestInfo(SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.request.SolrRequestInfo
 
SolrRequestInfo(SolrQueryRequest, SolrQueryResponse, SolrDispatchFilter.Action) - Constructor for class org.apache.solr.request.SolrRequestInfo
 
SolrRequestParsers - Class in org.apache.solr.servlet
 
SolrRequestParsers(SolrConfig) - Constructor for class org.apache.solr.servlet.SolrRequestParsers
Pass in an xml configuration.
solrResourceLoader - Variable in class org.apache.solr.rest.ManagedResource
 
SolrResourceLoader - Class in org.apache.solr.core
 
SolrResourceLoader(String, List<Path>, Path, ClassLoader) - Constructor for class org.apache.solr.core.SolrResourceLoader
Creates a loader.
SolrResourceLoader(Path) - Constructor for class org.apache.solr.core.SolrResourceLoader
Creates a loader.
SolrResourceLoader(Path, ClassLoader) - Constructor for class org.apache.solr.core.SolrResourceLoader
This loader will delegate to Solr's classloader when possible, otherwise it will attempt to resolve resources using any jar files found in the "lib/" directory in the specified instance directory.
SolrResourceLoader.SolrFileInputStream - Class in org.apache.solr.core
 
SolrResourceNotFoundException - Exception in org.apache.solr.core
 
SolrResourceNotFoundException() - Constructor for exception org.apache.solr.core.SolrResourceNotFoundException
 
SolrResourceNotFoundException(String) - Constructor for exception org.apache.solr.core.SolrResourceNotFoundException
 
SolrResourceNotFoundException(String, Throwable) - Constructor for exception org.apache.solr.core.SolrResourceNotFoundException
 
SolrResourceNotFoundException(Throwable) - Constructor for exception org.apache.solr.core.SolrResourceNotFoundException
 
SolrResponseUtil - Class in org.apache.solr.util
 
SolrReturnFields - Class in org.apache.solr.search
The default implementation of return fields parsing for Solr.
SolrReturnFields() - Constructor for class org.apache.solr.search.SolrReturnFields
 
SolrReturnFields(String[], SolrQueryRequest) - Constructor for class org.apache.solr.search.SolrReturnFields
 
SolrReturnFields(String, SolrQueryRequest) - Constructor for class org.apache.solr.search.SolrReturnFields
 
SolrReturnFields(Collection<String>, DocTransformer) - Constructor for class org.apache.solr.search.SolrReturnFields
For pre-parsed simple field list with optional transformer.
SolrReturnFields(SolrQueryRequest) - Constructor for class org.apache.solr.search.SolrReturnFields
 
SolrReturnFields.FIELD_SOURCES - Enum in org.apache.solr.search
 
SolrSlf4jReporter - Class in org.apache.solr.metrics.reporters
Metrics reporter that wraps Slf4jReporter.
SolrSlf4jReporter(SolrMetricManager, String) - Constructor for class org.apache.solr.metrics.reporters.SolrSlf4jReporter
Create a SLF4J reporter for metrics managed in a named registry.
SolrSnapshotManager - Class in org.apache.solr.core.snapshots
This class provides functionality required to handle the data files corresponding to Solr snapshots.
SolrSnapshotManager() - Constructor for class org.apache.solr.core.snapshots.SolrSnapshotManager
 
SolrSnapshotMetaDataManager - Class in org.apache.solr.core.snapshots
This class is responsible to manage the persistent snapshots meta-data for the Solr indexes.
SolrSnapshotMetaDataManager(SolrCore, Directory) - Constructor for class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
A constructor.
SolrSnapshotMetaDataManager(SolrCore, Directory, IndexWriterConfig.OpenMode) - Constructor for class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager
A constructor.
SolrSnapshotMetaDataManager.SnapshotMetaData - Class in org.apache.solr.core.snapshots
A class defining the meta-data for a specific snapshot.
SolrSpanQueryBuilder - Class in org.apache.solr.search
 
SolrSpanQueryBuilder(String, Analyzer, SolrQueryRequest, SpanQueryBuilder) - Constructor for class org.apache.solr.search.SolrSpanQueryBuilder
 
SolrSpellChecker - Class in org.apache.solr.spelling
SolrSpellChecker() - Constructor for class org.apache.solr.spelling.SolrSpellChecker
 
SolrSuggester - Class in org.apache.solr.spelling.suggest
Responsible for loading the lookup and dictionary Implementations specified by the SolrConfig.
SolrSuggester() - Constructor for class org.apache.solr.spelling.suggest.SolrSuggester
 
solrUrl - Static variable in class org.apache.solr.cli.PackageTool
 
solrUrl - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
SolrXmlConfig - Class in org.apache.solr.core
Loads solr.xml.
SolrXmlConfig() - Constructor for class org.apache.solr.core.SolrXmlConfig
 
solrZkClient - Variable in class org.apache.solr.servlet.RateLimitManager.Builder
 
SolrZkServer - Class in org.apache.solr.cloud
 
SolrZkServer(String, String, File, String, int) - Constructor for class org.apache.solr.cloud.SolrZkServer
 
sort - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
 
sort() - Method in class org.apache.solr.handler.component.PivotFacetField
Recursively sorts the collection of values associated with this field, and any sub-pivots those values have.
sort() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Sorts the collection and recursively sorts the collections assocaited with any sub-pivots.
sort(int) - Method in class org.apache.solr.util.LongPriorityQueue
Pops the smallest n items from the heap, placing them in the internal array at arr[size] through arr[size-(n-1)] with the smallest (first element popped) being at arr[size].
sort(int, int, int[], PrimUtils.IntComparator) - Static method in class org.apache.solr.util.PrimUtils
Sort the integer array from "start" inclusive to "end" exclusive in ascending order, using the provided comparator.
sort(List<CoreDescriptor>) - Method in class org.apache.solr.core.CoreSorter
 
SORT - org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelectorType
 
SORT_FIELD - Static variable in class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
Label used to define the name of the sortField used in the DocumentExpressionDictionaryFactory.WEIGHT_EXPRESSION
SORT_MISSING_FIRST - Static variable in class org.apache.solr.schema.FieldProperties
 
SORT_MISSING_LAST - Static variable in class org.apache.solr.schema.FieldProperties
 
SortableStr2double(String) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2double(BytesRef) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2doubleStr(String) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2float(String) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2float(BytesRef) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2floatStr(String) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2int(String) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2int(String, int, int) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2int(BytesRef) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2int(BytesRef, int, int) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2long(String) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2long(String, int, int) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2long(BytesRef) - Static method in class org.apache.solr.util.NumberUtils
 
SortableStr2long(BytesRef, int, int) - Static method in class org.apache.solr.util.NumberUtils
 
SortableTextField - Class in org.apache.solr.schema
SortableTextField is a specialized form of TextField that supports Sorting and ValueSource functions, using docValues built from the first maxCharsForDocValues characters of the original (pre-analyzed) String values of this field.
SortableTextField() - Constructor for class org.apache.solr.schema.SortableTextField
 
sortBuckets(FacetRequest.FacetSort) - Method in class org.apache.solr.search.facet.FacetRangeMerger
 
sortDocSet(QueryResult, QueryCommand) - Method in class org.apache.solr.search.SolrIndexSearcher
 
SORTED - org.apache.solr.uninverting.UninvertingReader.Type
Single-valued Binary, (e.g.
SORTED_SET_BINARY - org.apache.solr.uninverting.UninvertingReader.Type
Multi-valued Binary, (e.g.
SORTED_SET_DOUBLE - org.apache.solr.uninverting.UninvertingReader.Type
Multi-valued Double, (e.g.
SORTED_SET_FLOAT - org.apache.solr.uninverting.UninvertingReader.Type
Multi-valued Float, (e.g.
SORTED_SET_INTEGER - org.apache.solr.uninverting.UninvertingReader.Type
Multi-valued Integer, (e.g.
SORTED_SET_LONG - org.apache.solr.uninverting.UninvertingReader.Type
Multi-valued Long, (e.g.
SortedDateStatsValues - Class in org.apache.solr.handler.component
 
SortedDateStatsValues(StatsValuesFactory.DateStatsValues, StatsField) - Constructor for class org.apache.solr.handler.component.SortedDateStatsValues
 
SortedDocValuesImpl(PagedBytes.Reader, PackedLongValues, PackedInts.Reader, int) - Constructor for class org.apache.solr.uninverting.FieldCacheImpl.SortedDocValuesImpl
 
SortedIntDocSet - Class in org.apache.solr.search
A simple sorted int[] array implementation of DocSet, good for small sets.
SortedIntDocSet(int[]) - Constructor for class org.apache.solr.search.SortedIntDocSet
 
SortedIntDocSet(int[], int) - Constructor for class org.apache.solr.search.SortedIntDocSet
 
SortedLogReader(long) - Constructor for class org.apache.solr.update.TransactionLog.SortedLogReader
 
SortedNumericStatsValues - Class in org.apache.solr.handler.component
 
SortedNumericStatsValues(StatsValuesFactory.NumericStatsValues, StatsField) - Constructor for class org.apache.solr.handler.component.SortedNumericStatsValues
 
sortFieldValues - Variable in class org.apache.solr.handler.component.ShardDoc
 
SortingMergePolicy - Class in org.apache.solr.index
 
SortingMergePolicy(MergePolicy, Sort) - Constructor for class org.apache.solr.index.SortingMergePolicy
Create a new MergePolicy that sorts documents with the given sort.
SortingMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for SortingMergePolicy objects.
SortingMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.SortingMergePolicyFactory
 
sortKeys(JaspellTernarySearchTrie.TSTNode, int) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellTernarySearchTrie
Deprecated.
Returns keys sorted in alphabetical order.
sortMissingFirst() - Method in class org.apache.solr.schema.SchemaField
 
sortMissingHigh - Variable in enum org.apache.solr.schema.NumberType
The effective value to use when sorting on this field should result in docs w/o a value sorting "low" (which may be "first" or "last" depending on sort direction)
sortMissingLast() - Method in class org.apache.solr.schema.SchemaField
 
sortMissingLow - Variable in enum org.apache.solr.schema.NumberType
The effective value to use when sorting on this field should result in docs w/o a value sorting "low" (which may be "first" or "last" depending on sort direction)
sortSeqs(List<String>) - Static method in class org.apache.solr.cloud.LeaderElector
Sort n string sequence list.
SortSpec - Class in org.apache.solr.search
SortSpec encapsulates a Lucene Sort and a count of the number of documents to return.
SortSpec(Sort, List<SchemaField>) - Constructor for class org.apache.solr.search.SortSpec
 
SortSpec(Sort, List<SchemaField>, int, int) - Constructor for class org.apache.solr.search.SortSpec
 
SortSpec(Sort, SchemaField[]) - Constructor for class org.apache.solr.search.SortSpec
 
SortSpec(Sort, SchemaField[], int, int) - Constructor for class org.apache.solr.search.SortSpec
 
SortSpecParsing - Class in org.apache.solr.search
 
SortSpecParsing() - Constructor for class org.apache.solr.search.SortSpecParsing
 
sortType - Variable in enum org.apache.solr.schema.NumberType
The SortField type that corrisponds with this NumberType
SOURCE - Static variable in class org.apache.solr.schema.IndexSchema
 
SOURCE_FILE_CHAR_ENCODING - Static variable in class org.apache.solr.spelling.FileBasedSpellChecker
 
SOURCE_PARAM - Static variable in class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
 
source1 - Variable in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
source2 - Variable in class org.apache.solr.search.function.distance.VectorDistanceFunction
 
sourceLocation - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
sourceLocation - Variable in class org.apache.solr.spelling.suggest.Suggester
 
sources - Variable in class org.apache.solr.search.function.MultiStringFunction
 
sp - Variable in class org.apache.solr.search.FunctionQParser
 
spanFactory - Variable in class org.apache.solr.search.SolrSpanQueryBuilder
 
spansNonTaggable(int, int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
SPARSE - org.apache.solr.util.hll.HLLType
 
SpatialBoxQParserPlugin - Class in org.apache.solr.search
 
SpatialBoxQParserPlugin() - Constructor for class org.apache.solr.search.SpatialBoxQParserPlugin
 
SpatialFilterQParser - Class in org.apache.solr.search
 
SpatialFilterQParser(String, SolrParams, SolrParams, SolrQueryRequest, boolean) - Constructor for class org.apache.solr.search.SpatialFilterQParser
 
SpatialFilterQParserPlugin - Class in org.apache.solr.search
Creates a spatial Filter based on the type of spatial point used.
SpatialFilterQParserPlugin() - Constructor for class org.apache.solr.search.SpatialFilterQParserPlugin
 
SpatialHeatmapFacets - Class in org.apache.solr.handler.component
A 2D spatial faceting summary of a rectangular region.
SpatialHeatmapFacets() - Constructor for class org.apache.solr.handler.component.SpatialHeatmapFacets
 
SpatialHeatmapFacets.HeatmapFacet - Class in org.apache.solr.handler.component
SpatialOptions - Class in org.apache.solr.search
 
SpatialOptions() - Constructor for class org.apache.solr.search.SpatialOptions
 
SpatialOptions(String, double, SchemaField, String, double) - Constructor for class org.apache.solr.search.SpatialOptions
 
SpatialQueryable - Interface in org.apache.solr.schema
Indicate that the implementing class is capable of generating a Query against spatial resources.
SpatialRecursivePrefixTreeFieldType - Class in org.apache.solr.schema
 
SpatialRecursivePrefixTreeFieldType() - Constructor for class org.apache.solr.schema.SpatialRecursivePrefixTreeFieldType
 
SpatialUtils - Class in org.apache.solr.util
Utility methods pertaining to spatial.
spec - Variable in class org.apache.solr.api.Api
 
specialToken - Variable in class org.apache.solr.parser.Token
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
SpellCheckCollation - Class in org.apache.solr.spelling
 
SpellCheckCollation() - Constructor for class org.apache.solr.spelling.SpellCheckCollation
 
SpellCheckCollator - Class in org.apache.solr.spelling
 
SpellCheckCollator() - Constructor for class org.apache.solr.spelling.SpellCheckCollator
 
SpellCheckComponent - Class in org.apache.solr.handler.component
A SearchComponent implementation which provides support for spell checking and suggestions using the Lucene contributed SpellChecker.
SpellCheckComponent() - Constructor for class org.apache.solr.handler.component.SpellCheckComponent
 
SpellCheckCorrection - Class in org.apache.solr.spelling
 
SpellCheckCorrection() - Constructor for class org.apache.solr.spelling.SpellCheckCorrection
 
spellChecker - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
SPELLCHECKER - org.apache.solr.core.SolrInfoBean.Category
 
SPELLCHECKER_ARG_NAME - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
spellCheckers - Variable in class org.apache.solr.handler.component.SpellCheckComponent
Key is the dictionary, value is the SpellChecker for that dictionary name
SpellCheckMergeData - Class in org.apache.solr.handler.component
 
SpellCheckMergeData() - Constructor for class org.apache.solr.handler.component.SpellCheckMergeData
 
SpellingOptions - Class in org.apache.solr.spelling
 
SpellingOptions() - Constructor for class org.apache.solr.spelling.SpellingOptions
 
SpellingOptions(Collection<Token>, int) - Constructor for class org.apache.solr.spelling.SpellingOptions
 
SpellingOptions(Collection<Token>, IndexReader) - Constructor for class org.apache.solr.spelling.SpellingOptions
 
SpellingOptions(Collection<Token>, IndexReader, int) - Constructor for class org.apache.solr.spelling.SpellingOptions
 
SpellingOptions(Collection<Token>, IndexReader, int, int, SuggestMode, boolean, float, SolrParams) - Constructor for class org.apache.solr.spelling.SpellingOptions
 
SpellingOptions(Collection<Token>, IndexReader, int, SuggestMode, boolean, float, SolrParams) - Constructor for class org.apache.solr.spelling.SpellingOptions
 
SpellingQueryConverter - Class in org.apache.solr.spelling
Converts the query string to a Collection of Lucene tokens using a regular expression.
SpellingQueryConverter() - Constructor for class org.apache.solr.spelling.SpellingQueryConverter
 
SpellingResult - Class in org.apache.solr.spelling
Implementations of SolrSpellChecker must return suggestions as SpellResult instance.
SpellingResult() - Constructor for class org.apache.solr.spelling.SpellingResult
 
SpellingResult(Collection<Token>) - Constructor for class org.apache.solr.spelling.SpellingResult
 
split(String) - Static method in class org.apache.solr.util.SolrPluginUtils
Split a value between spaces and/or commas.
split(String, boolean) - Static method in class org.apache.solr.search.ExtendedDismaxQParser
 
split(ClusterState, ZkNodeProps, NamedList<Object>) - Method in class org.apache.solr.cloud.api.collections.SplitShardCmd
Shard splits start here and make additional requests to the host of the parent shard.
split(NamedList<Object>) - Method in class org.apache.solr.update.SolrIndexSplitter
 
split(SplitIndexCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
 
split(SplitIndexCommand) - Method in class org.apache.solr.update.UpdateHandler
 
SPLIT - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
SPLIT_ON_WHITESPACE - Static variable in class org.apache.solr.search.QueryParsing
 
SPLIT_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
splitCore(PayloadObj<SplitCoreAPI.SplitCorePayload>) - Method in class org.apache.solr.handler.admin.api.SplitCoreAPI
 
SplitCoreAPI - Class in org.apache.solr.handler.admin.api
V2 API for splitting a single core into multiple pieces
SplitCoreAPI(CoreAdminHandler) - Constructor for class org.apache.solr.handler.admin.api.SplitCoreAPI
 
SplitCoreAPI.SplitCorePayload - Class in org.apache.solr.handler.admin.api
 
SplitCorePayload() - Constructor for class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
splitFailureAfterReplicaCreation - Static variable in class org.apache.solr.util.TestInjection
 
splitFailureBeforeReplicaCreation - Static variable in class org.apache.solr.util.TestInjection
 
SplitIndexCommand - Class in org.apache.solr.update
A split index command encapsulated in an object.
SplitIndexCommand(SolrQueryRequest, SolrQueryResponse, List<String>, List<SolrCore>, List<DocRouter.Range>, DocRouter, String, String, SolrIndexSplitter.SplitMethod) - Constructor for class org.apache.solr.update.SplitIndexCommand
 
splitIntoClauses(String, boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser
 
splitIntRange(LegacyNumericUtils.IntRangeBuilder, int, int, int) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Splits an int range recursively.
splitKey - Variable in class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
splitKey - Variable in class org.apache.solr.update.SplitIndexCommand
 
splitLatch - Static variable in class org.apache.solr.util.TestInjection
 
splitLongRange(LegacyNumericUtils.LongRangeBuilder, int, long, long) - Static method in class org.apache.solr.legacy.LegacyNumericUtils
Deprecated.
Splits a long range recursively.
splitMethod - Variable in class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
splitMethod - Variable in class org.apache.solr.update.SplitIndexCommand
 
splitOnWhitespace - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
splitShard(PayloadObj<SplitShardPayload>) - Method in class org.apache.solr.handler.admin.api.SplitShardAPI
 
SPLITSHARD_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
SplitShardAPI - Class in org.apache.solr.handler.admin.api
V2 API for splitting an existing shard up into multiple pieces.
SplitShardAPI(CollectionsHandler) - Constructor for class org.apache.solr.handler.admin.api.SplitShardAPI
 
SplitShardCmd - Class in org.apache.solr.cloud.api.collections
SolrCloud logic for splitting a shard.
SplitShardCmd(CollectionCommandContext) - Constructor for class org.apache.solr.cloud.api.collections.SplitShardCmd
 
SPREAD_DOMAIN_SYSPROP - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Name of the system property on a node indicating the spread domain group.
spreadAcrossDomains - Variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
When this property is set to true, Solr will try to place replicas for the same shard in nodes that have different value for the AffinityPlacementConfig.SPREAD_DOMAIN_SYSPROP System property.
SquaredEuclideanFunction - Class in org.apache.solr.search.function.distance
While not strictly a distance, the Sq.
SquaredEuclideanFunction(MultiValueSource, MultiValueSource) - Constructor for class org.apache.solr.search.function.distance.SquaredEuclideanFunction
 
squashIntoNamedList(NamedList<Object>, Object) - Static method in class org.apache.solr.handler.api.V2ApiUtils
 
squashIntoNamedListWithoutHeader(NamedList<Object>, Object) - Static method in class org.apache.solr.handler.api.V2ApiUtils
 
squashIntoSolrResponseWithHeader(SolrQueryResponse, Object) - Static method in class org.apache.solr.handler.api.V2ApiUtils
Convert a JacksonReflectMapWriter (typically a SolrJerseyResponse) into the NamedList on a SolrQueryResponse, including the response header
squashIntoSolrResponseWithoutHeader(SolrQueryResponse, Object) - Static method in class org.apache.solr.handler.api.V2ApiUtils
Convert a JacksonReflectMapWriter (typically a SolrJerseyResponse) into the NamedList on a SolrQueryResponse, omitting the response header
squashObjectIntoNamedList(NamedList<Object>, Object, boolean) - Static method in class org.apache.solr.handler.api.V2ApiUtils
 
SSL_CLIENT_KEY_STORE_PASSWORD - org.apache.solr.util.configuration.SSLCredentialProvider.CredentialType
 
SSL_CLIENT_KEY_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.SSLConfigurations.SysProps
 
SSL_CLIENT_TRUST_STORE_PASSWORD - org.apache.solr.util.configuration.SSLCredentialProvider.CredentialType
 
SSL_CLIENT_TRUST_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.SSLConfigurations.SysProps
 
SSL_KEY_STORE_PASSWORD - org.apache.solr.util.configuration.SSLCredentialProvider.CredentialType
 
SSL_KEY_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.SSLConfigurations.SysProps
 
SSL_TRUST_STORE_PASSWORD - org.apache.solr.util.configuration.SSLCredentialProvider.CredentialType
 
SSL_TRUST_STORE_PASSWORD - Static variable in class org.apache.solr.util.configuration.SSLConfigurations.SysProps
 
SSLConfigurations - Class in org.apache.solr.util.configuration
Dedicated object to handle Solr configurations
SSLConfigurations(List<SSLCredentialProvider>) - Constructor for class org.apache.solr.util.configuration.SSLConfigurations
 
SSLConfigurations(SSLCredentialProviderFactory) - Constructor for class org.apache.solr.util.configuration.SSLConfigurations
 
SSLConfigurations.SysProps - Class in org.apache.solr.util.configuration
 
SSLConfigurationsFactory - Class in org.apache.solr.util.configuration
 
SSLConfigurationsFactory() - Constructor for class org.apache.solr.util.configuration.SSLConfigurationsFactory
 
SSLCredentialProvider - Interface in org.apache.solr.util.configuration
Interface for different source of SSL configurations.
SSLCredentialProvider.CredentialType - Enum in org.apache.solr.util.configuration
 
SSLCredentialProviderFactory - Class in org.apache.solr.util.configuration
Class responsible to build SSL credential providers
SSLCredentialProviderFactory() - Constructor for class org.apache.solr.util.configuration.SSLCredentialProviderFactory
 
SSLCredentialProviderFactory(String) - Constructor for class org.apache.solr.util.configuration.SSLCredentialProviderFactory
 
stage - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
STAGE_DONE - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
STAGE_EXECUTE_QUERY - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
STAGE_GET_FIELDS - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
STAGE_PARSE_QUERY - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
STAGE_START - Static variable in class org.apache.solr.handler.component.ResponseBuilder
public static final String NUMDOCS = "nd"; public static final String DOCFREQS = "tdf"; public static final String TERMS = "terms"; public static final String EXTRACT_QUERY_TERMS = "eqt"; public static final String LOCAL_SHARD = "local"; public static final String DOC_QUERY = "dq"; *
STAGE_TOP_GROUPS - Static variable in class org.apache.solr.handler.component.ResponseBuilder
 
STANDARD - Static variable in class org.apache.solr.servlet.SolrRequestParsers
 
standard_components - Static variable in class org.apache.solr.handler.component.SearchComponent
 
StandardDirectoryFactory - Class in org.apache.solr.core
Directory provider which mimics original Solr FSDirectory based behavior.
StandardDirectoryFactory() - Constructor for class org.apache.solr.core.StandardDirectoryFactory
 
StandardIndexReaderFactory - Class in org.apache.solr.core
Default IndexReaderFactory implementation.
StandardIndexReaderFactory() - Constructor for class org.apache.solr.core.StandardIndexReaderFactory
 
standardPlugins - Static variable in class org.apache.solr.search.QParserPlugin
Internal use - name to parser for the builtin parsers.
standardPropNames - Static variable in class org.apache.solr.core.CoreDescriptor
 
StandardRequestHandler - Class in org.apache.solr.handler
Deprecated.
StandardRequestHandler() - Constructor for class org.apache.solr.handler.StandardRequestHandler
Deprecated.
 
standardValueSourceParsers - Static variable in class org.apache.solr.search.ValueSourceParser
standard functions supported by default
STAR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
start - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
start - Variable in class org.apache.solr.handler.component.RangeFacetRequest
 
start() - Method in interface org.apache.solr.cloud.ClusterSingleton
Start the operation of the component.
start() - Method in class org.apache.solr.cloud.SolrZkServer
 
start() - Method in class org.apache.solr.cluster.events.impl.ClusterEventProducerFactory
 
start() - Method in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
start() - Method in class org.apache.solr.cluster.events.impl.DefaultClusterEventProducer
 
start() - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
start() - Method in class org.apache.solr.cluster.events.NoOpProducer
 
start() - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter
 
start() - Method in interface org.apache.solr.util.RTimer.TimerImpl
 
start(String) - Method in class org.apache.solr.cloud.Overseer
 
START - org.apache.solr.cloud.api.collections.ReindexCollectionCmd.Cmd
 
START_TIME_PROP - Static variable in class org.apache.solr.core.backup.BackupManager
 
startClusterSingletons() - Method in class org.apache.solr.core.ClusterSingletons
Start singletons when the helper is ready and when it's supposed to start (as determined by ClusterSingletons.runSingletons function).
startCollectionApiCommandSpan(Tracer, String, String, boolean) - Static method in class org.apache.solr.util.tracing.TraceUtils
 
STARTED - Static variable in class org.apache.solr.util.RTimer
 
startIndexes - Variable in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory.Resolved
 
STARTING - org.apache.solr.cloud.ClusterSingleton.State
Component is starting.
startingVersions - Variable in class org.apache.solr.update.UpdateLog
 
startObj - Variable in class org.apache.solr.handler.component.RangeFacetRequest
The computed start value of this range
startRecovering(String) - Method in class org.apache.solr.cloud.ZkShardTerms
Mark coreNodeName as recovering
startReplication(boolean) - Method in class org.apache.solr.cloud.ReplicateFromLeader
Start a replication handler thread that will periodically pull indices from the shard leader
startReplicationFromLeader(String, boolean) - Method in class org.apache.solr.cloud.ZkController
 
startSolr(File, boolean, CommandLine, int, String, int) - Method in class org.apache.solr.cli.RunExampleTool
 
startTime - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
startTime - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
startTime - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
StartupLoggingUtils - Class in org.apache.solr.util
Handles programmatic modification of logging during startup
StartupLoggingUtils() - Constructor for class org.apache.solr.util.StartupLoggingUtils
 
stat - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.ListZkChildrenResponse
 
Stat() - Constructor for class org.apache.solr.cloud.Stats.Stat
 
state - Variable in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
state - Variable in class org.apache.solr.update.UpdateLog
 
state - Variable in class org.apache.solr.util.RTimer
 
STATE - org.apache.solr.cloud.overseer.OverseerAction
 
STATE - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
STATE_UPDATE_BATCH_SIZE - Static variable in class org.apache.solr.cloud.Overseer
 
STATE_UPDATE_DELAY - Static variable in class org.apache.solr.cloud.Overseer
 
STATE_UPDATE_MAX_QUEUE - Static variable in class org.apache.solr.cloud.Overseer
 
stateManager - Variable in class org.apache.solr.cloud.overseer.ClusterStateMutator
 
stateManager - Variable in class org.apache.solr.cloud.overseer.CollectionMutator
 
stateManager - Variable in class org.apache.solr.cloud.overseer.ReplicaMutator
 
stateManager - Variable in class org.apache.solr.cloud.overseer.SliceMutator
 
states - Variable in class org.apache.solr.schema.PreAnalyzedField.ParseResult
 
STATIC_LEXER_ERROR - Static variable in error org.apache.solr.parser.TokenMgrError
An attempt was made to create a second instance of a static token manager.
STATICWARMING - org.apache.solr.search.SolrCache.State
:TODO
STATISTICS_KEY - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
stats - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
 
stats - Variable in class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
Stats - Class in org.apache.solr.cloud
Used to hold statistics about some SolrCloud operations.
Stats() - Constructor for class org.apache.solr.cloud.Stats
 
Stats() - Constructor for class org.apache.solr.util.ConcurrentLRUCache.Stats
 
STATS - org.apache.solr.util.PivotListEntry
 
STATS_SOURCE - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
Stats.FailedOp - Class in org.apache.solr.cloud
 
Stats.Stat - Class in org.apache.solr.cloud
 
StatsCache - Class in org.apache.solr.search.stats
This class represents a cache of global document frequency information for selected terms.
StatsCache() - Constructor for class org.apache.solr.search.stats.StatsCache
 
StatsCache.StatsCacheMetrics - Class in org.apache.solr.search.stats
 
statsCacheMetrics - Variable in class org.apache.solr.search.stats.StatsCache
 
StatsCacheMetrics() - Constructor for class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
StatsComponent - Class in org.apache.solr.handler.component
Stats component calculates simple statistics on numeric field values
StatsComponent() - Constructor for class org.apache.solr.handler.component.StatsComponent
 
StatsField - Class in org.apache.solr.handler.component
Models all of the information associated with a single StatsParams.STATS_FIELD instance.
StatsField(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.StatsField
 
StatsField.HllOptions - Class in org.apache.solr.handler.component
Helper Struct for parsing and encapsulating all of the options relaed to building a HLL
StatsField.Stat - Enum in org.apache.solr.handler.component
An enumeration representing the sumer set of all possible stat values that can be computed.
StatsSource - Class in org.apache.solr.search.stats
The purpose of this class is only to provide two pieces of information necessary to create Weight from a Query, that is TermStatistics for a term and CollectionStatistics for the whole collection.
StatsSource() - Constructor for class org.apache.solr.search.stats.StatsSource
 
StatsUtil - Class in org.apache.solr.search.stats
Various utilities for de/serialization of term stats and collection stats.
StatsUtil() - Constructor for class org.apache.solr.search.stats.StatsUtil
 
StatsValues - Interface in org.apache.solr.handler.component
StatsValue defines the interface for the collection of statistical values about fields and facets.
StatsValuesFactory - Class in org.apache.solr.handler.component
Factory class for creating instance of StatsValues
StatsValuesFactory() - Constructor for class org.apache.solr.handler.component.StatsValuesFactory
 
status - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.FileListResponse
 
status - Variable in class org.apache.solr.handler.admin.api.CoreReplicationAPI.IndexVersionResponse
 
status - Variable in class org.apache.solr.handler.admin.api.SnapshotBackupAPI.BackupReplicationResponse
 
status - Variable in class org.apache.solr.handler.SnapShooter.CoreSnapshotResponse
 
status - Variable in enum org.apache.solr.security.AuditEvent.EventType
 
STATUS - org.apache.solr.cloud.api.collections.ReindexCollectionCmd.Cmd
 
STATUS - org.apache.solr.handler.PingRequestHandler.ACTIONS
 
STATUS - Static variable in class org.apache.solr.handler.ReplicationHandler
 
STATUS_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
statusCode - Variable in class org.apache.solr.security.AuthorizationResponse
 
statusCode - Variable in class org.apache.solr.update.SolrCmdDistributor.SolrError
 
StatusTool - Class in org.apache.solr.cli
 
StatusTool() - Constructor for class org.apache.solr.cli.StatusTool
Get the status of a Solr server.
StatusTool(PrintStream) - Constructor for class org.apache.solr.cli.StatusTool
 
stddev - org.apache.solr.handler.component.StatsField.Stat
 
stdDev(double, double, long) - Static method in class org.apache.solr.search.facet.AggUtil
Computes and returns corrected standard deviation for given values
StddevAgg - Class in org.apache.solr.search.facet
 
StddevAgg(ValueSource) - Constructor for class org.apache.solr.search.facet.StddevAgg
 
StdNode(ZkCoreNodeProps) - Constructor for class org.apache.solr.update.SolrCmdDistributor.StdNode
 
StdNode(ZkCoreNodeProps, String, String) - Constructor for class org.apache.solr.update.SolrCmdDistributor.StdNode
 
StdNode(ZkCoreNodeProps, String, String, int) - Constructor for class org.apache.solr.update.SolrCmdDistributor.StdNode
 
stdout - Variable in class org.apache.solr.cli.ToolBase
 
stop() - Method in interface org.apache.solr.cloud.ClusterSingleton
Stop the operation of the component.
stop() - Method in class org.apache.solr.cloud.SolrZkServer
 
stop() - Method in class org.apache.solr.cluster.events.impl.ClusterEventProducerFactory
 
stop() - Method in class org.apache.solr.cluster.events.impl.CollectionsRepairEventListener
 
stop() - Method in class org.apache.solr.cluster.events.impl.DefaultClusterEventProducer
 
stop() - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
stop() - Method in class org.apache.solr.cluster.events.NoOpProducer
 
stop() - Method in class org.apache.solr.util.RTimer
Stop this timer
stop() - Method in class org.apache.solr.util.RTimerTree
Recursively stop timer and sub timers
stopAndWaitForPendingTasksToComplete() - Method in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
Best effort wait for termination of all tasks for a (short) while, then return.
stopClusterSingletons() - Method in class org.apache.solr.core.ClusterSingletons
Stop all registered singletons.
STOPPED - org.apache.solr.cloud.ClusterSingleton.State
Component is idle.
STOPPED - Static variable in class org.apache.solr.util.RTimer
 
STOPPING - org.apache.solr.cloud.ClusterSingleton.State
Component is stopping.
stopReplication() - Method in class org.apache.solr.cloud.ReplicateFromLeader
 
stopReplicationFromLeader(String) - Method in class org.apache.solr.cloud.ZkController
 
stopwords - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
storage - Variable in class org.apache.solr.rest.ManagedResource
 
STORAGE_DIR_INIT_ARG - Static variable in class org.apache.solr.rest.ManagedResourceStorage
 
STORAGE_IO_CLASS_INIT_ARG - Static variable in class org.apache.solr.rest.ManagedResourceStorage
 
storageIO - Variable in class org.apache.solr.rest.ManagedResourceStorage
 
storageIO - Variable in class org.apache.solr.rest.RestManager
 
store(Writer) - Method in class org.apache.solr.core.backup.BackupProperties
 
store(String, Object) - Method in class org.apache.solr.rest.ManagedResourceStorage.JsonStorage
 
store(String, Object) - Method in class org.apache.solr.rest.ManagedResourceStorage
Persists the given toStore object with the given resourceId.
store(DataOutput) - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookup
Deprecated.
 
store(BackupRepository, URI, ShardBackupId) - Method in class org.apache.solr.core.backup.ShardBackupMetadata
Storing ShardBackupMetadata at folderURI with name filename.
STORE_DIR - Static variable in class org.apache.solr.spelling.suggest.SolrSuggester
Name of the location where to persist the dictionary.
STORE_DIR - Static variable in class org.apache.solr.spelling.suggest.Suggester
Name of the location where to persist the dictionary.
STORE_OFFSETS - Static variable in class org.apache.solr.schema.FieldProperties
 
STORE_TERMOFFSETS - Static variable in class org.apache.solr.schema.FieldProperties
 
STORE_TERMPAYLOADS - Static variable in class org.apache.solr.schema.FieldProperties
 
STORE_TERMPOSITIONS - Static variable in class org.apache.solr.schema.FieldProperties
 
STORE_TERMVECTORS - Static variable in class org.apache.solr.schema.FieldProperties
 
stored() - Method in class org.apache.solr.schema.SchemaField
 
STORED - Static variable in class org.apache.solr.schema.FieldProperties
 
STORED_FIELDS - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
storedFields() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
StoredFieldsShardRequestFactory - Class in org.apache.solr.search.grouping.distributed.requestfactory
 
StoredFieldsShardRequestFactory() - Constructor for class org.apache.solr.search.grouping.distributed.requestfactory.StoredFieldsShardRequestFactory
 
StoredFieldsShardResponseProcessor - Class in org.apache.solr.search.grouping.distributed.responseprocessor
Concrete implementation for processing the stored field values from shard responses.
StoredFieldsShardResponseProcessor() - Constructor for class org.apache.solr.search.grouping.distributed.responseprocessor.StoredFieldsShardResponseProcessor
 
storeDir - Variable in class org.apache.solr.spelling.suggest.Suggester
 
storedToIndexed(IndexableField) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
storedToIndexed(IndexableField) - Method in class org.apache.solr.schema.EnumFieldType
 
storedToIndexed(IndexableField) - Method in class org.apache.solr.schema.FieldType
Given the stored field, return the indexed form
storedToIndexed(IndexableField) - Method in class org.apache.solr.schema.PointField
 
storedToIndexed(IndexableField) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
storedToReadable(IndexableField) - Method in class org.apache.solr.schema.FieldType
Given the stored field, return the human readable representation
storedToReadable(IndexableField) - Method in class org.apache.solr.schema.PointField
 
storedToReadable(IndexableField) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
storeFailureDetails(String, ZkNodeProps, SolrResponse) - Method in class org.apache.solr.cloud.Stats
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.fst.BlendedInfixLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.fst.FreeTextLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.fst.FSTLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.fst.WFSTLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.jaspell.JaspellLookupFactory
 
storeFileName() - Method in class org.apache.solr.spelling.suggest.LookupFactory
Returns the filename in which the in-memory data structure is stored NOTE: not all Lookup implementations store in-memory data structures
storeFileName() - Method in class org.apache.solr.spelling.suggest.tst.TSTLookupFactory
 
storeManagedData(Object) - Method in class org.apache.solr.rest.ManagedResource
Persists managed data to the configured storage IO as a JSON object.
storeOffsetsWithPositions() - Method in class org.apache.solr.schema.SchemaField
 
storeTermOffsets() - Method in class org.apache.solr.schema.SchemaField
 
storeTermPayloads() - Method in class org.apache.solr.schema.SchemaField
 
storeTermPositions() - Method in class org.apache.solr.schema.SchemaField
 
storeTermVector() - Method in class org.apache.solr.schema.SchemaField
 
storeTermVectorOffsets() - Method in class org.apache.solr.schema.SchemaField
 
storeTermVectorPayloads() - Method in class org.apache.solr.schema.SchemaField
 
storeTermVectorPositions() - Method in class org.apache.solr.schema.SchemaField
 
storeTermVectors() - Method in class org.apache.solr.schema.SchemaField
 
str - Variable in class org.apache.solr.schema.PreAnalyzedField.ParseResult
 
str1 - Variable in class org.apache.solr.search.function.distance.StringDistanceFunction
 
str2 - Variable in class org.apache.solr.search.function.distance.StringDistanceFunction
 
StrAggValueSource - Class in org.apache.solr.search.facet
 
StrAggValueSource(String, String) - Constructor for class org.apache.solr.search.facet.StrAggValueSource
 
strategy - Variable in class org.apache.solr.internal.csv.CSVPrinter
 
stream(InputStream) - Method in class org.apache.solr.handler.loader.CborLoader
 
STREAM - org.apache.solr.search.facet.FacetField.FacetMethod
 
streamAsBytes(InputStream) - Static method in class org.apache.solr.handler.designer.DefaultSampleDocumentsLoader
 
StreamHandler - Class in org.apache.solr.handler
Solr Request Handler for streaming data.
StreamHandler() - Constructor for class org.apache.solr.handler.StreamHandler
 
StreamHandler.DaemonCollectionStream - Class in org.apache.solr.handler
 
StreamHandler.DaemonResponseStream - Class in org.apache.solr.handler
 
StreamHandler.DummyErrorStream - Class in org.apache.solr.handler
 
StreamHandler.ExpressibleHolder - Class in org.apache.solr.handler
 
StreamHandler.TimerStream - Class in org.apache.solr.handler
 
STREAMING - org.apache.solr.security.AuditEvent.RequestType
 
StreamingSolrClients - Class in org.apache.solr.update
 
StreamingSolrClients(UpdateShardHandler) - Constructor for class org.apache.solr.update.StreamingSolrClients
 
streams - Variable in class org.apache.solr.request.SolrQueryRequestBase
 
StrField - Class in org.apache.solr.schema
 
StrField() - Constructor for class org.apache.solr.schema.StrField
 
StrFieldSource - Class in org.apache.solr.schema
 
StrFieldSource(String) - Constructor for class org.apache.solr.schema.StrFieldSource
 
STRING_DISTANCE - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
 
STRING_DISTANCE - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
STRING_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
StringDistanceFunction - Class in org.apache.solr.search.function.distance
 
StringDistanceFunction(ValueSource, ValueSource, StringDistance) - Constructor for class org.apache.solr.search.function.distance.StringDistanceFunction
 
stringIncludingLocalParams - Variable in class org.apache.solr.search.QParser
 
stringToStream(String) - Static method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Converts a string to an input stream
stringValueToIntValue(String) - Method in class org.apache.solr.schema.AbstractEnumField.EnumMapping
Converting the string (displayed) value (internal) to integer value (indicating the sort order)
stripIllegalOperators(CharSequence) - Static method in class org.apache.solr.util.SolrPluginUtils
Strips operators that are used illegally, otherwise returns its input.
stripTrailingSlash(String) - Method in class org.apache.solr.core.CachingDirectoryFactory
 
stripUnbalancedQuotes(CharSequence) - Static method in class org.apache.solr.util.SolrPluginUtils
Returns its input if there is an even (ie: balanced) number of '"' characters -- otherwise returns a String in which all '"' characters are striped out.
StrParser - Class in org.apache.solr.search
Simple class to help with parsing a string.
StrParser(String) - Constructor for class org.apache.solr.search.StrParser
 
StrParser(String, int, int) - Constructor for class org.apache.solr.search.StrParser
 
strValue() - Method in class org.apache.solr.schema.CurrencyValue
Returns a string representing the currency value such as "3.14,USD" for a CurrencyValue of $3.14 USD.
sub(String) - Method in class org.apache.solr.util.RTimerTree
Returns a subtimer given its name.
sub(Query, DocSet) - Method in class org.apache.solr.search.facet.FacetContext
 
SUB_FIELD_SUFFIX - Static variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
SUB_FIELD_TYPE - Static variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
Subfacet() - Constructor for class org.apache.solr.search.facet.LegacyFacet.Subfacet
 
subFacets - Variable in class org.apache.solr.search.facet.FacetRequest
 
subField(SchemaField, int, IndexSchema) - Method in class org.apache.solr.schema.AbstractSubTypeFieldType
 
subFieldType - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
submit(Overseer.Message) - Method in class org.apache.solr.cloud.Overseer
Submit an intra-process message which will be picked up and executed when Overseer.ClusterStateUpdater's loop runs next time
submit(ShardRequest, String, ModifiableSolrParams) - Method in class org.apache.solr.handler.component.HttpShardHandler
 
submit(ShardRequest, String, ModifiableSolrParams) - Method in class org.apache.solr.handler.component.ShardHandler
 
submitAsyncTask(CoreAdminHandler.CoreAdminAsyncTracker.TaskObject) - Method in class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker
 
submitCollectionApiCommand(ZkNodeProps, CollectionParams.CollectionAction) - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
submitCollectionApiCommand(ZkNodeProps, CollectionParams.CollectionAction, long) - Method in class org.apache.solr.handler.admin.CollectionsHandler
 
submitCollectionApiCommand(CoreContainer, Optional<DistributedCollectionConfigSetCommandRunner>, ZkNodeProps, CollectionParams.CollectionAction, long) - Static method in class org.apache.solr.handler.admin.CollectionsHandler
 
submitIntraProcessMessage(Overseer.Message) - Method in interface org.apache.solr.cloud.api.collections.CollectionCommandContext
Method used by Per Replica States implementation to force the cluster state updater to immediately reload a collection from Zookeeper.
submitIntraProcessMessage(Overseer.Message) - Method in class org.apache.solr.cloud.api.collections.OcmhCollectionCommandContext
 
submitRemoteMessageAndHandleResponse(SubResponseAccumulatingJerseyResponse, CollectionParams.CollectionAction, ZkNodeProps, String) - Method in class org.apache.solr.handler.admin.api.AdminAPIBase
 
subParser - Variable in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
 
subQuery(String, String) - Method in class org.apache.solr.search.QParser
Create a new QParser for parsing an embedded sub-query
SubQueryAugmenterFactory - Class in org.apache.solr.response.transform
This transformer executes subquery per every result document.
SubQueryAugmenterFactory() - Constructor for class org.apache.solr.response.transform.SubQueryAugmenterFactory
 
subset(int, int) - Method in interface org.apache.solr.search.DocList
Get a subset of an existing DocList.
subset(int, int) - Method in class org.apache.solr.search.DocSlice
 
subsetMatch - Variable in class org.apache.solr.handler.component.QueryElevationComponent.ElevatingQuery
 
substitutableProperties - Variable in class org.apache.solr.core.CoreDescriptor
The properties for this core, substitutable by resource loaders
substitutableProperties - Variable in class org.apache.solr.schema.IndexSchema
 
substring() - Method in class org.apache.solr.request.SubstringBytesRefFilter
 
SubstringBytesRefFilter - Class in org.apache.solr.request
An implementation of Predicate which returns true if the BytesRef contains a given substring.
SubstringBytesRefFilter(String, boolean) - Constructor for class org.apache.solr.request.SubstringBytesRefFilter
 
subSuffix - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
subtituteVal(String) - Method in class org.apache.solr.util.DataConfigNode
 
subType - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
success - Variable in class org.apache.solr.cloud.Stats.Stat
 
success() - Static method in class org.apache.solr.update.PeerSync.PeerSyncResult
 
success(String) - Method in class org.apache.solr.cloud.Stats
 
Successful - org.apache.solr.core.snapshots.CollectionSnapshotMetaData.SnapshotStatus
 
suffix - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
SUFFIX_MAXX - Static variable in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
SUFFIX_MAXY - Static variable in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
SUFFIX_MINX - Static variable in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
SUFFIX_MINY - Static variable in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
SUFFIX_XDL - Static variable in class org.apache.solr.legacy.BBoxStrategy
Deprecated.
 
suffixes - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
 
SUGGEST_ALL_TERMS_REQUIRED - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
Whether all terms are required or not
SUGGEST_BUILD - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
Whether to build the index or not.
SUGGEST_BUILD_ALL - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
Whether to build the index or not for all suggesters in the component.
SUGGEST_CONTEXT_FILTER_QUERY - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
contextFilterQuery to use for filtering the result of the suggestion
SUGGEST_COUNT - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
The count of suggestions to return for each query term not in the index and/or dictionary.
SUGGEST_DICT - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
The name of the dictionary to be used for giving the suggestion for a request.
SUGGEST_HIGHLIGHT - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
Whether keyword should be highlighted in result or not
SUGGEST_PREFIX - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
 
SUGGEST_Q - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
Use the value for this parameter as the query to spell check.
SUGGEST_RELOAD - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
Whether to reload the index.
SUGGEST_RELOAD_ALL - Static variable in interface org.apache.solr.spelling.suggest.SuggesterParams
Whether to reload the index or not for all suggesters in the component.
SuggestComponent - Class in org.apache.solr.handler.component
SuggestComponent: interacts with multiple SolrSuggester to serve up suggestions Responsible for routing commands and queries to the appropriate SolrSuggester and for initializing them as specified by SolrConfig
SuggestComponent() - Constructor for class org.apache.solr.handler.component.SuggestComponent
 
suggestedVsWord - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
Suggester - Class in org.apache.solr.spelling.suggest
 
Suggester() - Constructor for class org.apache.solr.spelling.suggest.Suggester
 
SuggesterOptions - Class in org.apache.solr.spelling.suggest
Encapsulates the inputs required to be passed on to the underlying suggester in SolrSuggester
SuggesterOptions(CharsRef, int, String, boolean, boolean) - Constructor for class org.apache.solr.spelling.suggest.SuggesterOptions
 
SuggesterParams - Interface in org.apache.solr.spelling.suggest
 
SuggesterResult - Class in org.apache.solr.spelling.suggest
Encapsulates the results returned by the suggester in SolrSuggester
SuggesterResult() - Constructor for class org.apache.solr.spelling.suggest.SuggesterResult
 
suggesters - Variable in class org.apache.solr.handler.component.SuggestComponent
Key is the dictionary name used in SolrConfig, value is the corresponding SolrSuggester
suggestField(String, List<Object>, IndexSchema, List<String>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
suggestField(String, List<Object>, IndexSchema, List<String>) - Method in interface org.apache.solr.handler.designer.SchemaSuggester
 
suggestion - Variable in class org.apache.solr.spelling.ResultEntry
 
suggestMode - Variable in class org.apache.solr.spelling.SpellingOptions
 
SuggestQueryConverter - Class in org.apache.solr.spelling
Passes the entire query string to the configured analyzer as-is.
SuggestQueryConverter() - Constructor for class org.apache.solr.spelling.SuggestQueryConverter
 
sum - org.apache.solr.handler.component.StatsField.Stat
 
SUM_FREQ - org.apache.solr.spelling.WordBreakSolrSpellChecker.BreakSuggestionTieBreaker
See WordBreakSpellChecker.BreakSuggestionSortMethod.NUM_CHANGES_THEN_SUMMED_FREQUENCY
SumAgg - Class in org.apache.solr.search.facet
 
SumAgg(ValueSource) - Constructor for class org.apache.solr.search.facet.SumAgg
 
SumAgg.Merger - Class in org.apache.solr.search.facet
 
sumDocFreq - Variable in class org.apache.solr.search.stats.CollectionStats
 
summarize(List<PhrasesIdentificationComponent.Phrase>) - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
Given a list of phrases to be returned to the user, summarizes those phrases by decorating the original input string to indicate where the identified phrases exist, using PhrasesIdentificationComponent.PhrasesContextData.summaryPre and PhrasesIdentificationComponent.PhrasesContextData.summaryPost
SUMMARY - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
summaryPost - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
summaryPre - Variable in class org.apache.solr.handler.component.PhrasesIdentificationComponent.PhrasesContextData
 
sumOfSquares - org.apache.solr.handler.component.StatsField.Stat
 
SumsqAgg - Class in org.apache.solr.search.facet
 
SumsqAgg(ValueSource) - Constructor for class org.apache.solr.search.facet.SumsqAgg
 
sumTotalTermFreq - Variable in class org.apache.solr.search.stats.CollectionStats
 
supportedModes() - Method in enum org.apache.solr.core.NodeRoles.Role
 
supportedRoles(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.ClusterAPI
 
supportedScoreModes - Variable in class org.apache.solr.schema.AbstractSpatialFieldType
 
supportsAnalyzers() - Method in class org.apache.solr.schema.FieldType
Returns true if this type supports index and query analyzers, false otherwise.
supportsAnalyzers() - Method in class org.apache.solr.schema.TextField
 
SUPPRESS_ERROR_ON_NOT_FOUND_EXCEPTION - Static variable in interface org.apache.solr.jersey.RequestContextKeys
A flag read by NotFoundExceptionMapper to suppress its normal error response
SurroundQParserPlugin - Class in org.apache.solr.search
Plugin for lucene Surround query parser, bringing SpanQuery support to Solr.
SurroundQParserPlugin() - Constructor for class org.apache.solr.search.SurroundQParserPlugin
 
suspend(long, TimeUnit, ContainerResponseWriter.TimeoutHandler) - Method in class org.apache.solr.jersey.container.JettyBridgeResponseWriter
 
swap(String, String) - Method in class org.apache.solr.core.CoreContainer
Swaps two SolrCore descriptors.
swap(String, String) - Method in class org.apache.solr.core.SolrCores
 
swap(CoreContainer, CoreDescriptor, CoreDescriptor) - Method in class org.apache.solr.core.CorePropertiesLocator
 
swap(CoreContainer, CoreDescriptor, CoreDescriptor) - Method in interface org.apache.solr.core.CoresLocator
Swap two core definitions
SWAP_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
swapCores(String, SwapCoresRequestBody) - Method in class org.apache.solr.handler.admin.api.SwapCores
 
SwapCores - Class in org.apache.solr.handler.admin.api
 
SwapCores(CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.SwapCores
 
swapRegistries(String, String) - Method in class org.apache.solr.metrics.SolrMetricManager
Swap registries.
SWEEP_COLLECTION - Static variable in class org.apache.solr.search.facet.RelatednessAgg
 
SweetSpotSimilarityFactory - Class in org.apache.solr.search.similarities
Factory for SweetSpotSimilarity.
SweetSpotSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.SweetSpotSimilarityFactory
 
SWITCH_CASE - Static variable in class org.apache.solr.search.SwitchQParserPlugin
Used as both a local params key to find the "default" if no blank input is provided to the parser, as well as a prefix (followed by '.' for looking up the switch input.
SWITCH_DEFAULT - Static variable in class org.apache.solr.search.SwitchQParserPlugin
A local param whose value, if specified, is used if no switch case matches the parser input.
SwitchQParserPlugin - Class in org.apache.solr.search
A QParserPlugin that acts like a "switch/case" statement.
SwitchQParserPlugin() - Constructor for class org.apache.solr.search.SwitchQParserPlugin
 
SwitchTo(int) - Method in class org.apache.solr.parser.QueryParserTokenManager
Switch to specified lex state.
sync() - Method in class org.apache.solr.update.PeerSync
Returns true if peer sync was successful, meaning that this core may be considered to have the latest updates.
sync(File) - Static method in class org.apache.solr.util.FileUtils
Copied from Lucene's FSDirectory.fsync(String)
sync(List<Long>) - Method in class org.apache.solr.update.PeerSyncWithLeader
Sync with leader
sync(ZkController, SolrCore, ZkNodeProps) - Method in class org.apache.solr.cloud.SyncStrategy
 
sync(ZkController, SolrCore, ZkNodeProps, boolean) - Method in class org.apache.solr.cloud.SyncStrategy
 
synchronous - Variable in class org.apache.solr.update.SolrCmdDistributor.Req
 
syncRequestTracker(CollectionCommandContext) - Static method in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
syncShard(String, String) - Method in class org.apache.solr.handler.admin.api.SyncShard
 
SyncShard - Class in org.apache.solr.handler.admin.api
V2 API implementation for triggering a shard-sync operation within a particular collection and shard.
SyncShard(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.SyncShard
 
SYNCSHARD_OP - org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
 
SyncStrategy - Class in org.apache.solr.cloud
 
SyncStrategy(CoreContainer) - Constructor for class org.apache.solr.cloud.SyncStrategy
 
syncToAllNodes(String) - Method in class org.apache.solr.filestore.DistribFileStore
 
syncToAllNodes(String) - Method in interface org.apache.solr.filestore.FileStore
Sync a local file to all nodes.
SYNONYM_MAPPINGS - Static variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory
Deprecated.
 
SYNONYM_MAPPINGS - Static variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory
 
SYNONYM_QUERY_STYLE - Static variable in class org.apache.solr.schema.FieldType
 
SynonymManager(String, SolrResourceLoader, ManagedResourceStorage.StorageIO) - Constructor for class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
SynonymManager(String, SolrResourceLoader, ManagedResourceStorage.StorageIO) - Constructor for class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
synonymMappings - Variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymFilterFactory.SynonymManager
Deprecated.
 
synonymMappings - Variable in class org.apache.solr.rest.schema.analysis.ManagedSynonymGraphFilterFactory.SynonymManager
 
synonymQueryStyle - Variable in class org.apache.solr.parser.SolrQueryParserBase
 
synonymQueryStyle - Variable in class org.apache.solr.schema.TextField
 
syntaxError - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
SyntaxError - Exception in org.apache.solr.search
Simple checked exception for parsing errors
SyntaxError(String) - Constructor for exception org.apache.solr.search.SyntaxError
 
SyntaxError(String, Throwable) - Constructor for exception org.apache.solr.search.SyntaxError
 
SyntaxError(Throwable) - Constructor for exception org.apache.solr.search.SyntaxError
 
SYNTHETIC_COLL_PREFIX - Static variable in class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
SYSLOAD_AVG - Static variable in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
System load average.
SYSPROP_CSP_CONNECT_SRC_URLS - Static variable in class org.apache.solr.servlet.LoadAdminUiServlet
 
SYSPROP_PREFIX - Static variable in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
SYSPROP_QUERY_CPU - Static variable in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
SYSPROP_QUERY_LOADAVG - Static variable in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
SYSPROP_QUERY_MEM - Static variable in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
SYSPROP_UPDATE_CPU - Static variable in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
SYSPROP_UPDATE_LOADAVG - Static variable in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
SYSPROP_UPDATE_MEM - Static variable in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
 
SysProps() - Constructor for class org.apache.solr.util.configuration.SSLConfigurations.SysProps
 
SysPropSSLCredentialProvider - Class in org.apache.solr.util.configuration.providers
System property based SSL configuration provider
SysPropSSLCredentialProvider() - Constructor for class org.apache.solr.util.configuration.providers.SysPropSSLCredentialProvider
 
SYSTEM_COLL_PREFIX - Static variable in class org.apache.solr.cloud.api.collections.Assign
 
systemCollectionCompatCheck(BiConsumer<String, Object>) - Method in class org.apache.solr.cloud.Overseer
 
SYSTEMID_UNTRUSTED - Static variable in class org.apache.solr.util.SafeXMLParsing
 
SystemIdResolver - Class in org.apache.solr.util
This is a helper class to support resolving of XIncludes or other hrefs inside XML files on top of a ResourceLoader.
SystemIdResolver(ResourceLoader) - Constructor for class org.apache.solr.util.SystemIdResolver
 
SystemInfoHandler - Class in org.apache.solr.handler.admin
This handler returns system info
SystemInfoHandler() - Constructor for class org.apache.solr.handler.admin.SystemInfoHandler
 
SystemInfoHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.SystemInfoHandler
 

T

TabularResponseWriter - Class in org.apache.solr.response
Base response writer for table-oriented data
TabularResponseWriter(Writer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.response.TabularResponseWriter
 
tag - Variable in class org.apache.solr.core.SolrConfig.SolrPluginInfo
 
tagCallback(int, int, Object) - Method in class org.apache.solr.handler.tagger.Tagger
Invoked by Tagger.process() for each tag found.
TagClusterReducer - Interface in org.apache.solr.handler.tagger
 
tagEnclosesOffset(int, int) - Method in class org.apache.solr.handler.tagger.OffsetCorrector
 
Tagger - Class in org.apache.solr.handler.tagger
Tags maximum string of words in a corpus.
Tagger(Terms, Bits, TokenStream, TagClusterReducer, boolean, boolean) - Constructor for class org.apache.solr.handler.tagger.Tagger
 
TaggerRequestHandler - Class in org.apache.solr.handler.tagger
Scans posted text, looking for matching strings in the Solr index.
TaggerRequestHandler() - Constructor for class org.apache.solr.handler.tagger.TaggerRequestHandler
 
TaggingAttribute - Interface in org.apache.solr.handler.tagger
Attribute used by the Tagger to decide if a token can start a new tag.
TaggingAttributeImpl - Class in org.apache.solr.handler.tagger
Implementation of the TaggingAttribute
TaggingAttributeImpl() - Constructor for class org.apache.solr.handler.tagger.TaggingAttributeImpl
 
tagInfo - Variable in class org.apache.solr.handler.tagger.OffsetCorrector
Array of tag info comprised of 5 int fields: [int parentTag, int openStartOff, int openEndOff, int closeStartOff, int closeEndOff].
TagLL - Class in org.apache.solr.handler.tagger
This is a Tag -- a startOffset, endOffset and value.
tags - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
TAGS_LIMIT - Static variable in class org.apache.solr.handler.tagger.TaggerRequestHandler
Request parameter.
take() - Method in class org.apache.solr.cloud.ZkDistributedQueue
Removes the head of the queue and returns it, blocks until it succeeds.
takeCompletedIncludingErrors() - Method in class org.apache.solr.handler.component.HttpShardHandler
returns a ShardResponse of the last response correlated with a ShardRequest.
takeCompletedIncludingErrors() - Method in class org.apache.solr.handler.component.ShardHandler
 
takeCompletedOrError() - Method in class org.apache.solr.handler.component.HttpShardHandler
returns a ShardResponse of the last response correlated with a ShardRequest, or immediately returns a ShardResponse if there was an error detected
takeCompletedOrError() - Method in class org.apache.solr.handler.component.ShardHandler
 
TARGET - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
TARGET_COL_PREFIX - Static variable in class org.apache.solr.cloud.api.collections.ReindexCollectionCmd
 
targetCore - Variable in class org.apache.solr.handler.admin.api.SplitCoreAPI.SplitCorePayload
 
TaskManagementHandler - Class in org.apache.solr.handler.component
Abstract class which serves as the root of all task managing handlers
TaskManagementHandler() - Constructor for class org.apache.solr.handler.component.TaskManagementHandler
 
TaskObject(String, String, boolean, Callable<SolrQueryResponse>) - Constructor for class org.apache.solr.handler.admin.CoreAdminHandler.CoreAdminAsyncTracker.TaskObject
 
TDF_STRATEGY - Static variable in class org.apache.solr.internal.csv.CSVStrategy
 
TEMP_COLLECTION_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
templateAdd - Variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
TemplateUpdateProcessorFactory - Class in org.apache.solr.update.processor
Adds new fields to documents based on a template pattern specified via Template.field request parameters (multi-valued) or 'field' value specified in initArgs.
TemplateUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.TemplateUpdateProcessorFactory
 
TemplateUpdateProcessorFactory.Resolved - Class in org.apache.solr.update.processor
 
term - Variable in class org.apache.solr.handler.MoreLikeThisHandler.InterestingTerm
 
term - Variable in class org.apache.solr.search.stats.TermStats
 
Term(String) - Method in class org.apache.solr.parser.QueryParser
 
TERM - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
TERM_IN_BOOLEAN_QUERY_FLAG - Static variable in class org.apache.solr.spelling.QueryConverter
This term exists in a query that contains boolean operators (AND/OR/NOT)
TERM_PRECEDES_NEW_BOOLEAN_OPERATOR_FLAG - Static variable in class org.apache.solr.spelling.QueryConverter
This term is directly followed by a boolean operator (AND/OR/NOT) and this operator differs from the prior boolean operator in the query (this signifies this term is likely part of a different query clause than the next term in the query)
TERM_STATS_KEY - Static variable in class org.apache.solr.search.stats.StatsCache
Map of terms and TermStats.
TERM_VECTORS - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
TERM_VECTORS - Static variable in class org.apache.solr.handler.component.TermVectorComponent
 
TermCountComparator() - Constructor for class org.apache.solr.handler.component.TermsComponent.TermCountComparator
 
termFromEncodedString(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
TERMINATE_EARLY - Static variable in class org.apache.solr.search.SolrIndexSearcher
 
termInstances - Variable in class org.apache.solr.uninverting.DocTermOrds
Total number of references to term numbers.
termNum - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
termNum - Variable in class org.apache.solr.handler.component.FacetComponent.ShardFacetCount
 
TermQParserPlugin - Class in org.apache.solr.search
Create a single term query from the input value equivalent to readableToIndexed().
TermQParserPlugin() - Constructor for class org.apache.solr.search.TermQParserPlugin
 
terms(String) - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
TERMS - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
TERMS_KEY - Static variable in class org.apache.solr.search.stats.StatsCache
List of terms in the query.
TERMS_QUERY_THRESHOLD - Static variable in class org.apache.solr.parser.SolrQueryParserBase
 
TermsComponent - Class in org.apache.solr.handler.component
Return TermEnum information, useful for things like auto suggest.
TermsComponent() - Constructor for class org.apache.solr.handler.component.TermsComponent
 
TermsComponent.TermCountComparator - Class in org.apache.solr.handler.component
Comparator for TermsResponse.Term sorting This sorts term by frequency in descending order
TermsComponent.TermsHelper - Class in org.apache.solr.handler.component
 
termsEnum - Variable in class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
 
termsEnum(Terms) - Method in interface org.apache.solr.uninverting.FieldCache.Parser
Deprecated.
index with Points instead
termsEnum(Terms) - Method in class org.apache.solr.uninverting.FieldCache.PointParser
 
termsFromEncodedString(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
TermsHelper() - Constructor for class org.apache.solr.handler.component.TermsComponent.TermsHelper
 
TermsQParserPlugin - Class in org.apache.solr.search
Finds documents whose specified field has any of the specified values.
TermsQParserPlugin() - Constructor for class org.apache.solr.search.TermsQParserPlugin
 
termStatistics(Term, int, long) - Method in class org.apache.solr.search.SolrIndexSearcher
 
termStatistics(SolrIndexSearcher, Term, int, long) - Method in class org.apache.solr.search.stats.ExactStatsCache.ExactStatsSource
 
termStatistics(SolrIndexSearcher, Term, int, long) - Method in class org.apache.solr.search.stats.LocalStatsSource
 
termStatistics(SolrIndexSearcher, Term, int, long) - Method in class org.apache.solr.search.stats.StatsSource
 
TermStats - Class in org.apache.solr.search.stats
Modifiable version of TermStatistics useful for aggregation of per-shard stats.
TermStats(String) - Constructor for class org.apache.solr.search.stats.TermStats
 
TermStats(String, long, long) - Constructor for class org.apache.solr.search.stats.TermStats
 
TermStats(String, TermStatistics) - Constructor for class org.apache.solr.search.stats.TermStats
 
termStatsMapFromString(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
termStatsMapToString(Map<String, TermStats>) - Static method in class org.apache.solr.search.stats.StatsUtil
 
termStatsToString(TermStats, boolean) - Static method in class org.apache.solr.search.stats.StatsUtil
 
termsToEncodedString(Collection<?>) - Static method in class org.apache.solr.search.stats.StatsUtil
 
termToEncodedString(String) - Static method in class org.apache.solr.search.stats.StatsUtil
 
termToEncodedString(Term) - Static method in class org.apache.solr.search.stats.StatsUtil
 
TermVectorComponent - Class in org.apache.solr.handler.component
Return term vectors for the documents in a query result set.
TermVectorComponent() - Constructor for class org.apache.solr.handler.component.TermVectorComponent
 
termVectors() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
test(BytesRef) - Method in class org.apache.solr.request.RegexBytesRefFilter
 
test(BytesRef) - Method in class org.apache.solr.request.SubstringBytesRefFilter
 
TEST_DEFAULT - Static variable in class org.apache.solr.update.UpdateShardHandlerConfig
 
TEST_DISTRIB_SKIP_SERVERS - Static variable in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
TEST_HACK_IGNORE_USELESS_TRIEFIELD_ARGS - Static variable in class org.apache.solr.schema.PointField
The Test framework can set this global variable to instruct PointField that (on init) it should be tolerant of the precisionStep argument used by TrieFields.
testAndSetAchievedRf(int) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor.RollupRequestReplicationTracker
 
testing_beforeRegisterInZk - Static variable in class org.apache.solr.core.ZkContainer
 
testing_beforeReplayBufferingUpdates - Static variable in class org.apache.solr.cloud.RecoveryStrategy
 
testing_errorHook - Static variable in class org.apache.solr.update.SolrCmdDistributor
 
testing_logReplayFinishHook - Static variable in class org.apache.solr.update.UpdateLog
 
testing_logReplayHook - Static variable in class org.apache.solr.update.UpdateLog
 
TestInjection - Class in org.apache.solr.util
Allows random faults to be injected in running code during test runs.
TestInjection() - Constructor for class org.apache.solr.util.TestInjection
 
TestInjection.Hook - Interface in org.apache.solr.util
 
TestInjection.TestShutdownFailError - Error in org.apache.solr.util
 
TestShutdownFailError(String) - Constructor for error org.apache.solr.util.TestInjection.TestShutdownFailError
 
text - org.apache.solr.response.transform.ExplainAugmenterFactory.Style
 
textData - Variable in class org.apache.solr.util.DataConfigNode
 
TextField - Class in org.apache.solr.schema
TextField is the basic type for configurable text analysis.
TextField() - Constructor for class org.apache.solr.schema.TextField
 
TextLogisticRegressionQParserPlugin - Class in org.apache.solr.search
Returns an AnalyticsQuery implementation that performs one Gradient Descent iteration of a result set to train a logistic regression model
TextLogisticRegressionQParserPlugin() - Constructor for class org.apache.solr.search.TextLogisticRegressionQParserPlugin
 
TextProfileSignature - Class in org.apache.solr.update.processor
This implementation is copied from Apache Nutch.
TextProfileSignature() - Constructor for class org.apache.solr.update.processor.TextProfileSignature
 
TextResponseWriter - Class in org.apache.solr.response
Base class for text-oriented response writers.
TextResponseWriter(Writer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.response.TextResponseWriter
 
ThreadDumpHandler - Class in org.apache.solr.handler.admin
 
ThreadDumpHandler() - Constructor for class org.apache.solr.handler.admin.ThreadDumpHandler
 
threads - Variable in class org.apache.solr.request.SimpleFacets.ParsedParams
 
threadsIntervalSeconds - Variable in class org.apache.solr.core.MetricsConfig.CacheConfig
 
threshold - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LogMessageInfo
 
threshold - Variable in class org.apache.solr.logging.ListenerConfig
 
threshold - Variable in class org.apache.solr.spelling.IndexBasedSpellChecker
 
threshold - Variable in class org.apache.solr.spelling.suggest.Suggester
 
threshold(int) - Method in interface org.apache.solr.util.DynamicMap
Compute threshold for switching from hashMap based to array
THRESHOLD_TOKEN_FREQUENCY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
 
THRESHOLD_TOKEN_FREQUENCY - Static variable in class org.apache.solr.spelling.IndexBasedSpellChecker
 
THRESHOLD_TOKEN_FREQUENCY - Static variable in class org.apache.solr.spelling.suggest.HighFrequencyDictionaryFactory
Minimum frequency of terms to consider when building the dictionary.
THRESHOLD_TOKEN_FREQUENCY - Static variable in class org.apache.solr.spelling.suggest.Suggester
Minimum frequency of terms to consider when building the dictionary.
throwErrorIfReplicaReplaced(CoreDescriptor) - Method in class org.apache.solr.cloud.ZkController
 
tie - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias
 
tie - Variable in class org.apache.solr.util.SolrPluginUtils.DisjunctionMaxQueryParser.Alias
 
tiebreaker - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
 
TieredMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for TieredMergePolicy objects.
TieredMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.TieredMergePolicyFactory
 
time() - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
time(Runnable) - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
time(String) - Method in class org.apache.solr.cloud.Stats
 
time(Callable<T>) - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
TIME - Static variable in class org.apache.solr.cloud.api.collections.RoutedAlias
 
TimeAllowedExceededFromScorerException(String) - Constructor for exception org.apache.solr.search.SolrIndexSearcher.TimeAllowedExceededFromScorerException
 
TimedVersionBucket - Class in org.apache.solr.update
This implementation uses lock and condition and will throw exception if it can't obtain the lock within lockTimeoutMs.
TimedVersionBucket() - Constructor for class org.apache.solr.update.TimedVersionBucket
 
timeElapsed(TimeUnit) - Method in class org.apache.solr.util.TimeOut
 
timeLeft(TimeUnit) - Method in class org.apache.solr.util.TimeOut
 
TimeOut - Class in org.apache.solr.util
 
TimeOut(long, TimeUnit, TimeSource) - Constructor for class org.apache.solr.util.TimeOut
 
timer(String, String...) - Method in class org.apache.solr.metrics.SolrDelegateRegistryMetricsContext
 
timer(String, String...) - Method in class org.apache.solr.metrics.SolrMetricsContext
timer(SolrMetricsContext, String, String, String...) - Method in class org.apache.solr.metrics.SolrMetricManager
Create or get an existing named Timer
TIMER - Static variable in interface org.apache.solr.jersey.RequestContextKeys
 
timeRandomId() - Static method in class org.apache.solr.util.IdUtils
Generate a random id with a timestamp, in the format: hex(timestamp) + 'T' + randomId .
timeRandomId(long) - Static method in class org.apache.solr.util.IdUtils
Generate a random id with a timestamp, in the format: hex(timestamp) + 'T' + randomId .
TimeRoutedAlias - Class in org.apache.solr.cloud.api.collections
Holds configuration for a routed alias, and some common code and constants.
TimeRoutedAliasProperties() - Constructor for class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
TimerStream(TupleStream) - Constructor for class org.apache.solr.handler.GraphHandler.TimerStream
 
TimerStream(TupleStream) - Constructor for class org.apache.solr.handler.StreamHandler.TimerStream
 
timerSupplier(SolrResourceLoader, PluginInfo) - Static method in class org.apache.solr.metrics.MetricSuppliers
Create a Timer supplier.
timestamp - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
TimestampUpdateProcessorFactory - Class in org.apache.solr.update.processor
An update processor that adds a newly generated Date value of "NOW" to any document being added that does not already have a value in the specified field.
TimestampUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.TimestampUpdateProcessorFactory
 
timeSupplier(Supplier<T>) - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
TimeZoneUtils - Class in org.apache.solr.util
Simple utilities for working with TimeZones
tlog - Variable in class org.apache.solr.update.TransactionLog
 
tlog - Variable in class org.apache.solr.update.UpdateLog
 
TLOG - org.apache.solr.cluster.Replica.ReplicaType
 
TLOG - org.apache.solr.core.SolrInfoBean.Category
 
TLOG_FILE - Static variable in class org.apache.solr.handler.ReplicationHandler
 
TLOG_NAME - Static variable in class org.apache.solr.update.UpdateLog
 
tlogDir - Variable in class org.apache.solr.update.UpdateLog
 
tlogFiles - Variable in class org.apache.solr.update.UpdateLog
 
tnums - Variable in class org.apache.solr.uninverting.DocTermOrds
Holds term ords for documents.
to - Variable in class org.apache.solr.handler.admin.api.RenameCoreAPI.RenameCorePayload
 
to - Variable in class org.apache.solr.search.facet.FacetRequest.Domain.JoinField
 
TO - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
toArray() - Method in class org.apache.solr.search.DocSetCollector.ExpandingIntArray
 
toByteArray() - Method in class org.apache.solr.core.ConfigOverlay
 
toByteArray() - Method in class org.apache.solr.core.RequestParams
 
toBytes() - Method in class org.apache.solr.util.hll.HLL
Serializes the HLL to an array of bytes in correspondence with the format of the default schema version, SerializationUtil.DEFAULT_SCHEMA_VERSION.
toBytes(ISchemaVersion) - Method in class org.apache.solr.util.hll.HLL
Serializes the HLL to an array of bytes in correspondence with the format of the specified schema version.
toBytesRef(String) - Method in class org.apache.solr.handler.component.QueryElevationComponent.ElevationBuilder
 
toChildren - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
 
toChildren(DocSet, BitDocSet, DocSet, QueryContext) - Static method in class org.apache.solr.search.facet.BlockJoin
acceptDocs will normally be used to avoid deleted documents from being generated as part of the answer DocSet (just use *:*) although it can be used to further constrain the generated documents.
toCollectionStatistics() - Method in class org.apache.solr.search.stats.CollectionStats
 
toDocIDs(DocList) - Method in class org.apache.solr.highlight.UnifiedSolrHighlighter
Converts solr's DocList to the int[] docIDs
toDocument(SolrInputDocument, IndexSchema) - Static method in class org.apache.solr.update.DocumentBuilder
 
toDocument(SolrInputDocument, IndexSchema, boolean, boolean) - Static method in class org.apache.solr.update.DocumentBuilder
Convert a SolrInputDocument to a lucene Document.
toErrorMessage(List<CircuitBreaker>) - Static method in class org.apache.solr.util.circuitbreaker.CircuitBreakerRegistry
Construct the final error message to be printed when circuit breakers trip.
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.AnalyzeEvaluator
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.CatStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.ClassifyStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.export.ExportWriterStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.GraphHandler.DummyErrorStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.GraphHandler.TimerStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.StreamHandler.DaemonCollectionStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.StreamHandler.DaemonResponseStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.StreamHandler.DummyErrorStream
 
toExplanation(StreamFactory) - Method in class org.apache.solr.handler.StreamHandler.TimerStream
 
toExpression(StreamFactory) - Method in class org.apache.solr.handler.AnalyzeEvaluator
 
toExpression(StreamFactory) - Method in class org.apache.solr.handler.CatStream
 
toExpression(StreamFactory) - Method in class org.apache.solr.handler.ClassifyStream
 
toExpression(StreamFactory) - Method in class org.apache.solr.handler.export.ExportWriterStream
 
toExternal(IndexableField) - Method in class org.apache.solr.schema.AbstractEnumField
 
toExternal(IndexableField) - Method in class org.apache.solr.schema.BinaryField
 
toExternal(IndexableField) - Method in class org.apache.solr.schema.BoolField
 
toExternal(IndexableField) - Method in class org.apache.solr.schema.FieldType
Convert the stored-field format to an external (string, human readable) value
toExternal(IndexableField) - Method in class org.apache.solr.schema.LatLonPointSpatialField
 
toExternal(IndexableField) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
toField - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
toFormattedString(Field) - Method in class org.apache.solr.schema.JsonPreAnalyzedParser
 
toFormattedString(Field) - Method in interface org.apache.solr.schema.PreAnalyzedField.PreAnalyzedParser
Format a field so that the resulting String is valid for parsing with PreAnalyzedField.PreAnalyzedParser.parse(Reader, AttributeSource).
toFormattedString(Field) - Method in class org.apache.solr.schema.PreAnalyzedField
Utility method to convert a field to a string that is parse-able by this class.
toFormattedString(Field) - Method in class org.apache.solr.schema.SimplePreAnalyzedParser
 
toGlobalValue(SortValue) - Method in class org.apache.solr.handler.export.IntValue
 
toGlobalValue(SortValue) - Method in class org.apache.solr.handler.export.LongValue
 
toHtml(Explanation) - Static method in class org.apache.solr.response.transform.ExplainAugmenterFactory
Render an explanation as HTML.
toIndexWriterConfig(SolrCore) - Method in class org.apache.solr.update.SolrIndexConfig
 
toInternal(String) - Method in class org.apache.solr.schema.AbstractEnumField
 
toInternal(String) - Method in class org.apache.solr.schema.BoolField
 
toInternal(String) - Method in class org.apache.solr.schema.FieldType
Convert an external value (from XML update command or from query string) into the internal format for both storing and indexing (which can be modified by any analyzers).
toInternal(String) - Method in class org.apache.solr.schema.PointField
 
toInternal(String) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
toInternal(String) - Method in class org.apache.solr.schema.UUIDField
Generates a UUID if val is either null, empty or "NEW".
toInternal(UUID) - Method in class org.apache.solr.schema.UUIDField
 
toInternalByteRef(String) - Method in class org.apache.solr.schema.PointField
 
token - Variable in class org.apache.solr.parser.QueryParser
Current token.
token - Variable in class org.apache.solr.spelling.ResultEntry
 
Token - Class in org.apache.solr.parser
Describes the input token stream.
Token - Class in org.apache.solr.spelling
Deprecated.
Token() - Constructor for class org.apache.solr.parser.Token
No-argument constructor
Token() - Constructor for class org.apache.solr.spelling.Token
Deprecated.
Constructs a Token will null text.
Token(int) - Constructor for class org.apache.solr.parser.Token
Constructs a new token for the specified Image.
Token(int, String) - Constructor for class org.apache.solr.parser.Token
Constructs a new token for the specified Image and Kind.
Token(CharSequence, int, int) - Constructor for class org.apache.solr.spelling.Token
Deprecated.
Constructs a Token with the given term text, start and end offsets.
TOKEN_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
token_source - Variable in class org.apache.solr.parser.QueryParser
Generated Token Manager.
TOKEN_TYPE_FULL_PREC - Static variable in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
The full precision token gets this token type assigned.
TOKEN_TYPE_LOWER_PREC - Static variable in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
The lower precision tokens gets this token type assigned.
tokenImage - Variable in exception org.apache.solr.parser.ParseException
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
tokenImage - Static variable in interface org.apache.solr.parser.QueryParserConstants
Literal token values.
tokenized() - Method in class org.apache.solr.schema.SchemaField
 
TOKENIZED - Static variable in class org.apache.solr.schema.FieldProperties
 
TOKENIZER - Static variable in class org.apache.solr.schema.FieldType
 
TokenizerChain - Class in org.apache.solr.analysis
An analyzer that uses a tokenizer and a list of token filters to create a TokenStream.
TokenizerChain(CharFilterFactory[], TokenizerFactory, TokenFilterFactory[]) - Constructor for class org.apache.solr.analysis.TokenizerChain
Creates a new TokenizerChain.
TokenizerChain(CustomAnalyzer) - Constructor for class org.apache.solr.analysis.TokenizerChain
Copy from CustomAnalyzer.
TokenizerChain(TokenizerFactory, TokenFilterFactory[]) - Constructor for class org.apache.solr.analysis.TokenizerChain
Creates a new TokenizerChain w/o any CharFilterFactories.
TokenMgrError - Error in org.apache.solr.parser
Token Manager Error.
TokenMgrError() - Constructor for error org.apache.solr.parser.TokenMgrError
No arg constructor.
TokenMgrError(boolean, int, int, int, String, int, int) - Constructor for error org.apache.solr.parser.TokenMgrError
Full Constructor.
TokenMgrError(String, int) - Constructor for error org.apache.solr.parser.TokenMgrError
Constructor with message and reason.
tokens - Variable in class org.apache.solr.spelling.SpellingOptions
The tokens to spell check
TOKENS_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
tokenStream(Analyzer, TokenStream) - Method in class org.apache.solr.legacy.LegacyField
Deprecated.
 
TokenTrackingAttributeImpl() - Constructor for class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
 
TOLEADER - org.apache.solr.update.processor.DistributedUpdateProcessor.DistribPhase
 
TolerantUpdateProcessor - Class in org.apache.solr.update.processor
Suppresses errors for individual add/delete commands within a single request.
TolerantUpdateProcessor(SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor, int, DistributedUpdateProcessor.DistribPhase) - Constructor for class org.apache.solr.update.processor.TolerantUpdateProcessor
 
TolerantUpdateProcessorFactory - Class in org.apache.solr.update.processor
Suppresses errors for individual add/delete commands within a single request.
TolerantUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.TolerantUpdateProcessorFactory
 
toList() - Method in class org.apache.solr.logging.CircularList
 
toLocale(String) - Static method in class org.apache.solr.util.LocaleUtils
 
toLog - Variable in class org.apache.solr.response.SolrQueryResponse
Container for storing information that should be logged by Solr before returning.
toLower() - Method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.Cmd
 
toLower() - Method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
 
toLower() - Method in enum org.apache.solr.cloud.overseer.OverseerAction
 
toLower() - Method in enum org.apache.solr.search.ReRankOperator
 
toLower() - Method in enum org.apache.solr.update.SolrIndexSplitter.SplitMethod
 
toMap(Map<String, Object>) - Method in class org.apache.solr.core.ConfigOverlay
 
toMap(Map<String, Object>) - Method in class org.apache.solr.core.PluginInfo
 
toMap(Map<String, Object>) - Method in class org.apache.solr.core.RequestParams.ParamSet
 
toMap(Map<String, Object>) - Method in class org.apache.solr.core.RequestParams
 
toMap(Map<String, Object>) - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
 
toMap(Map<String, Object>) - Method in class org.apache.solr.core.SolrConfig
 
toMap(Map<String, Object>) - Method in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
toMap(Map<String, Object>) - Method in class org.apache.solr.schema.IndexSchema.SchemaProps
 
toMap(Map<String, Object>) - Method in class org.apache.solr.search.CacheConfig
 
toMap(Map<String, Object>) - Method in class org.apache.solr.update.IndexFingerprint
 
toMap(Map<String, Object>) - Method in class org.apache.solr.update.SolrIndexConfig
 
toMaps(MetricRegistry, List<MetricFilter>, MetricFilter, Predicate<CharSequence>, boolean, boolean, boolean, boolean, BiConsumer<String, Object>) - Static method in class org.apache.solr.util.stats.MetricUtils
Convert selected metrics to maps or to flattened objects.
toNamedList() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
toNamedList() - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
toNamedList(boolean, SpellingResult, String, boolean) - Method in class org.apache.solr.handler.component.SpellCheckComponent
 
toNativeType(Object) - Method in class org.apache.solr.schema.AbstractEnumField
 
toNativeType(Object) - Method in class org.apache.solr.schema.BinaryField
 
toNativeType(Object) - Method in class org.apache.solr.schema.BoolField
 
toNativeType(Object) - Method in class org.apache.solr.schema.DatePointField
 
toNativeType(Object) - Method in class org.apache.solr.schema.DoublePointField
 
toNativeType(Object) - Method in class org.apache.solr.schema.FieldType
Converts any Object to a java Object native to this field type
toNativeType(Object) - Method in class org.apache.solr.schema.FloatPointField
 
toNativeType(Object) - Method in class org.apache.solr.schema.IntPointField
 
toNativeType(Object) - Method in class org.apache.solr.schema.LongPointField
 
toNativeType(Object) - Method in class org.apache.solr.schema.TrieDateField
Deprecated.
 
toNativeType(Object) - Method in class org.apache.solr.schema.TrieDoubleField
Deprecated.
 
toNativeType(Object) - Method in class org.apache.solr.schema.TrieFloatField
Deprecated.
 
toNativeType(Object) - Method in class org.apache.solr.schema.TrieIntField
Deprecated.
 
toNativeType(Object) - Method in class org.apache.solr.schema.TrieLongField
Deprecated.
 
toNode(Map<String, ?>) - Static method in class org.apache.solr.rest.schema.FieldTypeXmlAdapter
 
toObject(IndexableField) - Method in class org.apache.solr.schema.AbstractEnumField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.BinaryField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.BoolField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.DatePointField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.DenseVectorField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.DoublePointField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.FieldType
Convert the stored-field format to an external object.
toObject(IndexableField) - Method in class org.apache.solr.schema.FloatPointField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.IntPointField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.LongPointField
 
toObject(IndexableField) - Method in class org.apache.solr.schema.TrieDateField
Deprecated.
 
toObject(IndexableField) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.BoolField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.DatePointField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.DoublePointField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.EnumField
Deprecated.
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.EnumFieldType
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.FieldType
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.FloatPointField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.IntPointField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.LongPointField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.StrField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.TextField
 
toObject(SchemaField, BytesRef) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
Tool - Interface in org.apache.solr.cli
 
ToolBase - Class in org.apache.solr.cli
 
ToolBase() - Constructor for class org.apache.solr.cli.ToolBase
 
ToolBase(PrintStream) - Constructor for class org.apache.solr.cli.ToolBase
 
top() - Method in class org.apache.solr.util.LongPriorityQueue
Returns the least element of the PriorityQueue in constant time.
toParent - Variable in class org.apache.solr.search.facet.FacetRequest.Domain
 
toParents(DocSet, BitDocSet, QueryContext) - Static method in class org.apache.solr.search.facet.BlockJoin
childInput may also contain parents (i.e.
topDocs(int, int) - Method in class org.apache.solr.search.ReRankCollector
 
TopGroupsFieldCommand - Class in org.apache.solr.search.grouping.distributed.command
Defines all collectors for retrieving the second phase and how to handle the collector result.
TopGroupsFieldCommand.Builder - Class in org.apache.solr.search.grouping.distributed.command
 
TopGroupsResultTransformer - Class in org.apache.solr.search.grouping.distributed.shardresultserializer
Implementation for transforming TopGroups and TopDocs into a NamedList structure and vice versa.
TopGroupsResultTransformer(ResponseBuilder) - Constructor for class org.apache.solr.search.grouping.distributed.shardresultserializer.TopGroupsResultTransformer
 
TopGroupsShardRequestFactory - Class in org.apache.solr.search.grouping.distributed.requestfactory
Concrete implementation of ShardRequestFactory that creates ShardRequest instances for getting the top groups from all shards.
TopGroupsShardRequestFactory() - Constructor for class org.apache.solr.search.grouping.distributed.requestfactory.TopGroupsShardRequestFactory
 
TopGroupsShardResponseProcessor - Class in org.apache.solr.search.grouping.distributed.responseprocessor
Concrete implementation for merging TopGroups instances from shard responses.
TopGroupsShardResponseProcessor() - Constructor for class org.apache.solr.search.grouping.distributed.responseprocessor.TopGroupsShardResponseProcessor
 
TopLevelJoinQuery - Class in org.apache.solr.search
JoinQuery implementation using global (top-level) DocValues ordinals to efficiently compare values in the "from" and "to" fields.
TopLevelJoinQuery(String, String, String, Query) - Constructor for class org.apache.solr.search.TopLevelJoinQuery
 
TopLevelJoinQuery.BitsetBounds - Class in org.apache.solr.search
 
TopLevelQuery(String) - Method in class org.apache.solr.parser.QueryParser
 
TopLevelQuery(String) - Method in class org.apache.solr.parser.SolrQueryParserBase
 
toResponse(NotFoundException) - Method in class org.apache.solr.jersey.NotFoundExceptionMapper
 
toResponse(Exception) - Method in class org.apache.solr.jersey.CatchAllExceptionMapper
 
toSmallSet(BitDocSet) - Static method in class org.apache.solr.search.DocSetUtil
 
toSolrDoc(SolrInputDocument, IndexSchema) - Static method in class org.apache.solr.handler.component.RealTimeGetComponent
Converts a SolrInputDocument to SolrDocument, using an IndexSchema instance.
toSolrDoc(SolrInputDocument, IndexSchema, boolean) - Static method in class org.apache.solr.handler.component.RealTimeGetComponent
Converts a SolrInputDocument to SolrDocument, using an IndexSchema instance.
toSolrDocument(E) - Method in class org.apache.solr.logging.LogWatcher
 
toSolrDocument(LogRecord) - Method in class org.apache.solr.logging.jul.JulWatcher
 
toSolrDocument(LogEvent) - Method in class org.apache.solr.logging.log4j2.Log4j2Watcher
 
toSolrInputDocuments(MetricRegistry, List<MetricFilter>, MetricFilter, Predicate<CharSequence>, boolean, boolean, boolean, Map<String, Object>, Consumer<SolrInputDocument>) - Static method in class org.apache.solr.util.stats.MetricUtils
Provides a representation of the given metric registry as SolrInputDocument-s.
toString() - Method in class org.apache.solr.analysis.TokenizerChain
 
toString() - Method in class org.apache.solr.cloud.ActiveReplicaWatcher
 
toString() - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
toString() - Method in class org.apache.solr.cloud.overseer.ZkWriteCommand
 
toString() - Method in class org.apache.solr.cluster.placement.impl.MetricImpl
 
toString() - Method in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
 
toString() - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
toString() - Method in class org.apache.solr.core.AbstractSolrEventListener
 
toString() - Method in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
 
toString() - Method in class org.apache.solr.core.ConfigOverlay
 
toString() - Method in class org.apache.solr.core.CoreDescriptor
 
toString() - Method in enum org.apache.solr.core.NodeRoles.Role
 
toString() - Method in class org.apache.solr.core.PluginBag.PluginHolder
 
toString() - Method in class org.apache.solr.core.PluginInfo.ClassName
 
toString() - Method in class org.apache.solr.core.PluginInfo
 
toString() - Method in class org.apache.solr.core.snapshots.SolrSnapshotMetaDataManager.SnapshotMetaData
 
toString() - Method in class org.apache.solr.core.SolrCore
 
toString() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Item
 
toString() - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.ItemPriorityQueue
 
toString() - Method in class org.apache.solr.handler.admin.SecurityConfHandler.SecurityConfig
 
toString() - Method in class org.apache.solr.handler.component.FacetComponent.ShardFacetCount
 
toString() - Method in class org.apache.solr.handler.component.PhrasesIdentificationComponent.Phrase
 
toString() - Method in class org.apache.solr.handler.component.PivotFacet
 
toString() - Method in class org.apache.solr.handler.component.PivotFacetField
 
toString() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
 
toString() - Method in class org.apache.solr.handler.component.PivotFacetValue
 
toString() - Method in class org.apache.solr.handler.component.QueryElevationComponent.Elevation
 
toString() - Method in class org.apache.solr.handler.component.ShardDoc
 
toString() - Method in class org.apache.solr.handler.component.ShardRequest
 
toString() - Method in class org.apache.solr.handler.component.ShardResponse
 
toString() - Method in class org.apache.solr.handler.component.StatsField
 
toString() - Method in class org.apache.solr.handler.tagger.TagLL
 
toString() - Method in class org.apache.solr.index.MergePolicyFactoryArgs
 
toString() - Method in class org.apache.solr.index.SlowCompositeReaderWrapper
 
toString() - Method in class org.apache.solr.index.SortingMergePolicy
 
toString() - Method in class org.apache.solr.internal.csv.CharBuffer
Converts the contents of the buffer into a StringBuffer.
toString() - Method in class org.apache.solr.legacy.LegacyFieldType
Deprecated.
Prints a Field for human consumption.
toString() - Method in class org.apache.solr.legacy.LegacyNumericTokenStream
Deprecated.
 
toString() - Method in class org.apache.solr.logging.CircularList
 
toString() - Method in class org.apache.solr.metrics.AggregateMetric
 
toString() - Method in class org.apache.solr.metrics.AggregateMetric.Update
 
toString() - Method in class org.apache.solr.metrics.MetricsMap
 
toString() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
 
toString() - Method in class org.apache.solr.metrics.SolrMetricInfo
 
toString() - Method in class org.apache.solr.metrics.SolrMetricManager.PrefixFilter
 
toString() - Method in class org.apache.solr.metrics.SolrMetricManager.RegexFilter
 
toString() - Method in class org.apache.solr.metrics.SolrMetricReporter
 
toString() - Method in class org.apache.solr.packagemanager.SolrPackage.Command
 
toString() - Method in class org.apache.solr.packagemanager.SolrPackage.Plugin
 
toString() - Method in class org.apache.solr.packagemanager.SolrPackage.SolrPackageRelease
 
toString() - Method in class org.apache.solr.packagemanager.SolrPackage
 
toString() - Method in class org.apache.solr.packagemanager.SolrPackageInstance
 
toString() - Method in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
 
toString() - Method in class org.apache.solr.parser.Token
Returns the image.
toString() - Method in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
toString() - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage.Version
 
toString() - Method in class org.apache.solr.request.IntervalFacets.FacetInterval
 
toString() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
toString() - Method in class org.apache.solr.response.transform.DocTransformer
 
toString() - Method in class org.apache.solr.schema.CurrencyValue
 
toString() - Method in enum org.apache.solr.schema.FieldType.MultiValueSelector
 
toString() - Method in class org.apache.solr.schema.FieldType
 
toString() - Method in class org.apache.solr.schema.FileExchangeRateProvider
 
toString() - Method in class org.apache.solr.schema.IndexSchema.DynamicCopy
 
toString() - Method in class org.apache.solr.schema.IndexSchema.DynamicField
 
toString() - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
 
toString() - Method in class org.apache.solr.schema.SchemaField
 
toString() - Method in class org.apache.solr.schema.ZkIndexSchemaReader
 
toString() - Method in class org.apache.solr.search.BitDocSet
 
toString() - Method in class org.apache.solr.search.CaffeineCache
 
toString() - Method in class org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelector
 
toString() - Method in class org.apache.solr.search.facet.FacetDebugInfo
 
toString() - Method in class org.apache.solr.search.facet.FacetRequest.FacetSort
 
toString() - Method in class org.apache.solr.search.facet.FacetRequest
 
toString() - Method in class org.apache.solr.search.facet.SlotAcc
 
toString() - Method in class org.apache.solr.search.facet.UnInvertedField
 
toString() - Method in class org.apache.solr.search.function.FileFloatSource
 
toString() - Method in class org.apache.solr.search.SolrCacheBase.AutoWarmCountRef
 
toString() - Method in class org.apache.solr.search.SolrIndexSearcher
 
toString() - Method in class org.apache.solr.search.SolrQueryTimeoutImpl
 
toString() - Method in class org.apache.solr.search.SolrReturnFields
 
toString() - Method in class org.apache.solr.search.SortedIntDocSet
 
toString() - Method in class org.apache.solr.search.SortSpec
 
toString() - Method in class org.apache.solr.search.stats.CollectionStats
 
toString() - Method in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
toString() - Method in class org.apache.solr.search.stats.TermStats
 
toString() - Method in class org.apache.solr.search.StrParser
 
toString() - Method in class org.apache.solr.security.AllowListUrlChecker
 
toString() - Method in class org.apache.solr.security.AuthorizationContext.CollectionRequest
 
toString() - Method in class org.apache.solr.security.PKIAuthenticationPlugin.PKIHeaderData
 
toString() - Method in class org.apache.solr.servlet.ServletInputStreamWrapper
 
toString() - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
toString() - Method in class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
 
toString() - Method in class org.apache.solr.spelling.suggest.SolrSuggester
 
toString() - Method in class org.apache.solr.uninverting.FieldCache.CacheEntry
 
toString() - Method in class org.apache.solr.uninverting.UninvertingReader
 
toString() - Method in class org.apache.solr.update.AddUpdateCommand
 
toString() - Method in class org.apache.solr.update.CommitTracker
 
toString() - Method in class org.apache.solr.update.CommitUpdateCommand
 
toString() - Method in class org.apache.solr.update.DeleteUpdateCommand
 
toString() - Method in class org.apache.solr.update.IndexFingerprint
 
toString() - Method in class org.apache.solr.update.MergeIndexesCommand
 
toString() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor.LeaderRequestReplicationTracker
 
toString() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor.RollupRequestReplicationTracker
 
toString() - Method in class org.apache.solr.update.RollbackUpdateCommand
 
toString() - Method in class org.apache.solr.update.SolrCmdDistributor.Req
 
toString() - Method in class org.apache.solr.update.SolrCmdDistributor.SolrError
 
toString() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
 
toString() - Method in class org.apache.solr.update.SplitIndexCommand
 
toString() - Method in class org.apache.solr.update.TransactionLog.ChannelFastInputStream
 
toString() - Method in class org.apache.solr.update.TransactionLog.FSReverseReader
 
toString() - Method in class org.apache.solr.update.TransactionLog.LogReader
 
toString() - Method in class org.apache.solr.update.TransactionLog.ReverseReader
 
toString() - Method in class org.apache.solr.update.TransactionLog
 
toString() - Method in class org.apache.solr.update.UpdateCommand
 
toString() - Method in class org.apache.solr.update.UpdateLog.DBQ
 
toString() - Method in class org.apache.solr.update.UpdateLog.LogPtr
 
toString() - Method in class org.apache.solr.update.UpdateLog.RecoveryInfo
 
toString() - Method in class org.apache.solr.update.UpdateLog
 
toString() - Method in class org.apache.solr.util.ConcurrentLRUCache.CacheEntry
 
toString() - Method in class org.apache.solr.util.DistanceUnits
 
toString() - Method in class org.apache.solr.util.RegexFileFilter
 
toString() - Method in class org.apache.solr.util.RTimerTree
 
toString() - Method in class org.apache.solr.util.TimeOut
 
toString(int) - Method in class org.apache.solr.search.function.CollapseScoreFunction.CollapseScoreFunctionValues
 
toString(String) - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
 
toString(String) - Method in class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
toString(String) - Method in class org.apache.solr.query.FilterQuery
 
toString(String) - Method in class org.apache.solr.query.SolrRangeQuery
 
toString(String) - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
toString(String) - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
toString(String) - Method in class org.apache.solr.search.ExtendedQueryBase
 
toString(String) - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
toString(String) - Method in class org.apache.solr.search.FunctionRangeQuery
 
toString(String) - Method in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
toString(String) - Method in class org.apache.solr.search.join.GraphQuery
 
toString(String) - Method in class org.apache.solr.search.join.HashRangeQuery
 
toString(String) - Method in class org.apache.solr.search.MatchCostQuery
 
toString(String) - Method in class org.apache.solr.search.WrappedQuery
 
toString(List<Query>, IndexSchema) - Static method in class org.apache.solr.search.QueryParsing
Builds a list of String which are stringified versions of a list of Queries
toString(Query, IndexSchema) - Static method in class org.apache.solr.search.QueryParsing
Formats a Query for debugging, using the IndexSchema to make complex field types readable.
toString(Query, IndexSchema, Appendable, int) - Static method in class org.apache.solr.search.QueryParsing
 
TOTAL_BUFFER_SIZE - Static variable in class org.apache.solr.search.PointMerger
 
TOTAL_DISK_GB - Static variable in class org.apache.solr.cluster.placement.impl.NodeMetricImpl
Total disk space in GB.
total_time - Variable in class org.apache.solr.uninverting.DocTermOrds
Total time to uninvert the field.
totalCount - Variable in class org.apache.solr.search.Grouping.Command
 
totalHitCount - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
totalNumberShardResponses - Variable in class org.apache.solr.handler.component.SpellCheckMergeData
 
totalSize - Variable in class org.apache.solr.uninverting.UninvertingReader.FieldCacheStats
 
totalSize() - Method in class org.apache.solr.core.backup.ShardBackupMetadata
 
totalTermFreq - Variable in class org.apache.solr.search.stats.TermStats
 
totalTime - Variable in class org.apache.solr.handler.RequestHandlerBase.HandlerMetrics
 
totalTime - Variable in class org.apache.solr.security.AuditLoggerPlugin
 
totalTime - Variable in class org.apache.solr.security.AuthenticationPlugin
 
totalWordCount() - Method in interface org.apache.solr.util.hll.IWordDeserializer
Returns the number of words that could be encoded in the sequence.
toTermStatistics() - Method in class org.apache.solr.search.stats.TermStats
 
touchConfDir(ZkSolrResourceLoader) - Static method in class org.apache.solr.cloud.ZkController
 
TOUCHED_ZNODE_DATA - Static variable in class org.apache.solr.cloud.ZkController
 
tpe - Variable in class org.apache.solr.cloud.OverseerTaskProcessor
 
trace_enabled() - Method in class org.apache.solr.parser.QueryParser
Trace enabled.
TRACE_ID - Static variable in class org.apache.solr.logging.MDCLoggingContext
 
TRACE_ID_GEN_ENABLED - Static variable in class org.apache.solr.core.TracerConfigurator
 
TraceAwareCommand(CollApiCmds.CollectionApiCommand) - Constructor for class org.apache.solr.cloud.api.collections.CollApiCmds.TraceAwareCommand
 
tracer - Variable in class org.apache.solr.core.CoreContainer
 
tracer - Variable in class org.apache.solr.handler.component.ShardRequest
Not null but may implement NoopTracer.
TracerConfigurator - Class in org.apache.solr.core
Produces an OpenTracing Tracer from configuration.
TracerConfigurator() - Constructor for class org.apache.solr.core.TracerConfigurator
 
TraceUtils - Class in org.apache.solr.util.tracing
Utilities for distributed tracing.
TraceUtils() - Constructor for class org.apache.solr.util.tracing.TraceUtils
 
trackDeleteByQuery(String, long) - Method in class org.apache.solr.update.UpdateLog
 
trackRequestResult(SolrCmdDistributor.Node, boolean) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor.LeaderRequestReplicationTracker
 
trackRequestResult(Response, InputStream, boolean) - Method in class org.apache.solr.update.SolrCmdDistributor.Req
 
TRADITIONAL_BACKUP - Static variable in class org.apache.solr.core.backup.BackupId
 
TRADITIONAL_BACKUP_PROPS_FILE - Static variable in class org.apache.solr.core.backup.BackupManager
 
traditionalBackup() - Static method in class org.apache.solr.core.backup.BackupId
 
TransactionLog - Class in org.apache.solr.update
Log Format: List{Operation, Version, ...} ADD, VERSION, DOC DELETE, VERSION, ID_BYTES DELETE_BY_QUERY, VERSION, String
TransactionLog() - Constructor for class org.apache.solr.update.TransactionLog
 
TransactionLog(Path, Collection<String>, boolean, TransactionLog.OutputStreamOpener, TransactionLog.ChannelInputStreamOpener) - Constructor for class org.apache.solr.update.TransactionLog
 
TransactionLog.ChannelFastInputStream - Class in org.apache.solr.update
 
TransactionLog.ChannelInputStreamOpener - Interface in org.apache.solr.update
TransactionLog.FSReverseReader - Class in org.apache.solr.update
 
TransactionLog.LogCodec - Class in org.apache.solr.update
 
TransactionLog.LogReader - Class in org.apache.solr.update
 
TransactionLog.OutputStreamOpener - Interface in org.apache.solr.update
TransactionLog.ReverseReader - Class in org.apache.solr.update
 
TransactionLog.SortedLogReader - Class in org.apache.solr.update
 
transfomResponse(ShardRequest, ShardResponse, String) - Method in class org.apache.solr.handler.component.HttpShardHandler
Subclasses could modify the Response based on the shard
transform(List<Command<?>>) - Method in class org.apache.solr.search.grouping.distributed.shardresultserializer.SearchGroupsResultTransformer
 
transform(List<Command<?>>) - Method in class org.apache.solr.search.grouping.distributed.shardresultserializer.TopGroupsResultTransformer
 
transform(Map<String, ?>, ResponseBuilder, EndResultTransformer.SolrDocumentSource) - Method in interface org.apache.solr.search.grouping.endresulttransformer.EndResultTransformer
Transforms the specified result into its final form and puts it into the specified response.
transform(Map<String, ?>, ResponseBuilder, EndResultTransformer.SolrDocumentSource) - Method in class org.apache.solr.search.grouping.endresulttransformer.GroupedEndResultTransformer
 
transform(Map<String, ?>, ResponseBuilder, EndResultTransformer.SolrDocumentSource) - Method in class org.apache.solr.search.grouping.endresulttransformer.MainEndResultTransformer
 
transform(Map<String, ?>, ResponseBuilder, EndResultTransformer.SolrDocumentSource) - Method in class org.apache.solr.search.grouping.endresulttransformer.SimpleEndResultTransformer
 
transform(SolrDocument, int) - Method in class org.apache.solr.response.transform.BaseEditorialTransformer
 
transform(SolrDocument, int) - Method in class org.apache.solr.response.transform.DocTransformer.NoopFieldTransformer
 
transform(SolrDocument, int) - Method in class org.apache.solr.response.transform.DocTransformer
This is where implementations do the actual work.
transform(SolrDocument, int) - Method in class org.apache.solr.response.transform.DocTransformers
 
transform(SolrDocument, int) - Method in class org.apache.solr.response.transform.RenameFieldTransformer
 
transform(SolrDocument, int) - Method in class org.apache.solr.response.transform.ScoreAugmenter
 
transform(SolrDocument, int) - Method in class org.apache.solr.response.transform.ValueSourceAugmenter
 
transform(SolrDocument, int, float) - Method in class org.apache.solr.response.transform.DocTransformer
This is where implementations do the actual work.
transform(SolrDocument, int, float) - Method in class org.apache.solr.response.transform.DocTransformers
 
transform(SolrDocument, int, float) - Method in class org.apache.solr.response.transform.ScoreAugmenter
 
transform(T) - Method in interface org.apache.solr.search.grouping.distributed.shardresultserializer.ShardResultTransformer
Transforms data to a NamedList structure for serialization purposes.
transformAnalyzer(Document, Map<String, ?>, String, String) - Static method in class org.apache.solr.rest.schema.FieldTypeXmlAdapter
 
transformer - Variable in class org.apache.solr.search.SolrReturnFields
 
TransformerFactory - Class in org.apache.solr.response.transform
New instance for each request
TransformerFactory() - Constructor for class org.apache.solr.response.transform.TransformerFactory
 
TransformerFactory.FieldRenamer - Interface in org.apache.solr.response.transform
The TransformerFactory.FieldRenamer interface should be implemented by any TransformerFactory capable of generating transformers that might rename fields, and should implement TransformerFactory.FieldRenamer.create(String, SolrParams, SolrQueryRequest, Map, Set) in place of TransformerFactory.create(String, SolrParams, SolrQueryRequest) (with the latter method overridden to throw UnsupportedOperationException).
transformSimilarity(Document, Map<String, ?>, String) - Static method in class org.apache.solr.rest.schema.FieldTypeXmlAdapter
 
transformToNative(NamedList<NamedList<?>>, Sort, Sort, String) - Method in class org.apache.solr.search.grouping.distributed.shardresultserializer.SearchGroupsResultTransformer
 
transformToNative(NamedList<NamedList<?>>, Sort, Sort, String) - Method in interface org.apache.solr.search.grouping.distributed.shardresultserializer.ShardResultTransformer
Transforms the specified shard response into native structures.
transformToNative(NamedList<NamedList<?>>, Sort, Sort, String) - Method in class org.apache.solr.search.grouping.distributed.shardresultserializer.TopGroupsResultTransformer
 
transformToNativeShardDoc(List<NamedList<Object>>, Sort, String, IndexSchema) - Method in class org.apache.solr.search.grouping.distributed.shardresultserializer.TopGroupsResultTransformer
 
TRANSIENT_CACHE_SIZE - Static variable in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
transientCores - Variable in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
"Lazily loaded" cores cache with limited size.
transientDescriptors - Variable in class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
Unlimited map of all the descriptors for all the registered transient cores, including the cores in the TransientSolrCoreCacheDefault.transientCores as well as all the others.
transientSolrCoreCache - Variable in class org.apache.solr.core.TransientSolrCores
Deprecated.
 
TransientSolrCoreCache - Class in org.apache.solr.core
Deprecated.
TransientSolrCoreCache() - Constructor for class org.apache.solr.core.TransientSolrCoreCache
Deprecated.
 
TransientSolrCoreCacheDefault - Class in org.apache.solr.core
Deprecated.
TransientSolrCoreCacheDefault(TransientSolrCores, int) - Constructor for class org.apache.solr.core.TransientSolrCoreCacheDefault
Deprecated.
 
TransientSolrCores - Class in org.apache.solr.core
Deprecated.
TransientSolrCores(CoreContainer, int) - Constructor for class org.apache.solr.core.TransientSolrCores
Deprecated.
 
transposeDocs(List<SolrInputDocument>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
transposeDocs(List<SolrInputDocument>) - Method in interface org.apache.solr.handler.designer.SchemaSuggester
 
TRANSPOSITIONS - Static variable in class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
If transpositions are allowed, Fuzzy suggestions will be computed based on a primitive edit operation.
treatUnboundedRangeAsExistence(SchemaField) - Method in class org.apache.solr.schema.FieldType
Returns whether an unbounded range query should be treated the same as an existence query for the given field type.
treatUnboundedRangeAsExistence(SchemaField) - Method in class org.apache.solr.schema.NumericFieldType
For doubles and floats, unbounded range queries (which do not match NaN values) are not equivalent to existence queries (which do match NaN values).
TrieDateField - Class in org.apache.solr.schema
Deprecated.
Trie fields are deprecated as of Solr 7.0
TrieDateField() - Constructor for class org.apache.solr.schema.TrieDateField
Deprecated.
 
TrieDoubleField - Class in org.apache.solr.schema
Deprecated.
Trie fields are deprecated as of Solr 7.0
TrieDoubleField() - Constructor for class org.apache.solr.schema.TrieDoubleField
Deprecated.
 
TrieField - Class in org.apache.solr.schema
Deprecated.
Trie fields are deprecated as of Solr 7.0
TrieField() - Constructor for class org.apache.solr.schema.TrieField
Deprecated.
 
TrieFloatField - Class in org.apache.solr.schema
Deprecated.
Trie fields are deprecated as of Solr 7.0
TrieFloatField() - Constructor for class org.apache.solr.schema.TrieFloatField
Deprecated.
 
TrieIntField - Class in org.apache.solr.schema
Deprecated.
Trie fields are deprecated as of Solr 7.0
TrieIntField() - Constructor for class org.apache.solr.schema.TrieIntField
Deprecated.
 
TrieLongField - Class in org.apache.solr.schema
Deprecated.
Trie fields are deprecated as of Solr 7.0
TrieLongField() - Constructor for class org.apache.solr.schema.TrieLongField
Deprecated.
 
triggerThreadDump(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.NodeThreadsAPI
 
trim() - Method in class org.apache.solr.handler.component.PivotFacetField
Destructive method that recursively prunes values from the data structure based on the counts for those values and the effective sort, mincount, limit, and offset being used for each field.
trim() - Method in class org.apache.solr.handler.component.PivotFacetFieldValueCollection
Destructive method that recursively prunes values from the data structure based on the counts for those values and the effective sort, mincount, limit, and offset being used for each field.
TRIM - Static variable in class org.apache.solr.handler.loader.CSVLoaderBase
 
TrimFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Trims leading and trailing whitespace from any CharSequence values found in fields matching the specified conditions and returns the resulting String.
TrimFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.TrimFieldUpdateProcessorFactory
 
trimLeadingAndTrailingSlashes(String) - Static method in class org.apache.solr.cloud.ZkController
Utility method for trimming and leading and/or trailing slashes from its input.
trimTrailingWhitespace() - Method in class org.apache.solr.internal.csv.CharBuffer
Removes trailing whitespace.
TRUE_TOKEN - Static variable in class org.apache.solr.schema.BoolField
 
trueProperties - Variable in class org.apache.solr.schema.FieldType
properties explicitly set to true
TruncateFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
Truncates any CharSequence values found in fields matching the specified conditions to a maximum character length.
TruncateFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.TruncateFieldUpdateProcessorFactory
 
TRUSTED_DIR - Static variable in class org.apache.solr.filestore.FileStoreAPI
 
try_incref() - Method in class org.apache.solr.update.TransactionLog
 
tryCancelAllElections() - Method in class org.apache.solr.cloud.ZkController
Attempts to cancel all leader elections.
tryLock(int) - Method in class org.apache.solr.update.TimedVersionBucket
 
tryReadBackupProperties() - Method in class org.apache.solr.core.backup.BackupManager
 
TSTLookupFactory - Class in org.apache.solr.spelling.suggest.tst
Factory for TSTLookup
TSTLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.tst.TSTLookupFactory
 
TT_EOF - Static variable in class org.apache.solr.internal.csv.CSVParser
Token (which can have content) when end of file is reached.
TT_EORECORD - Static variable in class org.apache.solr.internal.csv.CSVParser
Token with content when end of a line is reached.
TT_INVALID - Static variable in class org.apache.solr.internal.csv.CSVParser
Token has no valid content, i.e.
TT_TOKEN - Static variable in class org.apache.solr.internal.csv.CSVParser
Token with content, at beginning or in the middle of a line.
ttl - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
TTL - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
TTL_DEFAULT - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
txt() - Method in class org.apache.solr.util.DataConfigNode
 
txt() - Method in class org.apache.solr.util.DOMConfigNode
 
type - Variable in class org.apache.solr.core.PluginInfo
 
type - Variable in class org.apache.solr.packagemanager.SolrPackage.Plugin
 
type - Variable in class org.apache.solr.schema.NumericFieldType
 
type - Variable in class org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelector
The type for this selector, will never be null
type - Variable in class org.apache.solr.search.DocValuesIteratorCache.FieldDocValuesSupplier
 
type - Variable in class org.apache.solr.search.facet.LegacyFacet.Subfacet
 
TYPE - Static variable in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
TYPE - Static variable in class org.apache.solr.core.InitParams
 
TYPE - Static variable in interface org.apache.solr.request.SolrRequestHandler
 
TYPE - Static variable in class org.apache.solr.schema.FieldType
 
TYPE - Static variable in class org.apache.solr.schema.IndexSchema
 
TYPE - Static variable in class org.apache.solr.search.QueryParsing
 
TYPE_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
TYPE_NAME - Static variable in class org.apache.solr.schema.FieldType
 
TYPE_NOT_STORED - Static variable in class org.apache.solr.legacy.LegacyDoubleField
Deprecated.
Type for a LegacyDoubleField that is not stored: normalization factors, frequencies, and positions are omitted.
TYPE_NOT_STORED - Static variable in class org.apache.solr.legacy.LegacyFloatField
Deprecated.
Type for a LegacyFloatField that is not stored: normalization factors, frequencies, and positions are omitted.
TYPE_NOT_STORED - Static variable in class org.apache.solr.legacy.LegacyIntField
Deprecated.
Type for an LegacyIntField that is not stored: normalization factors, frequencies, and positions are omitted.
TYPE_NOT_STORED - Static variable in class org.apache.solr.legacy.LegacyLongField
Deprecated.
Type for a LegacyLongField that is not stored: normalization factors, frequencies, and positions are omitted.
TYPE_PARAM - Static variable in class org.apache.solr.handler.admin.MetricsHandler
 
TYPE_STORED - Static variable in class org.apache.solr.legacy.LegacyDoubleField
Deprecated.
Type for a stored LegacyDoubleField: normalization factors, frequencies, and positions are omitted.
TYPE_STORED - Static variable in class org.apache.solr.legacy.LegacyFloatField
Deprecated.
Type for a stored LegacyFloatField: normalization factors, frequencies, and positions are omitted.
TYPE_STORED - Static variable in class org.apache.solr.legacy.LegacyIntField
Deprecated.
Type for a stored LegacyIntField: normalization factors, frequencies, and positions are omitted.
TYPE_STORED - Static variable in class org.apache.solr.legacy.LegacyLongField
Deprecated.
Type for a stored LegacyLongField: normalization factors, frequencies, and positions are omitted.
typeClass - Variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
 
typeName - Variable in class org.apache.solr.schema.FieldType
The name of the type (not the name of the field)
typeName - Variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
 
TYPES - Static variable in class org.apache.solr.schema.IndexSchema
 
TYPES_BY_SIZE - Static variable in class org.apache.solr.handler.admin.IndexSizeEstimator
 
typeSupported(String) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
Uses the mime-type map to reverse lookup whether the file ending for our type is supported by the fileTypes option
tz - Variable in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 

U

uhandler - Variable in class org.apache.solr.update.UpdateLog
 
UIF - org.apache.solr.search.facet.FacetField.FacetMethod
 
uifOutOfMemoryError - Static variable in class org.apache.solr.util.TestInjection
 
ulog - Variable in class org.apache.solr.update.UpdateHandler
 
UNAUTHORIZED - org.apache.solr.security.AuditEvent.EventType
 
unblockUpdates() - Method in class org.apache.solr.update.VersionInfo
 
UNCHANGED - org.apache.solr.api.ContainerPluginsRegistry.Diff
 
uncorrectedStdDev(double, double, long) - Static method in class org.apache.solr.search.facet.AggUtil
Computes and returns uncorrected standard deviation for given values
uncorrectedVariance(double, double, long) - Static method in class org.apache.solr.search.facet.AggUtil
Computes and returns uncorrected variance for given values
UNDEFINED_AVAILABILITY_ZONE - Static variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
This is the "AZ" name for nodes that do not define an AZ.
undeploy(String, String[], boolean) - Method in class org.apache.solr.packagemanager.PackageManager
Undeploys a package from given collections.
ungrouped - org.apache.solr.search.Grouping.TotalCount
Computations should be based on plain documents, so not taking grouping into account.
UNICODE_AWARE - Static variable in class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
If true, maxEdits, minFuzzyLength, transpositions and nonFuzzyPrefix will be measured in Unicode code points (actual letters) instead of bytes.
unicodeEscapeLexer(int) - Method in class org.apache.solr.internal.csv.CSVParser
Decodes Unicode escapes.
UNIFIED - org.apache.solr.handler.component.HighlightComponent.HighlightMethod
 
unifiedResourcePath(SolrResourceLoader) - Static method in class org.apache.solr.cloud.CloudUtil
Returns a displayable unified path to the given resource.
UnifiedSolrHighlighter - Class in org.apache.solr.highlight
Highlighter impl that uses UnifiedHighlighter
UnifiedSolrHighlighter() - Constructor for class org.apache.solr.highlight.UnifiedSolrHighlighter
 
UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter - Class in org.apache.solr.highlight
UNINITIALIZED - Static variable in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
uninstall(String, String) - Method in class org.apache.solr.packagemanager.PackageManager
 
uninstallCommand - Variable in class org.apache.solr.packagemanager.SolrPackage.Plugin
 
uninvert(LeafReader, Bits, BytesRef) - Method in class org.apache.solr.uninverting.DocTermOrds
Call this only once (if you subclass!)
UnInvertedField - Class in org.apache.solr.search.facet
Final form of the un-inverted field: Each document points to a list of term numbers that are contained in that document.
UnInvertedField(String, SolrIndexSearcher) - Constructor for class org.apache.solr.search.facet.UnInvertedField
 
UnInvertedField.Callback - Interface in org.apache.solr.search.facet
 
UnInvertedField.DocToTerm - Class in org.apache.solr.search.facet
 
UnInvertedFieldAcc - Class in org.apache.solr.search.facet
Base accumulator for UnInvertedField
UnInvertedFieldAcc(FacetContext, SchemaField, int) - Constructor for class org.apache.solr.search.facet.UnInvertedFieldAcc
 
UNINVERTIBLE - Static variable in class org.apache.solr.schema.FieldProperties
 
UninvertingReader - Class in org.apache.solr.uninverting
A FilterReader that exposes indexed values as if they also had docvalues.
UninvertingReader.FieldCacheStats - Class in org.apache.solr.uninverting
Return information about the backing cache
UninvertingReader.Type - Enum in org.apache.solr.uninverting
Specifies the type of uninversion to apply for the field.
union(DocSet) - Method in class org.apache.solr.search.BitDocSet
 
union(DocSet) - Method in class org.apache.solr.search.DocSet
Returns the union of this set with another set.
union(DocSet) - Method in class org.apache.solr.search.SortedIntDocSet
 
union(HLL) - Method in class org.apache.solr.util.hll.HLL
Computes the union of HLLs and stores the result in this instance.
unionSize(DocSet) - Method in class org.apache.solr.search.BitDocSet
 
unionSize(DocSet) - Method in class org.apache.solr.search.DocSet
Returns the number of documents of the union of this set with another set.
UniqFieldsUpdateProcessorFactory - Class in org.apache.solr.update.processor
Removes duplicate values found in fields matching the specified conditions.
UniqFieldsUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.UniqFieldsUpdateProcessorFactory
 
UNIQUE - Static variable in class org.apache.solr.search.facet.UniqueAgg
 
UNIQUE_KEY - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
UNIQUE_KEY - Static variable in class org.apache.solr.schema.IndexSchema
 
UNIQUE_KEY_FIELD_PARAM - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
UniqueAgg - Class in org.apache.solr.search.facet
 
UniqueAgg(String) - Constructor for class org.apache.solr.search.facet.UniqueAgg
 
UniqueBlockAgg - Class in org.apache.solr.search.facet
 
UniqueBlockAgg(String) - Constructor for class org.apache.solr.search.facet.UniqueBlockAgg
 
UniqueBlockAgg.UniqueBlockSlotAcc - Class in org.apache.solr.search.facet
 
UniqueBlockFieldAgg - Class in org.apache.solr.search.facet
 
UniqueBlockFieldAgg(String) - Constructor for class org.apache.solr.search.facet.UniqueBlockFieldAgg
 
UniqueBlockQueryAgg - Class in org.apache.solr.search.facet
 
UniqueBlockQueryAgg(Query) - Constructor for class org.apache.solr.search.facet.UniqueBlockQueryAgg
 
UniqueBlockSlotAcc(FacetContext, SchemaField, int) - Constructor for class org.apache.solr.search.facet.UniqueBlockAgg.UniqueBlockSlotAcc
 
uniqueFileName - Variable in class org.apache.solr.core.backup.ShardBackupMetadata.BackedFile
 
uniqueId - Variable in class org.apache.solr.core.SolrCore
A unique id to differentiate multiple instances of the same core If we reload a core, the name remains same , but the id will be new
uniqueKeyField - Variable in class org.apache.solr.handler.component.QueryElevationComponent
 
uniqueKeyField - Variable in class org.apache.solr.schema.IndexSchema
 
uniqueKeyFieldName - Variable in class org.apache.solr.schema.IndexSchema
 
uniqueKeyFieldType - Variable in class org.apache.solr.schema.IndexSchema
 
UNKNOWN - org.apache.solr.security.AuditEvent.RequestType
 
UNKNOWN - org.apache.solr.security.AuthorizationContext.RequestType
 
UNKNOWN_FIELD_TYPE - org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
The component parameter QueryElevationComponent.FIELD_TYPE defines an unknown field type.
UNKNOWN_VALUE - Static variable in class org.apache.solr.cli.PostLogsTool
 
UNKNOWN_VALUE - Static variable in class org.apache.solr.util.SolrPluginUtils
 
unknownProperties() - Method in class org.apache.solr.handler.admin.ZookeeperReadAPI.ListZkChildrenResponse
 
UNLIMITED - Static variable in class org.apache.solr.schema.CopyField
 
UNLIMITED_MAX_COUNT - Static variable in class org.apache.solr.handler.component.TermsComponent
 
unload(String) - Method in class org.apache.solr.core.CoreContainer
Unload a core from this container, leaving all files on disk
unload(String, boolean, boolean, boolean) - Method in class org.apache.solr.core.CoreContainer
Unload a core from this container, optionally removing the core's data and configuration
UNLOAD_OP - org.apache.solr.handler.admin.CoreAdminOperation
 
unloadCore(String, UnloadCoreRequestBody) - Method in class org.apache.solr.handler.admin.api.UnloadCore
 
UnloadCore - Class in org.apache.solr.handler.admin.api
V2 API implementation for unloading a Solr core.
UnloadCore(CoreContainer, CoreAdminHandler.CoreAdminAsyncTracker, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.api.UnloadCore
 
unloadOnClose(CoreDescriptor, boolean, boolean, boolean) - Method in class org.apache.solr.core.SolrCore
 
unlock() - Method in interface org.apache.solr.cloud.OverseerMessageHandler.Lock
 
unlock() - Method in class org.apache.solr.update.TimedVersionBucket
 
unlock() - Method in class org.apache.solr.update.VersionBucket
Nothing to do for the intrinsic object monitor.
unlockForSplit(SolrCloudManager, String, String) - Static method in class org.apache.solr.cloud.api.collections.SplitShardCmd
 
unlockForUpdate() - Method in class org.apache.solr.update.VersionInfo
 
unmarshalBase64SortValue(Object) - Static method in class org.apache.solr.schema.FieldType
Unmarshals a binary field value.
unmarshalSortValue(Object) - Method in class org.apache.solr.schema.BoolField
 
unmarshalSortValue(Object) - Method in class org.apache.solr.schema.CollationField
 
unmarshalSortValue(Object) - Method in class org.apache.solr.schema.FieldType
Convert a value marshaled via FieldType.marshalSortValue(java.lang.Object) back into a value usable by the FieldComparator for this FieldType's SortField
unmarshalSortValue(Object) - Method in class org.apache.solr.schema.StrField
 
unmarshalSortValue(Object) - Method in class org.apache.solr.schema.TextField
 
unmarshalSortValues(SortSpec, NamedList<List<Object>>, IndexSchema) - Method in class org.apache.solr.handler.component.QueryComponent
 
unmarshalStringSortValue(Object) - Static method in class org.apache.solr.schema.FieldType
Unmarshals a string-based field value.
unregister() - Method in class org.apache.solr.metrics.SolrMetricsContext
Unregister all Gauge metrics that use this context's tag.
unregister(String, CoreDescriptor) - Method in class org.apache.solr.cloud.ZkController
 
unregister(String, CoreDescriptor, boolean) - Method in class org.apache.solr.cloud.ZkController
 
unregister(SolrRequest.METHOD, String) - Method in class org.apache.solr.api.ApiBag
 
unregisterGauges(String, String) - Method in class org.apache.solr.metrics.SolrMetricManager
 
unregisterListener(ContainerPluginsRegistry.PluginRegistryListener) - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
unregisterListener(ClusterEventListener) - Method in interface org.apache.solr.cluster.events.ClusterEventProducer
Unregister an event listener for all event types.
unregisterListener(ClusterEventListener, ClusterEvent.EventType...) - Method in interface org.apache.solr.cluster.events.ClusterEventProducer
Unregister an event listener for specified event types.
unregisterListener(ClusterEventListener, ClusterEvent.EventType...) - Method in class org.apache.solr.cluster.events.ClusterEventProducerBase
 
unregisterListener(ClusterEventListener, ClusterEvent.EventType...) - Method in class org.apache.solr.cluster.events.impl.DelegatingClusterEventProducer
 
UNSET_PROPERTY - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
UNSET_USER_PROPERTY - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
unsetProperty(String) - Method in class org.apache.solr.core.ConfigOverlay
 
unsetUserProperty(String) - Method in class org.apache.solr.core.ConfigOverlay
 
UNSPECIFIED - org.apache.solr.cluster.placement.NodeMetric.Registry
In case when the registry name is not relevant (eg.
unwrapQuery(Query, BooleanClause.Occur) - Method in class org.apache.solr.search.join.FiltersQParser
 
unwrapStats(NamedList<NamedList<NamedList<?>>>) - Static method in class org.apache.solr.handler.component.StatsComponent
Helper to pull the "stats_fields" out of the extra "stats" wrapper
update(int) - Method in class org.apache.solr.metrics.DelegateRegistryHistogram
 
update(long) - Method in class org.apache.solr.metrics.DelegateRegistryHistogram
 
update(long, TimeUnit) - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
update(Object) - Method in class org.apache.solr.metrics.AggregateMetric.Update
 
update(Duration) - Method in class org.apache.solr.metrics.DelegateRegistryTimer
 
update(Map) - Method in class org.apache.solr.core.RequestParams.ParamSet
 
update(PayloadObj<PluginMeta>) - Method in class org.apache.solr.handler.admin.ContainerPluginsApi.Edit
 
update(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.UpdateAPI
 
Update() - Constructor for class org.apache.solr.update.UpdateLog.Update
 
Update(Object) - Constructor for class org.apache.solr.metrics.AggregateMetric.Update
 
UPDATE - org.apache.solr.core.SolrInfoBean.Category
 
UPDATE - org.apache.solr.security.AuditEvent.RequestType
 
UPDATE - Static variable in class org.apache.solr.handler.SolrConfigHandler
 
UPDATE_ERROR - Static variable in interface org.apache.solr.handler.designer.SchemaDesignerConstants
 
UPDATE_INPLACE - Static variable in class org.apache.solr.update.UpdateLog
 
UPDATE_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
UPDATE_RATE_1MIN - Static variable in class org.apache.solr.cluster.placement.impl.ReplicaMetricImpl
1-min update rate of the /update handler.
UPDATE_TIMEOUT_SECS - Static variable in class org.apache.solr.rest.BaseSolrResource
 
updateAliasProperties(String, UpdateAliasPropertiesRequestBody) - Method in class org.apache.solr.handler.admin.api.AliasProperty
 
UpdateAPI - Class in org.apache.solr.handler.admin.api
All v2 APIs that share a prefix of /update
UpdateAPI(UpdateRequestHandler) - Constructor for class org.apache.solr.handler.admin.api.UpdateAPI
 
updateAuthenticationConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.ModifyNoAuthPluginSecurityConfigAPI
 
updateAuthorizationConfig(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.ModifyNoAuthzPluginSecurityConfigAPI
 
updateClock(long) - Method in class org.apache.solr.update.VersionInfo
 
updateClusterState(Function<ClusterState, ClusterState>) - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
if any collection is updated not through this class (directly written to ZK, then it needs to be updated locally)
updateCollectionLevelSnapshot(SolrZkClient, String, CollectionSnapshotMetaData) - Static method in class org.apache.solr.core.snapshots.SolrSnapshotManager
This method updates an entry for the named snapshot for the specified collection in Zookeeper.
UpdateCommand - Class in org.apache.solr.update
An index update command encapsulated in an object (Command pattern)
UpdateCommand(SolrQueryRequest) - Constructor for class org.apache.solr.update.UpdateCommand
 
updateCommit(CommitUpdateCommand, SolrParams) - Static method in class org.apache.solr.handler.RequestHandlerUtils
Modify UpdateCommand based on request parameters
updateConfigSetFile(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.configsets.UploadConfigSetFileAPI
 
updateContext(SortedDocValues) - Method in class org.apache.solr.request.IntervalFacets.FacetInterval
Update the ordinals based on the current reader.
updateContext(SortedSetDocValues) - Method in class org.apache.solr.request.IntervalFacets.FacetInterval
Update the ordinals based on the current reader.
updateCount - Variable in class org.apache.solr.metrics.AggregateMetric.Update
 
updateCsv(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.UpdateAPI
 
UPDATED - org.apache.solr.api.ContainerPluginsRegistry.Diff
 
UPDATED_SINCE_INIT_JSON_FIELD - Static variable in class org.apache.solr.rest.ManagedResource
 
updateFileContents(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
UpdateHandler - Class in org.apache.solr.update
UpdateHandler handles requests to change the index (adds, deletes, commits, optimizes, etc).
UpdateHandler(SolrCore) - Constructor for class org.apache.solr.update.UpdateHandler
 
UpdateHandler(SolrCore, UpdateLog) - Constructor for class org.apache.solr.update.UpdateHandler
 
updateHandlerInfo - Variable in class org.apache.solr.core.SolrConfig
 
UpdateHandlerInfo(String, int, int, long, boolean, int, int, boolean) - Constructor for class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
UpdateHandlerInfo(ConfigNode) - Constructor for class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
 
updateInitArgs(NamedList<?>) - Method in class org.apache.solr.rest.ManagedResource
Called from ManagedResource.doPut(BaseSolrResource,Object) to update this resource's init args using the given updatedArgs
updateInitArgs(NamedList<?>) - Method in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
 
updateJavabin(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.UpdateAPI
 
updateJson(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.UpdateAPI
 
UpdateLog - Class in org.apache.solr.update
This holds references to the transaction logs.
UpdateLog() - Constructor for class org.apache.solr.update.UpdateLog
 
UpdateLog.DBQ - Class in org.apache.solr.update
Holds the query and the version for a DeleteByQuery command
UpdateLog.DeleteUpdate - Class in org.apache.solr.update
 
UpdateLog.LogPtr - Class in org.apache.solr.update
 
UpdateLog.RecentUpdates - Class in org.apache.solr.update
 
UpdateLog.RecoveryInfo - Class in org.apache.solr.update
 
UpdateLog.State - Enum in org.apache.solr.update
 
UpdateLog.SyncLevel - Enum in org.apache.solr.update
 
UpdateLog.Update - Class in org.apache.solr.update
 
updateLogReplayRandomPause - Static variable in class org.apache.solr.util.TestInjection
 
updateParsedCollectionAliases(ZkStateReader, boolean) - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
updateParsedCollectionAliases(ZkStateReader, boolean) - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
updateParsedCollectionAliases(ZkStateReader, boolean) - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
Ensure our parsed version of the alias collection list is up to date.
updateParsedCollectionAliases(ZkStateReader, boolean) - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
updatePermission(PayloadObj<UpdateRuleBasedAuthPermissionPayload>) - Method in class org.apache.solr.handler.admin.api.ModifyRuleBasedAuthConfigAPI
 
updateRandomPause - Static variable in class org.apache.solr.util.TestInjection
 
updateReplica(DocCollection, Slice, String, Replica) - Static method in class org.apache.solr.cloud.overseer.SliceMutator
 
updateReplicas(DocCollection, PerReplicaStates) - Static method in class org.apache.solr.cloud.overseer.CollectionMutator
 
UpdateRequestHandler - Class in org.apache.solr.handler
UpdateHandler that uses content-type to pick the right Loader
UpdateRequestHandler() - Constructor for class org.apache.solr.handler.UpdateRequestHandler
 
UpdateRequestProcessor - Class in org.apache.solr.update.processor
This is a good place for subclassed update handlers to process the document before it is indexed.
UpdateRequestProcessor(UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.UpdateRequestProcessor
 
UpdateRequestProcessorChain - Class in org.apache.solr.update.processor
Manages a chain of UpdateRequestProcessorFactories.
UpdateRequestProcessorChain(List<UpdateRequestProcessorFactory>, SolrCore) - Constructor for class org.apache.solr.update.processor.UpdateRequestProcessorChain
Creates a chain backed directly by the specified list.
UpdateRequestProcessorChain(SolrCore) - Constructor for class org.apache.solr.update.processor.UpdateRequestProcessorChain
 
UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder - Class in org.apache.solr.update.processor
 
UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder.LazyUpdateRequestProcessorFactory - Class in org.apache.solr.update.processor
 
UpdateRequestProcessorChain.ProcessorInfo - Class in org.apache.solr.update.processor
 
UpdateRequestProcessorFactory - Class in org.apache.solr.update.processor
A factory to generate an UpdateRequestProcessor for each request.
UpdateRequestProcessorFactory() - Constructor for class org.apache.solr.update.processor.UpdateRequestProcessorFactory
 
UpdateRequestProcessorFactory.RunAlways - Interface in org.apache.solr.update.processor
A marker interface for UpdateRequestProcessorFactory implementations indicating that the factory should be used even if the update.distrib parameter would otherwise cause it to not be run.
updates - Variable in class org.apache.solr.cloud.overseer.ZkStateWriter
 
updateSchemaObject(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
updateSchemaToLatest() - Method in class org.apache.solr.request.DelegatingSolrQueryRequest
 
updateSchemaToLatest() - Method in interface org.apache.solr.request.SolrQueryRequest
Replaces the current schema snapshot with the latest from the core.
updateSchemaToLatest() - Method in class org.apache.solr.request.SolrQueryRequestBase
 
UpdateShardHandler - Class in org.apache.solr.update
 
UpdateShardHandler(UpdateShardHandlerConfig) - Constructor for class org.apache.solr.update.UpdateShardHandler
 
UpdateShardHandlerConfig - Class in org.apache.solr.update
 
UpdateShardHandlerConfig(int, int, int, int, String, int) - Constructor for class org.apache.solr.update.UpdateShardHandlerConfig
 
updateShardState(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.SliceMutator
 
UPDATESHARDSTATE - org.apache.solr.cloud.overseer.OverseerAction
 
updateSlice(String, DocCollection, Slice) - Static method in class org.apache.solr.cloud.overseer.CollectionMutator
 
updateState(ClusterState, ZkNodeProps) - Method in class org.apache.solr.cloud.overseer.ReplicaMutator
 
updateStats(ResponseBuilder, ShardRequest) - Method in class org.apache.solr.handler.component.QueryComponent
 
updateTerm - Variable in class org.apache.solr.update.AddUpdateCommand
The term to use to delete an existing document (for dedupe).
updateTop() - Method in class org.apache.solr.util.LongPriorityQueue
Should be called when the Object at top changes values.
updateXml(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.UpdateAPI
 
UPGRADED_SCHEMA_EXTENSION - Static variable in class org.apache.solr.schema.ManagedIndexSchemaFactory
 
UpgradeIndexMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for UpgradeIndexMergePolicy objects.
UpgradeIndexMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.UpgradeIndexMergePolicyFactory
 
upload(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.filestore.FileStoreAPI.FSWrite
 
UPLOAD_FILENAME_EXCLUDE_PATTERN - Static variable in class org.apache.solr.core.ConfigSetService
 
UPLOAD_FILENAME_EXCLUDE_REGEX - Static variable in class org.apache.solr.core.ConfigSetService
 
uploadBlob(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.admin.api.UploadBlobAPI
 
UploadBlobAPI - Class in org.apache.solr.handler.admin.api
V2 API for uploading blobs into Solr's .system blobstore
UploadBlobAPI(BlobHandler) - Constructor for class org.apache.solr.handler.admin.api.UploadBlobAPI
 
uploadCollectionProperties(String) - Method in class org.apache.solr.core.backup.BackupManager
 
uploadConfig(String, Path) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
uploadConfig(String, Path) - Method in class org.apache.solr.core.ConfigSetService
Upload files from a given path to config
uploadConfig(String, Path) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
uploadConfigDir(String, String, ConfigSetService) - Method in class org.apache.solr.core.backup.BackupManager
This method uploads the Solr configuration files to the desired location in Zookeeper.
uploadConfigSet(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.handler.configsets.UploadConfigSetAPI
 
UploadConfigSetAPI - Class in org.apache.solr.handler.configsets
V2 API for uploading a new configset (or overwriting an existing one).
UploadConfigSetAPI(CoreContainer) - Constructor for class org.apache.solr.handler.configsets.UploadConfigSetAPI
 
UploadConfigSetFileAPI - Class in org.apache.solr.handler.configsets
V2 API for adding or updating a single file within a configset.
UploadConfigSetFileAPI(CoreContainer) - Constructor for class org.apache.solr.handler.configsets.UploadConfigSetFileAPI
 
uploadedIndexFileCount - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
uploadedIndexFileMB - Variable in class org.apache.solr.handler.IncrementalShardBackup.IncrementalShardSnapshotResponse
 
uploadFileToConfig(String, String, byte[], boolean) - Method in class org.apache.solr.cloud.ZkConfigSetService
 
uploadFileToConfig(String, String, byte[], boolean) - Method in class org.apache.solr.core.ConfigSetService
Upload a file to config If file does not exist, it will be uploaded If overwriteOnExists is set to true then file will be overwritten
uploadFileToConfig(String, String, byte[], boolean) - Method in class org.apache.solr.core.FileSystemConfigSetService
 
uploadKey(byte[], String, Path) - Static method in class org.apache.solr.packagemanager.PackageUtils
 
upper - Variable in class org.apache.solr.handler.component.RangeFacetRequest.FacetRange
 
upper - Variable in class org.apache.solr.search.join.HashRangeQuery
 
upper - Variable in class org.apache.solr.search.TopLevelJoinQuery.BitsetBounds
 
UPPER_BOUND - Static variable in class org.apache.solr.search.join.HashRangeQParser
 
uptime(long) - Static method in class org.apache.solr.cli.SolrCLI
 
uReq - Variable in class org.apache.solr.update.SolrCmdDistributor.Req
 
url - Variable in class org.apache.solr.packagemanager.SolrPackage.Artifact
 
URL_ALLOW_LIST - Static variable in class org.apache.solr.security.AllowListUrlChecker
SolrXmlConfig property to configure the allowed URLs.
URLClassifyProcessor - Class in org.apache.solr.update.processor
Update processor which examines a URL and outputs to various other fields characteristics of that URL, including length, number of path levels, whether it is a top level URL (levels==0), whether it looks like a landing/index page, a canonical representation of the URL (e.g.
URLClassifyProcessor(SolrParams, SolrQueryRequest, SolrQueryResponse, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.URLClassifyProcessor
 
URLClassifyProcessorFactory - Class in org.apache.solr.update.processor
Creates URLClassifyProcessor
URLClassifyProcessorFactory() - Constructor for class org.apache.solr.update.processor.URLClassifyProcessorFactory
 
urlDecode(String) - Static method in class org.apache.solr.rest.BaseSolrResource
Decode URL-encoded strings as UTF-8, and avoid converting "+" to space
URLS - org.apache.solr.response.transform.ShardAugmenterFactory.Style
 
urlScheme - Variable in class org.apache.solr.cli.RunExampleTool
 
USE_CONTENT_TYPE - Static variable in class org.apache.solr.handler.admin.ShowFileRequestHandler
 
USE_CROSSCOLLECTION - Static variable in class org.apache.solr.search.join.ScoreJoinQParserPlugin
 
USE_DOCVALUES_AS_STORED - Static variable in class org.apache.solr.schema.FieldProperties
 
useArrayBased(int) - Method in interface org.apache.solr.util.DynamicMap
 
useCachedGlobalStats - Variable in class org.apache.solr.search.stats.StatsCache.StatsCacheMetrics
 
useColdSearcher - Variable in class org.apache.solr.core.SolrConfig
 
useCompoundFile - Variable in class org.apache.solr.update.SolrIndexConfig
 
useConfiguredElevatedOrder - Variable in class org.apache.solr.handler.component.QueryElevationComponent
 
useDocValuesAsStored() - Method in class org.apache.solr.schema.FieldType
Returns true if the fields' docValues should be used for obtaining stored value
useDocValuesAsStored() - Method in class org.apache.solr.schema.SchemaField
 
useFastVectorHighlighter(SolrParams, SchemaField) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
Determines if we should use the FastVectorHighlighter for this field.
useFilterForSortedQuery - Variable in class org.apache.solr.core.SolrConfig
 
USEPARAM - Static variable in class org.apache.solr.core.RequestParams
 
userCacheConfigs - Variable in class org.apache.solr.core.SolrConfig
 
userFields - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
The field names specified by 'uf' that users are allowed to include literally in their query string.
userForDir(Path) - Static method in class org.apache.solr.cli.AssertTool
 
userInput - Variable in class org.apache.solr.cli.RunExampleTool
 
userPrincipalName - Variable in class org.apache.solr.request.LocalSolrQueryRequest
 
useServerToken() - Method in class org.apache.solr.request.SolrRequestInfo
Used when making remote requests to other Solr nodes from the thread associated with this request, true means the server token header should be used instead of the Principal associated with the request.
usingDefaultDataDir() - Method in class org.apache.solr.core.CoreDescriptor
 
UTC - Static variable in class org.apache.solr.util.DateMathParser
 
UTF_8 - Static variable in class org.apache.solr.rest.ManagedResourceStorage
 
UUIDField - Class in org.apache.solr.schema
This FieldType accepts UUID string values, as well as the special value of "NEW" which triggers generation of a new random UUID.
UUIDField() - Constructor for class org.apache.solr.schema.UUIDField
 
UUIDUpdateProcessorFactory - Class in org.apache.solr.update.processor
An update processor that adds a newly generated UUID value to any document being added that does not already have a value in the specified field.
UUIDUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.UUIDUpdateProcessorFactory
 

V

V - Static variable in class org.apache.solr.search.QueryParsing
 
V2_APPLY_CORE_UPDATES_CMD - Static variable in class org.apache.solr.handler.admin.api.RequestApplyCoreUpdatesAPI
 
V2_CREATE_CORE_CMD - Static variable in class org.apache.solr.handler.admin.api.CreateCoreAPI
 
V2_PREP_RECOVERY_CMD - Static variable in class org.apache.solr.handler.admin.api.PrepareCoreRecoveryAPI
 
V2_REQUEST_BUFFER_UPDATES_CMD - Static variable in class org.apache.solr.handler.admin.api.RequestBufferUpdatesAPI
 
V2_REQUEST_RECOVERY_CMD - Static variable in class org.apache.solr.handler.admin.api.RequestCoreRecoveryAPI
 
V2_REQUEST_SYNC_SHARD_CMD - Static variable in class org.apache.solr.handler.admin.api.RequestSyncShardAPI
 
V2ApiUtils - Class in org.apache.solr.handler.api
Utilities helpful for common V2 API declaration tasks.
V2HttpCall - Class in org.apache.solr.api
 
V2HttpCall(SolrDispatchFilter, CoreContainer, HttpServletRequest, HttpServletResponse, boolean) - Constructor for class org.apache.solr.api.V2HttpCall
 
V2HttpCall.CompositeApi - Class in org.apache.solr.api
 
v2lookup(String, String, Map<String, String>) - Method in class org.apache.solr.core.PluginBag
 
V2NodeLoggingAPI - Class in org.apache.solr.handler.admin.api
V2 API for getting log levels on an individual node.
V2NodeLoggingAPI(LogWatcher<?>) - Constructor for class org.apache.solr.handler.admin.api.V2NodeLoggingAPI
 
V2UpdateRequestHandler - Class in org.apache.solr.handler
An extension of UpdateRequestHandler used solely to register the v2 /update APIs
V2UpdateRequestHandler() - Constructor for class org.apache.solr.handler.V2UpdateRequestHandler
 
val - Variable in class org.apache.solr.request.SimpleFacets.CountPair
 
val - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
 
val - Variable in class org.apache.solr.search.FloatPayloadValueSource
 
val - Variable in class org.apache.solr.search.StrParser
 
VAL - org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
 
VAL_EXPLICIT - Static variable in class org.apache.solr.search.QueryParsing
 
valFollowedParams - Variable in class org.apache.solr.search.QParser
 
validate() - Method in class org.apache.solr.cloud.api.collections.InstallShardDataCmd.RemoteMessage
 
validate() - Method in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
 
validate() - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.CategoryRoutedAliasProperties
 
validate() - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.CreateAliasRequestBody
 
validate() - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.RoutedAliasProperties
 
validate() - Method in class org.apache.solr.handler.admin.api.CreateAliasAPI.TimeRoutedAliasProperties
 
validate() - Method in class org.apache.solr.metrics.reporters.SolrGraphiteReporter
 
validate() - Method in class org.apache.solr.metrics.reporters.SolrJmxReporter
Validates that the reporter has been correctly configured.
validate() - Method in class org.apache.solr.metrics.reporters.SolrSlf4jReporter
 
validate() - Method in class org.apache.solr.metrics.SolrMetricReporter
Validates that the reporter has been correctly configured.
validate(List<String>, FileStore.FileEntry, boolean) - Method in class org.apache.solr.filestore.FileStoreAPI
Validate a file for signature
validateCollections(String[]) - Static method in class org.apache.solr.packagemanager.PackageUtils
 
validateCommitParams(SolrParams) - Static method in class org.apache.solr.handler.RequestHandlerUtils
 
validateCreateSnapshot() - Method in class org.apache.solr.handler.SnapShooter
 
validateDeleteSnapshot() - Method in class org.apache.solr.handler.SnapShooter
 
validateFields(String) - Method in class org.apache.solr.search.join.GraphQueryParser
 
validateFiles(List<String>, boolean, Consumer<String>) - Method in class org.apache.solr.filestore.FileStoreAPI
 
validateFormatter(DateTimeFormatter) - Static method in class org.apache.solr.update.processor.ParseDateFieldUpdateProcessorFactory
 
validateName(String) - Static method in class org.apache.solr.handler.SolrConfigHandler
 
validateName(String, boolean) - Static method in class org.apache.solr.filestore.FileStoreAPI
 
validateNumericTypeChange(SchemaField, FieldType, List<SolrInputDocument>, NumberType) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
validateQueryFields(ExtendedDismaxQParser.ExtendedSolrQueryParser) - Method in class org.apache.solr.search.ExtendedDismaxQParser
Validate query field names.
validateRequestBody(CreateCollectionRequestBody) - Static method in class org.apache.solr.handler.admin.api.CreateCollection
 
validateRequestBody(RestoreCoreRequestBody) - Static method in class org.apache.solr.handler.admin.api.RestoreCore
 
validateRouteValue(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.CategoryRoutedAlias
 
validateRouteValue(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.DimensionalRoutedAlias
 
validateRouteValue(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.RoutedAlias
Check that the value we will be routing on is legal for this type of routed alias.
validateRouteValue(AddUpdateCommand) - Method in class org.apache.solr.cloud.api.collections.TimeRoutedAlias
 
validateTypeChange(SchemaField, FieldType, List<SolrInputDocument>) - Method in class org.apache.solr.handler.designer.DefaultSchemaSuggester
 
validateTypeChange(SchemaField, FieldType, List<SolrInputDocument>) - Method in interface org.apache.solr.handler.designer.SchemaSuggester
 
validateZkRawResponse(List<String>, String, String) - Method in class org.apache.solr.handler.admin.ZookeeperStatusHandler
Takes the raw response lines returned by ZookeeperStatusHandler.getZkRawResponse(String, String) and runs some validations
validateZooKeeperAwareCoreContainer(CoreContainer) - Static method in class org.apache.solr.handler.admin.api.AdminAPIBase
 
vals - Variable in class org.apache.solr.handler.export.IntValue
 
vals - Variable in class org.apache.solr.handler.export.LongValue
 
value - Variable in class org.apache.solr.metrics.AggregateMetric.Update
 
value - Variable in class org.apache.solr.response.transform.ValueAugmenterFactory
 
value - Variable in class org.apache.solr.search.facet.LegacyFacet.Subfacet
 
value() - Method in annotation type org.apache.solr.jersey.PermissionName
 
VALUE - org.apache.solr.util.PivotListEntry
 
VALUE - Static variable in class org.apache.solr.util.stats.MetricUtils
 
ValueAugmenterFactory - Class in org.apache.solr.response.transform
 
ValueAugmenterFactory() - Constructor for class org.apache.solr.response.transform.ValueAugmenterFactory
 
valueCollection - Variable in class org.apache.solr.handler.component.PivotFacetField
 
ValueIterator(SchemaField, List<LeafReaderContext>) - Constructor for class org.apache.solr.search.PointMerger.ValueIterator
 
ValueIterator(SchemaField, List<LeafReaderContext>, int, int) - Constructor for class org.apache.solr.search.PointMerger.ValueIterator
 
valueMutator(FieldMutatingUpdateProcessor.FieldNameSelector, UpdateRequestProcessor, Function<Object, Object>) - Static method in class org.apache.solr.update.processor.FieldValueMutatingUpdateProcessor
 
valueOf(String) - Static method in enum org.apache.solr.api.ContainerPluginsRegistry.Diff
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.client.solrj.embedded.EmbeddedSolrServer.RequestWriterSupplier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.Cmd
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cloud.ClusterSingleton.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cloud.overseer.OverseerAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cluster.events.ClusterEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cluster.placement.NodeMetric.Registry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cluster.Replica.ReplicaState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cluster.Replica.ReplicaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.cluster.Shard.ShardState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.backup.repository.BackupRepository.PathType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.DirectoryFactory.DirContext
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.NodeRoles.Role
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.snapshots.CollectionSnapshotMetaData.SnapshotStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.SolrConfig.HttpCachingConfig.LastModFrom
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.SolrConfig.PluginOpts
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.SolrInfoBean.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.core.SolrInfoBean.Group
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.filestore.FileStore.FileType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.admin.ClusterStatus.Health
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.admin.CoreAdminOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.component.HighlightComponent.HighlightMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.component.RealTimeGetComponent.Resolution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.component.StatsField.Stat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.handler.PingRequestHandler.ACTIONS
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.legacy.LegacyNumericType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.metrics.SolrMetricManager.ResolutionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.parser.QueryParser.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.parser.SolrQueryParserBase.SynonymQueryStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.response.transform.ExplainAugmenterFactory.Style
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.response.transform.ShardAugmenterFactory.Style
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.schema.FieldType.MultiValueSelector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.schema.IndexSchema.SchemaProps.Handler
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.schema.NumberType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.schema.SchemaManager.OpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelectorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.facet.FacetField.FacetMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.facet.FacetRequest.RefineMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.facet.FacetRequest.SortDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.Grouping.Format
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.Grouping.TotalCount
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.ReRankOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.SolrCache.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.search.SolrReturnFields.FIELD_SOURCES
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.security.AuditEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.security.AuditEvent.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.security.AuditEvent.RequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.security.AuthorizationContext.RequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.security.PermissionNameProvider.Name
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.servlet.cache.Method
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.servlet.SolrDispatchFilter.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.spelling.WordBreakSolrSpellChecker.BreakSuggestionTieBreaker
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.uninverting.UninvertingReader.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.update.processor.ClassificationUpdateProcessorFactory.Algorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.update.processor.DistributedUpdateProcessor.DistribPhase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.update.SolrIndexSplitter.SplitMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.update.UpdateLog.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.update.UpdateLog.SyncLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.util.configuration.SSLCredentialProvider.CredentialType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.apache.solr.util.DistanceUnits
Parses a string representation of distance units and returns its implementing class instance.
valueOf(String) - Static method in enum org.apache.solr.util.hll.HLLType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.util.PivotListEntry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.solr.util.vector.DenseVectorParser.BuilderPhase
Returns the enum constant of this type with the specified name.
values - Variable in class org.apache.solr.response.SolrQueryResponse
Container for user defined values
values - Variable in class org.apache.solr.search.facet.SlotAcc.FuncSlotAcc
 
values - Static variable in interface org.apache.solr.security.PermissionNameProvider
 
values() - Static method in enum org.apache.solr.api.ContainerPluginsRegistry.Diff
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.client.solrj.embedded.EmbeddedSolrServer.RequestWriterSupplier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.Cmd
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cloud.api.collections.ReindexCollectionCmd.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cloud.ClusterSingleton.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cloud.DistributedClusterStateUpdater.MutatingCommand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cloud.overseer.OverseerAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cluster.events.ClusterEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cluster.placement.NodeMetric.Registry
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cluster.Replica.ReplicaState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cluster.Replica.ReplicaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.cluster.Shard.ShardState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.backup.repository.BackupRepository.PathType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.DirectoryFactory.DirContext
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.NodeRoles.Role
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.snapshots.CollectionSnapshotMetaData.SnapshotStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.SolrConfig.HttpCachingConfig.LastModFrom
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.SolrConfig.PluginOpts
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.SolrInfoBean.Category
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.core.SolrInfoBean.Group
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.filestore.FileStore.FileType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.admin.ClusterStatus.Health
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.admin.CollectionsHandler.CollectionOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.admin.CoreAdminOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.component.HighlightComponent.HighlightMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.component.QueryElevationComponent.InitializationExceptionCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.component.RealTimeGetComponent.Resolution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.component.StatsField.Stat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.handler.PingRequestHandler.ACTIONS
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.legacy.LegacyNumericType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxHistogramMBean
 
values() - Method in interface org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.JmxTimerMBean
 
values() - Static method in enum org.apache.solr.metrics.SolrMetricManager.ResolutionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.parser.QueryParser.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.parser.SolrQueryParserBase.SynonymQueryStyle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.response.transform.ExplainAugmenterFactory.Style
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.response.transform.ShardAugmenterFactory.Style
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.schema.FieldType.MultiValueSelector
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.schema.IndexSchema.SchemaProps.Handler
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.schema.NumberType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.schema.SchemaManager.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.CollapsingQParserPlugin.GroupHeadSelectorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.CollapsingQParserPlugin.NullPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.facet.FacetField.FacetMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.facet.FacetRequest.RefineMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.facet.FacetRequest.SortDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.Grouping.Format
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.Grouping.TotalCount
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.ReRankOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.SolrCache.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.search.SolrReturnFields.FIELD_SOURCES
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.security.AuditEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.security.AuditEvent.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.security.AuditEvent.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.security.AuthorizationContext.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.security.PermissionNameProvider.Name
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.servlet.cache.Method
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.servlet.SolrDispatchFilter.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.spelling.WordBreakSolrSpellChecker.BreakSuggestionTieBreaker
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.uninverting.UninvertingReader.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.update.processor.ClassificationUpdateProcessorFactory.Algorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.update.processor.DistributedUpdateProcessor.DistribPhase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.update.SolrIndexSplitter.SplitMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.update.UpdateLog.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.update.UpdateLog.SyncLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.util.configuration.SSLCredentialProvider.CredentialType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.util.hll.HLLType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.solr.util.MapListener
 
values() - Static method in enum org.apache.solr.util.PivotListEntry
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.solr.util.vector.DenseVectorParser.BuilderPhase
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in class org.apache.solr.util.stats.MetricUtils
 
valueSource - Variable in class org.apache.solr.response.transform.ValueSourceAugmenter
 
valueSource - Variable in class org.apache.solr.search.facet.SlotAcc.FuncSlotAcc
 
ValueSourceAugmenter - Class in org.apache.solr.response.transform
Add values from a ValueSource (function query etc)
ValueSourceAugmenter(String, QParser, ValueSource) - Constructor for class org.apache.solr.response.transform.ValueSourceAugmenter
 
ValueSourceParser - Class in org.apache.solr.search
A factory that parses user queries to generate ValueSource instances.
ValueSourceParser() - Constructor for class org.apache.solr.search.ValueSourceParser
 
ValueSourceRangeFilter - Class in org.apache.solr.search.function
RangeFilter over a ValueSource.
ValueSourceRangeFilter(ValueSource, String, String, boolean, boolean) - Constructor for class org.apache.solr.search.function.ValueSourceRangeFilter
 
variables - Variable in class org.apache.solr.update.processor.TemplateUpdateProcessorFactory.Resolved
 
variance(double, double, long) - Static method in class org.apache.solr.search.facet.AggUtil
Computes and returns corrected variance for given values
VarianceAgg - Class in org.apache.solr.search.facet
 
VarianceAgg(ValueSource) - Constructor for class org.apache.solr.search.facet.VarianceAgg
 
vectorBoxCorner(double[], double[], double, boolean) - Static method in class org.apache.solr.schema.PointType
Return the coordinates of a vector that is the corner of a box (upper right or lower left), assuming a Rectangular coordinate system.
vectorDimension() - Method in class org.apache.solr.schema.SchemaField
 
vectorDistance(double[], double[], double) - Static method in class org.apache.solr.search.function.distance.VectorDistanceFunction
Calculate the p-norm (i.e.
vectorDistance(double[], double[], double, double) - Static method in class org.apache.solr.search.function.distance.VectorDistanceFunction
Calculate the p-norm (i.e.
VectorDistanceFunction - Class in org.apache.solr.search.function.distance
Calculate the p-norm for a Vector.
VectorDistanceFunction(float, MultiValueSource, MultiValueSource) - Constructor for class org.apache.solr.search.function.distance.VectorDistanceFunction
 
vectorEncoding() - Method in class org.apache.solr.schema.SchemaField
 
vectorSimilarityFunction() - Method in class org.apache.solr.schema.SchemaField
 
verbose - Variable in class org.apache.solr.cli.ToolBase
 
verbose(Object...) - Static method in class org.apache.solr.core.SolrCore
 
VERBOSE - Static variable in class org.apache.solr.core.SolrCore
 
VerifiedUserRoles - Interface in org.apache.solr.security
Interface used to pass verified user roles in a Principal object.
verify(String, InputStream) - Method in class org.apache.solr.util.CryptoKeys
 
verify(String, ByteBuffer) - Method in class org.apache.solr.util.CryptoKeys
Try with all signatures and return the name of the signature that matched
verify(PublicKey, byte[], InputStream) - Static method in class org.apache.solr.util.CryptoKeys
 
verify(PublicKey, byte[], ByteBuffer) - Static method in class org.apache.solr.util.CryptoKeys
Verify the signature of a file
verify(SolrPackageInstance, List<String>, boolean, String[]) - Method in class org.apache.solr.packagemanager.PackageManager
Given a package and list of collections, verify if the package is installed in those collections.
verifyAllowedModification(ModificationRequest, PlacementContext) - Method in interface org.apache.solr.cluster.placement.PlacementPlugin
Verify that a collection layout modification doesn't violate constraints on replica placements required by this plugin.
verifyAllowedModification(ModificationRequest, PlacementContext) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
verifyCommand - Variable in class org.apache.solr.packagemanager.SolrPackage.Plugin
 
verifyDeleteCollection(SolrCloudManager, DocCollection) - Method in interface org.apache.solr.cloud.api.collections.Assign.AssignStrategy
Verify that deleting a collection doesn't violate the replica assignment constraints.
verifyDeleteCollection(SolrCloudManager, DocCollection) - Method in class org.apache.solr.cluster.placement.impl.PlacementPluginAssignStrategy
 
verifyDeleteCollection(DeleteCollectionRequest, PlacementContext) - Method in class org.apache.solr.cluster.placement.plugins.AffinityPlacementFactory.AffinityPlacementPlugin
 
verifyDeleteCollection(DeleteCollectionRequest, PlacementContext) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
verifyDeleteReplicas(SolrCloudManager, DocCollection, String, Set<Replica>) - Method in interface org.apache.solr.cloud.api.collections.Assign.AssignStrategy
Verify that deleting these replicas doesn't violate the replica assignment constraints.
verifyDeleteReplicas(SolrCloudManager, DocCollection, String, Set<Replica>) - Method in class org.apache.solr.cluster.placement.impl.PlacementPluginAssignStrategy
 
verifyDeleteReplicas(DeleteReplicasRequest, PlacementContext) - Method in class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin
 
verifySha256(byte[], byte[], PublicKey) - Static method in class org.apache.solr.util.CryptoKeys
 
version - Static variable in class org.apache.solr.core.SolrCore
 
version - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.AnnotatedStat
 
version - Variable in class org.apache.solr.packagemanager.SolrPackage.SolrPackageRelease
 
version - Variable in class org.apache.solr.packagemanager.SolrPackageInstance
 
version - Variable in class org.apache.solr.pkg.PackageAPI.PkgVersion
 
version - Variable in class org.apache.solr.schema.IndexSchema
 
version - Variable in class org.apache.solr.schema.IndexSchemaFactory.VersionedConfig
 
version - Variable in class org.apache.solr.update.UpdateCommand
 
version - Variable in class org.apache.solr.update.UpdateLog.DBQ
 
version - Variable in class org.apache.solr.update.UpdateLog.DeleteUpdate
 
version() - Method in class org.apache.solr.util.SolrJacksonAnnotationInspector
 
VERSION - org.apache.solr.schema.IndexSchema.SchemaProps.Handler
 
VERSION - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
VERSION - Static variable in class org.apache.solr.schema.IndexSchema
 
VERSION - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
VERSION_IDX - Static variable in class org.apache.solr.update.UpdateLog
The index of the _version_ value in an entry from the transaction log.
VERSION_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
 
versionAdd(AddUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
VersionBucket - Class in org.apache.solr.update
The default implementation which uses the intrinsic object monitor.
VersionBucket() - Constructor for class org.apache.solr.update.VersionBucket
 
VersionBucket.CheckedFunction<T,​R> - Interface in org.apache.solr.update
 
versionConstraint - Variable in class org.apache.solr.packagemanager.SolrPackage.Manifest
 
versionDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
versionDeleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
 
VersionedConfig(int, ConfigNode) - Constructor for class org.apache.solr.schema.IndexSchemaFactory.VersionedConfig
 
VersionedFile - Class in org.apache.solr.util
 
VersionedFile() - Constructor for class org.apache.solr.util.VersionedFile
 
VersionedParams(Map<String, ?>, RequestParams.ParamSet) - Constructor for class org.apache.solr.core.RequestParams.VersionedParams
 
versionInfo - Variable in class org.apache.solr.update.UpdateLog
 
VersionInfo - Class in org.apache.solr.update
 
VersionInfo(UpdateLog, int) - Constructor for class org.apache.solr.update.VersionInfo
 
versionInUpdateIsAcceptable(Object[], Object[]) - Method in class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessor
Returns whether or not the versions in the command are acceptable to be indexed.
versions - Variable in class org.apache.solr.packagemanager.SolrPackage
 
VersionTool - Class in org.apache.solr.cli
 
VersionTool() - Constructor for class org.apache.solr.cli.VersionTool
 
visit(QueryVisitor) - Method in class org.apache.solr.legacy.LegacyNumericRangeQuery
Deprecated.
 
visit(QueryVisitor) - Method in class org.apache.solr.parser.SolrQueryParserBase.RawQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.query.FilterQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.query.SolrRangeQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.AbstractReRankQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.AnalyticsQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
 
visit(QueryVisitor) - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
 
visit(QueryVisitor) - Method in class org.apache.solr.search.FunctionRangeQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.join.GraphQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.join.HashRangeQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.MatchCostQuery
 
visit(QueryVisitor) - Method in class org.apache.solr.search.WrappedQuery
 
visitOrds(SortedDocValues, DocIdSetIterator, FieldUtil.OrdFunc) - Static method in class org.apache.solr.search.facet.FieldUtil
 
visitTerm(TermsEnum, int) - Method in class org.apache.solr.search.facet.UnInvertedField
Called for each term in the field being uninverted.
visitTerm(TermsEnum, int) - Method in class org.apache.solr.uninverting.DocTermOrds
Subclass can override this

W

WAIT - Static variable in class org.apache.solr.handler.ReplicationHandler
Boolean param for tests that can be specified when using ReplicationHandler.CMD_FETCH_INDEX to force the current request to block until the fetch is complete.
WAIT_SEARCHER - Static variable in class org.apache.solr.handler.UpdateRequestHandler
 
waitAddPendingCoreOps(String) - Method in class org.apache.solr.core.SolrCores
 
waitFor(String, Supplier<Boolean>) - Method in class org.apache.solr.util.TimeOut
Wait until the given Supplier returns true or the time out expires which ever happens first
waitForActiveCollection(String, CoreContainer, SolrResponse) - Static method in class org.apache.solr.handler.admin.CollectionsHandler
 
waitForCoreNodeName(String, String, String, ZkStateReader) - Static method in class org.apache.solr.cloud.api.collections.CollectionHandlingUtils
 
waitForLoadingCore(String, long) - Method in class org.apache.solr.core.CoreContainer
 
waitForLoadingCoresToFinish(long) - Method in class org.apache.solr.core.CoreContainer
If using asyncSolrCoreLoad=true, calling this after CoreContainer.load() will not return until all cores have finished loading.
waitForLoadingCoresToFinish(long) - Method in class org.apache.solr.core.SolrCores
 
waitForLoadingCoreToFinish(String, long) - Method in class org.apache.solr.core.SolrCores
 
waitForQueueToDrain(int) - Method in class org.apache.solr.security.AuditLoggerPlugin
Blocks until the async event queue is drained
waitForSchemaZkVersionAgreement(String, String, int, ZkController, int) - Static method in class org.apache.solr.schema.ManagedIndexSchema
Block up to a specified maximum time until we see agreement on the schema version in ZooKeeper across all replicas for a collection.
waitForSearcher(String, int, int, boolean) - Method in interface org.apache.solr.util.TestInjection.Hook
 
waitForSlotAcquisition - Variable in class org.apache.solr.core.RateLimiterConfig
 
waitForState(SolrCloudManager, String, long, TimeUnit, CollectionStatePredicate) - Static method in class org.apache.solr.cloud.CloudUtil
Wait for a particular collection state to appear.
waitForState(SolrCloudManager, String, String, CollectionStatePredicate) - Static method in class org.apache.solr.cloud.CloudUtil
Wait for a particular collection state to appear.
waitSearcher - Variable in class org.apache.solr.update.CommitUpdateCommand
 
waitToSeeLiveNodes(String, int) - Method in class org.apache.solr.cli.RunExampleTool
wait until the number of live nodes == numNodes.
waitToSeeSampleDocs(String, long) - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
waitToSeeSolrUp(String, long, TimeUnit) - Method in class org.apache.solr.cli.StatusTool
 
waitUntilAcquired() - Method in interface org.apache.solr.cloud.DistributedLock
 
waitUntilAcquired() - Method in class org.apache.solr.cloud.DistributedMultiLock
 
waitUntilReady(long, TimeUnit) - Method in class org.apache.solr.core.ClusterSingletons
Wait for this helper to become ready.
wantsAllFields() - Method in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
wantsAllFields() - Method in class org.apache.solr.search.ReturnFields
Returns true if all fields should be returned to the external client.
wantsAllFields() - Method in class org.apache.solr.search.SolrReturnFields
 
wantsCScore(String) - Static method in class org.apache.solr.search.CollapsingQParserPlugin.CollapseScore
Huge HACK, but not really any better options until/unless we can recursively ask value sources if they depend on score
wantsField(String) - Method in class org.apache.solr.search.ReturnFields
Returns true if the specified field should be returned to the external client -- either using its own name, or via an alias.
wantsField(String) - Method in class org.apache.solr.search.SolrReturnFields
 
wantsScore() - Method in class org.apache.solr.search.ReturnFields
Returns true if the score should be returned.
wantsScore() - Method in class org.apache.solr.search.SolrReturnFields
 
wantsScores() - Method in class org.apache.solr.response.ResultContext
 
warm(SolrIndexSearcher) - Method in class org.apache.solr.search.SolrIndexSearcher
Warm this searcher based on an old one (primarily for auto-cache warming).
warm(SolrIndexSearcher, SolrCache<K, V>) - Method in class org.apache.solr.search.CaffeineCache
 
warm(SolrIndexSearcher, SolrCache<K, V>) - Method in interface org.apache.solr.search.SolrCache
Warm this cache associated with searcher using the old cache object.
WARN - org.apache.solr.security.AuditEvent.Level
 
warning - Variable in class org.apache.solr.jersey.ExperimentalResponse
 
watcherName - Variable in class org.apache.solr.handler.admin.api.NodeLoggingAPI.LoggingResponse
 
webCrawl(int, OutputStream) - Method in class org.apache.solr.cli.SimplePostTool
Deprecated.
A very simple crawler, pulling URLs to fetch from a backlog and then recurses N levels deep if recursive>0.
WEIGHT - Static variable in class org.apache.solr.search.RankQParserPlugin
 
WEIGHT_BUCKETS - Static variable in class org.apache.solr.spelling.suggest.fst.FSTLookupFactory
The number of separate buckets for weights (discretization).
WEIGHT_EXPRESSION - Static variable in class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
Label for defining expression to evaluate the weight for the terms
WEIGHT_FIELD - Static variable in class org.apache.solr.spelling.suggest.DocumentDictionaryFactory
 
WeightedFragListBuilder - Class in org.apache.solr.highlight
 
WeightedFragListBuilder() - Constructor for class org.apache.solr.highlight.WeightedFragListBuilder
 
WeightedNode(Node) - Constructor for class org.apache.solr.cluster.placement.plugins.OrderedNodePlacementPlugin.WeightedNode
 
weightSort(Sort) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns a weighted sort according to this searcher
weightSortSpec(SortSpec, Sort) - Method in class org.apache.solr.search.SolrIndexSearcher
Returns a weighted sort spec according to this searcher
WFSTLookupFactory - Class in org.apache.solr.spelling.suggest.fst
Factory for WFSTCompletionLookup
WFSTLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.WFSTLookupFactory
 
WHITE - Static variable in class org.apache.solr.packagemanager.PackageUtils
 
WILDTERM - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
withCollection - Variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
This property defines an additional constraint that primary collections (keys) should be located on the same nodes as the secondary collections (values).
withCollectionShards - Variable in class org.apache.solr.cluster.placement.plugins.AffinityPlacementConfig
Same as AffinityPlacementConfig.withCollection but ensures shard to shard correspondence.
withCore(Consumer<SolrCore>) - Method in class org.apache.solr.core.SolrCore.Provider
 
withDocs(DocSet) - Method in class org.apache.solr.request.SimpleFacets.ParsedParams
 
withHandler(String) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Handler name to use at the remote end.
withinGroupSort - Variable in class org.apache.solr.search.Grouping.Command
 
withReporterId(String) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Use this id to identify metrics from this instance.
withSearcher(IOFunction<SolrIndexSearcher, R>) - Method in class org.apache.solr.core.SolrCore
Executes the lambda with the SolrIndexSearcher.
withServerIdentity(boolean) - Static method in class org.apache.solr.security.PKIAuthenticationPlugin
Mark the current thread as a server thread and set a flag in SolrRequestInfo to indicate you want to send a request as the server identity instead of as the authenticated user.
withSolrParams(SolrParams) - Method in class org.apache.solr.metrics.reporters.solr.SolrReporter.Builder
Additional SolrParams to add to every request.
withSolrResourceLoader(SolrResourceLoader) - Method in class org.apache.solr.handler.SolrDefaultStreamFactory
 
withTag(String) - Method in class org.apache.solr.metrics.reporters.jmx.JmxMetricsReporter.Builder
 
WORD_FIELD_NAME - Static variable in class org.apache.solr.spelling.FileBasedSpellChecker
 
WORD_SET_JSON_FIELD - Static variable in class org.apache.solr.rest.schema.analysis.ManagedWordSetResource
 
WordBreakSolrSpellChecker - Class in org.apache.solr.spelling
A spellchecker that breaks and combines words.
WordBreakSolrSpellChecker() - Constructor for class org.apache.solr.spelling.WordBreakSolrSpellChecker
 
WordBreakSolrSpellChecker.BreakSuggestionTieBreaker - Enum in org.apache.solr.spelling
Specify a value on the "breakSugestionTieBreaker" parameter.
wrap(DirectoryReader, Function<String, UninvertingReader.Type>) - Static method in class org.apache.solr.uninverting.UninvertingReader
Wraps a provided DirectoryReader.
wrap(DirectoryReader, Map<String, UninvertingReader.Type>) - Static method in class org.apache.solr.uninverting.UninvertingReader
 
wrap(IndexReader) - Static method in class org.apache.solr.index.SlowCompositeReaderWrapper
This method is sugar for getting an LeafReader from an IndexReader of any kind.
wrap(LeafReader, String) - Static method in class org.apache.solr.search.NumericHidingLeafReader
Deprecated.
Returns a view over leafReader where field is a string instead of a numeric.
wrap(LeafReader, Function<String, UninvertingReader.Type>) - Static method in class org.apache.solr.uninverting.UninvertingReader
Create a new UninvertingReader with the specified mapping, wrapped around the input.
wrap(PostingsEnum, Bits) - Static method in class org.apache.solr.search.BitsFilteredPostingsEnum
 
wrap(Query) - Method in class org.apache.solr.handler.component.ResponseBuilder
Calls RankQuery.wrap(Query) if there's a rank query, otherwise just returns the query.
wrap(Query) - Method in class org.apache.solr.search.AbstractReRankQuery
 
wrap(Query) - Method in class org.apache.solr.search.ExportQParserPlugin.ExportQuery
 
wrap(Query) - Method in class org.apache.solr.search.RankQuery
 
wrap(SolrQueryRequest, UpdateRequestProcessor) - Static method in class org.apache.solr.update.processor.RoutedAliasUpdateProcessor
 
wrap(FieldMutatingUpdateProcessor.FieldNameSelector, FieldMutatingUpdateProcessor.FieldNameSelector) - Static method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessor
Wraps two FieldNameSelectors such that the FieldNameSelector returned matches all fields specified by the "includes" unless they are matched by "excludes"
wrapAndSetZkHostFromSysPropIfNeeded(Properties) - Static method in class org.apache.solr.core.SolrXmlConfig
Given some node Properties, checks if non-null and a 'zkHost' is already included.
wrapParams(SolrQueryRequest, Object...) - Static method in class org.apache.solr.handler.ClusterAPI
 
wrapParams(SolrQueryRequest, Map<String, Object>) - Static method in class org.apache.solr.handler.ClusterAPI
 
WrappedQuery - Class in org.apache.solr.search
A simple query that wraps another query and implements ExtendedQuery.
WrappedQuery(Query) - Constructor for class org.apache.solr.search.WrappedQuery
 
wrappedReq(SolrQueryRequest, String, HttpSolrCall) - Static method in class org.apache.solr.servlet.CoordinatorHttpSolrCall
 
wrapperFunction - Variable in class org.apache.solr.response.JSONWriter
 
WrapperMergePolicyFactory - Class in org.apache.solr.index
A MergePolicyFactory for wrapping additional factories.
WrapperMergePolicyFactory(SolrResourceLoader, MergePolicyFactoryArgs, IndexSchema) - Constructor for class org.apache.solr.index.WrapperMergePolicyFactory
 
wrapRequestHandlers(SolrRequestHandler, String...) - Static method in class org.apache.solr.api.ApiBag
 
wrapSubordinateClause(Query) - Method in class org.apache.solr.search.join.BlockJoinParentQParser
 
wrapSubordinateClause(Query) - Method in class org.apache.solr.search.join.FiltersQParser
 
wrapWithPrincipal(HttpServletRequest, Principal) - Method in class org.apache.solr.security.AuthenticationPlugin
 
wrapWithPrincipal(HttpServletRequest, Principal, String) - Method in class org.apache.solr.security.AuthenticationPlugin
 
write(byte[]) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
write(byte[], int, int) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
write(char[]) - Method in class org.apache.solr.security.PrintWriterWrapper
 
write(char[], int, int) - Method in class org.apache.solr.security.PrintWriterWrapper
 
write(int) - Method in class org.apache.solr.security.PrintWriterWrapper
 
write(int) - Method in class org.apache.solr.servlet.ServletOutputStreamWrapper
 
write(int) - Method in class org.apache.solr.servlet.ServletUtils.ClosedServletOutputStream
 
write(int) - Method in class org.apache.solr.util.PropertiesOutputStream
 
write(OutputStream) - Method in interface org.apache.solr.core.SolrCore.RawWriter
 
write(OutputStream) - Method in class org.apache.solr.handler.export.ExportWriter
 
write(OutputStream, SolrQueryRequest, SolrQueryResponse) - Method in interface org.apache.solr.response.BinaryQueryResponseWriter
Use it to write the response in a binary format
write(OutputStream, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.BinaryResponseWriter
 
write(OutputStream, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.CborResponseWriter
 
write(OutputStream, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.JacksonJsonWriter
 
write(OutputStream, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.RawResponseWriter
 
write(OutputStream, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.SmileResponseWriter
 
write(Writer, boolean, String, Object) - Static method in class org.apache.solr.response.JSONWriter
Strictly for testing only
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.BinaryResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.CSVResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.GeoJSONResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.GraphMLResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.JSONResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.PHPResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.PHPSerializedResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.PythonResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in interface org.apache.solr.response.QueryResponseWriter
Write a SolrQueryResponse, this method must be thread save.
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.RawResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.RubyResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.SchemaXmlResponseWriter
 
write(Writer, SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.XMLResponseWriter
 
write(String) - Method in class org.apache.solr.security.PrintWriterWrapper
 
write(String, int, int) - Method in class org.apache.solr.security.PrintWriterWrapper
 
write(IteratorWriter.ItemWriter) - Method in class org.apache.solr.schema.FieldType
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.AbstractEnumField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.BinaryField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.BoolField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.CollationField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.CurrencyFieldType
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.ExternalFileField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.FieldType
calls back to TextResponseWriter to write the field value
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.PointField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.PointType
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.PreAnalyzedField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.RandomSortField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.RankField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.SchemaField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.StrField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.TextField
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.TrieField
Deprecated.
 
write(TextResponseWriter, String, IndexableField) - Method in class org.apache.solr.schema.UUIDField
 
write(AddUpdateCommand) - Method in class org.apache.solr.update.TransactionLog
Writes an add update command to the transaction log.
write(AddUpdateCommand, long) - Method in class org.apache.solr.update.TransactionLog
Writes an add update command to the transaction log.
write(JSONWriter) - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData.CoreSnapshotMetaData
 
write(JSONWriter) - Method in class org.apache.solr.core.snapshots.CollectionSnapshotMetaData
 
WRITE - org.apache.solr.security.AuthorizationContext.RequestType
 
writeAll(FastOutputStream) - Method in class org.apache.solr.update.MemOutputStream
 
writeAPI - Variable in class org.apache.solr.filestore.FileStoreAPI
 
writeArray(String, Object[], boolean) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeArray(String, Object[], boolean) - Method in class org.apache.solr.response.XMLWriter
 
writeArray(String, Iterator<?>, boolean) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeArray(String, Iterator<?>, boolean) - Method in class org.apache.solr.response.TabularResponseWriter
 
writeArray(String, Iterator<?>, boolean) - Method in class org.apache.solr.response.XMLWriter
 
writeArrayCloser() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeArrayCloser() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeArrayOpener(int) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeArrayOpener(int) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeArraySeparator() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeArraySeparator() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeAttr(String, String, boolean) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeAttr(String, String, boolean) - Method in class org.apache.solr.response.XMLWriter
 
writeBackupProperties(BackupProperties) - Method in class org.apache.solr.core.backup.BackupManager
This method stores the backup properties at the specified location in the repository.
writeBool(String, boolean) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeBool(String, boolean) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeBool(String, Boolean) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeBool(String, Boolean) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeBool(String, String) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeBool(String, String) - Method in class org.apache.solr.response.XMLWriter
 
writeByteArr(String, byte[], int, int) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeByteArr(String, byte[], int, int) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeCollectionState(String, DocCollection) - Method in class org.apache.solr.core.backup.BackupManager
This method writes the collection meta-data to the specified location in the repository.
writeCommit(CommitUpdateCommand) - Method in class org.apache.solr.update.TransactionLog
 
writeData(Object) - Method in class org.apache.solr.update.TransactionLog
 
writeDate(String, String) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeDate(String, String) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeDate(String, String) - Method in class org.apache.solr.response.XMLWriter
 
writeDate(String, Date) - Method in class org.apache.solr.response.TabularResponseWriter
 
writeDelete(DeleteUpdateCommand) - Method in class org.apache.solr.update.TransactionLog
 
writeDeleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.TransactionLog
 
writeDocs(SolrQueryRequest, OutputStream, IteratorWriter.ItemWriter, Sort) - Method in class org.apache.solr.handler.export.ExportWriter
 
writeDocuments(String, ResultContext) - Method in class org.apache.solr.response.TextResponseWriter
 
writeDouble(String, double) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeDouble(String, double) - Method in class org.apache.solr.response.XMLWriter
 
writeDouble(String, String) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeDouble(String, String) - Method in class org.apache.solr.response.XMLWriter
 
writeEndDocumentList() - Method in class org.apache.solr.response.JSONWriter
 
writeEndDocumentList() - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeEndDocumentList() - Method in class org.apache.solr.response.TabularResponseWriter
 
writeEndDocumentList() - Method in class org.apache.solr.response.TextResponseWriter
 
writeEndDocumentList() - Method in class org.apache.solr.response.XMLWriter
 
writeException(Exception, PushWriter, boolean) - Method in class org.apache.solr.handler.export.ExportWriter
 
writeExternString(CharSequence) - Method in class org.apache.solr.update.TransactionLog.LogCodec
 
writeFloat(String, float) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeFloat(String, float) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeFloat(String, float) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeFloat(String, float) - Method in class org.apache.solr.response.XMLWriter
 
writeFloat(String, String) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeFloat(String, String) - Method in class org.apache.solr.response.XMLWriter
 
writeInt(String, int) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeInt(String, int) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeInt(String, String) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeInt(String, String) - Method in class org.apache.solr.response.XMLWriter
 
writeIterator(String, IteratorWriter, boolean) - Method in class org.apache.solr.response.XMLWriter
 
writeKey(String, boolean) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeKey(String, boolean) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeLockTimeout - Variable in class org.apache.solr.update.SolrIndexConfig
 
writeLogHeader(TransactionLog.LogCodec) - Method in class org.apache.solr.update.TransactionLog
 
writeLogsForTesting() - Static method in class org.apache.solr.handler.admin.api.NodeLoggingAPI
 
writeLong(String, long) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeLong(String, long) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeLong(String, String) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeLong(String, String) - Method in class org.apache.solr.response.XMLWriter
 
writeMap(String, Map<?, ?>, boolean, boolean) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeMap(String, Map<?, ?>, boolean, boolean) - Method in class org.apache.solr.response.TabularResponseWriter
 
writeMap(String, Map<?, ?>, boolean, boolean) - Method in class org.apache.solr.response.XMLWriter
 
writeMap(String, MapWriter) - Method in class org.apache.solr.response.XMLWriter
 
writeMap(MapWriter.EntryWriter) - Method in class org.apache.solr.api.ContainerPluginsRegistry
 
writeMap(MapWriter.EntryWriter) - Method in class org.apache.solr.filestore.FileStoreAPI.MetaData
 
writeMap(MapWriter.EntryWriter) - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.Estimate
 
writeMap(MapWriter.EntryWriter) - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.ItemPriorityQueue
 
writeMap(MapWriter.EntryWriter) - Method in class org.apache.solr.handler.admin.IndexSizeEstimator.MapWriterSummaryStatistics
 
writeMap(MapWriter.EntryWriter) - Method in interface org.apache.solr.jersey.JacksonReflectMapWriter
 
writeMap(MapWriter.EntryWriter) - Method in class org.apache.solr.metrics.MetricsMap
 
writeMap(MapWriter.EntryWriter) - Method in class org.apache.solr.pkg.SolrPackageLoader.SolrPackage.Version
 
writeMapCloser() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeMapCloser() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeMapOpener(int) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeMapOpener(int) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeMapSeparator() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeMapSeparator() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeMetadata(byte[], IHLLMetadata) - Method in interface org.apache.solr.util.hll.ISchemaVersion
Writes metadata bytes to serialized HLL.
writeNamedList(String, NamedList<?>) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeNamedList(String, NamedList<?>) - Method in class org.apache.solr.response.TabularResponseWriter
 
writeNamedList(String, NamedList<?>) - Method in class org.apache.solr.response.XMLWriter
 
writeNull(String) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeNull(String) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeNull(String) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeNull(String) - Method in class org.apache.solr.response.XMLWriter
 
writeNumber(String, Number) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeNumber(String, Number) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writePendingUpdates() - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
 
writePendingUpdates(Map<String, ZkWriteCommand>, boolean) - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
Writes all pending updates to ZooKeeper and returns the modified cluster state
writePrimitive(Object) - Method in class org.apache.solr.update.TransactionLog.LogCodec
 
writeQueryResponse(OutputStream, QueryResponseWriter, SolrQueryRequest, SolrQueryResponse, String) - Static method in class org.apache.solr.response.QueryResponseWriterUtil
Writes the response writer's result to the given output stream.
writer - Variable in class org.apache.solr.response.TextResponseWriter
 
writeResponse() - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeResponse() - Method in class org.apache.solr.response.JSONWriter
 
writeResponse() - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeResponse() - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeResponse() - Method in class org.apache.solr.response.XMLWriter
 
writeResponse(Writer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.response.SchemaXmlWriter
 
writeResponse(Writer, SolrQueryRequest, SolrQueryResponse) - Static method in class org.apache.solr.response.XMLWriter
 
writeResponse(Object) - Method in class org.apache.solr.response.TabularResponseWriter
 
writeResponse(SolrQueryResponse, QueryResponseWriter, Method) - Method in class org.apache.solr.api.V2HttpCall
 
writeResponse(SolrQueryResponse, QueryResponseWriter, Method) - Method in class org.apache.solr.servlet.HttpSolrCall
 
writeResponseStatusAndHeaders(long, ContainerResponse) - Method in class org.apache.solr.jersey.container.JettyBridgeResponseWriter
 
writeResults(ResultContext, JavaBinCodec) - Method in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
writeResultsBody(ResultContext, JavaBinCodec) - Method in class org.apache.solr.response.BinaryResponseWriter.Resolver
 
WriterImpl(JsonFactory, OutputStream, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeSolrDocument(String, SolrDocument, ReturnFields, int) - Method in class org.apache.solr.response.JSONWriter
 
writeSolrDocument(String, SolrDocument, ReturnFields, int) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeSolrDocument(String, SolrDocument, ReturnFields, int) - Method in class org.apache.solr.response.TextResponseWriter
 
writeSolrDocument(String, SolrDocument, ReturnFields, int) - Method in class org.apache.solr.response.XMLWriter
The SolrDocument should already have multivalued fields implemented as Collections -- this will not rewrite to <arr>
writeSolrDocumentList(String, SolrDocumentList, ReturnFields) - Method in class org.apache.solr.response.TextResponseWriter
 
writeStartDocumentList(String, long, int, long, Float, Boolean) - Method in class org.apache.solr.response.JSONWriter
 
writeStartDocumentList(String, long, int, long, Float, Boolean) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeStartDocumentList(String, long, int, long, Float, Boolean) - Method in class org.apache.solr.response.TabularResponseWriter
 
writeStartDocumentList(String, long, int, long, Float, Boolean) - Method in class org.apache.solr.response.TextResponseWriter
 
writeStartDocumentList(String, long, int, long, Float, Boolean) - Method in class org.apache.solr.response.XMLWriter
 
writeStr(String, String, boolean) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeStr(String, String, boolean) - Method in class org.apache.solr.response.SchemaXmlWriter
 
writeStr(String, String, boolean) - Method in class org.apache.solr.response.SmileResponseWriter.SmileWriter
 
writeStr(String, String, boolean) - Method in class org.apache.solr.response.XMLWriter
 
writeStrRaw(String, String) - Method in class org.apache.solr.response.JacksonJsonWriter.WriterImpl
 
writeStrRaw(String, String) - Method in class org.apache.solr.response.XMLWriter
 
writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.solr.jersey.MessageBodyWriters.BaseMessageBodyWriter
 
writeUpdate(ZkWriteCommand) - Method in class org.apache.solr.cloud.overseer.ZkStateWriter
 
writeVal(String, Object, boolean) - Method in class org.apache.solr.response.TextResponseWriter
 
wrongIndexFingerprint - Static variable in class org.apache.solr.util.TestInjection
 

X

XML - org.apache.solr.client.solrj.embedded.EmbeddedSolrServer.RequestWriterSupplier
 
XML_OFFSET_ADJUST - Static variable in class org.apache.solr.handler.tagger.TaggerRequestHandler
Request parameter.
XmlConfigFile - Class in org.apache.solr.core
Wrapper around an XML DOM object to provide convenient accessors to it.
XmlConfigFile(SolrResourceLoader, String, InputSource, String, Properties) - Constructor for class org.apache.solr.core.XmlConfigFile
 
XmlConfigFile(SolrResourceLoader, Function<String, InputStream>, String, InputSource, String, Properties) - Constructor for class org.apache.solr.core.XmlConfigFile
Builds a config.
XMLLoader - Class in org.apache.solr.handler.loader
 
XMLLoader() - Constructor for class org.apache.solr.handler.loader.XMLLoader
 
xmllog - Static variable in class org.apache.solr.handler.loader.XMLLoader
 
XmlMessageBodyWriter() - Constructor for class org.apache.solr.jersey.MessageBodyWriters.XmlMessageBodyWriter
 
XmlOffsetCorrector - Class in org.apache.solr.handler.tagger
Corrects offsets to adjust for XML formatted data.
XmlOffsetCorrector(String) - Constructor for class org.apache.solr.handler.tagger.XmlOffsetCorrector
Initialize based on the document text.
XmlQParserPlugin - Class in org.apache.solr.search
The XmlQParserPlugin extends the QParserPlugin and supports the creation of queries from XML.
XmlQParserPlugin() - Constructor for class org.apache.solr.search.XmlQParserPlugin
 
XMLResponseWriter - Class in org.apache.solr.response
 
XMLResponseWriter() - Constructor for class org.apache.solr.response.XMLResponseWriter
 
XMLWriter - Class in org.apache.solr.response
 
XMLWriter(Writer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.response.XMLWriter
 

Y

YELLOW - org.apache.solr.handler.admin.ClusterStatus.Health
Some replicas down, leader exists.
YELLOW - Static variable in class org.apache.solr.packagemanager.PackageUtils
 

Z

zero - Static variable in class org.apache.solr.search.SortedIntDocSet
 
zero() - Static method in class org.apache.solr.core.backup.BackupId
 
zeroInts - Static variable in class org.apache.solr.search.SortedIntDocSet
 
ZK_HOST - Static variable in class org.apache.solr.cli.SolrCLI
 
ZK_HOST - Static variable in class org.apache.solr.core.SolrXmlConfig
 
ZK_HOST - Static variable in class org.apache.solr.search.join.CrossCollectionJoinQParser
 
ZK_PATH_SEPARATOR - Static variable in class org.apache.solr.cloud.api.collections.DistributedCollectionConfigSetCommandRunner
 
ZK_READ_PERM - org.apache.solr.security.PermissionNameProvider.Name
 
ZK_STATE_DIR - Static variable in class org.apache.solr.core.backup.BackupManager
 
ZK_WHITELIST_PROPERTY - Static variable in class org.apache.solr.cloud.SolrZkServer
 
ZkByteArrayInputStream(byte[], String, Stat) - Constructor for class org.apache.solr.cloud.ZkSolrResourceLoader.ZkByteArrayInputStream
 
ZkCLI - Class in org.apache.solr.cloud
 
ZkCLI() - Constructor for class org.apache.solr.cloud.ZkCLI
 
zkClient - Variable in class org.apache.solr.cloud.LeaderElector
 
zkClient - Variable in class org.apache.solr.cloud.overseer.CollectionMutator
 
zkClient - Variable in class org.apache.solr.cloud.overseer.NodeMutator
 
zkClient - Variable in class org.apache.solr.cloud.overseer.ReplicaMutator
 
zkClient - Variable in class org.apache.solr.cloud.overseer.SliceMutator
 
zkClient - Variable in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
zkClientSupplier - Variable in class org.apache.solr.core.CoreContainer
Minimize exposure to CoreContainer.
ZkClusterPluginsSource - Class in org.apache.solr.api
The plugin configurations are stored and retrieved from the ZooKeeper cluster properties, stored at the ZkStateReader.CONTAINER_PLUGINS location This supports mutable configurations, and management via the /cluster/plugin APIs
ZkClusterPluginsSource(CoreContainer) - Constructor for class org.apache.solr.api.ZkClusterPluginsSource
 
ZkConfigSetService - Class in org.apache.solr.cloud
SolrCloud Zookeeper ConfigSetService impl.
ZkConfigSetService(SolrZkClient) - Constructor for class org.apache.solr.cloud.ZkConfigSetService
This is for ZkCLI and some tests
ZkConfigSetService(CoreContainer) - Constructor for class org.apache.solr.cloud.ZkConfigSetService
 
ZkContainer - Class in org.apache.solr.core
Used by CoreContainer to hold ZooKeeper / SolrCloud info, especially ZkController.
ZkContainer() - Constructor for class org.apache.solr.core.ZkContainer
 
zkController - Variable in class org.apache.solr.core.ZkContainer
 
ZkController - Class in org.apache.solr.cloud
Handle ZooKeeper interactions.
ZkController(CoreContainer, String, int, CloudConfig, Supplier<List<CoreDescriptor>>) - Constructor for class org.apache.solr.cloud.ZkController
 
ZkController.NotInClusterStateException - Exception in org.apache.solr.cloud
Thrown during pre register process if the replica is not present in clusterstate
ZkController.ResourceModifiedInZkException - Exception in org.apache.solr.cloud
 
ZkCpTool - Class in org.apache.solr.cli
 
ZkCpTool() - Constructor for class org.apache.solr.cli.ZkCpTool
 
ZkCpTool(PrintStream) - Constructor for class org.apache.solr.cli.ZkCpTool
 
zkData - Variable in class org.apache.solr.handler.admin.ZookeeperReadAPI.ZooKeeperFileResponse
 
ZkDistributedCollectionLockFactory - Class in org.apache.solr.cloud
A distributed lock implementation using Zookeeper "directory" nodes created within a collection znode hierarchy, for use with the distributed Collection API implementation.
ZkDistributedCollectionLockFactory(SolrZkClient, String) - Constructor for class org.apache.solr.cloud.ZkDistributedCollectionLockFactory
 
ZkDistributedConfigSetLockFactory - Class in org.apache.solr.cloud
A distributed lock implementation using Zookeeper "directory" nodes created within a collection znode hierarchy, for use with the distributed Collection API implementation.
ZkDistributedConfigSetLockFactory(SolrZkClient, String) - Constructor for class org.apache.solr.cloud.ZkDistributedConfigSetLockFactory
 
ZkDistributedQueue - Class in org.apache.solr.cloud
A ZK-based distributed queue.
ZkDistributedQueue(SolrZkClient, String) - Constructor for class org.apache.solr.cloud.ZkDistributedQueue
 
ZkDistributedQueue(SolrZkClient, String, Stats) - Constructor for class org.apache.solr.cloud.ZkDistributedQueue
 
ZkDistributedQueue(SolrZkClient, String, Stats, int) - Constructor for class org.apache.solr.cloud.ZkDistributedQueue
 
ZkDistributedQueue(SolrZkClient, String, Stats, int, ConnectionManager.IsClosed) - Constructor for class org.apache.solr.cloud.ZkDistributedQueue
 
zkHost - Variable in class org.apache.solr.search.join.CrossCollectionJoinQuery
 
ZkIndexSchemaReader - Class in org.apache.solr.schema
Keeps a ManagedIndexSchema up-to-date when changes are made to the serialized managed schema in ZooKeeper
ZkIndexSchemaReader(ManagedIndexSchemaFactory, SolrCore) - Constructor for class org.apache.solr.schema.ZkIndexSchemaReader
 
ZkIndexSchemaReader.SchemaWatcher - Class in org.apache.solr.schema
Watches for schema changes and triggers updates in the ZkIndexSchemaReader.
ZkLsTool - Class in org.apache.solr.cli
 
ZkLsTool() - Constructor for class org.apache.solr.cli.ZkLsTool
 
ZkLsTool(PrintStream) - Constructor for class org.apache.solr.cli.ZkLsTool
 
ZkMkrootTool - Class in org.apache.solr.cli
 
ZkMkrootTool() - Constructor for class org.apache.solr.cli.ZkMkrootTool
 
ZkMkrootTool(PrintStream) - Constructor for class org.apache.solr.cli.ZkMkrootTool
 
ZkMvTool - Class in org.apache.solr.cli
 
ZkMvTool() - Constructor for class org.apache.solr.cli.ZkMvTool
 
ZkMvTool(PrintStream) - Constructor for class org.apache.solr.cli.ZkMvTool
 
ZkRmTool - Class in org.apache.solr.cli
 
ZkRmTool() - Constructor for class org.apache.solr.cli.ZkRmTool
 
ZkRmTool(PrintStream) - Constructor for class org.apache.solr.cli.ZkRmTool
 
ZkShardTerms - Class in org.apache.solr.cloud
Class used for interact with a ZK term node.
ZkShardTerms(String, String, SolrZkClient) - Constructor for class org.apache.solr.cloud.ZkShardTerms
 
ZkSolrResourceLoader - Class in org.apache.solr.cloud
ResourceLoader that works with ZooKeeper.
ZkSolrResourceLoader(Path, String, ClassLoader, ZkController) - Constructor for class org.apache.solr.cloud.ZkSolrResourceLoader
This loader will first attempt to load resources from ZooKeeper, but if not found will delegate to the context classloader when possible, otherwise it will attempt to resolve resources using any jar files found in the "lib/" directory in the specified instance directory.
ZkSolrResourceLoader.ZkByteArrayInputStream - Class in org.apache.solr.cloud
 
zkStateReader - Variable in class org.apache.solr.cloud.ZkController
 
zkStateReader - Variable in class org.apache.solr.core.backup.BackupManager
 
zkStateReader() - Method in class org.apache.solr.handler.designer.SchemaDesignerAPI
 
ZkStateWriter - Class in org.apache.solr.cloud.overseer
ZkStateWriter is responsible for writing updates to the cluster state stored in ZooKeeper for collections each of which gets their own individual state.json in ZK.
ZkStateWriter(ZkStateReader, Stats, int, Compressor) - Constructor for class org.apache.solr.cloud.overseer.ZkStateWriter
 
ZkStateWriter.ZkWriteCallback - Interface in org.apache.solr.cloud.overseer
 
zkSys - Variable in class org.apache.solr.core.CoreContainer
 
ZkWriteCommand - Class in org.apache.solr.cloud.overseer
 
ZkWriteCommand(String, DocCollection) - Constructor for class org.apache.solr.cloud.overseer.ZkWriteCommand
 
ZkWriteCommand(String, DocCollection, PerReplicaStatesOps, boolean) - Constructor for class org.apache.solr.cloud.overseer.ZkWriteCommand
 
znodeBase - Variable in class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 
ZNODEVER - Static variable in class org.apache.solr.core.ConfigOverlay
 
znodeVersion - Variable in class org.apache.solr.pkg.PackageAPI.Packages
 
zookeeper - Variable in class org.apache.solr.cloud.DistributedMap
 
ZooKeeperFileResponse() - Constructor for class org.apache.solr.handler.admin.ZookeeperReadAPI.ZooKeeperFileResponse
 
ZookeeperInfoHandler - Class in org.apache.solr.handler.admin
Zookeeper Info
ZookeeperInfoHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.ZookeeperInfoHandler
 
ZookeeperReadAPI - Class in org.apache.solr.handler.admin
Exposes the content of the Zookeeper This is an expert feature that exposes the data inside the back end zookeeper.This API may change or be removed in future versions.
ZookeeperReadAPI(CoreContainer, SolrQueryRequest, SolrQueryResponse) - Constructor for class org.apache.solr.handler.admin.ZookeeperReadAPI
 
ZookeeperReadAPI.AnnotatedStat - Class in org.apache.solr.handler.admin
 
ZookeeperReadAPI.ListZkChildrenResponse - Class in org.apache.solr.handler.admin
 
ZookeeperReadAPI.ZooKeeperFileResponse - Class in org.apache.solr.handler.admin
 
ZookeeperStatusHandler - Class in org.apache.solr.handler.admin
Zookeeper Status handler, talks to ZK using sockets and four-letter words
ZookeeperStatusHandler(CoreContainer) - Constructor for class org.apache.solr.handler.admin.ZookeeperStatusHandler
 
ZooKeeperStorageIO(SolrZkClient, String) - Constructor for class org.apache.solr.rest.ManagedResourceStorage.ZooKeeperStorageIO
 

_

_createJsonMetaData(byte[], List<String>) - Static method in class org.apache.solr.filestore.FileStoreAPI
Creates a JSON string with the metadata.
_ESCAPED_CHAR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
_facetInfo - Variable in class org.apache.solr.handler.component.ResponseBuilder
 
_getFileType(File) - Static method in class org.apache.solr.filestore.DistribFileStore
 
_getHandler() - Method in class org.apache.solr.api.V2HttpCall
 
_getHandler() - Method in class org.apache.solr.servlet.HttpSolrCall
 
_NUM_CHAR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
_persistToFile(Path, String, ByteBuffer, ByteBuffer) - Static method in class org.apache.solr.filestore.DistribFileStore
Internal API
_QUOTED_CHAR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
_SQUOTED_CHAR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
_TERM_CHAR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
_TERM_START_CHAR - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
_toRefine - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
 
_wantsAllFields - Variable in class org.apache.solr.search.SolrReturnFields
 
_wantsScore - Variable in class org.apache.solr.search.SolrReturnFields
 
_WHITESPACE - Static variable in interface org.apache.solr.parser.QueryParserConstants
RegularExpression Id.
_writeChar(char) - Method in class org.apache.solr.response.JSONWriter
 
_writeStr(String) - Method in class org.apache.solr.response.JSONWriter
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages