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

A

A - Variable in class org.apache.lucene.spatial.geometry.shape.LineSegment
Deprecated.
 
abort() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.
 
ABSOLUTE_MIN_SORT_BUFFER_SIZE - Static variable in class org.apache.lucene.search.suggest.fst.Sort
Absolute minimum required buffer size for sorting.
AbstractAllGroupHeadsCollector<GH extends AbstractAllGroupHeadsCollector.GroupHead> - Class in org.apache.lucene.search.grouping
This collector specializes in collecting the most relevant document (group head) for each group that match the query.
AbstractAllGroupHeadsCollector(int) - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
 
AbstractAllGroupHeadsCollector.GroupHead<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
Represents a group head.
AbstractAllGroupHeadsCollector.GroupHead(GROUP_VALUE_TYPE, int) - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.GroupHead
 
AbstractAllGroupHeadsCollector.TemporalResult - Class in org.apache.lucene.search.grouping
Contains the result of group head retrieval.
AbstractAllGroupHeadsCollector.TemporalResult() - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.TemporalResult
 
AbstractAllGroupsCollector<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
A collector that collects all groups that match the query.
AbstractAllGroupsCollector() - Constructor for class org.apache.lucene.search.grouping.AbstractAllGroupsCollector
 
AbstractAllTermDocs - Class in org.apache.lucene.index
Base class for enumerating all but deleted docs.
AbstractAllTermDocs(int) - Constructor for class org.apache.lucene.index.AbstractAllTermDocs
 
AbstractEncoder - Class in org.apache.lucene.analysis.payloads
Base class for payload encoders.
AbstractEncoder() - Constructor for class org.apache.lucene.analysis.payloads.AbstractEncoder
 
AbstractField - Class in org.apache.lucene.document
Base class for Field implementations
AbstractField() - Constructor for class org.apache.lucene.document.AbstractField
 
AbstractField(String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.AbstractField
 
AbstractFirstPassGroupingCollector<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
FirstPassGroupingCollector is the first of two passes necessary to collect grouped hits.
AbstractFirstPassGroupingCollector(Sort, int) - Constructor for class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
Create the first pass collector.
AbstractQueryConfig - Class in org.apache.lucene.queryParser.core.config
This class is the base of QueryConfigHandler and FieldConfig.
AbstractQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
Abstract base query maker.
AbstractQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
 
AbstractRangeQueryNode<T extends FieldValuePairQueryNode<?>> - Class in org.apache.lucene.queryParser.standard.nodes
This class should be extended by nodes intending to represent range queries.
AbstractRangeQueryNode() - Constructor for class org.apache.lucene.queryParser.standard.nodes.AbstractRangeQueryNode
Constructs an AbstractRangeQueryNode, it should be invoked only by its extenders.
AbstractSecondPassGroupingCollector<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
SecondPassGroupingCollector is the second of two passes necessary to collect grouped docs.
AbstractSecondPassGroupingCollector(Collection<SearchGroup<GROUP_VALUE_TYPE>>, Sort, Sort, int, boolean, boolean, boolean) - Constructor for class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
 
AbstractSecondPassGroupingCollector.SearchGroupDocs<GROUP_VALUE_TYPE> - Class in org.apache.lucene.search.grouping
 
AbstractSecondPassGroupingCollector.SearchGroupDocs(GROUP_VALUE_TYPE, TopDocsCollector<?>) - Constructor for class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector.SearchGroupDocs
 
accept() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
Override this method and return if the current input token should be returned by FilteringTokenFilter.incrementToken().
accept() - Method in class org.apache.lucene.analysis.ja.JapanesePartOfSpeechStopFilter
 
accept() - Method in class org.apache.lucene.analysis.LengthFilter
 
accept(AttributeSource) - Method in class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
 
accept(AttributeSource) - Method in class org.apache.lucene.analysis.sinks.TokenRangeSinkFilter
 
accept(AttributeSource) - Method in class org.apache.lucene.analysis.sinks.TokenTypeSinkFilter
 
accept() - Method in class org.apache.lucene.analysis.StopFilter
Returns the next input Token whose term() is not a stop word.
accept(AttributeSource) - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkFilter
Returns true, iff the current state of the passed-in AttributeSource shall be stored in the sink.
accept() - Method in class org.apache.lucene.analysis.TypeTokenFilter
By default accept the token if its type is not a stop type.
accept(String) - Method in interface org.apache.lucene.document.FieldSelector
 
accept(String) - Method in class org.apache.lucene.document.LoadFirstFieldSelector
 
accept(String) - Method in class org.apache.lucene.document.MapFieldSelector
Load field according to its associated value in fieldSelections
accept(String) - Method in class org.apache.lucene.document.SetBasedFieldSelector
Indicate whether to load the field with the given name or not.
accept(File, String) - Method in class org.apache.lucene.index.IndexFileNameFilter
 
accept(IndexReader, int, String, TermVectorMapper) - Method in class org.apache.lucene.index.TermVectorAccessor
Visits the TermVectorMapper and populates it with terms available for a given document, either via a vector created at index time or by resolving them from the inverted index.
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
Implementing classes are required to return whether the current position is a match for the passed in "match" SpanQuery.
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.facet.search.FacetsCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CachingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CheckHits.SetCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.Collector
Return true if this collector does not require the matching docIDs to be delivered in int sort order (smallest to largest) to Collector.collect(int).
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractAllGroupsCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.join.ToParentBlockJoinCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.MultiCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TimeLimitingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TopFieldCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TotalHitCountCollector
 
accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
 
accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.FacetsAccumulator
Accumulate facets over given documents, according to facet requests in effect.
accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.sampling.SamplingAccumulator
 
accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.SamplingWrapper
 
accumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.StandardFacetsAccumulator
 
acquire() - Method in class org.apache.lucene.search.ReferenceManager
Obtain the current reference.
acquire(long) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Retrieve a previously recorded IndexSearcher, if it has not yet been closed NOTE: this may return null when the requested searcher has already timed out.
acquireWriteLock() - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
ACRONYM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
ACRONYM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
ACRONYM_DEP - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
Deprecated.
this solves a bug where HOSTs that end with '.' are identified as ACRONYMs.
ACRONYM_DEP - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated.
this solves a bug where HOSTs that end with '.' are identified as ACRONYMs.
ACRONYM_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
actualDocsToAccumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.sampling.SamplingAccumulator
 
actualDocsToAccumulate(ScoredDocIDs) - Method in class org.apache.lucene.facet.search.StandardFacetsAccumulator
Set the actual set of documents over which accumulation should take place.
actualEnum - Variable in class org.apache.lucene.search.FilteredTermEnum
the delegate enum - to set this member use FilteredTermEnum.setEnum(org.apache.lucene.index.TermEnum)
actualSampleRatio - Variable in class org.apache.lucene.facet.search.sampling.Sampler.SampleResult
 
AdaptiveFacetsAccumulator - Class in org.apache.lucene.facet.search
FacetsAccumulator whose behavior regarding complements, sampling, etc. is not set up front but rather is determined at accumulation time according to the statistics of the accumulated set of documents and the index.
AdaptiveFacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader) - Constructor for class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
AdaptiveFacetsAccumulator(FacetSearchParams, IndexReader, TaxonomyReader, IntArrayAllocator, FloatArrayAllocator) - Constructor for class org.apache.lucene.facet.search.AdaptiveFacetsAccumulator
add(Object) - Method in class org.apache.lucene.analysis.CharArraySet
 
add(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
Add this CharSequence into the set
add(String) - Method in class org.apache.lucene.analysis.CharArraySet
Add this String into the set
add(char[]) - Method in class org.apache.lucene.analysis.CharArraySet
Add this char[] directly to the set.
add(AttributeSource.State) - Method in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
 
add(String, String) - Method in class org.apache.lucene.analysis.NormalizeCharMap
Records a replacement to be applied to the inputs stream.
add(Reader) - Method in class org.apache.lucene.analysis.synonym.SolrSynonymParser
 
add(CharsRef, CharsRef, boolean) - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
Add a phrase->phrase synonym mapping.
add(Reader) - Method in class org.apache.lucene.analysis.synonym.WordnetSynonymParser
 
add(TaskStats) - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
Add data from another stat, for aggregation
add(Fieldable) - Method in class org.apache.lucene.document.Document
Adds a field to a document.
add(T) - Method in interface org.apache.lucene.facet.search.Heap
Add a new value to the heap, return the new top().
add(CharSequence) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Add the given component to the end of the path.
add(CharSequence, char) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Add the given components to the end of the path.
add(FieldInfos) - Method in class org.apache.lucene.index.FieldInfos
 
add(Document) - Method in class org.apache.lucene.index.FieldInfos
Adds field info for a Document.
add(String, boolean) - Method in class org.apache.lucene.index.FieldInfos
Calls 5 parameter add with false for all TermVector parameters.
add(String, boolean, boolean) - Method in class org.apache.lucene.index.FieldInfos
Calls 5 parameter add with false for term vector positions and offsets.
add(String, boolean, boolean, boolean) - Method in class org.apache.lucene.index.FieldInfos
If the field is not yet known, adds it.
add(String, boolean, boolean, boolean, boolean, FieldInfo.IndexOptions) - Method in class org.apache.lucene.index.FieldInfos
If the field is not yet known, adds it.
add(FieldInfo) - Method in class org.apache.lucene.index.FieldInfos
 
add(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
 
add(IndexReader) - Method in class org.apache.lucene.index.ParallelReader
Add an IndexReader.
add(IndexReader, boolean) - Method in class org.apache.lucene.index.ParallelReader
Add an IndexReader whose stored fields will not be returned.
add(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
 
add(QueryNode) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
 
add(List<QueryNode>) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
 
add(QueryNode) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
 
add(List<QueryNode>) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
 
add(QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
 
add(int, QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
 
add(String, ParserExtension) - Method in class org.apache.lucene.queryParser.ext.Extensions
Adds a new ParserExtension instance associated with the given key.
add(FilterClause) - Method in class org.apache.lucene.search.BooleanFilter
Adds a new FilterClause to the Boolean Filter container
add(Filter, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanFilter
 
add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery
Adds a clause to a boolean query.
add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery
Adds a clause to a boolean query.
add(Query) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Add a subquery to this disjunction
add(Collection<Query>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Add a collection of disjuncts to this disjunction via Iterable
add(Term) - Method in class org.apache.lucene.search.MultiPhraseQuery
Add a single term at the next position in the phrase.
add(Term[]) - Method in class org.apache.lucene.search.MultiPhraseQuery
Add multiple terms at the next position in the phrase.
add(Term[], int) - Method in class org.apache.lucene.search.MultiPhraseQuery
Allows to specify the relative position of terms within the phrase.
add(Term) - Method in class org.apache.lucene.search.PhraseQuery
Adds a term to the end of the query phrase.
add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery
Adds a term to the end of the query phrase.
add(BytesRef) - Method in interface org.apache.lucene.search.suggest.fst.BytesRefSorter
Adds a single suggestion entry (possibly compound with its bucket).
add(BytesRef) - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
 
add(BytesRef, int) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
Appends a single suggestion and its weight to the internal buffers.
add(BytesRef) - Method in class org.apache.lucene.search.suggest.fst.InMemorySorter
 
add(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
 
add(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
 
add(int, int, List<FieldPhraseList.WeightedPhraseInfo>) - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList
convert the list of WeightedPhraseInfo to WeightedFragInfo, then add it to the fragInfos
add(Vector2D) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
Deprecated.
 
add(Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Point2D
Deprecated.
 
add(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef
add(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef with a pre-calculated hash code.
add(int) - Method in class org.apache.lucene.util.collections.IntHashSet
Add a mapping int key -> int value.
add(IntsRef, T) - Method in class org.apache.lucene.util.fst.Builder
It's OK to add the same input twice in a row with different outputs, as long as outputs impls the merge method.
add(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
add(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
add(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
add(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg add("foo", "bar") -> "foobar"
add(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
add(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
add(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
add(E) - Method in class org.apache.lucene.util.MapBackedSet
 
add(long) - Method in class org.apache.lucene.util.packed.PackedInts.Writer
 
add(T) - Method in class org.apache.lucene.util.PriorityQueue
Adds an Object to a PriorityQueue in log(size) time.
add(int, IndexReader) - Method in class org.apache.lucene.util.ReaderUtil.Gather
 
add(CharSequence, CharSequence) - Method in class org.egothor.stemmer.MultiTrie
Add an element to this structure consisting of the given key and patch command.
add(CharSequence, CharSequence) - Method in class org.egothor.stemmer.MultiTrie2
Add an element to this structure consisting of the given key and patch command.
add(CharSequence, CharSequence) - Method in class org.egothor.stemmer.Trie
Add the given key associated with the given patch command.
add_escapes(String) - Method in exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
add_escapes(String) - Method in exception org.apache.lucene.queryParser.surround.parser.ParseException
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
addAll(Iterable<SegmentInfo>) - Method in class org.apache.lucene.index.SegmentInfos
 
addAll(Collection<? extends QueryNodeProcessor>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
 
addAll(int, Collection<? extends QueryNodeProcessor>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
 
addAnalyzer(String, Analyzer) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Deprecated.
Changing the Analyzer for a field after instantiation prevents reusability. Analyzers for fields should be set during construction.
addAndGet(long) - Method in class org.apache.lucene.util.Counter
Adds the given delta to the counters current value
addArc(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
addAttribute(Class<A>) - Method in class org.apache.lucene.queryParser.core.config.AbstractQueryConfig
 
addAttribute(Class<A>) - Method in class org.apache.lucene.util.AttributeSource
The caller must pass in a Class<?
addAttributeImpl(AttributeImpl) - Method in class org.apache.lucene.util.AttributeSource
Expert: Adds a custom AttributeImpl instance with one or more Attribute interfaces.
addBox(double) - Method in class org.apache.lucene.spatial.tier.Shape
Deprecated.
 
addBuffer(int) - Method in class org.apache.lucene.store.RAMFile
 
addBuilder(String, SpanQueryBuilder) - Method in class org.apache.lucene.xmlparser.builders.SpanQueryBuilderFactory
 
addBuilder(String, FilterBuilder) - Method in class org.apache.lucene.xmlparser.FilterBuilderFactory
 
addBuilder(String, QueryBuilder) - Method in class org.apache.lucene.xmlparser.QueryBuilderFactory
 
addByPoolOffset(int) - Method in class org.apache.lucene.util.BytesRefHash
 
addBytes(long) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
update count of bytes generated by this source
addCategory(CategoryPath) - Method in class org.apache.lucene.facet.index.CategoryContainer
Add a category.
addCategory(CategoryPath, CategoryProperty) - Method in class org.apache.lucene.facet.index.CategoryContainer
Add a category with a property.
addCategory(CategoryPath, CategoryProperty...) - Method in class org.apache.lucene.facet.index.CategoryContainer
Add a category with multiple properties.
addCategory(CategoryAttribute) - Method in class org.apache.lucene.facet.index.CategoryContainer
Add an entire CategoryAttribute.
addCategory(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
 
addCategory(CategoryPath) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyWriter
addCategory() adds a category with a given path name to the taxonomy, and returns its ordinal.
addCategoryDocument(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
 
addCategoryEnhancements(CategoryEnhancement...) - Method in class org.apache.lucene.facet.enhancements.params.DefaultEnhancementsIndexingParams
 
addCategoryEnhancements(CategoryEnhancement...) - Method in interface org.apache.lucene.facet.enhancements.params.EnhancementsIndexingParams
Add CategoryEnhancements to the indexing parameters
addCategoryListParams(CategoryPath, CategoryListParams) - Method in class org.apache.lucene.facet.index.params.PerDimensionIndexingParams
Add a CategoryListParams for a given CategoryPath's dimension or "zero-th" category.
addClass(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
Add a character class to the tree.
addClass(String) - Method in interface org.apache.lucene.analysis.compound.hyphenation.PatternConsumer
Add a character class.
addClass(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
 
addClause(List<BooleanClause>, int, int, Query) - Method in class org.apache.lucene.queryParser.QueryParser
 
addClause(BooleanQuery, Term, float) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
addClause(BooleanQuery, Term, float) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
addClause(SpanQuery) - Method in class org.apache.lucene.search.spans.SpanOrQuery
Adds a clause to this query
addCoreClosedListener(SegmentReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
Expert: adds a CoreClosedListener to this reader's shared core
addCount - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
 
addDefaultQueryTemplate(InputStream) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
 
addDetail(Explanation) - Method in class org.apache.lucene.search.Explanation
Adds a sub-node to this explanation node.
AddDocTask - Class in org.apache.lucene.benchmark.byTask.tasks
Add a document, optionally of a certain size.
AddDocTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
 
addDocument(Document) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index.
addDocument(Document, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index, using the provided analyzer instead of the value of IndexWriter.getAnalyzer().
addDocument(Document) - Method in class org.apache.lucene.index.RandomIndexWriter
Adds a Document.
addDocument(Term, Document) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
 
addDocument(Document, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addDocument(Document) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addDocument(Document) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.
Adds a document to this index.
addDocument(Document, Analyzer) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.
Adds a document to this index, using the provided analyzer instead of the value of InstantiatedIndexWriter.getAnalyzer().
addDocument(InstantiatedDocument, Analyzer) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.
Tokenizes a document and adds it to the buffer.
addDocuments(Collection<Document>) - Method in class org.apache.lucene.index.IndexWriter
Atomically adds a block of documents with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
addDocuments(Collection<Document>, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
Atomically adds a block of documents, analyzed using the provided analyzer, with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
addDocuments(Collection<Document>) - Method in class org.apache.lucene.index.RandomIndexWriter
 
addDocuments(Term, Collection<Document>) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
 
addDocuments(Collection<Document>, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addDocuments(Collection<Document>) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addDone() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
 
addDone() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
 
addDone() - Method in interface org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.OrdinalMap
Call addDone() to say that all addMapping() have been done.
addError(Test, Throwable) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
A test caused an error.
addEscapes(String) - Static method in error org.apache.lucene.benchmark.byTask.feeds.demohtml.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addEscapes(String) - Static method in error org.apache.lucene.queryParser.standard.parser.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addEscapes(String) - Static method in error org.apache.lucene.queryParser.surround.parser.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addEscapes(String) - Static method in error org.apache.lucene.queryParser.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addException(String, ArrayList<Object>) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
Add an exception to the tree.
addException(String, ArrayList<Object>) - Method in interface org.apache.lucene.analysis.compound.hyphenation.PatternConsumer
Add a hyphenation exception.
addException(String, ArrayList<Object>) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
 
AddFacetedDocTask - Class in org.apache.lucene.benchmark.byTask.tasks
Add a faceted document.
AddFacetedDocTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.AddFacetedDocTask
 
addFacetRequest(FacetRequest) - Method in class org.apache.lucene.facet.search.params.FacetSearchParams
Add a facet request to apply for this faceted search.
addFailure(Test, Throwable) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
Interface TestListener for JUnit <= 3.4.
addFailure(Test, AssertionFailedError) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
Interface TestListener for JUnit > 3.4.
addField(String, String, Analyzer) - Method in class org.apache.lucene.index.memory.MemoryIndex
Convenience method; Tokenizes the given field text and adds the resulting terms to the index; Equivalent to adding an indexed non-keyword Lucene Field that is tokenized, not stored, termVectorStored with positions (or termVectorStored with positions and offsets),
addField(String, TokenStream) - Method in class org.apache.lucene.index.memory.MemoryIndex
Equivalent to addField(fieldName, stream, 1.0f).
addField(String, TokenStream, float) - Method in class org.apache.lucene.index.memory.MemoryIndex
Iterates over the given token stream and adds the resulting terms to the index; Equivalent to adding a tokenized, indexed, termVectorStored, unstored, Lucene Field.
addFieldConfigListener(FieldConfigListener) - Method in class org.apache.lucene.queryParser.core.config.QueryConfigHandler
Adds a listener.
addFile(String) - Method in class org.apache.lucene.index.CompoundFileWriter
Add a source stream.
addFile(String, Directory) - Method in class org.apache.lucene.index.CompoundFileWriter
Same as CompoundFileWriter.addFile(String), only for files that are found in an external Directory.
addFilterBuilder(String, FilterBuilder) - Method in class org.apache.lucene.xmlparser.CoreParser
 
addIndexes(Directory...) - Method in class org.apache.lucene.index.IndexWriter
Adds all segments from an array of indexes into this index.
addIndexes(IndexReader...) - Method in class org.apache.lucene.index.IndexWriter
Merges the provided indexes into this index.
addIndexes(Directory...) - Method in class org.apache.lucene.index.RandomIndexWriter
 
addIndexes(IndexReader...) - Method in class org.apache.lucene.index.RandomIndexWriter
 
addIndexes(Directory...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addIndexes(IndexReader...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addIndexes(IndexReader[]) - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.
 
addIndexesNoOptimize(Directory...) - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
addItem() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
update count of items generated by this source
addLabel(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
 
addLabel(CategoryPath, int, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
 
addLabel(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
 
addLabel(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
 
addLabel(CategoryPath, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
Adds a new label if its not yet in the table.
addLabel(CategoryPath, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
Adds a new label if its not yet in the table.
addLabelOffset(int, int, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
This method does not check if the same value is already in the map because we pass in an char-array offset, so so we now that we're in resize-mode here.
addMapping(int, int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
 
addMapping(int, int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
 
addMapping(int, int) - Method in interface org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.OrdinalMap
 
addOffCorrectMap(int, int) - Method in class org.apache.lucene.analysis.BaseCharFilter
Adds an offset correction mapping at the given output stream offset.
addOffCorrectMap(int, int) - Method in class org.apache.lucene.analysis.MockCharFilter
 
addPattern(String, String) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
Add a pattern to the tree.
addPattern(String, String) - Method in interface org.apache.lucene.analysis.compound.hyphenation.PatternConsumer
Add hyphenation patterns.
addPattern(String, String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
 
addPosition(int, int) - Method in class org.apache.lucene.search.SpanFilterResult.PositionInfo
 
addPositionSpans(List<PositionSpan>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
 
addPrefix(HunspellAffix) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
Adds a prefix to the list of prefixes used to generate this stem.
addProcessor(QueryNodeProcessor) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
Deprecated.
this class now conforms to List interface, so use QueryNodeProcessorPipeline.add(QueryNodeProcessor) instead
addProperty(CategoryProperty) - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
Add a property.
addProperty(CategoryProperty) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
 
addQueryBuilder(String, QueryBuilder) - Method in class org.apache.lucene.xmlparser.CoreParser
 
addQueryTemplate(String, InputStream) - Method in class org.apache.lucene.xmlparser.QueryTemplateManager
 
addRange(String, String) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRange(int, int, int) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
Overwrite this method, if you like to receive the raw int range bounds.
addRange(String, String) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRange(long, long, int) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
Overwrite this method, if you like to receive the raw long range bounds.
addReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
addResult(int, boolean, long) - Method in class org.apache.lucene.benchmark.quality.QualityStats
Add a (possibly relevant) doc.
addRetainableProperty(Class<? extends CategoryProperty>) - Method in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
Add a CategoryProperty class which is retained when creating parent tokens.
addSinkTokenStream(TeeSinkTokenFilter.SinkTokenStream) - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
Adds a TeeSinkTokenFilter.SinkTokenStream created by another TeeSinkTokenFilter to this one.
addSpanNearQuery(Query) - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
 
addSpanQueries(SpanNearClauseFactory) - Method in class org.apache.lucene.queryParser.surround.query.DistanceQuery
 
addSpanQueries(SpanNearClauseFactory) - Method in interface org.apache.lucene.queryParser.surround.query.DistanceSubQuery
 
addSpanQueries(SpanNearClauseFactory) - Method in class org.apache.lucene.queryParser.surround.query.OrQuery
 
addSpanQueries(SpanNearClauseFactory) - Method in class org.apache.lucene.queryParser.surround.query.SimpleTerm
 
addSpanQueryWeighted(SpanQuery, float) - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
 
addStopWords(IndexReader) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
Deprecated.
addStopWords(IndexReader, int) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
Deprecated.
addStopWords(IndexReader, float) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
Deprecated.
addStopWords(IndexReader, String, float) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
addStopWords(IndexReader, String, int) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
addSuffix(HunspellAffix) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer.Stem
Adds a suffix to the list of suffixes used to generate this stem.
addTask(PerfTask) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
 
addTaxonomy(Directory, DirectoryTaxonomyWriter.OrdinalMap) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
Takes the categories from the given taxonomy directory, and adds the missing ones to this taxonomy.
addTerm(Term) - Method in class org.apache.lucene.search.TermsFilter
Adds a term to the list of acceptable terms
addTerms(String, String, float, int) - Method in class org.apache.lucene.search.FuzzyLikeThisQuery
Adds user input for "fuzzification"
addTermWeighted(Term, float) - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
 
addToArray(int) - Method in class org.apache.lucene.util.collections.IntArray
Adds a value to the array.
addWaitingListener(NRTManager.WaitingListener) - Method in class org.apache.lucene.search.NRTManager
Adds a listener, to be notified when a caller is waiting for a specific generation searcher to be visible.
adjustBeginLineColumn(int, int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
adjustBeginLineColumn(int, int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
Method to adjust line and column numbers for the start of a token.
AdjustBuffSize() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
 
adjustTop() - Method in class org.apache.lucene.util.ScorerDocQueue
Should be called when the scorer at top changes doc() value.
advance(int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
advance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
Advances to the first beyond (see NOTE below) the current whose document number is greater than or equal to target.
advance(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
advance(int) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
advance(int) - Method in class org.apache.lucene.search.spans.SpanScorer
 
advance(int) - Method in class org.apache.lucene.util.OpenBitSetIterator
 
advise(FileDescriptor, long, long, int) - Static method in class org.apache.lucene.store.NativePosixUtil
 
afterClass() - Static method in class org.apache.lucene.search.SearchEquivalenceTestBase
 
afterClassLuceneTestCaseJ4() - Static method in class org.apache.lucene.util.LuceneTestCase
 
afterClose() - Method in class org.apache.lucene.search.NRTManager
 
afterClose() - Method in class org.apache.lucene.search.ReferenceManager
Called after close(), so subclass can free any resources.
AfterEquals - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
Lexical state.
afterPosition() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
This is called when all input tokens leaving a given position have been returned.
afterPosition() - Method in class org.apache.lucene.analysis.MockGraphTokenFilter
 
afterPosition() - Method in class org.apache.lucene.analysis.MockRandomLookaheadTokenFilter
 
afterRefresh() - Method in class org.apache.lucene.search.NRTManager
 
afterRefresh() - Method in class org.apache.lucene.search.ReferenceManager
Called after swapReference has installed a new instance.
aggregate(int) - Method in interface org.apache.lucene.facet.search.aggregator.Aggregator
Collect (and do whatever an implementation deems appropriate) the category given by its ordinal.
aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
 
aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
 
aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.ComplementCountingAggregator
 
aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.CountingAggregator
 
aggregate(int) - Method in class org.apache.lucene.facet.search.aggregator.ScoringAggregator
 
Aggregator - Interface in org.apache.lucene.facet.search.aggregator
An Aggregator is the analogue of Lucene's Collector (see Collector), for processing the categories belonging to a certain document.
ALEF - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
 
ALEF - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
 
ALEF_HAMZA_ABOVE - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
 
ALEF_HAMZA_BELOW - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
 
ALEF_MADDA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
 
Algorithm - Class in org.apache.lucene.benchmark.byTask.utils
Test algorithm, as read from file
Algorithm(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.utils.Algorithm
Read algorithm from file Property examined: alt.tasks.packages == comma separated list of alternate package names where tasks would be searched for, when not found in the default package (that of PerfTaskObject.getClass()).
alignObjectSize(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Aligns an object size to be the next multiple of RamUsageEstimator.NUM_BYTES_OBJECT_ALIGNMENT.
ALL - Static variable in class org.apache.lucene.index.SortedTermVectorMapper
Stand-in name for the field in TermVectorEntry.
allFragmentsProcessed() - Method in class org.apache.lucene.search.highlight.QueryTermScorer
 
alloc(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
This is to implement memory allocation in the array.
alloc(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
 
allocate() - Method in class org.apache.lucene.facet.search.TemporaryObjectAllocator
Allocate a new object.
allocate() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
 
allocSlice(byte[], int) - Method in class org.apache.lucene.util.ByteBlockPool
 
ALLOW_LEADING_WILDCARD - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
Key used to set whether leading wildcards are supported
allowedSuffix(String) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
 
allowedTruncation(String) - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
 
AllowLeadingWildcardAttribute - Interface in org.apache.lucene.queryParser.standard.config
Deprecated. 
AllowLeadingWildcardAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
Deprecated. 
AllowLeadingWildcardAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
Deprecated.
 
AllowLeadingWildcardProcessor - Class in org.apache.lucene.queryParser.standard.processors
AllowLeadingWildcardProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.AllowLeadingWildcardProcessor
 
ALPHA - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
 
ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
 
ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
ALPHANUM_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
AlreadyClosedException - Exception in org.apache.lucene.store
This exception is thrown when there is an attempt to access something that has already been closed.
AlreadyClosedException(String) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
 
alwaysIgnoredTestMethod() - Method in class org.apache.lucene.util.LuceneTestCase
 
Among - Class in org.tartarus.snowball
 
Among(String, int, int, String, SnowballProgram) - Constructor for class org.tartarus.snowball.Among
 
ANALYSIS_DATA_DIR - Static variable in class org.apache.lucene.analysis.cn.smart.AnalyzerProfile
Global indicating the configured analysis data directory
analyze(Analyzer, String, CharsRef) - Static method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
Sugar: analyzes the text with the analyzer and separates by SynonymMap.WORD_SEPARATOR.
Analyzer - Class in org.apache.lucene.analysis
An Analyzer builds TokenStreams, which analyze text.
Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
 
ANALYZER - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
Key used to set the Analyzer used for terms found in the query
analyzer - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
 
analyzer - Variable in class org.apache.lucene.xmlparser.CoreParser
 
AnalyzerAttribute - Interface in org.apache.lucene.queryParser.standard.config
Deprecated. 
AnalyzerAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
Deprecated. 
AnalyzerAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
Deprecated.
 
AnalyzerProfile - Class in org.apache.lucene.analysis.cn.smart
Manages analysis data configuration for SmartChineseAnalyzer SmartChineseAnalyzer has a built-in dictionary and stopword list out-of-box.
AnalyzerProfile() - Constructor for class org.apache.lucene.analysis.cn.smart.AnalyzerProfile
 
AnalyzerQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
AnalyzerQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.AnalyzerQueryNodeProcessor
 
AnalyzingQueryParser - Class in org.apache.lucene.queryParser.analyzing
Overrides Lucene's default QueryParser so that Fuzzy-, Prefix-, Range-, and WildcardQuerys are also passed through the given analyzer, but wild card characters (like *) don't get removed from the search terms.
AnalyzingQueryParser(Version, String, Analyzer) - Constructor for class org.apache.lucene.queryParser.analyzing.AnalyzingQueryParser
Constructs a query parser.
AND - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
AND - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
RegularExpression Id.
AND - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
RegularExpression Id.
AND - Static variable in class org.apache.lucene.search.ChainedFilter
 
and(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place AND of the bits provided by the iterator.
and(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND other
and(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
 
AND_OPERATOR - Static variable in class org.apache.lucene.queryParser.QueryParser
Alternative form of QueryParser.Operator.AND
AND_OPERATOR - Static variable in class org.apache.lucene.queryParser.standard.QueryParserWrapper
Deprecated.
Alternative form of QueryParser.Operator.AND
ANDNOT - Static variable in class org.apache.lucene.search.ChainedFilter
 
andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place AND NOT of the bits provided by the iterator.
andNot(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND NOT other
andNot(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
 
andNotCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
Returns the popcount or cardinality of "a and not b" or "intersection(a, not(b))".
AndQuery() - Method in class org.apache.lucene.queryParser.surround.parser.QueryParser
 
AndQuery - Class in org.apache.lucene.queryParser.surround.query
 
AndQuery(List<SrndQuery>, boolean, String) - Constructor for class org.apache.lucene.queryParser.surround.query.AndQuery
 
AndQueryNode - Class in org.apache.lucene.queryParser.core.nodes
A AndQueryNode represents an AND boolean operation performed on a list of nodes.
AndQueryNode(List<QueryNode>) - Constructor for class org.apache.lucene.queryParser.core.nodes.AndQueryNode
 
angularDistance(double, double) - Static method in class org.apache.lucene.spatial.DistanceUtils
Deprecated.
distance/radius.
anyFilesExceptWriteLock(Directory) - Static method in class org.apache.lucene.util._TestUtil
 
AnyQueryNode - Class in org.apache.lucene.queryParser.core.nodes
A AnyQueryNode represents an ANY operator performed on a list of nodes.
AnyQueryNode(List<QueryNode>, CharSequence, int) - Constructor for class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
 
AnyQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
 
AnyQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.AnyQueryNodeBuilder
 
anyUnhandledExceptions() - Static method in class org.apache.lucene.index.ConcurrentMergeScheduler
Used for testing
APOSTROPHE - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
APOSTROPHE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
APOSTROPHE_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
append(CharSequence) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(CharSequence, int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(char) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(String) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the specified String to this character sequence.
append(StringBuilder) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the specified StringBuilder to this character sequence.
append(CharTermAttribute) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the contents of the other CharTermAttribute to this character sequence.
append(CharSequence) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(char) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(String) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(StringBuilder) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharTermAttribute) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharSequence) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
 
append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
 
append(char) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
 
append(BytesRef) - Method in class org.apache.lucene.search.suggest.BytesRefList
Appends a copy of the given BytesRef to this BytesRefList.
append(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Appends the bytes from the given BytesRef NOTE: if this would exceed the array size, this method creates a new reference array.
append(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
Appends the given array to this CharsRef
append(String) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
 
append(long) - Method in class org.apache.lucene.util.LuceneJUnitResultFormatter
 
appendIntToStream(int) - Method in class org.apache.lucene.facet.index.CategoryListPayloadStream
Appends an integer to the stream.
appendRegExpForChar(char, StringBuilder) - Method in class org.apache.lucene.queryParser.surround.query.SrndTruncQuery
 
appendSubResult(FacetResultNode) - Method in class org.apache.lucene.facet.search.results.MutableFacetResultNode
Append a sub result (as last).
appendTo(Appendable, char) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Build a string representation of the path, with its components separated by the given delimiter character.
appendTo(Appendable, char, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
like CategoryPath.appendTo(Appendable, char), but takes only a prefix of the path, rather than the whole path.
appendTo(Appendable, char, int, int) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
like CategoryPath.appendTo(Appendable, char), but takes only a part of the path, rather than the whole path.
apply(char[], int) - Method in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
 
apply(Statement, Description) - Method in class org.apache.lucene.util.StoreClassNameRule
 
apply(Statement, Description) - Method in class org.apache.lucene.util.SystemPropertiesInvariantRule
 
apply(Statement, Description) - Method in class org.apache.lucene.util.SystemPropertiesRestoreRule
 
apply(Statement, Description) - Method in class org.apache.lucene.util.UncaughtExceptionsRule
 
apply(StringBuilder, CharSequence) - Static method in class org.egothor.stemmer.Diff
Apply the given patch string diff to the given string dest.
applyAffix(char[], int, HunspellAffix, int) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemmer
Applies the affix rule to the given word, producing a list of stems if any are found
ArabicAnalyzer - Class in org.apache.lucene.analysis.ar
Analyzer for Arabic.
ArabicAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
Builds an analyzer with the default stop words: ArabicAnalyzer.DEFAULT_STOPWORD_FILE.
ArabicAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
Builds an analyzer with the given stop words
ArabicAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
Builds an analyzer with the given stop word.
ArabicAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
ArabicAnalyzer(Version, Hashtable<?, ?>) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
ArabicAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
ArabicLetterTokenizer - Class in org.apache.lucene.analysis.ar
Deprecated.
(3.1) Use StandardTokenizer instead.
ArabicLetterTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
Deprecated.
Construct a new ArabicLetterTokenizer.
ArabicLetterTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
Deprecated.
Construct a new ArabicLetterTokenizer using a given AttributeSource.
ArabicLetterTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
Deprecated.
Construct a new ArabicLetterTokenizer using a given AttributeSource.AttributeFactory. * @param matchVersion Lucene version to match See above
ArabicLetterTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
Deprecated.
use ArabicLetterTokenizer.ArabicLetterTokenizer(Version, Reader) instead. This will be removed in Lucene 4.0.
ArabicLetterTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
Deprecated.
ArabicLetterTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.ar.ArabicLetterTokenizer
ArabicNormalizationFilter - Class in org.apache.lucene.analysis.ar
A TokenFilter that applies ArabicNormalizer to normalize the orthography.
ArabicNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ar.ArabicNormalizationFilter
 
ArabicNormalizer - Class in org.apache.lucene.analysis.ar
Normalizer for Arabic.
ArabicNormalizer() - Constructor for class org.apache.lucene.analysis.ar.ArabicNormalizer
 
ArabicStemFilter - Class in org.apache.lucene.analysis.ar
A TokenFilter that applies ArabicStemmer to stem Arabic words..
ArabicStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ar.ArabicStemFilter
 
ArabicStemmer - Class in org.apache.lucene.analysis.ar
Stemmer for Arabic.
ArabicStemmer() - Constructor for class org.apache.lucene.analysis.ar.ArabicStemmer
 
arcCount - Variable in class org.apache.lucene.util.fst.FST
 
arcDistance(LatLng) - Method in class org.apache.lucene.spatial.geometry.LatLng
Deprecated.
Calculates the distance between two lat/lng's in miles.
arcDistance(LatLng, DistanceUnits) - Method in class org.apache.lucene.spatial.geometry.LatLng
Deprecated.
Calculates the distance between two lat/lng's in miles or meters.
arcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
arcWithOutputCount - Variable in class org.apache.lucene.util.fst.FST
 
area() - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
Deprecated.
 
area() - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
Deprecated.
Return the area
area() - Method in class org.apache.lucene.spatial.geometry.shape.LLRect
Deprecated.
Return the area in units of lat-lng squared.
area() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
Deprecated.
 
ArgEquals - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
ArgName - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
ArgQuote1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
ArgQuote2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
ArgValue() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
 
ArgValue - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
ArmenianAnalyzer - Class in org.apache.lucene.analysis.hy
Analyzer for Armenian.
ArmenianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
Builds an analyzer with the default stop words: ArmenianAnalyzer.DEFAULT_STOPWORD_FILE.
ArmenianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
Builds an analyzer with the given stop words.
ArmenianAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
Builds an analyzer with the given stop words.
ArmenianStemmer - Class in org.tartarus.snowball.ext
This class was automatically generated by a Snowball to Java compiler It implements the stemming algorithm defined by a snowball script.
ArmenianStemmer() - Constructor for class org.tartarus.snowball.ext.ArmenianStemmer
 
ArrayHashMap<K,V> - Class in org.apache.lucene.util.collections
An Array-based hashtable which maps, similar to Java's HashMap, only performance tests showed it performs better.
ArrayHashMap() - Constructor for class org.apache.lucene.util.collections.ArrayHashMap
Constructs a map with default capacity.
ArrayHashMap(int) - Constructor for class org.apache.lucene.util.collections.ArrayHashMap
Constructs a map with given capacity.
arrayToString(int[]) - Static method in class org.apache.lucene.util._TestUtil
Deprecated.
-- in 3.0 we can use Arrays.toString instead
arrayToString(Object[]) - Static method in class org.apache.lucene.util._TestUtil
Deprecated.
-- in 3.0 we can use Arrays.toString instead
ArrayUtil - Class in org.apache.lucene.util
Methods for manipulating arrays.
ArrayUtil() - Constructor for class org.apache.lucene.util.ArrayUtil
Deprecated.
This constructor was not intended to be public and should not be used. This class contains solely a static utility methods. It will be made private in Lucene 4.0
ASCIIFoldingFilter - Class in org.apache.lucene.analysis
This class converts alphabetic, numeric, and symbolic Unicode characters which are not in the first 127 ASCII characters (the "Basic Latin" Unicode block) into their ASCII equivalents, if one exists.
ASCIIFoldingFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ASCIIFoldingFilter
 
asList() - Method in class org.apache.lucene.index.SegmentInfos
Returns all contained segments as an unmodifiable List view.
assertAnalyzesTo(Analyzer, String, String[], int[], int[], String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesTo(Analyzer, String, String[], int[], int[], String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesTo(Analyzer, String, String[], int[], int[], String[], int[], int[], boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesTo(Analyzer, String, String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesTo(Analyzer, String, String[], String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesTo(Analyzer, String, String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesTo(Analyzer, String, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesTo(Analyzer, String, String[], int[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesToPositions(Analyzer, String, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesToReuse(Analyzer, String, String[], int[], int[], String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesToReuse(Analyzer, String, String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesToReuse(Analyzer, String, String[], String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesToReuse(Analyzer, String, String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesToReuse(Analyzer, String, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAnalyzesToReuse(Analyzer, String, String[], int[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertAttributeReflection(AttributeImpl, Map<String, T>) - Static method in class org.apache.lucene.util._TestUtil
Checks some basic behaviour of an AttributeImpl
assertDateRangeQueryEquals(QueryParser, String, String, String, Date, DateTools.Resolution) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
assertEquals(TopDocs, TopDocs) - Static method in class org.apache.lucene.util._TestUtil
 
assertEquals(double, double) - Static method in class org.apache.lucene.util.LuceneTestCase
Deprecated.
assertEquals(String, double, double) - Static method in class org.apache.lucene.util.LuceneTestCase
Deprecated.
assertEquals(float, float) - Static method in class org.apache.lucene.util.LuceneTestCase
Deprecated.
assertEquals(String, float, float) - Static method in class org.apache.lucene.util.LuceneTestCase
Deprecated.
assertEscapedQueryEquals(String, Analyzer, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
AssertingIndexSearcher - Class in org.apache.lucene.search
Helper class that adds some extra checks to ensure correct usage of IndexSearcher and Weight.
AssertingIndexSearcher(IndexReader) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
 
AssertingIndexSearcher(IndexReader, ExecutorService) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
 
assertParseException(String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
assertQueryEquals(String, Analyzer, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
assertQueryEquals(QueryParser, String, String, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
assertQueryEqualsDOA(String, Analyzer, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
assertSameSet(Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
Asserts that the documents returned by q1 are the same as of those returned by q2
assertSaneFieldCaches(String) - Method in class org.apache.lucene.util.LuceneTestCase
Asserts that FieldCacheSanityChecker does not detect any problems with FieldCache.DEFAULT.
assertSubsetOf(Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
Asserts that the documents returned by q1 are a subset of those returned by q2
assertSubsetOf(Query, Query, Filter) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
Asserts that the documents returned by q1 are a subset of those returned by q2.
assertThreadSafe(Analyzer) - Method in class org.apache.lucene.analysis.CollationTestBase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], int[], Integer, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertTokenStreamContents(TokenStream, String[], int[], int[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
assertVocabulary(Analyzer, InputStream, InputStream) - Static method in class org.apache.lucene.analysis.VocabularyAssert
Run a vocabulary test against two data files.
assertVocabulary(Analyzer, InputStream) - Static method in class org.apache.lucene.analysis.VocabularyAssert
Run a vocabulary test against one file: tab separated.
assertVocabulary(Analyzer, File, String, String) - Static method in class org.apache.lucene.analysis.VocabularyAssert
Run a vocabulary test against two data files inside a zip file
assertVocabulary(Analyzer, File, String) - Static method in class org.apache.lucene.analysis.VocabularyAssert
Run a vocabulary test against a tab-separated data file inside a zip file
assertWildcardQueryEquals(String, boolean, String, boolean) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
assertWildcardQueryEquals(String, boolean, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
assertWildcardQueryEquals(String, String) - Method in class org.apache.lucene.queryParser.QueryParserTestBase
 
asSet() - Method in class org.apache.lucene.index.SegmentInfos
Returns all contained segments as an unmodifiable Set view.
asSet(T...) - Static method in class org.apache.lucene.util.LuceneTestCase
 
assign_to(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
 
association - Variable in class org.apache.lucene.facet.enhancements.association.AssociationProperty
 
ASSOCIATION_POSTING_TERM - Static variable in class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
Default Term for associations
AssociationEnhancement - Class in org.apache.lucene.facet.enhancements.association
A CategoryEnhancement for adding associations data to the index (categories with AssociationPropertys).
AssociationEnhancement() - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationEnhancement
 
AssociationFloatProperty - Class in org.apache.lucene.facet.enhancements.association
An AssociationProperty which treats the association as float - the association bits are actually float bits, and thus merging two associations is done by float summation.
AssociationFloatProperty(float) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationFloatProperty
Constructor.
AssociationFloatSumAggregator - Class in org.apache.lucene.facet.search.aggregator.association
An Aggregator which updates the weight of a category by summing the weights of the float association it finds for every document.
AssociationFloatSumAggregator(IndexReader, float[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
 
AssociationFloatSumAggregator(String, IndexReader, float[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
 
AssociationFloatSumFacetRequest - Class in org.apache.lucene.facet.search.params.association
Facet request for weighting facets according to their float association by summing the association values.
AssociationFloatSumFacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.association.AssociationFloatSumFacetRequest
Create a float association facet request for a given node in the taxonomy.
AssociationIntProperty - Class in org.apache.lucene.facet.enhancements.association
An AssociationProperty which treats the association as int - merges two associations by summation.
AssociationIntProperty(int) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationIntProperty
 
AssociationIntSumAggregator - Class in org.apache.lucene.facet.search.aggregator.association
An Aggregator which updates the weight of a category by summing the weights of the integer association it finds for every document.
AssociationIntSumAggregator(IndexReader, int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
 
AssociationIntSumAggregator(String, IndexReader, int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
 
AssociationIntSumFacetRequest - Class in org.apache.lucene.facet.search.params.association
Facet request for weighting facets according to their integer association by summing the association values.
AssociationIntSumFacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.association.AssociationIntSumFacetRequest
Create an integer association facet request for a given node in the taxonomy.
AssociationListTokenizer - Class in org.apache.lucene.facet.enhancements.association
Tokenizer for associations of a category
AssociationListTokenizer(TokenStream, EnhancementsIndexingParams, CategoryEnhancement) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationListTokenizer
 
AssociationProperty - Class in org.apache.lucene.facet.enhancements.association
A CategoryProperty associating a single integer value to a CategoryAttribute.
AssociationProperty(int) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationProperty
Construct an AssociationProperty.
AssociationsPayloadIterator - Class in org.apache.lucene.facet.enhancements.association
Allows easy iteration over the associations payload, decoding and breaking it to (ordinal, value) pairs, stored in a hash.
AssociationsPayloadIterator(IndexReader, String) - Constructor for class org.apache.lucene.facet.enhancements.association.AssociationsPayloadIterator
Construct a new association-iterator, initializing the inner payload iterator, with the supplied term and checking whether there are any associations within the given index
associationsPayloadIterator - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationFloatSumAggregator
 
associationsPayloadIterator - Variable in class org.apache.lucene.facet.search.aggregator.association.AssociationIntSumAggregator
 
assumeFalse(String, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
 
assumeNoException(String, Exception) - Static method in class org.apache.lucene.util.LuceneTestCase
 
assumeTrue(String, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
 
atLeast(Random, int) - Static method in class org.apache.lucene.util.LuceneTestCase
Returns a number of at least i The actual number returned will be influenced by whether LuceneTestCase.TEST_NIGHTLY is active and LuceneTestCase.RANDOM_MULTIPLIER, but also with some random fudge.
atLeast(int) - Static method in class org.apache.lucene.util.LuceneTestCase
 
Attribute - Interface in org.apache.lucene.util
Base interface for attributes.
AttributeImpl - Class in org.apache.lucene.util
Base class for Attributes that can be added to a AttributeSource.
AttributeImpl() - Constructor for class org.apache.lucene.util.AttributeImpl
 
AttributeReflector - Interface in org.apache.lucene.util
This interface is used to reflect contents of AttributeSource or AttributeImpl.
AttributeSource - Class in org.apache.lucene.util
An AttributeSource contains a list of different AttributeImpls, and methods to add and get them.
AttributeSource() - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the default attribute factory AttributeSource.AttributeFactory.DEFAULT_ATTRIBUTE_FACTORY.
AttributeSource(AttributeSource) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource that uses the same attributes as the supplied one.
AttributeSource(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the supplied AttributeSource.AttributeFactory for creating new Attribute instances.
AttributeSource.AttributeFactory - Class in org.apache.lucene.util
An AttributeFactory creates instances of AttributeImpls.
AttributeSource.AttributeFactory() - Constructor for class org.apache.lucene.util.AttributeSource.AttributeFactory
 
AttributeSource.State - Class in org.apache.lucene.util
This class holds the state of an AttributeSource.
AttributeSource.State() - Constructor for class org.apache.lucene.util.AttributeSource.State
 
automatic() - Static method in class org.apache.lucene.search.suggest.fst.Sort.BufferSize
Approximately half of the currently available free heap, but no less than Sort.ABSOLUTE_MIN_SORT_BUFFER_SIZE.
available() - Method in class org.apache.lucene.util.UnsafeByteArrayInputStream
 
average(QualityStats[]) - Static method in class org.apache.lucene.benchmark.quality.QualityStats
Create a QualityStats object that is the average of the input QualityStats objects.
AveragePayloadFunction - Class in org.apache.lucene.search.payloads
Calculate the final score as the average score of all payloads seen.
AveragePayloadFunction() - Constructor for class org.apache.lucene.search.payloads.AveragePayloadFunction
 

B

B - Variable in class org.apache.lucene.spatial.geometry.shape.LineSegment
Deprecated.
 
backup(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
Backup a number of characters.
backup(int) - Method in interface org.apache.lucene.queryParser.CharStream
Backs up the input stream by amount steps.
backup(int) - Method in class org.apache.lucene.queryParser.FastCharStream
 
backup(int) - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
Retreat.
backup(int) - Method in interface org.apache.lucene.queryParser.surround.parser.CharStream
Backs up the input stream by amount steps.
backup(int) - Method in class org.apache.lucene.queryParser.surround.parser.FastCharStream
 
balance() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
Balance the tree for best search performance
BalancedSegmentMergePolicy - Class in org.apache.lucene.index
Merge policy that tries to balance not doing large segment merges with not accumulating too many segments in the index, to provide for better performance in near real-time setting.
BalancedSegmentMergePolicy() - Constructor for class org.apache.lucene.index.BalancedSegmentMergePolicy
 
BalancedSegmentMergePolicy.MergePolicyParams - Class in org.apache.lucene.index
Specifies configuration parameters for BalancedSegmentMergePolicy.
BalancedSegmentMergePolicy.MergePolicyParams() - Constructor for class org.apache.lucene.index.BalancedSegmentMergePolicy.MergePolicyParams
 
balancedTree(Object[], Object[], int, int, TernaryTreeNode) - Method in class org.apache.lucene.search.suggest.tst.TSTAutocomplete
Inserting keys in TST in the order middle,small,big (lexicographic measure) recursively creates a balanced tree which reduces insertion and search times significantly.
BAREOPER - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
base - Variable in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
base - Variable in class org.apache.lucene.search.CachingCollector
 
BaseCharFilter - Class in org.apache.lucene.analysis
Base utility class for implementing a CharFilter.
BaseCharFilter(CharStream) - Constructor for class org.apache.lucene.analysis.BaseCharFilter
 
BaseFormAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
Attribute for Token.getBaseForm().
BaseFormAttributeImpl - Class in org.apache.lucene.analysis.ja.tokenattributes
Attribute for Token.getBaseForm().
BaseFormAttributeImpl() - Constructor for class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
 
BaseFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
 
BaseFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
BaseFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
BaseFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
BaseFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
baselineTf(float) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
Implemented as: (x <= min) ? base : sqrt(x+(base**2)-min) ...but with a special case check for 0.
BaseTokenStreamTestCase - Class in org.apache.lucene.analysis
Base class for all Lucene unit tests that use TokenStreams.
BaseTokenStreamTestCase() - Constructor for class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
BaseTokenStreamTestCase.CheckClearAttributesAttribute - Interface in org.apache.lucene.analysis
Attribute that records if it was cleared or not.
BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl - Class in org.apache.lucene.analysis
Attribute that records if it was cleared or not.
BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl() - Constructor for class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
 
BasicQueryFactory - Class in org.apache.lucene.queryParser.surround.query
 
BasicQueryFactory(int) - Constructor for class org.apache.lucene.queryParser.surround.query.BasicQueryFactory
 
BasicQueryFactory() - Constructor for class org.apache.lucene.queryParser.surround.query.BasicQueryFactory
 
BasqueAnalyzer - Class in org.apache.lucene.analysis.eu
Analyzer for Basque.
BasqueAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
Builds an analyzer with the default stop words: BasqueAnalyzer.DEFAULT_STOPWORD_FILE.
BasqueAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
Builds an analyzer with the given stop words.
BasqueAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
Builds an analyzer with the given stop words.
BasqueStemmer - Class in org.tartarus.snowball.ext
This class was automatically generated by a Snowball to Java compiler It implements the stemming algorithm defined by a snowball script.
BasqueStemmer() - Constructor for class org.tartarus.snowball.ext.BasqueStemmer
 
beforeClass() - Static method in class org.apache.lucene.search.SearchEquivalenceTestBase
 
beforeClassLuceneTestCaseJ4() - Static method in class org.apache.lucene.util.LuceneTestCase
 
begin - Variable in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
The term's begin position.
beginColumn - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
The column number of the first character of this Token.
beginColumn - Variable in class org.apache.lucene.queryParser.standard.parser.Token
The column number of the first character of this Token.
beginColumn - Variable in class org.apache.lucene.queryParser.surround.parser.Token
The column number of the first character of this Token.
beginColumn - Variable in class org.apache.lucene.queryParser.Token
The column number of the first character of this Token.
beginLine - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.Token
The line number of the first character of this Token.
beginLine - Variable in class org.apache.lucene.queryParser.standard.parser.Token
The line number of the first character of this Token.
beginLine - Variable in class org.apache.lucene.queryParser.surround.parser.Token
The line number of the first character of this Token.
beginLine - Variable in class org.apache.lucene.queryParser.Token
The line number of the first character of this Token.
BeginToken() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
Start.
BeginToken() - Method in interface org.apache.lucene.queryParser.CharStream
Returns the next character that marks the beginning of the next token.
BeginToken() - Method in class org.apache.lucene.queryParser.FastCharStream
 
BeginToken() - Method in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
 
BeginToken() - Method in interface org.apache.lucene.queryParser.surround.parser.CharStream
Returns the next character that marks the beginning of the next token.
BeginToken() - Method in class org.apache.lucene.queryParser.surround.parser.FastCharStream
 
BEH - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
 
BeiderMorseFilter - Class in org.apache.lucene.analysis.phonetic
TokenFilter for Beider-Morse phonetic encoding.
BeiderMorseFilter(TokenStream, PhoneticEngine) - Constructor for class org.apache.lucene.analysis.phonetic.BeiderMorseFilter
BeiderMorseFilter(TokenStream, PhoneticEngine, Languages.LanguageSet) - Constructor for class org.apache.lucene.analysis.phonetic.BeiderMorseFilter
Create a new BeiderMorseFilter
Benchmark - Class in org.apache.lucene.benchmark.byTask
Run the benchmark algorithm.
Benchmark(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.Benchmark
 
BenchmarkHighlighter - Class in org.apache.lucene.benchmark.byTask.tasks
 
BenchmarkHighlighter() - Constructor for class org.apache.lucene.benchmark.byTask.tasks.BenchmarkHighlighter
 
bestFit(double) - Method in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
Deprecated.
Find the tier with the best fit for a bounding box Best fit is defined as the ceiling of log2 (circumference of earth / distance) distance is defined as the smallest box fitting the corner between a radius and a bounding box.
BinaryDictionary - Class in org.apache.lucene.analysis.ja.dict
Base class for a binary-encoded in-memory dictionary.
BinaryDictionary() - Constructor for class org.apache.lucene.analysis.ja.dict.BinaryDictionary
 
binaryLength - Variable in class org.apache.lucene.document.AbstractField
 
binaryOffset - Variable in class org.apache.lucene.document.AbstractField
 
binarySearch(String[], String) - Static method in class org.apache.lucene.search.FieldComparator
 
binarySearch(String[], String, int, int) - Static method in class org.apache.lucene.search.FieldComparator
 
binarySearchAssociatedDocuments(int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
 
binarySearchAssociatedDocuments(int, int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
 
binarySearchAssociatedDocuments(int, int, int) - Method in class org.apache.lucene.store.instantiated.InstantiatedTerm
 
binarySearchLookup(String) - Method in class org.apache.lucene.search.FieldCache.StringIndex
 
bitlist - Static variable in class org.apache.lucene.util.OpenBitSetIterator
 
Bits - Interface in org.apache.lucene.util
Interface for Bitset-like structures.
bits - Variable in class org.apache.lucene.util.OpenBitSet
 
Bits.MatchAllBits - Class in org.apache.lucene.util
Bits impl of the specified length with all bits set.
Bits.MatchAllBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchAllBits
 
Bits.MatchNoBits - Class in org.apache.lucene.util
Bits impl of the specified length with no bits set.
Bits.MatchNoBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchNoBits
 
bits2words(int) - Static method in class org.apache.lucene.util.FixedBitSet
returns the number of 64 bit words it would take to hold numBits
bits2words(long) - Static method in class org.apache.lucene.util.OpenBitSet
returns the number of 64 bit words it would take to hold numBits
bitSpans(IndexReader) - Method in class org.apache.lucene.search.CachingSpanFilter
 
bitSpans(IndexReader) - Method in class org.apache.lucene.search.SpanFilter
Returns a SpanFilterResult with true for documents which should be permitted in search results, and false for those that should not and Spans for where the true docs match.
bitSpans(IndexReader) - Method in class org.apache.lucene.search.SpanQueryFilter
 
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
 
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
bitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
Returns how many bits are required to hold values up to and including maxValue
BitUtil - Class in org.apache.lucene.util
A variety of high efficiency bit twiddling routines.
BitVector - Class in org.apache.lucene.util
Optimized implementation of a vector of bits.
BitVector(int) - Constructor for class org.apache.lucene.util.BitVector
Constructs a vector capable of holding n bits.
BitVector(Directory, String) - Constructor for class org.apache.lucene.util.BitVector
Constructs a bit vector from the file name in Directory d, as written by the BitVector.write(org.apache.lucene.store.Directory, java.lang.String) method.
BLOCK_SIZE - Static variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
 
BlockGroupingCollector - Class in org.apache.lucene.search.grouping
BlockGroupingCollector performs grouping with a single pass collector, as long as you are grouping by a doc block field, ie all documents sharing a given group value were indexed as a doc block using the atomic IndexWriter.addDocuments(java.util.Collection<org.apache.lucene.document.Document>) or IndexWriter.updateDocuments(org.apache.lucene.index.Term, java.util.Collection<org.apache.lucene.document.Document>) API.
BlockGroupingCollector(Sort, int, boolean, Filter) - Constructor for class org.apache.lucene.search.grouping.BlockGroupingCollector
Create the single pass collector.
blockSize - Variable in class org.apache.lucene.util.ByteBlockPool.Allocator
 
BODY_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
 
bodyIndexVal - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
 
bodyStoreVal - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
 
BOLD - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
BOLD_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
BOLD_ITALICS - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
BOLD_ITALICS_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
BooleanClause - Class in org.apache.lucene.search
A clause in a BooleanQuery.
BooleanClause(Query, BooleanClause.Occur) - Constructor for class org.apache.lucene.search.BooleanClause
Constructs a BooleanClause.
BooleanClause.Occur - Enum in org.apache.lucene.search
Specifies how clauses are to occur in matching documents.
BooleanFilter - Class in org.apache.lucene.search
A container Filter that allows Boolean composition of Filters.
BooleanFilter() - Constructor for class org.apache.lucene.search.BooleanFilter
 
BooleanFilterBuilder - Class in org.apache.lucene.xmlparser.builders
 
BooleanFilterBuilder(FilterBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.BooleanFilterBuilder
 
BooleanModifierNode - Class in org.apache.lucene.queryParser.standard.nodes
A BooleanModifierNode has the same behaviour as ModifierQueryNode, it only indicates that this modifier was added by GroupQueryNodeProcessor and not by the user.
BooleanModifierNode(QueryNode, ModifierQueryNode.Modifier) - Constructor for class org.apache.lucene.queryParser.standard.nodes.BooleanModifierNode
 
BooleanModifiersQueryNodeProcessor - Class in org.apache.lucene.queryParser.precedence.processors
This processor is used to apply the correct ModifierQueryNode to BooleanQueryNodes children.
BooleanModifiersQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.precedence.processors.BooleanModifiersQueryNodeProcessor
 
BooleanQuery - Class in org.apache.lucene.search
A Query that matches documents matching boolean combinations of other queries, e.g.
BooleanQuery() - Constructor for class org.apache.lucene.search.BooleanQuery
Constructs an empty boolean query.
BooleanQuery(boolean) - Constructor for class org.apache.lucene.search.BooleanQuery
Constructs an empty boolean query.
BooleanQuery.BooleanWeight - Class in org.apache.lucene.search
Expert: the Weight for BooleanQuery, used to normalize, score and explain these queries.
BooleanQuery.BooleanWeight(Searcher, boolean) - Constructor for class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
Thrown when an attempt is made to add more than BooleanQuery.getMaxClauseCount() clauses.
BooleanQuery.TooManyClauses() - Constructor for exception org.apache.lucene.search.BooleanQuery.TooManyClauses
 
BooleanQueryBuilder - Class in org.apache.lucene.xmlparser.builders
 
BooleanQueryBuilder(QueryBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.BooleanQueryBuilder
 
BooleanQueryNode - Class in org.apache.lucene.queryParser.core.nodes
A BooleanQueryNode represents a list of elements which do not have an explicit boolean operator defined between them.
BooleanQueryNode(List<QueryNode>) - Constructor for class org.apache.lucene.queryParser.core.nodes.BooleanQueryNode
 
BooleanQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
Builds a BooleanQuery object from a BooleanQueryNode object.
BooleanQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.BooleanQueryNodeBuilder
 
BOOLEANS - Static variable in class org.apache.lucene.benchmark.Constants
 
BooleanSingleChildOptimizationQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
This processor removes every BooleanQueryNode that contains only one child and returns this child.
BooleanSingleChildOptimizationQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
 
boost - Variable in class org.apache.lucene.document.AbstractField
 
Boost - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
Lexical state.
BOOST - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
Key used to set the boost value in FieldConfig objects.
Boost - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
Lexical state.
Boost - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
Lexical state.
boost(float) - Static method in class org.apache.lucene.util.ToStringUtils
for printing boost only if not 1.0
BoostAttribute - Interface in org.apache.lucene.queryParser.standard.config
Deprecated. 
BoostAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
Deprecated. 
BoostAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
Deprecated.
 
BoostingQuery - Class in org.apache.lucene.search
The BoostingQuery class can be used to effectively demote results that match a given query.
BoostingQuery(Query, Query, float) - Constructor for class org.apache.lucene.search.BoostingQuery
 
BoostingQueryBuilder - Class in org.apache.lucene.xmlparser.builders
 
BoostingQueryBuilder(QueryBuilder) - Constructor for class org.apache.lucene.xmlparser.builders.BoostingQueryBuilder
 
BoostingTermBuilder - Class in org.apache.lucene.xmlparser.builders
 
BoostingTermBuilder() - Constructor for class org.apache.lucene.xmlparser.builders.BoostingTermBuilder
 
BoostQueryNode - Class in org.apache.lucene.queryParser.core.nodes
A BoostQueryNode boosts the QueryNode tree which is under this node.
BoostQueryNode(QueryNode, float) - Constructor for class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
Constructs a boost node
BoostQueryNodeBuilder - Class in org.apache.lucene.queryParser.standard.builders
This builder basically reads the Query object set on the BoostQueryNode child using QueryTreeBuilder.QUERY_TREE_BUILDER_TAGID and applies the boost value defined in the BoostQueryNode.
BoostQueryNodeBuilder() - Constructor for class org.apache.lucene.queryParser.standard.builders.BoostQueryNodeBuilder
 
BoostQueryNodeProcessor - Class in org.apache.lucene.queryParser.standard.processors
This processor iterates the query node tree looking for every FieldableNode that has StandardQueryConfigHandler.ConfigurationKeys.BOOST in its config.
BoostQueryNodeProcessor() - Constructor for class org.apache.lucene.queryParser.standard.processors.BoostQueryNodeProcessor
 
boosts - Variable in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
BOTH - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
Output the both the untokenized token and the splits
boundaryChars - Variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
 
BoundaryScanner - Interface in org.apache.lucene.search.vectorhighlight
 
bra - Variable in class org.tartarus.snowball.SnowballProgram
 
BRAZILIAN_STOP_WORDS - Static variable in class org.apache.lucene.analysis.br.BrazilianAnalyzer
Deprecated.
BrazilianAnalyzer - Class in org.apache.lucene.analysis.br
Analyzer for Brazilian Portuguese language.
BrazilianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
Builds an analyzer with the default stop words (BrazilianAnalyzer.getDefaultStopSet()).
BrazilianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
Builds an analyzer with the given stop words
BrazilianAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
Builds an analyzer with the given stop words and stemming exclusion words
BrazilianAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
BrazilianAnalyzer(Version, Map<?, ?>) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
BrazilianAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
BrazilianStemFilter - Class in org.apache.lucene.analysis.br
BrazilianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.br.BrazilianStemFilter
Creates a new BrazilianStemFilter
BrazilianStemFilter(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.br.BrazilianStemFilter
Deprecated.
BrazilianStemmer - Class in org.apache.lucene.analysis.br
A stemmer for Brazilian Portuguese words.
BrazilianStemmer() - Constructor for class org.apache.lucene.analysis.br.BrazilianStemmer
 
BreakIteratorBoundaryScanner - Class in org.apache.lucene.search.vectorhighlight
A BoundaryScanner implementation that uses BreakIterator to find boundaries in the text.
BreakIteratorBoundaryScanner(BreakIterator) - Constructor for class org.apache.lucene.search.vectorhighlight.BreakIteratorBoundaryScanner
 
bucket - Variable in class org.apache.lucene.search.suggest.fst.FSTCompletion.Completion
 
buf - Variable in class org.apache.lucene.analysis.util.OpenStringBuilder
 
BUF_SIZE_INT - Static variable in class org.apache.lucene.util.NumericUtils
Expert: The maximum term length (used for char[] buffer size) for encoding int values.
BUF_SIZE_LONG - Static variable in class org.apache.lucene.util.NumericUtils
Expert: The maximum term length (used for char[] buffer size) for encoding long values.
bufcolumn - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
 
bufcolumn - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
 
buffer() - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Returns the internal termBuffer character array which you can then directly alter.
buffer() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
buffer - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
 
buffer - Variable in class org.apache.lucene.facet.search.PayloadIterator
 
buffer - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
 
buffer - Variable in class org.apache.lucene.store.BufferedIndexInput
 
buffer - Variable in class org.apache.lucene.util.ByteBlockPool
 
BUFFER_SIZE - Static variable in class org.apache.lucene.benchmark.byTask.utils.StreamUtils
Buffer size used across the benchmark package
BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
Default buffer size
BufferedIndexInput - Class in org.apache.lucene.store
Base implementation class for buffered IndexInput.
BufferedIndexInput() - Constructor for class org.apache.lucene.store.BufferedIndexInput
Deprecated.
please pass resourceDesc
BufferedIndexInput(String) - Constructor for class org.apache.lucene.store.BufferedIndexInput
 
BufferedIndexInput(int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
Deprecated.
please pass resourceDesc
BufferedIndexInput(String, int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
Inits BufferedIndexInput with a specific bufferSize
BufferedIndexOutput - Class in org.apache.lucene.store
Base implementation class for buffered IndexOutput.
BufferedIndexOutput() - Constructor for class org.apache.lucene.store.BufferedIndexOutput
 
BufferingTermFreqIteratorWrapper - Class in org.apache.lucene.search.suggest
This wrapper buffers incoming elements.
BufferingTermFreqIteratorWrapper(TermFreqIterator) - Constructor for class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
 
buffers - Variable in class org.apache.lucene.store.RAMFile
 
buffers - Variable in class org.apache.lucene.util.ByteBlockPool
 
bufferSize - Variable in class org.apache.lucene.search.suggest.fst.Sort.SortInfo
 
bufline - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
 
bufline - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
 
bufpos - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
Position in buffer.
bufpos - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
Position in buffer.
build() - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
Builds an SynonymMap and returns it.
build(Document) - Method in class org.apache.lucene.facet.index.CategoryDocumentBuilder
Adds the fields created in one of the "set" methods to the document
build(QueryNode) - Method in interface org.apache.lucene.queryParser.core.builders.QueryBuilder
Builds some kind of object from a query tree.
build(QueryNode) - Method in class org.apache.lucene.queryParser.core.builders.QueryTreeBuilder
Builds some kind of object from a query tree.
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.AnyQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.BooleanQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.BoostQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.DummyQueryNodeBuilder
Always return null.
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.FieldQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.FuzzyQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.GroupQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.MatchAllDocsQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.MatchNoDocsQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.ModifierQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.MultiPhraseQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.NumericRangeQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.PhraseQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.PrefixWildcardQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.RangeQueryNodeBuilder
Deprecated.
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.SlopQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.StandardBooleanQueryNodeBuilder
 
build(QueryNode) - Method in interface org.apache.lucene.queryParser.standard.builders.StandardQueryBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.StandardQueryTreeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.TermRangeQueryNodeBuilder
 
build(QueryNode) - Method in class org.apache.lucene.queryParser.standard.builders.WildcardQueryNodeBuilder
 
build() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
Builds the final automaton from a list of added entries.
build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
Builds up a new internal Lookup representation based on the given TermFreqIterator.
build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.fst.FSTLookup
Deprecated.
 
build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
 
build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
 
build(Dictionary) - Method in class org.apache.lucene.search.suggest.Lookup
Build lookup from a dictionary.
build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.Lookup
Builds up a new internal Lookup representation based on the given TermFreqIterator.
build(TermFreqIterator) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
 
Builder<T> - Class in org.apache.lucene.util.fst
Builds a minimal FST (maps an IntsRef term to an arbitrary output) from pre-sorted terms with outputs.
Builder(FST.INPUT_TYPE, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.Builder
Instantiates an FST/FSA builder without any pruning.
Builder(FST.INPUT_TYPE, int, int, boolean, boolean, int, Outputs<T>, Builder.FreezeTail<T>, boolean) - Constructor for class org.apache.lucene.util.fst.Builder
Instantiates an FST/FSA builder with all the possible tuning and construction tweaks.
Builder.Arc<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) arc.
Builder.Arc() - Constructor for class org.apache.lucene.util.fst.Builder.Arc
 
Builder.FreezeTail<T> - Class in org.apache.lucene.util.fst
Expert: this is invoked by Builder whenever a suffix is serialized.
Builder.FreezeTail() - Constructor for class org.apache.lucene.util.fst.Builder.FreezeTail
 
Builder.UnCompiledNode<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) Node.
Builder.UnCompiledNode(Builder<T>, int) - Constructor for class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
buildExtensionField(String) - Method in class org.apache.lucene.queryParser.ext.Extensions
Builds an extension field string from a given extension key and the default query field.
buildExtensionField(String, String) - Method in class org.apache.lucene.queryParser.ext.Extensions
Builds an extension field string from a given extension key and the extensions field.
buildFieldConfig(FieldConfig) - Method in interface org.apache.lucene.queryParser.core.config.FieldConfigListener
This method is called ever time a field configuration is requested.
buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapFCListener
 
buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionFCListener
 
buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryParser.standard.config.NumericFieldConfigListener
 
BulgarianAnalyzer - Class in org.apache.lucene.analysis.bg
Analyzer for Bulgarian.
BulgarianAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
Builds an analyzer with the default stop words: BulgarianAnalyzer.DEFAULT_STOPWORD_FILE.
BulgarianAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
Builds an analyzer with the given stop words.
BulgarianAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
Builds an analyzer with the given stop words and a stem exclusion set.
BulgarianStemFilter - Class in org.apache.lucene.analysis.bg
A TokenFilter that applies BulgarianStemmer to stem Bulgarian words.
BulgarianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.bg.BulgarianStemFilter
 
BulgarianStemmer - Class in org.apache.lucene.analysis.bg
Light Stemmer for Bulgarian.
BulgarianStemmer() - Constructor for class org.apache.lucene.analysis.bg.BulgarianStemmer
 
BYTE - Static variable in class org.apache.lucene.search.function.FieldScoreQuery.Type
field values are interpreted as numeric byte values.
BYTE - Static variable in class org.apache.lucene.search.SortField
Sort using term values as encoded Bytes.
byte315ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
byteToFloat(b, mantissaBits=3, zeroExponent=15)
byte52ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
byteToFloat(b, mantissaBits=5, zeroExponent=2)
BYTE_BLOCK_MASK - Static variable in class org.apache.lucene.util.ByteBlockPool
 
BYTE_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.ByteBlockPool
 
BYTE_BLOCK_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
 
byteArray(StringBuilder, byte[]) - Static method in class org.apache.lucene.util.ToStringUtils
 
ByteArrayDataInput - Class in org.apache.lucene.store
DataInput backed by a byte array.
ByteArrayDataInput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput() - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataOutput - Class in org.apache.lucene.store
DataOutput backed by a byte array.
ByteArrayDataOutput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput() - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
byteAt(int) - Method in class org.apache.lucene.index.Payload
Returns the byte at the given index.
ByteBlockPool - Class in org.apache.lucene.util
Class that Posting and PostingVector use to write byte streams into shared fixed-size byte[] arrays.
ByteBlockPool(ByteBlockPool.Allocator) - Constructor for class org.apache.lucene.util.ByteBlockPool
 
ByteBlockPool.Allocator - Class in org.apache.lucene.util
Abstract class for allocating and freeing byte blocks.
ByteBlockPool.Allocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.Allocator
 
ByteBlockPool.DirectAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles.
ByteBlockPool.DirectAllocator() - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
ByteBlockPool.DirectAllocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
ByteBlockPool.DirectTrackingAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles, but tracks how much total RAM is in use.
ByteBlockPool.DirectTrackingAllocator(AtomicLong) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
ByteBlockPool.DirectTrackingAllocator(int, AtomicLong) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
ByteFieldSource - Class in org.apache.lucene.search.function
Expert: obtains single byte field values from the FieldCache using getBytes() and makes those values available as other numeric types, casting as needed.
ByteFieldSource(String) - Constructor for class org.apache.lucene.search.function.ByteFieldSource
Create a cached byte field source with default string-to-byte parser.
ByteFieldSource(String, FieldCache.ByteParser) - Constructor for class org.apache.lucene.search.function.ByteFieldSource
Create a cached byte field source with a specific string-to-byte parser.
byteOffset - Variable in class org.apache.lucene.util.ByteBlockPool
 
bytes - Variable in class org.apache.lucene.util.BytesRef
The contents of the BytesRef.
bytes - Variable in class org.apache.lucene.util.fst.FST.BytesReader
 
BYTES_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
 
bytesDifference(byte[], int, byte[], int) - Static method in class org.apache.lucene.util.StringHelper
Compares two byte[] arrays, element by element, and returns the number of elements common to both arrays.
bytesEquals(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Expert: compares the bytes against another BytesRef, returning true if the bytes are equal.
ByteSequenceOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a sequence of bytes.
bytesNeeded(int) - Static method in class org.apache.lucene.util.Vint8
Returns the number of bytes needed to encode number.
BytesRef - Class in org.apache.lucene.util
Represents byte[], as a slice (offset + length) into an existing byte[].
BytesRef() - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef with BytesRef.EMPTY_BYTES
BytesRef(byte[], int, int) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(byte[]) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(int) - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef pointing to a new array of size capacity.
BytesRef(CharSequence) - Constructor for class org.apache.lucene.util.BytesRef
Initialize the byte[] from the UTF8 bytes for the provided String.
BytesRefFSTEnum<T> - Class in org.apache.lucene.util.fst
Enumerates all input (BytesRef) + output pairs in an FST.
BytesRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum
doFloor controls the behavior of advance: if it's true doFloor is true, advance positions to the biggest term before target.
BytesRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
Holds a single input (BytesRef) + output pair.
BytesRefFSTEnum.InputOutput() - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
BytesRefHash - Class in org.apache.lucene.util
BytesRefHash is a special purpose hash-map like data-structure optimized for BytesRef instances.
BytesRefHash() - Constructor for class org.apache.lucene.util.BytesRefHash
BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash.BytesStartArray - Class in org.apache.lucene.util
Manages allocation of the per-term addresses.
BytesRefHash.BytesStartArray() - Constructor for class org.apache.lucene.util.BytesRefHash.BytesStartArray
 
BytesRefHash.DirectBytesStartArray - Class in org.apache.lucene.util
A simple BytesRefHash.BytesStartArray that tracks memory allocation using a private AtomicLong instance.
BytesRefHash.DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
Thrown if a BytesRef exceeds the BytesRefHash limit of ByteBlockPool.BYTE_BLOCK_SIZE-2.
BytesRefHash.TrackingDirectBytesStartArray - Class in org.apache.lucene.util
A simple BytesRefHash.BytesStartArray that tracks all memory allocation using a shared AtomicLong instance.
BytesRefHash.TrackingDirectBytesStartArray(int, AtomicLong) - Constructor for class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
BytesRefIterator - Interface in org.apache.lucene.util
A simple iterator interface for BytesRef iteration.
BytesRefList - Class in org.apache.lucene.search.suggest
A simple append only random-access BytesRef array that stores full copies of the appended bytes in a ByteBlockPool.
BytesRefList() - Constructor for class org.apache.lucene.search.suggest.BytesRefList
Creates a new BytesRefList
BytesRefSorter - Interface in org.apache.lucene.search.suggest.fst
Collects BytesRef and then allows one to iterate over their sorted order.
byteStart(int) - Method in class org.apache.lucene.util.BytesRefHash
Returns the bytesStart offset into the internally used ByteBlockPool for the given ord
bytesToCharSequence(BytesRef, Random) - Static method in class org.apache.lucene.util._TestUtil
 
bytesUsed() - Method in class org.apache.lucene.search.suggest.BytesRefList
Returns the number internally used bytes to hold the appended bytes in memory
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
A AtomicLong reference holding the number of bytes used by this BytesRefHash.BytesStartArray.
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
bytesUsed - Variable in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
bytesUsed() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
byteToFloat(byte, int, int) - Static method in class org.apache.lucene.util.SmallFloat
Converts an 8 bit float to a 32 bit float.
byteUpto - Variable in class org.apache.lucene.util.ByteBlockPool
 
ByteVector - Class in org.apache.lucene.analysis.compound.hyphenation
This class implements a simple byte vector with access to the underlying array.
ByteVector() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
 
ByteVector(int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
 
ByteVector(byte[]) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
 
ByteVector(byte[], int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
 

C

cache - Variable in class org.apache.lucene.search.CachingWrapperFilter
 
cache - Variable in class org.apache.lucene.search.FilterManager
Deprecated.
The cache itself
cacheCleanSize - Variable in class org.apache.lucene.search.FilterManager
Deprecated.
Maximum allowed cache size
cachedDocs - Variable in class org.apache.lucene.search.CachingCollector
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.ByteFieldSource
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.FieldCacheSource
Check if equals to another FieldCacheSource, already knowing that cache and field are equal.
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.FloatFieldSource
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.IntFieldSource
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.ShortFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.ByteFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.FieldCacheSource
Return a hash code of a FieldCacheSource, without the hash-codes of the field and the cache (those are taken care of elsewhere).
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.FloatFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.IntFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.ShortFieldSource
 
CachedFilterBuilder - Class in org.apache.lucene.xmlparser.builders
Filters are cached in an LRU Cache keyed on the contained query or filter object.
CachedFilterBuilder(QueryBuilderFactory, FilterBuilderFactory, int) - Constructor for class org.apache.lucene.xmlparser.builders.CachedFilterBuilder
 
cachedSegs - Variable in class org.apache.lucene.search.CachingCollector
 
CachingCollector - Class in org.apache.lucene.search
Caches all docs, and optionally also scores, coming from a search, and is then able to replay them to another collector.
CachingSpanFilter - Class in org.apache.lucene.search
Wraps another SpanFilter's result and caches it.
CachingSpanFilter(SpanFilter) - Constructor for class org.apache.lucene.search.CachingSpanFilter
New deletions always result in a cache miss, by default (CachingWrapperFilter.DeletesMode.RECACHE.
CachingSpanFilter(SpanFilter, CachingWrapperFilter.DeletesMode) - Constructor for class org.apache.lucene.search.CachingSpanFilter
 
CachingTokenFilter - Class in org.apache.lucene.analysis
This class can be used if the token attributes of a TokenStream are intended to be consumed more than once.
CachingTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.CachingTokenFilter
 
CachingWrapperFilter - Class in org.apache.lucene.search
Wraps another filter's result and caches it.
CachingWrapperFilter(Filter) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
New deletes are ignored by default, which gives higher cache hit rate on reopened readers.
CachingWrapperFilter(Filter, CachingWrapperFilter.DeletesMode) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
Expert: by default, the cached filter will be shared across reopened segments that only had changes to their deletions.
CachingWrapperFilter.DeletesMode - Enum in org.apache.lucene.search
Expert: Specifies how new deletions against a reopened reader should be handled.
CachingWrapperFilterHelper - Class in org.apache.lucene.search
A unit test helper class to test when the filter is getting cached and when it is not.
CachingWrapperFilterHelper(Filter) - Constructor for class org.apache.lucene.search.CachingWrapperFilterHelper
 
calcBaseHashIndex(K) - Method in class org.apache.lucene.util.collections.ArrayHashMap
Calculating the baseHash index using the internal internal hashFactor.
calcBaseHashIndex(float) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
Calculating the baseHash index using the internal hashFactor.
calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntHashSet
Calculating the baseHash index using the internal hashFactor .
calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
Calculating the baseHash index using the internal hashFactor .
calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
Calculating the baseHash index using the internal hashFactor.
calcBaseHashIndex(int) - Method in class org.apache.lucene.util.collections.IntToObjectMap
Calculating the baseHash index using the internal hashFactor.
calcBaseHashIndex(K) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
Calculating the baseHash index using the internal hashFactor.
calcBaseHashIndex(K) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
Calculating the baseHash index using the internal hashFactor.
calculateMidpoint(LatLng) - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
Deprecated.
 
calculateMidpoint(LatLng) - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
Deprecated.
 
calculateMidpoint(LatLng) - Method in class org.apache.lucene.spatial.geometry.LatLng
Deprecated.
Calculate the midpoint between this point an another.
calculateShingleWeight(Token, List<Token>, int, List<ShingleMatrixFilter.Matrix.Column.Row>, List<Token>) - Method in class org.apache.lucene.analysis.shingle.ShingleMatrixFilter
Deprecated.
Evaluates the new shingle token weight.
calibrateSizeByDeletes - Variable in class org.apache.lucene.index.LogMergePolicy
 
CannedTokenStream - Class in org.apache.lucene.analysis
TokenStream from a canned list of Tokens.
CannedTokenStream(Token...) - Constructor for class org.apache.lucene.analysis.CannedTokenStream
 
cantOpenSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
True if we were unable to open the segments_N file.
capacity() - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
returns current capacity of array
capacity() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
returns current capacity of array
capacity() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
 
capacity() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
 
capacity() - Method in class org.apache.lucene.util.OpenBitSet
Returns the current capacity in bits (1 greater than the index of the last bit)
capacityChars() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Returns the current character capacity of the CategoryPath.
capacityComponents() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Returns the current component capacity of the CategoryPath.
captureState() - Method in class org.apache.lucene.util.AttributeSource
Captures the state of all Attributes.
CARAT - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
CARAT - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
RegularExpression Id.
CARAT - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
RegularExpression Id.
cardinality() - Method in class org.apache.lucene.util.FixedBitSet
Returns number of set bits.
cardinality() - Method in class org.apache.lucene.util.OpenBitSet
 
CarmelTopKTermPruningPolicy - Class in org.apache.lucene.index.pruning
Pruning policy with a search quality parameterized guarantee - configuration of this policy allows to specify two parameters: k and ε such that: For any OR query with r terms, the score of each of the top k results in the original index, should be "practically the same" as the score that document in the pruned index: the scores difference should not exceed r * ε.
CarmelTopKTermPruningPolicy(IndexReader, Map<String, Integer>) - Constructor for class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
Constructor with default parameters
CarmelTopKTermPruningPolicy(IndexReader, Map<String, Integer>, int, float, int, Similarity) - Constructor for class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
Constructor with specific settings
CarmelTopKTermPruningPolicy.ByDocComparator - Class in org.apache.lucene.index.pruning
 
CarmelTopKTermPruningPolicy.ByDocComparator() - Constructor for class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy.ByDocComparator
 
CarmelUniformTermPruningPolicy - Class in org.apache.lucene.index.pruning
Enhanced implementation of Carmel Uniform Pruning, TermPositions whose in-document frequency is below a specified threshold See CarmelTopKTermPruningPolicy for link to the paper describing this policy. are pruned.
CarmelUniformTermPruningPolicy(IndexReader, Map<String, Integer>, Map<String, Float>, float, Similarity) - Constructor for class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy
 
CarmelUniformTermPruningPolicy.ByDocComparator - Class in org.apache.lucene.index.pruning
 
CarmelUniformTermPruningPolicy.ByDocComparator() - Constructor for class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy.ByDocComparator
 
CartesianPoint - Class in org.apache.lucene.spatial.geometry
Deprecated.
CartesianPoint(int, int) - Constructor for class org.apache.lucene.spatial.geometry.CartesianPoint
Deprecated.
 
CartesianPolyFilterBuilder - Class in org.apache.lucene.spatial.tier
Deprecated.
CartesianPolyFilterBuilder(String, int, int) - Constructor for class org.apache.lucene.spatial.tier.CartesianPolyFilterBuilder
Deprecated.
 
CartesianShapeFilter - Class in org.apache.lucene.spatial.tier
Deprecated.
CartesianTierPlotter - Class in org.apache.lucene.spatial.tier.projections
Deprecated.
CartesianTierPlotter(int, IProjector, String) - Constructor for class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
Deprecated.
 
CatalanAnalyzer - Class in org.apache.lucene.analysis.ca
Analyzer for Catalan.
CatalanAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
Builds an analyzer with the default stop words: CatalanAnalyzer.DEFAULT_STOPWORD_FILE.
CatalanAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
Builds an analyzer with the given stop words.
CatalanAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
Builds an analyzer with the given stop words.
CatalanStemmer - Class in org.tartarus.snowball.ext
This class was automatically generated by a Snowball to Java compiler It implements the stemming algorithm defined by a snowball script.
CatalanStemmer() - Constructor for class org.tartarus.snowball.ext.CatalanStemmer
 
categoriesMap - Variable in class org.apache.lucene.facet.index.CategoryDocumentBuilder
 
CATEGORY - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
CATEGORY_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
CategoryAttribute - Interface in org.apache.lucene.facet.index.attributes
An attribute which contains for a certain category the CategoryPath and additional properties.
categoryAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryAttributesStream
 
categoryAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
An attribute containing all data related to the category
categoryAttribute - Variable in class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
The stream's category attributes.
CategoryAttributeImpl - Class in org.apache.lucene.facet.index.attributes
An implementation of CategoryAttribute.
CategoryAttributeImpl() - Constructor for class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
Construct an empty CategoryAttributeImpl.
CategoryAttributeImpl(CategoryPath) - Constructor for class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
Construct a CategoryAttributeImpl with the given CategoryPath.
CategoryAttributesIterable - Class in org.apache.lucene.facet.index.attributes
This class transforms an Iterable of CategoryPath objects into an Iterable of CategoryAttribute objects, which can be used to construct a CategoryAttributesStream.
CategoryAttributesIterable(Iterable<CategoryPath>) - Constructor for class org.apache.lucene.facet.index.attributes.CategoryAttributesIterable
 
CategoryAttributesStream - Class in org.apache.lucene.facet.index.streaming
An attribute stream built from an Iterable of CategoryAttribute.
CategoryAttributesStream(Iterable<CategoryAttribute>) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryAttributesStream
Constructor
CategoryContainer - Class in org.apache.lucene.facet.index
A container to add categories which are to be introduced to CategoryDocumentBuilder.setCategories(Iterable).
CategoryContainer() - Constructor for class org.apache.lucene.facet.index.CategoryContainer
Constructor.
CategoryDocumentBuilder - Class in org.apache.lucene.facet.index
A utility class which allows attachment of CategoryPaths or CategoryAttributes to a given document using a taxonomy.
CategoryDocumentBuilder(TaxonomyWriter) - Constructor for class org.apache.lucene.facet.index.CategoryDocumentBuilder
Creating a facets document builder with default facet indexing parameters.
CategoryDocumentBuilder(TaxonomyWriter, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.CategoryDocumentBuilder
Creating a facets document builder with a given facet indexing parameters object.
CategoryEnhancement - Interface in org.apache.lucene.facet.enhancements
This interface allows easy addition of enhanced category features.
CategoryListCache - Class in org.apache.lucene.facet.search.cache
CategoryListCache() - Constructor for class org.apache.lucene.facet.search.cache.CategoryListCache
 
CategoryListData - Class in org.apache.lucene.facet.search.cache
Category list data maintained in RAM.
CategoryListData() - Constructor for class org.apache.lucene.facet.search.cache.CategoryListData
Empty constructor for extensions with modified computation of the data.
CategoryListIterator - Interface in org.apache.lucene.facet.search
An interface for iterating over a "category list", i.e., the list of categories per document.
CategoryListParams - Class in org.apache.lucene.facet.index.params
Contains parameters for a category list *
CategoryListParams() - Constructor for class org.apache.lucene.facet.index.params.CategoryListParams
Constructs a default category list parameters object, using CategoryListParams.DEFAULT_TERM.
CategoryListParams(Term) - Constructor for class org.apache.lucene.facet.index.params.CategoryListParams
Constructs a category list parameters object, using the given Term.
CategoryListPayloadStream - Class in org.apache.lucene.facet.index
Accumulates category IDs for a single document, for writing in byte array form, for example, to a Lucene Payload.
CategoryListPayloadStream(IntEncoder) - Constructor for class org.apache.lucene.facet.index.CategoryListPayloadStream
Creates a Payload stream using the specified encoder.
CategoryListTokenizer - Class in org.apache.lucene.facet.index.streaming
A base class for category list tokenizers, which add category list tokens to category streams.
CategoryListTokenizer(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryListTokenizer
 
CategoryParentsStream - Class in org.apache.lucene.facet.index.streaming
This class adds parents to a CategoryAttributesStream.
CategoryParentsStream(CategoryAttributesStream, TaxonomyWriter, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryParentsStream
Constructor.
categoryPath - Variable in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
The category path instance.
CategoryPath - Class in org.apache.lucene.facet.taxonomy
A CategoryPath holds a sequence of string components, specifying the hierarchical name of a category.
CategoryPath(int, int) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
Construct a new empty CategoryPath object.
CategoryPath() - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
Create an empty CategoryPath object.
CategoryPath(String, char) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
Construct a new CategoryPath object, given a single string with components separated by a given delimiter character.
CategoryPath(CharSequence...) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
Construct a new CategoryPath object, copying an existing path given as an array of strings.
CategoryPath(CategoryPath) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
Construct a new CategoryPath object, copying the path given in an existing CategoryPath object.
CategoryPath(CategoryPath, int) - Constructor for class org.apache.lucene.facet.taxonomy.CategoryPath
Construct a new CategoryPath object, copying a prefix with the given number of components of the path given in an existing CategoryPath object.
CategoryProperty - Interface in org.apache.lucene.facet.index.attributes
Property that can be added to CategoryAttributes during indexing.
CategoryTokenizer - Class in org.apache.lucene.facet.index.streaming
Basic class for setting the CharTermAttributes and PayloadAttributes of category tokens.
CategoryTokenizer(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryTokenizer
 
CategoryTokenizerBase - Class in org.apache.lucene.facet.index.streaming
A base class for all token filters which add term and payload attributes to tokens and are to be used in CategoryDocumentBuilder.
CategoryTokenizerBase(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CategoryTokenizerBase
Constructor.
centroid() - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
Deprecated.
 
centroid() - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
Deprecated.
Return the centroid
centroid() - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
Deprecated.
 
ChainedFilter - Class in org.apache.lucene.search
Allows multiple Filters to be chained.
ChainedFilter(Filter[]) - Constructor for class org.apache.lucene.search.ChainedFilter
Ctor.
ChainedFilter(Filter[], int[]) - Constructor for class org.apache.lucene.search.ChainedFilter
Ctor.
ChainedFilter(Filter[], int) - Constructor for class org.apache.lucene.search.ChainedFilter
Ctor.
changed() - Method in class org.apache.lucene.index.SegmentInfos
Call this before committing if changes have been made to the segments.
CharacterDefinition - Class in org.apache.lucene.analysis.ja.dict
Character category data.
characters(char[], int, int) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
 
CharacterUtils - Class in org.apache.lucene.util
CharacterUtils provides a unified interface to Character-related operations to implement backwards compatible character operations based on a Version instance.
CharacterUtils() - Constructor for class org.apache.lucene.util.CharacterUtils
 
CharacterUtils.CharacterBuffer - Class in org.apache.lucene.util
A simple IO buffer to use with CharacterUtils.fill(CharacterBuffer, Reader).
charArray - Variable in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
Character array containing token text
CharArrayIterator - Class in org.apache.lucene.analysis.util
A CharacterIterator used internally for use with BreakIterator
CharArrayIterator() - Constructor for class org.apache.lucene.analysis.util.CharArrayIterator
 
CharArrayMap<V> - Class in org.apache.lucene.analysis
A simple class that stores key Strings as char[]'s in a hash table.
CharArrayMap(Version, int, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
Create map with enough capacity to hold startSize terms
CharArrayMap(Version, Map<?, ? extends V>, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
Creates a map from the mappings in another map.
CharArrayMap.EntryIterator - Class in org.apache.lucene.analysis
public iterator class so efficient methods are exposed to users
CharArrayMap.EntrySet - Class in org.apache.lucene.analysis
public EntrySet class so efficient methods are exposed to users
CharArraySet - Class in org.apache.lucene.analysis
A simple class that stores Strings as char[]'s in a hash table.
CharArraySet(Version, int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
Create set with enough capacity to hold startSize terms
CharArraySet(Version, Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
Creates a set from a Collection of objects.
CharArraySet(int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
CharArraySet(Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
CharArraySet.CharArraySetIterator - Class in org.apache.lucene.analysis
Deprecated.
Use the standard iterator, which returns char[] instances.
charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
charAt(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
 
charAt(int) - Method in class org.apache.lucene.queryParser.core.util.UnescapedCharSequence
 
charAt(int) - Method in class org.apache.lucene.util.CharsRef
 
CharFilter - Class in org.apache.lucene.analysis
Subclasses of CharFilter can be chained to filter CharStream.
CharFilter(CharStream) - Constructor for class org.apache.lucene.analysis.CharFilter
 
CharReader - Class in org.apache.lucene.analysis
CharReader is a Reader wrapper.
chars - Variable in class org.apache.lucene.facet.taxonomy.CategoryPath
 
chars - Variable in class org.apache.lucene.util.CharsRef
 
charsEquals(CharsRef) - Method in class org.apache.lucene.util.CharsRef
 
CHARSEQUENCE_COMPARATOR - Static variable in class org.apache.lucene.search.suggest.Lookup
A simple char-by-char comparator for CharSequence
charset - Variable in class org.apache.lucene.analysis.payloads.IdentityEncoder
 
CHARSET_UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
UTF-8 Charset instance to prevent repeated Charset.forName(String) lookups
charsetName - Variable in class org.apache.lucene.analysis.payloads.IdentityEncoder
Deprecated.
This field is no longer used. Use IdentityEncoder.charset instead.
charsNeededForFullPath() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Returns the number of characters required to represent this entire category path, if written using CategoryPath.copyToCharArray(char[], int, int, char) or CategoryPath.appendTo(Appendable, char).
CharsRef - Class in org.apache.lucene.util
Represents char[], as a slice (offset + length) into an existing char[].
CharsRef() - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized an empty array zero-length
CharsRef(int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with an array of the given capacity
CharsRef(char[], int, int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given array, offset and length
CharsRef(String) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given Strings character array
CharStream - Class in org.apache.lucene.analysis
CharStream adds CharStream.correctOffset(int) functionality over Reader.
CharStream() - Constructor for class org.apache.lucene.analysis.CharStream
 
CharStream - Interface in org.apache.lucene.queryParser
This interface describes a character stream that maintains line and column number positions of the characters.
CharStream - Interface in org.apache.lucene.queryParser.surround.parser
This interface describes a character stream that maintains line and column number positions of the characters.
CharTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The term text of a Token.
CharTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
The term text of a Token.
CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
CharTokenizer - Class in org.apache.lucene.analysis
An abstract base class for simple, character-oriented tokenizers.
CharTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Creates a new CharTokenizer instance
CharTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Creates a new CharTokenizer instance
CharTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Creates a new CharTokenizer instance
CharTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Deprecated.
use CharTokenizer.CharTokenizer(Version, Reader) instead. This will be removed in Lucene 4.0.
CharTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Deprecated.
use CharTokenizer.CharTokenizer(Version, AttributeSource, Reader) instead. This will be removed in Lucene 4.0.
CharTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Deprecated.
CharType - Class in org.apache.lucene.analysis.cn.smart
Internal SmartChineseAnalyzer character type constants.
CharType() - Constructor for class org.apache.lucene.analysis.cn.smart.CharType
 
CharVector - Class in org.apache.lucene.analysis.compound.hyphenation
This class implements a simple char vector with access to the underlying array.
CharVector() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
 
CharVector(int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
 
CharVector(char[]) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
 
CharVector(char[], int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
 
check(Query) - Static method in class org.apache.lucene.search.QueryUtils
Check the types of things query objects should be able to do.
check(Random, Query, Searcher) - Static method in class org.apache.lucene.search.QueryUtils
Various query sanity checks on a searcher, some checks are only done for instanceof IndexSearcher.
check(Random, Query, Searcher, boolean) - Static method in class org.apache.lucene.search.QueryUtils
 
check(FieldCache.CacheEntry...) - Method in class org.apache.lucene.util.FieldCacheSanityChecker
Tests a CacheEntry[] for indication of "insane" cache usage.
checkAnalysisConsistency(Random, Analyzer, boolean, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
checkAnalysisConsistency(Random, Analyzer, boolean, String, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
checkCondition(CharSequence) - Method in class org.apache.lucene.analysis.hunspell.HunspellAffix
Checks whether the given text matches the conditional pattern on this affix
checkDistanceSubQueries(DistanceQuery, String) - Static method in class org.apache.lucene.queryParser.surround.parser.QueryParser
 
checkDocIds(String, int[], ScoreDoc[]) - Static method in class org.apache.lucene.search.CheckHits
Tests that a Hits has an expected order of documents
checkEqual(Query, ScoreDoc[], ScoreDoc[]) - Static method in class org.apache.lucene.search.CheckHits
 
checkEqual(Query, Query) - Static method in class org.apache.lucene.search.QueryUtils
 
checkExplanations(Query, String, Searcher) - Static method in class org.apache.lucene.search.CheckHits
Asserts that the explanation value for every document matching a query corresponds with the true score.
checkExplanations(Query, String, Searcher, boolean) - Static method in class org.apache.lucene.search.CheckHits
Asserts that the explanation value for every document matching a query corresponds with the true score.
checkExplanations(Query) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
 
checkExplanations(Query, Searcher) - Static method in class org.apache.lucene.search.QueryUtils
deep check that explanations of a query 'score' correctly
checkHashEquals(Query) - Static method in class org.apache.lucene.search.QueryUtils
check very basic hashCode and equals
checkHeader(DataInput, String, int, int) - Static method in class org.apache.lucene.util.CodecUtil
 
checkHitCollector(Random, Query, String, Searcher, int[]) - Static method in class org.apache.lucene.search.CheckHits
Tests that a query matches the an expected set of documents using a HitCollector.
CheckHits - Class in org.apache.lucene.search
Utility class for asserting expected hits in tests.
CheckHits() - Constructor for class org.apache.lucene.search.CheckHits
 
checkHits(Random, Query, String, Searcher, int[]) - Static method in class org.apache.lucene.search.CheckHits
Tests that a query matches the an expected set of documents using Hits.
CheckHits.ExplanationAsserter - Class in org.apache.lucene.search
Asserts that the score explanation for every document matching a query corresponds with the true score.
CheckHits.ExplanationAsserter(Query, String, Searcher) - Constructor for class org.apache.lucene.search.CheckHits.ExplanationAsserter
Constructs an instance which does shallow tests on the Explanation
CheckHits.ExplanationAsserter(Query, String, Searcher, boolean) - Constructor for class org.apache.lucene.search.CheckHits.ExplanationAsserter
 
CheckHits.ExplanationAssertingSearcher - Class in org.apache.lucene.search
an IndexSearcher that implicitly checks hte explanation of every match whenever it executes a search.
CheckHits.ExplanationAssertingSearcher(IndexReader) - Constructor for class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
 
CheckHits.SetCollector - Class in org.apache.lucene.search
Just collects document ids into a set.
CheckHits.SetCollector(Set<Integer>) - Constructor for class org.apache.lucene.search.CheckHits.SetCollector
 
checkHitsQuery(Query, ScoreDoc[], ScoreDoc[], int[]) - Static method in class org.apache.lucene.search.CheckHits
Tests that two queries have an expected order of documents, and that the two queries have the same score values.
CheckIndex - Class in org.apache.lucene.index
Basic tool and API to check the health of an index and write a new segments file that removes reference to problematic segments.
CheckIndex(Directory) - Constructor for class org.apache.lucene.index.CheckIndex
Create a new CheckIndex on the directory.
checkIndex() - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
checkIndex(List<String>) - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
checkIndex(Directory) - Static method in class org.apache.lucene.util._TestUtil
This runs the CheckIndex tool on the index in.
CheckIndex.Status - Class in org.apache.lucene.index
Returned from CheckIndex.checkIndex() detailing the health and status of the index.
CheckIndex.Status() - Constructor for class org.apache.lucene.index.CheckIndex.Status
 
CheckIndex.Status.FieldNormStatus - Class in org.apache.lucene.index
Status from testing field norms.
CheckIndex.Status.FieldNormStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
 
CheckIndex.Status.SegmentInfoStatus - Class in org.apache.lucene.index
Holds the status of each segment in the index.
CheckIndex.Status.SegmentInfoStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
 
CheckIndex.Status.StoredFieldStatus - Class in org.apache.lucene.index
Status from testing stored fields.
CheckIndex.Status.StoredFieldStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
 
CheckIndex.Status.TermIndexStatus - Class in org.apache.lucene.index
Status from testing term index.
CheckIndex.Status.TermIndexStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
 
CheckIndex.Status.TermVectorStatus - Class in org.apache.lucene.index
Status from testing stored fields.
CheckIndex.Status.TermVectorStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
 
checkNoMatchExplanations(Query, String, Searcher, int[]) - Static method in class org.apache.lucene.search.CheckHits
Tests that all documents up to maxDoc which are *not* in the expected result set, have an explanation which indicates that the document does not match
checkOneTerm(Analyzer, String, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
checkOneTermReuse(Analyzer, String, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
checkPosition(int) - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
Checks to see if this term is valid at position.
checkRandomData(Random, Analyzer, int) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
utility method for blasting tokenstreams with data to make sure they don't do anything crazy
checkRandomData(Random, Analyzer, int, int) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
utility method for blasting tokenstreams with data to make sure they don't do anything crazy
checkRandomData(Random, Analyzer, int, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
utility method for blasting tokenstreams with data to make sure they don't do anything crazy
checkRandomData(Random, Analyzer, int, int, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
checkRandomData(Random, Analyzer, int, int, boolean, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
 
checkSanity(FieldCache) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
Quick and dirty convenience method
checkSanity(FieldCache.CacheEntry...) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
Quick and dirty convenience method that instantiates an instance with "good defaults" and uses it to test the CacheEntrys
checkSkipTo(Query, IndexSearcher) - Static method in class org.apache.lucene.search.QueryUtils
alternate scorer skipTo(),skipTo(),next(),next(),skipTo(),skipTo(), etc and ensure a hitcollector receives same docs and scores
checkSnapshotted(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Checks if the given id is already used by another snapshot, and throws IllegalStateException if it is.
ChecksumIndexInput - Class in org.apache.lucene.store
Writes bytes through to a primary IndexOutput, computing checksum as it goes.
ChecksumIndexInput(IndexInput) - Constructor for class org.apache.lucene.store.ChecksumIndexInput
 
ChecksumIndexOutput - Class in org.apache.lucene.store
Writes bytes through to a primary IndexOutput, computing checksum.
ChecksumIndexOutput(IndexOutput) - Constructor for class org.apache.lucene.store.ChecksumIndexOutput
 
checkUnequal(Query, Query) - Static method in class org.apache.lucene.search.QueryUtils
 
CHINESE_WORD - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
Chinese Word
ChineseAnalyzer - Class in org.apache.lucene.analysis.cn
Deprecated.
Use StandardAnalyzer instead, which has the same functionality. This analyzer will be removed in Lucene 5.0
ChineseAnalyzer() - Constructor for class org.apache.lucene.analysis.cn.ChineseAnalyzer
Deprecated.
 
ChineseFilter - Class in org.apache.lucene.analysis.cn
Deprecated.
Use StopFilter instead, which has the same functionality. This filter will be removed in Lucene 5.0
ChineseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cn.ChineseFilter
Deprecated.
 
ChineseTokenizer - Class in org.apache.lucene.analysis.cn
Deprecated.
Use StandardTokenizer instead, which has the same functionality. This filter will be removed in Lucene 5.0
ChineseTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.cn.ChineseTokenizer
Deprecated.
 
ChineseTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.cn.ChineseTokenizer
Deprecated.
 
ChineseTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.cn.ChineseTokenizer
Deprecated.
 
ChunksIntEncoder - Class in org.apache.lucene.util.encoding
An IntEncoder which encodes values in chunks.
ChunksIntEncoder(int) - Constructor for class org.apache.lucene.util.encoding.ChunksIntEncoder
 
chunkSize - Variable in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
CITATION - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
CITATION_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
CJ - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
CJ - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
CJ_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
CJKAnalyzer - Class in org.apache.lucene.analysis.cjk
An Analyzer that tokenizes text with StandardTokenizer, normalizes content with CJKWidthFilter, folds case with LowerCaseFilter, forms bigrams of CJK with CJKBigramFilter, and filters stopwords with StopFilter
CJKAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.cjk.CJKAnalyzer
Builds an analyzer which removes words in CJKAnalyzer.getDefaultStopSet().
CJKAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.cjk.CJKAnalyzer
Builds an analyzer with the given stop words
CJKAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.cjk.CJKAnalyzer
Deprecated.
CJKBigramFilter - Class in org.apache.lucene.analysis.cjk
Forms bigrams of CJK terms that are generated from StandardTokenizer or ICUTokenizer.
CJKBigramFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cjk.CJKBigramFilter
CJKBigramFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.cjk.CJKBigramFilter
Create a new CJKBigramFilter, specifying which writing systems should be bigrammed.
CJKTokenizer - Class in org.apache.lucene.analysis.cjk
Deprecated.
Use StandardTokenizer, CJKWidthFilter, CJKBigramFilter, and LowerCaseFilter instead.
CJKTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.cjk.CJKTokenizer
Deprecated.
Construct a token stream processing the given input.
CJKTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.cjk.CJKTokenizer
Deprecated.
 
CJKTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.cjk.CJKTokenizer
Deprecated.
 
CJKWidthFilter - Class in org.apache.lucene.analysis.cjk
A TokenFilter that normalizes CJK width differences: Folds fullwidth ASCII variants into the equivalent basic latin Folds halfwidth Katakana variants into the equivalent kana NOTE: this filter can be viewed as a (practical) subset of NFKC/NFKD Unicode normalization.
CJKWidthFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cjk.CJKWidthFilter
 
Cl2oTaxonomyWriterCache - Class in org.apache.lucene.facet.taxonomy.writercache.cl2o
Cl2oTaxonomyWriterCache(int, float, int) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
 
CLASS_COUNT - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
 
ClassicAnalyzer - Class in org.apache.lucene.analysis.standard
Filters ClassicTokenizer with ClassicFilter, LowerCaseFilter and StopFilter, using a list of English stop words.
ClassicAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
Builds an analyzer with the given stop words.
ClassicAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
Builds an analyzer with the default stop words (ClassicAnalyzer.STOP_WORDS_SET).
ClassicAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
ClassicAnalyzer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
Builds an analyzer with the stop words from the given reader.
ClassicFilter - Class in org.apache.lucene.analysis.standard
Normalizes tokens extracted with ClassicTokenizer.
ClassicFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.standard.ClassicFilter
Construct filtering in.
ClassicTokenizer - Class in org.apache.lucene.analysis.standard
A grammar-based tokenizer constructed with JFlex This should be a good tokenizer for most European-language documents: Splits words at punctuation characters, removing punctuation.
ClassicTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
Creates a new instance of the ClassicTokenizer.
ClassicTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
Creates a new ClassicTokenizer with a given AttributeSource.
ClassicTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
Creates a new ClassicTokenizer with a given AttributeSource.AttributeFactory
classmap - Variable in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
This map stores the character classes
classRules - Static variable in class org.apache.lucene.util.LuceneTestCase
This controls how suite-level rules are nested.
Clause(String) - Method in class org.apache.lucene.queryParser.QueryParser
 
Clause(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
 
clauses() - Method in class org.apache.lucene.search.BooleanFilter
Returns the list of clauses
clauses() - Method in class org.apache.lucene.search.BooleanQuery
Returns the list of clauses in this query.
clauses - Variable in class org.apache.lucene.search.spans.SpanNearQuery
 
clean - Variable in class org.apache.lucene.index.CheckIndex.Status
True if no problems were found with the index.
cleanSleepTime - Variable in class org.apache.lucene.search.FilterManager
Deprecated.
Cache cleaning frequency
cleanUp() - Method in class org.apache.lucene.spatial.tier.DistanceFieldComparatorSource
Deprecated.
 
clear() - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.CharArrayMap
Clears all entries in this map.
clear() - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
clear() - Method in class org.apache.lucene.analysis.CharArraySet
Clears all entries in this set.
clear() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
Reset Vector but don't resize or clear elements
clear() - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.Token
Resets the term text, payload, flags, and positionIncrement, startOffset, endOffset and token type to default.
clear() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
clear() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
 
clear() - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
Resets this attribute to its initial value: a null category path and no properties.
clear() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
 
clear() - Method in class org.apache.lucene.facet.index.attributes.OrdinalProperty
 
clear() - Method in class org.apache.lucene.facet.index.CategoryContainer
Remove all categories.
clear(float[]) - Method in class org.apache.lucene.facet.search.FloatArrayAllocator
 
clear() - Method in interface org.apache.lucene.facet.search.Heap
Clear the heap
clear(int[]) - Method in class org.apache.lucene.facet.search.IntArrayAllocator
 
clear(T) - Method in class org.apache.lucene.facet.search.TemporaryObjectAllocator
Subclasses must override this method to clear an existing object of the desired type, to prepare it for reuse.
clear() - Method in class org.apache.lucene.facet.search.TotalFacetCountsCache
Clear the cache.
clear() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Empty the CategoryPath object, so that it has zero components.
clear() - Method in class org.apache.lucene.index.SegmentInfos
 
clear() - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
Deprecated.
 
clear() - Method in class org.apache.lucene.queryParser.surround.query.SpanNearClauseFactory
 
clear() - Method in class org.apache.lucene.search.grouping.SentinelIntSet
 
clear() - Method in class org.apache.lucene.search.suggest.BytesRefList
Clears this BytesRefList
clear() - Method in class org.apache.lucene.util.AttributeImpl
Clears the values in this AttributeImpl and resets it to its default value.
clear(int) - Method in class org.apache.lucene.util.BitVector
Sets the value of bit to zero.
clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
clears the BytesRefHash.BytesStartArray and returns the cleared instance.
clear(boolean) - Method in class org.apache.lucene.util.BytesRefHash
Clears the BytesRef which maps to the given BytesRef
clear() - Method in class org.apache.lucene.util.BytesRefHash
 
clear() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
clear() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
clear() - Method in class org.apache.lucene.util.collections.ArrayHashMap
Empties the map.
clear() - Method in class org.apache.lucene.util.collections.FloatToObjectMap
Empties the map.
clear(boolean) - Method in class org.apache.lucene.util.collections.IntArray
Clear the IntArray (set all elements to zero).
clear() - Method in class org.apache.lucene.util.collections.IntHashSet
Empties the map.
clear() - Method in class org.apache.lucene.util.collections.IntToDoubleMap
Empties the map.
clear() - Method in class org.apache.lucene.util.collections.IntToIntMap
Empties the map.
clear() - Method in class org.apache.lucene.util.collections.IntToObjectMap
Empties the map.
clear() - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
Empties the map.
clear() - Method in class org.apache.lucene.util.collections.ObjectToIntMap
Empties the map.
clear(int) - Method in class org.apache.lucene.util.FixedBitSet
 
clear(int, int) - Method in class org.apache.lucene.util.FixedBitSet
Clears a range of bits.
clear() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
clear() - Method in class org.apache.lucene.util.MapBackedSet
 
clear(long) - Method in class org.apache.lucene.util.OpenBitSet
clears a bit, allowing access beyond the current set size without changing the size.
clear(int, int) - Method in class org.apache.lucene.util.OpenBitSet
Clears a range of bits.
clear(long, long) - Method in class org.apache.lucene.util.OpenBitSet
Clears a range of bits.
clear() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
clear() - Method in interface org.apache.lucene.util.packed.PackedInts.Mutable
Sets all values to 0.
clear() - Method in class org.apache.lucene.util.PriorityQueue
Removes all entries from the PriorityQueue.
clear() - Method in class org.apache.lucene.util.ScorerDocQueue
Removes all entries from the ScorerDocQueue.
clear() - Method in class org.apache.lucene.util.WeakIdentityMap
 
clearAttributes() - Method in class org.apache.lucene.util.AttributeSource
Resets all Attributes in this AttributeSource by calling AttributeImpl.clear() on each Attribute implementation.
clearCategoryProperties() - Method in class org.apache.lucene.facet.index.streaming.CategoryParentsStream
Clear the properties of the current CategoryAttribute attribute before setting the parent attributes.
clearCrash() - Method in class org.apache.lucene.store.MockDirectoryWrapper
 
clearData() - Method in class org.apache.lucene.benchmark.byTask.stats.Points
Clear all data, prepare for more tests.
clearDoFail() - Method in class org.apache.lucene.store.MockDirectoryWrapper.Failure
 
clearIndex() - Method in class org.apache.lucene.search.spell.SpellChecker
Removes all terms from the spell check index.
clearLock(String) - Method in class org.apache.lucene.store.Directory
Attempt to clear (forcefully unlock and remove) the specified lock.
clearLock(String) - Method in class org.apache.lucene.store.LockFactory
Attempt to clear (forcefully unlock and remove) the specified lock.
clearLock(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
 
clearLock(String) - Method in class org.apache.lucene.store.MockLockFactoryWrapper
 
clearLock(String) - Method in class org.apache.lucene.store.NativeFSLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.NoLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
clearLock(String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.VerifyingLockFactory
 
clearProperties() - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
Clear all properties.
clearProperties() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
 
ClearStatsTask - Class in org.apache.lucene.benchmark.byTask.tasks
Clear statistics data.
ClearStatsTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ClearStatsTask
 
clearTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQuery
Deprecated.
Don't use this method, as its not thread safe and useless.
clearTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
Don't use this method, as its not thread safe and useless.
clearUnhandledExceptions() - Static method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
clnName - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
 
clone() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
 
clone() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
 
clone() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
Clone method.
clone() - Method in class org.apache.lucene.analysis.Token
 
clone(char[], int, int, int, int) - Method in class org.apache.lucene.analysis.Token
Makes a clone, but replaces the term buffer & start/end offset in the process.
clone() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
 
clone() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
 
clone() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
 
clone() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
 
clone() - Method in interface org.apache.lucene.facet.index.attributes.CategoryAttribute
Clone this CategoryAttribute.
clone() - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
 
clone() - Method in class org.apache.lucene.facet.search.params.FacetRequest
 
clone() - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
 
clone() - Method in class org.apache.lucene.index.FieldInfo
 
clone() - Method in class org.apache.lucene.index.FieldInfos
Returns a deep clone of this FieldInfos instance.
clone() - Method in class org.apache.lucene.index.IndexReader
Efficiently clones the IndexReader (sharing most internal state).
clone(boolean) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. Use IndexReader.clone() instead.
clone() - Method in class org.apache.lucene.index.IndexWriterConfig
 
clone() - Method in class org.apache.lucene.index.MultiReader
 
clone(boolean) - Method in class org.apache.lucene.index.MultiReader
Deprecated.
Write support will be removed in Lucene 4.0. Use MultiReader.clone() instead.
clone() - Method in class org.apache.lucene.index.ParallelReader
 
clone(boolean) - Method in class org.apache.lucene.index.ParallelReader
Deprecated.
Write support will be removed in Lucene 4.0. Use ParallelReader.clone() instead.
clone() - Method in class org.apache.lucene.index.Payload
Clones this payload by creating a copy of the underlying byte array.
clone() - Method in class org.apache.lucene.index.SegmentInfo
 
clone() - Method in class org.apache.lucene.index.SegmentInfos
Returns a copy of this instance, also copying each SegmentInfo.
clone() - Method in class org.apache.lucene.index.SegmentReader
 
clone(boolean) - Method in class org.apache.lucene.index.SegmentReader
Deprecated.
clone() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode.QueryText
 
clone() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
 
clone() - Method in class org.apache.lucene.queryParser.surround.query.SrndQuery
 
clone() - Method in class org.apache.lucene.search.BooleanQuery
 
clone() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create a shallow copy of us -- used in rewriting if necessary
clone() - Method in class org.apache.lucene.search.function.CustomScoreQuery
 
clone() - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
 
clone() - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
 
clone() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
clone() - Method in class org.apache.lucene.search.Query
Returns a clone of this query.
clone() - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
clone() - Method in class org.apache.lucene.store.BufferedIndexInput
 
clone() - Method in class org.apache.lucene.store.DataInput
Returns a clone of this stream.
clone() - Method in class org.apache.lucene.store.MockIndexInputWrapper
 
clone() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
clone() - Method in class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
 
clone() - Method in class org.apache.lucene.util.AttributeImpl
Shallow clone.
clone() - Method in class org.apache.lucene.util.AttributeSource.State
 
clone() - Method in class org.apache.lucene.util.BitVector
 
clone() - Method in class org.apache.lucene.util.BytesRef
 
clone() - Method in class org.apache.lucene.util.CharsRef
 
clone() - Method in class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
 
clone() - Method in class org.apache.lucene.util.FixedBitSet
 
clone() - Method in class org.apache.lucene.util.IntsRef
 
clone() - Method in class org.apache.lucene.util.OpenBitSet
 
clone() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
cloneAttributes() - Method in class org.apache.lucene.util.AttributeSource
Performs a clone of all AttributeImpl instances returned in a new AttributeSource instance.
cloneDeletedDocs(BitVector) - Method in class org.apache.lucene.index.SegmentReader
Deprecated. 
cloneDocument(Document) - Static method in class org.apache.lucene.util._TestUtil
 
cloneNormBytes(byte[]) - Method in class org.apache.lucene.index.SegmentReader
Deprecated. 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.AnyQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.BooleanQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.BoostQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.DeletedQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.FieldQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.FuzzyQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.GroupQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.MatchAllDocsQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ModifierQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.NoTokenFoundQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.OpaqueQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricQueryNode
Deprecated.
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ParametricRangeQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.PathQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.PhraseSlopQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.ProximityQueryNode
 
cloneTree() - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
Recursive clone the QueryNode tree The tags are not copied to the new tree when you call the cloneTree() method
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.QuotedFieldQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.SlopQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.core.nodes.TokenizedPhraseQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.standard.nodes.MultiPhraseQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.standard.nodes.PrefixWildcardQueryNode
 
cloneTree() - Method in class org.apache.lucene.queryParser.standard.nodes.WildcardQueryNode
 
close() - Method in class org.apache.lucene.analysis.Analyzer
Frees persistent resources used by this Analyzer
close() - Method in class org.apache.lucene.analysis.CharFilter
 
close() - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
 
close() - Method in class org.apache.lucene.analysis.CharReader
 
close() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAndSuffixAwareTokenFilter
 
close() - Method in class org.apache.lucene.analysis.miscellaneous.PrefixAwareTokenFilter
 
close() - Method in class org.apache.lucene.analysis.MockCharFilter
 
close() - Method in class org.apache.lucene.analysis.MockReaderWrapper
 
close() - Method in class org.apache.lucene.analysis.MockTokenizer
 
close() - Method in class org.apache.lucene.analysis.TokenFilter
Close the input TokenStream.
close() - Method in class org.apache.lucene.analysis.Tokenizer
By default, closes the input Reader.
close() - Method in class org.apache.lucene.analysis.TokenStream
Releases resources associated with this stream.
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
Called when reading from this content source is no longer required.
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
Closes the DocMaker.
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.EnwikiContentSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishContentSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.RandomFacetSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.ReutersContentSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.SingleDocSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
 
close() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
 
close() - Method in class org.apache.lucene.benchmark.byTask.tasks.ConsumeContentSourceTask
 
close() - Method in class org.apache.lucene.benchmark.byTask.tasks.NearRealtimeReaderTask
 
close() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
 
close() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
 
close() - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
 
close() - Method in class org.apache.lucene.benchmark.byTask.utils.StringBuilderReader
 
close() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
 
close() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
Frees used resources as well as closes the underlying IndexWriter, which commits whatever changes made to it to the underlying Directory.
close() - Method in class org.apache.lucene.facet.taxonomy.writercache.cl2o.Cl2oTaxonomyWriterCache
 
close() - Method in class org.apache.lucene.facet.taxonomy.writercache.lru.LruTaxonomyWriterCache
 
close() - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
Let go of whatever resources the cache is holding.
close() - Method in class org.apache.lucene.index.AbstractAllTermDocs
 
close() - Method in class org.apache.lucene.index.CompoundFileWriter
Merge files with the extensions added up to now.
close() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
close() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
 
close() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
 
close() - Method in class org.apache.lucene.index.IndexReader
Closes files associated with this index.
close() - Method in class org.apache.lucene.index.IndexWriter
Commits all changes to an index and closes all associated files.
close(boolean) - Method in class org.apache.lucene.index.IndexWriter
Closes the index with or without waiting for currently running merges to finish.
close() - Method in class org.apache.lucene.index.LogMergePolicy
 
close() - Method in class org.apache.lucene.index.MergePolicy
Release all resources for the policy.
close() - Method in class org.apache.lucene.index.MergeScheduler
Close this MergeScheduler.
close() - Method in class org.apache.lucene.index.MockIndexInput
 
close() - Method in class org.apache.lucene.index.MockRandomMergePolicy
 
close() - Method in class org.apache.lucene.index.MultipleTermPositions
 
close() - Method in class org.apache.lucene.index.NoMergePolicy
 
close() - Method in class org.apache.lucene.index.NoMergeScheduler
 
close() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
Closes the index which writes the snapshots to the directory.
close() - Method in class org.apache.lucene.index.RandomIndexWriter
Close this writer.
close() - Method in class org.apache.lucene.index.SerialMergeScheduler
 
close() - Method in interface org.apache.lucene.index.TermDocs
Frees associated resources.
close() - Method in class org.apache.lucene.index.TermEnum
Closes the enumeration to further activity, freeing resources.
close() - Method in class org.apache.lucene.index.TieredMergePolicy
 
close() - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
close() - Method in class org.apache.lucene.search.FilteredTermEnum
Closes the enumeration to further activity, freeing resources.
close() - Method in class org.apache.lucene.search.FuzzyTermEnum
Closes the enumeration to further activity, freeing resources.
close() - Method in class org.apache.lucene.search.IndexSearcher
Note that the underlying IndexReader is not closed, if IndexSearcher was constructed with IndexSearcher(IndexReader r).
close() - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
 
close() - Method in class org.apache.lucene.search.NRTManagerReopenThread
 
close() - Method in class org.apache.lucene.search.ParallelMultiSearcher
Deprecated.
 
close() - Method in class org.apache.lucene.search.ReferenceManager
Close this ReferenceManager to future acquiring.
close() - Method in class org.apache.lucene.search.regex.RegexTermEnum
 
close() - Method in class org.apache.lucene.search.RemoteSearchable
Deprecated.
 
close() - Method in interface org.apache.lucene.search.Searchable
Deprecated.
Frees resources associated with this Searcher.
close() - Method in class org.apache.lucene.search.Searcher
Deprecated.
 
close() - Method in class org.apache.lucene.search.SearcherLifetimeManager
Close this to future searching; any searches still in process in other threads won't be affected, and they should still call SearcherLifetimeManager.release(org.apache.lucene.search.IndexSearcher) after they are done.
close() - Method in class org.apache.lucene.search.spell.SpellChecker
Close the IndexSearcher used by this SpellChecker
close() - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
Removes any written temporary files.
close() - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesReader
Closes the provided DataInput if it is Closeable.
close() - Method in class org.apache.lucene.search.suggest.fst.Sort.ByteSequencesWriter
Closes the provided DataOutput if it is Closeable.
close() - Method in class org.apache.lucene.store.BufferedIndexOutput
Closes this stream to further operations.
close() - Method in class org.apache.lucene.store.ChecksumIndexInput
 
close() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
close() - Method in class org.apache.lucene.store.Directory
Closes the store.
close() - Method in class org.apache.lucene.store.FileSwitchDirectory
 
close() - Method in class org.apache.lucene.store.FSDirectory
Closes the store to future operations.
close() - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
 
close() - Method in class org.apache.lucene.store.IndexInput
Closes the stream to further operations.
close() - Method in class org.apache.lucene.store.IndexOutput
Closes this stream to further operations.
close() - Method in class org.apache.lucene.store.InputStreamDataInput
 
close() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndex
Deprecated.
 
close() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.
Flushes all changes to an index and closes all associated files.
close() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
Does nothing
close() - Method in class org.apache.lucene.store.instantiated.InstantiatedTermEnum
Closes the enumeration to further activity, freeing resources.
close() - Method in class org.apache.lucene.store.MockDirectoryWrapper
 
close() - Method in class org.apache.lucene.store.MockIndexInputWrapper
 
close() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
 
close() - Method in class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
 
close() - Method in class org.apache.lucene.store.NRTCachingDirectory
Close this directory, which flushes any cached files to the delegate and then closes the delegate.
close() - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
close() - Method in class org.apache.lucene.store.RAMDirectory
Closes the store to future operations, releasing associated memory.
close() - Method in class org.apache.lucene.store.RAMInputStream
 
close() - Method in class org.apache.lucene.store.RAMOutputStream
 
close() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
close() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput.Descriptor
 
close() - Method in class org.apache.lucene.store.WindowsDirectory.WindowsIndexInput
 
close() - Method in class org.apache.lucene.util.BytesRefHash
Closes the BytesRefHash and releases all internally used memory
close() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
close() - Method in class org.apache.lucene.util.encoding.ChunksIntEncoder
 
close() - Method in class org.apache.lucene.util.encoding.IntEncoder
Instructs the encoder to finish the encoding process.
close() - Method in class org.apache.lucene.util.encoding.IntEncoderFilter
 
close() - Method in class org.apache.lucene.util.encoding.NOnesIntEncoder
 
close() - Method in class org.apache.lucene.util.encoding.SortingIntEncoder
 
close(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables.
close(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
 
close() - Method in class org.apache.lucene.util.LineFileDocs
 
close() - Method in class org.apache.lucene.util.ThrottledIndexOutput
 
CloseableThreadLocal<T> - Class in org.apache.lucene.util
Java's builtin ThreadLocal has a serious flaw: it can take an arbitrarily long amount of time to dereference the things you had stored in it, even once the ThreadLocal instance itself is no longer referenced.
CloseableThreadLocal() - Constructor for class org.apache.lucene.util.CloseableThreadLocal
 
CloseIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
Close index writer.
CloseIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseIndexTask
 
CloseQuote1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
CloseQuote2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
CloseReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
Close index reader.
CloseReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseReaderTask
 
closeResources() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
A hook for extending classes to close additional resources that were used.
CloseTaxonomyIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
Close taxonomy index.
CloseTaxonomyIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseTaxonomyIndexTask
 
CloseTaxonomyReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
Close taxonomy reader.
CloseTaxonomyReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseTaxonomyReaderTask
 
closeWhileHandlingException(E, Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(E, Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
 
closeWhileHandlingException(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
 
CodecUtil - Class in org.apache.lucene.util
Utility class for reading and writing versioned headers.
codePointAt(char[], int) - Method in class org.apache.lucene.util.CharacterUtils
Returns the code point at the given index of the char array.
codePointAt(CharSequence, int) - Method in class org.apache.lucene.util.CharacterUtils
Returns the code point at the given index of the CharSequence.
codePointAt(char[], int, int) - Method in class org.apache.lucene.util.CharacterUtils
Returns the code point at the given index of the char array where only elements with index less than the limit are used.
CollationKeyAnalyzer - Class in org.apache.lucene.collation
CollationKeyAnalyzer(Collator) - Constructor for class org.apache.lucene.collation.CollationKeyAnalyzer
 
CollationKeyFilter - Class in org.apache.lucene.collation
Converts each token into its CollationKey, and then encodes the CollationKey with IndexableBinaryStringTools, to allow it to be stored as an index term.
CollationKeyFilter(TokenStream, Collator) - Constructor for class org.apache.lucene.collation.CollationKeyFilter
 
CollationTestBase - Class in org.apache.lucene.analysis
Base test class for testing Unicode collation.
CollationTestBase() - Constructor for class org.apache.lucene.analysis.CollationTestBase
 
collect(int) - Method in class org.apache.lucene.facet.search.FacetsCollector
 
collect(int) - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
 
collect(int) - Method in class org.apache.lucene.search.CheckHits.SetCollector
 
collect(int) - Method in class org.apache.lucene.search.Collector
Called once for every document matching a query, with the unbased document number.
collect(int) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
 
collect(int) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
 
collect(int) - Method in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector
 
collect(int) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
 
collect(int) - Method in class org.apache.lucene.search.grouping.TermAllGroupsCollector
 
collect(int) - Method in class org.apache.lucene.search.join.ToParentBlockJoinCollector
 
collect(int) - Method in class org.apache.lucene.search.MultiCollector
 
collect(int) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
collect(int) - Method in class org.apache.lucene.search.TimeLimitingCollector
Calls Collector.collect(int) on the decorated Collector unless the allowed time has passed, in which case it throws an exception.
collect(int) - Method in class org.apache.lucene.search.TotalHitCountCollector
 
collectFiles(File, ArrayList<File>) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
A convenience method for collecting all the files of a content source from a given directory.
CollectionUtil - Class in org.apache.lucene.util
Methods for manipulating (sorting) collections.
Collector - Class in org.apache.lucene.search
Expert: Collectors are primarily meant to be used to gather raw results from a search, and implement sorting or custom result filtering, collation, etc.
Collector() - Constructor for class org.apache.lucene.search.Collector
 
collector - Variable in class org.apache.lucene.search.grouping.AbstractSecondPassGroupingCollector.SearchGroupDocs
 
collectSpanQueryFields(SpanQuery, Set<String>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
 
CollisionMap - Class in org.apache.lucene.facet.taxonomy.writercache.cl2o
HashMap to store colliding labels.
CollisionMap(CharBlockArray) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
 
CollisionMap(int, CharBlockArray) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.CollisionMap
 
COLON - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
COLON - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
RegularExpression Id.
COLON - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
RegularExpression Id.
COLORED_POST_TAGS - Static variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
COLORED_PRE_TAGS - Static variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
COLS - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
 
column - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.SimpleCharStream
 
column - Variable in class org.apache.lucene.queryParser.standard.parser.JavaCharStream
 
combine(Query[]) - Method in class org.apache.lucene.search.Query
Expert: called when re-writing queries under MultiSearcher.
COMMA - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
RegularExpression Id.
CommandLineUtil - Class in org.apache.lucene.util
Class containing some useful methods used by command line tools
Comment1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
Comment2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
CommentEnd1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
CommentEnd2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
CommentTag() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
 
CommentText1 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
CommentText2 - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
commit() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
Calling commit() ensures that all the categories written so far are visible to a reader that is opened (or reopened) after that call.
commit(Map<String, String>) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
Like commit(), but also store properties with the index.
commit() - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
commit(Map<String, String>) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
commit() - Method in class org.apache.lucene.index.IndexWriter
Commits all pending changes (added & deleted documents, segment merges, added indexes, etc.) to the index, and syncs all referenced index files, such that a reader will see the changes and the index updates will survive an OS or machine crash or power loss.
commit(Map<String, String>) - Method in class org.apache.lucene.index.IndexWriter
Commits all changes to the index, specifying a commitUserData Map (String -> String).
commit() - Method in class org.apache.lucene.index.RandomIndexWriter
 
commit() - Method in class org.apache.lucene.store.instantiated.InstantiatedIndexWriter
Deprecated.
Locks the index and commits the buffered documents.
commit() - Method in interface org.apache.lucene.util.TwoPhaseCommit
The second phase of a 2-phase commit.
commit(Map<String, String>) - Method in interface org.apache.lucene.util.TwoPhaseCommit
Like TwoPhaseCommit.commit(), but takes an additional commit data to be included w/ the commit.
commit() - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
 
commit(Map<String, String>) - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
 
CommitIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
Commits the IndexWriter.
CommitIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CommitIndexTask
 
CommitTaxonomyIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
Commits the Taxonomy Index.
CommitTaxonomyIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CommitTaxonomyIndexTask
 
common(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
common(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
common(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
common(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg common("foo", "foobar") -> "foo"
common(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
common(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
common(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
COMMON_DELIMITER - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
Delimiters will be filtered to this character by SegTokenFilter
compact() - Method in class org.apache.lucene.util.BytesRefHash
Returns the ords array in arbitrary order.
CompactLabelToOrdinal - Class in org.apache.lucene.facet.taxonomy.writercache.cl2o
This is a very efficient LabelToOrdinal implementation that uses a CharBlockArray to store all labels and a configurable number of HashArrays to reference the labels.
CompactLabelToOrdinal(int, float, int) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.cl2o.CompactLabelToOrdinal
 
COMPANY - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
COMPANY - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
COMPANY_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
 
comparator - Static variable in class org.apache.lucene.store.instantiated.InstantiatedTerm
 
comparators - Variable in class org.apache.lucene.search.FieldValueHitQueue
 
compare(ScoreDoc, ScoreDoc) - Method in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy.ByDocComparator
 
compare(ScoreDoc, ScoreDoc) - Method in class org.apache.lucene.index.pruning.CarmelUniformTermPruningPolicy.ByDocComparator
 
compare(TermVectorEntry, TermVectorEntry) - Method in class org.apache.lucene.index.TermVectorEntryFreqSortedComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator
Compare hit at slot1 with hit at slot2.
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
compare(int, int) - Method in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector.GroupHead
Compares the specified document for a specified comparator against the current most relevant document.
compare(SuggestWord, SuggestWord) - Method in class org.apache.lucene.search.spell.SuggestWordFrequencyComparator
 
compare(SuggestWord, SuggestWord) - Method in class org.apache.lucene.search.spell.SuggestWordScoreComparator
 
compare(FieldFragList.WeightedFragInfo, FieldFragList.WeightedFragInfo) - Method in class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder.ScoreComparator
 
compare(int, int) - Method in class org.apache.lucene.util.SorterTemplate
Compares slots i and j of you data.
compareArray(char[], int, char[], int) - Static method in class org.apache.lucene.analysis.cn.smart.Utility
compare two arrays starting at the specified offsets.
compareArrayByPrefix(char[], int, char[], int) - Static method in class org.apache.lucene.analysis.cn.smart.Utility
Compare two arrays, starting at the specified offsets, but treating shortArray as a prefix to longArray.
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator
Compare the bottom of the queue with doc.
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
compareByMergeDocCount - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
 
compareImplementationDistance(Class<? extends C>, VirtualMethod<C>, VirtualMethod<C>) - Static method in class org.apache.lucene.util.VirtualMethod
Utility method that compares the implementation/override distance of two methods.
comparePivot(int) - Method in class org.apache.lucene.util.SorterTemplate
Implements the compare function for the previously stored pivot value.
compareTo(QualityQuery) - Method in class org.apache.lucene.benchmark.quality.QualityQuery
 
compareTo(CategoryPath) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Compares this CategoryPath with the other CategoryPath for lexicographic order.
compareTo(IndexCommit) - Method in class org.apache.lucene.index.IndexCommit
 
compareTo(Term) - Method in class org.apache.lucene.index.Term
Compares two terms, returning a negative integer if this term belongs before the argument, zero if this term is equal to the argument, and a positive integer if this term belongs after the argument.
compareTo(SimpleTerm) - Method in class org.apache.lucene.queryParser.surround.query.SimpleTerm
 
compareTo(FSTCompletion.Completion) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion.Completion
 
compareTo(Lookup.LookupResult) - Method in class org.apache.lucene.search.suggest.Lookup.LookupResult
Compare alphabetically.
compareTo(FieldTermStack.TermInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
 
compareTo(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Unsigned byte order comparison
compareTo(CharsRef) - Method in class org.apache.lucene.util.CharsRef
Signed int order comparison
compareTo(Util.MinResult<T>) - Method in class org.apache.lucene.util.fst.Util.MinResult
 
compareTo(IntsRef) - Method in class org.apache.lucene.util.IntsRef
Signed int order comparison
compareValues(T, T) - Method in class org.apache.lucene.search.FieldComparator
Returns -1 if first is less than second.
compareValues(Float, Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
compIDXEnd - Variable in class org.apache.lucene.search.grouping.AbstractAllGroupHeadsCollector
 
compile(String) - Method in class org.apache.lucene.search.regex.JakartaRegexpCapabilities
 
compile(String) - Method in class org.apache.lucene.search.regex.JavaUtilRegexCapabilities
 
compile(String) - Method in interface org.apache.lucene.search.regex.RegexCapabilities
Called by the constructor of RegexTermEnum allowing implementations to cache a compiled version of the regular expression pattern.
Compile - Class in org.egothor.stemmer
The Compile class is used to compile a stemmer table.
Compile() - Constructor for class org.egothor.stemmer.Compile
 
ComplementCountingAggregator - Class in org.apache.lucene.facet.search.aggregator
A CountingAggregator used during complement counting.
ComplementCountingAggregator(int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.ComplementCountingAggregator
 
ComplexExplanation - Class in org.apache.lucene.search
Expert: Describes the score computation for document and query, and can distinguish a match independent of a positive value.
ComplexExplanation() - Constructor for class org.apache.lucene.search.ComplexExplanation
 
ComplexExplanation(boolean, float, String) - Constructor for class org.apache.lucene.search.ComplexExplanation
 
ComplexPhraseQueryParser - Class in org.apache.lucene.queryParser.complexPhrase
QueryParser which permits complex phrase query syntax eg "(john jon jonathan~) peters*".
ComplexPhraseQueryParser(Version, String, Analyzer) - Constructor for class org.apache.lucene.queryParser.complexPhrase.ComplexPhraseQueryParser
 
ComposedQuery - Class in org.apache.lucene.queryParser.surround.query
 
ComposedQuery(List, boolean, String) - Constructor for class org.apache.lucene.queryParser.surround.query.ComposedQuery
 
compound - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if segment is compound file format.
COMPOUND_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
File extensions of old-style index files
COMPOUND_FILE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of compound file
COMPOUND_FILE_STORE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of compound file for doc store files
COMPOUND_FILES - Static variable in class org.apache.lucene.index.NoMergePolicy
A singleton NoMergePolicy which indicates the index uses compound files.
CompoundFileExtractor - Class in org.apache.lucene.index
Command-line tool for extracting sub-files out of a compound file.
CompoundFileExtractor() - Constructor for class org.apache.lucene.index.CompoundFileExtractor
 
CompoundFileWriter - Class in org.apache.lucene.index
Combines multiple files into a single compound file.
CompoundFileWriter(Directory, String) - Constructor for class org.apache.lucene.index.CompoundFileWriter
Create the compound stream in the specified file.
CompoundWordTokenFilterBase - Class in org.apache.lucene.analysis.compound
Base class for decomposition token filters.
CompoundWordTokenFilterBase(TokenStream, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
CompoundWordTokenFilterBase(TokenStream, String[], boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
CompoundWordTokenFilterBase(TokenStream, Set<?>, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
CompoundWordTokenFilterBase(TokenStream, String[]) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
CompoundWordTokenFilterBase(TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
CompoundWordTokenFilterBase(TokenStream, Set<?>, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
CompoundWordTokenFilterBase(Version, TokenStream, String[], int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
 
CompoundWordTokenFilterBase(Version, TokenStream, String[], boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
 
CompoundWordTokenFilterBase(Version, TokenStream, Set<?>, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
 
CompoundWordTokenFilterBase(Version, TokenStream, String[]) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
 
CompoundWordTokenFilterBase(Version, TokenStream, Set<?>) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
 
CompoundWordTokenFilterBase(Version, TokenStream, Set<?>, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
 
CompoundWordTokenFilterBase.CompoundToken - Class in org.apache.lucene.analysis.compound
Helper class to hold decompounded token information
CompoundWordTokenFilterBase.CompoundToken(int, int) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase.CompoundToken
Construct the compound token based on a slice of the current CompoundWordTokenFilterBase.termAtt.
compress(byte[], int, int, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the specified byte range using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
compress(byte[], int, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the specified byte range, with default BEST_COMPRESSION level
compress(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
Compresses all bytes in the array, with default BEST_COMPRESSION level
CompressionTools - Class in org.apache.lucene.document
Simple utility class providing static methods to compress and decompress binary data for stored fields.
compressString(String) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the String value, with default BEST_COMPRESSION level
compressString(String, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the String value using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
computeLengthNorm(String, int) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
Implemented as: 1/sqrt( steepness * (abs(x-min) + abs(x-max) - (max-min)) + 1 ) .
computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
Implemented as state.getBoost() * lengthNorm(fieldName, numTokens) where numTokens does not count overlap tokens if discountOverlaps is true by default or true for this specific field.
computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.DefaultSimilarity
Implemented as state.getBoost()*lengthNorm(numTerms), where numTerms is FieldInvertState.getLength() if DefaultSimilarity.setDiscountOverlaps(boolean) is false, else it's FieldInvertState.getLength() - FieldInvertState.getNumOverlap().
computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.Similarity
Computes the normalization value for a field, given the accumulated state of term processing for this field (see FieldInvertState).
computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.SimilarityDelegator
Deprecated.
 
computeTestMethods() - Method in class org.apache.lucene.util.LuceneTestCaseRunner
 
ConcurrentMergeScheduler - Class in org.apache.lucene.index
A MergeScheduler that runs each merge using a separate thread.
ConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler
 
ConcurrentMergeScheduler.MergeThread - Class in org.apache.lucene.index
 
ConcurrentMergeScheduler.MergeThread(IndexWriter, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
 
config - Variable in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
 
config - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
 
Config - Class in org.apache.lucene.benchmark.byTask.utils
Perf run configuration properties.
Config(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.utils.Config
Read both algorithm and config properties.
Config(Properties) - Constructor for class org.apache.lucene.benchmark.byTask.utils.Config
Create config without algorithm - useful for a programmatic perf test.
ConfigAttribute - Interface in org.apache.lucene.queryParser.core.config
Deprecated. 
ConfigurationKey<T> - Class in org.apache.lucene.queryParser.core.config
An instance of this class represents a key that is used to retrieve a value from AbstractQueryConfig.
configureWriter(Config, PerfRunData, IndexWriterConfig.OpenMode, IndexCommit) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
 
ConjQuery(CharSequence) - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
 
Conjunction() - Method in class org.apache.lucene.queryParser.QueryParser
 
Conjunction() - Method in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParser
 
ConnectionCosts - Class in org.apache.lucene.analysis.ja.dict
n-gram connection cost data
CONSTANT_SCORE_AUTO_REWRITE_DEFAULT - Static variable in class org.apache.lucene.search.MultiTermQuery
Read-only default instance of MultiTermQuery.ConstantScoreAutoRewrite, with ConstantScoreAutoRewrite.setTermCountCutoff(int) set to ConstantScoreAutoRewrite.DEFAULT_TERM_COUNT_CUTOFF and ConstantScoreAutoRewrite.setDocCountPercent(double) set to ConstantScoreAutoRewrite.DEFAULT_DOC_COUNT_PERCENT.
CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
Like MultiTermQuery.SCORING_BOOLEAN_QUERY_REWRITE except scores are not computed.
CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
Like ScoringRewrite.SCORING_BOOLEAN_QUERY_REWRITE except scores are not computed.
CONSTANT_SCORE_FILTER_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
A rewrite method that first creates a private Filter, by visiting each term in sequence and marking all docs for that term.
Constants - Class in org.apache.lucene.benchmark
Various benchmarking constants (mostly defaults)
Constants() - Constructor for class org.apache.lucene.benchmark.Constants
 
Constants - Class in org.apache.lucene.util
Some useful constants.
ConstantScoreQuery - Class in org.apache.lucene.search
A query that wraps another query or a filter and simply returns a constant score equal to the query boost for every document that matches the filter or query.
ConstantScoreQuery(Query) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Strips off scores from the passed in Query.
ConstantScoreQuery(Filter) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Wraps a Filter as a Query.
ConstantScoreQuery.ConstantScorer - Class in org.apache.lucene.search
 
ConstantScoreQuery.ConstantScorer(Similarity, DocIdSetIterator, Weight) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
ConstantScoreQuery.ConstantWeight - Class in org.apache.lucene.search
 
ConstantScoreQuery.ConstantWeight(Searcher) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
 
ConstantScoreQueryBuilder - Class in org.apache.lucene.xmlparser.builders
 
ConstantScoreQueryBuilder(FilterBuilderFactory) - Constructor for class org.apache.lucene.xmlparser.builders.ConstantScoreQueryBuilder
 
consumeAllTokens() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
TeeSinkTokenFilter passes all tokens to the added sinks when itself is consumed.
ConsumeContentSourceTask - Class in org.apache.lucene.benchmark.byTask.tasks
Consumes a ContentSource.
ConsumeContentSourceTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ConsumeContentSourceTask
 
contains(Object) - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
contains(char[], int, int) - Method in class org.apache.lucene.analysis.CharArraySet
true if the len chars of text starting at off are in the set
contains(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
true if the CharSequence is in the set
contains(Object) - Method in class org.apache.lucene.analysis.CharArraySet
 
contains(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
 
contains(Object) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
 
contains(Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Ellipse
Deprecated.
 
contains(Point2D) - Method in interface org.apache.lucene.spatial.geometry.shape.Geometry2D
Deprecated.
Does the shape contain the given point
contains(Point2D) - Method in class org.apache.lucene.spatial.geometry.shape.Rectangle
Deprecated.
 
contains(int) - Method in class org.apache.lucene.util.collections.IntHashSet
Checks if a given key exists in the map.
contains(Object) - Method in class org.apache.lucene.util.MapBackedSet
 
containsAll(Collection<?>) - Method in class org.apache.lucene.queryParser.core.processors.QueryNodeProcessorPipeline
 
containsKey(char[], int, int) - Method in class org.apache.lucene.analysis.CharArrayMap
true if the len chars of text starting at off are in the CharArrayMap.keySet
containsKey(CharSequence) - Method in class org.apache.lucene.analysis.CharArrayMap
true if the CharSequence is in the CharArrayMap.keySet
containsKey(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
 
containsKey(K) - Method in class org.apache.lucene.util.collections.ArrayHashMap
Returns true iff the key exists in the map.
containsKey(float) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
Checks if a given key exists in the map.
containsKey(int) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
Checks if a given key exists in the map.
containsKey(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
Checks if a given key exists in the map.
containsKey(int) - Method in class org.apache.lucene.util.collections.IntToObjectMap
Checks if a given key exists in the map.
containsKey(K) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
Checks if a given key exists in the map.
containsKey(K) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
Checks if a given key exists in the map.
containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
 
containsTag(String) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
verify if a node contains a tag
containsTag(CharSequence) - Method in interface org.apache.lucene.queryParser.core.nodes.QueryNode
Deprecated.
containsTag(CharSequence) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
Deprecated.
containsTag(String) - Method in class org.apache.lucene.queryParser.core.nodes.QueryNodeImpl
verify if a node contains a tag
containsValue(Object) - Method in class org.apache.lucene.util.collections.ArrayHashMap
Returns true iff the object exists in the map.
containsValue(Object) - Method in class org.apache.lucene.util.collections.FloatToObjectMap
Checks if the given object exists in the map.
containsValue(double) - Method in class org.apache.lucene.util.collections.IntToDoubleMap
Checks if the given value exists in the map.
containsValue(int) - Method in class org.apache.lucene.util.collections.IntToIntMap
Checks if the given object exists in the map.
containsValue(Object) - Method in class org.apache.lucene.util.collections.IntToObjectMap
Checks if the given object exists in the map.
containsValue(float) - Method in class org.apache.lucene.util.collections.ObjectToFloatMap
Checks if the given object exists in the map.
containsValue(int) - Method in class org.apache.lucene.util.collections.ObjectToIntMap
Checks if the given object exists in the map.
ContentItemsSource - Class in org.apache.lucene.benchmark.byTask.feeds
Base class for source of data for benchmarking Keeps track of various statistics, such as how many data items were generated, size in bytes etc.
ContentItemsSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
 
ContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
Represents content from a specified source, such as TREC, Reuters etc.
ContentSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.ContentSource
 
convert(double, DistanceUnits) - Method in enum org.apache.lucene.spatial.geometry.DistanceUnits
Deprecated.
Converts the given distance in given DistanceUnit, to a distance in the unit represented by this
convertStreamToByteArray() - Method in class org.apache.lucene.facet.index.CategoryListPayloadStream
Returns the streamed bytes so far accumulated, as an array of bytes.
coord(int, int) - Method in class org.apache.lucene.search.DefaultSimilarity
Implemented as overlap / maxOverlap.
coord(int, int) - Method in class org.apache.lucene.search.Similarity
Computes a score factor based on the fraction of all query terms that a document contains.
coord(int, int) - Method in class org.apache.lucene.search.SimilarityDelegator
Deprecated.
 
coords(double, double) - Method in interface org.apache.lucene.spatial.tier.projections.IProjector
Deprecated.
 
coords(double, double) - Method in class org.apache.lucene.spatial.tier.projections.SinusoidalProjector
Deprecated.
 
coordsAsString(double, double) - Method in interface org.apache.lucene.spatial.tier.projections.IProjector
Deprecated.
 
coordsAsString(double, double) - Method in class org.apache.lucene.spatial.tier.projections.SinusoidalProjector
Deprecated.
 
copy(Version, Map<?, ? extends V>) - Static method in class org.apache.lucene.analysis.CharArrayMap
Returns a copy of the given map as a CharArrayMap.
copy(Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
Deprecated.
copy(Version, Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
Returns a copy of the given set as a CharArraySet.
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator
This method is called when a new hit is competitive.
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
copy() - Method in class org.apache.lucene.spatial.geometry.FixedLatLng
Deprecated.
 
copy() - Method in class org.apache.lucene.spatial.geometry.FloatLatLng
Deprecated.
 
copy() - Method in class org.apache.lucene.spatial.geometry.LatLng
Deprecated.
 
copy(Directory, String, String) - Method in class org.apache.lucene.store.Directory
Copies the file src to Directory to under the new file name dest.
copy(Directory, Directory, boolean) - Static method in class org.apache.lucene.store.Directory
Deprecated.
should be replaced with calls to Directory.copy(Directory, String, String) for every file that needs copying. You can use the following code:
 IndexFileNameFilter filter = IndexFileNameFilter.getFilter();
 for (String file : src.listAll()) {
   if (filter.accept(null, file)) {
     src.copy(dest, file, file);
   }
 }
 
copy(Directory, String, String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
 
copy(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
Copies the given BytesRef at the current positions ( ByteBlockPool.byteUpto across buffer boundaries
copy(IndexInput, long) - Method in class org.apache.lucene.util.PagedBytes
Read this many bytes from in
copy(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy BytesRef in
copy(BytesRef, BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy BytesRef in, setting BytesRef out to the result.
copy_from(SnowballProgram) - Method in class org.tartarus.snowball.SnowballProgram
 
copyBuffer(char[], int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Copies the contents of buffer, starting at offset for length characters, into the termBuffer array.
copyBuffer(char[], int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
copyBytes(DataInput, long) - Method in class org.apache.lucene.store.DataOutput
Copy numBytes bytes from input to ourself.
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.IndexInput
Copies numBytes bytes to the given IndexOutput.
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.MockIndexInputWrapper
 
copyBytes(DataInput, long) - Method in class org.apache.lucene.store.MockIndexOutputWrapper
 
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.RAMInputStream
 
copyBytes(DataInput, long) - Method in class org.apache.lucene.store.RAMOutputStream
 
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
copyBytes(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Copies the bytes from the given BytesRef NOTE: if this would exceed the array size, this method creates a new reference array.
copyBytes(DataInput, long) - Method in class org.apache.lucene.util.ThrottledIndexOutput
 
copyChars(CharSequence) - Method in class org.apache.lucene.util.BytesRef
Copies the UTF8 bytes for this string.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.BytesRef
Copies the UTF8 bytes for this string.
copyChars(CharsRef) - Method in class org.apache.lucene.util.CharsRef
Copies the given CharsRef referenced content into this instance.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
Copies the given array into this CharsRef.
copyDocGroupValue(GROUP_VALUE_TYPE, GROUP_VALUE_TYPE) - Method in class org.apache.lucene.search.grouping.AbstractFirstPassGroupingCollector
Returns a copy of the specified group value by creating a new instance and copying the value from the specified groupValue in the new instance.
copyDocGroupValue(String, String) - Method in class org.apache.lucene.search.grouping.TermFirstPassGroupingCollector
 
copyFrom(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
 
copyFrom(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST.Arc
Returns this
copyInts(IntsRef) - Method in class org.apache.lucene.util.IntsRef
 
copyText(UnicodeUtil.UTF16Result) - Method in class org.apache.lucene.util.UnicodeUtil.UTF16Result
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.Token
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.facet.index.attributes.CategoryAttributeImpl
 
copyTo(byte[], int) - Method in class org.apache.lucene.index.Payload
Copies the payload data to a byte array.
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.AllowLeadingWildcardAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.AnalyzerAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.BoostAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.DefaultOperatorAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.DefaultPhraseSlopAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.FieldBoostMapAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.FieldDateResolutionMapAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.FuzzyAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.LocaleAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.LowercaseExpandedTermsAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.MultiFieldAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.MultiTermRewriteMethodAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.PositionIncrementsAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.queryParser.standard.config.RangeCollatorAttributeImpl
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.util.AttributeImpl
Copies the values from this Attribute into the passed-in target attribute.
copyTo(AttributeSource) - Method in class org.apache.lucene.util.AttributeSource
Copies the contents of this AttributeSource to the given target AttributeSource.
copyToCharArray(char[], int, int, char) - Method in class org.apache.lucene.facet.taxonomy.CategoryPath
Copies the specified number of components from this category path to the specified character array, with the components separated by a given delimiter character.
copyUsingLengthPrefix(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy bytes in, writing the length as a 1 or 2 byte vInt prefix.
CoreParser - Class in org.apache.lucene.xmlparser
Assembles a QueryBuilder which uses only core Lucene Query objects
CoreParser(Analyzer, QueryParser) - Constructor for class org.apache.lucene.xmlparser.CoreParser
Construct an XML parser that uses a single instance QueryParser for handling UserQuery tags - all parse operations are synchronised on this parser
CoreParser(String, Analyzer) - Constructor for class org.apache.lucene.xmlparser.CoreParser
Constructs an XML parser that creates a QueryParser for each UserQuery request.
CoreParser(String, Analyzer, QueryParser) - Constructor for class org.apache.lucene.xmlparser.CoreParser
 
CorePlusExtensionsParser - Class in org.apache.lucene.xmlparser
 
CorePlusExtensionsParser(Analyzer, QueryParser) - Constructor for class org.apache.lucene.xmlparser.CorePlusExtensionsParser
Construct an XML parser that uses a single instance QueryParser for handling UserQuery tags - all parse operations are synchronized on this parser
CorePlusExtensionsParser(String, Analyzer) - Constructor for class org.apache.lucene.xmlparser.CorePlusExtensionsParser
Constructs an XML parser that creates a QueryParser for each UserQuery request.
correct(int) - Method in class org.apache.lucene.analysis.BaseCharFilter
Retrieve the corrected offset.
correct(int) - Method in class org.apache.lucene.analysis.CharFilter
Subclass may want to override to correct the current offset.
correctOffset(int) - Method in class org.apache.lucene.analysis.CharFilter
Chains the corrected offset through the input CharFilter.
correctOffset(int) - Method in class org.apache.lucene.analysis.CharReader
 
correctOffset(int) - Method in class org.apache.lucene.analysis.CharStream
Called by CharFilter(s) and Tokenizer to correct token offset.
correctOffset(int) - Method in class org.apache.lucene.analysis.MockCharFilter
 
correctOffset(int) - Method in class org.apache.lucene.analysis.Tokenizer
Return the corrected offset.
CorruptIndexException - Exception in org.apache.lucene.index
This exception is thrown when Lucene detects an inconsistency in the index.
CorruptIndexException(String) - Constructor for exception org.apache.lucene.index.CorruptIndexException
 
COULD_NOT_PARSE_NUMBER - Static variable in class org.apache.lucene.queryParser.core.messages.QueryParserMessages
 
count - Static variable in class org.apache.lucene.benchmark.utils.ExtractWikipedia
 
count - Variable in class org.apache.lucene.search.grouping.SentinelIntSet
 
count - Variable in class org.apache.lucene.search.spans.TermSpans
 
count() - Method in class org.apache.lucene.util.BitVector
Returns the total number of one bits in this vector.
counter - Variable in class org.apache.lucene.facet.taxonomy.writercache.cl2o.LabelToOrdinal
 
counter - Variable in class org.apache.lucene.index.SegmentInfos
 
Counter - Class in org.apache.lucene.util
Simple counter class
Counter() - Constructor for class org.apache.lucene.util.Counter
 
counterArray - Variable in class org.apache.lucene.facet.search.aggregator.CountingAggregator
 
CountFacetRequest - Class in org.apache.lucene.facet.search.params
Facet request for counting facets.
CountFacetRequest(CategoryPath, int) - Constructor for class org.apache.lucene.facet.search.params.CountFacetRequest
Create a count facet request for a given node in the taxonomy.
CountingAggregator - Class in org.apache.lucene.facet.search.aggregator
A CountingAggregator updates a counter array with the size of the whole taxonomy, counting the number of times each category appears in the given set of documents.
CountingAggregator(int[]) - Constructor for class org.apache.lucene.facet.search.aggregator.CountingAggregator
 
CountingListTokenizer - Class in org.apache.lucene.facet.index.streaming
CategoryListTokenizer for facet counting
CountingListTokenizer(TokenStream, FacetIndexingParams) - Constructor for class org.apache.lucene.facet.index.streaming.CountingListTokenizer
 
cp - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
crash() - Method in class org.apache.lucene.store.MockDirectoryWrapper
Simulates a crash of OS or machine by overwriting unsynced files.
create(String, String, String, String) - Method in class org.apache.lucene.benchmark.utils.ExtractWikipedia
 
create() - Method in class org.apache.lucene.facet.search.FloatArrayAllocator
 
create() - Method in class org.apache.lucene.facet.search.IntArrayAllocator
 
create(int, boolean) - Static method in class org.apache.lucene.facet.search.ScoredDocIdCollector
Creates a new ScoredDocIdCollector with the given parameters.
create() - Method in class org.apache.lucene.facet.search.TemporaryObjectAllocator
Subclasses must override this method to actually create a new object of the desired type.
create(boolean, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
Creates a CachingCollector which does not wrap another collector.
create(Collector, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
Create a new CachingCollector that wraps the given collector and caches documents and scores up to the specified RAM threshold.
create(Collector, boolean, int) - Static method in class org.apache.lucene.search.CachingCollector
Create a new CachingCollector that wraps the given collector and caches documents and scores up to the specified max docs threshold.
create(SortField[], int) - Static method in class org.apache.lucene.search.FieldValueHitQueue
Creates a hit queue sorted by the given list of fields.
create(String, Sort) - Static method in class org.apache.lucene.search.grouping.TermAllGroupHeadsCollector
Creates an AbstractAllGroupHeadsCollector instance based on the supplied arguments.
create(String, Sort, int) - Static method in class org.apache.lucene.search.grouping.TermAllGroupHeadsCollector
Creates an AbstractAllGroupHeadsCollector instance based on the supplied arguments.
create(Sort, int, boolean, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
Creates a new TopFieldCollector from the given arguments.
create(int, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect and whether documents are scored in order by the input Scorer to TopScoreDocCollector.setScorer(Scorer).
create(int, ScoreDoc, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect, the bottom of the previous page, and whether documents are scored in order by the input Scorer to TopScoreDocCollector.setScorer(Scorer).
createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.association.AssociationFloatSumFacetRequest
 
createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.association.AssociationIntSumFacetRequest
 
createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.CountFacetRequest
 
createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.FacetRequest
Create an aggregator for this facet request.
createAggregator(boolean, FacetArrays, IndexReader, TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.ScoreFacetRequest
 
createAllDocsScoredDocIDs(IndexReader) - Static method in class org.apache.lucene.facet.util.ScoredDocIdsUtils
Creates a ScoredDocIDs which returns document IDs all non-deleted doc ids according to the given reader.
createAnalyzer(String) - Static method in class org.apache.lucene.benchmark.byTask.tasks.NewAnalyzerTask
 
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
 
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource.AttributeFactory
returns an AttributeImpl for the supplied Attribute interface class.
createBox(LatLng, double, double) - Static method in class org.apache.lucene.spatial.geometry.shape.LLRect
Deprecated.
Approximates a box centered at the given point with the given width and height in miles.
createCategoryListIterator(IndexReader, int) - Method in class org.apache.lucene.facet.index.params.CategoryListParams
Create the category list iterator for the specified partition.
createCategoryListIterator(IndexReader, TaxonomyReader, FacetSearchParams, int) - Method in class org.apache.lucene.facet.search.params.FacetRequest
Create the category list iterator for the specified partition.
createCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
 
createCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ar.ArabicAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.bg.BulgarianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ca.CatalanAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.cjk.CJKAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.cn.ChineseAnalyzer
Deprecated.
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.cz.CzechAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.da.DanishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.de.GermanAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.el.GreekAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.en.EnglishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.es.SpanishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.eu.BasqueAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.fa.PersianAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.fi.FinnishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ga.IrishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.gl.GalicianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.hi.HindiAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.hu.HungarianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.hy.ArmenianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.id.IndonesianAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.it.ItalianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ja.JapaneseAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.KeywordAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.lv.LatvianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader, String) - Method in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
Creates a token stream that tokenizes the given string into token terms (aka words).
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
Creates a token stream that tokenizes all the text in the given Reader; This implementation forwards to tokenStream(String, Reader, String) and is less efficient than tokenStream(String, Reader, String).
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
Returns a (possibly reused) TokenStream which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.no.NorwegianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.pl.PolishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.pt.PortugueseAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase
Creates a new ReusableAnalyzerBase.TokenStreamComponents instance for this analyzer.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ro.RomanianAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ru.RussianAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.SimpleAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.StopAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.sv.SwedishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.th.ThaiAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.tr.TurkishAnalyzer
Creates a ReusableAnalyzerBase.TokenStreamComponents which tokenizes all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.WhitespaceAnalyzer
 
createEncoder() - Method in class org.apache.lucene.facet.index.params.CategoryListParams
Allows to override how categories are encoded and decoded.
createFacetResultsHandler(TaxonomyReader) - Method in class org.apache.lucene.facet.search.params.FacetRequest
Creates a new FacetResultsHandler that matches the request logic and current settings, such as depth, limits-mode, etc, as well as the passed in TaxonomyReader.
createFieldFragList(FieldPhraseList, int) - Method in interface org.apache.lucene.search.vectorhighlight.FragListBuilder
create a FieldFragList.
createFieldFragList(FieldPhraseList, int) - Method in class org.apache.lucene.search.vectorhighlight.SimpleFragListBuilder
 
createFieldFragList(FieldPhraseList, int) - Method in class org.apache.lucene.search.vectorhighlight.SingleFragListBuilder
 
createFragment(IndexReader, int, String, FieldFragList) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
createFragment(IndexReader, int, String, FieldFragList, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
createFragment(IndexReader, int, String, FieldFragList) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
create a fragment.
createFragment(IndexReader, int, String, FieldFragList, String[], String[], Encoder) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
create a fragment.
createFragments(IndexReader, int, String, FieldFragList, int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
createFragments(IndexReader, int, String, FieldFragList, int, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
 
createFragments(IndexReader, int, String, FieldFragList, int) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
create multiple fragments.
createFragments(IndexReader, int, String, FieldFragList, int, String[], String[], Encoder) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
create multiple fragments.
CreateIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
Create an index.
CreateIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
 
createIndexWriterConfig(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
Create the IndexWriterConfig that would be used for opening the internal index writer.
createJoinQuery(String, String, Query, IndexSearcher) - Static method in class org.apache.lucene.search.join.JoinUtil
Method for query time joining.
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.DGapIntEncoder
 
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.EightFlagsIntEncoder
 
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.FourFlagsIntEncoder
 
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.IntEncoder
Returns an IntDecoder which matches this encoder.
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.NOnesIntEncoder
 
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.SimpleIntEncoder
 
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.SortingIntEncoder
 
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.UniqueValuesIntEncoder
 
createMatchingDecoder() - Method in class org.apache.lucene.util.encoding.VInt8IntEncoder
 
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.AssertingIndexSearcher
Ensures, that the returned Weight is not normalized again, which may produce wrong scores.
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.IndexSearcher
Creates a normalized weight for a top-level Query.
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
Create weight in multiple index scenario.
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.Searcher
Deprecated.
Creates a normalized weight for a top-level Query.
createOutput(String) - Method in class org.apache.lucene.store.DirectIOLinuxDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.Directory
Creates a new, empty file in the directory with the given name.
createOutput(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.FSDirectory
Creates an IndexOutput for the file with the given name.
createOutput(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
 
createOutput(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.RAMDirectory
Creates a new, empty file in the directory with the given name.
createQueryParser(String, Analyzer) - Method in class org.apache.lucene.xmlparser.builders.UserInputQueryBuilder
Method to create a QueryParser - designed to be overridden
createSample(ScoredDocIDs, int, int) - Method in class org.apache.lucene.facet.search.sampling.RandomSampler
 
createSample(ScoredDocIDs, int, int) - Method in class org.apache.lucene.facet.search.sampling.RepeatableSampler
 
createSample(ScoredDocIDs, int, int) - Method in class org.apache.lucene.facet.search.sampling.Sampler
Create and return a sample of the input set
createScoredDocIds(DocIdSet, int) - Static method in class org.apache.lucene.facet.util.ScoredDocIdsUtils
Create a ScoredDocIDs out of a given docIdSet and the total number of documents in an index
createScoredDocIDsSubset(ScoredDocIDs, int[]) - Static method in class org.apache.lucene.facet.util.ScoredDocIdsUtils
Create a subset of an existing ScoredDocIDs object.
createSearcher() - Method in class org.apache.lucene.index.memory.MemoryIndex
Creates and returns a searcher that can be used to execute arbitrary Lucene queries and to collect the resulting query results as hits.
createSuitableHeap(FacetRequest) - Static method in class org.apache.lucene.facet.util.ResultSortUtils
Create a suitable heap according to facet request being served.
CreateTaxonomyIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
Create a taxonomy index.
CreateTaxonomyIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CreateTaxonomyIndexTask
 
createTempFile(String, String, File) - Static method in class org.apache.lucene.util._TestUtil
insecure, fast version of File.createTempFile uses Random instead of SecureRandom.
createTerm(String) - Method in class org.apache.lucene.index.Term
Optimized construction of new Terms by reusing same field as this Term - avoids field.intern() overhead
createWeight(Searcher) - Method in class org.apache.lucene.search.BooleanQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create the Weight used to score us
createWeight(Searcher) - Method in class org.apache.lucene.search.FilteredQuery
Returns a Weight that applies the filter to the enclosed query's Weight.
createWeight(Searcher) - Method in class org.apache.lucene.search.function.CustomScoreQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.function.ValueSourceQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.PhraseQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.Query
Expert: Constructs an appropriate Weight implementation for this query.
createWeight(Query) - Method in class org.apache.lucene.search.Searcher
Deprecated.
never ever use this method in Weight implementations. Subclasses of Searcher should use Searcher.createNormalizedWeight(org.apache.lucene.search.Query), instead.
createWeight(Searcher) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.spans.SpanQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.TermQuery
 
createWriterConfig(Config, PerfRunData, IndexWriterConfig.OpenMode, IndexCommit) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
 
CSVUtil - Class in org.apache.lucene.analysis.ja.util
Utility class for parsing CSV text
cud - Variable in class org.apache.lucene.queryParser.ext.Extensions.Pair
 
cur - Variable in class org.apache.lucene.queryParser.ext.Extensions.Pair
 
curChar - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
 
curChar - Variable in class org.apache.lucene.queryParser.QueryParserTokenManager
 
curChar - Variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
 
curChar - Variable in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
 
curDocs - Variable in class org.apache.lucene.search.CachingCollector
 
curPos - Variable in class org.apache.lucene.search.suggest.BufferingTermFreqIteratorWrapper
 
current() - Method in class org.apache.lucene.analysis.icu.segmentation.LaoBreakIterator
 
current() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
 
current - Variable in class org.apache.lucene.search.ReferenceManager
 
current() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
current() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
CURRENT_FORMAT - Static variable in class org.apache.lucene.index.SegmentInfos
 
currentDocumentInformation - Variable in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
Calculate the score up to this point for this doc and field
currentTerm - Variable in class org.apache.lucene.search.FilteredTermEnum
the current term
currentTerm - Variable in class org.apache.lucene.store.instantiated.InstantiatedTermDocs
 
currentToken - Variable in exception org.apache.lucene.benchmark.byTask.feeds.demohtml.ParseException
This is the last token that has been consumed successfully.
currentToken - Variable in exception org.apache.lucene.queryParser.ParseException
This is the last token that has been consumed successfully.
currentToken - Variable in exception org.apache.lucene.queryParser.standard.parser.ParseException
This is the last token that has been consumed successfully.
currentToken - Variable in exception org.apache.lucene.queryParser.surround.parser.ParseException
This is the last token that has been consumed successfully.
currentValue() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
returns the value associated with the last key returned
cursor - Variable in class org.tartarus.snowball.SnowballProgram
 
curThr - Variable in class org.apache.lucene.index.pruning.TFTermPruningPolicy
 
CUSTOM - Static variable in class org.apache.lucene.search.SortField
Sort using a custom Comparator.
customExplain(int, Explanation, Explanation[]) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Explain the custom score.
customExplain(int, Explanation, Explanation) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Explain the custom score.
customScore(int, float, float[]) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Compute a custom score by the subQuery score and a number of ValueSourceQuery scores.
customScore(int, float, float) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Compute a custom score by the subQuery score and the ValueSourceQuery score.
CustomScoreProvider - Class in org.apache.lucene.search.function
An instance of this subclass should be returned by CustomScoreQuery.getCustomScoreProvider(org.apache.lucene.index.IndexReader), if you want to modify the custom score calculation of a CustomScoreQuery.
CustomScoreProvider(IndexReader) - Constructor for class org.apache.lucene.search.function.CustomScoreProvider
Creates a new instance of the provider class for the given IndexReader.
CustomScoreQuery - Class in org.apache.lucene.search.function
Query that sets document score as a programmatic function of several (sub) scores: the score of its subQuery (any query) (optional) the score of its ValueSourceQuery (or queries).
CustomScoreQuery(Query) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
Create a CustomScoreQuery over input subQuery.
CustomScoreQuery(Query, ValueSourceQuery) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
Create a CustomScoreQuery over input subQuery and a ValueSourceQuery.
CustomScoreQuery(Query, ValueSourceQuery...) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
Create a CustomScoreQuery over input subQuery and a ValueSourceQuery.
CYRILLIC - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
 
CZECH_STOP_WORDS - Static variable in class org.apache.lucene.analysis.cz.CzechAnalyzer
Deprecated.
CzechAnalyzer - Class in org.apache.lucene.analysis.cz
Analyzer for Czech language.
CzechAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
Builds an analyzer with the default stop words (CzechAnalyzer.getDefaultStopSet()).
CzechAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
Builds an analyzer with the given stop words.
CzechAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
Builds an analyzer with the given stop words and a set of work to be excluded from the CzechStemFilter.
CzechAnalyzer(Version, String...) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
CzechAnalyzer(Version, HashSet<?>) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
CzechAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
CzechStemFilter - Class in org.apache.lucene.analysis.cz
A TokenFilter that applies CzechStemmer to stem Czech words.
CzechStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cz.CzechStemFilter
 
CzechStemmer - Class in org.apache.lucene.analysis.cz
Light Stemmer for Czech.
CzechStemmer() - Constructor for class org.apache.lucene.analysis.cz.CzechStemmer
 

D

DAMMA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
 
DAMMATAN - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
 
DanishAnalyzer - Class in org.apache.lucene.analysis.da
Analyzer for Danish.
DanishAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
Builds an analyzer with the default stop words: DanishAnalyzer.DEFAULT_STOPWORD_FILE.
DanishAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
Builds an analyzer with the given stop words.
DanishAnalyzer(Version, Set<?>, Set<?>) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
Builds an analyzer with the given stop words.
DanishStemmer - Class in org.tartarus.snowball.ext
Generated class implementing code defined by a snowball script.
DanishStemmer() - Constructor for class org.tartarus.snowball.ext.DanishStemmer
 
data - Variable in class org.apache.lucene.index.Payload
the byte array containing the payload data
data - Variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
The key to the node.
DataInput - Class in org.apache.lucene.store
Abstract base class for performing read operations of Lucene's low-level data types.
DataInput() - Constructor for class org.apache.lucene.store.DataInput
 
DataOutput - Class in org.apache.lucene.store
Abstract base class for performing write operations of Lucene's low-level data types.
DataOutput() - Constructor for class org.apache.lucene.store.DataOutput
 
DATE_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
 
DATE_MSEC_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
 
DATE_RESOLUTION - Static variable in class org.apache.lucene.queryParser.standard.config.StandardQueryConfigHandler.ConfigurationKeys
Key used to set default DateTools.Resolution.
DATE_TYPE - Static variable in class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
 
DateField - Class in org.apache.lucene.document
Deprecated.
If you build a new index, use DateTools or NumericField instead. This class is included for use with existing indices and will be removed in a future release (possibly Lucene 4.0).
dateFormat - Variable in class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
 
DateRecognizerSinkFilter - Class in org.apache.lucene.analysis.sinks
Attempts to parse the CharTermAttributeImpl.termBuffer() as a Date using a DateFormat.
DateRecognizerSinkFilter() - Constructor for class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
DateRecognizerSinkFilter(DateFormat) - Constructor for class org.apache.lucene.analysis.sinks.DateRecognizerSinkFilter
 
DateResolutionAttribute - Interface in org.apache.lucene.queryParser.standard.config
Deprecated. 
DateResolutionAttributeImpl - Class in org.apache.lucene.queryParser.standard.config
Deprecated. 
DateResolutionAttributeImpl() - Constructor for class org.apache.lucene.queryParser.standard.config.DateResolutionAttributeImpl
Deprecated.
 
DateTools - Class in org.apache.lucene.document
Provides support for converting dates to strings and vice-versa.
DateTools.Resolution - Enum in org.apache.lucene.document
Specifies the time granularity.
dateToString(Date) - Static method in class org.apache.lucene.document.DateField
Deprecated.
Converts a Date to a string suitable for indexing.
dateToString(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
Converts a Date to a string suitable for indexing.
DBBI_AVAILABLE - Static variable in class org.apache.lucene.analysis.th.ThaiWordFilter
True if the JRE supports a working dictionary-based breakiterator for Thai.
debugStream - Variable in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserTokenManager
Debug output.
debugStream - Variable in class org.apache.lucene.queryParser.QueryParserTokenManager
Debug output.
debugStream - Variable in class org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserTokenManager
Debug output.
debugStream - Variable in class org.apache.lucene.queryParser.surround.parser.QueryParserTokenManager
Debug output.
Decl() - Method in class org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParser
 
DeclName - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
RegularExpression Id.
decode(BytesRef, ByteArrayDataInput) - Method in class org.apache.lucene.search.suggest.SortedTermFreqIteratorWrapper
 
decode(String) - Static method in class org.apache.lucene.spatial.geohash.GeoHashUtils
Deprecated.
Decodes the given geohash into a latitude and longitude
decode() - Method in class org.apache.lucene.util.encoding.DGapIntDecoder
 
decode() - Method in class org.apache.lucene.util.encoding.EightFlagsIntDecoder
 
decode() - Method in class org.apache.lucene.util.encoding.FourFlagsIntDecoder
 
decode() - Method in class org.apache.lucene.util.encoding.IntDecoder
Decodes data received from the input stream, and returns one decoded integer.
decode() - Method in class org.apache.lucene.util.encoding.NOnesIntDecoder
 
decode() - Method in class org.apache.lucene.util.encoding.SimpleIntDecoder
 
decode() - Method in class org.apache.lucene.util.encoding.VInt8IntDecoder
 
decode(CharBuffer, ByteBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.decode(char[], int, int, byte[], int, int) instead. This method will be removed in Lucene 4.0
decode(char[], int, int, byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Decodes the input char sequence into the output byte sequence.
decode(CharBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.decode(char[], int, int, byte[], int, int) instead. This method will be removed in Lucene 4.0
decode(byte[], Vint8.Position) - Static method in class org.apache.lucene.util.Vint8
Decodes a 32-bit integer from bytes, beginning at offset pos.pos.
decode(InputStream) - Static method in class org.apache.lucene.util.Vint8
Decodes a 32-bit integer from bytes read from in.
decodeFloat(byte[]) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
 
decodeFloat(byte[], int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
Decode the payload that was encoded using PayloadHelper.encodeFloat(float).
decodeInt(byte[], int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
 
decodeNorm(byte) - Static method in class org.apache.lucene.search.Similarity
Deprecated.
decodeNormValue(byte) - Method in class org.apache.lucene.search.Similarity
Decodes a normalization factor stored in an index.
decompose() - Method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
decompose() - Method in class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
 
decompose() - Method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
 
decompose(CharSequence) - Method in class org.egothor.stemmer.MultiTrie2
Break the given patch command into its constituent pieces.
decompress(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
Decompress the byte array previously returned by compress
decompressString(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
Decompress the byte array previously returned by compressString back into a String
decRef() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
Expert: decreases the refCount of this TaxonomyReader instance.
decRef() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyReader
Expert: decreases the refCount of this TaxonomyReader instance.
decRef() - Method in class org.apache.lucene.index.IndexReader
Expert: decreases the refCount of this IndexReader instance.
decRef(IndexSearcher) - Method in class org.apache.lucene.search.NRTManager
 
decRef(G) - Method in class org.apache.lucene.search.ReferenceManager
Decrement reference counting on the given reference.
decRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
 
deepCopyOf(BytesRef) - Static method in class org.apache.lucene.util.BytesRef
Creates a new BytesRef that points to a copy of the bytes from other The returned BytesRef will have a length of other.length and an offset of zero.
deepCopyOf(CharsRef) - Static method in class org.apache.lucene.util.CharsRef
Creates a new CharsRef that points to a copy of the chars from other The returned CharsRef will have a length of other.length and an offset of zero.
deepCopyOf(IntsRef) - Static method in class org.apache.lucene.util.IntsRef
Creates a new IntsRef that points to a copy of the ints from other The returned IntsRef will have a length of other.length and an offset of zero.
DEFALT_FIELD_PREFIX - Static variable in class org.apache.lucene.spatial.tier.projections.CartesianTierPlotter
Deprecated.
 
DEFAULT - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
 
DEFAULT - Static variable in interface org.apache.lucene.benchmark.byTask.feeds.demohtml.HTMLParserConstants
Lexical state.
DEFAULT - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
Lexical state.
DEFAULT - Static variable in interface org.apache.lucene.queryParser.standard.parser.StandardSyntaxParserConstants
Lexical state.
DEFAULT - Static variable in interface org.apache.lucene.queryParser.surround.parser.QueryParserConstants
Lexical state.
DEFAULT - Static variable in class org.apache.lucene.search.ChainedFilter
Logical operation when none is declared.
DEFAULT - Static variable in interface org.apache.lucene.search.FieldCache
Expert: The cache used internally by sorting and range query classes.
DEFAULT_ACCURACY - Static variable in class org.apache.lucene.search.spell.SpellChecker
The default minimum score to use, if not specified by calling SpellChecker.setAccuracy(float) .
DEFAULT_ANALYZER - Static variable in class org.apache.lucene.analysis.miscellaneous.PatternAnalyzer
A lower-casing word analyzer with English stop words (can be shared freely across threads without harm); global per class loader.
DEFAULT_ANALYZER - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Deprecated.
This default will be removed in Lucene 4.0 (with the default being null). If you are not using term vectors, explicitly set your analyzer instead.
DEFAULT_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.util.AttributeSource.AttributeFactory
This is the default factory that creates AttributeImpls using the class name of the supplied Attribute interface class by appending Impl to it.
DEFAULT_BOOST - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Boost terms in query based on score.
DEFAULT_BOUNDARY_CHARS - Static variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
 
DEFAULT_BUCKETS - Static variable in class org.apache.lucene.search.suggest.fst.FSTCompletion
Default number of buckets.
DEFAULT_BUCKETS - Static variable in class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
Default number of buckets.
DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
DEFAULT_BYTE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for byte values, which are encoded by Byte.toString(byte)
DEFAULT_CACHE_CLEAN_SIZE - Static variable in class org.apache.lucene.search.FilterManager
Deprecated.
The default maximum number of Filters in the cache
DEFAULT_CACHE_SIZE - Static variable in class org.apache.lucene.facet.search.TotalFacetCountsCache
Default size of in memory cache for computed total facet counts.
DEFAULT_CACHE_SLEEP_TIME - Static variable in class org.apache.lucene.search.FilterManager
Deprecated.
The default frequency of cache cleanup
DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
 
DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.search.spell.SuggestWordQueue
 
DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.search.suggest.fst.Sort
 
DEFAULT_COMPLEMENT_THRESHOLD - Static variable in class org.apache.lucene.facet.search.FacetsAccumulator
Default threshold for using the complements optimization.
DEFAULT_DELIMITER - Static variable in class org.apache.lucene.analysis.path.PathHierarchyTokenizer
 
DEFAULT_DELIMITER - Static variable in class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
 
DEFAULT_DELIMITER - Static variable in class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilter
 
DEFAULT_DEPTH - Static variable in class org.apache.lucene.facet.search.params.FacetRequest
Default depth for facets accumulation.
DEFAULT_DOC_DELETE_STEP - Static variable in class org.apache.lucene.benchmark.byTask.tasks.DeleteDocTask
Gap between ids of deleted docs, applies when no docid param is provided.
DEFAULT_DOUBLE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for double values, which are encoded by Double.toString(double)
DEFAULT_EPSILON - Static variable in class org.apache.lucene.index.pruning.CarmelTopKTermPruningPolicy
Default largest meaningless score difference
DEFAULT_EXTENSION_FIELD_DELIMITER - Static variable in class org.apache.lucene.queryParser.ext.Extensions
The default extension field delimiter character.
DEFAULT_FACET_DELIM_CHAR - Static variable in class org.apache.lucene.facet.index.params.DefaultFacetIndexingParams
delimiter between a categories in a path, e.g.
DEFAULT_FIELD_MATCH - Static variable in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
 
DEFAULT_FIELD_NAMES - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Default field names.
DEFAULT_FIELDS - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
Fields to be written by default
DEFAULT_FLOAT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for float values, which are encoded by Float.toString(float)
DEFAULT_INT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for int values, which are encoded by Integer.toString(int)
DEFAULT_LOG_STEP - Static variable in class org.apache.lucene.benchmark.Constants
 
DEFAULT_LONG_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for long values, which are encoded by Long.toString(long)
DEFAULT_MAX_BUFF - Static variable in class org.apache.lucene.store.MMapDirectory
 
DEFAULT_MAX_BUFFERED - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
 
DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriter
DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriter
DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_CHARS_TO_ANALYZE - Static variable in class org.apache.lucene.search.highlight.Highlighter
 
DEFAULT_MAX_DOC_FREQ - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Ignore words which occur in more than this many docs.
DEFAULT_MAX_FIELD_LENGTH - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
 
DEFAULT_MAX_FIELD_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
Deprecated.
DEFAULT_MAX_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
 
DEFAULT_MAX_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
 
DEFAULT_MAX_MERGE_DOCS - Static variable in class org.apache.lucene.index.LogMergePolicy
Default maximum segment size.
DEFAULT_MAX_MERGE_MB - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
Default maximum segment size.
DEFAULT_MAX_MERGE_MB_FOR_FORCED_MERGE - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
Default maximum segment size.
DEFAULT_MAX_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenFilter
 
DEFAULT_MAX_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenizer
 
DEFAULT_MAX_NUM_TOKENS_PARSED - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Default maximum number of tokens to parse in each example doc field that is not stored with TermVector support.
DEFAULT_MAX_QUERY_TERMS - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Return a Query with no more than this many terms.
DEFAULT_MAX_SAMPLE_SIZE - Static variable in class org.apache.lucene.facet.search.sampling.SamplingParams
Default maximum size of sample.
DEFAULT_MAX_SCAN - Static variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
 
DEFAULT_MAX_SHINGLE_SIZE - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
default maximum shingle size is 2.
DEFAULT_MAX_SUBWORD_SIZE - Static variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
The default for maximal length of subwords that get propagated to the output of this filter
DEFAULT_MAX_THREAD_STATES - Static variable in class org.apache.lucene.index.IndexWriterConfig
The maximum number of simultaneous threads that may be indexing documents at once in IndexWriter; if more than this many threads arrive they will wait for others to finish.
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.MockTokenizer
 
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.standard.ClassicAnalyzer
Default maximum allowed token length
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.standard.StandardAnalyzer
Default maximum allowed token length
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
Default maximum allowed token length
DEFAULT_MAX_WORD_LENGTH - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Ignore words greater than this length or if 0 then this has no effect.
DEFAULT_MAXIMUM_DOCUMENTS - Static variable in class org.apache.lucene.benchmark.Constants
 
DEFAULT_MERGE_FACTOR - Static variable in class org.apache.lucene.index.LogMergePolicy
Default merge factor, which is how many segments are merged at a time
DEFAULT_MERGE_PFACTOR - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
 
DEFAULT_MIN_DOC_FREQ - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Ignore words which do not occur in at least this many docs.
DEFAULT_MIN_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
 
DEFAULT_MIN_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
 
DEFAULT_MIN_LENGTH - Static variable in class org.apache.lucene.analysis.stempel.StempelFilter
Minimum length of input words to be processed.
DEFAULT_MIN_MERGE_DOCS - Static variable in class org.apache.lucene.index.LogDocMergePolicy
Default minimum segment size.
DEFAULT_MIN_MERGE_MB - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
Default minimum segment size.
DEFAULT_MIN_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenFilter
 
DEFAULT_MIN_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenizer
 
DEFAULT_MIN_SAMPLE_SIZE - Static variable in class org.apache.lucene.facet.search.sampling.SamplingParams
Default minimum size of sample.
DEFAULT_MIN_SHINGLE_SIZE - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
default minimum shingle size is 2.
DEFAULT_MIN_SUBWORD_SIZE - Static variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
The default for minimal length of subwords that get propagated to the output of this filter
DEFAULT_MIN_TERM_FREQ - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Ignore terms with less than this frequency in the source doc.
DEFAULT_MIN_WORD_LENGTH - Static variable in class org.apache.lucene.search.similar.MoreLikeThis
Ignore words less than this length or if 0 then this has no effect.
DEFAULT_MIN_WORD_SIZE - Static variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
The default for minimal word length that gets decomposed
DEFAULT_MIN_WRITTEN_BYTES - Static variable in class org.apache.lucene.util.ThrottledIndexOutput
 
DEFAULT_MINIMAL_SUBPATH_LENGTH - Variable in class org.apache.lucene.facet.index.categorypolicy.NonTopLevelPathPolicy
The shortest path length delivered is two components (root + one child).