- abortCheck() - Method in interface org.apache.solr.update.SolrCmdDistributor.AbortCheck
-
- abortErrorMessage - Variable in class org.apache.solr.servlet.SolrDispatchFilter
-
- 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
-
- AbstractDefaultValueUpdateProcessorFactory.DefaultValueUpdateProcessor - Class in org.apache.solr.update.processor
-
- AbstractDefaultValueUpdateProcessorFactory.DefaultValueUpdateProcessor(String, UpdateRequestProcessor) - Constructor for class org.apache.solr.update.processor.AbstractDefaultValueUpdateProcessorFactory.DefaultValueUpdateProcessor
-
- 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>, boolean, boolean) - Constructor for class org.apache.solr.util.plugin.AbstractPluginLoader
-
- AbstractPluginLoader(String, Class<T>) - Constructor for class org.apache.solr.util.plugin.AbstractPluginLoader
-
- AbstractSolrEventListener - Class in org.apache.solr.core
-
- AbstractSolrEventListener(SolrCore) - Constructor for class org.apache.solr.core.AbstractSolrEventListener
-
- AbstractSpatialFieldType<T extends 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
-
- AbstractSpatialPrefixTreeFieldType<T extends PrefixTreeStrategy> - Class in org.apache.solr.schema
-
- AbstractSpatialPrefixTreeFieldType() - Constructor for class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
-
- 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(File) - Method in class org.apache.solr.util.RegexFileFilter
-
- acceptsDocsOutOfOrder() - Method in class org.apache.solr.search.DelegatingCollector
-
- acceptsDocsOutOfOrder() - Method in class org.apache.solr.search.DocSetCollector
-
- acceptsDocsOutOfOrder() - Method in class org.apache.solr.search.EarlyTerminatingCollector
-
This collector requires that docs be collected in order, otherwise
the computed number of scanned docs in the resulting
EarlyTerminatingCollectorException
will be meaningless.
- acceptsDocsOutOfOrder() - Method in class org.apache.solr.search.grouping.collector.FilterCollector
-
- accumulate(NamedList) - Method in interface org.apache.solr.handler.component.StatsValues
-
Accumulate the values based on those in the given NamedList
- accumulate(int) - Method in interface org.apache.solr.handler.component.StatsValues
-
Accumulate the value associated with docID
.
- accumulate(BytesRef, int) - Method in interface org.apache.solr.handler.component.StatsValues
-
Accumulate the values based on the given value
- accumulateTermNum(int, BytesRef) - Method in class org.apache.solr.handler.component.FieldFacetStats
-
- ACCURACY - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
-
- accuracy - Variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
-
- ACCURACY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
-
- accuracy - Variable in class org.apache.solr.spelling.SpellingOptions
-
Optionally restrict the results to have a minimum accuracy level.
- acquire() - Method in class org.apache.solr.util.AdjustableSemaphore
-
- activateOptions() - Method in class org.apache.solr.util.SolrLogLayout
-
- actualShards - Variable in class org.apache.solr.handler.component.ShardRequest
-
actual shards to send the request to, filled out by framework
- ADD - Static variable in class org.apache.solr.handler.UpdateRequestHandler
-
- add(T) - Method in class org.apache.solr.logging.CircularList
-
- add(E, long) - Method in class org.apache.solr.logging.LogWatcher
-
- 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(int) - Method in class org.apache.solr.search.BitDocSet
-
- add(int) - Method in interface org.apache.solr.search.DocSet
-
Adds the specified document if it is not currently in the DocSet
(optional operation).
- add(Grouping.Command) - Method in class org.apache.solr.search.Grouping
-
- 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(Token, String, int) - Method in class org.apache.solr.spelling.SpellingResult
-
Suggestions must be added with the best suggestion first.
- add(String, String, List<Lookup.LookupResult>) - Method in class org.apache.solr.spelling.suggest.SuggesterResult
-
Add suggestion results for token
- 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 - Static variable in class org.apache.solr.update.UpdateLog
-
- add(AddUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
-
- add(AddUpdateCommand, boolean) - Method in class org.apache.solr.update.UpdateLog
-
- add(E) - Method in class org.apache.solr.util.BoundedTreeSet
-
- add(ConcurrentLFUCache.Stats) - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- add(ConcurrentLRUCache.Stats) - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- add(Calendar, int, String) - Static method in class org.apache.solr.util.DateMathParser
-
Modifies the specified Calendar by "adding" the specified value of units
- add(long) - Method in class org.apache.solr.util.LongPriorityQueue
-
Adds an object to a PriorityQueue in log(size) time.
- ADD_ROUTING_RULE - Static variable in class org.apache.solr.cloud.Overseer
-
- 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(DocSet) - Method in class org.apache.solr.search.BitDocSet
-
- addAllTo(DocSet) - Method in interface org.apache.solr.search.DocSet
-
Adds all the docs from this set to the target set.
- addAllTo(DocSet) - Method in class org.apache.solr.search.SortedIntDocSet
-
- addBoostFunctions(BooleanQuery, SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
-
- addBoostQuery(BooleanQuery, SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
-
- addChecker(SolrSpellChecker) - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
-
- addClause(List<BooleanClause>, int, int, Query) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- addCloseHook(CloseHook) - Method in class org.apache.solr.core.SolrCore
-
Add a close callback hook
- addCloseHook(Closeable) - Method in class org.apache.solr.request.SolrRequestInfo
-
- 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, boolean) - Method in class org.apache.solr.handler.component.SpellCheckComponent
-
- addCommandField(Command) - Method in class org.apache.solr.search.grouping.CommandHandler.Builder
-
- addCopyFields(Map<String, Collection<String>>) - Method in class org.apache.solr.schema.IndexSchema
-
Copies this schema and adds the new copy fields to the copy, then persists the new schema
- addCopyFields(Map<String, Collection<String>>) - Method in class org.apache.solr.schema.ManagedIndexSchema
-
- 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
-
- addDoc(AddUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- addDoc(AddUpdateCommand) - Method in class org.apache.solr.update.UpdateHandler
-
- addDocList(NamedList, GroupDocs) - Method in class org.apache.solr.search.Grouping.Command
-
- addedDocument(int) - Method in class org.apache.solr.update.CommitTracker
-
Indicate that documents have been added
- 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) - Method in class org.apache.solr.core.AbstractSolrEventListener
-
- addExperimentalFormatWarning(SolrQueryResponse) - Static method in class org.apache.solr.handler.RequestHandlerUtils
-
A common way to mark the response format as experimental
- 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(CSVField) - Method in class org.apache.solr.internal.csv.writer.CSVConfig
-
- addField(SchemaField) - Method in class org.apache.solr.schema.IndexSchema
-
Copies this schema, adds the given field to the copy, then persists the new schema.
- addField(SchemaField, Collection<String>) - Method in class org.apache.solr.schema.IndexSchema
-
Copies this schema, adds the given field to the copy, then persists the new schema.
- addField(SchemaField) - Method in class org.apache.solr.schema.ManagedIndexSchema
-
- addField(SchemaField, Collection<String>) - Method in class org.apache.solr.schema.ManagedIndexSchema
-
- addFieldCommand(String, SolrQueryRequest) - Method in class org.apache.solr.search.Grouping
-
Adds a field command based on the specified field.
- addFields(Collection<SchemaField>) - Method in class org.apache.solr.schema.IndexSchema
-
Copies this schema, adds the given fields to the copy, then persists the new schema.
- addFields(Collection<SchemaField>, Map<String, Collection<String>>) - Method in class org.apache.solr.schema.IndexSchema
-
Copies this schema, adds the given fields to the copy, then persists the new schema.
- addFields(Collection<SchemaField>) - Method in class org.apache.solr.schema.ManagedIndexSchema
-
- addFields(Collection<SchemaField>, Map<String, Collection<String>>) - Method in class org.apache.solr.schema.ManagedIndexSchema
-
- 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
-
- addHdfsResources(Configuration, String) - Static method in class org.apache.solr.util.HdfsUtil
-
- addMainQuery(BooleanQuery, SolrParams) - Method in class org.apache.solr.search.DisMaxQParser
-
Adds the main query to the query argument.
- addMissing(int) - Method in interface org.apache.solr.handler.component.StatsValues
-
Updates the statistics when multiple documents are missing a value
- addNoCheck(long) - Method in class org.apache.solr.util.LongPriorityQueue
-
Adds an object to a PriorityQueue in log(size) time.
- addOldLog(TransactionLog, boolean) - Method in class org.apache.solr.update.UpdateLog
-
- addParser(String, ValueSourceParser) - Static method in class org.apache.solr.search.ValueSourceParser
-
Adds a new parser for the name and returns any existing one that was overriden.
- addParser(NamedParser) - Static method in class org.apache.solr.search.ValueSourceParser
-
Adds a new parser for the name and returns any existing one that was overriden.
- addPhraseFieldQueries(BooleanQuery, 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
- addQueryCommand(String, SolrQueryRequest) - Method in class org.apache.solr.search.Grouping
-
- addRequest(SearchComponent, ShardRequest) - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- 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
-
- addShingledPhraseQueries(BooleanQuery, List<ExtendedDismaxQParser.Clause>, Map<String, Float>, 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.
- addToLog(String, Object) - Method in class org.apache.solr.response.SolrQueryResponse
-
Add a value to be logged.
- addToNamedList(Node, NamedList, List) - Static method in class org.apache.solr.util.DOMUtil
-
Examines a Node from the DOM representation of a NamedList and adds the
contents of that node to both the specified NamedList and List passed
as arguments.
- addTransformer(DocTransformer) - Method in class org.apache.solr.response.transform.DocTransformers
-
- addTransformerFactory(String, TransformerFactory) - Method in class org.apache.solr.core.SolrCore
-
- addUnique(int) - Method in class org.apache.solr.search.BitDocSet
-
- addUnique(int) - Method in interface org.apache.solr.search.DocSet
-
Adds a document the caller knows is not currently in the DocSet
(optional operation).
- AddUpdateCommand - Class in org.apache.solr.update
-
- 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
-
- AdminHandlers - Class in org.apache.solr.handler.admin
-
A special Handler that registers all standard admin handlers
- AdminHandlers() - Constructor for class org.apache.solr.handler.admin.AdminHandlers
-
- advance(int) - Method in class org.apache.solr.search.SolrConstantScoreQuery.ConstantScorer
-
- agentId - Variable in class org.apache.solr.core.SolrConfig.JmxConfiguration
-
- 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.
- ALL_SHARDS - Static variable in class org.apache.solr.handler.component.ShardRequest
-
- allPhraseFields - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
-
- 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
-
- alternativeTermCount - Variable in class org.apache.solr.spelling.SpellingOptions
-
- altQ - Variable in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
-
- altQParser - Variable in class org.apache.solr.search.DisMaxQParser
-
- altUserQuery - Variable in class org.apache.solr.search.DisMaxQParser
-
- amILeader() - Method in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- analyseLines(String[]) - Method in class org.apache.solr.internal.csv.writer.CSVConfigGuesser
-
- 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.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.
- AnalysisRequestHandlerBase.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.
- AnalysisRequestHandlerBase.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.
- 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
-
- AnalysisRequestHandlerBase.TokenTrackingAttributeImpl() - Constructor for class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
-
- analyze(Collection<Token>, String, int, int) - Method in class org.apache.solr.spelling.SpellingQueryConverter
-
- analyzeIfMultitermTermText(String, String, FieldType) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- analyzeMultiTerm(String, String, Analyzer) - Static method in class org.apache.solr.schema.TextField
-
- analyzer - Variable in class org.apache.solr.schema.FieldType
-
Analyzer set by schema for text types to use when indexing fields
of this type, subclasses can set analyzer themselves or override
getAnalyzer()
- ANALYZER - Static variable in class org.apache.solr.schema.FieldType
-
- analyzer - Variable in class org.apache.solr.spelling.QueryConverter
-
- analyzer - Variable in class org.apache.solr.spelling.SolrSpellChecker
-
- 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
-
- AnalyzingInfixLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.AnalyzingInfixLookupFactory
-
- AnalyzingLookupFactory - Class in org.apache.solr.spelling.suggest.fst
-
- AnalyzingLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.AnalyzingLookupFactory
-
- 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
- andNot(DocSet) - Method in class org.apache.solr.search.BitDocSet
-
- andNot(DocSet) - Method in interface 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.HashDocSet
-
- 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(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 interface org.apache.solr.search.DocSet
-
Returns the number of documents in this set that are not in the other set.
- answer - Variable in class org.apache.solr.search.SolrIndexSearcher.ProcessedFilter
-
- append(CharBuffer) - Method in class org.apache.solr.internal.csv.CharBuffer
-
Appends the contents of cb
to the end of this CharBuffer.
- 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
-
Appends sb
to the end of this CharBuffer.
- append(char[]) - Method in class org.apache.solr.internal.csv.CharBuffer
-
Appends data
to the end of this CharBuffer.
- append(char) - Method in class org.apache.solr.internal.csv.CharBuffer
-
Appends a single character to the end of this CharBuffer.
- append(LoggingEvent) - Method in class org.apache.solr.logging.log4j.EventAppender
-
- append(char) - Method in class org.apache.solr.util.FastWriter
-
- appendParam(String, String) - Static method in class org.apache.solr.util.SimplePostTool
-
Appends a URL query parameter to a URL
- appends - Variable in class org.apache.solr.handler.RequestHandlerBase
-
- appendThread(StringBuilder, LogRecord) - Method in class org.apache.solr.SolrLogFormatter
-
- appendThread(StringBuilder, LoggingEvent) - Method in class org.apache.solr.util.SolrLogLayout
-
- appendUrlPath(URL, String) - Static method in class org.apache.solr.util.SimplePostTool
-
Appends to the path of the URL
- applyBufferedUpdates() - Method in class org.apache.solr.update.UpdateLog
-
Returns the Future to wait on, or null if no replay was needed
- 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
-
- 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.RTimer
-
- Assign - Class in org.apache.solr.cloud
-
- Assign() - Constructor for class org.apache.solr.cloud.Assign
-
- assignNode(String, ClusterState) - Static method in class org.apache.solr.cloud.Assign
-
- assignShard(String, ClusterState, Integer) - Static method in class org.apache.solr.cloud.Assign
-
Assign a new unique id up to slices count - then add replicas evenly.
- asURIResolver() - Method in class org.apache.solr.util.SystemIdResolver
-
- asXMLResolver() - Method in class org.apache.solr.util.SystemIdResolver
-
- attributes - Variable in class org.apache.solr.core.PluginInfo
-
- autoCommmitMaxDocs - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
-
- autoCommmitMaxTime - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
-
- 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
-
- Cache - Interface in org.apache.solr.store.blockcache
-
- 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
-
- CachedIndexOutput - Class in org.apache.solr.store.blockcache
-
- CachedIndexOutput(BlockDirectory, IndexOutput, int, String, Cache, int) - Constructor for class org.apache.solr.store.blockcache.CachedIndexOutput
-
- cacheDocSet(Query, DocSet, boolean) - Method in class org.apache.solr.search.SolrIndexSearcher
-
Compute and cache the DocSet that matches a query.
- 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.
- CachingDirectoryFactory - Class in org.apache.solr.core
-
- CachingDirectoryFactory() - Constructor for class org.apache.solr.core.CachingDirectoryFactory
-
- CachingDirectoryFactory.CacheValue - Class in org.apache.solr.core
-
- CachingDirectoryFactory.CacheValue(String, Directory) - Constructor for class org.apache.solr.core.CachingDirectoryFactory.CacheValue
-
- CachingDirectoryFactory.CloseListener - Interface in org.apache.solr.core
-
- cal - Variable in class org.apache.solr.response.TextResponseWriter
-
- 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.
- CALENDAR_UNITS - Static variable in class org.apache.solr.util.DateMathParser
-
A mapping from (uppercased) String labels idenyifying time units,
to the corresponding Calendar constant used to set/add/roll that unit
of measurement.
- call(Diagnostics.Callable, Object...) - Static method in class org.apache.solr.core.Diagnostics
-
- call(Object...) - Method in interface org.apache.solr.core.Diagnostics.Callable
-
- 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
-
- cancelAll() - Method in class org.apache.solr.handler.component.HttpShardHandler
-
- cancelAll() - Method in class org.apache.solr.handler.component.ShardHandler
-
- cancelApplyBufferedUpdates() - Method in class org.apache.solr.update.UpdateLog
-
- cancelApplyBufferUpdate - Variable in class org.apache.solr.update.UpdateLog
-
- cancelCoreRecoveries() - Method in class org.apache.solr.core.CoreContainer
-
- cancelElection() - Method in class org.apache.solr.cloud.ElectionContext
-
- 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
-
- CANONICAL_LOCALE - Static variable in class org.apache.solr.schema.DateField
-
Deprecated.
Fixed Locale needed for parsing/formating Milliseconds in the
canonical representation.
- CANONICAL_TZ - Static variable in class org.apache.solr.schema.DateField
-
Deprecated.
Fixed TimeZone (UTC) needed for parsing/formating Dates in the
canonical representation.
- 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.
- cfg - Variable in class org.apache.solr.core.CoreContainer
-
- 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.
- charStream(Reader) - Method in class org.apache.solr.analysis.SolrAnalyzer
-
Deprecated.
- CharStream - Interface in org.apache.solr.parser
-
This interface describes a character stream that maintains line and
column number positions of the characters.
- 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).
- checkDistributed(ResponseBuilder) - Method in class org.apache.solr.handler.component.HttpShardHandler
-
- checkDistributed(ResponseBuilder) - Method in class org.apache.solr.handler.component.ShardHandler
-
- checker - Variable in class org.apache.solr.search.SolrFieldCacheMBean
-
- 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(QParser) - 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.
- 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.
- checkIfIamLeaderFired() - Method in class org.apache.solr.cloud.ElectionContext
-
- checkLastModValidators(HttpServletRequest, HttpServletResponse, long) - Static method in class org.apache.solr.servlet.cache.HttpCacheHeaderUtil
-
Check for modify time related conditional headers and set status
- checkPropertyIsNotEmpty(String, String) - Static method in class org.apache.solr.core.CoreDescriptor
-
- checkRetry() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
-
- checkRetry() - Method in class org.apache.solr.update.SolrCmdDistributor.RetryNode
-
- checkRetry() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
-
- checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.CollationField
-
- checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.CurrencyField
-
- checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.EnumField
-
Check's
SchemaField
instances constructed
using this field type to ensure that they are valid.
- 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.
- checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.StrField
-
- checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.TrieDateField
-
- checkSchemaField(SchemaField) - Method in class org.apache.solr.schema.TrieField
-
- 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.
- CHECKSUM - Static variable in class org.apache.solr.handler.ReplicationHandler
-
- childNodesToList(Node) - Static method in class org.apache.solr.util.DOMUtil
-
- childNodesToNamedList(Node) - Static method in class org.apache.solr.util.DOMUtil
-
- children - Variable in class org.apache.solr.core.PluginInfo
-
- children - Variable in class org.apache.solr.util.RTimer
-
- CircularList<T> - Class in org.apache.solr.logging
-
FIFO Circular List.
- CircularList(int) - Constructor for class org.apache.solr.logging.CircularList
-
- CLASS_NAME - Static variable in class org.apache.solr.schema.FieldType
-
- CLASS_NAME - Static variable in class org.apache.solr.schema.SimilarityFactory
-
- classAliases - Variable in class org.apache.solr.SolrLogFormatter
-
- classAliases - Variable in class org.apache.solr.util.SolrLogLayout
-
- ClassicIndexSchemaFactory - Class in org.apache.solr.schema
-
- ClassicIndexSchemaFactory() - Constructor for class org.apache.solr.schema.ClassicIndexSchemaFactory
-
- 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.SolrConfig.UpdateHandlerInfo
-
- className - Variable in class org.apache.solr.SolrLogFormatter.Method
-
- className - Variable in class org.apache.solr.util.SolrLogLayout.Method
-
- Clause(String) - Method in class org.apache.solr.parser.QueryParser
-
- clear() - Method in class org.apache.solr.core.JmxMonitoredMap
-
Clears the map and unregisters all SolrInfoMBeans in the map from
MBeanServer
- clear() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
-
- clear() - Method in class org.apache.solr.internal.csv.CharBuffer
-
Empties the buffer.
- clear() - Method in class org.apache.solr.logging.CircularList
-
- clear() - Method in class org.apache.solr.search.FastLRUCache
-
- clear() - Method in class org.apache.solr.search.LFUCache
-
- clear() - Method in class org.apache.solr.search.LRUCache
-
- clear() - Method in interface org.apache.solr.search.SolrCache
-
:TODO: copy from Map
- clear(int) - Method in class org.apache.solr.store.blockcache.BlockLocks
-
- 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.ConcurrentLFUCache
-
- clear() - Method in class org.apache.solr.util.ConcurrentLRUCache
-
- clear() - Method in class org.apache.solr.util.LongPriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in class org.apache.solr.util.stats.ExponentiallyDecayingSample
-
- clear() - Method in class org.apache.solr.util.stats.Histogram
-
Clears all recorded values.
- clear() - Method in interface org.apache.solr.util.stats.Sample
-
Clears all recorded values.
- clear() - Method in class org.apache.solr.util.stats.Timer
-
Clears all recorded durations.
- clear() - Method in class org.apache.solr.util.stats.UniformSample
-
- CLEAR_CACHES - Static variable in class org.apache.solr.update.UpdateCommand
-
- clearErrors() - Method in class org.apache.solr.update.StreamingSolrServers
-
- clearFlags(int) - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- clearIndex() - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- clearLock(String) - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- clearLock(String) - Method in class org.apache.solr.store.hdfs.HdfsLockFactory
-
- clearLog(SolrCore, PluginInfo) - Method in class org.apache.solr.update.HdfsUpdateLog
-
Clears the logs on the file system.
- clearLog(SolrCore, PluginInfo) - Method in class org.apache.solr.update.UpdateLog
-
Clears the logs on the file system.
- clearRequestInfo() - Static method in class org.apache.solr.request.SolrRequestInfo
-
- Clock - Class in org.apache.solr.util.stats
-
An abstraction for how time passes.
- Clock() - Constructor for class org.apache.solr.util.stats.Clock
-
- Clock.CpuTimeClock - Class in org.apache.solr.util.stats
-
A clock implementation which returns the current thread's CPU time.
- Clock.CpuTimeClock() - Constructor for class org.apache.solr.util.stats.Clock.CpuTimeClock
-
- Clock.UserTimeClock - Class in org.apache.solr.util.stats
-
A clock implementation which returns the current time in epoch nanoseconds.
- Clock.UserTimeClock() - Constructor for class org.apache.solr.util.stats.Clock.UserTimeClock
-
- clone() - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
-
- clone() - Method in class org.apache.solr.internal.csv.CSVStrategy
-
- clone() - Method in class org.apache.solr.search.BitDocSet
-
- clone() - Method in class org.apache.solr.search.DocSlice
-
- clone() - Method in class org.apache.solr.search.HashDocSet
-
- clone() - Method in class org.apache.solr.search.SortedIntDocSet
-
- clone() - Method in class org.apache.solr.search.WrappedQuery
-
- clone() - Method in class org.apache.solr.store.blockcache.BlockCacheKey
-
- clone() - Method in class org.apache.solr.store.blockcache.CustomBufferedIndexInput
-
- clone() - Method in class org.apache.solr.store.blockcache.ReusedBufferedIndexOutput
-
- clone() - Method in class org.apache.solr.store.hdfs.HdfsFileReader
-
- clone() - Method in class org.apache.solr.update.UpdateCommand
-
- CloneFieldUpdateProcessorFactory - Class in org.apache.solr.update.processor
-
Clones the values found in any matching source
field into
the configured dest
field.
- CloneFieldUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.CloneFieldUpdateProcessorFactory
-
- 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.OverseerCollectionProcessor
-
- 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.core.CachingDirectoryFactory
-
- close() - Method in class org.apache.solr.core.DirectoryFactory
-
Close the this and all of the Directories it contains.
- 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.SolrResourceLoader
-
- close() - Method in class org.apache.solr.core.ZkContainer
-
- 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.logging.jul.RecordHandler
-
- close() - Method in class org.apache.solr.logging.log4j.EventAppender
-
- 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.TextResponseWriter
-
done with this ResponseWriter...
- close() - Method in class org.apache.solr.search.FastLRUCache
-
- close() - Method in class org.apache.solr.search.LFUCache
-
- close() - Method in class org.apache.solr.search.LRUCache
-
- 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.servlet.DirectSolrConnection
-
Use this method to close the underlying SolrCore.
- close() - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- close() - Method in class org.apache.solr.store.blockcache.CustomBufferedIndexInput
-
- close() - Method in class org.apache.solr.store.blockcache.ReusedBufferedIndexOutput
-
- close() - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- close() - Method in class org.apache.solr.store.hdfs.HdfsFileReader
-
- close() - Method in class org.apache.solr.store.hdfs.HdfsFileWriter
-
- close() - Method in class org.apache.solr.store.hdfs.NullIndexOutput
-
- close() - Method in class org.apache.solr.update.CommitTracker
-
- close(SolrCoreState.IndexWriterCloser) - Method in class org.apache.solr.update.DefaultSolrCoreState
-
- close() - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- close() - Method in class org.apache.solr.update.HdfsTransactionLog
-
- close() - Method in class org.apache.solr.update.HdfsTransactionLog.HDFSLogReader
-
- close() - Method in class org.apache.solr.update.HdfsTransactionLog.HDFSReverseReader
-
- close(boolean) - Method in class org.apache.solr.update.HdfsUpdateLog
-
- close() - Method in class org.apache.solr.update.LoggingInfoStream
-
- close(SolrCoreState.IndexWriterCloser) - Method in class org.apache.solr.update.SolrCoreState
-
- close() - Method in class org.apache.solr.update.SolrIndexWriter
-
- 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.UpdateHandler
-
- close(boolean) - Method in class org.apache.solr.update.UpdateLog
-
- close(boolean, boolean) - Method in class org.apache.solr.update.UpdateLog
-
- 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.FastWriter
-
- 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
-
- closeCacheValueCalled - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
-
- closed - Variable in class org.apache.solr.update.SolrCoreState
-
- closeEntries - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
-
- CloseHook - Class in org.apache.solr.core
-
Used to request notification when the core is closed.
- CloseHook() - Constructor for class org.apache.solr.core.CloseHook
-
- closeHooks - Variable in class org.apache.solr.request.SolrRequestInfo
-
- closeIndexWriter(SolrCore, boolean) - Method in class org.apache.solr.update.DefaultSolrCoreState
-
- closeIndexWriter(SolrCore, boolean) - Method in class org.apache.solr.update.SolrCoreState
-
- closeInternal() - Method in class org.apache.solr.store.blockcache.CachedIndexOutput
-
- closeInternal() - Method in class org.apache.solr.store.blockcache.CustomBufferedIndexInput
-
- closeInternal() - Method in class org.apache.solr.store.blockcache.ReusedBufferedIndexOutput
-
- closeListeners - Variable in class org.apache.solr.core.CachingDirectoryFactory
-
- closeQuietly(Closeable) - Static method in class org.apache.solr.util.IOUtils
-
- closeSearcher() - Method in class org.apache.solr.core.SolrCore
-
- closeWriter(IndexWriter) - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- closeWriter(IndexWriter) - Method in interface org.apache.solr.update.SolrCoreState.IndexWriterCloser
-
- CloudDescriptor - Class in org.apache.solr.cloud
-
- CloudDescriptor(String, Properties, CoreDescriptor) - Constructor for class org.apache.solr.cloud.CloudDescriptor
-
- cloudParamToProp - Static variable in class org.apache.solr.handler.admin.CoreAdminHandler
-
- CMD_ABORT_FETCH - Static variable in class org.apache.solr.handler.ReplicationHandler
-
- CMD_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_SHOW_COMMITS - Static variable in class org.apache.solr.handler.ReplicationHandler
-
- cmdString - Variable in class org.apache.solr.update.SolrCmdDistributor.Req
-
- CodecFactory - Class in org.apache.solr.core
-
Factory for plugging in a custom
Codec
- CodecFactory() - Constructor for class org.apache.solr.core.CodecFactory
-
- COLL_CONF - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- COLL_PROP_PREFIX - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- COLL_PROPS - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- 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
-
- CollapseScoreFunction.CollapseScoreFunctionValues(Map) - Constructor for class org.apache.solr.search.function.CollapseScoreFunction.CollapseScoreFunctionValues
-
- 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.CollapseScore() - Constructor for class org.apache.solr.search.CollapsingQParserPlugin.CollapseScore
-
- CollapsingQParserPlugin.CollapsingPostFilter - Class in org.apache.solr.search
-
- CollapsingQParserPlugin.CollapsingPostFilter(SolrParams, SolrParams, SolrQueryRequest) - Constructor for class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
-
- 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
-
- 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.DocSetDelegateCollector
-
- collect(int) - Method in class org.apache.solr.search.EarlyTerminatingCollector
-
- collect(int) - Method in class org.apache.solr.search.grouping.collector.FilterCollector
-
- COLLECTION_PARAM_PREFIX - Static variable in class org.apache.solr.cloud.ZkController
-
- 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.
- COLON - Static variable in interface org.apache.solr.parser.QueryParserConstants
-
RegularExpression Id.
- COMMAND - Static variable in class org.apache.solr.handler.ReplicationHandler
-
- Command<T> - Interface in org.apache.solr.search.grouping
-
Defines a grouping command.
- 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
-
- CommandHandler.Builder() - Constructor for class org.apache.solr.search.grouping.CommandHandler.Builder
-
- COMMENTS_DISABLED - Static variable in class org.apache.solr.internal.csv.CSVStrategy
-
- COMMIT - Static variable in class org.apache.solr.handler.UpdateRequestHandler
-
- 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.update.UpdateLog
-
- commit() - Method in class org.apache.solr.util.SimplePostTool
-
Does a simple commit operation
- 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
-
- commitCallbacks - Variable in class org.apache.solr.update.UpdateHandler
-
- commitIntervalLowerBound - Variable in class org.apache.solr.core.SolrConfig.UpdateHandlerInfo
-
- commitLock - Variable in class org.apache.solr.update.DefaultSolrCoreState
-
- commitOnClose - Static 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, boolean, boolean) - Constructor for class org.apache.solr.update.CommitTracker
-
- commitTracker - Variable in class org.apache.solr.update.DirectUpdateHandler2
-
- CommitUpdateCommand - Class in org.apache.solr.update
-
- 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
-
- COMPARATOR_CLASS - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
-
- COMPARATOR_CLASS - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
-
- compare(int, int) - Method in class org.apache.solr.util.PrimUtils.IntComparator
-
- compareTo(LoggerInfo) - Method in class org.apache.solr.logging.LoggerInfo
-
- compareTo(SimpleFacets.CountPair<K, V>) - Method in class org.apache.solr.request.SimpleFacets.CountPair
-
- 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
-
- complainAboutUnknownAttributes(String, String...) - Method in class org.apache.solr.core.Config
-
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.
- COMPONENT_NAME - Static variable in class org.apache.solr.handler.component.DebugComponent
-
- 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.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
-
- components - Variable in class org.apache.solr.handler.component.ResponseBuilder
-
- components - Variable in class org.apache.solr.handler.component.SearchHandler
-
- COMPRESSION - Static variable in class org.apache.solr.handler.ReplicationHandler
-
- computeFullUrl(URL, String) - Method in class org.apache.solr.util.SimplePostTool
-
Computes the full URL based on a base url and a possibly relative link found
in the href param of an HTML anchor.
- 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
-
- ConcurrentLFUCache<K,V> - Class in org.apache.solr.util
-
A LFU cache implementation based upon ConcurrentHashMap.
- ConcurrentLFUCache(int, int, int, int, boolean, boolean, ConcurrentLFUCache.EvictionListener<K, V>, boolean) - Constructor for class org.apache.solr.util.ConcurrentLFUCache
-
- ConcurrentLFUCache(int, int) - Constructor for class org.apache.solr.util.ConcurrentLFUCache
-
- ConcurrentLFUCache.EvictionListener<K,V> - Interface in org.apache.solr.util
-
- ConcurrentLFUCache.Stats - Class in org.apache.solr.util
-
- ConcurrentLFUCache.Stats() - Constructor for class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- 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, int, int, boolean, boolean, ConcurrentLRUCache.EvictionListener<K, V>) - Constructor for class org.apache.solr.util.ConcurrentLRUCache
-
- ConcurrentLRUCache(int, int) - Constructor for class org.apache.solr.util.ConcurrentLRUCache
-
- ConcurrentLRUCache.EvictionListener<K,V> - Interface in org.apache.solr.util
-
- ConcurrentLRUCache.Stats - Class in org.apache.solr.util
-
- ConcurrentLRUCache.Stats() - Constructor for class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- 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
-
- Config - Class in org.apache.solr.core
-
- Config(SolrResourceLoader, String) - Constructor for class org.apache.solr.core.Config
-
Builds a config from a resource name with no xpath prefix.
- Config(SolrResourceLoader, String, InputSource, String) - Constructor for class org.apache.solr.core.Config
-
- Config(SolrResourceLoader, String, InputSource, String, boolean) - Constructor for class org.apache.solr.core.Config
-
Builds a config:
- Config(SolrResourceLoader, String, Document) - Constructor for class org.apache.solr.core.Config
-
- config - Variable in class org.apache.solr.core.ConfigSolr
-
- config - Variable in class org.apache.solr.internal.csv.writer.CSVConfigGuesser
-
The found config
- CONFIG_DIRECTORY - Static variable in class org.apache.solr.core.HdfsDirectoryFactory
-
- configFileExists(String, String) - Method in class org.apache.solr.cloud.ZkController
-
Returns true if config file exists
- CONFIGNAME_PROP - Static variable in class org.apache.solr.cloud.ZkController
-
- CONFIGS_ZKNODE - Static variable in class org.apache.solr.cloud.ZkController
-
- ConfigSolr - Class in org.apache.solr.core
-
- ConfigSolr(Config) - Constructor for class org.apache.solr.core.ConfigSolr
-
- ConfigSolr() - Constructor for class org.apache.solr.core.ConfigSolr
-
- ConfigSolr.CfgProp - Enum in org.apache.solr.core
-
- ConfigSolrXml - Class in org.apache.solr.core
-
- ConfigSolrXml(Config) - Constructor for class org.apache.solr.core.ConfigSolrXml
-
- ConfigSolrXmlOld - Class in org.apache.solr.core
-
- ConfigSolrXmlOld(Config, String) - Constructor for class org.apache.solr.core.ConfigSolrXmlOld
-
- configuration - Variable in class org.apache.solr.store.hdfs.HdfsDirectory
-
- configureSAXParserFactory(SAXParserFactory) - Static method in class org.apache.solr.util.EmptyEntityResolver
-
Configures the given
SAXParserFactory
to do secure XML processing of untrusted sources.
- configureXMLInputFactory(XMLInputFactory) - Static method in class org.apache.solr.util.EmptyEntityResolver
-
- 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
-
- 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
-
- consumeArgumentDelimiter() - Method in class org.apache.solr.search.FunctionQParser
-
Consume an argument delimiter (a comma) from the token stream.
- containerProperties - Variable in class org.apache.solr.core.CoreContainer
-
- 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_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
-
- ContentStreamLoader() - Constructor for class org.apache.solr.handler.ContentStreamLoader
-
- ContentStreamLoader - Class in org.apache.solr.handler.loader
-
Load a
ContentStream
into Solr
This should be thread safe and can be called from multiple threads
- ContentStreamLoader() - Constructor for class org.apache.solr.handler.loader.ContentStreamLoader
-
- context - Variable in class org.apache.solr.request.SolrQueryRequestBase
-
- context - Variable in class org.apache.solr.response.transform.TransformerWithContext
-
- context - Variable in class org.apache.solr.search.DelegatingCollector
-
- CONTEXT_TRANSFORMER_KEY - Static variable in class org.apache.solr.handler.loader.XMLLoader
-
- CONTEXT_TRANSFORMER_KEY - Static variable in class org.apache.solr.response.XSLTResponseWriter
-
- convert(String) - Method in class org.apache.solr.spelling.QueryConverter
-
Returns the Collection of
Token
s 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
-
- CoordinateFieldType - Class in org.apache.solr.schema
-
A CoordinateFieldType is the base class for
FieldType
s that have semantics
related to items in a coordinate system.
- CoordinateFieldType() - Constructor for class org.apache.solr.schema.CoordinateFieldType
-
- copy(Directory, String, String, IOContext) - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- COPY_FIELD - Static variable in class org.apache.solr.schema.IndexSchema
-
- COPY_FIELDS - Static variable in class org.apache.solr.rest.SolrRestApi
-
- COPY_FIELDS - Static variable in class org.apache.solr.schema.IndexSchema
-
- COPY_FIELDS_PATH - Static variable in class org.apache.solr.rest.SolrRestApi
-
- 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
-
- CopyFieldCollectionResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/copyfields
To restrict the set of copyFields in the response, specify one or both
of the following as query parameters, with values as space and/or comma
separated dynamic or explicit field names:
dest.fl: include copyFields that have one of these as a destination
source.fl: include copyFields that have one of these as a source
If both dest.fl and source.fl are given as query parameters, the copyfields
in the response will be restricted to those that match any of the destinations
in dest.fl and also match any of the sources in source.fl.
- CopyFieldCollectionResource() - Constructor for class org.apache.solr.rest.schema.CopyFieldCollectionResource
-
- 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
-
- copyTo(AttributeImpl) - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
-
- core - Variable in class org.apache.solr.core.RequestHandlers
-
- 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.spelling.suggest.Suggester
-
- core - Variable in class org.apache.solr.update.UpdateHandler
-
- CORE_ABS_INSTDIR - Static variable in class org.apache.solr.core.CoreDescriptor
-
- CORE_COLLECTION - Static variable in class org.apache.solr.core.CoreDescriptor
-
- CORE_CONFIG - Static variable in class org.apache.solr.core.CoreDescriptor
-
- CORE_DATADIR - Static variable in class org.apache.solr.core.CoreDescriptor
-
- CORE_INSTDIR - Static variable in class org.apache.solr.core.CoreDescriptor
-
- 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_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
-
- 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.
- coreContainer - Variable in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
-
- CoreContainer - Class in org.apache.solr.core
-
- CoreContainer() - Constructor for class org.apache.solr.core.CoreContainer
-
Create a new CoreContainer using system properties to detect the solr home
directory.
- CoreContainer(SolrResourceLoader) - Constructor for class org.apache.solr.core.CoreContainer
-
Create a new CoreContainer using the given SolrResourceLoader.
- CoreContainer(String) - Constructor for class org.apache.solr.core.CoreContainer
-
Create a new CoreContainer using the given solr home directory.
- CoreContainer(SolrResourceLoader, ConfigSolr) - Constructor for class org.apache.solr.core.CoreContainer
-
Create a new CoreContainer using the given SolrResourceLoader,
configuration and CoresLocator.
- CoreContainer(SolrResourceLoader, ConfigSolr, CoresLocator) - Constructor for class org.apache.solr.core.CoreContainer
-
- coreContainer - Variable in class org.apache.solr.handler.admin.CollectionsHandler
-
- coreContainer - Variable in class org.apache.solr.handler.admin.CoreAdminHandler
-
- coreContainer - Variable in class org.apache.solr.handler.admin.InfoHandler
-
- CoreDescriptor - Class in org.apache.solr.core
-
A Solr core descriptor
- CoreDescriptor(CoreContainer, String, String, Properties) - Constructor for class org.apache.solr.core.CoreDescriptor
-
Create a new CoreDescriptor.
- CoreDescriptor(CoreContainer, String, String, Properties, SolrParams) - Constructor for class org.apache.solr.core.CoreDescriptor
-
Create a new CoreDescriptor.
- CoreDescriptor(CoreContainer, String, String) - Constructor for class org.apache.solr.core.CoreDescriptor
-
Create a new CoreDescriptor with a given name and instancedir
- 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
-
- coreName - Variable in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
-
- 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(String) - Constructor for class org.apache.solr.core.CorePropertiesLocator
-
- cores - Variable in class org.apache.solr.servlet.SolrDispatchFilter
-
- 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
- corrections - Variable in class org.apache.solr.spelling.PossibilityIterator.RankedSpellPossibility
-
- cost() - Method in class org.apache.solr.search.SolrConstantScoreQuery.ConstantScorer
-
- 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.
- counted - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
-
- CountFieldValuesUpdateProcessorFactory - Class in org.apache.solr.update.processor
-
Replaces any list of values for a field matching the specified
conditions with the the count of the number of values for that field.
- CountFieldValuesUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.CountFieldValuesUpdateProcessorFactory
-
- counts - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
-
- countSorted - Variable in class org.apache.solr.handler.component.FacetComponent.DistribFieldFacet
-
- create(Reader) - Method in class org.apache.solr.analysis.LegacyHTMLStripCharFilterFactory
-
Deprecated.
- create(TokenStream) - Method in class org.apache.solr.analysis.ReversedWildcardFilterFactory
-
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.CachingDirectoryFactory
-
- create(CoreDescriptor) - Method in class org.apache.solr.core.CoreContainer
-
Creates a new core based on a descriptor but does not register it.
- 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(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.DirectoryFactory
-
Creates a new Directory for a given path.
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.HdfsDirectoryFactory
-
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.MMapDirectoryFactory
-
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.NIOFSDirectoryFactory
-
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.NRTCachingDirectoryFactory
-
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.RAMDirectoryFactory
-
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.SimpleFSDirectoryFactory
-
- create(CoreContainer, CoreDescriptor...) - Method in class org.apache.solr.core.SolrXMLCoresLocator
-
- create(String, DirectoryFactory.DirContext) - Method in class org.apache.solr.core.StandardDirectoryFactory
-
- 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.ShardAugmenterFactory
-
- 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(SolrResourceLoader, String, String, Node) - Method in class org.apache.solr.schema.FieldTypePluginLoader
-
- create(String, SolrConfig) - Method in class org.apache.solr.schema.IndexSchemaFactory
-
Returns an index schema created from a local resource
- create(String, SolrConfig) - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
-
First, try to locate the managed schema file named in the managedSchemaResourceName
param.
- 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(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(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(SolrCore, SolrIndexSearcher) - Method in class org.apache.solr.spelling.suggest.HighFrequencyDictionaryFactory
-
- 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(String, String, DirectoryFactory, boolean, IndexSchema, SolrIndexConfig, IndexDeletionPolicy, Codec) - Static method in class org.apache.solr.update.SolrIndexWriter
-
- create(SolrResourceLoader, String, String, Node) - Method in class org.apache.solr.util.plugin.AbstractPluginLoader
-
Create a plugin from an XML configuration.
- CREATE_NODE_SET - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- CREATEALIAS - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- 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
-
Returns a collector that is able to return the most relevant document of all groups.
- createAllGroupCollector() - Method in class org.apache.solr.search.Grouping.CommandFunc
-
- createAndLoad(String, File) - Static method in class org.apache.solr.core.CoreContainer
-
Create a new CoreContainer and load its cores
- 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
-
- CREATECOLLECTION - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- createCollection(String) - Method in class org.apache.solr.cloud.ZkController
-
- createCollectionZkNode(CloudDescriptor) - Method in class org.apache.solr.cloud.ZkController
-
- createComponents(String, Reader) - Method in class org.apache.solr.analysis.TokenizerChain
-
- createComponents(String, Reader) - Method in class org.apache.solr.schema.FieldType.DefaultAnalyzer
-
- createConfiguration(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.ExtendedDismaxQParser
-
Creates an instance of ExtendedDismaxConfiguration.
- createCoreContainer() - Method in class org.apache.solr.servlet.SolrDispatchFilter
-
Override this to change CoreContainer initialization
- createDefaultLoaders(NamedList) - Method in class org.apache.solr.handler.UpdateRequestHandler
-
- 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.
- createEventListener(String) - Method in class org.apache.solr.core.SolrCore
-
- createField(SchemaField, Object, float) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
-
- createField(SchemaField, Object, float) - Method in class org.apache.solr.schema.BinaryField
-
- createField(SchemaField, Object, float) - Method in class org.apache.solr.schema.DateField
-
Deprecated.
- createField(SchemaField, Object, float) - Method in class org.apache.solr.schema.EnumField
-
Used for adding a document when a field needs to be created from a
type and a string.
- createField(SchemaField, Object, float) - 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(String, String, FieldType, float) - Method in class org.apache.solr.schema.FieldType
-
Create the field from native Lucene parts.
- createField(SchemaField, Object, float) - Method in class org.apache.solr.schema.LatLonType
-
- createField(SchemaField, Object, float) - 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, float) - Method in class org.apache.solr.schema.PreAnalyzedField
-
- createField(Object, float) - Method in class org.apache.solr.schema.SchemaField
-
- createField(SchemaField, Object, float) - Method in class org.apache.solr.schema.TrieDateField
-
- createField(SchemaField, Object, float) - Method in class org.apache.solr.schema.TrieField
-
- 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.
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.CollationField
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.CurrencyField
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.FieldType
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.LatLonType
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.PointType
-
- createFields(Object, float) - Method in class org.apache.solr.schema.SchemaField
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.StrField
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.TrieDateField
-
- createFields(SchemaField, Object, float) - Method in class org.apache.solr.schema.TrieField
-
- createFieldType(SchemaField) - Static method in class org.apache.solr.schema.PreAnalyzedField
-
- 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
-
Returns one or more
Collector
instances that are needed to perform the first pass search.
- createFirstPassCollector() - Method in class org.apache.solr.search.Grouping.CommandFunc
-
Returns one or more
Collector
instances that are needed to perform the first pass search.
- createFirstPassCollector() - Method in class org.apache.solr.search.Grouping.CommandQuery
-
Returns one or more
Collector
instances that are needed to perform the first pass search.
- createHandler(String, Class<T>) - Method in class org.apache.solr.core.CoreContainer
-
- createInboundRoot() - Method in class org.apache.solr.rest.SolrRestApi
-
Bind URL paths to the appropriate ServerResource subclass.
- createInitInstance(PluginInfo, Class<T>, String, String) - Method in class org.apache.solr.core.SolrCore
-
- createLoadbalancer(HttpClient) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
-
- createMainIndexWriter(SolrCore, String) - Method in class org.apache.solr.update.DefaultSolrCoreState
-
- createName(Properties, File) - Static method in class org.apache.solr.core.CorePropertiesLocator
-
- 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.
- createOutput(String, IOContext) - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- createOutput(String, IOContext) - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- 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.DisMaxQParserPlugin
-
- 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.join.BlockJoinParentQParserPlugin
-
- 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.NestedQParserPlugin
-
- createParser(String, SolrParams, SolrParams, SolrQueryRequest) - Method in class org.apache.solr.search.OldLuceneQParserPlugin
-
- 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
-
- 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.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
-
- 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.
- createQuery(Query, Query) - Method in class org.apache.solr.search.join.BlockJoinChildQParser
-
- createRequestHandler(String) - Method in class org.apache.solr.core.SolrCore
-
- createSchemaWatcher() - Method in class org.apache.solr.schema.ZkIndexSchemaReader
-
- 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
-
Returns zero or more
Collector
instances that are needed to perform the second pass search.
- createSecondPassCollector() - Method in class org.apache.solr.search.Grouping.CommandFunc
-
Returns zero or more
Collector
instances that are needed to perform the second pass search.
- CREATESHARD - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- createSimpleResponse() - Method in class org.apache.solr.search.Grouping.Command
-
- 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.GeoHashField
-
- createSpatialQuery(QParser, SpatialOptions) - Method in class org.apache.solr.schema.LatLonType
-
- 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
-
- createStatsValues(SchemaField, boolean) - Static method in class org.apache.solr.handler.component.StatsValuesFactory
-
Creates an instance of StatsValues which supports values from a field of the given FieldType
- 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
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.solr.search.function.distance.HaversineConstFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.solr.search.function.distance.HaversineFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.solr.search.function.distance.VectorDistanceFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
-
- createWeight(IndexSearcher) - Method in class org.apache.solr.search.join.IgnoreAcceptDocsQuery
-
- createWeight(IndexSearcher) - Method in class org.apache.solr.search.SolrConstantScoreQuery
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.solr.search.SolrFilter
-
Implementations should propagate createWeight to sub-ValueSources which can store weight info in the context.
- createWeight(IndexSearcher) - Method in class org.apache.solr.search.WrappedQuery
-
- CSVConfig - Class in org.apache.solr.internal.csv.writer
-
The CSVConfig is used to configure the CSV writer
- CSVConfig() - Constructor for class org.apache.solr.internal.csv.writer.CSVConfig
-
- CSVConfigGuesser - Class in org.apache.solr.internal.csv.writer
-
Tries to guess a config based on an InputStream.
- CSVConfigGuesser() - Constructor for class org.apache.solr.internal.csv.writer.CSVConfigGuesser
-
- CSVConfigGuesser(InputStream) - Constructor for class org.apache.solr.internal.csv.writer.CSVConfigGuesser
-
- CSVField - Class in org.apache.solr.internal.csv.writer
-
- CSVField() - Constructor for class org.apache.solr.internal.csv.writer.CSVField
-
- CSVField(String) - Constructor for class org.apache.solr.internal.csv.writer.CSVField
-
- CSVField(String, int) - Constructor for class org.apache.solr.internal.csv.writer.CSVField
-
- CSVLoader - Class in org.apache.solr.handler.loader
-
- CSVLoader() - Constructor for class org.apache.solr.handler.loader.CSVLoader
-
- 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
-
- CSVParser(Reader, char) - Constructor for class org.apache.solr.internal.csv.CSVParser
-
- CSVParser(Reader, char, char, char) - Constructor for class org.apache.solr.internal.csv.CSVParser
-
- CSVParser(Reader, CSVStrategy) - Constructor for class org.apache.solr.internal.csv.CSVParser
-
- 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.
- CSVRequestHandler - Class in org.apache.solr.handler
-
Deprecated.
- CSVRequestHandler() - Constructor for class org.apache.solr.handler.CSVRequestHandler
-
Deprecated.
- CSVResponseWriter - Class in org.apache.solr.response
-
- CSVResponseWriter() - Constructor for class org.apache.solr.response.CSVResponseWriter
-
- CSVStrategy - Class in org.apache.solr.internal.csv
-
CSVStrategy
Represents the strategy for a CSV.
- CSVStrategy(char, char, char) - Constructor for class org.apache.solr.internal.csv.CSVStrategy
-
- CSVStrategy(char, char, char, char, boolean, boolean, boolean, boolean) - Constructor for class org.apache.solr.internal.csv.CSVStrategy
-
Customized CSV strategy setter.
- CSVStrategy(char, char, char, boolean, boolean, boolean) - Constructor for class org.apache.solr.internal.csv.CSVStrategy
-
- 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.
- CSVWriter - Class in org.apache.solr.internal.csv.writer
-
CSVWriter
- CSVWriter() - Constructor for class org.apache.solr.internal.csv.writer.CSVWriter
-
- CSVWriter(CSVConfig) - Constructor for class org.apache.solr.internal.csv.writer.CSVWriter
-
- ctx - Variable in class org.apache.solr.schema.AbstractSpatialFieldType
-
- culmTime - Variable in class org.apache.solr.util.RTimer
-
- curChar - Variable in class org.apache.solr.parser.QueryParserTokenManager
-
- CurrencyField - Class in org.apache.solr.schema
-
Field type for support of monetary values.
- CurrencyField() - Constructor for class org.apache.solr.schema.CurrencyField
-
- CURRENT_VERSION - Static variable in class org.apache.solr.response.XMLWriter
-
- currentCapacity - Variable in class org.apache.solr.util.LongPriorityQueue
-
- CurrentCoreDescriptorProvider - Class in org.apache.solr.cloud
-
- CurrentCoreDescriptorProvider() - Constructor for class org.apache.solr.cloud.CurrentCoreDescriptorProvider
-
- currentToken - Variable in exception org.apache.solr.parser.ParseException
-
This is the last token that has been consumed successfully.
- 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
.
- CustomBufferedIndexInput - Class in org.apache.solr.store.blockcache
-
- CustomBufferedIndexInput(String) - Constructor for class org.apache.solr.store.blockcache.CustomBufferedIndexInput
-
- CustomBufferedIndexInput(String, int) - Constructor for class org.apache.solr.store.blockcache.CustomBufferedIndexInput
-
- customize(ScriptEngine) - Method in interface org.apache.solr.update.processor.ScriptEngineCustomizer
-
- customParams - Variable in class org.apache.solr.spelling.SpellingOptions
-
Any other custom params can be passed through.
- dataDir - Variable in class org.apache.solr.core.SolrConfig
-
- dataDir - Variable in class org.apache.solr.update.UpdateLog
-
- DATE_FMT - Static variable in class org.apache.solr.handler.SnapShooter
-
- dateFacets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
-
- DateField - Class in org.apache.solr.schema
-
- DateField() - Constructor for class org.apache.solr.schema.DateField
-
Deprecated.
- 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
-
Default constructor that assumes UTC should be used for rounding unless
otherwise specified in the SolrRequestInfo
- DateMathParser(TimeZone, Locale) - Constructor for class org.apache.solr.util.DateMathParser
-
- DateValueFieldType - Interface in org.apache.solr.schema
-
Marker interface for Date-valued field types.
- debug - Variable in class org.apache.solr.update.PeerSync
-
- debug - Variable in class org.apache.solr.update.UpdateLog
-
- DebugComponent - Class in org.apache.solr.handler.component
-
Adds debugging information to a request.
- DebugComponent() - Constructor for class org.apache.solr.handler.component.DebugComponent
-
- debugStream - Variable in class org.apache.solr.parser.QueryParserTokenManager
-
Debug output.
- decLevel() - Method in class org.apache.solr.response.TextResponseWriter
-
- 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
-
- DEF_SOLR_XML - Static variable in class org.apache.solr.core.ConfigSolrXmlOld
-
- 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_ACCURACY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
-
- DEFAULT_CONF_FILE - Static variable in class org.apache.solr.core.SolrConfig
-
- DEFAULT_CONTENT_TYPE - Static variable in class org.apache.solr.response.XSLTResponseWriter
-
- DEFAULT_CORE_ADMIN_PATH - Static variable in class org.apache.solr.core.ConfigSolr
-
- DEFAULT_CORE_NAME - Static variable in class org.apache.solr.core.SolrXMLCoresLocator
-
Core name to use if a core definition has no name
- DEFAULT_COUNT - Static variable in class org.apache.solr.handler.admin.LukeRequestHandler
-
- DEFAULT_DEFAULT_CORE_NAME - Static variable in class org.apache.solr.core.ConfigSolrXmlOld
-
- DEFAULT_DEFAULT_CURRENCY - Static variable in class org.apache.solr.schema.CurrencyField
-
- 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_EXTERNAL_PROPERTIES_FILE - Static variable in class org.apache.solr.core.CoreDescriptor
-
- DEFAULT_FIELD_VALUES_ARRAY_LEN - Static variable in class org.apache.solr.schema.AbstractSpatialPrefixTreeFieldType
-
- 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_HOST_CONTEXT - Static variable in class org.apache.solr.core.ZkContainer
-
Deprecated.
will be remove in Solr 5.0 (SOLR-4622)
- DEFAULT_HOST_PORT - Static variable in class org.apache.solr.core.ZkContainer
-
Deprecated.
will be remove in Solr 5.0 (SOLR-4622)
- DEFAULT_INDEX_BASED_DICT - Static variable in class org.apache.solr.spelling.suggest.DictionaryFactory
-
Default dictionary implementation to use for IndexBasedDictionaries
- DEFAULT_MANAGED_SCHEMA_RESOURCE_NAME - Static variable in class org.apache.solr.schema.ManagedIndexSchemaFactory
-
- DEFAULT_MATH_LOCALE - Static variable in class org.apache.solr.util.DateMathParser
-
Default Locale for DateMath rounding (Locale.ROOT)
- 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_MERGE_SIZE_MB - Static variable in class org.apache.solr.core.NRTCachingDirectoryFactory
-
- 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_MERGE_SCHEDULER_CLASSNAME - Static variable in class org.apache.solr.update.SolrIndexConfig
-
- 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.rest.SolrRestApi
-
- DEFAULT_OPERATOR - Static variable in class org.apache.solr.schema.IndexSchema
-
- DEFAULT_OPERATOR_PATH - Static variable in class org.apache.solr.rest.SolrRestApi
-
- 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
-
- DEFAULT_PRECISION_STEP - Static variable in class org.apache.solr.schema.EnumField
-
- DEFAULT_PRECISION_STEP - Static variable in class org.apache.solr.schema.TrieField
-
- DEFAULT_QTYPE - Static variable in class org.apache.solr.search.QParserPlugin
-
internal use - name of the default parser
- DEFAULT_RATE_PROVIDER_CLASS - Static variable in class org.apache.solr.schema.CurrencyField
-
- DEFAULT_READ_AHEAD - Static variable in class org.apache.solr.analysis.LegacyHTMLStripCharFilter
-
Deprecated.
- 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_SCHEMA_FILE - Static variable in class org.apache.solr.schema.IndexSchema
-
- DEFAULT_SEARCH_FIELD - Static variable in class org.apache.solr.rest.SolrRestApi
-
- DEFAULT_SEARCH_FIELD - Static variable in class org.apache.solr.schema.IndexSchema
-
- DEFAULT_SEARCH_FIELD_PATH - Static variable in class org.apache.solr.rest.SolrRestApi
-
- DEFAULT_SHARDHANDLER_INFO - Static variable in class org.apache.solr.handler.component.ShardHandlerFactory
-
- 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_THRESHOLD_TOKEN_FREQUENCY - Static variable in class org.apache.solr.spelling.DirectSolrSpellChecker
-
- DEFAULT_VALUE - Static variable in class org.apache.solr.schema.EnumField
-
- DEFAULT_ZK_TIMEOUT - Static variable in class org.apache.solr.handler.admin.CollectionsHandler
-
- defaultClient - Variable in class org.apache.solr.handler.component.HttpShardHandlerFactory
-
- defaultClock() - Static method in class org.apache.solr.util.stats.Clock
-
The default clock to use.
- DefaultEncoder - Class in org.apache.solr.highlight
-
- DefaultEncoder() - Constructor for class org.apache.solr.highlight.DefaultEncoder
-
- defaultFactories - Static variable in class org.apache.solr.response.transform.TransformerFactory
-
- defaultIndexConfig - Variable in class org.apache.solr.core.SolrConfig
-
Deprecated.
- 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.handler.RequestHandlerBase
-
- defaults - Variable in class org.apache.solr.highlight.HighlightingPluginBase
-
- DefaultSchemaResource - Class in org.apache.solr.rest.schema
-
This class is invoked when a request URL starts with /schema/
but then further path elements don't match any defined resources.
- DefaultSchemaResource() - Constructor for class org.apache.solr.rest.schema.DefaultSchemaResource
-
- defaultSearchFieldName - Variable in class org.apache.solr.schema.IndexSchema
-
- DefaultSearchFieldResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/defaultsearchfield
- DefaultSearchFieldResource() - Constructor for class org.apache.solr.rest.schema.DefaultSearchFieldResource
-
- DefaultSimilarityFactory - Class in org.apache.solr.search.similarities
-
- DefaultSimilarityFactory() - Constructor for class org.apache.solr.search.similarities.DefaultSimilarityFactory
-
- DefaultSolrCoreState - Class in org.apache.solr.update
-
- DefaultSolrCoreState(DirectoryFactory) - Constructor for class org.apache.solr.update.DefaultSolrCoreState
-
- DefaultSolrHighlighter - Class in org.apache.solr.highlight
-
- DefaultSolrHighlighter() - Constructor for class org.apache.solr.highlight.DefaultSolrHighlighter
-
- DefaultSolrHighlighter(SolrCore) - Constructor for class org.apache.solr.highlight.DefaultSolrHighlighter
-
- DefaultSolrThreadFactory - Class in org.apache.solr.util
-
- DefaultSolrThreadFactory(String) - Constructor for class org.apache.solr.util.DefaultSolrThreadFactory
-
- defaultStyle - Variable in class org.apache.solr.response.transform.ExplainAugmenterFactory
-
- defaultSyncLevel - Variable in class org.apache.solr.update.UpdateLog
-
- 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
-
- 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
-
- delegate - Variable in class org.apache.solr.search.DelegatingCollector
-
- delegate() - Method in class org.apache.solr.util.MapListener
-
- 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
-
- 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(CoreContainer, CoreDescriptor...) - Method in class org.apache.solr.core.SolrXMLCoresLocator
-
- DELETE - Static variable in class org.apache.solr.handler.UpdateRequestHandler
-
- delete(String) - Method in class org.apache.solr.store.blockcache.BlockDirectoryCache
-
- delete(String) - Method in interface org.apache.solr.store.blockcache.Cache
-
Remove a file from the cache.
- delete(DeleteUpdateCommand) - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- delete(DeleteUpdateCommand) - Method in class org.apache.solr.update.UpdateHandler
-
- DELETE - Static variable in class org.apache.solr.update.UpdateLog
-
- delete(DeleteUpdateCommand) - Method in class org.apache.solr.update.UpdateLog
-
- DELETE_BY_QUERY - Static variable in class org.apache.solr.update.UpdateLog
-
- 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 - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- deleteAll() - Method in class org.apache.solr.update.UpdateLog
-
currently for testing only
- deleteByQueries - Variable in class org.apache.solr.update.UpdateLog
-
- 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
-
- deleteByQuery - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
-
- DELETECOLLECTION - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- DELETECORE - Static variable in class org.apache.solr.cloud.Overseer
-
- 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
- deleteFile(String) - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- deleteFile(String) - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- deleteFile(File) - Static method in class org.apache.solr.update.UpdateLog
-
- deleteOnClose - Variable in class org.apache.solr.update.TransactionLog
-
- DELETEREPLICA - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- deletes - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
-
- DELETESHARD - Static variable in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- DeleteUpdateCommand - Class in org.apache.solr.update
-
- DeleteUpdateCommand(SolrQueryRequest) - Constructor for class org.apache.solr.update.DeleteUpdateCommand
-
- 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.function.CollapseScoreFunction
-
- description() - Method in class org.apache.solr.search.function.distance.GeohashFunction
-
- description() - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
-
- 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.FileFloatSource
-
- 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.client.solrj.embedded.JettySolrRunner.DebugFilter
-
- destroy() - Method in class org.apache.solr.handler.SnapPuller
-
- destroy() - Method in class org.apache.solr.servlet.SolrDispatchFilter
-
- destroy() - Method in class org.apache.solr.util.ConcurrentLFUCache
-
- destroy() - Method in class org.apache.solr.util.ConcurrentLRUCache
-
- 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
-
- dfMap - Variable in class org.apache.solr.handler.component.ResponseBuilder.GlobalCollectionStat
-
- DFRSimilarityFactory - Class in org.apache.solr.search.similarities
-
- 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
- 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 - Static variable in class org.apache.solr.schema.CoordinateFieldType
-
- directory - Variable in class org.apache.solr.core.CachingDirectoryFactory.CacheValue
-
- 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
-
- DirectSolrConnection - Class in org.apache.solr.servlet
-
DirectSolrConnection provides an interface to Solr that is similar to
the 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
-
- 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
-
- disable_tracing() - Method in class org.apache.solr.parser.QueryParser
-
Disable tracing.
- DISCOUNT_OVERLAPS - Static variable in class org.apache.solr.search.similarities.DefaultSimilarityFactory
-
- discountOverlaps - Variable in class org.apache.solr.search.similarities.DefaultSimilarityFactory
-
- 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
- discover(CoreContainer) - Method in class org.apache.solr.core.SolrXMLCoresLocator
-
- 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
-
- dist - Variable in class org.apache.solr.search.function.distance.StringDistanceFunction
-
- DIST_DOC_ID - Static variable in class org.apache.solr.handler.component.MoreLikeThisComponent
-
- distance(int, FunctionValues, FunctionValues) - Method in class org.apache.solr.search.function.distance.GeohashHaversineFunction
-
- 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 - Variable in class org.apache.solr.search.SpatialOptions
-
- 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_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
-
- 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) - Method in class org.apache.solr.update.SolrCmdDistributor
-
- distributedProcess(ResponseBuilder) - Method in class org.apache.solr.handler.component.FacetComponent
-
- 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
-
- DistributedQueue - Class in org.apache.solr.cloud
-
A distributed queue from zk recipes.
- DistributedQueue(SolrZkClient, String, List<ACL>) - Constructor for class org.apache.solr.cloud.DistributedQueue
-
- DistributedQueue.QueueEvent - Class in org.apache.solr.cloud
-
- DistributedUpdateProcessor - Class in org.apache.solr.update.processor
-
- 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
.
- DistributedUpdateProcessorFactory - Class in org.apache.solr.update.processor
-
- DistributedUpdateProcessorFactory() - Constructor for class org.apache.solr.update.processor.DistributedUpdateProcessorFactory
-
- 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.
- 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
-
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.FieldAnalysisRequestHandler
-
Performs the analysis based on the given solr request and returns the analysis result as a named list.
- doc(int) - 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.SolrIndexSearcher
-
Visit a document's fields using a
StoredFieldVisitor
This method does not currently add to the Solr document cache.
- doc(int, Set<String>) - Method in class org.apache.solr.search.SolrIndexSearcher
-
Retrieve the
Document
instance corresponding to the document id.
- DOC_COMMIT_DELAY_MS - Variable in class org.apache.solr.update.CommitTracker
-
- DOC_ID - Static variable in class org.apache.solr.handler.admin.LukeRequestHandler
-
- 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
-
- 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
name of a versionField
.
- DocBasedVersionConstraintsProcessorFactory() - Constructor for class org.apache.solr.update.processor.DocBasedVersionConstraintsProcessorFactory
-
- docFreq(Term) - Method in class org.apache.solr.search.SolrIndexSearcher
-
- DOCID - Static variable in class org.apache.solr.search.QueryParsing
-
- docID() - Method in class org.apache.solr.search.SolrConstantScoreQuery.ConstantScorer
-
- DocIdAugmenterFactory - Class in org.apache.solr.response.transform
-
- 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 - Interface in org.apache.solr.search
-
DocList
represents the result of a query: an ordered list of document ids with optional score.
- docList - Variable in class org.apache.solr.search.DocListAndSet
-
- 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
-
- docListToSolrDocumentList(DocList, SolrIndexSearcher, Set<String>, Map<SolrDocument, Integer>) - Static method in class org.apache.solr.util.SolrPluginUtils
-
Convert a DocList to a SolrDocumentList
The optional param "ids" is populated with the lucene document id
for each SolrDocument.
- docs - Variable in class org.apache.solr.request.SimpleFacets
-
- docs - Variable in class org.apache.solr.response.ResultContext
-
- docs - Variable in class org.apache.solr.search.SortedIntDocSet
-
- docsEnum - Variable in class org.apache.solr.search.SolrIndexSearcher.DocsEnumState
-
- docSet - Variable in class org.apache.solr.search.DocListAndSet
-
- DocSet - Interface in org.apache.solr.search
-
DocSet
represents an unordered set of Lucene Document Ids.
- DocSetCollector - Class in org.apache.solr.search
-
- DocSetCollector(int, int) - Constructor for class org.apache.solr.search.DocSetCollector
-
- DocSetDelegateCollector - Class in org.apache.solr.search
-
- DocSetDelegateCollector(int, int, Collector) - Constructor for class org.apache.solr.search.DocSetDelegateCollector
-
- DocSlice - Class in org.apache.solr.search
-
DocSlice
implements DocList as an array of docids and optional scores.
- DocSlice(int, int, int[], float[], int, float) - 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
-
- 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
-
- 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
-
- DocumentAnalysisRequestHandler - Class in org.apache.solr.handler
-
An analysis handler that provides a breakdown of the analysis process of provided docuemnts.
- DocumentAnalysisRequestHandler() - Constructor for class org.apache.solr.handler.DocumentAnalysisRequestHandler
-
- DocumentBuilder - Class in org.apache.solr.update
-
- 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
-
- DocumentDictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.DocumentDictionaryFactory
-
- DocumentExpressionDictionaryFactory - Class in org.apache.solr.spelling.suggest
-
- DocumentExpressionDictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
-
- 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
- doDeleteByQuery(DeleteUpdateCommand) - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
-
- doFacets - Variable in class org.apache.solr.handler.component.ResponseBuilder
-
- doFetch(SolrParams, boolean) - Method in class org.apache.solr.handler.ReplicationHandler
-
- doFieldSortValues(ResponseBuilder, SolrIndexSearcher) - Method in class org.apache.solr.handler.component.QueryComponent
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.solr.client.solrj.embedded.JettySolrRunner.DebugFilter
-
- 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(HttpServletRequest, HttpServletResponse) - Method in class org.apache.solr.servlet.LoadAdminUiServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.solr.servlet.RedirectServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.solr.servlet.ZookeeperInfoServlet
-
- doGet(String) - Static method in class org.apache.solr.util.SimplePostTool
-
Performs a simple get on the given URL
- doGet(URL) - Static method in class org.apache.solr.util.SimplePostTool
-
Performs a simple get on the given URL
- 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.PostingsSolrHighlighter
-
- 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.
- doHighlights - Variable in class org.apache.solr.handler.component.ResponseBuilder
-
- doIndent - Variable in class org.apache.solr.response.TextResponseWriter
-
- doInit() - Method in class org.apache.solr.rest.schema.CopyFieldCollectionResource
-
- doInit() - Method in class org.apache.solr.rest.schema.DefaultSchemaResource
-
- doInit() - Method in class org.apache.solr.rest.schema.DefaultSearchFieldResource
-
- doInit() - Method in class org.apache.solr.rest.schema.DynamicFieldCollectionResource
-
- doInit() - Method in class org.apache.solr.rest.schema.DynamicFieldResource
-
Gets the field name pattern from the request attribute where it's stored by Restlet.
- doInit() - Method in class org.apache.solr.rest.schema.FieldCollectionResource
-
- doInit() - Method in class org.apache.solr.rest.schema.FieldResource
-
- doInit() - Method in class org.apache.solr.rest.schema.FieldTypeCollectionResource
-
- doInit() - Method in class org.apache.solr.rest.schema.FieldTypeResource
-
- doInit() - Method in class org.apache.solr.rest.schema.SchemaNameResource
-
- doInit() - Method in class org.apache.solr.rest.schema.SchemaResource
-
- doInit() - Method in class org.apache.solr.rest.schema.SchemaSimilarityResource
-
- doInit() - Method in class org.apache.solr.rest.schema.SchemaVersionResource
-
- doInit() - Method in class org.apache.solr.rest.schema.SolrQueryParserDefaultOperatorResource
-
- doInit() - Method in class org.apache.solr.rest.schema.SolrQueryParserResource
-
- doInit() - Method in class org.apache.solr.rest.schema.UniqueKeyFieldResource
-
- DOMUtil - Class in org.apache.solr.util
-
- DOMUtil() - Constructor for class org.apache.solr.util.DOMUtil
-
- Done() - Method in interface org.apache.solr.parser.CharStream
-
The lexer calls this function to indicate that it is done with the stream
and hence implementations can free any resources held by this class.
- Done() - Method in class org.apache.solr.parser.FastCharStream
-
- 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 it's ref count
hits 0, it can be closed.
- doPersist(String) - Method in class org.apache.solr.core.SolrXMLCoresLocator
-
- doPersist(String) - Method in class org.apache.solr.core.SolrXMLCoresLocator.NonPersistingLocator
-
- doPivots(NamedList<Integer>, String, String, Deque<String>, DocSet) - Method in class org.apache.solr.handler.component.PivotFacetHelper
-
Recursive function to do all the pivots
- doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.solr.servlet.ZookeeperInfoServlet
-
- doPrefetch(ResponseBuilder) - Method in class org.apache.solr.handler.component.QueryComponent
-
- doRecovery(SolrCore) - Method in class org.apache.solr.cloud.RecoveryStrategy
-
- doRecovery(CoreContainer, CoreDescriptor) - Method in class org.apache.solr.update.DefaultSolrCoreState
-
- doRecovery(CoreContainer, CoreDescriptor) - Method in class org.apache.solr.update.SolrCoreState
-
- doSimpleQuery(String, SolrQueryRequest, int, int) - Static method in class org.apache.solr.util.SolrPluginUtils
-
Executes a basic query
- 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) - Static method in class org.apache.solr.util.SolrPluginUtils
-
- doStandardResultsDebug(SolrQueryRequest, Query, DocList, boolean, NamedList) - Static method in class org.apache.solr.util.SolrPluginUtils
-
- doStats - Variable in class org.apache.solr.handler.component.ResponseBuilder
-
- doTerms - Variable in class org.apache.solr.handler.component.ResponseBuilder
-
- double2sortableStr(double) - Static method in class org.apache.solr.util.NumberUtils
-
- double2sortableStr(String) - Static method in class org.apache.solr.util.NumberUtils
-
- DoubleField - Class in org.apache.solr.schema
-
A legacy numeric field type that encodes "Double" values as simple Strings.
- DoubleField() - Constructor for class org.apache.solr.schema.DoubleField
-
- 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.
- doUpdates(MetricsContext) - Method in class org.apache.solr.store.blockcache.Metrics
-
- downloadConfigDir(SolrZkClient, String, File) - Static method in class org.apache.solr.cloud.ZkController
-
- downloadFromZK(SolrZkClient, String, File) - Static method in class org.apache.solr.cloud.ZkController
-
- dropBufferedUpdates() - Method in class org.apache.solr.update.HdfsUpdateLog
-
- 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
- DumpRequestHandler - Class in org.apache.solr.handler
-
- DumpRequestHandler() - Constructor for class org.apache.solr.handler.DumpRequestHandler
-
- DYNAMIC_FIELD - Static variable in class org.apache.solr.schema.IndexSchema
-
- DYNAMIC_FIELDS - Static variable in class org.apache.solr.rest.SolrRestApi
-
- DYNAMIC_FIELDS - Static variable in class org.apache.solr.schema.IndexSchema
-
- DYNAMIC_FIELDS_PATH - Static variable in class org.apache.solr.rest.SolrRestApi
-
- dynamicCopyFields - Variable in class org.apache.solr.schema.IndexSchema
-
- DynamicFieldCollectionResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/dynamicfields
To restrict the set of dynamic fields in the response, specify a comma
and/or space separated list of dynamic field patterns in the "fl" query
parameter.
- DynamicFieldCollectionResource() - Constructor for class org.apache.solr.rest.schema.DynamicFieldCollectionResource
-
- DynamicFieldResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/dynamicfields/(pattern)
where pattern is a field name pattern (with an asterisk at the beginning or the end).
- DynamicFieldResource() - Constructor for class org.apache.solr.rest.schema.DynamicFieldResource
-
- dynamicFields - Variable in class org.apache.solr.schema.IndexSchema
-
- dynFieldProps - Variable in class org.apache.solr.schema.AbstractSubTypeFieldType
-
- F - Static variable in class org.apache.solr.search.QueryParsing
-
- facet(int) - Method in class org.apache.solr.handler.component.FieldFacetStats
-
- FacetComponent - Class in org.apache.solr.handler.component
-
TODO!
- 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.FacetBase(ResponseBuilder, String, String) - Constructor for class org.apache.solr.handler.component.FacetComponent.FacetBase
-
- FacetComponent.FacetInfo - Class in org.apache.solr.handler.component
-
This API is experimental and subject to change
- FacetComponent.FacetInfo() - Constructor for class org.apache.solr.handler.component.FacetComponent.FacetInfo
-
- FacetComponent.FieldFacet - Class in org.apache.solr.handler.component
-
This API is experimental and subject to change
- FacetComponent.FieldFacet(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.FacetComponent.FieldFacet
-
- FacetComponent.QueryFacet - Class in org.apache.solr.handler.component
-
This API is experimental and subject to change
- FacetComponent.QueryFacet(ResponseBuilder, String) - Constructor for class org.apache.solr.handler.component.FacetComponent.QueryFacet
-
- FacetComponent.ShardFacetCount - Class in org.apache.solr.handler.component
-
This API is experimental and subject to change
- FacetComponent.ShardFacetCount() - Constructor for class org.apache.solr.handler.component.FacetComponent.ShardFacetCount
-
- facetResponse - Variable in class org.apache.solr.request.SimpleFacets
-
- facets - Variable in class org.apache.solr.handler.component.FacetComponent.FacetInfo
-
- 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
-
- failed() - Method in interface org.apache.solr.cloud.RecoveryStrategy.RecoveryListener
-
- failed() - Method in class org.apache.solr.update.DefaultSolrCoreState
-
- failed - Variable in class org.apache.solr.update.UpdateLog.RecoveryInfo
-
- 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
- FastCharStream - Class in org.apache.solr.parser
-
An efficient implementation of JavaCC's CharStream interface.
- FastCharStream(Reader) - Constructor for class org.apache.solr.parser.FastCharStream
-
Constructs from a Reader.
- FastLRUCache<K,V> - Class in org.apache.solr.search
-
SolrCache based on ConcurrentLRUCache implementation.
- FastLRUCache() - Constructor for class org.apache.solr.search.FastLRUCache
-
- FastWriter - Class in org.apache.solr.util
-
Single threaded BufferedWriter
Internal Solr use only, subject to change.
- FastWriter(Writer) - Constructor for class org.apache.solr.util.FastWriter
-
- FastWriter(Writer, char[], int) - Constructor for class org.apache.solr.util.FastWriter
-
- fetch(BlockCacheKey, byte[], int, int, int) - Method in class org.apache.solr.store.blockcache.BlockCache
-
- fetch(BlockCacheKey, byte[]) - Method in class org.apache.solr.store.blockcache.BlockCache
-
- fetch(String, long, int, byte[], int, int) - Method in class org.apache.solr.store.blockcache.BlockDirectoryCache
-
- fetch(String, long, int, byte[], int, int) - Method in interface org.apache.solr.store.blockcache.Cache
-
Fetch the specified cache file content.
- field - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
-
- field - Variable in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
-
- FIELD - Static variable in class org.apache.solr.schema.IndexSchema
-
- field - Variable in class org.apache.solr.search.ExtendedDismaxQParser.Clause
-
- field - Variable in class org.apache.solr.search.SpatialOptions
-
- FIELD - Static variable in class org.apache.solr.spelling.AbstractLuceneSpellChecker
-
- FIELD - Static variable in class org.apache.solr.spelling.SolrSpellChecker
-
- field - 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_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
-
- FIELD_SUFFIX_CURRENCY - Static variable in class org.apache.solr.schema.CurrencyField
-
- FIELD_TYPE - Static variable in class org.apache.solr.schema.IndexSchema
-
- FIELD_TYPE - Static variable in class org.apache.solr.spelling.SolrSpellChecker
-
- 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
-
- FieldCollectionResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/fields
Two query parameters are supported:
"fl": a comma- and/or space-separated list of fields to send properties
for in the response, rather than the default: all of them.
- FieldCollectionResource() - Constructor for class org.apache.solr.rest.schema.FieldCollectionResource
-
- 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, String, SchemaField, SchemaField, boolean) - Constructor for class org.apache.solr.handler.component.FieldFacetStats
-
- 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
-
- FieldMutatingUpdateProcessorFactory.SelectorParams() - Constructor for class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
-
- 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
-
- fieldNameMatchesSchemaField - Variable in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory.SelectorParams
-
- 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
-
- FieldResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/fields/(fieldname)
where "fieldname" is the name of a field.
- FieldResource() - Constructor for class org.apache.solr.rest.schema.FieldResource
-
- FIELDS - Static variable in class org.apache.solr.schema.IndexSchema
-
- 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_PATH - Static variable in class org.apache.solr.rest.SolrRestApi
-
- fieldsWithDefaultValue - Variable in class org.apache.solr.schema.IndexSchema
-
- 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...
- fieldTypeAmountRaw - Variable in class org.apache.solr.schema.CurrencyField
-
- FieldTypeCollectionResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/fieldtypes
The GET method returns properties for all field types defined in the schema.
- FieldTypeCollectionResource() - Constructor for class org.apache.solr.rest.schema.FieldTypeCollectionResource
-
- fieldTypeCurrency - Variable in class org.apache.solr.schema.CurrencyField
-
- 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
-
- FieldTypeResource - Class in org.apache.solr.rest.schema
-
This class responds to requests at /solr/(corename)/schema/fieldtype/(typename)
where "typename" is the name of a field type in the schema.
- FieldTypeResource() - Constructor for class org.apache.solr.rest.schema.FieldTypeResource
-
- FIELDTYPES - Static variable in class org.apache.solr.rest.SolrRestApi
-
- fieldTypes - Variable in class org.apache.solr.schema.IndexSchema
-
- FIELDTYPES_PATH - Static variable in class org.apache.solr.rest.SolrRestApi
-
- 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
-
- fifteenMinuteEWMA() - Static method in class org.apache.solr.util.stats.EWMA
-
Creates a new EWMA which is equivalent to the UNIX fifteen minute load average and which
expects to be ticked every 5 seconds.
- FILE - Static variable in class org.apache.solr.handler.ReplicationHandler
-
- 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
-
- FileDictionaryFactory - Class in org.apache.solr.spelling.suggest
-
- FileDictionaryFactory() - Constructor for class org.apache.solr.spelling.suggest.FileDictionaryFactory
-
- fileExists(String) - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- fileExists(String) - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- 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
-
- FileFloatSource.ReloadCacheRequestHandler() - Constructor for class org.apache.solr.search.function.FileFloatSource.ReloadCacheRequestHandler
-
- fileLength(String) - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- fileLength(String) - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- fileModified(String) - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- FileUtils - Class in org.apache.solr.util
-
- FileUtils() - Constructor for class org.apache.solr.util.FileUtils
-
- FILLLEFT - Static variable in class org.apache.solr.internal.csv.writer.CSVConfig
-
Fill content the the left.
- FILLNONE - Static variable in class org.apache.solr.internal.csv.writer.CSVConfig
-
Do no do any filling
- FILLRIGHT - Static variable in class org.apache.solr.internal.csv.writer.CSVConfig
-
Fill content to the right.
- FILTER - Static variable in class org.apache.solr.schema.FieldType
-
- filter - Variable in class org.apache.solr.search.SolrIndexSearcher.ProcessedFilter
-
- 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.
- 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
-
- FILTERS - Static variable in class org.apache.solr.schema.FieldType
-
- finalize() - Method in class org.apache.solr.core.CoreContainer
-
- finalize() - Method in class org.apache.solr.core.SolrCore
-
- finalize() - Method in class org.apache.solr.update.SolrIndexWriter
-
- finalize() - Method in class org.apache.solr.util.ConcurrentLFUCache
-
- finalize() - Method in class org.apache.solr.util.ConcurrentLRUCache
-
- findClass(String, Class<T>) - Method in class org.apache.solr.core.SolrResourceLoader
-
- findClass(String, Class<T>, String...) - Method in class org.apache.solr.core.SolrResourceLoader
-
This method loads a class either with it's FQN or a short-name (solr.class-simplename or class-simplename).
- findIndex(int[], int, int, int) - Static method in class org.apache.solr.search.SortedIntDocSet
-
- finish() - Method in class org.apache.solr.search.DelegatingCollector
-
- 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
-
Performs any necessary post actions to prepare the response.
- finish() - Method in class org.apache.solr.search.Grouping.CommandFunc
-
Performs any necessary post actions to prepare the response.
- finish() - Method in class org.apache.solr.search.Grouping.CommandQuery
-
Performs any necessary post actions to prepare the response.
- finish(UpdateLog.SyncLevel) - Method in class org.apache.solr.update.HdfsTransactionLog
-
- finish() - Method in class org.apache.solr.update.processor.DistributedUpdateProcessor
-
- finish() - Method in class org.apache.solr.update.processor.UpdateRequestProcessor
-
- finish() - Method in class org.apache.solr.update.SolrCmdDistributor
-
- 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
-
- finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.DebugComponent
-
- 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.QueryComponent
-
- finishStage(ResponseBuilder) - Method in class org.apache.solr.handler.component.RealTimeGetComponent
-
private void handleRegularResponses(ResponseBuilder rb, ShardRequest sreq) {
}
- 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
-
- 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
-
- firstNonSorted(int[], int, int) - Static method in class org.apache.solr.search.SortedIntDocSet
-
Returns the index of the first non-sorted element or -1 if they are all sorted
- firstPhaseElapsedTime - Variable in class org.apache.solr.handler.component.ResponseBuilder
-
- fiveMinuteEWMA() - Static method in class org.apache.solr.util.stats.EWMA
-
Creates a new EWMA which is equivalent to the UNIX five minute load average and which expects
to be ticked every 5 seconds.
- 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_GAP - Static variable in class org.apache.solr.update.UpdateLog
-
- flags - Variable in class org.apache.solr.update.UpdateCommand
-
- FLAGS_KEY - Static variable in class org.apache.solr.schema.JsonPreAnalyzedParser
-
- flattenBooleanQuery(BooleanQuery, 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.
- float2sortableStr(float) - Static method in class org.apache.solr.util.NumberUtils
-
- float2sortableStr(String) - Static method in class org.apache.solr.util.NumberUtils
-
- FloatField - Class in org.apache.solr.schema
-
A legacy numeric field type that encodes "Float" values as simple Strings.
- FloatField() - Constructor for class org.apache.solr.schema.FloatField
-
- 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.store.blockcache.ReusedBufferedIndexOutput
-
- flush() - Method in class org.apache.solr.store.hdfs.HdfsFileWriter
-
- flush() - Method in class org.apache.solr.store.hdfs.NullIndexOutput
-
- flush(byte[], int, int) - Method in class org.apache.solr.update.MemOutputStream
-
- flush() - Method in class org.apache.solr.util.FastWriter
-
- flush(char[], int, int) - Method in class org.apache.solr.util.FastWriter
-
- flush(String, int, int) - Method in class org.apache.solr.util.FastWriter
-
- flushBuffer(IndexOutput, long) - Method in class org.apache.solr.store.blockcache.CustomBufferedIndexInput
-
Flushes the in-memory bufer to the given output, copying at most
numBytes
.
- flushBuffer() - Method in class org.apache.solr.util.FastWriter
-
- flushInternal() - Method in class org.apache.solr.store.blockcache.CachedIndexOutput
-
- flushInternal() - Method in class org.apache.solr.store.blockcache.ReusedBufferedIndexOutput
-
- forceClose() - Method in class org.apache.solr.update.TransactionLog
-
- forceOverSeer() - Method in class org.apache.solr.cloud.ZkController
-
- format - Variable in class org.apache.solr.search.Grouping.Command
-
- format(LogRecord) - Method in class org.apache.solr.SolrLogFormatter
-
- format(LoggingEvent) - Method in class org.apache.solr.util.SolrLogLayout
-
- formatDate(Date) - Method in class org.apache.solr.schema.DateField
-
Deprecated.
Thread safe method that can be used by subclasses to format a Date
using the Internal representation.
- formatExternal(Date) - Static method in class org.apache.solr.schema.DateField
-
Deprecated.
Return the standard human readable form of the date
- formatMessage(LogRecord) - Method in class org.apache.solr.SolrLogFormatter
-
- formatters - Variable in class org.apache.solr.highlight.DefaultSolrHighlighter
-
- FORMDATA - Static variable in class org.apache.solr.servlet.SolrRequestParsers
-
- 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
-
- FreeTextLookupFactory - Class in org.apache.solr.spelling.suggest.fst
-
- 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() - Method in class org.apache.solr.search.SolrConstantScoreQuery.ConstantScorer
-
- 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
-
- fromConfig(Config, String) - Static method in class org.apache.solr.core.ConfigSolr
-
- fromExpression(String, Set<SortField>) - Method in class org.apache.solr.spelling.suggest.DocumentExpressionDictionaryFactory
-
- fromFile(SolrResourceLoader, File) - Static method in class org.apache.solr.core.ConfigSolr
-
- fromInputStream(SolrResourceLoader, InputStream) - Static method in class org.apache.solr.core.ConfigSolr
-
- fromSolrHome(SolrResourceLoader, String) - Static method in class org.apache.solr.core.ConfigSolr
-
- fromString(SolrResourceLoader, String) - Static method in class org.apache.solr.core.ConfigSolr
-
- fromString(SchemaField, String, float) - Method in class org.apache.solr.schema.PreAnalyzedField
-
- FSTLookupFactory - Class in org.apache.solr.spelling.suggest.fst
-
- FSTLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.FSTLookupFactory
-
- ftype - Variable in class org.apache.solr.handler.component.FacetComponent.FieldFacet
-
- 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
-
- FuzzyLookupFactory() - Constructor for class org.apache.solr.spelling.suggest.fst.FuzzyLookupFactory
-
- GapFragmenter - Class in org.apache.solr.highlight
-
- GapFragmenter() - Constructor for class org.apache.solr.highlight.GapFragmenter
-
- generateDescription(int, int, int, int, boolean) - Method in class org.apache.solr.search.FastLRUCache
-
- generateParseException() - Method in class org.apache.solr.parser.QueryParser
-
Generate ParseException.
- GENERATION - Static variable in class org.apache.solr.handler.ReplicationHandler
-
- GeoDistValueSourceParser - Class in org.apache.solr.search.function.distance
-
- GeoDistValueSourceParser() - Constructor for class org.apache.solr.search.function.distance.GeoDistValueSourceParser
-
- GeoHashField - Class in org.apache.solr.schema
-
This is a class that represents a
Geohash field.
- GeoHashField() - Constructor for class org.apache.solr.schema.GeoHashField
-
- GeohashFunction - Class in org.apache.solr.search.function.distance
-
Takes in a latitude and longitude ValueSource and produces a GeoHash.
- GeohashFunction(ValueSource, ValueSource) - Constructor for class org.apache.solr.search.function.distance.GeohashFunction
-
- GeohashHaversineFunction - Class in org.apache.solr.search.function.distance
-
Calculate the Haversine distance between two geo hash codes.
- GeohashHaversineFunction(ValueSource, ValueSource, double) - Constructor for class org.apache.solr.search.function.distance.GeohashHaversineFunction
-
- get(String, DirectoryFactory.DirContext, String) - Method in class org.apache.solr.core.CachingDirectoryFactory
-
- get(String) - Method in class org.apache.solr.core.Config
-
- get(String, String) - Method in class org.apache.solr.core.Config
-
- get(ConfigSolr.CfgProp, String) - Method in class org.apache.solr.core.ConfigSolr
-
- 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(String) - Method in class org.apache.solr.core.RequestHandlers
-
- 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(int) - Method in class org.apache.solr.logging.CircularList
-
- get(String) - Static method in enum org.apache.solr.parser.SolrQueryParserBase.MagicFieldName
-
- get() - Method in interface org.apache.solr.rest.GETable
-
- get() - Method in class org.apache.solr.rest.schema.CopyFieldCollectionResource
-
- get() - Method in class org.apache.solr.rest.schema.DefaultSchemaResource
-
- get() - Method in class org.apache.solr.rest.schema.DefaultSearchFieldResource
-
- get() - Method in class org.apache.solr.rest.schema.DynamicFieldCollectionResource
-
- get() - Method in class org.apache.solr.rest.schema.DynamicFieldResource
-
- get() - Method in class org.apache.solr.rest.schema.FieldCollectionResource
-
- get() - Method in class org.apache.solr.rest.schema.FieldResource
-
- get() - Method in class org.apache.solr.rest.schema.FieldTypeCollectionResource
-
- get() - Method in class org.apache.solr.rest.schema.FieldTypeResource
-
- get() - Method in class org.apache.solr.rest.schema.SchemaNameResource
-
- get() - Method in class org.apache.solr.rest.schema.SchemaResource
-
- get() - Method in class org.apache.solr.rest.schema.SchemaSimilarityResource
-
- get() - Method in class org.apache.solr.rest.schema.SchemaVersionResource
-
- get() - Method in class org.apache.solr.rest.schema.SolrQueryParserDefaultOperatorResource
-
- get() - Method in class org.apache.solr.rest.schema.SolrQueryParserResource
-
- get() - Method in class org.apache.solr.rest.schema.UniqueKeyFieldResource
-
- get(K) - Method in class org.apache.solr.search.FastLRUCache
-
- get(K) - Method in class org.apache.solr.search.LFUCache
-
- get(K) - Method in class org.apache.solr.search.LRUCache
-
- get(K) - Method in interface org.apache.solr.search.SolrCache
-
:TODO: copy from Map
- get(Token) - Method in class org.apache.solr.spelling.SpellingResult
-
Gets the suggestions for the given token.
- get(K) - Method in class org.apache.solr.util.ConcurrentLFUCache
-
- get(K) - Method in class org.apache.solr.util.ConcurrentLRUCache
-
- get(Object) - Method in class org.apache.solr.util.MapListener
-
- get() - Method in class org.apache.solr.util.RefCounted
-
- get75thPercentile() - Method in class org.apache.solr.util.stats.Snapshot
-
Returns the value at the 75th percentile in the distribution.
- get95thPercentile() - Method in class org.apache.solr.util.stats.Snapshot
-
Returns the value at the 95th percentile in the distribution.
- get98thPercentile() - Method in class org.apache.solr.util.stats.Snapshot
-
Returns the value at the 98th percentile in the distribution.
- get999thPercentile() - Method in class org.apache.solr.util.stats.Snapshot
-
Returns the value at the 99.9th percentile in the distribution.
- get99thPercentile() - Method in class org.apache.solr.util.stats.Snapshot
-
Returns the value at the 99th percentile in the distribution.
- GET_DOCLIST - Static variable in class org.apache.solr.search.SolrIndexSearcher
-
- GET_DOCSET - Static variable in class org.apache.solr.search.SolrIndexSearcher
-
- GET_SCORES - Static variable in class org.apache.solr.search.SolrIndexSearcher
-
- getA() - Method in class org.apache.solr.search.grouping.distributed.command.Pair
-
- GETable - Interface in org.apache.solr.rest
-
Marker interface for resource classes that handle GET requests.
- 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
-
- 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 class org.apache.solr.core.ConfigSolr
-
- getAdminPath() - Method in class org.apache.solr.core.ConfigSolrXml
-
- getAdminPath() - Method in class org.apache.solr.core.CoreContainer
-
- getAlias(String) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
-
Returns the aliases found for a field.
- 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.
- getAll(Class<T>) - Method in class org.apache.solr.core.RequestHandlers
-
- getAllCoreNames() - Method in class org.apache.solr.core.ConfigSolrXmlOld
-
- getAllCoreNames() - Method in class org.apache.solr.core.CoreContainer
-
get a list of all the cores that are currently loaded
- getAllLevels() - Method in class org.apache.solr.logging.jul.JulWatcher
-
- getAllLevels() - Method in class org.apache.solr.logging.log4j.Log4jWatcher
-
- 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.log4j.Log4jWatcher
-
- getAllLoggers() - Method in class org.apache.solr.logging.LogWatcher
-
- getAllowLeadingWildcard() - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- getAllPhraseFields() - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedDismaxConfiguration
-
- 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
-
- getAnalyzer() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
-
- getAnalyzer() - Method in class org.apache.solr.schema.BoolField
-
- getAnalyzer() - Method in class org.apache.solr.schema.CollationField
-
- getAnalyzer() - Method in class org.apache.solr.schema.FieldType
-
Returns the Analyzer to be used when indexing fields of this type.
- getAnalyzer() - Method in class org.apache.solr.schema.IndexSchema
-
Returns the Analyzer used when indexing documents for this index
- getAnalyzer() - Method in class org.apache.solr.schema.PreAnalyzedField
-
- 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 name
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
VersionInfo.VERSION_FIELD
from the specified
schema, after verifying that it is indexed, stored, and single-valued.
- getArgs() - Method in class org.apache.solr.core.AbstractSolrEventListener
-
- getAtomicReader() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getAttr(NamedNodeMap, String) - Static method in class org.apache.solr.util.DOMUtil
-
- getAttr(Node, String) - Static method in class org.apache.solr.util.DOMUtil
-
- getAttr(NamedNodeMap, String, String) - Static method in class org.apache.solr.util.DOMUtil
-
- getAttr(Node, String, String) - Static method in class org.apache.solr.util.DOMUtil
-
- 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
-
- getB() - Method in class org.apache.solr.search.grouping.distributed.command.Pair
-
- getBankId() - Method in class org.apache.solr.store.blockcache.BlockCacheLocation
-
- getBaseUrl() - Method in class org.apache.solr.client.solrj.embedded.JettySolrRunner
-
Returns a base URL consisting of the protocal, host, and port for a
Connector in use by the Jetty Server contained in this runner.
- getBaseUrl() - Method in class org.apache.solr.cloud.ZkController
-
- getBaseUrl() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
-
- getBaseUrl() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
-
- getBaseWriter(SolrQueryRequest) - Method in class org.apache.solr.response.RawResponseWriter
-
- getBeginColumn() - Method in interface org.apache.solr.parser.CharStream
-
Returns the column number of the first character for current token (being
matched after the last call to BeginTOken).
- getBeginColumn() - Method in class org.apache.solr.parser.FastCharStream
-
- getBeginLine() - Method in interface org.apache.solr.parser.CharStream
-
Returns the line number of the first character for current token (being
matched after the last call to BeginTOken).
- getBeginLine() - Method in class org.apache.solr.parser.FastCharStream
-
- getBits() - Method in class org.apache.solr.search.BitDocSet
-
- getBits() - Method in class org.apache.solr.search.SortedIntDocSet
-
- getBlock() - Method in class org.apache.solr.store.blockcache.BlockCacheKey
-
- getBlock() - Method in class org.apache.solr.store.blockcache.BlockCacheLocation
-
- getBlock(long) - Static method in class org.apache.solr.store.blockcache.BlockDirectory
-
- getBool(String) - Method in class org.apache.solr.core.Config
-
- getBool(String, boolean) - Method in class org.apache.solr.core.Config
-
- getBool(ConfigSolr.CfgProp, boolean) - Method in class org.apache.solr.core.ConfigSolr
-
- getBooleanArg(NamedList, String) - Static method in class org.apache.solr.update.processor.FieldMutatingUpdateProcessorFactory
-
- getBooleanQuery(List<BooleanClause>) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
Factory method for generating query, given a set of clauses.
- getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
Factory method for generating query, given a set of clauses.
- getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
-
- getBoost() - Method in class org.apache.solr.search.FieldParams
-
- getBoost() - Method in class org.apache.solr.search.join.IgnoreAcceptDocsQuery
-
- getBoost() - Method in class org.apache.solr.search.WrappedQuery
-
- getBoostedMLTQuery() - 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.SolrBoundaryScanner
-
- getBufferSize() - Method in class org.apache.solr.logging.CircularList
-
- getBufferStart() - Method in class org.apache.solr.store.blockcache.ReusedBufferedIndexOutput
-
- getBytes() - Method in class org.apache.solr.cloud.DistributedQueue.QueueEvent
-
- 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() - Method in class org.apache.solr.search.SolrConstantScoreQuery
-
- getCache(String) - Method in class org.apache.solr.search.SolrIndexSearcher
-
return the named generic cache
- getCacheControlHeader() - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
-
null if no Cache-Control header
- getCacheSep() - Method in class org.apache.solr.search.CollapsingQParserPlugin.CollapsingPostFilter
-
- getCacheSep() - Method in interface org.apache.solr.search.ExtendedQuery
-
If true, the clauses of this boolean query should be cached separately.
- getCacheSep() - Method in class org.apache.solr.search.ExtendedQueryBase
-
- getCacheSep() - Method in class org.apache.solr.search.SolrConstantScoreQuery
-
- 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.RequestHandlers.LazyRequestHandlerWrapper
-
- getCategory() - Method in class org.apache.solr.core.SolrCore
-
- getCategory() - Method in interface org.apache.solr.core.SolrInfoMBean
-
Purpose of this Class
- getCategory() - Method in class org.apache.solr.handler.admin.AdminHandlers
-
- getCategory() - Method in class org.apache.solr.handler.component.SearchComponent
-
- getCategory() - Method in class org.apache.solr.handler.RequestHandlerBase
-
- getCategory() - Method in class org.apache.solr.highlight.HighlightingPluginBase
-
- getCategory() - Method in class org.apache.solr.search.LFUCache
-
- 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.SolrFieldCacheMBean
-
- getCategory() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getCategory() - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- 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
-
- getChild(Node, String) - Static method in class org.apache.solr.util.DOMUtil
-
- getChildren(String) - Method in class org.apache.solr.core.PluginInfo
-
Filter children by type
- getChildren() - Method in class org.apache.solr.util.RTimer
-
Manipulating this map may have undefined results.
- getClassArg() - Method in class org.apache.solr.schema.FieldType
-
- getClassArg() - Method in class org.apache.solr.schema.SimilarityFactory
-
- getClassLoader() - Method in class org.apache.solr.core.SolrResourceLoader
-
EXPERT
The underlying class loader.
- getClientString() - Method in class org.apache.solr.cloud.SolrZkServer
-
- getClientTimeout() - Method in class org.apache.solr.cloud.ZkController
-
- getClientTimeZone() - Method in class org.apache.solr.request.SolrRequestInfo
-
The TimeZone specified by the request, or null if none was specified
- getCloudDescriptor() - Method in class org.apache.solr.core.CoreDescriptor
-
- getClusterState() - Method in class org.apache.solr.cloud.ZkController
-
- getCodec() - Method in class org.apache.solr.core.CodecFactory
-
- getCodec() - Method in class org.apache.solr.core.SchemaCodecFactory
-
- getCodec() - Method in class org.apache.solr.core.SolrCore
-
- getCollationQuery() - Method in class org.apache.solr.spelling.SpellCheckCollation
-
- getCollectionName() - Method in class org.apache.solr.cloud.CloudDescriptor
-
- getCollectionName() - Method in class org.apache.solr.core.CoreDescriptor
-
- getCollectionsHandler() - Method in class org.apache.solr.core.CoreContainer
-
- getCollectionsHandlerClass() - Method in class org.apache.solr.core.ConfigSolr
-
- getCollectionZkPath() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
-
- getColumn() - Method in interface org.apache.solr.parser.CharStream
-
Deprecated.
- getColumn() - Method in class org.apache.solr.parser.FastCharStream
-
- getCommands() - Method in class org.apache.solr.search.Grouping
-
- 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
-
Gets the commit points for the index.
- getCommitTimestamp(IndexCommit) - Static method in class org.apache.solr.core.IndexDeletionPolicyWrapper
-
- getCommitTracker() - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- getComponents() - Method in class org.apache.solr.handler.component.SearchHandler
-
- getConfDir() - Method in class org.apache.solr.core.HdfsDirectoryFactory
-
- getConfig() - Method in class org.apache.solr.core.ConfigSolr
-
- getConfig() - Method in class org.apache.solr.internal.csv.writer.CSVWriter
-
- getConfig(SolrConfig, String) - Static method in class org.apache.solr.search.CacheConfig
-
- getConfig(SolrConfig, Node) - Static method in class org.apache.solr.search.CacheConfig
-
- getConfigDir() - Method in class org.apache.solr.cloud.ZkSolrResourceLoader
-
- getConfigDir() - Method in class org.apache.solr.core.SolrResourceLoader
-
- getConfigFileData(String, String) - Method in class org.apache.solr.cloud.ZkController
-
Returns config file data (in bytes)
- getConfigName() - Method in class org.apache.solr.core.CoreDescriptor
-
- getConfigResource() - Method in class org.apache.solr.core.SolrCore
-
Gets the configuration resource name used by this core instance.
- getConfiguration() - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- getConnectionManager() - Method in class org.apache.solr.update.UpdateShardHandler
-
- getContainerProperties() - Method in class org.apache.solr.core.CoreContainer
-
- 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(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.core.SolrCore.LazyQueryResponseWriterWrapper
-
- getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.BinaryResponseWriter
-
- getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.CSVResponseWriter
-
- 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
-
- getContentType(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.response.XSLTResponseWriter
-
- getContext() - Method in class org.apache.solr.cloud.LeaderElector
-
- 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
-
- getConvertedValueSource(String, CurrencyField.RawCurrencyValueSource) - Method in class org.apache.solr.schema.CurrencyField
-
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.
- 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(String) - Method in class org.apache.solr.core.CoreContainer
-
Gets a core by name and increase its refcount.
- 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
-
- getCoreAdminHandlerClass() - Method in class org.apache.solr.core.ConfigSolr
-
- getCoreContainer() - Method in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
-
Getter method for the CoreContainer
- getCoreContainer() - Method in class org.apache.solr.core.CoreDescriptor
-
- 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.InfoHandler
-
The instance of CoreContainer this handler handles.
- getCoreDescriptor(String) - Method in class org.apache.solr.core.CoreContainer
-
- getCoreDescriptor() - Method in class org.apache.solr.core.SolrCore
-
- getCoreDescriptors() - Method in class org.apache.solr.core.CoreContainer
-
Get the CoreDescriptors for all cores managed by this container
- getCoreInitFailures() - Method in class org.apache.solr.core.CoreContainer
-
Returns an immutable Map of Exceptions that occured 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() - Method in class org.apache.solr.core.ConfigSolr
-
- getCoreName() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
-
- getCoreName() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
-
- getCoreNames() - Method in class org.apache.solr.core.CoreContainer
-
- getCoreNames(SolrCore) - Method in class org.apache.solr.core.CoreContainer
-
This method is currently experimental.
- getCoreNodeName() - Method in class org.apache.solr.cloud.CloudDescriptor
-
- getCoreNodeName(CoreDescriptor) - Method in class org.apache.solr.cloud.ZkController
-
- getCoreProperties(String) - Method in class org.apache.solr.core.ConfigSolrXmlOld
-
- getCoreProperties() - Method in class org.apache.solr.core.SolrResourceLoader
-
- 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.ConfigSolr
-
The directory against which relative core instance dirs are resolved.
- getCoreRootDirectory() - Method in class org.apache.solr.core.CoreContainer
-
- getCores() - Method in class org.apache.solr.core.CoreContainer
-
- getCores() - Method in class org.apache.solr.servlet.SolrDispatchFilter
-
- getCoresLocator() - Method in class org.apache.solr.core.ConfigSolr
-
- getCoresLocator() - Method in class org.apache.solr.core.ConfigSolrXml
-
- getCoresLocator() - Method in class org.apache.solr.core.ConfigSolrXmlOld
-
- getCoresLocator() - Method in class org.apache.solr.core.CoreContainer
-
- getCoreStatus(CoreContainer, String, boolean) - Method in class org.apache.solr.handler.admin.CoreAdminHandler
-
Returns the core status for a particular core.
- getCorrection() - Method in class org.apache.solr.spelling.SpellCheckCorrection
-
- 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
-
- getCost() - Method in class org.apache.solr.search.SolrConstantScoreQuery
-
- 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.util.stats.Histogram
-
Returns the number of values recorded.
- getCount() - Method in class org.apache.solr.util.stats.Meter
-
- getCount() - Method in class org.apache.solr.util.stats.Timer
-
- getCounts(SolrIndexSearcher, DocSet, String, int, int, int, boolean, String, String) - Static method in class org.apache.solr.request.DocValuesFacets
-
- getCounts(SolrIndexSearcher, DocSet, int, int, Integer, boolean, String, String) - Method in class org.apache.solr.request.UnInvertedField
-
- 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
-
- getCumulativeEvictions() - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- getCumulativeEvictions() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- getCumulativeHits() - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- getCumulativeHits() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- getCumulativeLookups() - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- getCumulativeLookups() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- getCumulativeMisses() - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- getCumulativeMisses() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- getCumulativeNonLivePuts() - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- getCumulativeNonLivePuts() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- getCumulativePuts() - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- getCumulativePuts() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- getCurrency(String) - Static method in class org.apache.solr.schema.CurrencyField
-
A wrapper arround Currency.getInstance
that returns null
instead of throwing IllegalArgumentException
if the specified Currency does not exist in this JVM.
- getCurrentCapacity() - Method in class org.apache.solr.util.LongPriorityQueue
-
- getCurrentDescriptors() - Method in class org.apache.solr.cloud.CurrentCoreDescriptorProvider
-
- getCurrentSize() - Method in class org.apache.solr.util.ConcurrentLFUCache.Stats
-
- getCurrentSize() - Method in class org.apache.solr.util.ConcurrentLRUCache.Stats
-
- getCursorMark() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- getCursorMark() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- 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
- 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
-
- getDataDir() - Method in class org.apache.solr.core.SolrResourceLoader
-
- getDataHome(CoreDescriptor) - Method in class org.apache.solr.core.DirectoryFactory
-
- getDataHome(CoreDescriptor) - Method in class org.apache.solr.core.HdfsDirectoryFactory
-
- getDBQNewer(long) - Method in class org.apache.solr.update.UpdateLog
-
- getDebugFilter() - Method in class org.apache.solr.client.solrj.embedded.JettySolrRunner
-
- getDebugInfo() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- 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
-
- getDefaultCoreName() - Method in class org.apache.solr.core.ConfigSolr
-
- getDefaultCoreName() - Method in class org.apache.solr.core.ConfigSolrXml
-
- getDefaultCoreName() - Method in class org.apache.solr.core.ConfigSolrXmlOld
-
- getDefaultCoreName() - Method in class org.apache.solr.core.CoreContainer
-
the default core name, or null if there is no default core name
- getDefaultField() - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- getDefaultField(IndexSchema, String) - Static method in class org.apache.solr.search.QueryParsing
-
Returns the effective default field based on the 'df' param or
hardcoded schema default.
- 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
-
- getDefaultLuceneMatchVersion() - Method in class org.apache.solr.schema.IndexSchema
-
The Default Lucene Match Version for this IndexSchema
- 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
- getDefaultSearchFieldName() - Method in class org.apache.solr.schema.IndexSchema
-
Name of the default search field specified in the schema file.
- 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
-
- getDefaultValue() - Method in class org.apache.solr.schema.SchemaField
-
- getDefaultValue() - Method in class org.apache.solr.update.processor.AbstractDefaultValueUpdateProcessorFactory.DefaultValueUpdateProcessor
-
- 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
-
- getDelegate() - Method in class org.apache.solr.search.DelegatingCollector
-
- getDelegate() - Method in class org.apache.solr.search.grouping.collector.FilterCollector
-
Returns the delegate collector
- getDeleteByQuery(long) - 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
-
- getDelimiter() - Method in class org.apache.solr.internal.csv.writer.CSVConfig
-
- getDescription() - Method in class org.apache.solr.core.RequestHandlers.LazyRequestHandlerWrapper
-
- getDescription() - Method in class org.apache.solr.core.SolrCore
-
- getDescription() - Method in interface org.apache.solr.core.SolrInfoMBean
-
Simple one or two line description
- getDescription() - Method in class org.apache.solr.handler.admin.AdminHandlers
-
- getDescription() - Method in class org.apache.solr.handler.admin.CollectionsHandler
-
- getDescription() - Method in class org.apache.solr.handler.admin.CoreAdminHandler
-
- 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.PluginInfoHandler
-
- getDescription() - Method in class org.apache.solr.handler.admin.PropertiesRequestHandler
-
- 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.BinaryUpdateRequestHandler
-
Deprecated.
- getDescription() - Method in class org.apache.solr.handler.component.DebugComponent
-
- 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.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.CSVRequestHandler
-
Deprecated.
- 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.JsonUpdateRequestHandler
-
Deprecated.
- getDescription() - Method in class org.apache.solr.handler.MoreLikeThisHandler
-
- 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.StandardRequestHandler
-
- getDescription() - Method in class org.apache.solr.handler.UpdateRequestHandler
-
- getDescription() - Method in class org.apache.solr.handler.XmlUpdateRequestHandler
-
Deprecated.
- getDescription() - Method in class org.apache.solr.handler.XsltUpdateRequestHandler
-
Deprecated.
- 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.FastLRUCache
-
- getDescription() - Method in class org.apache.solr.search.function.FileFloatSource.ReloadCacheRequestHandler
-
- getDescription() - Method in class org.apache.solr.search.LFUCache
-
- getDescription() - Method in class org.apache.solr.search.LRUCache
-
- getDescription() - Method in class org.apache.solr.search.QParserPlugin
-
- getDescription() - Method in class org.apache.solr.search.SolrFieldCacheMBean
-
- getDescription() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getDescription() - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- 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
-
- 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
-
- getDirectory() - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- 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
-
- getDispatchFilter() - Method in class org.apache.solr.client.solrj.embedded.JettySolrRunner
-
- getDistributedConnectionTimeout() - Method in class org.apache.solr.core.ConfigSolr
-
- getDistributedSocketTimeout() - Method in class org.apache.solr.core.ConfigSolr
-
- getDoc(Document) - Method in class org.apache.solr.response.BinaryResponseWriter.Resolver
-
- getDocIdSet(Map, AtomicReaderContext, Bits) - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
-
- getDocIdSet(Map, AtomicReaderContext, Bits) - Method in class org.apache.solr.search.SolrFilter
-
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.solr.search.SolrFilter
-
- getDocList(GroupDocs) - Method in class org.apache.solr.search.Grouping.Command
-
- 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, 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, DocSet, Sort, int, int) - Method in class org.apache.solr.search.SolrIndexSearcher
-
Returns documents matching both query
and filter
and sorted by sort
.
- getDocList() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryResult
-
- 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, 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, 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
.
- getDocListAndSet() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryResult
-
- getDocs() - Method in class org.apache.solr.core.RequestHandlers.LazyRequestHandlerWrapper
-
- getDocs() - Method in class org.apache.solr.core.SolrCore
-
- getDocs() - Method in interface org.apache.solr.core.SolrInfoMBean
-
Documentation URL list.
- getDocs() - Method in class org.apache.solr.handler.admin.AdminHandlers
-
- getDocs() - Method in class org.apache.solr.handler.admin.LukeRequestHandler
-
- getDocs() - Method in class org.apache.solr.handler.component.DebugComponent
-
- getDocs() - Method in class org.apache.solr.handler.component.FacetComponent
-
- getDocs() - Method in class org.apache.solr.handler.component.HighlightComponent
-
- getDocs() - Method in class org.apache.solr.handler.component.MoreLikeThisComponent
-
- getDocs() - Method in class org.apache.solr.handler.component.QueryComponent
-
- getDocs() - Method in class org.apache.solr.handler.component.QueryElevationComponent
-
- getDocs() - Method in class org.apache.solr.handler.component.RealTimeGetComponent
-
- getDocs() - Method in class org.apache.solr.handler.component.SearchComponent
-
- getDocs() - Method in class org.apache.solr.handler.MoreLikeThisHandler
-
- getDocs() - Method in class org.apache.solr.handler.RealTimeGetHandler
-
- getDocs() - Method in class org.apache.solr.handler.RequestHandlerBase
-
- getDocs() - Method in class org.apache.solr.handler.StandardRequestHandler
-
- getDocs() - Method in class org.apache.solr.highlight.HighlightingPluginBase
-
- getDocs() - Method in class org.apache.solr.search.LFUCache
-
- getDocs() - Method in class org.apache.solr.search.QParserPlugin
-
- getDocs() - Method in class org.apache.solr.search.SolrCacheBase
-
- getDocs() - Method in class org.apache.solr.search.SolrFieldCacheMBean
-
- getDocs() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getDocs() - Method in class org.apache.solr.search.SortedIntDocSet
-
- getDocs() - Method in class org.apache.solr.update.DirectUpdateHandler2
-
- getDocSet() - Method in class org.apache.solr.search.DocSetCollector
-
- getDocSet() - Method in class org.apache.solr.search.DocSetDelegateCollector
-
- getDocSet(Query) - Method in class org.apache.solr.search.SolrIndexSearcher
-
Returns the set of document ids matching a query.
- getDocSet(List<Query>) - Method in class org.apache.solr.search.SolrIndexSearcher
-
Returns the set of document ids matching all queries.
- getDocSet(SolrIndexSearcher.DocsEnumState) - Method in class org.apache.solr.search.SolrIndexSearcher
-
lucene.internal
- 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() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryResult
-
- getDocSetNC(Query, DocSet) - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getDocument() - Method in class org.apache.solr.core.Config
-
- getDocValuesFormat() - Method in class org.apache.solr.schema.FieldType
-
- getDouble(String) - Method in class org.apache.solr.core.Config
-
- getDouble(String, double) - Method in class org.apache.solr.core.Config
-
- getDurationUnit() - Method in class org.apache.solr.util.stats.Timer
-
Returns the timer's duration scale unit.
- getDynamicCopyFields() - Method in class org.apache.solr.schema.IndexSchema
-
- getDynamicFieldPrototypes() - Method in class org.apache.solr.schema.IndexSchema
-
- getDynamicFields() - Method in class org.apache.solr.schema.IndexSchema
-
- getDynamicFieldsWithFieldType(FieldType) - Method in class org.apache.solr.rest.schema.FieldTypeCollectionResource
-
Returns dynamic field lists from the map constructed in doInit()
- getDynamicFieldsWithFieldType(FieldType) - Method in class org.apache.solr.rest.schema.FieldTypeResource
-
Returns a dynamic field list using the given field type by iterating over all
dynamic fields defined in the schema.
- 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
-
- getElapsedTime() - Method in class org.apache.solr.cloud.OverseerSolrResponse
-
- 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.
- getEndColumn() - Method in interface org.apache.solr.parser.CharStream
-
Returns the column number of the last character for current token (being
matched after the last call to BeginTOken).
- getEndColumn() - Method in class org.apache.solr.parser.FastCharStream
-
- getEndLine() - Method in interface org.apache.solr.parser.CharStream
-
Returns the line number of the last character for current token (being
matched after the last call to BeginTOken).
- getEndLine() - Method in class org.apache.solr.parser.FastCharStream
-
- getEndTime() - Method in class org.apache.solr.response.SolrQueryResponse
-
Get the time in milliseconds when the response officially finished.
- getErrHeader() - Method in class org.apache.solr.handler.ContentStreamLoader
-
- getErrorInfo(Throwable, NamedList, Logger) - Static method in class org.apache.solr.servlet.ResponseUtils
-
Adds the given Throwable's message to the given NamedList.
- getErrors() - Method in class org.apache.solr.update.SolrCmdDistributor
-
- getErrors() - Method in class org.apache.solr.update.StreamingSolrServers
-
- getEscape() - Method in class org.apache.solr.internal.csv.CSVStrategy
-
- getEtagSeed() - Method in class org.apache.solr.core.SolrConfig.HttpCachingConfig
-
- getEventType() - Method in class org.apache.solr.util.stats.Meter
-
- getEventType() - Method in class org.apache.solr.util.stats.Timer
-
- getException() - Method in class org.apache.solr.handler.component.ShardResponse
-
- getException() - Method in class org.apache.solr.response.SolrQueryResponse
-
Returns an Exception if there was a fatal error in processing the request.
- getExchangeRate(String, String) - Method in interface org.apache.solr.schema.ExchangeRateProvider
-
Get the exchange rate betwen the two given currencies
- getExchangeRate(String, String) - Method in class org.apache.solr.schema.OpenExchangeRatesOrgProvider
-
Returns the currently known exchange rate between two currencies.
- 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.
- getExternalSubset(String, String) - Method in class org.apache.solr.util.SystemIdResolver
-
- getFacetCounts() - Method in class org.apache.solr.request.SimpleFacets
-
Looks at various Params to determining if any simple Facet Constraint count
computations are desired.
- getFacetDateCounts() - Method in class org.apache.solr.request.SimpleFacets
-
Deprecated.
Use getFacetRangeCounts which is more generalized
- getFacetDateCounts(String, NamedList<Object>) - Method in class org.apache.solr.request.SimpleFacets
-
Deprecated.
Use getFacetRangeCounts which is more generalized
- 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.
- 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.request.SimpleFacets
-
Returns a list of value constraints and the associated facet
counts for each facet numerical field, range, and interval
specified in the SolrParams
- getFacetTermEnumCounts(SolrIndexSearcher, DocSet, String, int, int, int, boolean, String, String) - 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.
- getFactories() - Method in class org.apache.solr.update.processor.UpdateRequestProcessorChain
-
Returns the underlying array of factories used in this chain.
- getField(String) - Method in class org.apache.solr.internal.csv.writer.CSVConfig
-
- 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() - Method in class org.apache.solr.search.FieldParams
-
- getField() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
-
- getFieldCacheCounts(SolrIndexSearcher, DocSet, String, int, int, int, boolean, String, String) - Static method in class org.apache.solr.request.SimpleFacets
-
Use the Lucene FieldCache to get counts for each unique field value in docs
.
- getFieldFlags() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- getFieldFlagsKey() - Static method in class org.apache.solr.handler.admin.LukeRequestHandler
-
- 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(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
- 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, int) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- getFieldQuery(String, String, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- 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.CurrencyField
-
- 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.LatLonType
-
- getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.PointType
-
- getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.TextField
-
- getFieldQuery(QParser, SchemaField, String) - Method in class org.apache.solr.schema.TrieField
-
- getFieldQuery(String, String, boolean) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
-
- getFieldQuery(String, String, int) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
-
- getFieldQuery(String, String, 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.
- getFields() - Method in class org.apache.solr.internal.csv.writer.CSVConfig
-
- 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
-
- getFieldsWithDefaultValue() - Method in class org.apache.solr.schema.IndexSchema
-
Provides direct access to the List containing all fields with a default value
- getFieldsWithFieldType(FieldType) - Method in class org.apache.solr.rest.schema.FieldTypeCollectionResource
-
Returns field lists from the map constructed in doInit()
- getFieldsWithFieldType(FieldType) - Method in class org.apache.solr.rest.schema.FieldTypeResource
-
Returns a field list using the given field type by iterating over all fields
defined in the schema.
- getFieldType() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.AnalysisContext
-
- 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
-
- 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
- getFifteenMinuteRate() - Method in class org.apache.solr.util.stats.Meter
-
- getFifteenMinuteRate() - Method in class org.apache.solr.util.stats.Timer
-
- getFile() - Method in class org.apache.solr.store.blockcache.BlockCacheKey
-
- getFileFilterFromFileTypes(String) - Method in class org.apache.solr.util.SimplePostTool
-
- 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.
- getFilePointer() - Method in class org.apache.solr.store.blockcache.CustomBufferedIndexInput
-
- getFilePointer() - Method in class org.apache.solr.store.blockcache.ReusedBufferedIndexOutput
-
- getFilePointer() - Method in class org.apache.solr.store.hdfs.NullIndexOutput
-
- getFileSystem() - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- getFill() - Method in class org.apache.solr.internal.csv.writer.CSVConfig
-
- getFill() - Method in class org.apache.solr.internal.csv.writer.CSVField
-
- getFillChar() - Method in class org.apache.solr.internal.csv.writer.CSVConfig
-
- getFilter() - Method in class org.apache.solr.search.SolrConstantScoreQuery
-
Returns the encapsulated filter
- getFilter() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- 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 it's filters, but before any sorting or grouping collectors
- getFilterList() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- getFilters() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- 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.util.stats.Meter
-
- getFiveMinuteRate() - Method in class org.apache.solr.util.stats.Timer
-
- getFlags() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- getFlags() - Method in class org.apache.solr.update.UpdateCommand
-
- getFloat(String) - Method in class org.apache.solr.core.Config
-
- getFloat(String, float) - Method in class org.apache.solr.core.Config
-
- 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
-
- 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
-
- 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, BoundaryScanner) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
-
- getFragmentsBuilder(SolrParams, String[], String[], BoundaryScanner) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
-
- getFs() - Method in class org.apache.solr.update.UpdateLog
-
- 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
-
- getGenericCoreNodeNames() - Method in class org.apache.solr.core.ConfigSolr
-
- getGlobbedId(String) - Method in class org.apache.solr.search.QueryParsing.StrParser
-
- getGroupedCounts(SolrIndexSearcher, DocSet, String, boolean, int, int, int, boolean, String, String) - Method in class org.apache.solr.request.SimpleFacets
-
- getGroupedFacetQueryCount(Query) - 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
-
- getGroupLimit() - Method in class org.apache.solr.search.grouping.GroupingSpecification
-
- getGroupOffset() - Method in class org.apache.solr.search.grouping.GroupingSpecification
-
- 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
-
- getGroupSort() - Method in class org.apache.solr.search.grouping.GroupingSpecification
-
- getHandlerClass() - Method in class org.apache.solr.core.RequestHandlers.LazyRequestHandlerWrapper
-
- getHashableId() - Method in class org.apache.solr.update.AddUpdateCommand
-
- getHdfsDirPath() - Method in class org.apache.solr.store.hdfs.HdfsDirectory
-
- getHead(Handler) - Method in class org.apache.solr.SolrLogFormatter
-
- getHiddenFiles() - Method in class org.apache.solr.handler.admin.ShowFileRequestHandler
-
- getHighlighter(SolrCore) - Static method in class org.apache.solr.handler.component.HighlightComponent
-
- getHighlighter() - Method in class org.apache.solr.handler.component.HighlightComponent
-
- getHighlighter(Query, String, SolrQueryRequest) - Method in class org.apache.solr.highlight.DefaultSolrHighlighter
-
- 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
-
- 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
-
- getHost() - Method in class org.apache.solr.core.ConfigSolr
-
- 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
-
- getHttpCachingConfig() - Method in class org.apache.solr.core.SolrConfig
-
- getHttpClient() - Method in class org.apache.solr.update.StreamingSolrServers
-
- getHttpClient() - Method in class org.apache.solr.update.UpdateShardHandler
-
- getId() - Method in class org.apache.solr.cloud.DistributedQueue.QueueEvent
-
- getId() - Method in class org.apache.solr.update.DeleteUpdateCommand
-
- getIdSet() - Method in class org.apache.solr.response.transform.BaseEditorialTransformer
-
- 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
-
- GetImage() - Method in interface org.apache.solr.parser.CharStream
-
Returns a string made up of characters from the marked token beginning
to the current buffer position.
- GetImage() - Method in class org.apache.solr.parser.FastCharStream
-
- getIndexDir() - Method in class org.apache.solr.core.SolrCore
-
- getIndexDir() - Method in class org.apache.solr.spelling.AbstractLuceneSpellChecker
-
- getIndexedId() - Method in class org.apache.solr.update.AddUpdateCommand
-
Returns the indexed ID for this document.
- getIndexedId() - Method in class org.apache.solr.update.DeleteUpdateCommand
-
Returns the indexed ID for this delete.
- getIndexInfo(DirectoryReader, boolean) - Static method in class org.apache.solr.handler.admin.LukeRequestHandler
-
- getIndexInfo(DirectoryReader) - Static method in class org.apache.solr.handler.admin.LukeRequestHandler
-
- getIndexOptions(SchemaField, String) - Method in class org.apache.solr.schema.FieldType
-
- getIndexReader() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getIndexReaderFactory() - Method in class org.apache.solr.core.SolrCore
-
- getIndexWriter(SolrCore) - Method in class org.apache.solr.update.DefaultSolrCoreState
-
- getIndexWriter(SolrCore) - Method in class org.apache.solr.update.SolrCoreState
-
Get the current IndexWriter.
- getInfo() - Method in class org.apache.solr.logging.LoggerInfo
-
- getInfoHandler() - Method in class org.apache.solr.core.CoreContainer
-
- getInfoHandlerClass() - Method in class org.apache.solr.core.ConfigSolr
-
- getInfoRegistry() - Method in class org.apache.solr.core.SolrCore
-
Returns a Map of name vs SolrInfoMBean objects.
- getInitArgs() - Method in class org.apache.solr.handler.RequestHandlerBase
-
- getInputDocument(SolrCore, BytesRef) - Static method in class org.apache.solr.handler.component.RealTimeGetComponent
-
- getInputDocumentFromTlog(SolrCore, BytesRef) - 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.
- getInputStream() - Method in class org.apache.solr.internal.csv.writer.CSVConfigGuesser
-
Allow override.
- getInQueue(SolrZkClient) - Static method in class org.apache.solr.cloud.Overseer
-
Get queue that can be used to send messages to Overseer.
- 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.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.FieldLengthUpdateProcessorFactory
-
- 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.IgnoreFieldUpdateProcessorFactory
-
- 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.NoOpDistributingUpdateProcessorFactory
-
Returns null
- 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.StatelessScriptUpdateProcessorFactory
-
- 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.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.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
-
- getInstanceDir() - Method in class org.apache.solr.core.SolrResourceLoader
-
- getInt(String) - Method in class org.apache.solr.core.Config
-
- getInt(String, int) - Method in class org.apache.solr.core.Config
-
- getInt(ConfigSolr.CfgProp, int) - Method in class org.apache.solr.core.ConfigSolr
-
- 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()].
- getInternalRank() - Method in class org.apache.solr.spelling.SpellCheckCollation
-
- getJvmInfo() - Static method in class org.apache.solr.handler.admin.SystemInfoHandler
-
Get JVM Info - including memory info
- getKey() - Method in class org.apache.solr.handler.component.FacetComponent.FacetBase
-
returns the key in the response that this facet will be under
- getKey(SolrDocument) - Method in class org.apache.solr.response.transform.BaseEditorialTransformer
-
- 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
-
- getKeyStore() - Method in class org.apache.solr.client.solrj.embedded.SSLConfig
-
- getKeyStorePassword() - Method in class org.apache.solr.client.solrj.embedded.SSLConfig
-
- getLastAccess() - Method in class org.apache.solr.store.blockcache.BlockCacheLocation
-
- 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
-
- getLastPublished() - Method in class org.apache.solr.cloud.CloudDescriptor
-
- getLatestAccessedItems(int) - Method in class org.apache.solr.util.ConcurrentLRUCache
-
- getLatestCommit() - Method in class org.apache.solr.core.IndexDeletionPolicyWrapper
-
Gets the most recent commit point
It is recommended to reserve a commit point for the duration of usage so that
it is not deleted by the underlying deletion policy
- getLatestFile(String, String) - Static method in class org.apache.solr.util.VersionedFile
-
- getLatestOperation() - Method in class org.apache.solr.update.UpdateLog.RecentUpdates
-
- getLatestSchema() - Method in class org.apache.solr.core.SolrCore
-
- getLeaderConflictResolveWait() - Method in class org.apache.solr.core.ConfigSolr
-
- getLeaderNode(SolrZkClient) - Static method in class org.apache.solr.cloud.OverseerCollectionProcessor
-
- 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.
- getLeaderVoteWait() - Method in class org.apache.solr.cloud.ZkController
-
- getLeaderVoteWait() - Method in class org.apache.solr.core.ConfigSolr
-
- getLeastUsedItems(int) - Method in class org.apache.solr.util.ConcurrentLFUCache
-
Returns 'n' number of least used entries present in this cache.
- getLen() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- getLength(FileSystem, Path) - Static method in class org.apache.solr.store.hdfs.HdfsFileReader
-
- getLevel() - Method in class org.apache.solr.logging.jul.JulInfo
-
- getLevel() - Method in class org.apache.solr.logging.log4j.Log4jInfo
-
- getLevel() - Method in class org.apache.solr.logging.LoggerInfo
-
- 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
-
- getLimit() - Method in class org.apache.solr.search.grouping.GroupingSpecification
-
- 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.
- getLine() - Method in interface org.apache.solr.parser.CharStream
-
Deprecated.
- getLine() - Method in class org.apache.solr.parser.FastCharStream
-
- 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
-
- getLivePaths() - Method in class org.apache.solr.core.CachingDirectoryFactory
-
Test only method for inspecting the cache
- getLocalParams(String, String) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- getLocalParams() - Method in class org.apache.solr.search.QParser
-
- 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")
- getLocalPort() - Method in class org.apache.solr.client.solrj.embedded.JettySolrRunner
-
Returns the Local Port of the jetty Server.
- getLockFactory() - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- getLockID() - Method in class org.apache.solr.store.blockcache.BlockDirectory
-
- getLockPath() - Method in class org.apache.solr.store.hdfs.HdfsLockFactory
-
- getLogDir() - Method in class org.apache.solr.update.HdfsUpdateLog
-
- getLogDir() - Method in class org.apache.solr.update.UpdateLog
-
- 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
-
- getLogId() - Method in class org.apache.solr.core.SolrCore
-
- getLogList(FileSystem, Path) - Static method in class org.apache.solr.update.HdfsUpdateLog
-
- getLogList(File) - Method in class org.apache.solr.update.UpdateLog
-
- getLogSize() - Method in class org.apache.solr.update.TransactionLog
-
- getLogWatcherConfig() - Method in class org.apache.solr.core.ConfigSolr
-
- 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
- getLowerVal() - Method in class org.apache.solr.search.function.ValueSourceRangeFilter
-
- getLuceneDocument() - Method in class org.apache.solr.update.AddUpdateCommand
-
Creates and returns a lucene Document to index.
- 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
-
- getLuceneVersion(String) - Method in class org.apache.solr.core.Config
-
- getLuceneVersion(String, Version) - Method in class org.apache.solr.core.Config
-
- getMainValuePrefix(FieldType) - Static method in class org.apache.solr.schema.TrieField
-
expert internal use, subject to change.
- getManagedSchemaResourceName() - Method in class org.apache.solr.schema.ManagedIndexSchemaFactory
-
- getManagementPath() - Method in class org.apache.solr.core.ConfigSolr
-
- 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.
- getMap() - Method in class org.apache.solr.util.ConcurrentLFUCache
-
- getMap() - Method in class org.apache.solr.util.ConcurrentLRUCache
-
- getMarkerChar() - Method in class org.apache.solr.analysis.ReversedWildcardFilterFactory
-
- 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
-
Returns the number of matches for this Command
.
- getMatches() - Method in class org.apache.solr.search.Grouping.CommandFunc
-
Returns the number of matches for this Command
.
- getMatches() - Method in class org.apache.solr.search.Grouping.CommandQuery
-
Returns the number of matches for this Command
.
- getMatches() - Method in class org.apache.solr.search.grouping.distributed.command.QueryCommandResult
-
- getMax() - Method in class org.apache.solr.util.stats.Histogram
-
- getMax() - Method in class org.apache.solr.util.stats.Timer
-
Returns the longest recorded duration.
- 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
-
- getMaxOptimizedCommitsToKeep() - Method in class org.apache.solr.core.SolrDeletionPolicy
-
- getMaxPermits() - Method in class org.apache.solr.util.AdjustableSemaphore
-
- 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.core.ConfigSolr
-
- getMaxUpdateConnectionsPerHost() - Method in class org.apache.solr.core.ConfigSolr
-
- getMBeanInfo(SolrQueryRequest) - Method in class org.apache.solr.handler.admin.SolrInfoMBeanHandler
-
- getMean() - Method in class org.apache.solr.util.stats.Histogram
-
- getMean() - Method in class org.apache.solr.util.stats.Timer
-
Returns the arithmetic mean of all recorded durations.
- getMeanRate() - Method in class org.apache.solr.util.stats.Meter
-
- getMeanRate() - Method in class org.apache.solr.util.stats.Timer
-
- getMedian() - Method in class org.apache.solr.util.stats.Snapshot
-
Returns the median value in the distribution.
- getMessage() - Method in error org.apache.solr.parser.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMethod(String) - Static method in enum org.apache.solr.servlet.cache.Method
-
- getMin() - Method in class org.apache.solr.util.stats.Histogram
-
- getMin() - Method in class org.apache.solr.util.stats.Timer
-
Returns the shortest recorded duration.
- getMisspellingsAndCorrections() - Method in class org.apache.solr.spelling.SpellCheckCollation
-
- getMoreLikeThese(DocList, int, int) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
-
Deprecated.
- getMoreLikeTheseQuery(DocList) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
-
- getMoreLikeThis(int, int, int, List<Query>, List<MoreLikeThisHandler.InterestingTerm>, int) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
-
- getMoreLikeThis(Reader, int, int, List<Query>, List<MoreLikeThisHandler.InterestingTerm>, int) - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
-
- getMoreLikeThis() - Method in class org.apache.solr.handler.MoreLikeThisHandler.MoreLikeThisHelper
-
- getMostUsedItems(int) - Method in class org.apache.solr.util.ConcurrentLFUCache
-
Returns 'n' number of most used entries present in this cache.
- getMultiCoreHandler() - Method in class org.apache.solr.core.CoreContainer
-
- getMultipartUploadLimitKB() - Method in class org.apache.solr.core.SolrConfig
-
- getMultipleConfigs(SolrConfig, String) - Static method in class org.apache.solr.search.CacheConfig
-
- getMultiplicativeBoosts() - Method in class org.apache.solr.search.ExtendedDismaxQParser
-
Parses all multiplicative boosts
- 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.
- getMultiTermRewriteMethod() - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- getMultiValuedSeparatorChar(SolrParams) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
-
- getName() - Method in class org.apache.solr.core.Config
-
- getName() - Method in class org.apache.solr.core.CoreDescriptor
-
- getName() - Method in class org.apache.solr.core.RequestHandlers.LazyRequestHandlerWrapper
-
- getName() - Method in class org.apache.solr.core.SolrCore
-
- getName() - Method in interface org.apache.solr.core.SolrInfoMBean
-
Simple common usage name, e.g.
- getName() - Method in class org.apache.solr.handler.admin.AdminHandlers
-
- 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.internal.csv.writer.CSVField
-
- getName() - Method in class org.apache.solr.logging.jul.JulWatcher
-
- getName() - Method in class org.apache.solr.logging.log4j.Log4jInfo
-
- getName() - Method in class org.apache.solr.logging.log4j.Log4jWatcher
-
- 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.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.FastLRUCache
-
- getName() - Method in class org.apache.solr.search.LFUCache
-
- getName() - Method in class org.apache.solr.search.LRUCache
-
- getName() - Method in class org.apache.solr.search.QParserPlugin
-
- getName() - Method in class org.apache.solr.search.SolrFieldCacheMBean
-
- getName() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- 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
-
- getNamedPropertyValues(boolean) - Method in class org.apache.solr.schema.FieldType
-
Get a map of property name -> value for this field type.
- getNamedPropertyValues() - Method in class org.apache.solr.schema.IndexSchema
-
Get a map of property name -> value for the whole schema.
- getNamedPropertyValues(boolean) - Method in class org.apache.solr.schema.SchemaField
-
Get a map of property name -> value for this field.
- getNamedPropertyValues() - Method in class org.apache.solr.schema.SimilarityFactory
-
Returns a serializable description of this similarity(factory)
- getNewClock() - Method in class org.apache.solr.update.VersionInfo
-
- getNewestSearcher(boolean) - Method in class org.apache.solr.core.SolrCore
-
- getNewIndexDir() - Method in class org.apache.solr.core.SolrCore
-
Returns the indexdir as given in index.properties.
- getNextCursorMark() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- getNextCursorMark() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryResult
-
- 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(String, boolean) - Method in class org.apache.solr.core.Config
-
- getNode(String, Document, boolean) - Method in class org.apache.solr.core.Config
-
- getNodeList(String, boolean) - Method in class org.apache.solr.core.Config
-
- getNodeName(String) - Static method in class org.apache.solr.cloud.LeaderElector
-
- getNodeName() - Method in class org.apache.solr.cloud.ZkController
-
- getNodeName() - Method in class org.apache.solr.handler.component.ShardResponse
-
- getNodeProps() - Method in class org.apache.solr.update.SolrCmdDistributor.Node
-
- getNodeProps() - Method in class org.apache.solr.update.SolrCmdDistributor.StdNode
-
- getNodesForNewShard(ClusterState, String, int, int, int, String) - Static method in class org.apache.solr.cloud.Assign
-
- getNodesFromXP(Node, String) - Static method in class org.apache.solr.util.SimplePostTool
-
Gets all nodes matching an XPath
- getNonFieldPropertyArgs() - Method in class org.apache.solr.schema.FieldType
-
Returns args to this field type that aren't standard field properties
- 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.
- getNormalizedURL(String) - Method in class org.apache.solr.update.processor.URLClassifyProcessor
-
- getNOW() - Method in class org.apache.solr.request.SolrRequestInfo
-
- getNow() - Method in class org.apache.solr.util.DateMathParser
-
Returns a cloned of this instance's concept of "now".
- 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
-
- getNumberOfAccesses() - Method in class org.apache.solr.store.blockcache.BlockCacheLocation
-
- 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
-
Returns the number of groups found for this Command
.
- getNumberOfGroups() - Method in class org.apache.solr.search.Grouping.CommandFunc
-
Returns the number of groups found for this Command
.
- getNumberOfOccurences() - Method in class org.apache.solr.spelling.SpellCheckCorrection
-
- getNumberScanned() - Method in exception org.apache.solr.search.EarlyTerminatingCollectorException
-
- getNumericType() - 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.
- getNumericType() - Method in class org.apache.solr.schema.TrieDateField
-
- getNumericType() - Method in class org.apache.solr.schema.TrieField
-
- getNumShards() - Method in class org.apache.solr.cloud.CloudDescriptor
-
- getNumTerms() - Method in class org.apache.solr.request.UnInvertedField
-
- getObjectFrom(String, String) - Static method in class org.apache.solr.response.transform.ValueAugmenterFactory
-
- getOffset() - Method in class org.apache.solr.search.grouping.GroupingSpecification
-
- getOffset() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- getOffset() - Method in class org.apache.solr.search.SortSpec
-
Offset into the list of results.
- 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.util.stats.Meter
-
- getOneMinuteRate() - Method in class org.apache.solr.util.stats.Timer
-
- getOpenCount() - Method in class org.apache.solr.core.SolrCore
-
Current core usage count.
- getOpenSearcher() - Method in class org.apache.solr.update.CommitTracker
-
- getOpenTime() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getOptions() - Method in class org.apache.solr.search.ExtendedQueryBase
-
- getOptionsString(ExtendedQuery) - Static method in class org.apache.solr.search.ExtendedQueryBase
-
- getOriginal() - Method in class org.apache.solr.spelling.SpellCheckCorrection
-
- getOriginalAsString() - Method in class org.apache.solr.spelling.SpellCheckCorrection
-
- getOriginalConfig() - Method in class org.apache.solr.core.Config
-
- getOriginalParams() - Method in interface org.apache.solr.request.SolrQueryRequest
-
Returns the original request parameters.
- getOriginalParams() - Method in class org.apache.solr.request.SolrQueryRequestBase
-
- getOverseer() - Method in class org.apache.solr.cloud.ZkController
-
- getOverseerCollectionQueue() - Method in class org.apache.solr.cloud.ZkController
-
- getOverseerElector() - Method in class org.apache.solr.cloud.ZkController
-
- getOverseerJobQueue() - Method in class org.apache.solr.cloud.ZkController
-
- getOverwriteDupes() - Method in class org.apache.solr.update.processor.SignatureUpdateProcessorFactory
-
- getParam(String) - Method in class org.apache.solr.search.QParser
-
check both local and global params
- getParameter(NamedList, String, T) - Method in class org.apache.solr.handler.component.HttpShardHandlerFactory
-
- getParams() - Method in class org.apache.solr.cloud.CloudDescriptor
-
Optional parameters that can change how a core is created.
- 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
-
- 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
-
- getParentFilterLocalParamName() - Method in class org.apache.solr.search.join.BlockJoinChildQParser
-
- getParsedResponse(SolrQueryRequest, SolrQueryResponse) - Method in class org.apache.solr.client.solrj.embedded.EmbeddedSolrServer
-
- 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...
- getParseMultipleSources() - Method in class org.apache.solr.search.FunctionQParser
-
parse multiple comma separated value sources
- getParser(Map<String, Float>, String, SolrParams, float) - Method in class org.apache.solr.search.DisMaxQParser
-
- getParser(String, String, SolrQueryRequest) - Static method in class org.apache.solr.search.QParser
-
Create a QParser
to parse qstr
,
assuming that the default query parser is defaultParser
.
- getParseToEnd() - Method in class org.apache.solr.search.FunctionQParser
-
throw exception if there is extra stuff at the end of the parsed valuesource(s).
- getPath() - Method in class org.apache.solr.search.SolrIndexSearcher
-
- getPathPrefix() - Method in class org.apache.solr.servlet.SolrDispatchFilter
-
- 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, CachingTokenFilter) - 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.
- 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.
- getPosition(long) - Static method in class org.apache.solr.store.blockcache.BlockDirectory
-
- getPosition() - Method in class org.apache.solr.store.hdfs.HdfsFileWriter
-
- getPositionIncrementGap(String) - Method in class org.apache.solr.analysis.SolrAnalyzer
-
- getPositions() - Method in interface org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttribute
-
- getPositions() - Method in class org.apache.solr.handler.AnalysisRequestHandlerBase.TokenTrackingAttributeImpl
-
- getPostingsFormat() - Method in class org.apache.solr.schema.FieldType
-
- getPostTags(SolrParams, String) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
-
- getPrecisionStep() - Method in class org.apache.solr.schema.TrieDateField
-
- getPrecisionStep() - Method in class org.apache.solr.schema.TrieField
-
- getPrefixQuery(String, String) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- 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(String, String) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
-
- getPreTags(SolrParams, String) - Method in class org.apache.solr.highlight.SolrFragmentsBuilder
-
- getPrintableId() - Method in class org.apache.solr.update.AddUpdateCommand
-
- getPrinterNewline() - Method in class org.apache.solr.internal.csv.CSVStrategy
-
- getProcessedFilter(DocSet, List<Query>) - Method in class org.apache.solr.search.SolrIndexSearcher
-
- 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
-
- getProperty(String, String, String) - Method in class org.apache.solr.core.ConfigSolrXmlOld
-
- getPrototype() - Method in class org.apache.solr.schema.IndexSchema.DynamicField
-
- getProvider() - Method in class org.apache.solr.schema.CurrencyField
-
- getQparser() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- getQueries(ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias) - Method in class org.apache.solr.search.ExtendedDismaxQParser.ExtendedSolrQueryParser
-
- getQueries() - Method in class org.apache.solr.search.grouping.GroupingSpecification
-
- getQuery() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
- 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.SolrConstantScoreQuery.ConstantWeight
-
- getQuery() - Method in class org.apache.solr.search.SolrIndexSearcher.QueryCommand
-
- getQuery() - Method in class org.apache.solr.update.DeleteUpdateCommand
-
- 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
-
- getQueryAnalyzer() - Method in class org.apache.solr.spelling.ConjunctionSolrSpellChecker
-
- getQueryAnalyzer() - Method in class org.apache.solr.spelling.SolrSpellChecker
-
- getQueryCommand() - Method in class org.apache.solr.handler.component.ResponseBuilder
-
Creates a SolrIndexSearcher.QueryCommand from this
ResponseBuilder.
- getQueryParserDefaultOperator() - Method in class org.apache.solr.schema.IndexSchema
-
default operator ("AND" or "OR") for QueryParser
- getQueryParserDefaultOperator(IndexSchema, String) - Static method in class org.apache.solr.search.QueryParsing
-
Returns the "preferred" default operator for use by Query Parsers,
based on the settings in the IndexSchema which may be overridden using
an optional String override value.
- 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.
- 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.
- getRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.solr.parser.SolrQueryParserBase
-
- getRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.AbstractSpatialFieldType
-
- getRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.CollationField
-
- getRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.CurrencyField
-
- getRangeQuery(QParser, SchemaField, CurrencyValue, CurrencyValue, boolean, boolean) - Method in class org.apache.solr.schema.CurrencyField
-
- getRangeQuery(QParser, SchemaField, Date, Date, boolean, boolean) - Method in class org.apache.solr.schema.DateField
-
Deprecated.
DateField specific range query
- getRangeQuery(QParser, SchemaField, String, String, boolean, boolean) - Method in class org.apache.solr.schema.EnumField
-
Returns a Query instance for doing range searches on this field