- abort() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-  
- abort() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- abort() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
-  
- abort() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- abort() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
- 
Aborts writing entirely, implementation should remove
  any partially-written files, etc. 
- abort() - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Aborts writing entirely, implementation should remove
  any partially-written files, etc. 
- accept(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
Return if term is accepted, not accepted or the iteration should ended
 (and possibly seek). 
- accept(BytesRef) - Method in class org.apache.lucene.index.SingleTermsEnum
-  
- accept(BytesRef) - Method in class org.apache.lucene.search.PrefixTermsEnum
-  
- accept(BytesRef) - Method in class org.apache.lucene.search.TermRangeTermsEnum
-  
- acceptDocs - Variable in class org.apache.lucene.search.FieldCacheDocIdSet
-  
- 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
-  
- acceptResult(IntsRef, T) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-  
- acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CachingCollector
-  
- 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.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
-  
- acosh(double) - Static method in class org.apache.lucene.util.MathUtil
- 
Calculates inverse hyperbolic cosine of a doublevalue.
 
- 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 
- add(IndexableField) - Method in class org.apache.lucene.document.Document
- 
Adds a field to a document. 
- add(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
- 
- add(SegmentCommitInfo) - Method in class org.apache.lucene.index.SegmentInfos
- 
- 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<Query>
 
- add(String, T) - Method in class org.apache.lucene.search.LiveFieldValues
- 
Call this after you've successfully added a document
  to the index, to record what value you just set the
  field to. 
- 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 class org.apache.lucene.util.BytesRefHash
- 
- add(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefHash
- 
Adds a new  BytesRef with a pre-calculated hash code. 
- 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(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-  
- 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(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
-  
- add(long) - Method in class org.apache.lucene.util.packed.PackedInts.Writer
- 
Add a value to the stream. 
- add(int) - Method in class org.apache.lucene.util.PForDeltaDocIdSet.Builder
- 
Add a document to this builder. 
- add(DocIdSetIterator) - Method in class org.apache.lucene.util.PForDeltaDocIdSet.Builder
- 
- add(T) - Method in class org.apache.lucene.util.PriorityQueue
- 
Adds an Object to a PriorityQueue in log(size) time. 
- add(int) - Method in class org.apache.lucene.util.WAH8DocIdSet.Builder
- 
Add a document to this builder. 
- add(DocIdSetIterator) - Method in class org.apache.lucene.util.WAH8DocIdSet.Builder
- 
- addAll(Iterable<SegmentCommitInfo>) - Method in class org.apache.lucene.index.SegmentInfos
- 
- addAllDocVectors(Fields, MergeState) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Safe (but, slowish) default method to write every
  vector field in the document. 
- 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<T>) - Method in class org.apache.lucene.util.AttributeSource
- 
The caller must pass in a Class<? extends Attribute> value. 
- addAttributeImpl(AttributeImpl) - Method in class org.apache.lucene.util.AttributeSource
- 
Expert: Adds a custom AttributeImpl instance with one or more Attribute interfaces. 
- addBinaryField(FieldInfo, Iterable<BytesRef>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Writes binary docvalues for a field. 
- addBinaryField(FieldInfo, Iterable<BytesRef>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
-  
- addBuffer(int) - Method in class org.apache.lucene.store.RAMFile
-  
- addByPoolOffset(int) - Method in class org.apache.lucene.util.BytesRefHash
- 
Adds a "arbitrary" int offset instead of a BytesRef
  term. 
- addClause(BooleanQuery, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-  
- addClause(BooleanQuery, Term, int, float, TermContext) - 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 
- addDetail(Explanation) - Method in class org.apache.lucene.search.Explanation
- 
Adds a sub-node to this explanation node. 
- addDocument(Iterable<? extends IndexableField>, FieldInfos) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
- 
sugar method for startDocument() + writeField() for every stored field in the document 
- addDocument(Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.IndexWriter
- 
Adds a document to this index. 
- addDocument(Iterable<? extends IndexableField>, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
- 
- addDocument(Iterable<? extends IndexableField>, Analyzer) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- addDocument(Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- addDocuments(Iterable<? extends Iterable<? extends IndexableField>>) - 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(Iterable<? extends Iterable<? extends IndexableField>>, 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(Iterable<? extends Iterable<? extends IndexableField>>, Analyzer) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- addDocuments(Iterable<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- addEpsilons(Automaton, Collection<StatePair>) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Adds epsilon transitions to the given automaton. 
- addField(FieldInfo) - Method in class org.apache.lucene.codecs.BlockTreeTermsWriter
-  
- addField(FieldInfo) - Method in class org.apache.lucene.codecs.FieldsConsumer
- 
Add a new field 
- addFile(String) - Method in class org.apache.lucene.index.SegmentInfo
- 
Add this file to the set of files written for this
  segment. 
- addFiles(Collection<String>) - Method in class org.apache.lucene.index.SegmentInfo
- 
Add these files to the set of files written for this
  segment. 
- addIfCompetitive(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-  
- 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.TrackingIndexWriter
- 
- addIndexes(IndexReader...) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- addListener(ReferenceManager.RefreshListener) - Method in class org.apache.lucene.search.ReferenceManager
- 
Adds a listener, to be notified when a reference is refreshed/swapped. 
- addNumericField(FieldInfo, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Writes numeric docvalues for a field. 
- addNumericField(FieldInfo, Iterable<Number>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
-  
- addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
- 
Add a new position & payload 
- addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.PostingsConsumer
- 
Add a new position & payload, and start/end offset. 
- addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Adds a term position and offsets 
- addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Called by IndexWriter when writing new segments. 
- addRange(BytesRef, BytesRef) - 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(BytesRef, BytesRef) - 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. 
- addRawDocuments(IndexInput, int[], int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
- 
Bulk write a contiguous series of documents. 
- addReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
- 
- addressesOffset - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
- 
offset to the addressing data that maps a value to its slice of the byte[] 
- addressInterval - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
- 
interval of shared prefix chunks (when using prefix-compressed binary) 
- addSortedField(FieldInfo, Iterable<BytesRef>, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Writes pre-sorted binary docvalues for a field. 
- addSortedField(FieldInfo, Iterable<BytesRef>, Iterable<Number>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
-  
- addSortedSetField(FieldInfo, Iterable<BytesRef>, Iterable<Number>, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Writes pre-sorted set docvalues for a field 
- addSortedSetField(FieldInfo, Iterable<BytesRef>, Iterable<Number>, Iterable<Number>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
-  
- addStartPaths(FST.Arc<T>, T, boolean, IntsRef) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
- 
Adds all leaving arcs, including 'finished' arc, if
  the node is final, from this node into the queue. 
- addTermsDict(FieldInfo, Iterable<BytesRef>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
expert: writes a value dictionary for a sorted/sortedset field 
- addTransition(Transition) - Method in class org.apache.lucene.util.automaton.State
- 
Adds an outgoing transition. 
- advance(int) - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- advance(int) - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
-  
- advance(int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- advance(int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
-  
- advance(int) - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- advance(int) - Method in class org.apache.lucene.index.MultiDocsEnum
-  
- 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 the current whose document number is greater 
 than or equal to target, and returns the document number itself. 
- 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.FixedBitSet.FixedBitSetIterator
-  
- advance(int) - Method in class org.apache.lucene.util.OpenBitSetIterator
-  
- advanceToIndex(long) - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
Advance the decoding index to a given index. 
- advanceToValue(long) - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
Given a target value, advance the decoding index to the first bigger or equal value
 and return it if it is available. 
- afterClose() - Method in class org.apache.lucene.search.ReferenceManager
- 
Called after close(), so subclass can free any resources. 
- AfterEffect - Class in org.apache.lucene.search.similarities
- 
This class acts as the base class for the implementations of the first
 normalization of the informative content in the DFR framework. 
- AfterEffect() - Constructor for class org.apache.lucene.search.similarities.AfterEffect
- 
Sole constructor. 
- afterEffect - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
- 
The first normalization of the information content. 
- AfterEffect.NoAfterEffect - Class in org.apache.lucene.search.similarities
- 
Implementation used when there is no aftereffect. 
- AfterEffect.NoAfterEffect() - Constructor for class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
- 
Sole constructor: parameter-free 
- AfterEffectB - Class in org.apache.lucene.search.similarities
- 
Model of the information gain based on the ratio of two Bernoulli processes. 
- AfterEffectB() - Constructor for class org.apache.lucene.search.similarities.AfterEffectB
- 
Sole constructor: parameter-free 
- AfterEffectL - Class in org.apache.lucene.search.similarities
- 
Model of the information gain based on Laplace's law of succession. 
- AfterEffectL() - Constructor for class org.apache.lucene.search.similarities.AfterEffectL
- 
Sole constructor: parameter-free 
- afterMaybeRefresh() - Method in class org.apache.lucene.search.ReferenceManager
- 
Called after a refresh was attempted, regardless of
  whether a new reference was in fact created. 
- afterRefresh(boolean) - Method in class org.apache.lucene.search.LiveFieldValues
-  
- afterRefresh(boolean) - Method in interface org.apache.lucene.search.ReferenceManager.RefreshListener
- 
Called after the attempted refresh; if the refresh
 did open a new reference then didRefresh will be true
 and  ReferenceManager.acquire() is guaranteed to return the new
 reference. 
- alignObjectSize(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
- ALL - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables all optional regexp syntax. 
- allocSlice(byte[], int) - Method in class org.apache.lucene.util.ByteBlockPool
- 
Creates a new byte slice with the given starting size and 
 returns the slices offset in the pool. 
- 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
-  
- Analyzer - Class in org.apache.lucene.analysis
- 
An Analyzer builds TokenStreams, which analyze text. 
- Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
- 
- Analyzer(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.Analyzer
- 
- Analyzer.GlobalReuseStrategy - Class in org.apache.lucene.analysis
- 
- Analyzer.GlobalReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.GlobalReuseStrategy
- 
- Analyzer.PerFieldReuseStrategy - Class in org.apache.lucene.analysis
- 
- Analyzer.PerFieldReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.PerFieldReuseStrategy
- 
- Analyzer.ReuseStrategy - Class in org.apache.lucene.analysis
- 
- Analyzer.ReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.ReuseStrategy
- 
Sole constructor. 
- Analyzer.TokenStreamComponents - Class in org.apache.lucene.analysis
- 
This class encapsulates the outer components of a token stream. 
- Analyzer.TokenStreamComponents(Tokenizer, TokenStream) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
- 
- Analyzer.TokenStreamComponents(Tokenizer) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
- 
- AnalyzerWrapper - Class in org.apache.lucene.analysis
- 
Extension to  Analyzer suitable for Analyzers which wrap
 other Analyzers. 
- AnalyzerWrapper() - Constructor for class org.apache.lucene.analysis.AnalyzerWrapper
- 
- AnalyzerWrapper(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.AnalyzerWrapper
- 
Creates a new AnalyzerWrapper with the given reuse strategy. 
- 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(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
- 
this = this AND other 
- and(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
-  
- 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(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
- 
this = this AND NOT other 
- andNot(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
-  
- andNotCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
- 
Returns the popcount or cardinality of "a and not b" or
 "intersection(a, not(b))". 
- 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))". 
- ANYSTRING - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables anystring (@). 
- 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 Stringto this character sequence.
 
- append(StringBuilder) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- 
Appends the specified StringBuilderto this character sequence.
 
- append(CharTermAttribute) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- 
Appends the contents of the other CharTermAttributeto 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(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
- 
Appends the bytes in the provided  BytesRef at
 the current position. 
- append(BytesRef) - Method in class org.apache.lucene.util.BytesRef
- 
Appends the bytes from the given  BytesRef
- append(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
- 
Appends the given array to this CharsRef 
- AppendingDeltaPackedLongBuffer - Class in org.apache.lucene.util.packed
- 
Utility class to buffer a list of signed longs in memory. 
- AppendingDeltaPackedLongBuffer(int, int, float) - Constructor for class org.apache.lucene.util.packed.AppendingDeltaPackedLongBuffer
- 
- AppendingDeltaPackedLongBuffer() - Constructor for class org.apache.lucene.util.packed.AppendingDeltaPackedLongBuffer
- 
- AppendingDeltaPackedLongBuffer(float) - Constructor for class org.apache.lucene.util.packed.AppendingDeltaPackedLongBuffer
- 
- AppendingPackedLongBuffer - Class in org.apache.lucene.util.packed
- 
Utility class to buffer a list of signed longs in memory. 
- AppendingPackedLongBuffer(int, int, float) - Constructor for class org.apache.lucene.util.packed.AppendingPackedLongBuffer
- 
- AppendingPackedLongBuffer() - Constructor for class org.apache.lucene.util.packed.AppendingPackedLongBuffer
- 
- AppendingPackedLongBuffer(float) - Constructor for class org.apache.lucene.util.packed.AppendingPackedLongBuffer
- 
- arc - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-  
- arcCount - Variable in class org.apache.lucene.util.fst.FST
-  
- arcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- arcWithOutputCount - Variable in class org.apache.lucene.util.fst.FST
-  
- ArrayUtil - Class in org.apache.lucene.util
- 
Methods for manipulating arrays. 
- asin(double) - Static method in class org.apache.lucene.util.SloppyMath
- 
Returns the arc sine of a value. 
- asinh(double) - Static method in class org.apache.lucene.util.MathUtil
- 
Calculates inverse hyperbolic sine of a doublevalue.
 
- asList() - Method in class org.apache.lucene.index.SegmentInfos
- 
Returns all contained segments as an  unmodifiableList view. 
- atanh(double) - Static method in class org.apache.lucene.util.MathUtil
- 
Calculates inverse hyperbolic tangent of a doublevalue.
 
- AtomicReader - Class in org.apache.lucene.index
- 
AtomicReaderis an abstract class, providing an interface for accessing an
 index.
 
- AtomicReader() - Constructor for class org.apache.lucene.index.AtomicReader
- 
Sole constructor. 
- AtomicReaderContext - Class in org.apache.lucene.index
- 
- Attribute - Interface in org.apache.lucene.util
- 
Base interface for attributes. 
- AttributeImpl - Class in org.apache.lucene.util
- 
- AttributeImpl() - Constructor for class org.apache.lucene.util.AttributeImpl
-  
- AttributeReflector - Interface in org.apache.lucene.util
- 
- attributes() - Method in class org.apache.lucene.index.DocsEnum
- 
Returns the related attributes. 
- attributes() - Method in class org.apache.lucene.index.FieldInfo
- 
Returns internal codec attributes map. 
- attributes() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- attributes() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
-  
- attributes() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- attributes() - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
Returns the related attributes, the returned  AttributeSource
 is shared with the delegate  TermsEnum. 
- attributes() - Method in class org.apache.lucene.index.SegmentInfo
- 
Deprecated.
no longer supported 
 
- attributes() - Method in class org.apache.lucene.index.TermsEnum
- 
Returns the related attributes. 
- 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
- 
- 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
- 
- AttributeSource.AttributeFactory - Class in org.apache.lucene.util
- 
- 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
-  
- automata() - Method in interface org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttribute
-  
- automata() - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-  
- automaton - Variable in class org.apache.lucene.search.AutomatonQuery
- 
the automaton to match index terms against 
- Automaton - Class in org.apache.lucene.util.automaton
- 
Finite-state automaton with regular expression operations. 
- Automaton(State) - Constructor for class org.apache.lucene.util.automaton.Automaton
- 
Constructs a new automaton that accepts the empty language. 
- Automaton() - Constructor for class org.apache.lucene.util.automaton.Automaton
-  
- AUTOMATON - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables named automata (<identifier>). 
- AutomatonProvider - Interface in org.apache.lucene.util.automaton
- 
- AutomatonQuery - Class in org.apache.lucene.search
- 
A  Query that will match terms against a finite-state machine. 
- AutomatonQuery(Term, Automaton) - Constructor for class org.apache.lucene.search.AutomatonQuery
- 
Create a new AutomatonQuery from an  Automaton. 
- availableCodecs() - Static method in class org.apache.lucene.codecs.Codec
- 
returns a list of all available codec names 
- availableDocValuesFormats() - Static method in class org.apache.lucene.codecs.DocValuesFormat
- 
returns a list of all available format names 
- availablePostingsFormats() - Static method in class org.apache.lucene.codecs.PostingsFormat
- 
returns a list of all available format names 
- availableServices() - Method in class org.apache.lucene.util.NamedSPILoader
-  
- 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
-  
- avgFieldLength - Variable in class org.apache.lucene.search.similarities.BasicStats
- 
The average field length. 
- avgFieldLength(CollectionStatistics) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
The default implementation computes the average as sumTotalTermFreq / maxDoc,
 or returns1if the index does not store sumTotalTermFreq (Lucene 3.x indexes
 or any field that omits frequency information).
 
- backToValue(long) - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
Given a target value, go back to the first smaller or equal value
 and return it if it is available. 
- base - Variable in class org.apache.lucene.index.UpgradeIndexMergePolicy
- 
- base - Variable in class org.apache.lucene.search.CachingCollector
-  
- BaseCompositeReader<R extends IndexReader> - Class in org.apache.lucene.index
- 
Base class for implementing  CompositeReaders based on an array
 of sub-readers. 
- BaseCompositeReader(R[]) - Constructor for class org.apache.lucene.index.BaseCompositeReader
- 
Constructs a BaseCompositeReaderon the given subReaders.
 
- BaseDirectory - Class in org.apache.lucene.store
- 
Base implementation for a concrete  Directory. 
- BaseDirectory() - Constructor for class org.apache.lucene.store.BaseDirectory
- 
Sole constructor. 
- baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
-  
- baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedMutable
-  
- BasicAutomata - Class in org.apache.lucene.util.automaton
- 
Construction of basic automata. 
- BasicModel - Class in org.apache.lucene.search.similarities
- 
This class acts as the base class for the specific basic model
 implementations in the DFR framework. 
- BasicModel() - Constructor for class org.apache.lucene.search.similarities.BasicModel
- 
Sole constructor. 
- basicModel - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
- 
The basic model for information content. 
- BasicModelBE - Class in org.apache.lucene.search.similarities
- 
Limiting form of the Bose-Einstein model. 
- BasicModelBE() - Constructor for class org.apache.lucene.search.similarities.BasicModelBE
- 
Sole constructor: parameter-free 
- BasicModelD - Class in org.apache.lucene.search.similarities
- 
Implements the approximation of the binomial model with the divergence
 for DFR. 
- BasicModelD() - Constructor for class org.apache.lucene.search.similarities.BasicModelD
- 
Sole constructor: parameter-free 
- BasicModelG - Class in org.apache.lucene.search.similarities
- 
Geometric as limiting form of the Bose-Einstein model. 
- BasicModelG() - Constructor for class org.apache.lucene.search.similarities.BasicModelG
- 
Sole constructor: parameter-free 
- BasicModelIF - Class in org.apache.lucene.search.similarities
- 
An approximation of the I(ne) model. 
- BasicModelIF() - Constructor for class org.apache.lucene.search.similarities.BasicModelIF
- 
Sole constructor: parameter-free 
- BasicModelIn - Class in org.apache.lucene.search.similarities
- 
The basic tf-idf model of randomness. 
- BasicModelIn() - Constructor for class org.apache.lucene.search.similarities.BasicModelIn
- 
Sole constructor: parameter-free 
- BasicModelIne - Class in org.apache.lucene.search.similarities
- 
Tf-idf model of randomness, based on a mixture of Poisson and inverse
 document frequency. 
- BasicModelIne() - Constructor for class org.apache.lucene.search.similarities.BasicModelIne
- 
Sole constructor: parameter-free 
- BasicModelP - Class in org.apache.lucene.search.similarities
- 
Implements the Poisson approximation for the binomial model for DFR. 
- BasicModelP() - Constructor for class org.apache.lucene.search.similarities.BasicModelP
- 
Sole constructor: parameter-free 
- BasicOperations - Class in org.apache.lucene.util.automaton
- 
Basic automata operations. 
- BasicStats - Class in org.apache.lucene.search.similarities
- 
Stores all statistics commonly used ranking methods. 
- BasicStats(String, float) - Constructor for class org.apache.lucene.search.similarities.BasicStats
- 
Constructor. 
- beforeRefresh() - Method in class org.apache.lucene.search.LiveFieldValues
-  
- beforeRefresh() - Method in interface org.apache.lucene.search.ReferenceManager.RefreshListener
- 
Called right before a refresh attempt starts. 
- BIG_TERM - Static variable in class org.apache.lucene.util.UnicodeUtil
- 
A binary term consisting of a number of 0xff bytes, likely to be bigger than other terms
  (e.g. 
- BINARY_FIXED_UNCOMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Uncompressed binary, written directly (fixed length). 
- BINARY_PREFIX_COMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Compressed binary with shared prefixes 
- BINARY_VARIABLE_UNCOMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Uncompressed binary, written directly (variable length). 
- BinaryDocValues - Class in org.apache.lucene.index
- 
A per-document byte[] 
- BinaryDocValues() - Constructor for class org.apache.lucene.index.BinaryDocValues
- 
Sole constructor. 
- BinaryDocValuesField - Class in org.apache.lucene.document
- 
Field that stores a per-document  BytesRef value. 
- BinaryDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.BinaryDocValuesField
- 
Create a new binary DocValues field. 
- binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-  
- binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.index.StoredFieldVisitor
- 
Process a binary field. 
- binaryValue() - Method in class org.apache.lucene.document.Field
-  
- binaryValue() - Method in interface org.apache.lucene.index.IndexableField
- 
Non-null if this field has a binary value 
- bitCount(byte) - Static method in class org.apache.lucene.util.BitUtil
- 
Return the number of bits sets in b. 
- bitList(byte) - Static method in class org.apache.lucene.util.BitUtil
- 
Return the list of bits which are set in b encoded as followed:
 (i >>> (4 * n)) & 0x0Fis the offset of the n-th set bit of
 the given byte plus one, or 0 if there are n or less bits set in the given
 byte.
 
- bits() - Method in class org.apache.lucene.search.DocIdSet
- 
Optionally provides a  Bits interface for random access
 to matching documents. 
- bits() - Method in class org.apache.lucene.search.FieldCacheDocIdSet
-  
- bits() - Method in class org.apache.lucene.search.FilteredDocIdSet
-  
- Bits - Interface in org.apache.lucene.util
- 
Interface for Bitset-like structures. 
- bits() - Method in class org.apache.lucene.util.DocIdBitSet
-  
- bits() - Method in class org.apache.lucene.util.FixedBitSet
-  
- bits - Variable in class org.apache.lucene.util.OpenBitSet
-  
- bits() - Method 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.LongBitSet
- 
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 
- BitsFilteredDocIdSet - Class in org.apache.lucene.search
- 
This implementation supplies a filtered DocIdSet, that excludes all
 docids which are not in a Bits instance. 
- BitsFilteredDocIdSet(DocIdSet, Bits) - Constructor for class org.apache.lucene.search.BitsFilteredDocIdSet
- 
Constructor. 
- bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
-  
- bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
-  
- bitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
- 
The number of bits per value. 
- 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. 
- BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
- 
Fixed packed block size, number of integers encoded in 
 a single packed block. 
- blockCountByPrefixLen - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Number of blocks at each prefix depth. 
- blockFilePointer - Variable in class org.apache.lucene.codecs.BlockTermState
- 
fp into the terms dict primary file (_X.tim) that holds this term 
- BlockPackedReader - Class in org.apache.lucene.util.packed
- 
- BlockPackedReader(IndexInput, int, int, long, boolean) - Constructor for class org.apache.lucene.util.packed.BlockPackedReader
- 
Sole constructor. 
- BlockPackedReaderIterator - Class in org.apache.lucene.util.packed
- 
- BlockPackedReaderIterator(DataInput, int, int, long) - Constructor for class org.apache.lucene.util.packed.BlockPackedReaderIterator
- 
Sole constructor. 
- BlockPackedWriter - Class in org.apache.lucene.util.packed
- 
A writer for large sequences of longs. 
- BlockPackedWriter(DataOutput, int) - Constructor for class org.apache.lucene.util.packed.BlockPackedWriter
- 
Sole constructor. 
- blockSize - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
- 
packed ints blocksize 
- blockSize - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.NumericEntry
- 
packed ints blocksize 
- blockSize - Variable in class org.apache.lucene.util.ByteBlockPool.Allocator
-  
- blockSize - Variable in class org.apache.lucene.util.IntBlockPool.Allocator
-  
- BlockTermState - Class in org.apache.lucene.codecs
- 
- BlockTermState() - Constructor for class org.apache.lucene.codecs.BlockTermState
- 
Sole constructor. 
- blockTreeStats - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
- 
Holds details of block allocations in the block
  tree terms dictionary (this is only set if the
   PostingsFormat for this segment uses block
  tree. 
- BlockTreeTermsReader - Class in org.apache.lucene.codecs
- 
A block-based terms index and dictionary that assigns
  terms to variable length blocks according to how they
  share prefixes. 
- BlockTreeTermsReader(Directory, FieldInfos, SegmentInfo, PostingsReaderBase, IOContext, String, int) - Constructor for class org.apache.lucene.codecs.BlockTreeTermsReader
- 
Sole constructor. 
- BlockTreeTermsReader.FieldReader - Class in org.apache.lucene.codecs
- 
BlockTree's implementation of  Terms. 
- BlockTreeTermsReader.Stats - Class in org.apache.lucene.codecs
- 
- BlockTreeTermsWriter - Class in org.apache.lucene.codecs
- 
Block-based terms index and dictionary writer. 
- BlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int) - Constructor for class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Create a new writer. 
- BM25Similarity - Class in org.apache.lucene.search.similarities
- 
BM25 Similarity. 
- BM25Similarity(float, float) - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
- 
BM25 with the supplied parameter values. 
- BM25Similarity() - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
- 
BM25 with these default values:
 
   k1 = 1.2,b = 0.75.
 
- 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. 
- 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(IndexSearcher, boolean) - Constructor for class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
- 
- BooleanQuery.TooManyClauses() - Constructor for exception org.apache.lucene.search.BooleanQuery.TooManyClauses
-  
- boost - Variable in class org.apache.lucene.document.Field
- 
Field's boost 
- boost() - Method in class org.apache.lucene.document.Field
- 
Returns the field's index-time boost. 
- boost() - Method in interface org.apache.lucene.index.IndexableField
- 
Returns the field's index-time boost. 
- 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.search
- 
- BoostAttributeImpl - Class in org.apache.lucene.search
- 
- BoostAttributeImpl() - Constructor for class org.apache.lucene.search.BoostAttributeImpl
-  
- BroadWord - Class in org.apache.lucene.util
- 
- BUF_SIZE_INT - Static variable in class org.apache.lucene.util.NumericUtils
- 
The maximum term length (used for byte[]buffer size)
 for encodingintvalues.
 
- BUF_SIZE_LONG - Static variable in class org.apache.lucene.util.NumericUtils
- 
The maximum term length (used for byte[]buffer size)
 for encodinglongvalues.
 
- 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.store.BufferedIndexInput
-  
- buffer - Variable in class org.apache.lucene.util.ByteBlockPool
- 
Current head buffer 
- buffer - Variable in class org.apache.lucene.util.IntBlockPool
- 
Current head buffer 
- BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
- 
Default buffer size set to 1024. 
- BufferedIndexInput - Class in org.apache.lucene.store
- 
Base implementation class for buffered  IndexInput. 
- BufferedIndexInput(String) - Constructor for class org.apache.lucene.store.BufferedIndexInput
-  
- BufferedIndexInput(String, IOContext) - Constructor for class org.apache.lucene.store.BufferedIndexInput
-  
- BufferedIndexInput(String, int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
- 
Inits BufferedIndexInput with a specific bufferSize 
- BufferedIndexOutput - Class in org.apache.lucene.store
- 
- BufferedIndexOutput() - Constructor for class org.apache.lucene.store.BufferedIndexOutput
- 
- BufferedIndexOutput(int) - Constructor for class org.apache.lucene.store.BufferedIndexOutput
- 
- buffers - Variable in class org.apache.lucene.store.RAMFile
-  
- buffers - Variable in class org.apache.lucene.util.ByteBlockPool
- 
array of buffers currently used in the pool. 
- buffers - Variable in class org.apache.lucene.util.IntBlockPool
- 
array of buffers currently used in the pool. 
- bufferSize(IOContext) - Static method in class org.apache.lucene.store.BufferedIndexInput
- 
Returns default buffer sizes for the given  IOContext
- bufferSkip(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
- 
Writes the current skip data to the buffers. 
- build(AtomicReader) - Static method in class org.apache.lucene.index.MergeState.DocMap
- 
- build(IndexReaderContext, Term) - Static method in class org.apache.lucene.index.TermContext
- 
- build() - Method in class org.apache.lucene.util.PForDeltaDocIdSet.Builder
- 
- build() - Method in class org.apache.lucene.util.WAH8DocIdSet.Builder
-  
- 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, float, boolean, int) - 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
-  
- byId(int) - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
- 
Get a format according to its ID. 
- 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
-  
- byteBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
The minimum number of byte blocks to encode in a single iteration, when
 using byte encoding. 
- byteBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
The minimum number of byte blocks to encode in a single iteration, when
 using byte encoding. 
- 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
- 
- 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
- 
- ByteBlockPool.DirectTrackingAllocator(Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-  
- ByteBlockPool.DirectTrackingAllocator(int, Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-  
- byteCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
- 
Computes how many byte blocks are needed to store valuesvalues of sizebitsPerValue.
 
- ByteDocValuesField - Class in org.apache.lucene.document
- 
- ByteDocValuesField(String, byte) - Constructor for class org.apache.lucene.document.ByteDocValuesField
- 
Deprecated. Creates a new DocValues field with the specified 8-bit byte value 
- byteOffset - Variable in class org.apache.lucene.util.ByteBlockPool
- 
Current head offset 
- ByteRunAutomaton - Class in org.apache.lucene.util.automaton
- 
Automaton representation for matching UTF-8 byte[]. 
- ByteRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
-  
- ByteRunAutomaton(Automaton, boolean) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
- 
expert: if utf8 is true, the input is already byte-based 
- bytes() - Method in class org.apache.lucene.index.Term
- 
Returns the bytes of this term. 
- bytes - Variable in class org.apache.lucene.util.BytesRef
- 
The contents of the BytesRef. 
- bytes - Variable in class org.apache.lucene.util.GrowableByteArrayDataOutput
- 
The bytes 
- bytesDifference(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
- 
Compares two  BytesRef, 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. 
- 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
- 
- 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() - Constructor for class org.apache.lucene.util.BytesRefHash
- 
- BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
- 
- BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.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
- 
- BytesRefHash.DirectBytesStartArray(int, Counter) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-  
- BytesRefHash.DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-  
- BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
- 
- BytesRefIterator - Interface in org.apache.lucene.util
- 
A simple iterator interface for  BytesRef iteration. 
- byteStart(int) - Method in class org.apache.lucene.util.BytesRefHash
- 
Returns the bytesStart offset into the internally used
  ByteBlockPool for the given bytesID 
- bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
- 
- bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-  
- bytesUsed() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-  
- bytesUsed() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-  
- 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
- 
Where we are in head buffer 
- byteValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
- byteValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
- cachedDocs - Variable in class org.apache.lucene.search.CachingCollector
-  
- cachedSegs - Variable in class org.apache.lucene.search.CachingCollector
-  
- cacheImpl(DocIdSetIterator, AtomicReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
- 
- 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. 
- 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
- 
Create a new CachingTokenFilter around  input,
 caching its token attributes, which can be replayed again
 after a call to  CachingTokenFilter.reset(). 
- 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
- 
Wraps another filter's result and caches it. 
- calibrateSizeByDeletes - Variable in class org.apache.lucene.index.LogMergePolicy
- 
If true, we pro-rate a segment's size by the
  percentage of non-deleted documents. 
- canReuse(MultiTermsEnum) - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
- 
Returns  true if this instance can be reused by
  the provided  MultiTermsEnum. 
- canReuse(MultiTermsEnum) - Method in class org.apache.lucene.index.MultiDocsEnum
- 
Returns  true if this instance can be reused by
  the provided  MultiTermsEnum. 
- 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.util.OpenBitSet
- 
Returns the current capacity in bits (1 greater than the index of the last bit) 
- captureState() - Method in class org.apache.lucene.util.AttributeSource
- 
Captures the state of all Attributes. 
- cardinality() - Method in class org.apache.lucene.util.FixedBitSet
- 
Returns number of set bits. 
- cardinality() - Method in class org.apache.lucene.util.LongBitSet
- 
Returns number of set bits. 
- cardinality() - Method in class org.apache.lucene.util.OpenBitSet
-  
- cardinality() - Method in class org.apache.lucene.util.PForDeltaDocIdSet
- 
Return the number of documents in this  DocIdSet in constant time. 
- cardinality() - Method in class org.apache.lucene.util.WAH8DocIdSet
- 
Return the number of documents in this  DocIdSet in constant time. 
- changed() - Method in class org.apache.lucene.index.SegmentInfos
- 
Call this before committing if changes have been made to the
  segments. 
- changeToken(BytesRef) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
- 
Subclass & implement this if you need to change the
  token (such as escaping certain bytes) before it's
  turned into a graph. 
- CharacterRunAutomaton - Class in org.apache.lucene.util.automaton
- 
Automaton representation for matching char[]. 
- CharacterRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CharacterRunAutomaton
-  
- charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- 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 a Reader
 They can be used as  Reader with additional offset
 correction. 
- CharFilter(Reader) - Constructor for class org.apache.lucene.analysis.CharFilter
- 
Create a new CharFilter wrapping the provided reader. 
- chars - Variable in class org.apache.lucene.util.CharsRef
- 
The contents of the CharsRef. 
- charsEquals(CharsRef) - Method in class org.apache.lucene.util.CharsRef
-  
- CharSequenceOutputs - Class in org.apache.lucene.util.fst
- 
An FST  Outputs implementation where each output
 is a sequence of characters. 
- CHARSET_UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
- 
- 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 
- CharTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
- 
The term text of a Token. 
- CharTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
- 
- CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- 
Initialize this attribute with empty term text 
- check(FieldCache.CacheEntry...) - Method in class org.apache.lucene.util.FieldCacheSanityChecker
- 
Tests a CacheEntry[] for indication of "insane" cache usage. 
- checkAbort - Variable in class org.apache.lucene.index.MergeState
- 
Holds the CheckAbort instance, which is invoked
  periodically to see if the merge has been aborted. 
- checkAborted(Directory) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Called periodically by  IndexWriter while
  merging to see if the merge is aborted. 
- checkHeader(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
- 
- checkHeaderNoMagic(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
- 
- 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
- 
- checkIndex(List<String>) - Method in class org.apache.lucene.index.CheckIndex
- 
- CheckIndex.Status - Class in org.apache.lucene.index
- 
- CheckIndex.Status.DocValuesStatus - Class in org.apache.lucene.index
- 
Status from testing DocValues 
- CheckIndex.Status.FieldNormStatus - Class in org.apache.lucene.index
- 
Status from testing field norms. 
- CheckIndex.Status.SegmentInfoStatus - Class in org.apache.lucene.index
- 
Holds the status of each segment in the index. 
- CheckIndex.Status.StoredFieldStatus - Class in org.apache.lucene.index
- 
Status from testing stored fields. 
- CheckIndex.Status.TermIndexStatus - Class in org.apache.lucene.index
- 
Status from testing term index. 
- CheckIndex.Status.TermVectorStatus - Class in org.apache.lucene.index
- 
Status from testing stored fields. 
- checkMaxClauseCount(int) - Method in class org.apache.lucene.search.ScoringRewrite
- 
This method is called after every new term to check if the number of max clauses
 (e.g. 
- 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 
- checkServiceName(String) - Static method in class org.apache.lucene.util.NamedSPILoader
- 
- ChecksumIndexInput - Class in org.apache.lucene.store
- 
Reads bytes through to a primary IndexInput, 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
-  
- checkVersion(int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Check the validity of a version number. 
- child - Variable in class org.apache.lucene.search.Scorer.ChildScorer
- 
Child Scorer. 
- children() - Method in class org.apache.lucene.index.AtomicReaderContext
-  
- children() - Method in class org.apache.lucene.index.CompositeReaderContext
-  
- children() - Method in class org.apache.lucene.index.IndexReaderContext
- 
Returns the context's children iff this context is a composite context
 otherwise null.
 
- 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. 
- clear() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- 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.index.SegmentInfos
- 
- clear() - Method in class org.apache.lucene.index.TermContext
- 
- clear() - Method in class org.apache.lucene.search.BoostAttributeImpl
-  
- clear() - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-  
- clear() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-  
- clear() - Method in class org.apache.lucene.util.AttributeImpl
- 
Clears the values in this AttributeImpl and resets it to its 
 default value. 
- clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
- 
- clear(boolean) - Method in class org.apache.lucene.util.BytesRefHash
- 
- clear() - Method in class org.apache.lucene.util.BytesRefHash
-  
- clear() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-  
- 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(long) - Method in class org.apache.lucene.util.LongBitSet
-  
- clear(long, long) - Method in class org.apache.lucene.util.LongBitSet
- 
Clears a range of bits. 
- clear(int) - Method in interface org.apache.lucene.util.MutableBits
- 
Sets the bit specified by indexto false.
 
- 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 class 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.SentinelIntSet
-  
- clear() - Method in class org.apache.lucene.util.WeakIdentityMap
- 
Removes all of the mappings from this map. 
- clearAttributes() - Method in class org.apache.lucene.util.AttributeSource
- 
Resets all Attributes in this AttributeSource by calling
  AttributeImpl.clear() on each Attribute implementation. 
- clearLock(String) - Method in class org.apache.lucene.store.BaseDirectory
-  
- 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.FilterDirectory
-  
- 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.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
-  
- clearNumberedStates() - Method in class org.apache.lucene.util.automaton.Automaton
-  
- 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.codecs.compressing.CompressingStoredFieldsIndexReader
-  
- clone() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-  
- clone() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-  
- clone() - Method in class org.apache.lucene.codecs.compressing.Decompressor
-  
- clone() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
- 
Returns a cloned FieldsReader that shares open
  IndexInputs with the original one. 
- clone() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
-  
- clone() - Method in class org.apache.lucene.codecs.StoredFieldsReader
-  
- clone() - Method in class org.apache.lucene.codecs.TermVectorsReader
- 
Create a clone that one caller at a time may use to
  read term vectors. 
- clone() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-  
- clone() - Method in class org.apache.lucene.index.IndexDeletionPolicy
-  
- clone() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- clone() - Method in class org.apache.lucene.index.MergePolicy
-  
- clone() - Method in class org.apache.lucene.index.MergeScheduler
-  
- clone() - Method in class org.apache.lucene.index.NoDeletionPolicy
-  
- clone() - Method in class org.apache.lucene.index.NoMergeScheduler
-  
- clone() - Method in class org.apache.lucene.index.SegmentCommitInfo
-  
- 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.SnapshotDeletionPolicy
-  
- clone() - Method in class org.apache.lucene.index.TermState
-  
- 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.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.FSDirectory.FSIndexInput
-  
- clone() - Method in class org.apache.lucene.store.IndexInput
- 
Returns a clone of this stream. 
- 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.automaton.Automaton
- 
Returns a clone of this automaton. 
- clone() - Method in class org.apache.lucene.util.automaton.Transition
- 
Clones this transition. 
- clone() - Method in class org.apache.lucene.util.BytesRef
- 
Returns a shallow clone of this instance (the underlying bytes are
 not copied and will be shared by both the returned object and this
 object. 
- clone() - Method in class org.apache.lucene.util.CharsRef
- 
Returns a shallow clone of this instance (the underlying characters are
 not copied and will be shared by both the returned object and this
 object. 
- 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.InfoStream
-  
- clone() - Method in class org.apache.lucene.util.IntsRef
- 
Returns a shallow clone of this instance (the underlying ints are
 not copied and will be shared by both the returned object and this
 object. 
- clone() - Method in class org.apache.lucene.util.LongBitSet
-  
- clone() - Method in class org.apache.lucene.util.LongsRef
- 
Returns a shallow clone of this instance (the underlying longs are
 not copied and will be shared by both the returned object and this
 object. 
- clone() - Method in class org.apache.lucene.util.OpenBitSet
-  
- clone() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-  
- clone() - Method in class org.apache.lucene.util.SetOnce
-  
- cloneAttributes() - Method in class org.apache.lucene.util.AttributeSource
- 
Performs a clone of all  AttributeImpl instances returned in a new
  AttributeSource instance. 
- 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
- 
Closes the underlying input stream. 
- close() - Method in class org.apache.lucene.analysis.TokenFilter
- 
Releases resources associated with this stream. 
- close() - Method in class org.apache.lucene.analysis.Tokenizer
- 
Releases resources associated with this stream. 
- close() - Method in class org.apache.lucene.analysis.TokenStream
- 
Releases resources associated with this stream. 
- close() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
-  
- close() - Method in class org.apache.lucene.codecs.BlockTreeTermsWriter
-  
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexWriter
-  
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
- 
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-  
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-  
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- close() - Method in class org.apache.lucene.codecs.FieldsConsumer
- 
Called when we are done adding everything. 
- close() - Method in class org.apache.lucene.codecs.FieldsProducer
-  
- close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. 
- close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
- 
- close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
-  
- close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
-  
- close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
- 
Close all streams. 
- close() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
-  
- close() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- close() - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
-  
- close() - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
-  
- close() - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-  
- close() - Method in class org.apache.lucene.codecs.PostingsReaderBase
-  
- close() - Method in class org.apache.lucene.codecs.PostingsWriterBase
-  
- close() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
-  
- close() - Method in class org.apache.lucene.codecs.TermVectorsWriter
-  
- close() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-  
- 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, waits for pending merges
 to complete, 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.NoMergePolicy
-  
- close() - Method in class org.apache.lucene.index.NoMergeScheduler
-  
- close() - Method in class org.apache.lucene.index.SerialMergeScheduler
-  
- 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.ControlledRealTimeReopenThread
-  
- close() - Method in class org.apache.lucene.search.LiveFieldValues
-  
- close() - Method in class org.apache.lucene.search.ReferenceManager
- 
 Closes this ReferenceManager to prevent future  acquiring. 
- close() - Method in class org.apache.lucene.search.SearcherLifetimeManager
- 
- close() - Method in class org.apache.lucene.store.BufferedIndexOutput
-  
- 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.CompoundFileDirectory
-  
- 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.FilterDirectory
-  
- close() - Method in class org.apache.lucene.store.FSDirectory
- 
Closes the store to future operations. 
- close() - Method in class org.apache.lucene.store.FSDirectory.FSIndexInput
-  
- 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.Lock
- 
Releases exclusive access. 
- 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.util.BytesRefHash
- 
Closes the BytesRefHash and releases all internally used memory 
- close() - Method in class org.apache.lucene.util.CloseableThreadLocal
-  
- 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
- 
Closes all given Closeables. 
- close() - Method in class org.apache.lucene.util.PrintStreamInfoStream
-  
- 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
-  
- 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
- 
Closes all given Closeables, suppressing all thrown exceptions. 
- 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
- 
Closes all given Closeables, suppressing all thrown exceptions. 
- Codec - Class in org.apache.lucene.codecs
- 
Encodes/decodes an inverted index segment. 
- Codec(String) - Constructor for class org.apache.lucene.codecs.Codec
- 
Creates a new codec. 
- codec - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Codec used to read this segment. 
- codec - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Codec used to write new segments. 
- CODEC_FILE_PATTERN - Static variable in class org.apache.lucene.index.IndexFileNames
- 
All files created by codecs much match this pattern (checked in
 SegmentInfo). 
- CODEC_MAGIC - Static variable in class org.apache.lucene.codecs.CodecUtil
- 
Constant to identify the start of a codec header. 
- CODEC_NAME - Static variable in class org.apache.lucene.util.packed.PackedInts
-  
- CodecUtil - Class in org.apache.lucene.codecs
- 
Utility class for reading and writing versioned headers. 
- codePointCount(BytesRef) - Static method in class org.apache.lucene.util.UnicodeUtil
- 
Returns the number of code points in this UTF8 sequence. 
- 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.MultiCollector
-  
- collect(int) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
-  
- collect(int) - Method in class org.apache.lucene.search.TimeLimitingCollector
- 
- collect(int) - Method in class org.apache.lucene.search.TotalHitCountCollector
-  
- collectionModel - Variable in class org.apache.lucene.search.similarities.LMSimilarity
- 
The collection model. 
- CollectionStatistics - Class in org.apache.lucene.search
- 
Contains statistics for a collection (field) 
- CollectionStatistics(String, long, long, long, long) - Constructor for class org.apache.lucene.search.CollectionStatistics
-  
- collectionStatistics(String) - Method in class org.apache.lucene.search.IndexSearcher
- 
- CollectionTerminatedException - Exception in org.apache.lucene.search
- 
- CollectionTerminatedException() - Constructor for exception org.apache.lucene.search.CollectionTerminatedException
- 
Sole constructor. 
- 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
-  
- CommandLineUtil - Class in org.apache.lucene.util
- 
Class containing some useful methods used by command line tools 
- 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 - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- commit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
- 
The second phase of a 2-phase commit. 
- common(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-  
- common(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-  
- 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("foobar", "food") -> "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
-  
- commonSuffixRef - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
- 
Shared common suffix accepted by the automaton. 
- COMPACT - Static variable in class org.apache.lucene.util.packed.PackedInts
- 
No memory overhead at all, but the returned implementation may be slow. 
- comparators - Variable in class org.apache.lucene.search.FieldValueHitQueue
-  
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 
Deprecated. 
- 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
- 
Deprecated. 
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- compare(int, int) - Method in class org.apache.lucene.util.Sorter
- 
Compare entries found in slots iandj.
 
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 
Deprecated. 
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator
- 
Compare the bottom of the queue with this 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
- 
Deprecated. 
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- CompareByDestThenMinMax - Static variable in class org.apache.lucene.util.automaton.Transition
-  
- compareByMergeDocCount - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
- CompareByMinMaxThenDest - Static variable in class org.apache.lucene.util.automaton.Transition
-  
- 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.IntroSorter
- 
Compare the pivot with the slot at  j, similarly to
   compare(i, j). 
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueBool
-  
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-  
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-  
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueInt
-  
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueLong
-  
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueStr
-  
- compareSaved(int, int) - Method in class org.apache.lucene.util.TimSorter
- 
Compare element  i from the temporary storage with element
   j from the slice to sort, similarly to
   Sorter.compare(int, int). 
- 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(State) - Method in class org.apache.lucene.util.automaton.State
- 
Compares this object with the specified object for order. 
- 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(IntsRef) - Method in class org.apache.lucene.util.IntsRef
- 
Signed int order comparison 
- compareTo(LongsRef) - Method in class org.apache.lucene.util.LongsRef
- 
Signed int order comparison 
- compareTo(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 
Deprecated. 
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator
- 
Compare the top value with this doc. 
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- 
Deprecated. 
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- 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(BytesRef, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- compareValues(BytesRef, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- compiled - Variable in class org.apache.lucene.search.AutomatonQuery
-  
- CompiledAutomaton - Class in org.apache.lucene.util.automaton
- 
Immutable class holding compiled details for a given
 Automaton. 
- CompiledAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
-  
- CompiledAutomaton(Automaton, Boolean, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
-  
- CompiledAutomaton.AUTOMATON_TYPE - Enum in org.apache.lucene.util.automaton
- 
Automata are compiled into different internal forms for the
 most efficient execution depending upon the language they accept. 
- complement() - Method in class org.apache.lucene.util.automaton.Automaton
- 
- complement(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns a (deterministic) automaton that accepts the complement of the
 language of the given automaton. 
- COMPLEMENT - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables complement (~). 
- 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
-  
- CompositeReader - Class in org.apache.lucene.index
- 
Instances of this reader type can only
 be used to get stored fields from the underlying AtomicReaders,
 but it is not possible to directly retrieve postings. 
- CompositeReader() - Constructor for class org.apache.lucene.index.CompositeReader
- 
Sole constructor. 
- CompositeReaderContext - Class in org.apache.lucene.index
- 
- compound - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
True if segment is compound file format. 
- COMPOUND_FILE_ENTRIES_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
- 
Extension of compound file entries 
- COMPOUND_FILE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
- 
Extension of compound file 
- COMPOUND_FILES - Static variable in class org.apache.lucene.index.NoMergePolicy
- 
A singleton  NoMergePolicy which indicates the index uses compound
 files. 
- CompoundFileDirectory - Class in org.apache.lucene.store
- 
Class for accessing a compound stream. 
- CompoundFileDirectory(Directory, String, IOContext, boolean) - Constructor for class org.apache.lucene.store.CompoundFileDirectory
- 
Create a new CompoundFileDirectory. 
- CompoundFileDirectory.FileEntry - Class in org.apache.lucene.store
- 
Offset/Length for a slice inside of a compound file 
- CompoundFileDirectory.FileEntry() - Constructor for class org.apache.lucene.store.CompoundFileDirectory.FileEntry
-  
- compress(byte[], int, int, DataOutput) - Method in class org.apache.lucene.codecs.compressing.Compressor
- 
Compress bytes into out.
 
- 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 
- CompressingStoredFieldsFormat - Class in org.apache.lucene.codecs.compressing
- 
- CompressingStoredFieldsFormat(String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
- 
- CompressingStoredFieldsFormat(String, String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
- 
- CompressingStoredFieldsIndexReader - Class in org.apache.lucene.codecs.compressing
- 
- CompressingStoredFieldsIndexWriter - Class in org.apache.lucene.codecs.compressing
- 
Efficient index format for block-based  Codecs. 
- CompressingStoredFieldsReader - Class in org.apache.lucene.codecs.compressing
- 
- CompressingStoredFieldsReader(Directory, SegmentInfo, String, FieldInfos, IOContext, String, CompressionMode) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
- 
Sole constructor. 
- CompressingStoredFieldsWriter - Class in org.apache.lucene.codecs.compressing
- 
- CompressingStoredFieldsWriter(Directory, SegmentInfo, String, IOContext, String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
- 
Sole constructor. 
- CompressingTermVectorsFormat - Class in org.apache.lucene.codecs.compressing
- 
A  TermVectorsFormat that compresses chunks of documents together in
 order to improve the compression ratio. 
- CompressingTermVectorsFormat(String, String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
- 
- CompressingTermVectorsReader - Class in org.apache.lucene.codecs.compressing
- 
- CompressingTermVectorsReader(Directory, SegmentInfo, String, FieldInfos, IOContext, String, CompressionMode) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
- 
Sole constructor. 
- CompressingTermVectorsWriter - Class in org.apache.lucene.codecs.compressing
- 
- CompressingTermVectorsWriter(Directory, SegmentInfo, String, IOContext, String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
- 
Sole constructor. 
- CompressionMode - Class in org.apache.lucene.codecs.compressing
- 
A compression mode. 
- CompressionMode() - Constructor for class org.apache.lucene.codecs.compressing.CompressionMode
- 
Sole constructor. 
- CompressionTools - Class in org.apache.lucene.document
- 
Simple utility class providing static methods to
  compress and decompress binary data for stored fields. 
- Compressor - Class in org.apache.lucene.codecs.compressing
- 
A data compressor. 
- Compressor() - Constructor for class org.apache.lucene.codecs.compressing.Compressor
- 
Sole constructor, typically called from sub-classes. 
- 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). 
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-  
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
-  
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-  
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.Similarity
- 
Computes the normalization value for a field, given the accumulated
 state of term processing for this field (see  FieldInvertState). 
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-  
- computePayloadFactor(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
- 
Calculate a scoring factor based on the data in the payload. 
- computeProbability(BasicStats) - Method in interface org.apache.lucene.search.similarities.LMSimilarity.CollectionModel
- 
Computes the probability p(w|C)according to the language model
 strategy for the current term.
 
- computeProbability(BasicStats) - Method in class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
-  
- computeSlopFactor(int) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
- 
Computes the amount of a sloppy phrase match, based on an edit distance. 
- computeStats() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
- 
For debugging -- used by CheckIndex too 
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-  
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
-  
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-  
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.Similarity
- 
Compute any collection-level weight (e.g. 
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-  
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-  
- concatenate(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
- 
- concatenate(List<Automaton>) - Static method in class org.apache.lucene.util.automaton.Automaton
- 
- concatenate(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns an automaton that accepts the concatenation of the languages of the
 given automata. 
- concatenate(List<Automaton>) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns an automaton that accepts the concatenation of the languages of the
 given automata. 
- ConcurrentMergeScheduler - Class in org.apache.lucene.index
- 
- ConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Sole constructor, with all settings set to default
  values. 
- ConcurrentMergeScheduler.MergeThread - Class in org.apache.lucene.index
- 
Runs a merge thread, which may run one or more merges
  in sequence. 
- ConcurrentMergeScheduler.MergeThread(IndexWriter, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- 
Sole constructor. 
- 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
- 
- CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
- 
- 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.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(DocIdSetIterator, Weight, float) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- ConstantScoreQuery.ConstantWeight - Class in org.apache.lucene.search
-  
- ConstantScoreQuery.ConstantWeight(IndexSearcher) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
-  
- containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
- 
Returns trueif this map contains a mapping for the specified key.
 
- context - Variable in class org.apache.lucene.index.SegmentReadState
- 
- context - Variable in class org.apache.lucene.index.SegmentWriteState
- 
- context - Variable in class org.apache.lucene.store.IOContext
- 
An object of a enumerator Context type 
- ControlledRealTimeReopenThread<T> - Class in org.apache.lucene.search
- 
Utility class that runs a thread to manage periodicc
  reopens of a  ReferenceManager, with methods to wait for a specific
  index changes to become visible. 
- ControlledRealTimeReopenThread(TrackingIndexWriter, ReferenceManager<T>, double, double) - Constructor for class org.apache.lucene.search.ControlledRealTimeReopenThread
- 
Create ControlledRealTimeReopenThread, to periodically
 reopen the a  ReferenceManager. 
- convert(Automaton) - Method in class org.apache.lucene.util.automaton.UTF32ToUTF8
- 
Converts an incoming utf32 automaton to an equivalent
  utf8 one. 
- coord(int, int) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- coord(int, int) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Implemented as overlap / maxOverlap.
 
- coord(int, int) - Method in class org.apache.lucene.search.similarities.Similarity
- 
Hook to integrate coordinate-level matching. 
- coord(int, int) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Computes a score factor based on the fraction of all query terms that a
 document contains. 
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 
Deprecated. 
- 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
- 
Deprecated. 
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- copy(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.Directory
- 
Copies the file  src to  Directoryto under the new
 file name  dest. 
- copy(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
-  
- copy(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-  
- copy(File, File) - Static method in class org.apache.lucene.util.IOUtils
- 
Copy one file's contents to another file. 
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueBool
-  
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-  
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-  
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueInt
-  
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueLong
-  
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueStr
-  
- copy(PackedInts.Reader, int, PackedInts.Mutable, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Copy src[srcPos:srcPos+len]intodest[destPos:destPos+len]using at mostmembytes.
 
- copy(IndexInput, long) - Method in class org.apache.lucene.util.PagedBytes
- 
Read this many bytes from in 
- copy(BytesRef, BytesRef) - Method in class org.apache.lucene.util.PagedBytes
- 
Copy BytesRef in, setting BytesRef out to the result. 
- copy(int, int) - Method in class org.apache.lucene.util.TimSorter
- 
Copy data from slot srcto slotdest.
 
- 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(DataInput, long) - Method in class org.apache.lucene.store.DataOutput
- 
Copy numBytes bytes from input to ourself. 
- copyBytes(BytesRef) - Method in class org.apache.lucene.util.BytesRef
- 
Copies the bytes from the given  BytesRef
- copyChars(CharSequence) - 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. 
- copyFrom(TermState) - Method in class org.apache.lucene.codecs.BlockTermState
-  
- copyFrom(TermState) - Method in class org.apache.lucene.index.OrdTermState
-  
- copyFrom(TermState) - Method in class org.apache.lucene.index.TermState
- 
Copies the content of the given  TermState to this instance 
- 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
-  
- copyLongs(LongsRef) - Method in class org.apache.lucene.util.LongsRef
-  
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- 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.search.BoostAttributeImpl
-  
- copyTo(AttributeImpl) - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-  
- copyTo(AttributeImpl) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-  
- 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 AttributeSourceto the given targetAttributeSource.
 
- copyUsingLengthPrefix(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
- 
Copy bytes in, writing the length as a 1 or 2 byte
  vInt prefix. 
- correct(int) - Method in class org.apache.lucene.analysis.CharFilter
- 
Subclasses override to correct the current offset. 
- correctOffset(int) - Method in class org.apache.lucene.analysis.CharFilter
- 
Chains the corrected offset through the input
 CharFilter(s). 
- 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
- 
Sole constructor. 
- cos(double) - Static method in class org.apache.lucene.util.SloppyMath
- 
Returns the trigonometric cosine of an angle. 
- cost() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- cost() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
-  
- cost() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- cost() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
-  
- cost() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- cost() - Method in class org.apache.lucene.index.MultiDocsEnum
-  
- cost() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- cost() - Method in class org.apache.lucene.search.DocIdSetIterator
- 
- cost() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-  
- cost() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- cost() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- cost() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- cost() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- cost() - Method in class org.apache.lucene.search.spans.Spans
- 
Returns the estimated cost of this spans. 
- cost() - Method in class org.apache.lucene.search.spans.SpanScorer
-  
- cost() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- cost() - Method in class org.apache.lucene.util.FixedBitSet.FixedBitSetIterator
-  
- cost - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-  
- cost() - Method in class org.apache.lucene.util.OpenBitSetIterator
-  
- count - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
- 
count of values written 
- count - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.NumericEntry
- 
count of values written 
- count - Variable in class org.apache.lucene.search.spans.TermSpans
-  
- count - Variable in class org.apache.lucene.util.SentinelIntSet
-  
- counter - Variable in class org.apache.lucene.index.SegmentInfos
- 
Used to name new segments. 
- Counter - Class in org.apache.lucene.util
- 
Simple counter class 
- Counter() - Constructor for class org.apache.lucene.util.Counter
-  
- create(boolean, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
- 
- 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(Sort, int, boolean, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
- 
- create(Sort, int, FieldDoc, boolean, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
- 
- create(int, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
- 
- create(int, ScoreDoc, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
- 
- 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
- 
- createBooleanQuery(String, String) - Method in class org.apache.lucene.util.QueryBuilder
- 
Creates a boolean query from the query text. 
- createBooleanQuery(String, String, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
- 
Creates a boolean query from the query text. 
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
- 
- createComponents(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-  
- createFieldQuery(Analyzer, BooleanClause.Occur, String, String, boolean, int) - Method in class org.apache.lucene.util.QueryBuilder
- 
Creates a query from the analysis chain. 
- createMinShouldMatchQuery(String, String, float) - Method in class org.apache.lucene.util.QueryBuilder
- 
Creates a minimum-should-match query from the query text. 
- createNormalizedWeight(Query) - Method in class org.apache.lucene.search.IndexSearcher
- 
Creates a normalized weight for a top-level  Query. 
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.CompoundFileDirectory
-  
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.Directory
- 
Creates a new, empty file in the directory with the given name. 
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
-  
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
-  
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.FSDirectory
- 
Creates an IndexOutput for the file with the given name. 
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.RAMDirectory
- 
Creates a new, empty file in the directory with the given name. 
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
-  
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-  
- createPhraseQuery(String, String) - Method in class org.apache.lucene.util.QueryBuilder
- 
Creates a phrase query from the query text. 
- createPhraseQuery(String, String, int) - Method in class org.apache.lucene.util.QueryBuilder
- 
Creates a phrase query from the query text. 
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.CompoundFileDirectory
-  
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.Directory
- 
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
-  
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.MMapDirectory
-  
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.NIOFSDirectory
-  
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
-  
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.SimpleFSDirectory
-  
- createSlicer(String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.BooleanQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.ConstantScoreQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
- 
Create the Weight used to score us 
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.FilteredQuery
- 
Returns a Weight that applies the filter to the enclosed query's Weight. 
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.MatchAllDocsQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.MultiPhraseQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.PhraseQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.Query
- 
Expert: Constructs an appropriate Weight implementation for this query. 
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.spans.SpanQuery
-  
- createWeight(IndexSearcher) - Method in class org.apache.lucene.search.TermQuery
-  
- curDocs - Variable in class org.apache.lucene.search.CachingCollector
-  
- 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
-  
- currentIndex() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
The current decoding index. 
- 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 
- currentValue() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
The value at the current decoding index. 
- 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
-  
- 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, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
- 
Converts a Date to a string suitable for indexing. 
- decode(char[], int, int, byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
- 
Deprecated. Decodes the input char sequence into the output byte sequence. 
- decode(long[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
Read iterations * blockCount()blocks fromblocks,
 decode them and writeiterations * valueCount()values intovalues.
 
- decode(byte[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
Read 8 * iterations * blockCount()blocks fromblocks,
 decode them and writeiterations * valueCount()values intovalues.
 
- decode(long[], int, int[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
Read iterations * blockCount()blocks fromblocks,
 decode them and writeiterations * valueCount()values intovalues.
 
- decode(byte[], int, int[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
Read 8 * iterations * blockCount()blocks fromblocks,
 decode them and writeiterations * valueCount()values intovalues.
 
- decodeNormValue(byte) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
- decodeNormValue(long) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Decodes the norm value, assuming it is a single byte. 
- decodeNormValue(byte) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Decodes a normalization factor (document length) stored in an index. 
- decodeNormValue(long) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Decodes a normalization factor stored in an index. 
- decodeTerm(long[], DataInput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. 
- decodeTerm(long[], DataInput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
-  
- decodeTerm(long[], DataInput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.PostingsReaderBase
- 
Actually decode metadata for next term 
- decompress(DataInput, int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.compressing.Decompressor
- 
Decompress bytes that were stored between offsets offsetandoffset+lengthin the original stream from the compressed
 streamintobytes.
 
- decompress(BytesRef) - Static method in class org.apache.lucene.document.CompressionTools
- 
Decompress the byte array previously returned by
  compress (referenced by the provided BytesRef) 
- decompress(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
- 
Decompress the byte array previously returned by
  compress 
- decompress(byte[], int, int) - Static method in class org.apache.lucene.document.CompressionTools
- 
Decompress the byte array previously returned by
  compress 
- Decompressor - Class in org.apache.lucene.codecs.compressing
- 
A decompressor. 
- Decompressor() - Constructor for class org.apache.lucene.codecs.compressing.Decompressor
- 
Sole constructor, typically called from sub-classes. 
- decompressString(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
- 
Decompress the byte array previously returned by
  compressString back into a String 
- decompressString(byte[], int, int) - Static method in class org.apache.lucene.document.CompressionTools
- 
Decompress the byte array previously returned by
  compressString back into a String 
- decompressString(BytesRef) - Static method in class org.apache.lucene.document.CompressionTools
- 
Decompress the byte array (referenced by the provided BytesRef) 
  previously returned by compressString back into a String 
- decRef() - Method in class org.apache.lucene.index.IndexReader
- 
Expert: decreases the refCount of this IndexReader
 instance. 
- decRef(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-  
- 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
-  
- decRef() - Method in class org.apache.lucene.util.RefCount
- 
Decrements the reference counting of this object. 
- 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
 
- 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
 
- 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
 
- deepCopyOf(LongsRef) - Static method in class org.apache.lucene.util.LongsRef
- 
Creates a new IntsRef that points to a copy of the longs from 
 other
 
- DEFAULT - Static variable in interface org.apache.lucene.search.FieldCache
- 
Expert: The cache used internally by sorting and range query classes. 
- DEFAULT - Static variable in class org.apache.lucene.store.IOContext
-  
- DEFAULT - Static variable in class org.apache.lucene.util.packed.PackedInts
- 
At most 20% memory overhead. 
- 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_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexOutput
- 
The default buffer size in bytes (16384). 
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.lucene.util.packed.PackedInts
- 
Default amount of memory to use for bulk operations. 
- DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingByteBlockAllocator
-  
- DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingIntBlockAllocator
-  
- DEFAULT_BYTE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
Deprecated. 
- DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
-  
- DEFAULT_DOUBLE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
Deprecated. 
- DEFAULT_FLOAT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
Deprecated. 
- DEFAULT_INDEX_INTERVAL - Static variable in class org.apache.lucene.util.packed.EliasFanoEncoder
- 
The default index interval for zero upper bits. 
- DEFAULT_INDEX_INTERVAL - Static variable in class org.apache.lucene.util.WAH8DocIdSet
- 
Default index interval. 
- DEFAULT_INDEX_INTERVAL_BITS - Static variable in class org.apache.lucene.index.DocTermOrds
- 
Every 128th term is indexed, by default. 
- DEFAULT_INT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
Deprecated. 
- DEFAULT_LONG_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
Deprecated. 
- DEFAULT_MAX_BLOCK_BITS - Static variable in class org.apache.lucene.util.fst.FST
-  
- DEFAULT_MAX_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
- DEFAULT_MAX_BUFF - Static variable in class org.apache.lucene.store.MMapDirectory
- 
Default max chunk size. 
- 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.IndexWriterConfig
- 
Disabled by default (because IndexWriter flushes by RAM usage by default). 
- DEFAULT_MAX_CFS_SEGMENT_SIZE - Static variable in class org.apache.lucene.index.MergePolicy
- 
Default max segment size in order to use compound file system. 
- DEFAULT_MAX_MERGE_COUNT - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Default maxMergeCount.
 
- 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_THREAD_COUNT - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Default maxThreadCount.
 
- 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_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_MIN_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
- 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_NO_CFS_RATIO - Static variable in class org.apache.lucene.index.LogMergePolicy
- 
Default noCFSRatio. 
- DEFAULT_NO_CFS_RATIO - Static variable in class org.apache.lucene.index.MergePolicy
- 
Default ratio for compound file system usage. 
- DEFAULT_NO_CFS_RATIO - Static variable in class org.apache.lucene.index.TieredMergePolicy
- 
Default noCFSRatio. 
- DEFAULT_RAM_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
- 
Default value is 16 MB (which means flush when buffered docs consume
 approximately 16 MB RAM). 
- DEFAULT_RAM_PER_THREAD_HARD_LIMIT_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
- 
Default value is 1945. 
- DEFAULT_READ_CHUNK_SIZE - Static variable in class org.apache.lucene.store.FSDirectory
- 
Deprecated.
This constant is no longer used since Lucene 4.5. 
 
- DEFAULT_READER_POOLING - Static variable in class org.apache.lucene.index.IndexWriterConfig
- 
- DEFAULT_READER_TERMS_INDEX_DIVISOR - Static variable in class org.apache.lucene.index.IndexWriterConfig
- 
Default value is 1. 
- DEFAULT_RESOLUTION - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-  
- DEFAULT_SHORT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
Deprecated. 
- DEFAULT_TERM_INDEX_INTERVAL - Static variable in class org.apache.lucene.index.IndexWriterConfig
- 
Default value is 32. 
- DEFAULT_TERMS_INDEX_DIVISOR - Static variable in class org.apache.lucene.index.DirectoryReader
- 
Default termInfosIndexDivisor. 
- DEFAULT_TYPE - Static variable in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
- 
the default type 
- DEFAULT_USE_COMPOUND_FILE_SYSTEM - Static variable in class org.apache.lucene.index.IndexWriterConfig
- 
Default value for compound file system for newly written segments
  (set to true).
 
- defaultMaxEdits - Static variable in class org.apache.lucene.search.FuzzyQuery
-  
- defaultMaxExpansions - Static variable in class org.apache.lucene.search.FuzzyQuery
-  
- defaultMinSimilarity - Static variable in class org.apache.lucene.search.FuzzyQuery
- 
Deprecated.
pass integer edit distances instead. 
 
- defaultPrefixLength - Static variable in class org.apache.lucene.search.FuzzyQuery
-  
- DefaultSimilarity - Class in org.apache.lucene.search.similarities
- 
Expert: Default scoring implementation which  encodes norm values as a single byte before being stored. 
- DefaultSimilarity() - Constructor for class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Sole constructor: parameter-free 
- defaultTranspositions - Static variable in class org.apache.lucene.search.FuzzyQuery
-  
- delCountOnFlush - Variable in class org.apache.lucene.index.SegmentWriteState
- 
Number of deleted documents set while flushing the
  segment. 
- delegate - Variable in class org.apache.lucene.codecs.FilterCodec
- 
The codec to filter. 
- delete() - Method in class org.apache.lucene.index.IndexCommit
- 
Delete this commit point. 
- delete(String) - Method in class org.apache.lucene.search.LiveFieldValues
- 
Call this after you've successfully deleted a document
  from the index. 
- deleteAll() - Method in class org.apache.lucene.index.IndexWriter
- 
Delete all documents in the index. 
- deleteAll() - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- deleteDocuments(Term) - Method in class org.apache.lucene.index.IndexWriter
- 
Deletes the document(s) containing term.
 
- deleteDocuments(Term...) - Method in class org.apache.lucene.index.IndexWriter
- 
Deletes the document(s) containing any of the
 terms. 
- deleteDocuments(Query) - Method in class org.apache.lucene.index.IndexWriter
- 
Deletes the document(s) matching the provided query. 
- deleteDocuments(Query...) - Method in class org.apache.lucene.index.IndexWriter
- 
Deletes the document(s) matching any of the provided queries. 
- deleteDocuments(Term) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- deleteDocuments(Term...) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- deleteDocuments(Query) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- deleteDocuments(Query...) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- deleteFile(String) - Method in class org.apache.lucene.store.CompoundFileDirectory
- 
Not implemented 
- deleteFile(String) - Method in class org.apache.lucene.store.Directory
- 
Removes an existing file in the directory. 
- deleteFile(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-  
- deleteFile(String) - Method in class org.apache.lucene.store.FilterDirectory
-  
- deleteFile(String) - Method in class org.apache.lucene.store.FSDirectory
- 
Removes an existing file in the directory. 
- deleteFile(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- deleteFile(String) - Method in class org.apache.lucene.store.RAMDirectory
- 
Removes an existing file in the directory. 
- deleteFile(String) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-  
- deleteFilesIgnoringExceptions(Directory, String...) - Static method in class org.apache.lucene.util.IOUtils
- 
Deletes all given files, suppressing all thrown IOExceptions. 
- deleteLast(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- deleteUnusedFiles() - Method in class org.apache.lucene.index.IndexWriter
- 
Expert: remove any index files that are no longer
  used. 
- deletionsGen - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Current deletions generation. 
- delPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- DELTA_COMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Compressed using packed blocks of ints. 
- delTermCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
- 
Number of terms with zero live docs docs. 
- depth - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
- 
This node's depth, starting from the automaton root. 
- DerefBytesDocValuesField - Class in org.apache.lucene.document
- 
- DerefBytesDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.DerefBytesDocValuesField
- 
Deprecated. Create a new fixed or variable-length DocValues field. 
- DerefBytesDocValuesField(String, BytesRef, boolean) - Constructor for class org.apache.lucene.document.DerefBytesDocValuesField
- 
Deprecated. Create a new fixed or variable length DocValues field. 
- description - Variable in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
-  
- determinize() - Method in class org.apache.lucene.util.automaton.Automaton
- 
- determinize(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Determinizes the given automaton. 
- DFRSimilarity - Class in org.apache.lucene.search.similarities
- 
Implements the divergence from randomness (DFR) framework
 introduced in Gianni Amati and Cornelis Joost Van Rijsbergen. 
- DFRSimilarity(BasicModel, AfterEffect, Normalization) - Constructor for class org.apache.lucene.search.similarities.DFRSimilarity
- 
Creates DFRSimilarity from the three components. 
- diagnostics - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Map that includes certain
  debugging details that IndexWriter records into
  each segment it creates 
- dir - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
Directory index is in. 
- dir - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
- dir - Variable in class org.apache.lucene.index.SegmentInfo
- 
Where this segment resides. 
- directory - Variable in class org.apache.lucene.index.DirectoryReader
- 
The index directory. 
- directory() - Method in class org.apache.lucene.index.DirectoryReader
- 
Returns the directory this index resides in. 
- directory() - Method in class org.apache.lucene.index.SegmentReader
- 
Returns the directory this index resides in. 
- directory - Variable in class org.apache.lucene.index.SegmentReadState
- 
- directory - Variable in class org.apache.lucene.index.SegmentWriteState
- 
Directory where this segment will be written
  to. 
- Directory - Class in org.apache.lucene.store
- 
A Directory is a flat list of files. 
- Directory() - Constructor for class org.apache.lucene.store.Directory
-  
- directory - Variable in class org.apache.lucene.store.FSDirectory
-  
- Directory.IndexInputSlicer - Class in org.apache.lucene.store
- 
Allows to create one or more sliced  IndexInput instances from a single 
 file handle. 
- Directory.IndexInputSlicer() - Constructor for class org.apache.lucene.store.Directory.IndexInputSlicer
-  
- DirectoryReader - Class in org.apache.lucene.index
- 
- DirectoryReader(Directory, AtomicReader[]) - Constructor for class org.apache.lucene.index.DirectoryReader
- 
Expert: Constructs a DirectoryReaderon the given subReaders.
 
- DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriterConfig
- 
Denotes a flush trigger is disabled. 
- discountOverlaps - Variable in class org.apache.lucene.search.similarities.BM25Similarity
- 
True if overlap tokens (tokens with a position of increment of zero) are
 discounted from the document's length. 
- discountOverlaps - Variable in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
True if overlap tokens (tokens with a position of increment of zero) are
 discounted from the document's length. 
- discountOverlaps - Variable in class org.apache.lucene.search.similarities.SimilarityBase
- 
True if overlap tokens (tokens with a position of increment of zero) are
 discounted from the document's length. 
- DisjunctionMaxQuery - Class in org.apache.lucene.search
- 
A query that generates the union of documents produced by its subqueries, and that scores each document with the maximum
 score for that document as produced by any subquery, plus a tie breaking increment for any additional matching subqueries. 
- DisjunctionMaxQuery(float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
- 
Creates a new empty DisjunctionMaxQuery. 
- DisjunctionMaxQuery(Collection<Query>, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
- 
Creates a new DisjunctionMaxQuery 
- DisjunctionMaxQuery.DisjunctionMaxWeight - Class in org.apache.lucene.search
- 
Expert: the Weight for DisjunctionMaxQuery, used to
 normalize, score and explain these queries. 
- DisjunctionMaxQuery.DisjunctionMaxWeight(IndexSearcher) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
- 
Construct the Weight for this Query searched by searcher. 
- Distribution - Class in org.apache.lucene.search.similarities
- 
The probabilistic distribution used to model term occurrence
 in information-based models. 
- Distribution() - Constructor for class org.apache.lucene.search.similarities.Distribution
- 
Sole constructor. 
- distribution - Variable in class org.apache.lucene.search.similarities.IBSimilarity
- 
The probabilistic distribution used to model term occurrence. 
- DistributionLL - Class in org.apache.lucene.search.similarities
- 
Log-logistic distribution. 
- DistributionLL() - Constructor for class org.apache.lucene.search.similarities.DistributionLL
- 
Sole constructor: parameter-free 
- DistributionSPL - Class in org.apache.lucene.search.similarities
- 
The smoothed power-law (SPL) distribution for the information-based framework
 that is described in the original paper. 
- DistributionSPL() - Constructor for class org.apache.lucene.search.similarities.DistributionSPL
- 
Sole constructor: parameter-free 
- doAfterFlush() - Method in class org.apache.lucene.index.IndexWriter
- 
A hook for extending classes to execute operations after pending added and
 deleted documents have been flushed to the Directory but before the change
 is committed (new segments_N file written). 
- doBeforeFlush() - Method in class org.apache.lucene.index.IndexWriter
- 
A hook for extending classes to execute operations before pending added and
 deleted documents are flushed to the Directory. 
- doBody(String) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
- 
Subclass must implement this. 
- doBody() - Method in class org.apache.lucene.store.Lock.With
- 
Code to execute with exclusive access. 
- doc(int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Sugar for .getIndexReader().document(docID)
 
- doc(int, StoredFieldVisitor) - Method in class org.apache.lucene.search.IndexSearcher
- 
Sugar for .getIndexReader().document(docID, fieldVisitor)
 
- doc(int, Set<String>) - Method in class org.apache.lucene.search.IndexSearcher
- 
Sugar for .getIndexReader().document(docID, fieldsToLoad)
 
- doc - Variable in class org.apache.lucene.search.ScoreDoc
- 
A hit document's number. 
- doc() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- doc() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- doc() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- doc() - Method in class org.apache.lucene.search.spans.Spans
- 
Returns the document number of the current match. 
- doc - Variable in class org.apache.lucene.search.spans.SpanScorer
-  
- doc - Variable in class org.apache.lucene.search.spans.TermSpans
-  
- doc() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- DOC_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
- 
Filename extension for document number, frequencies, and skip data. 
- doCacheWrite(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
- 
Subclass can override this to customize logic; return
  true if this file should be written to the RAMDirectory. 
- docBase - Variable in class org.apache.lucene.index.AtomicReaderContext
- 
The readers absolute doc base 
- docBase - Variable in class org.apache.lucene.index.MergeState
- 
New docID base per reader. 
- docBaseInParent - Variable in class org.apache.lucene.index.IndexReaderContext
- 
the doc base for this reader in the parent, 0 if parent is null 
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Document count (does not take deletions into account). 
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
- 
Number of documents tested. 
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
- 
Number of documents tested. 
- docCount() - Method in class org.apache.lucene.search.CollectionStatistics
- 
returns the total number of documents that
 have at least one term for this field. 
- docFreq - Variable in class org.apache.lucene.codecs.BlockTermState
- 
how many docs have this term 
- docFreq - Variable in class org.apache.lucene.codecs.TermStats
- 
How many documents have at least one occurrence of
  this term. 
- docFreq(Term) - Method in class org.apache.lucene.index.AtomicReader
-  
- docFreq(Term) - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- docFreq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- docFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
-  
- docFreq(Term) - Method in class org.apache.lucene.index.IndexReader
- 
Returns the number of documents containing the 
 term.
 
- docFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- docFreq() - Method in class org.apache.lucene.index.TermContext
- 
- docFreq() - Method in class org.apache.lucene.index.TermsEnum
- 
Returns the number of documents containing the current
  term. 
- docFreq() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- docFreq - Variable in class org.apache.lucene.search.similarities.BasicStats
- 
The document frequency. 
- docFreq() - Method in class org.apache.lucene.search.TermStatistics
- 
returns the number of documents this term occurs in 
- docID() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- docID() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
-  
- docID() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- docID() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
-  
- docID() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- docID() - Method in class org.apache.lucene.index.MultiDocsEnum
-  
- docID() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- docID() - Method in class org.apache.lucene.search.DocIdSetIterator
- 
- docID() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-  
- docID() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- docID() - Method in class org.apache.lucene.search.spans.SpanScorer
-  
- docID() - Method in class org.apache.lucene.util.FixedBitSet.FixedBitSetIterator
-  
- docID() - Method in class org.apache.lucene.util.OpenBitSetIterator
-  
- DocIdBitSet - Class in org.apache.lucene.util
- 
Simple DocIdSet and DocIdSetIterator backed by a BitSet 
- DocIdBitSet(BitSet) - Constructor for class org.apache.lucene.util.DocIdBitSet
-  
- DocIdSet - Class in org.apache.lucene.search
- 
A DocIdSet contains a set of doc ids. 
- DocIdSet() - Constructor for class org.apache.lucene.search.DocIdSet
-  
- DocIdSetIterator - Class in org.apache.lucene.search
- 
This abstract class defines methods to iterate over a set of non-decreasing
 doc ids. 
- DocIdSetIterator() - Constructor for class org.apache.lucene.search.DocIdSetIterator
-  
- docIdSetToCache(DocIdSet, AtomicReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
- 
Provide the DocIdSet to be cached, using the DocIdSet provided
  by the wrapped Filter. 
- doClose() - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- doClose() - Method in class org.apache.lucene.index.FilterDirectoryReader
-  
- doClose() - Method in class org.apache.lucene.index.IndexReader
- 
Implements close. 
- doClose() - Method in class org.apache.lucene.index.MultiReader
-  
- doClose() - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- doClose() - Method in class org.apache.lucene.index.ParallelCompositeReader
-  
- doClose() - Method in class org.apache.lucene.index.SegmentReader
-  
- doClose() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- docMaps - Variable in class org.apache.lucene.index.MergeState
- 
Maps docIDs around deletions. 
- docs(FieldInfo, BlockTermState, Bits, DocsEnum, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. 
- docs(FieldInfo, BlockTermState, Bits, DocsEnum, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
-  
- docs(FieldInfo, BlockTermState, Bits, DocsEnum, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
- 
Must fully consume state, since after this call that
  TermState may be reused. 
- docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.FilteredTermsEnum
-  
- docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- docs(Bits, DocsEnum) - Method in class org.apache.lucene.index.TermsEnum
- 
- docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
- 
Get  DocsEnum for the current term, with
  control over whether freqs are required. 
- docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- docsAndPositions(FieldInfo, BlockTermState, Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. 
- docsAndPositions(FieldInfo, BlockTermState, Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
-  
- docsAndPositions(FieldInfo, BlockTermState, Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
- 
Must fully consume state, since after this call that
  TermState may be reused. 
- docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.FilteredTermsEnum
-  
- docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- docsAndPositions(Bits, DocsAndPositionsEnum) - Method in class org.apache.lucene.index.TermsEnum
- 
- docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
- 
Get  DocsAndPositionsEnum for the current term,
  with control over whether offsets and payloads are
  required. 
- docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- DocsAndPositionsEnum - Class in org.apache.lucene.index
- 
Also iterates through positions. 
- DocsAndPositionsEnum() - Constructor for class org.apache.lucene.index.DocsAndPositionsEnum
- 
Sole constructor. 
- docsAndPositionsEnum - Variable in class org.apache.lucene.index.MultiDocsAndPositionsEnum.EnumWithSlice
- 
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
-  
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
-  
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
-  
- docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
- 
Calculate the final score for all the payloads seen so far for this doc/field 
- docScorer - Variable in class org.apache.lucene.search.spans.SpanScorer
-  
- DocsEnum - Class in org.apache.lucene.index
- 
Iterates through the documents and term freqs. 
- DocsEnum() - Constructor for class org.apache.lucene.index.DocsEnum
- 
Sole constructor. 
- docsEnum - Variable in class org.apache.lucene.index.DocTermOrds
- 
Used while uninverting. 
- docsEnum - Variable in class org.apache.lucene.index.MultiDocsEnum.EnumWithSlice
- 
- docStarts - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
- 
- docStarts - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
- 
- docStoreCompoundFile - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
True if the shared doc store files are compound file
  format. 
- docStoreOffset - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Doc store offset, if this segment shares the doc
  store files (stored fields and term vectors) with
  other segments. 
- docStoreSegment - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
String of the shared doc store segment, or null if
  this segment does not share the doc store files. 
- docsWithField - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
-  
- DocTermOrds - Class in org.apache.lucene.index
- 
This class enables fast access to multiple term ords for
 a specified field across all docIDs. 
- DocTermOrds(AtomicReader, Bits, String) - Constructor for class org.apache.lucene.index.DocTermOrds
- 
Inverts all terms 
- DocTermOrds(AtomicReader, Bits, String, BytesRef) - Constructor for class org.apache.lucene.index.DocTermOrds
- 
Inverts only terms starting w/ prefix 
- DocTermOrds(AtomicReader, Bits, String, BytesRef, int) - Constructor for class org.apache.lucene.index.DocTermOrds
- 
Inverts only terms starting w/ prefix, and only terms
  whose docFreq (not taking deletions into account) is
  <=  maxTermDocFreq 
- DocTermOrds(AtomicReader, Bits, String, BytesRef, int, int) - Constructor for class org.apache.lucene.index.DocTermOrds
- 
Inverts only terms starting w/ prefix, and only terms
  whose docFreq (not taking deletions into account) is
  <=  maxTermDocFreq, with a custom indexing interval
  (default is every 128nd term). 
- DocTermOrds(String, int, int) - Constructor for class org.apache.lucene.index.DocTermOrds
- 
Subclass inits w/ this, but be sure you then call
  uninvert, only once 
- DocTermOrdsRangeFilter - Class in org.apache.lucene.search
- 
A range filter built on top of a cached multi-valued term field (in  FieldCache). 
- DocTermOrdsRewriteMethod - Class in org.apache.lucene.search
- 
Rewrites MultiTermQueries into a filter, using DocTermOrds for term enumeration. 
- DocTermOrdsRewriteMethod() - Constructor for class org.apache.lucene.search.DocTermOrdsRewriteMethod
-  
- Document - Class in org.apache.lucene.document
- 
Documents are the unit of indexing and search. 
- Document() - Constructor for class org.apache.lucene.document.Document
- 
Constructs a new document with no fields. 
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.IndexReader
- 
Expert: visits the fields of a stored document, for
  custom processing/loading of each field. 
- document(int) - Method in class org.apache.lucene.index.IndexReader
- 
Returns the stored fields of the nthDocumentin this index.
 
- document(int, Set<String>) - Method in class org.apache.lucene.index.IndexReader
- 
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.SegmentReader
-  
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- document(int, Set<String>) - Method in class org.apache.lucene.search.IndexSearcher
- 
- DocumentStoredFieldVisitor - Class in org.apache.lucene.document
- 
- DocumentStoredFieldVisitor(Set<String>) - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
- 
Load only fields named in the provided Set<String>.
 
- DocumentStoredFieldVisitor(String...) - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
- 
Load only fields named in the provided fields. 
- DocumentStoredFieldVisitor() - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
- 
Load all stored fields. 
- DocValuesConsumer - Class in org.apache.lucene.codecs
- 
Abstract API that consumes numeric, binary and
 sorted docvalues. 
- DocValuesConsumer() - Constructor for class org.apache.lucene.codecs.DocValuesConsumer
- 
Sole constructor. 
- docValuesFormat() - Method in class org.apache.lucene.codecs.Codec
- 
Encodes/decodes docvalues 
- DocValuesFormat - Class in org.apache.lucene.codecs
- 
Encodes/decodes per-document values. 
- DocValuesFormat(String) - Constructor for class org.apache.lucene.codecs.DocValuesFormat
- 
Creates a new docvalues format. 
- docValuesFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-  
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. 
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. 
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. 
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. 
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
-  
- DocValuesProducer - Class in org.apache.lucene.codecs
- 
Abstract API that produces numeric, binary and
 sorted docvalues. 
- DocValuesProducer() - Constructor for class org.apache.lucene.codecs.DocValuesProducer
- 
Sole constructor. 
- DocValuesProducer.SortedDocsWithField - Class in org.apache.lucene.codecs
- 
- DocValuesProducer.SortedDocsWithField(SortedDocValues, int) - Constructor for class org.apache.lucene.codecs.DocValuesProducer.SortedDocsWithField
- 
Creates a  Bits returning true if the document has a value 
- DocValuesProducer.SortedSetDocsWithField - Class in org.apache.lucene.codecs
- 
- DocValuesProducer.SortedSetDocsWithField(SortedSetDocValues, int) - Constructor for class org.apache.lucene.codecs.DocValuesProducer.SortedSetDocsWithField
- 
Creates a  Bits returning true if the document has a value 
- docValuesStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Status for testing of DocValues (null if DocValues could not be tested). 
- docValueType() - Method in class org.apache.lucene.document.FieldType
- 
- docValueType() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
- doMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
- doNext() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- doOpenIfChanged() - Method in class org.apache.lucene.index.DirectoryReader
- 
- doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.DirectoryReader
- 
- doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.DirectoryReader
- 
- doOpenIfChanged() - Method in class org.apache.lucene.index.FilterDirectoryReader
-  
- doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.FilterDirectoryReader
-  
- doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.FilterDirectoryReader
-  
- doPrune(double, IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager.PruneByAge
-  
- doPrune(double, IndexSearcher) - Method in interface org.apache.lucene.search.SearcherLifetimeManager.Pruner
- 
Return true if this searcher should be removed. 
- DoubleBarrelLRUCache<K extends DoubleBarrelLRUCache.CloneableKey,V> - Class in org.apache.lucene.util
- 
Simple concurrent LRU cache, using a "double barrel"
 approach where two ConcurrentHashMaps record entries. 
- DoubleBarrelLRUCache(int) - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache
-  
- DoubleBarrelLRUCache.CloneableKey - Class in org.apache.lucene.util
- 
Object providing clone(); the key class must subclass this. 
- DoubleBarrelLRUCache.CloneableKey() - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
-  
- DoubleDocValuesField - Class in org.apache.lucene.document
- 
- DoubleDocValuesField(String, double) - Constructor for class org.apache.lucene.document.DoubleDocValuesField
- 
Creates a new DocValues field with the specified 64-bit double value 
- doubleField(FieldInfo, double) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-  
- DoubleField - Class in org.apache.lucene.document
- 
 Field that indexes doublevalues
 for efficient range filtering and sorting.
 
- DoubleField(String, double, Field.Store) - Constructor for class org.apache.lucene.document.DoubleField
- 
- DoubleField(String, double, FieldType) - Constructor for class org.apache.lucene.document.DoubleField
- 
Expert: allows you to customize the  FieldType. 
- doubleField(FieldInfo, double) - Method in class org.apache.lucene.index.StoredFieldVisitor
- 
Process a double numeric field. 
- doubleToSortableLong(double) - Static method in class org.apache.lucene.util.NumericUtils
- 
Converts a doublevalue to a sortable signedlong.
 
- doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.FilterDirectoryReader
- 
Called by the doOpenIfChanged() methods to return a new wrapped DirectoryReader. 
- DS_COMPOUND_KEY - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- DS_NAME_KEY - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- DS_OFFSET_KEY - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueBool
-  
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueDate
-  
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-  
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-  
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueInt
-  
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueLong
-  
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueStr
-  
- earthDiameter(double) - Static method in class org.apache.lucene.util.SloppyMath
- 
Return an approximate value of the diameter of the earth at the given latitude, in kilometers. 
- EliasFanoDecoder - Class in org.apache.lucene.util.packed
- 
- EliasFanoDecoder(EliasFanoEncoder) - Constructor for class org.apache.lucene.util.packed.EliasFanoDecoder
- 
- EliasFanoDocIdSet - Class in org.apache.lucene.util.packed
- 
A DocIdSet in Elias-Fano encoding. 
- EliasFanoDocIdSet(int, int) - Constructor for class org.apache.lucene.util.packed.EliasFanoDocIdSet
- 
Construct an EliasFanoDocIdSet. 
- EliasFanoEncoder - Class in org.apache.lucene.util.packed
- 
Encode a non decreasing sequence of non negative whole numbers in the Elias-Fano encoding
 that was introduced in the 1970's by Peter Elias and Robert Fano. 
- EliasFanoEncoder(long, long, long) - Constructor for class org.apache.lucene.util.packed.EliasFanoEncoder
- 
Construct an Elias-Fano encoder. 
- EliasFanoEncoder(long, long) - Constructor for class org.apache.lucene.util.packed.EliasFanoEncoder
- 
- EMPTY - Static variable in class org.apache.lucene.codecs.PostingsFormat
- 
Zero-length PostingsFormatarray.
 
- EMPTY - Static variable in class org.apache.lucene.index.BinaryDocValues
- 
- EMPTY - Static variable in class org.apache.lucene.index.NumericDocValues
- 
An empty NumericDocValues which returns zero for every document 
- EMPTY - Static variable in class org.apache.lucene.index.SortedDocValues
- 
- EMPTY - Static variable in class org.apache.lucene.index.SortedSetDocValues
- 
- EMPTY - Static variable in class org.apache.lucene.index.TermsEnum
- 
An empty TermsEnum for quickly returning an empty instance e.g. 
- empty() - Static method in class org.apache.lucene.search.DocIdSetIterator
- 
An empty DocIdSetIteratorinstance
 
- EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Bytes
- 
Zero value for every document 
- EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Doubles
- 
Zero value for every document 
- EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Floats
- 
Zero value for every document 
- EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Ints
- 
Zero value for every document 
- EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Longs
- 
Zero value for every document 
- EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Shorts
- 
Zero value for every document 
- EMPTY - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables empty language (#). 
- EMPTY - Static variable in interface org.apache.lucene.util.BytesRefIterator
- 
Singleton BytesRefIterator that iterates over 0 BytesRefs. 
- EMPTY_ARRAY - Static variable in class org.apache.lucene.index.Fields
- 
Zero-length Fieldsarray.
 
- EMPTY_ARRAY - Static variable in class org.apache.lucene.index.ReaderSlice
- 
Zero-length ReaderSlicearray.
 
- EMPTY_ARRAY - Static variable in class org.apache.lucene.index.Terms
- 
Zero-length array of  Terms. 
- EMPTY_ARRAY - Static variable in interface org.apache.lucene.util.Bits
-  
- EMPTY_BYTES - Static variable in class org.apache.lucene.util.BytesRef
- 
An empty byte array for convenience 
- EMPTY_CHARS - Static variable in class org.apache.lucene.util.CharsRef
- 
An empty character array for convenience 
- EMPTY_DOCIDSET - Static variable in class org.apache.lucene.search.CachingWrapperFilter
- 
An empty DocIdSetinstance
 
- EMPTY_INTS - Static variable in class org.apache.lucene.util.IntsRef
- 
An empty integer array for convenience 
- EMPTY_LONGS - Static variable in class org.apache.lucene.util.LongsRef
- 
An empty long array for convenience 
- EMPTY_TERM_SPANS - Static variable in class org.apache.lucene.search.spans.TermSpans
-  
- EMPTY_TOPDOCS - Static variable in class org.apache.lucene.search.TopDocsCollector
- 
This is used in case topDocs() is called with illegal parameters, or there
  simply aren't (enough) results. 
- emptyVal - Variable in class org.apache.lucene.util.SentinelIntSet
-  
- encode(byte[], int, int, char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
- 
Deprecated. Encodes the input byte sequence into the output char sequence. 
- encode(long[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
Read iterations * valueCount()values fromvalues,
 encode them and writeiterations * blockCount()blocks intoblocks.
 
- encode(long[], int, byte[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
Read iterations * valueCount()values fromvalues,
 encode them and write8 * iterations * blockCount()blocks intoblocks.
 
- encode(int[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
Read iterations * valueCount()values fromvalues,
 encode them and writeiterations * blockCount()blocks intoblocks.
 
- encode(int[], int, byte[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
Read iterations * valueCount()values fromvalues,
 encode them and write8 * iterations * blockCount()blocks intoblocks.
 
- encodeFromDisi(DocIdSetIterator) - Method in class org.apache.lucene.util.packed.EliasFanoDocIdSet
- 
Encode the document ids from a DocIdSetIterator. 
- encodeNext(long) - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
- 
Call at most numValuestimes to encode a non decreasing sequence of non negative numbers.
 
- encodeNormValue(float, int) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
- encodeNormValue(float) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Encodes a normalization factor for storage in an index. 
- encodeNormValue(float, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Encodes the length to a byte via SmallFloat. 
- encodeNormValue(float) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Encodes a normalization factor for storage in an index. 
- encodeTerm(long[], DataOutput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- encodeTerm(long[], DataOutput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.PostingsWriterBase
- 
Encode metadata as long[] and byte[]. 
- end() - Method in class org.apache.lucene.analysis.CachingTokenFilter
-  
- end() - Method in class org.apache.lucene.analysis.TokenFilter
- 
This method is called by the consumer after the last token has been
 consumed, after  TokenStream.incrementToken() returned  false
 (using the new  TokenStream API). 
- end() - Method in class org.apache.lucene.analysis.TokenStream
- 
This method is called by the consumer after the last token has been
 consumed, after  TokenStream.incrementToken() returned  false
 (using the new  TokenStream API). 
- end() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- end() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- end() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- end - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-  
- end() - Method in class org.apache.lucene.search.spans.Spans
- 
Returns the end position of the current match. 
- end() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- end - Variable in class org.apache.lucene.store.FSDirectory.FSIndexInput
- 
end offset (start+length) 
- END_LABEL - Static variable in class org.apache.lucene.util.fst.FST
- 
If arc has this label then that arc is final/accepted 
- endOffset() - Method in class org.apache.lucene.analysis.Token
- 
Returns this Token's ending offset, one greater than the position of the
 last character corresponding to this token in the source text. 
- endOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
- 
Returns this Token's ending offset, one greater than the position of the
 last character corresponding to this token in the source text. 
- endOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-  
- endOffset() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- endOffset() - Method in class org.apache.lucene.index.DocsAndPositionsEnum
- 
Returns end offset for the current position, or -1 if
  offsets were not indexed. 
- endOffset() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- endOffset() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- endOfSlice() - Method in class org.apache.lucene.util.IntBlockPool.SliceReader
- 
Returns trueiff the current slice is fully read.
 
- endsWith(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
- 
Returns trueiff the ref ends with the given suffix.
 
- ensureCanWrite(String) - Method in class org.apache.lucene.store.FSDirectory
-  
- ensureCapacity(FixedBitSet, int) - Static method in class org.apache.lucene.util.FixedBitSet
- 
If the given  FixedBitSet is large enough to hold  numBits,
 returns the given bits, otherwise returns a new  FixedBitSet which
 can hold the requested number of bits. 
- ensureCapacity(LongBitSet, long) - Static method in class org.apache.lucene.util.LongBitSet
- 
If the given  LongBitSet is large enough to hold
  numBits, returns the given bits, otherwise returns a new
  LongBitSet which can hold the requested number of bits. 
- ensureCapacity(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Ensure that the long[] is big enough to hold numBits, expanding it if
 necessary. 
- ensureCapacityWords(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
Expand the long[] with the size given as a number of words (64 bit longs). 
- ensureOpen() - Method in class org.apache.lucene.index.IndexReader
- 
Throws AlreadyClosedException if this IndexReader or any
 of its child readers is closed, otherwise returns. 
- ensureOpen(boolean) - Method in class org.apache.lucene.index.IndexWriter
- 
Used internally to throw an  AlreadyClosedException if this
 IndexWriter has been closed or is in the process of closing. 
- ensureOpen() - Method in class org.apache.lucene.index.IndexWriter
- 
Used internally to throw an  AlreadyClosedException if this IndexWriter has been
 closed ( closed=true) or is in the process of
 closing ( closing=true). 
- ensureOpen() - Method in class org.apache.lucene.store.BaseDirectory
-  
- ensureOpen() - Method in class org.apache.lucene.store.Directory
-  
- eof() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- equals(Object) - Method in class org.apache.lucene.analysis.Token
-  
- equals(Object) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.index.IndexCommit
- 
Two IndexCommits are equal if both their Directory and versions are equal. 
- equals(Object) - Method in class org.apache.lucene.index.IndexReader
- equals(Object) - Method in class org.apache.lucene.index.SegmentInfo
- 
We consider another SegmentInfo instance equal if it
  has the same dir and same name. 
- equals(Object) - Method in class org.apache.lucene.index.Term
-  
- equals(Object) - Method in class org.apache.lucene.search.AutomatonQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.BooleanClause
- 
Returns true if ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.BooleanQuery
- 
Returns true iff ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.CachingWrapperFilter
-  
- equals(Object) - Method in class org.apache.lucene.search.ConstantScoreQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
- 
Return true iff we represent the same query as o 
- equals(Object) - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
-  
- equals(Object) - Method in class org.apache.lucene.search.DocTermOrdsRewriteMethod
-  
- equals(Object) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
-  
- equals(Object) - Method in class org.apache.lucene.search.FieldCacheRewriteMethod
-  
- equals(Object) - Method in class org.apache.lucene.search.FieldValueFilter
-  
- equals(Object) - Method in class org.apache.lucene.search.FilteredQuery
- 
Returns true iff ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.FuzzyQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-  
- equals(Object) - Method in class org.apache.lucene.search.MatchAllDocsQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.MultiPhraseQuery
- 
Returns true if ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.MultiTermQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
-  
- equals(Object) - Method in class org.apache.lucene.search.NGramPhraseQuery
- 
Returns true iff ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.NumericRangeQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
-  
- equals(Object) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
-  
- equals(Object) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
-  
- equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadFunction
-  
- equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.PhraseQuery
- 
Returns true iff ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.PrefixQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.Query
-  
- equals(Object) - Method in class org.apache.lucene.search.QueryWrapperFilter
-  
- equals(Object) - Method in class org.apache.lucene.search.Sort
- 
Returns true if ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.SortField
- 
Returns true if ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearQuery
- 
Returns true iff ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanNotQuery
- 
Returns true iff ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.spans.SpanTermQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.TermQuery
- 
Returns true iff ois equal to this.
 
- equals(Object) - Method in class org.apache.lucene.search.TermRangeQuery
-  
- equals(Object) - Method in class org.apache.lucene.search.TopTermsRewrite
-  
- equals(Object) - Method in class org.apache.lucene.store.FlushInfo
-  
- equals(Object) - Method in class org.apache.lucene.store.IOContext
-  
- equals(Object) - Method in class org.apache.lucene.store.MergeInfo
-  
- equals(char[], int, char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
- 
See if two array slices are the same. 
- equals(byte[], int, byte[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
- 
See if two array slices are the same. 
- equals(int[], int, int[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
- 
See if two array slices are the same. 
- equals(Object) - Method in class org.apache.lucene.util.AttributeSource
-  
- equals(Object) - Method in class org.apache.lucene.util.automaton.Automaton
-  
- equals(Object) - Method in class org.apache.lucene.util.automaton.StatePair
- 
Checks for equality. 
- equals(Object) - Method in class org.apache.lucene.util.automaton.Transition
- 
Checks for equality. 
- equals(Object) - Method in class org.apache.lucene.util.BytesRef
-  
- equals(Object) - Method in class org.apache.lucene.util.CharsRef
-  
- equals(Object) - Method in class org.apache.lucene.util.FixedBitSet
- 
returns true if both sets have the same bits set 
- equals(Object) - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
-  
- equals(Object) - Method in class org.apache.lucene.util.IntsRef
-  
- equals(Object) - Method in class org.apache.lucene.util.LongBitSet
- 
returns true if both sets have the same bits set 
- equals(Object) - Method in class org.apache.lucene.util.LongsRef
-  
- equals(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- equals(Object) - Method in class org.apache.lucene.util.OpenBitSet
- 
returns true if both sets have the same bits set 
- equals(Object) - Method in class org.apache.lucene.util.packed.EliasFanoDocIdSet
-  
- equals(Object) - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
-  
- equals(String, String) - Static method in class org.apache.lucene.util.StringHelper
-  
- equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueBool
-  
- equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-  
- equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-  
- equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueInt
-  
- equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueLong
-  
- equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueStr
-  
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
- 
Exception thrown during doc values test (null on success) 
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
- 
Exception thrown during term index test (null on success) 
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
- 
Exception thrown during stored fields test (null on success) 
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
- 
Exception thrown during term index test (null on success) 
- error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
- 
Exception thrown during term vector test (null on success) 
- estimatedMergeBytes - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Estimated size in bytes of the merged segment. 
- estimatedMergeBytes - Variable in class org.apache.lucene.store.MergeInfo
-  
- estimatedSegmentSize - Variable in class org.apache.lucene.store.FlushInfo
-  
- estimateSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- 
Computes (and stores) the estimated size of the cache Value 
- execute(TwoPhaseCommit...) - Static method in class org.apache.lucene.index.TwoPhaseCommitTool
- 
- exists - Variable in class org.apache.lucene.util.mutable.MutableValue
-  
- exists() - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- exists(int) - Method in class org.apache.lucene.util.SentinelIntSet
- 
Does this set contain the specified integer? 
- expandingWordNum(long) - Method in class org.apache.lucene.util.OpenBitSet
-  
- expandSingleton() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Expands singleton representation to normal representation. 
- EXPECTED - Static variable in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
- 
Indicates an expected bit of "insanity". 
- explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
-  
- explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
- 
Explain the score we computed for doc 
- explain(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Returns an Explanation that describes how docscored againstquery.
 
- explain(Weight, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Expert: low-level implementation method
 Returns an Explanation that describes how docscored againstweight.
 
- explain(int, String, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
-  
- explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
-  
- explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight
-  
- explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect
- 
Returns an explanation for the score. 
- explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
-  
- explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectB
-  
- explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectL
-  
- explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModel
- 
Returns an explanation for the score. 
- explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIn
-  
- explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-  
- explain(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Distribution
- 
Explains the score. 
- explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.IBSimilarity
-  
- explain(BasicStats) - Method in class org.apache.lucene.search.similarities.Lambda
- 
Explains the lambda parameter. 
- explain(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaDF
-  
- explain(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaTTF
-  
- explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
-  
- explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-  
- explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMSimilarity
-  
- explain(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization
- 
Returns an explanation for the normalized term frequency. 
- explain(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
-  
- explain(int, Explanation) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
- 
Explain the score for a single document 
- explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Subclasses should implement this method to explain the score. 
- explain(BasicStats, int, Explanation, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Explains the score. 
- explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.spans.SpanWeight
-  
- explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.Weight
- 
An explanation of the score computation for the named document. 
- Explanation - Class in org.apache.lucene.search
- 
Expert: Describes the score computation for document and query. 
- Explanation() - Constructor for class org.apache.lucene.search.Explanation
-  
- Explanation(float, String) - Constructor for class org.apache.lucene.search.Explanation
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.BooleanQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.ConstantScoreQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.FilteredQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MatchAllDocsQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MultiPhraseQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.PhraseQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.Query
- 
Expert: adds all terms occurring in this query to the terms set. 
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanTermQuery
-  
- extractTerms(Set<Term>) - Method in class org.apache.lucene.search.TermQuery
-  
- failureReason - Variable in class org.apache.lucene.store.Lock
- 
If a lock obtain called, this failureReason may be set
 with the "root cause" Exception as to why the lock was
 not obtained. 
- FAST - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
- 
A compression mode that trades compression ratio for speed. 
- FAST - Static variable in class org.apache.lucene.util.packed.PackedInts
- 
At most 50% memory overhead, always select a reasonably fast implementation. 
- FAST_DECOMPRESSION - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
- 
This compression mode is similar to  CompressionMode.FAST but it spends more time
 compressing in order to improve the compression ratio. 
- fastClear(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
clears a bit. 
- fastClear(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
clears a bit. 
- FASTEST - Static variable in class org.apache.lucene.util.packed.PackedInts
- 
At most 700% memory overhead, always select a direct implementation. 
- fastestFormatAndBits(int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Try to find the  PackedInts.Format and number of bits per value that would
 restore from disk the fastest reader whose overhead is less than
  acceptableOverheadRatio. 
- fastFlip(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
flips a bit. 
- fastFlip(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
flips a bit. 
- fastGet(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns true or false for the specified bit index. 
- fastGet(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns true or false for the specified bit index. 
- fastSet(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
Sets the bit at the specified index. 
- fastSet(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Sets the bit at the specified index. 
- field - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Field name. 
- Field - Class in org.apache.lucene.document
- 
Expert: directly create a field for a document. 
- Field(String, FieldType) - Constructor for class org.apache.lucene.document.Field
- 
Expert: creates a field with no initial value. 
- Field(String, Reader, FieldType) - Constructor for class org.apache.lucene.document.Field
- 
Create field with Reader value. 
- Field(String, TokenStream, FieldType) - Constructor for class org.apache.lucene.document.Field
- 
Create field with TokenStream value. 
- Field(String, byte[], FieldType) - Constructor for class org.apache.lucene.document.Field
- 
Create field with binary value. 
- Field(String, byte[], int, int, FieldType) - Constructor for class org.apache.lucene.document.Field
- 
Create field with binary value. 
- Field(String, BytesRef, FieldType) - Constructor for class org.apache.lucene.document.Field
- 
Create field with binary value. 
- Field(String, String, FieldType) - Constructor for class org.apache.lucene.document.Field
- 
Create field with String value. 
- Field(String, String, Field.Store, Field.Index) - Constructor for class org.apache.lucene.document.Field
- 
- Field(String, String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
- 
- Field(String, Reader) - Constructor for class org.apache.lucene.document.Field
- 
- Field(String, Reader, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
- 
- Field(String, TokenStream) - Constructor for class org.apache.lucene.document.Field
- 
- Field(String, TokenStream, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
- 
- Field(String, byte[]) - Constructor for class org.apache.lucene.document.Field
- 
- Field(String, byte[], int, int) - Constructor for class org.apache.lucene.document.Field
- 
- field - Variable in class org.apache.lucene.index.DocTermOrds
- 
Field we are uninverting. 
- field() - Method in class org.apache.lucene.index.Term
- 
Returns the field of this term. 
- field() - Method in class org.apache.lucene.search.CollectionStatistics
- 
returns the field name 
- field - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
-  
- field() - Method in class org.apache.lucene.search.FieldValueFilter
- 
Returns the field this filter is applied on. 
- field - Variable in class org.apache.lucene.search.MultiTermQuery
-  
- field - Variable in class org.apache.lucene.search.spans.SpanNearQuery
-  
- Field.Index - Enum in org.apache.lucene.document
- 
Deprecated.
This is here only to ease transition from
  the pre-4.0 APIs. 
 
- Field.Store - Enum in org.apache.lucene.document
- 
Specifies whether and how a field should be stored. 
- Field.TermVector - Enum in org.apache.lucene.document
- 
Deprecated.
This is here only to ease transition from
  the pre-4.0 APIs. 
 
- FIELD_DOC - Static variable in class org.apache.lucene.search.SortField
- 
Represents sorting by document number (index order). 
- FIELD_SCORE - Static variable in class org.apache.lucene.search.SortField
- 
Represents sorting by document score (relevance). 
- FieldCache - Interface in org.apache.lucene.search
- 
Expert: Maintains caches of term values. 
- FieldCache.ByteParser - Interface in org.apache.lucene.search
- 
Deprecated. 
- FieldCache.Bytes - Class in org.apache.lucene.search
- 
Field values as 8-bit signed bytes 
- FieldCache.Bytes() - Constructor for class org.apache.lucene.search.FieldCache.Bytes
-  
- FieldCache.CacheEntry - Class in org.apache.lucene.search
- 
EXPERT: A unique Identifier/Description for each item in the FieldCache. 
- FieldCache.CacheEntry(Object, String, Class<?>, Object, Object) - Constructor for class org.apache.lucene.search.FieldCache.CacheEntry
-  
- FieldCache.CreationPlaceholder - Class in org.apache.lucene.search
- 
Placeholder indicating creation of this cache is currently in-progress. 
- FieldCache.CreationPlaceholder() - Constructor for class org.apache.lucene.search.FieldCache.CreationPlaceholder
-  
- FieldCache.DoubleParser - Interface in org.apache.lucene.search
- 
Interface to parse doubles from document fields. 
- FieldCache.Doubles - Class in org.apache.lucene.search
- 
Field values as 64-bit doubles 
- FieldCache.Doubles() - Constructor for class org.apache.lucene.search.FieldCache.Doubles
-  
- FieldCache.FloatParser - Interface in org.apache.lucene.search
- 
Interface to parse floats from document fields. 
- FieldCache.Floats - Class in org.apache.lucene.search
- 
Field values as 32-bit floats 
- FieldCache.Floats() - Constructor for class org.apache.lucene.search.FieldCache.Floats
-  
- FieldCache.IntParser - Interface in org.apache.lucene.search
- 
Interface to parse ints from document fields. 
- FieldCache.Ints - Class in org.apache.lucene.search
- 
Field values as 32-bit signed integers 
- FieldCache.Ints() - Constructor for class org.apache.lucene.search.FieldCache.Ints
-  
- FieldCache.LongParser - Interface in org.apache.lucene.search
- 
Interface to parse long from document fields. 
- FieldCache.Longs - Class in org.apache.lucene.search
- 
Field values as 64-bit signed long integers 
- FieldCache.Longs() - Constructor for class org.apache.lucene.search.FieldCache.Longs
-  
- FieldCache.Parser - Interface in org.apache.lucene.search
- 
Marker interface as super-interface to all parsers. 
- FieldCache.ShortParser - Interface in org.apache.lucene.search
- 
Deprecated. 
- FieldCache.Shorts - Class in org.apache.lucene.search
- 
Field values as 16-bit signed shorts 
- FieldCache.Shorts() - Constructor for class org.apache.lucene.search.FieldCache.Shorts
-  
- FieldCacheDocIdSet - Class in org.apache.lucene.search
- 
Base class for DocIdSet to be used with FieldCache. 
- FieldCacheDocIdSet(int, Bits) - Constructor for class org.apache.lucene.search.FieldCacheDocIdSet
-  
- FieldCacheRangeFilter<T> - Class in org.apache.lucene.search
- 
A range filter built on top of a cached single term field (in  FieldCache). 
- FieldCacheRewriteMethod - Class in org.apache.lucene.search
- 
Rewrites MultiTermQueries into a filter, using the FieldCache for term enumeration. 
- FieldCacheRewriteMethod() - Constructor for class org.apache.lucene.search.FieldCacheRewriteMethod
-  
- FieldCacheSanityChecker - Class in org.apache.lucene.util
- 
Provides methods for sanity checking that entries in the FieldCache 
 are not wasteful or inconsistent. 
- FieldCacheSanityChecker() - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker
-  
- FieldCacheSanityChecker.Insanity - Class in org.apache.lucene.util
- 
Simple container for a collection of related CacheEntry objects that 
 in conjunction with each other represent some "insane" usage of the 
 FieldCache. 
- FieldCacheSanityChecker.Insanity(FieldCacheSanityChecker.InsanityType, String, FieldCache.CacheEntry...) - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
-  
- FieldCacheSanityChecker.InsanityType - Class in org.apache.lucene.util
- 
An Enumeration of the different types of "insane" behavior that 
 may be detected in a FieldCache. 
- FieldCacheTermsFilter - Class in org.apache.lucene.search
- 
A  Filter that only accepts documents whose single
 term value in the specified field is contained in the
 provided set of allowed terms. 
- FieldCacheTermsFilter(String, BytesRef...) - Constructor for class org.apache.lucene.search.FieldCacheTermsFilter
-  
- FieldCacheTermsFilter(String, String...) - Constructor for class org.apache.lucene.search.FieldCacheTermsFilter
-  
- FieldComparator<T> - Class in org.apache.lucene.search
- 
Expert: a FieldComparator compares hits so as to determine their
 sort order when collecting the top results with  TopFieldCollector. 
- FieldComparator() - Constructor for class org.apache.lucene.search.FieldComparator
-  
- FieldComparator.ByteComparator - Class in org.apache.lucene.search
- 
Deprecated. 
- FieldComparator.DocComparator - Class in org.apache.lucene.search
- 
Sorts by ascending docID 
- FieldComparator.DoubleComparator - Class in org.apache.lucene.search
- 
- FieldComparator.FloatComparator - Class in org.apache.lucene.search
- 
- FieldComparator.IntComparator - Class in org.apache.lucene.search
- 
- FieldComparator.LongComparator - Class in org.apache.lucene.search
- 
- FieldComparator.NumericComparator<T extends Number> - Class in org.apache.lucene.search
- 
Base FieldComparator class for numeric types 
- FieldComparator.NumericComparator(String, T) - Constructor for class org.apache.lucene.search.FieldComparator.NumericComparator
-  
- FieldComparator.RelevanceComparator - Class in org.apache.lucene.search
- 
Sorts by descending relevance. 
- FieldComparator.ShortComparator - Class in org.apache.lucene.search
- 
Deprecated. 
- FieldComparator.TermOrdValComparator - Class in org.apache.lucene.search
- 
Sorts by field's natural Term sort order, using
  ordinals. 
- FieldComparator.TermOrdValComparator(int, String) - Constructor for class org.apache.lucene.search.FieldComparator.TermOrdValComparator
- 
Creates this, sorting missing values first. 
- FieldComparator.TermOrdValComparator(int, String, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.TermOrdValComparator
- 
Creates this, with control over how missing values
  are sorted. 
- FieldComparator.TermValComparator - Class in org.apache.lucene.search
- 
Sorts by field's natural Term sort order. 
- FieldComparatorSource - Class in org.apache.lucene.search
- 
- FieldComparatorSource() - Constructor for class org.apache.lucene.search.FieldComparatorSource
-  
- FieldDoc - Class in org.apache.lucene.search
- 
Expert: A ScoreDoc which also contains information about
 how to sort the referenced document. 
- FieldDoc(int, float) - Constructor for class org.apache.lucene.search.FieldDoc
- 
Expert: Creates one of these objects with empty sort information. 
- FieldDoc(int, float, Object[]) - Constructor for class org.apache.lucene.search.FieldDoc
- 
Expert: Creates one of these objects with the given sort information. 
- FieldDoc(int, float, Object[], int) - Constructor for class org.apache.lucene.search.FieldDoc
- 
Expert: Creates one of these objects with the given sort information. 
- FieldInfo - Class in org.apache.lucene.index
- 
Access to the Field Info file that describes document fields and whether or
  not they are indexed. 
- FieldInfo(String, boolean, int, boolean, boolean, boolean, FieldInfo.IndexOptions, FieldInfo.DocValuesType, FieldInfo.DocValuesType, Map<String, String>) - Constructor for class org.apache.lucene.index.FieldInfo
- 
Sole Constructor. 
- fieldInfo(String) - Method in class org.apache.lucene.index.FieldInfos
- 
Return the fieldinfo object referenced by the field name 
- fieldInfo(int) - Method in class org.apache.lucene.index.FieldInfos
- 
Return the fieldinfo object referenced by the fieldNumber. 
- FieldInfo.DocValuesType - Enum in org.apache.lucene.index
- 
DocValues types. 
- FieldInfo.IndexOptions - Enum in org.apache.lucene.index
- 
Controls how much information is stored in the postings lists. 
- FieldInfos - Class in org.apache.lucene.index
- 
Collection of  FieldInfos (accessible by number or by name). 
- FieldInfos(FieldInfo[]) - Constructor for class org.apache.lucene.index.FieldInfos
- 
Constructs a new FieldInfos from an array of FieldInfo objects 
- fieldInfos - Variable in class org.apache.lucene.index.MergeState
- 
- fieldInfos - Variable in class org.apache.lucene.index.SegmentReadState
- 
- fieldInfos - Variable in class org.apache.lucene.index.SegmentWriteState
- 
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.Codec
- 
Encodes/decodes field infos file 
- FieldInfosFormat - Class in org.apache.lucene.codecs
- 
- FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.FieldInfosFormat
- 
Sole constructor. 
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-  
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. 
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. 
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. 
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. 
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
-  
- FieldInfosReader - Class in org.apache.lucene.codecs
- 
- FieldInfosReader() - Constructor for class org.apache.lucene.codecs.FieldInfosReader
- 
Sole constructor. 
- FieldInfosWriter - Class in org.apache.lucene.codecs
- 
- FieldInfosWriter() - Constructor for class org.apache.lucene.codecs.FieldInfosWriter
- 
Sole constructor. 
- FieldInvertState - Class in org.apache.lucene.index
- 
This class tracks the number and position / offset parameters of terms
 being added to the index. 
- FieldInvertState(String) - Constructor for class org.apache.lucene.index.FieldInvertState
- 
Creates {code FieldInvertState} for the specified
  field name. 
- FieldInvertState(String, int, int, int, int, float) - Constructor for class org.apache.lucene.index.FieldInvertState
- 
Creates {code FieldInvertState} for the specified
  field name and values for all fields. 
- FieldMaskingSpanQuery - Class in org.apache.lucene.search.spans
- 
Wrapper to allow  SpanQuery objects participate in composite 
 single-field SpanQueries by 'lying' about their search field. 
- FieldMaskingSpanQuery(SpanQuery, String) - Constructor for class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- fieldName - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
-  
- fieldNormStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Status for testing of field norms (null if field norms could not be tested). 
- fields() - Method in class org.apache.lucene.index.AtomicReader
- 
Returns  Fields for this reader. 
- Fields - Class in org.apache.lucene.index
- 
Flex API for access to fields and terms 
- Fields() - Constructor for class org.apache.lucene.index.Fields
- 
Sole constructor. 
- fields() - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- fields() - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- fields() - Method in class org.apache.lucene.index.SegmentReader
-  
- fields() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- fields - Variable in class org.apache.lucene.search.FieldDoc
- 
Expert: The values which are used to sort the referenced document. 
- fields - Variable in class org.apache.lucene.search.FieldValueHitQueue
- 
Stores the sort criteria being used. 
- fields - Variable in class org.apache.lucene.search.TopFieldDocs
- 
The fields which were used to sort results by. 
- FIELDS_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
- 
Extension of stored fields file 
- FIELDS_INDEX_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
- 
Extension of stored fields index file 
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.DocValuesFormat
- 
- FieldsConsumer - Class in org.apache.lucene.codecs
- 
Abstract API that consumes terms, doc, freq, prox, offset and
 payloads postings. 
- FieldsConsumer() - Constructor for class org.apache.lucene.codecs.FieldsConsumer
- 
Sole constructor. 
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40DocValuesFormat
- 
Deprecated. 
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
- 
Deprecated. 
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
-  
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene42.Lucene42DocValuesFormat
- 
Deprecated. 
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesFormat
-  
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-  
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-  
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.PostingsFormat
- 
Writes a new segment 
- fieldsData - Variable in class org.apache.lucene.document.Field
- 
Field's value 
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.DocValuesFormat
- 
- FieldsProducer - Class in org.apache.lucene.codecs
- 
Abstract API that produces terms, doc, freq, prox, offset and
  payloads postings. 
- FieldsProducer() - Constructor for class org.apache.lucene.codecs.FieldsProducer
- 
Sole constructor. 
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40DocValuesFormat
- 
Deprecated. 
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
- 
Deprecated. 
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
-  
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene42.Lucene42DocValuesFormat
- 
Deprecated. 
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesFormat
-  
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-  
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-  
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.PostingsFormat
- 
Reads a segment. 
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-  
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsFormat
-  
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
- 
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-  
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsFormat
-  
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
- 
- fieldType() - Method in class org.apache.lucene.document.Field
- 
- FieldType - Class in org.apache.lucene.document
- 
Describes the properties of a field. 
- FieldType(FieldType) - Constructor for class org.apache.lucene.document.FieldType
- 
Create a new mutable FieldType with all of the properties from ref
 
- FieldType() - Constructor for class org.apache.lucene.document.FieldType
- 
Create a new FieldType with default properties. 
- fieldType() - Method in interface org.apache.lucene.index.IndexableField
- 
- FieldType.NumericType - Enum in org.apache.lucene.document
- 
Data type of the numeric value 
- FieldValueFilter - Class in org.apache.lucene.search
- 
A  Filter that accepts all documents that have one or more values in a
 given field. 
- FieldValueFilter(String) - Constructor for class org.apache.lucene.search.FieldValueFilter
- 
- FieldValueFilter(String, boolean) - Constructor for class org.apache.lucene.search.FieldValueFilter
- 
- FieldValueHitQueue<T extends FieldValueHitQueue.Entry> - Class in org.apache.lucene.search
- 
Expert: A hit queue for sorting by hits by terms in more than one field. 
- FieldValueHitQueue.Entry - Class in org.apache.lucene.search
- 
- FieldValueHitQueue.Entry(int, int, float) - Constructor for class org.apache.lucene.search.FieldValueHitQueue.Entry
-  
- file - Variable in class org.apache.lucene.store.FSDirectory.FSIndexInput
- 
the underlying RandomAccessFile 
- fileExists(String) - Method in class org.apache.lucene.store.CompoundFileDirectory
- 
Returns true iff a file with the given name exists. 
- fileExists(String) - Method in class org.apache.lucene.store.Directory
- 
Returns true iff a file with the given name exists. 
- fileExists(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-  
- fileExists(String) - Method in class org.apache.lucene.store.FilterDirectory
-  
- fileExists(String) - Method in class org.apache.lucene.store.FSDirectory
- 
Returns true iff a file with the given name exists. 
- fileExists(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- fileExists(String) - Method in class org.apache.lucene.store.RAMDirectory
- 
Returns true iff the named file exists in this directory. 
- fileLength(String) - Method in class org.apache.lucene.store.CompoundFileDirectory
- 
Returns the length of a file in the directory. 
- fileLength(String) - Method in class org.apache.lucene.store.Directory
- 
Returns the length of a file in the directory. 
- fileLength(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-  
- fileLength(String) - Method in class org.apache.lucene.store.FilterDirectory
-  
- fileLength(String) - Method in class org.apache.lucene.store.FSDirectory
- 
Returns the length in bytes of a file in the directory. 
- fileLength(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- fileLength(String) - Method in class org.apache.lucene.store.RAMDirectory
- 
Returns the length in bytes of a file in the directory. 
- fileMap - Variable in class org.apache.lucene.store.RAMDirectory
-  
- fileNameFromGeneration(String, String, long) - Static method in class org.apache.lucene.index.IndexFileNames
- 
Computes the full file name from base, extension and generation. 
- files(SegmentCommitInfo, Collection<String>) - Method in class org.apache.lucene.codecs.LiveDocsFormat
- 
- files(SegmentCommitInfo, Collection<String>) - Method in class org.apache.lucene.codecs.lucene40.Lucene40LiveDocsFormat
-  
- files() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns all files in use by this segment. 
- files() - Method in class org.apache.lucene.index.SegmentInfo
- 
Return all files referenced by this SegmentInfo. 
- files(Directory, boolean) - Method in class org.apache.lucene.index.SegmentInfos
- 
Returns all file names referenced by SegmentInfo
  instances matching the provided Directory (ie files
  associated with any "external" segments are skipped). 
- FileSwitchDirectory - Class in org.apache.lucene.store
- 
Expert: A Directory instance that switches files between
 two other Directory instances. 
- FileSwitchDirectory(Set<String>, Directory, Directory, boolean) - Constructor for class org.apache.lucene.store.FileSwitchDirectory
-  
- fill(int, int, long) - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- fill(int, int, long) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
- 
Fill the mutable from fromIndex(inclusive) totoIndex(exclusive) withval.
 
- fill(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
- 
Reads length as 1 or 2 byte vInt prefix, starting at start. 
- fillBasicStats(BasicStats, CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.LMSimilarity
- 
Computes the collection probability of the current term in addition to the
 usual statistics. 
- fillBasicStats(BasicStats, CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Fills all member fields defined in BasicStatsinstats.
 
- fillBytesRef() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- fillBytesRef() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- fillBytesRef() - Method in interface org.apache.lucene.analysis.tokenattributes.TermToBytesRefAttribute
- 
- fillSlice(BytesRef, long, int) - Method in class org.apache.lucene.util.PagedBytes.Reader
- 
Gets a slice out of  PagedBytes starting at  start with a
 given length. 
- filter - Variable in class org.apache.lucene.search.ConstantScoreQuery
-  
- Filter - Class in org.apache.lucene.search
- 
Abstract base class for restricting which documents may
  be returned during searching. 
- Filter() - Constructor for class org.apache.lucene.search.Filter
-  
- FilterAtomicReader - Class in org.apache.lucene.index
- 
A FilterAtomicReadercontains another AtomicReader, which it
 uses as its basic source of data, possibly transforming the data along the
 way or providing additional functionality.
 
- FilterAtomicReader(AtomicReader) - Constructor for class org.apache.lucene.index.FilterAtomicReader
- 
Construct a FilterAtomicReader based on the specified base reader. 
- FilterAtomicReader.FilterDocsAndPositionsEnum - Class in org.apache.lucene.index
- 
- FilterAtomicReader.FilterDocsAndPositionsEnum(DocsAndPositionsEnum) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
- 
Create a new FilterDocsAndPositionsEnum 
- FilterAtomicReader.FilterDocsEnum - Class in org.apache.lucene.index
- 
Base class for filtering  DocsEnum implementations. 
- FilterAtomicReader.FilterDocsEnum(DocsEnum) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
- 
Create a new FilterDocsEnum 
- FilterAtomicReader.FilterFields - Class in org.apache.lucene.index
- 
Base class for filtering  Fields
  implementations. 
- FilterAtomicReader.FilterFields(Fields) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterFields
- 
Creates a new FilterFields. 
- FilterAtomicReader.FilterTerms - Class in org.apache.lucene.index
- 
Base class for filtering  Terms implementations. 
- FilterAtomicReader.FilterTerms(Terms) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterTerms
- 
Creates a new FilterTerms 
- FilterAtomicReader.FilterTermsEnum - Class in org.apache.lucene.index
- 
Base class for filtering  TermsEnum implementations. 
- FilterAtomicReader.FilterTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
- 
Creates a new FilterTermsEnum 
- FilterCodec - Class in org.apache.lucene.codecs
- 
A codec that forwards all its method calls to another codec. 
- FilterCodec(String, Codec) - Constructor for class org.apache.lucene.codecs.FilterCodec
- 
Sole constructor. 
- FilterDirectory - Class in org.apache.lucene.store
- 
Directory implementation that delegates calls to another directory. 
- FilterDirectory(Directory) - Constructor for class org.apache.lucene.store.FilterDirectory
- 
Sole constructor, typically called from sub-classes. 
- FilterDirectoryReader - Class in org.apache.lucene.index
- 
A FilterDirectoryReader wraps another DirectoryReader, allowing implementations
 to transform or extend it. 
- FilterDirectoryReader(DirectoryReader) - Constructor for class org.apache.lucene.index.FilterDirectoryReader
- 
Create a new FilterDirectoryReader that filters a passed in DirectoryReader. 
- FilterDirectoryReader(DirectoryReader, FilterDirectoryReader.SubReaderWrapper) - Constructor for class org.apache.lucene.index.FilterDirectoryReader
- 
Create a new FilterDirectoryReader that filters a passed in DirectoryReader,
 using the supplied SubReaderWrapper to wrap its subreader. 
- FilterDirectoryReader.StandardReaderWrapper - Class in org.apache.lucene.index
- 
A no-op SubReaderWrapper that simply returns the parent
 DirectoryReader's original subreaders. 
- FilterDirectoryReader.StandardReaderWrapper() - Constructor for class org.apache.lucene.index.FilterDirectoryReader.StandardReaderWrapper
- 
Constructor 
- FilterDirectoryReader.SubReaderWrapper - Class in org.apache.lucene.index
- 
Factory class passed to FilterDirectoryReader constructor that allows
 subclasses to wrap the filtered DirectoryReader's subreaders. 
- FilterDirectoryReader.SubReaderWrapper() - Constructor for class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
- 
Constructor 
- FilteredDocIdSet - Class in org.apache.lucene.search
- 
Abstract decorator class for a DocIdSet implementation
 that provides on-demand filtering/validation
 mechanism on a given DocIdSet. 
- FilteredDocIdSet(DocIdSet) - Constructor for class org.apache.lucene.search.FilteredDocIdSet
- 
Constructor. 
- FilteredDocIdSetIterator - Class in org.apache.lucene.search
- 
Abstract decorator class of a DocIdSetIterator
 implementation that provides on-demand filter/validation
 mechanism on an underlying DocIdSetIterator. 
- FilteredDocIdSetIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.FilteredDocIdSetIterator
- 
Constructor. 
- FilteredQuery - Class in org.apache.lucene.search
- 
A query that applies a filter to the results of another query. 
- FilteredQuery(Query, Filter) - Constructor for class org.apache.lucene.search.FilteredQuery
- 
Constructs a new query which applies a filter to the results of the original query. 
- FilteredQuery(Query, Filter, FilteredQuery.FilterStrategy) - Constructor for class org.apache.lucene.search.FilteredQuery
- 
Expert: Constructs a new query which applies a filter to the results of the original query. 
- FilteredQuery.FilterStrategy - Class in org.apache.lucene.search
- 
Abstract class that defines how the filter ( DocIdSet) applied during document collection. 
- FilteredQuery.FilterStrategy() - Constructor for class org.apache.lucene.search.FilteredQuery.FilterStrategy
-  
- FilteredQuery.RandomAccessFilterStrategy - Class in org.apache.lucene.search
- 
- FilteredQuery.RandomAccessFilterStrategy() - Constructor for class org.apache.lucene.search.FilteredQuery.RandomAccessFilterStrategy
-  
- filteredScorer(AtomicReaderContext, boolean, boolean, Weight, DocIdSet) - Method in class org.apache.lucene.search.FilteredQuery.FilterStrategy
- 
Returns a filtered  Scorer based on this strategy. 
- filteredScorer(AtomicReaderContext, boolean, boolean, Weight, DocIdSet) - Method in class org.apache.lucene.search.FilteredQuery.RandomAccessFilterStrategy
-  
- FilteredTermsEnum - Class in org.apache.lucene.index
- 
Abstract class for enumerating a subset of all terms. 
- FilteredTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
- 
Creates a filtered  TermsEnum on a terms enum. 
- FilteredTermsEnum(TermsEnum, boolean) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
- 
Creates a filtered  TermsEnum on a terms enum. 
- FilteredTermsEnum.AcceptStatus - Enum in org.apache.lucene.index
- 
Return value, if term should be accepted or the iteration should
 END.
 
- FilterIterator<T> - Class in org.apache.lucene.util
- 
An  Iterator implementation that filters elements with a boolean predicate. 
- FilterIterator(Iterator<T>) - Constructor for class org.apache.lucene.util.FilterIterator
-  
- filterPrefixCodedInts(TermsEnum) - Static method in class org.apache.lucene.util.NumericUtils
- 
Filters the given  TermsEnum by accepting only prefix coded 32 bit
 terms with a shift value of  0. 
- filterPrefixCodedLongs(TermsEnum) - Static method in class org.apache.lucene.util.NumericUtils
- 
Filters the given  TermsEnum by accepting only prefix coded 64 bit
 terms with a shift value of  0. 
- find(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
- 
- find(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefHash
- 
Returns the id of the given  BytesRef with a pre-calculated hash code. 
- find(int) - Method in class org.apache.lucene.util.SentinelIntSet
- 
(internal) Returns the slot for this key, or -slot-1 if not found 
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
- 
Finds merges necessary to force-merge all deletes from the
 index. 
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
- 
Determine what set of merge operations is necessary in order to expunge all
 deletes from the index. 
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
-  
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
-  
- findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-  
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.LogMergePolicy
- 
Returns the merges necessary to merge the index down
  to a specified number of segments. 
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.MergePolicy
- 
Determine what set of merge operations is necessary in
 order to merge to <= the specified segment count. 
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.NoMergePolicy
-  
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.TieredMergePolicy
-  
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-  
- findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
- 
- findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
- 
Determine what set of merge operations are now necessary on the index. 
- findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
-  
- findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
-  
- findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-  
- findTargetArc(int, FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
- 
Finds an arc leaving the incoming arc, replacing the arc in place. 
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-  
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
-  
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
- 
- finish(long, long, int) - Method in class org.apache.lucene.codecs.TermsConsumer
- 
Called when we are done adding terms to this field. 
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
- finish() - Method in class org.apache.lucene.util.fst.Builder
- 
Returns final FST. 
- finish() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
- 
Perform end-of-stream operations. 
- finishCommit() - Method in class org.apache.lucene.store.ChecksumIndexOutput
- 
writes the checksum 
- finishDoc() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- finishDoc() - Method in class org.apache.lucene.codecs.PostingsConsumer
- 
Called when we are done adding positions & payloads
  for each doc. 
- finishDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-  
- finishDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- finishDocument() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- finishDocument() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
- 
Called when a document and all its fields have been added. 
- finishDocument() - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Called after a doc and all its fields have been added. 
- finishField() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- finishField() - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Called after a field and all its terms have been added. 
- finishTerm() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
- 
Called when we are done adding docs to this term 
- finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.PostingsWriterBase
- 
Finishes the current term. 
- finishTerm(BytesRef, TermStats) - Method in class org.apache.lucene.codecs.TermsConsumer
- 
Finishes the current term; numDocs must be > 0. 
- finishTerm() - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Called after a term and all its positions have been added. 
- finite - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
- 
Indicates if the automaton accepts a finite set of strings. 
- FIRST_LEVEL_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
- 
The first level size for new slices 
- firstComparator - Variable in class org.apache.lucene.search.FieldValueHitQueue
-  
- FixedBitSet - Class in org.apache.lucene.util
- 
- FixedBitSet(int) - Constructor for class org.apache.lucene.util.FixedBitSet
-  
- FixedBitSet(long[], int) - Constructor for class org.apache.lucene.util.FixedBitSet
-  
- FixedBitSet.FixedBitSetIterator - Class in org.apache.lucene.util
- 
- FixedBitSet.FixedBitSetIterator(FixedBitSet) - Constructor for class org.apache.lucene.util.FixedBitSet.FixedBitSetIterator
- 
- FixedBitSet.FixedBitSetIterator(long[], int, int) - Constructor for class org.apache.lucene.util.FixedBitSet.FixedBitSetIterator
- 
Creates an iterator over the given array of bits. 
- fixIndex(CheckIndex.Status) - Method in class org.apache.lucene.index.CheckIndex
- 
- FLAG_FREQS - Static variable in class org.apache.lucene.index.DocsEnum
- 
- FLAG_NONE - Static variable in class org.apache.lucene.index.DocsEnum
- 
- FLAG_OFFSETS - Static variable in class org.apache.lucene.index.DocsAndPositionsEnum
- 
- FLAG_PAYLOADS - Static variable in class org.apache.lucene.index.DocsAndPositionsEnum
- 
- FlagsAttribute - Interface in org.apache.lucene.analysis.tokenattributes
- 
This attribute can be used to pass different flags down the  Tokenizer chain,
 e.g. 
- FlagsAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
- 
- FlagsAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
- 
Initialize this attribute with no bits set 
- flip(int, int) - Method in class org.apache.lucene.util.FixedBitSet
- 
Flips a range of bits 
- flip(long, long) - Method in class org.apache.lucene.util.LongBitSet
- 
Flips a range of bits 
- flip(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
flips a bit, expanding the set size if necessary 
- flip(long, long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Flips a range of bits, expanding the set size if necessary 
- flipAndGet(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
flips a bit and returns the resulting bit value. 
- flipAndGet(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
flips a bit and returns the resulting bit value. 
- FloatDocValuesField - Class in org.apache.lucene.document
- 
- FloatDocValuesField(String, float) - Constructor for class org.apache.lucene.document.FloatDocValuesField
- 
Creates a new DocValues field with the specified 32-bit float value 
- floatField(FieldInfo, float) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-  
- FloatField - Class in org.apache.lucene.document
- 
 Field that indexes floatvalues
 for efficient range filtering and sorting.
 
- FloatField(String, float, Field.Store) - Constructor for class org.apache.lucene.document.FloatField
- 
- FloatField(String, float, FieldType) - Constructor for class org.apache.lucene.document.FloatField
- 
Expert: allows you to customize the  FieldType. 
- floatField(FieldInfo, float) - Method in class org.apache.lucene.index.StoredFieldVisitor
- 
Process a float numeric field. 
- floatToByte(float, int, int) - Static method in class org.apache.lucene.util.SmallFloat
- 
Converts a 32 bit float to an 8 bit float. 
- floatToByte315(float) - Static method in class org.apache.lucene.util.SmallFloat
- 
floatToByte(b, mantissaBits=3, zeroExponent=15)
 
 smallest non-zero value = 5.820766E-10
 largest value = 7.5161928E9
 epsilon = 0.125
 
- floatToByte52(float) - Static method in class org.apache.lucene.util.SmallFloat
- 
floatToByte(b, mantissaBits=5, zeroExponent=2)
 
 smallest nonzero value = 0.033203125
 largest value = 1984.0
 epsilon = 0.03125
 
- floatToEdits(float, int) - Static method in class org.apache.lucene.search.FuzzyQuery
- 
Deprecated.
pass integer edit distances instead. 
 
- floatToSortableInt(float) - Static method in class org.apache.lucene.util.NumericUtils
- 
Converts a floatvalue to a sortable signedint.
 
- floor(BytesRef, BytesRef) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
- 
Finds largest term accepted by this Automaton, that's
  <= the provided input term. 
- floorBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
The number of floor blocks (meta-blocks larger than the
  allowed maxItemsPerBlock) in the terms file.
 
- floorSubBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
The number of sub-blocks within the floor blocks. 
- flush(boolean, boolean) - Method in class org.apache.lucene.index.IndexWriter
- 
Flush all in-memory buffered updates (adds and deletes)
 to the Directory. 
- flush() - Method in class org.apache.lucene.store.BufferedIndexOutput
-  
- flush() - Method in class org.apache.lucene.store.ChecksumIndexOutput
-  
- flush() - Method in class org.apache.lucene.store.IndexOutput
- 
Forces any buffered output to be written. 
- flush() - Method in class org.apache.lucene.store.RAMOutputStream
-  
- flush() - Method in class org.apache.lucene.util.packed.BlockPackedWriter
-  
- flush() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
-  
- flush() - Method in class org.apache.lucene.util.packed.PackedDataOutput
- 
- flushBuffer(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
- 
Flushes the in-memory buffer to the given output, copying at most
 numBytes.
 
- flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexOutput
- 
Expert: implements buffer write. 
- flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
-  
- FlushInfo - Class in org.apache.lucene.store
- 
A FlushInfo provides information required for a FLUSH context. 
- FlushInfo(int, long) - Constructor for class org.apache.lucene.store.FlushInfo
- 
- flushInfo - Variable in class org.apache.lucene.store.IOContext
-  
- flushPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
FlushPolicyto control when segments are
  flushed.
 
- forceMerge(int) - Method in class org.apache.lucene.index.IndexWriter
- 
Forces merge policy to merge segments until there are <=
 maxNumSegments. 
- forceMerge(int, boolean) - Method in class org.apache.lucene.index.IndexWriter
- 
- forceMergeDeletes(boolean) - Method in class org.apache.lucene.index.IndexWriter
- 
- forceMergeDeletes() - Method in class org.apache.lucene.index.IndexWriter
- 
Forces merging of all segments that have deleted
  documents. 
- format - Variable in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
-  
- FORMAT_3_1 - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. Each segment records the Lucene version that created it. 
- FORMAT_DIAGNOSTICS - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. This format adds optional per-segment String
  diagnostics storage, and switches userData to Map 
- FORMAT_HAS_VECTORS - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. Each segment records whether it has term vectors 
- FORMAT_SEGMENTS_GEN_CURRENT - Static variable in class org.apache.lucene.index.SegmentInfos
- 
Used for the segments.gen file only!
 Whenever you add a new format, make it 1 smaller (negative version logic)! 
- forName(String) - Static method in class org.apache.lucene.codecs.Codec
- 
looks up a codec by name 
- forName(String) - Static method in class org.apache.lucene.codecs.DocValuesFormat
- 
looks up a format by name 
- forName(String) - Static method in class org.apache.lucene.codecs.PostingsFormat
- 
looks up a format by name 
- FREE_BSD - Static variable in class org.apache.lucene.util.Constants
- 
True iff running on FreeBSD 
- freeBefore(int) - Method in class org.apache.lucene.util.RollingBuffer
-  
- freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
- 
Removes the given number of byte blocks from the buffer if possible. 
- freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
- 
Removes the given number of int blocks from the buffer if possible. 
- freeze() - Method in class org.apache.lucene.document.FieldType
- 
Prevents future changes. 
- freeze(Builder.UnCompiledNode<T>[], int, IntsRef) - Method in class org.apache.lucene.util.fst.Builder.FreezeTail
-  
- freeze(boolean) - Method in class org.apache.lucene.util.PagedBytes
- 
Commits final byte[], trimming it if necessary and if trim=true 
- freq() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- freq() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
-  
- freq() - Method in class org.apache.lucene.index.DocsEnum
- 
- freq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- freq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
-  
- freq() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- freq() - Method in class org.apache.lucene.index.MultiDocsEnum
-  
- freq() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- freq() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- freq - Variable in class org.apache.lucene.search.spans.SpanScorer
-  
- freq() - Method in class org.apache.lucene.search.spans.SpanScorer
-  
- freq - Variable in class org.apache.lucene.search.spans.TermSpans
-  
- FSDirectory - Class in org.apache.lucene.store
- 
Base class for Directory implementations that store index
 files in the file system. 
- FSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.FSDirectory
- 
Create a new FSDirectory for the named location (ctor for subclasses). 
- FSDirectory.FSIndexInput - Class in org.apache.lucene.store
- 
Base class for reading input from a RandomAccessFile 
- FSDirectory.FSIndexInput(String, File, IOContext) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexInput
- 
Create a new FSIndexInput, reading the entire file from path
 
- FSDirectory.FSIndexInput(String, RandomAccessFile, long, long, int) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexInput
- 
Create a new FSIndexInput, representing a slice of an existing open file
 
- FSDirectory.FSIndexOutput - Class in org.apache.lucene.store
- 
- FSDirectory.FSIndexOutput(FSDirectory, String) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexOutput
-  
- FSLockFactory - Class in org.apache.lucene.store
- 
Base class for file system based locking implementation. 
- FSLockFactory() - Constructor for class org.apache.lucene.store.FSLockFactory
-  
- FST<T> - Class in org.apache.lucene.util.fst
- 
Represents an finite state machine (FST), using a
  compact byte[] format. 
- FST(DataInput, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.FST
- 
Load a previously saved FST. 
- FST(DataInput, Outputs<T>, int) - Constructor for class org.apache.lucene.util.fst.FST
- 
Load a previously saved FST; maxBlockBits allows you to
  control the size of the byte[] pages used to hold the FST bytes. 
- FST.Arc<T> - Class in org.apache.lucene.util.fst
- 
Represents a single arc. 
- FST.Arc() - Constructor for class org.apache.lucene.util.fst.FST.Arc
-  
- FST.BytesReader - Class in org.apache.lucene.util.fst
- 
Reads bytes stored in an FST. 
- FST.BytesReader() - Constructor for class org.apache.lucene.util.fst.FST.BytesReader
-  
- FST.INPUT_TYPE - Enum in org.apache.lucene.util.fst
- 
Specifies allowed range of each int input label for
  this FST. 
- fstSizeInBytes() - Method in class org.apache.lucene.util.fst.Builder
-  
- fsync(String) - Method in class org.apache.lucene.store.FSDirectory
-  
- function - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
-  
- function - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery
-  
- FuzzyQuery - Class in org.apache.lucene.search
- 
Implements the fuzzy search query. 
- FuzzyQuery(Term, int, int, int, boolean) - Constructor for class org.apache.lucene.search.FuzzyQuery
- 
Create a new FuzzyQuery that will match terms with an edit distance 
 of at most maxEditstoterm.
 
- FuzzyQuery(Term, int, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
- 
- FuzzyQuery(Term, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
- 
- FuzzyQuery(Term) - Constructor for class org.apache.lucene.search.FuzzyQuery
- 
- FuzzyTermsEnum - Class in org.apache.lucene.search
- 
Subclass of TermsEnum for enumerating all terms that are similar
 to the specified filter term. 
- FuzzyTermsEnum(Terms, AttributeSource, Term, float, int, boolean) - Constructor for class org.apache.lucene.search.FuzzyTermsEnum
- 
Constructor for enumeration of all terms from specified readerwhich share a prefix of
 lengthprefixLengthwithtermand which have a fuzzy similarity >minSimilarity.
 
- FuzzyTermsEnum.LevenshteinAutomataAttribute - Interface in org.apache.lucene.search
- 
reuses compiled automata across different segments,
 because they are independent of the index 
- FuzzyTermsEnum.LevenshteinAutomataAttributeImpl - Class in org.apache.lucene.search
- 
Stores compiled automata as a list (indexed by edit distance) 
- FuzzyTermsEnum.LevenshteinAutomataAttributeImpl() - Constructor for class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-  
- gcd(long, long) - Static method in class org.apache.lucene.util.MathUtil
- 
- GCD_COMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Compressed by computing the GCD. 
- GEN_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
- 
Extension of gen file 
- generationFromSegmentsFileName(String) - Static method in class org.apache.lucene.index.SegmentInfos
- 
Parse the generation off the segments file name and
 return it. 
- get(int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-  
- get(int) - Method in class org.apache.lucene.codecs.DocValuesProducer.SortedDocsWithField
-  
- get(int) - Method in class org.apache.lucene.codecs.DocValuesProducer.SortedSetDocsWithField
-  
- get(int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
-  
- get(int) - Method in class org.apache.lucene.codecs.TermVectorsReader
- 
Returns term vectors for this document, or null if
  term vectors were not indexed. 
- get(String) - Method in class org.apache.lucene.document.Document
- 
Returns the string value of the field with the given name if any exist in
 this document, or null. 
- get(int, BytesRef) - Method in class org.apache.lucene.index.BinaryDocValues
- 
Lookup the value for document. 
- get(int) - Method in class org.apache.lucene.index.MergeState.DocMap
- 
Returns the mapped docID corresponding to the provided one. 
- get(int) - Method in class org.apache.lucene.index.NumericDocValues
- 
Returns the numeric value for the specified document ID. 
- get(int, BytesRef) - Method in class org.apache.lucene.index.SortedDocValues
-  
- get(int) - Method in class org.apache.lucene.index.TermContext
- 
Returns the  TermState for an leaf ordinal or  null if no
  TermState for the ordinal was registered. 
- get() - Static method in class org.apache.lucene.LucenePackage
- 
Return Lucene's package, including version information. 
- get(int) - Method in class org.apache.lucene.search.FieldCache.Bytes
- 
Return a single Byte representation of this field's value. 
- get(int) - Method in class org.apache.lucene.search.FieldCache.Doubles
- 
Return an double representation of this field's value. 
- get(int) - Method in class org.apache.lucene.search.FieldCache.Floats
- 
Return an float representation of this field's value. 
- get(int) - Method in class org.apache.lucene.search.FieldCache.Ints
- 
Return an integer representation of this field's value. 
- get(int) - Method in class org.apache.lucene.search.FieldCache.Longs
- 
Return an long representation of this field's value. 
- get(int) - Method in class org.apache.lucene.search.FieldCache.Shorts
- 
Return a short representation of this field's value. 
- get(String) - Method in class org.apache.lucene.search.LiveFieldValues
- 
Returns the current value for this id, or null if the
  id isn't in the index or was deleted. 
- get(String) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
- 
- get(int) - Method in interface org.apache.lucene.util.Bits
- 
Returns the value of the bit with the specified index.
 
- get(int) - Method in class org.apache.lucene.util.Bits.MatchAllBits
-  
- get(int) - Method in class org.apache.lucene.util.Bits.MatchNoBits
-  
- get(int, BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
- 
Populates and returns a  BytesRef with the bytes for the given
 bytesID. 
- get() - Method in class org.apache.lucene.util.CloseableThreadLocal
-  
- get() - Method in class org.apache.lucene.util.Counter
- 
Returns the counters current value 
- get(int) - Method in class org.apache.lucene.util.DocIdBitSet
-  
- get(K) - Method in class org.apache.lucene.util.DoubleBarrelLRUCache
-  
- get(int) - Method in class org.apache.lucene.util.FixedBitSet
-  
- get(FST<T>, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
- 
Looks up the output for this input, or null if the
  input is not accepted. 
- get(FST<T>, BytesRef) - Static method in class org.apache.lucene.util.fst.Util
- 
Looks up the output for this input, or null if the
  input is not accepted 
- get(long) - Method in class org.apache.lucene.util.LongBitSet
-  
- get(long) - Method in class org.apache.lucene.util.LongValues
- 
Get value at index.
 
- get(int) - Method in class org.apache.lucene.util.LongValues
-  
- get(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns true or false for the specified bit index. 
- get(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns true or false for the specified bit index 
- get(long) - Method in class org.apache.lucene.util.packed.BlockPackedReader
-  
- get(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- get(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
-  
- get(int) - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-  
- get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-  
- get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.Reader
- 
Bulk get: read at least one and at most lenlongs starting
 fromindexintoarr[off:off+len]and return
 the actual number of values that have been read.
 
- get() - Method in class org.apache.lucene.util.RefCount
-  
- get(int) - Method in class org.apache.lucene.util.RollingBuffer
- 
Get T instance for this absolute position;
  this is allowed to be arbitrarily far "in the
  future" but cannot be before the last freeBefore. 
- get() - Method in class org.apache.lucene.util.SetOnce
- 
- get(Class<S>) - Static method in class org.apache.lucene.util.SPIClassIterator
-  
- get(Class<S>, ClassLoader) - Static method in class org.apache.lucene.util.SPIClassIterator
-  
- get(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
- 
Returns the value to which the specified key is mapped. 
- getAcceptStates() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns the set of reachable accept states. 
- getAddressInstance(IndexInput, FieldInfo, Lucene45DocValuesProducer.BinaryEntry) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
- 
returns an address instance for variable-length binary values. 
- getAfterEffect() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
- 
Returns the first normalization 
- getAnalyzer() - Method in class org.apache.lucene.index.IndexWriter
- 
Returns the analyzer used by this index. 
- getAnalyzer() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getAnalyzer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the default analyzer to use for indexing documents. 
- getAnalyzer() - Method in class org.apache.lucene.util.QueryBuilder
- 
Returns the analyzer. 
- getAndClear(int) - Method in class org.apache.lucene.util.FixedBitSet
-  
- getAndClear(long) - Method in class org.apache.lucene.util.LongBitSet
-  
- getAndIncrementGeneration() - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
Return and increment current gen. 
- getAndSet(int) - Method in class org.apache.lucene.util.FixedBitSet
-  
- getAndSet(long) - Method in class org.apache.lucene.util.LongBitSet
-  
- getAndSet(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
Sets a bit and returns the previous value. 
- getAndSet(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Sets a bit and returns the previous value. 
- getArcCount() - Method in class org.apache.lucene.util.fst.FST
-  
- getArcWithOutputCount() - Method in class org.apache.lucene.util.fst.FST
-  
- getArray() - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- getArray() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
- 
Expert: if the bit-width of this reader matches one of
 java's native types, returns the underlying array
 (ie, byte[], short[], int[], long[]); else, returns
 null. 
- getAttribute(String) - Method in class org.apache.lucene.index.FieldInfo
- 
Get a codec attribute value, or null if it does not exist 
- getAttribute(String) - Method in class org.apache.lucene.index.SegmentInfo
- 
Deprecated.
no longer supported 
 
- getAttribute(Class<T>) - Method in class org.apache.lucene.util.AttributeSource
- 
The caller must pass in a Class<? extends Attribute> value. 
- getAttributeClassesIterator() - Method in class org.apache.lucene.util.AttributeSource
- 
Returns a new iterator that iterates the attribute classes
 in the same order they were added in. 
- getAttributeFactory() - Method in class org.apache.lucene.util.AttributeSource
- 
returns the used AttributeFactory. 
- getAttributeImplsIterator() - Method in class org.apache.lucene.util.AttributeSource
- 
Returns a new iterator that iterates all unique Attribute implementations. 
- getAttributeSource() - Method in class org.apache.lucene.index.FieldInvertState
- 
- getAutomaton() - Method in class org.apache.lucene.search.AutomatonQuery
- 
Returns the automaton used to create this query 
- getAutomaton(String) - Method in interface org.apache.lucene.util.automaton.AutomatonProvider
- 
Returns automaton of the given name. 
- getAutomatonEnum(int, BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
- 
return an automata-based enum for matching up to editDistance from
 lastTerm, if possible 
- getAvgFieldLength() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Returns the average field length. 
- getB() - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Returns the bparameter
 
- getBasicModel() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
- 
Returns the basic model of information content 
- getBinary(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
- 
- getBinary(FieldInfo) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
-  
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.AtomicReader
- 
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.SegmentReader
-  
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getBinaryValue(String) - Method in class org.apache.lucene.document.Document
- 
Returns an array of bytes for the first (or only) field that has the name
 specified as the method parameter. 
- getBinaryValues(String) - Method in class org.apache.lucene.document.Document
- 
Returns an array of byte arrays for of the fields that have the name specified
 as the method parameter. 
- getBinaryValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
- 
Returns a BinaryDocValues for a reader's docvalues (potentially merging on-the-fly) 
- getBit(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
returns 1 if the bit is set, 0 if not. 
- getBits() - Method in class org.apache.lucene.util.FixedBitSet
- 
Expert. 
- getBits() - Method in class org.apache.lucene.util.LongBitSet
- 
Expert. 
- getBits() - Method in class org.apache.lucene.util.OpenBitSet
- 
Expert: returns the long[] storing the bits 
- getBitSet() - Method in class org.apache.lucene.util.DocIdBitSet
- 
Returns the underlying BitSet. 
- getBitsPerValue() - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-  
- getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
-  
- getBitsPerValue() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
- 
Returns number of bits per value 
- getBoost() - Method in class org.apache.lucene.index.FieldInvertState
- 
Get boost value. 
- getBoost() - Method in interface org.apache.lucene.search.BoostAttribute
- 
Retrieves the boost, default is 1.0f.
 
- getBoost() - Method in class org.apache.lucene.search.BoostAttributeImpl
-  
- getBoost() - Method in class org.apache.lucene.search.Query
- 
Gets the boost for this clause. 
- getBuffer(int) - Method in class org.apache.lucene.store.RAMFile
-  
- getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexInput
- 
Returns buffer size. 
- getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexOutput
- 
Returns size of the used output buffer in bytes. 
- getByOutput(FST<Long>, long) - Static method in class org.apache.lucene.util.fst.Util
- 
Reverse lookup (lookup by output instead of by input),
  in the special case when your FSTs outputs are
  strictly ascending. 
- getByOutput(FST<Long>, long, FST.BytesReader, FST.Arc<Long>, FST.Arc<Long>, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
- 
- getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
-  
- getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-  
- getByteBlock() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-  
- getBytes(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getBytes(AtomicReader, String, FieldCache.ByteParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getBytesComparator() - Method in class org.apache.lucene.search.SortField
-  
- getBytesReader() - Method in class org.apache.lucene.util.fst.FST
- 
- getBytesRef() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- getBytesRef() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- getBytesRef() - Method in interface org.apache.lucene.analysis.tokenattributes.TermToBytesRefAttribute
- 
Retrieve this attribute's BytesRef. 
- getC() - Method in class org.apache.lucene.search.similarities.NormalizationH1
- 
Returns the cparameter.
 
- getC() - Method in class org.apache.lucene.search.similarities.NormalizationH2
- 
Returns the cparameter.
 
- getCacheEntries() - Method in interface org.apache.lucene.search.FieldCache
- 
EXPERT: Generates an array of CacheEntry objects representing all items 
 currently in the FieldCache. 
- getCacheEntries() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
- 
CacheEntry objects which suggest a problem 
- getCacheType() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-  
- getCalibrateSizeByDeletes() - Method in class org.apache.lucene.index.LogMergePolicy
- 
Returns true if the segment size should be calibrated 
  by the number of deletes when choosing segments for merge. 
- getCharIntervals() - Method in class org.apache.lucene.util.automaton.RunAutomaton
- 
Returns array of codepoint class interval start points. 
- getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexInput
-  
- getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexOutput
-  
- getChildren() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- getChildren() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- getChildren() - Method in class org.apache.lucene.search.Scorer
- 
Returns child sub-scorers 
- getClauses() - Method in class org.apache.lucene.search.BooleanQuery
- 
Returns the set of clauses in this query. 
- getClauses() - Method in class org.apache.lucene.search.spans.SpanNearQuery
- 
Return the clauses whose spans are matched. 
- getClauses() - Method in class org.apache.lucene.search.spans.SpanOrQuery
- 
Return the clauses whose spans are matched. 
- getCodec() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getCodec() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the current  Codec. 
- getCodec() - Method in class org.apache.lucene.index.SegmentInfo
- 
Return  Codec that wrote this segment. 
- getCollectionProbability() - Method in class org.apache.lucene.search.similarities.LMSimilarity.LMStats
- 
Returns the probability that the current term is generated by the
 collection. 
- getCombinedCoreAndDeletesKey() - Method in class org.apache.lucene.index.IndexReader
- 
Expert: Returns a key for this IndexReader that also includes deletions,
 so FieldCache/CachingWrapperFilter can find it again. 
- getCombinedCoreAndDeletesKey() - Method in class org.apache.lucene.index.SegmentReader
-  
- getCombinedCoreAndDeletesKey() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getCommitData() - Method in class org.apache.lucene.index.IndexWriter
- 
- getCommonPrefix(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
- 
Returns the longest string that is a prefix of all accepted strings and
 visits each state at most once. 
- getCommonPrefixBytesRef(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
-  
- getCommonSuffix(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
- 
Returns the longest string that is a suffix of all accepted strings and
 visits each state at most once. 
- getCommonSuffixBytesRef(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
-  
- getComparator() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
-  
- getComparator() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- getComparator() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- getComparator() - Method in class org.apache.lucene.codecs.TermsConsumer
- 
Return the BytesRef Comparator used to sort terms
  before feeding to this API. 
- getComparator() - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Return the BytesRef Comparator used to sort terms
  before feeding to this API. 
- getComparator() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
-  
- getComparator() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- getComparator() - Method in class org.apache.lucene.index.FilteredTermsEnum
-  
- getComparator() - Method in class org.apache.lucene.index.MultiTerms
-  
- getComparator() - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- getComparator() - Method in class org.apache.lucene.index.Terms
- 
Return the BytesRef Comparator used to sort terms
  provided by the iterator. 
- getComparator() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- getComparator(int, int) - Method in class org.apache.lucene.search.SortField
- 
- getComparator() - Method in interface org.apache.lucene.util.BytesRefIterator
- 
Return the  BytesRef Comparator used to sort terms provided by the
 iterator. 
- getComparators() - Method in class org.apache.lucene.search.FieldValueHitQueue
-  
- getComparatorSource() - Method in class org.apache.lucene.search.SortField
- 
- getCompetitiveTerm() - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
- 
This is the term or nullof the term that triggered the boost change.
 
- getCompetitiveTerm() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-  
- getConfig() - Method in class org.apache.lucene.index.IndexWriter
- 
Returns a  LiveIndexWriterConfig, which can be used to query the IndexWriter
 current settings, as well as modify "live" ones. 
- getContext() - Method in class org.apache.lucene.index.AtomicReader
-  
- getContext() - Method in class org.apache.lucene.index.CompositeReader
-  
- getContext() - Method in class org.apache.lucene.index.IndexReader
- 
- getCoreCacheKey() - Method in class org.apache.lucene.index.IndexReader
- 
Expert: Returns a key for this IndexReader, so FieldCache/CachingWrapperFilter can find
 it again. 
- getCoreCacheKey() - Method in class org.apache.lucene.index.SegmentReader
-  
- getCoreCacheKey() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getCreatedFiles() - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-  
- getCrossCheckTermVectors() - Method in class org.apache.lucene.index.CheckIndex
- 
- getCurrentLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-  
- getCurrentLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-  
- getCurrentMerge() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- 
Return the current merge, or null if this MergeThreadis done.
 
- getCurrentOffset() - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
- 
Returns the offset of the currently written slice. 
- getCustom() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-  
- getDataInput() - Method in class org.apache.lucene.util.PagedBytes
- 
Returns a DataInput to read values from this
  PagedBytes instance. 
- getDataOutput() - Method in class org.apache.lucene.util.PagedBytes
- 
Returns a DataOutput that you may use to write into
  this PagedBytes instance. 
- getDecodedLength(char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
- 
Deprecated. Returns the number of bytes required to decode the given char sequence. 
- getDecoder() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
- 
- getDecoder(PackedInts.Format, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getDecodingReader(InputStream, Charset) - Static method in class org.apache.lucene.util.IOUtils
- 
- getDecodingReader(File, Charset) - Static method in class org.apache.lucene.util.IOUtils
- 
- getDecodingReader(Class<?>, String, Charset) - Static method in class org.apache.lucene.util.IOUtils
- 
- getDefault() - Static method in class org.apache.lucene.codecs.Codec
- 
- getDefault() - Static method in class org.apache.lucene.util.InfoStream
- 
The default InfoStreamused by a newly instantiated classes.
 
- getDefaultGenLookahedCount() - Static method in class org.apache.lucene.index.SegmentInfos
- 
Returns the defaultGenLookaheadCount.
 
- getDefaultSimilarity() - Static method in class org.apache.lucene.search.IndexSearcher
- 
Expert: returns a default Similarity instance. 
- getDefaultWriteLockTimeout() - Static method in class org.apache.lucene.index.IndexWriterConfig
- 
Returns the default write lock timeout for newly instantiated
 IndexWriterConfigs. 
- getDelCount() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns the number of deleted docs in the segment. 
- getDelegate() - Method in class org.apache.lucene.store.FilterDirectory
- 
- getDelegate() - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- getDelGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns generation number of the live docs file 
 or -1 if there are no deletes yet. 
- getDescription() - Method in class org.apache.lucene.search.Explanation
- 
A description of this explanation node. 
- getDest() - Method in class org.apache.lucene.util.automaton.Transition
- 
Returns destination of this transition. 
- getDetails() - Method in class org.apache.lucene.search.Explanation
- 
The sub-nodes of this explanation node. 
- getDiagnostics() - Method in class org.apache.lucene.index.SegmentInfo
- 
Returns diagnostics saved into the segment when it was
  written. 
- getDirectory() - Method in class org.apache.lucene.index.IndexCommit
- 
- getDirectory() - Method in class org.apache.lucene.index.IndexWriter
- 
Returns the Directory used by this index. 
- getDirectory() - Method in exception org.apache.lucene.index.MergePolicy.MergeException
- 
Returns the  Directory of the index that hit
  the exception. 
- getDirectory() - Method in class org.apache.lucene.store.CompoundFileDirectory
-  
- getDirectory() - Method in class org.apache.lucene.store.FSDirectory
-  
- getDirectReader(IndexInput) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getDirectReaderNoHeader(IndexInput, PackedInts.Format, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Expert: Construct a direct  PackedInts.Reader from a stream without reading
 metadata at the beginning of the stream. 
- getDirectReaderNoHeader(IndexInput, PackedInts.Header) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getDiscountOverlaps() - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Returns true if overlap tokens are discounted from the document's length. 
- getDiscountOverlaps() - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Returns true if overlap tokens are discounted from the document's length. 
- getDiscountOverlaps() - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Returns true if overlap tokens are discounted from the document's length. 
- getDisjuncts() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-  
- getDistribution() - Method in class org.apache.lucene.search.similarities.IBSimilarity
- 
Returns the distribution 
- getDoc() - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
- getDocCount() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
-  
- getDocCount(String) - Method in class org.apache.lucene.index.AtomicReader
-  
- getDocCount(String) - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- getDocCount() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
-  
- getDocCount(String) - Method in class org.apache.lucene.index.IndexReader
- 
Returns the number of documents that have at least one term for this field,
 or -1 if this measure isn't stored by the codec. 
- getDocCount() - Method in class org.apache.lucene.index.MultiTerms
-  
- getDocCount() - Method in class org.apache.lucene.index.SegmentInfo
- 
Returns number of documents in this segment (deletions
  are not taken into account). 
- getDocCount() - Method in class org.apache.lucene.index.Terms
- 
Returns the number of documents that have at least one
  term for this field, or -1 if this measure isn't
  stored by the codec. 
- getDocFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Returns the document frequency. 
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.CachingWrapperFilter
-  
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
- 
This method is implemented for each data type 
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
This method is implemented for each data type 
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.FieldCacheTermsFilter
-  
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.FieldValueFilter
-  
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.Filter
- 
Creates a  DocIdSet enumerating the documents that should be
 permitted in search results. 
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
- 
Returns a DocIdSet with documents that should be permitted in search
 results. 
- getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.QueryWrapperFilter
-  
- getDocMap(MergeState) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Expert: If  MergePolicy.OneMerge.getMergeReaders() reorders document IDs, this method
  must be overridden to return a mapping from the  natural doc ID
  (the doc ID that would result from a natural merge) to the actual doc
  ID. 
- getDocStoreFiles(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. Returns file names for shared doc stores, if any, else
 null. 
- getDocStoreIsCompoundFile(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- getDocStoreOffset(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- getDocStoreSegment(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- getDocsWithField(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
- 
Returns a  Bits at the size of  reader.maxDoc(), 
  with turned on bits for each docid that does have a value for this field. 
- getDocsWithField(FieldInfo) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
-  
- getDocsWithField(String) - Method in class org.apache.lucene.index.AtomicReader
- 
Returns a  Bits at the size of  reader.maxDoc(), 
  with turned on bits for each docid that does have a value for this field,
  or null if no DocValues were indexed for this field. 
- getDocsWithField(String) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getDocsWithField(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
- 
Returns a Bits for a reader's docsWithField (potentially merging on-the-fly) 
- getDocsWithField(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getDocsWithField(String) - Method in class org.apache.lucene.index.SegmentReader
-  
- getDocsWithField(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getDocsWithField(AtomicReader, String) - Method in interface org.apache.lucene.search.FieldCache
- 
Checks the internal cache for an appropriate entry, and if none is found,
  reads the terms in fieldand returns a bit set at the size ofreader.maxDoc(), with turned on bits for each docid that 
  does have a value for this field.
 
- getDocTermOrds(AtomicReader, String) - Method in interface org.apache.lucene.search.FieldCache
- 
Checks the internal cache for an appropriate entry, and if none is found, reads the term values
 in  field and returns a  DocTermOrds instance, providing a method to retrieve
 the terms (as ords) per document. 
- getDocument() - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
- 
Retrieve the visited document. 
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. Returns the docvalues format that should be used for writing 
  new segments of field.
 
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. Returns the docvalues format that should be used for writing 
  new segments of field.
 
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
- 
Returns the docvalues format that should be used for writing 
  new segments of field.
 
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
- 
Returns the doc values format that should be used for writing 
 new segments of field.
 
- getDocValuesGen() - Method in class org.apache.lucene.index.FieldInfo
- 
Returns the docValues generation of this field, or -1 if no docValues
 updates exist for it. 
- getDocValuesType() - Method in class org.apache.lucene.index.FieldInfo
- 
- getDoubles(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getDoubles(AtomicReader, String, FieldCache.DoubleParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getEliasFanoEncoder() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
-  
- getEmptyOutput() - Method in class org.apache.lucene.util.fst.FST
-  
- getEnablePositionIncrements() - Method in class org.apache.lucene.util.QueryBuilder
- 
Returns true if position increments are enabled. 
- getEncodedLength(byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
- 
Deprecated. Returns the number of chars required to encode the given bytes. 
- getEncoder(PackedInts.Format, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getEnd() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-  
- getEstimatedSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
- 
The most recently estimated size of the value, null unless 
 estimateSize has been called. 
- getExclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
- 
Return the SpanQuery whose matches must not overlap those returned. 
- getExtension(String) - Static method in class org.apache.lucene.store.FileSwitchDirectory
- 
Utility method to return a file's extension. 
- getField(String) - Method in class org.apache.lucene.document.Document
- 
Returns a field with the given name if any exist in this document, or
 null. 
- getField() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
- 
Returns the field name for this filter 
- getField() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Returns the field name for this filter 
- getField() - Method in class org.apache.lucene.search.MultiTermQuery
- 
Returns the field name for this query 
- getField() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
- 
Returns the field name for this query 
- getField() - Method in class org.apache.lucene.search.SortField
- 
Returns the name of the field. 
- getField() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- getField() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-  
- getField() - Method in class org.apache.lucene.search.spans.SpanNearQuery
-  
- getField() - Method in class org.apache.lucene.search.spans.SpanNotQuery
-  
- getField() - Method in class org.apache.lucene.search.spans.SpanOrQuery
-  
- getField() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-  
- getField() - Method in class org.apache.lucene.search.spans.SpanQuery
- 
Returns the name of the field matched by this query. 
- getField() - Method in class org.apache.lucene.search.spans.SpanTermQuery
-  
- getFieldCache() - Method in class org.apache.lucene.search.FieldCacheTermsFilter
-  
- getFieldInfos() - Method in class org.apache.lucene.index.AtomicReader
- 
Get the  FieldInfos describing all fields in
 this reader. 
- getFieldInfos() - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getFieldInfos() - Method in class org.apache.lucene.index.ParallelAtomicReader
- 
Get the  FieldInfos describing all fields in
 this reader. 
- getFieldInfos() - Method in class org.apache.lucene.index.SegmentReader
-  
- getFieldInfos() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getFieldInfosGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns the generation number of the field infos file or -1 if there are no
 field updates yet. 
- getFieldInfosReader() - Method in class org.apache.lucene.codecs.FieldInfosFormat
- 
- getFieldInfosReader() - Method in class org.apache.lucene.codecs.lucene40.Lucene40FieldInfosFormat
- 
Deprecated. 
- getFieldInfosReader() - Method in class org.apache.lucene.codecs.lucene42.Lucene42FieldInfosFormat
- 
Deprecated. 
- getFieldInfosReader() - Method in class org.apache.lucene.codecs.lucene46.Lucene46FieldInfosFormat
-  
- getFieldInfosWriter() - Method in class org.apache.lucene.codecs.FieldInfosFormat
- 
- getFieldInfosWriter() - Method in class org.apache.lucene.codecs.lucene40.Lucene40FieldInfosFormat
- 
Deprecated. 
- getFieldInfosWriter() - Method in class org.apache.lucene.codecs.lucene42.Lucene42FieldInfosFormat
- 
Deprecated. 
- getFieldInfosWriter() - Method in class org.apache.lucene.codecs.lucene46.Lucene46FieldInfosFormat
-  
- getFieldName() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-  
- getFields(String) - Method in class org.apache.lucene.document.Document
- 
- getFields() - Method in class org.apache.lucene.document.Document
- 
Returns a List of all the fields in a document. 
- getFields(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
- 
Returns a single  Fields instance for this
  reader, merging fields/terms/docs/positions on the
  fly. 
- getFieldsReader() - Method in class org.apache.lucene.index.SegmentReader
- 
- getFileNames() - Method in class org.apache.lucene.index.IndexCommit
- 
Returns all index files referenced by this commit point. 
- getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexOutput
-  
- getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexInput
-  
- getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexOutput
-  
- getFilePointer() - Method in class org.apache.lucene.store.IndexInput
- 
Returns the current position in this file, where the next read will
 occur. 
- getFilePointer() - Method in class org.apache.lucene.store.IndexOutput
- 
Returns the current position in this file, where the next write will
 occur. 
- getFilePointer() - Method in class org.apache.lucene.store.RAMInputStream
-  
- getFilePointer() - Method in class org.apache.lucene.store.RAMOutputStream
-  
- getFilter() - Method in class org.apache.lucene.search.CachingWrapperFilter
- 
Gets the contained filter. 
- getFilter() - Method in class org.apache.lucene.search.ConstantScoreQuery
- 
Returns the encapsulated filter, returns nullif a query is wrapped.
 
- getFilter() - Method in class org.apache.lucene.search.FilteredQuery
- 
Returns this FilteredQuery's filter 
- getFilterStrategy() - Method in class org.apache.lucene.search.FilteredQuery
- 
- getFiniteStrings(Automaton, int) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
- 
Returns the set of accepted strings, assuming that at most
 limitstrings are accepted.
 
- getFirstArc(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST
- 
Fills virtual 'start' arc, ie, an empty incoming arc to
  the FST's start node 
- getFirstSegmentNumber(long) - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
- 
Given a global ordinal, returns the index of the first
 segment that contains this term. 
- getFirstSegmentOrd(long) - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
- 
- getFirstState() - Method in class org.apache.lucene.util.automaton.StatePair
- 
Returns first component of this pair. 
- getFlags() - Method in class org.apache.lucene.analysis.Token
- 
Get the bitset for any bits that have been set. 
- getFlags() - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute
- 
Get the bitset for any bits that have been set. 
- getFlags() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-  
- getFloats(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getFloats(AtomicReader, String, FieldCache.FloatParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getFloorSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Returns the current floorSegmentMB. 
- getForceMergeDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Returns the current forceMergeDeletesPctAllowed setting. 
- getFormat() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
- 
The format used to serialize values. 
- getFreqPointer() - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. 
- getGeneration() - Method in class org.apache.lucene.index.IndexCommit
- 
Returns the generation (the _N in segments_N) for this
  IndexCommit 
- getGeneration() - Method in class org.apache.lucene.index.SegmentInfos
- 
Returns current generation. 
- getGeneration() - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
Return the current generation being indexed. 
- getGlobalCounter() - Static method in class org.apache.lucene.search.TimeLimitingCollector
- 
Returns the global TimerThreads  Counter
- getGlobalOrd(int, long) - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
- 
Given a segment number and segment ordinal, returns
 the corresponding global ordinal. 
- getGlobalTimerThread() - Static method in class org.apache.lucene.search.TimeLimitingCollector
- 
- getHeapArray() - Method in class org.apache.lucene.util.PriorityQueue
- 
This method returns the internal heap array as Object[]. 
- getId() - Method in enum org.apache.lucene.util.packed.PackedInts.Format
- 
Returns the ID of the format. 
- getIdentifiers() - Method in class org.apache.lucene.util.automaton.RegExp
- 
Returns set of automaton identifiers that occur in this regular expression. 
- getImplementationDistance(Class<? extends C>) - Method in class org.apache.lucene.util.VirtualMethod
- 
Returns the distance from the baseClassin which this method is overridden/implemented
 in the inheritance path betweenbaseClassand the given subclasssubclazz.
 
- getInclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
- 
Return the SpanQuery whose matches are filtered. 
- getIndexBits() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
- 
Expert. 
- getIndexCommit() - Method in class org.apache.lucene.index.DirectoryReader
- 
Expert: return the IndexCommit that this reader has opened. 
- getIndexCommit() - Method in class org.apache.lucene.index.FilterDirectoryReader
-  
- getIndexCommit() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getIndexCommit() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getIndexCommit(long) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Retrieve an  IndexCommit from its generation;
  returns null if this IndexCommit is not currently
  snapshotted 
- getIndexDeletionPolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getIndexDeletionPolicy() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getIndexedFields(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
- 
Call this to get the (merged) FieldInfos representing the
  set of indexed fields only for a composite reader. 
- getIndexOptions() - Method in class org.apache.lucene.index.FieldInfo
- 
Returns IndexOptions for the field, or null if the field is not indexed 
- getIndexReader() - Method in class org.apache.lucene.search.IndexSearcher
- 
- getIndexWriter() - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- getInfo() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns extra information associated with this automaton. 
- getInfoStream() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getInfoStream() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getInfoStream() - Static method in class org.apache.lucene.index.SegmentInfos
- 
Returns infoStream.
 
- getInfoStream() - Method in interface org.apache.lucene.search.FieldCache
- 
- getInitialState() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Gets initial state. 
- getInitialState() - Method in class org.apache.lucene.util.automaton.RunAutomaton
- 
Returns initial state. 
- getInputType() - Method in class org.apache.lucene.util.fst.FST
-  
- getIntBlock() - Method in class org.apache.lucene.util.IntBlockPool.Allocator
-  
- getIntBlock() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-  
- getIntervalInstance(IndexInput, FieldInfo, Lucene45DocValuesProducer.BinaryEntry) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
- 
returns an address instance for prefix-compressed binary values. 
- getInts(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
Returns an  FieldCache.Ints over the values found in documents in the given
 field. 
- getInts(AtomicReader, String, FieldCache.IntParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
Returns an  FieldCache.Ints over the values found in documents in the given
 field. 
- getK1() - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Returns the k1parameter
 
- getLambda() - Method in class org.apache.lucene.search.similarities.IBSimilarity
- 
Returns the distribution's lambda parameter 
- getLambda() - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
- 
Returns the λ parameter. 
- getLastCommitGeneration(String[]) - Static method in class org.apache.lucene.index.SegmentInfos
- 
Get the generation of the most recent commit to the
 list of index files (N in the segments_N file). 
- getLastCommitGeneration(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
- 
Get the generation of the most recent commit to the
 index in this directory (N in the segments_N file). 
- getLastCommitSegmentsFileName(String[]) - Static method in class org.apache.lucene.index.SegmentInfos
- 
Get the filename of the segments_N file for the most
 recent commit in the list of index files. 
- getLastCommitSegmentsFileName(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
- 
Get the filename of the segments_N file for the most
 recent commit to the index in this Directory. 
- getLastDocCollected() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
- 
Returns last doc (absolute doc id) that was collected when the search time exceeded. 
- getLastGeneration() - Method in class org.apache.lucene.index.SegmentInfos
- 
Returns last succesfully read or written generation. 
- getLastOutput(int) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- getLastSaveFile() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
- 
Returns the file name the snapshots are currently
  saved to, or null if no snapshots have been saved. 
- getLength() - Method in class org.apache.lucene.index.FieldInvertState
- 
Get total number of terms in this field. 
- getLength() - Method in class org.apache.lucene.store.RAMFile
-  
- getLiveDocs() - Method in class org.apache.lucene.index.AtomicReader
- 
Returns the  Bits representing live (not
  deleted) docs. 
- getLiveDocs() - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getLiveDocs(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
- 
Returns a single  Bits instance for this
  reader, merging live Documents on the
  fly. 
- getLiveDocs() - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getLiveDocs() - Method in class org.apache.lucene.index.SegmentReader
-  
- getLiveDocs() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getLockDir() - Method in class org.apache.lucene.store.FSLockFactory
- 
Retrieve the lock directory. 
- getLockFactory() - Method in class org.apache.lucene.store.BaseDirectory
-  
- getLockFactory() - Method in class org.apache.lucene.store.Directory
- 
Get the LockFactory that this Directory instance is
 using for its locking implementation. 
- getLockFactory() - Method in class org.apache.lucene.store.FilterDirectory
-  
- getLockFactory() - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- getLockID() - Method in class org.apache.lucene.store.Directory
- 
Return a string identifier that uniquely differentiates
 this Directory instance from other Directory instances. 
- getLockID() - Method in class org.apache.lucene.store.FilterDirectory
-  
- getLockID() - Method in class org.apache.lucene.store.FSDirectory
-  
- getLockID() - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- getLockID() - Method in class org.apache.lucene.store.RAMDirectory
-  
- getLockPrefix() - Method in class org.apache.lucene.store.LockFactory
- 
Get the prefix in use for all locks created in this LockFactory. 
- getLongs(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
Returns a  FieldCache.Longs over the values found in documents in the given
 field. 
- getLongs(AtomicReader, String, FieldCache.LongParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
Returns a  FieldCache.Longs over the values found in documents in the given
 field. 
- getLowerBits() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
- 
Expert. 
- getLowerTerm() - Method in class org.apache.lucene.search.TermRangeFilter
- 
Returns the lower value of this range filter 
- getLowerTerm() - Method in class org.apache.lucene.search.TermRangeQuery
- 
Returns the lower value of this range query 
- getLowerVal() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
- 
Returns the lower value of this range filter 
- getLowerVal() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Returns the lower value of this range filter 
- getMap() - Method in class org.apache.lucene.util.MapOfSets
-  
- getMappedStateCount() - Method in class org.apache.lucene.util.fst.Builder
-  
- getMaskedQuery() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- getMatch() - Method in class org.apache.lucene.search.ComplexExplanation
- 
The match status of this explanation node. 
- getMatch() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-  
- getMatchArray() - Method in class org.apache.lucene.index.MultiTermsEnum
- 
Returns sub-reader slices positioned to the current term. 
- getMatchCount() - Method in class org.apache.lucene.index.MultiTermsEnum
- 
Returns how many sub-reader slices contain the current
  term. 
- getMax() - Method in class org.apache.lucene.search.NumericRangeFilter
- 
Returns the upper value of this range filter 
- getMax() - Method in class org.apache.lucene.search.NumericRangeQuery
- 
Returns the upper value of this range query 
- getMax() - Method in class org.apache.lucene.util.automaton.Transition
- 
Returns maximum of this transition interval. 
- getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the number of buffered deleted terms that will trigger a flush of all
 buffered deletes if enabled. 
- getMaxBufferedDocs() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getMaxBufferedDocs() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the number of buffered added documents that will trigger a flush if
 enabled. 
- getMaxCFSSegmentSizeMB() - Method in class org.apache.lucene.index.MergePolicy
- 
Returns the largest size allowed for a compound file segment 
- getMaxChunkSize() - Method in class org.apache.lucene.store.MMapDirectory
- 
Returns the current mmap chunk size. 
- getMaxClauseCount() - Static method in class org.apache.lucene.search.BooleanQuery
- 
Return the maximum number of clauses permitted, 1024 by default. 
- getMaxEdits() - Method in class org.apache.lucene.search.FuzzyQuery
-  
- getMaxMergeAtOnce() - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Returns the current maxMergeAtOnce setting. 
- getMaxMergeAtOnceExplicit() - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Returns the current maxMergeAtOnceExplicit setting. 
- getMaxMergeCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
- getMaxMergeDocs() - Method in class org.apache.lucene.index.LogMergePolicy
- 
Returns the largest segment (measured by document
  count) that may be merged with other segments. 
- getMaxMergedSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Returns the current maxMergedSegmentMB setting. 
- getMaxMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
- 
Returns the largest segment (measured by total byte
  size of the segment's files, in MB) that may be merged
  with other segments. 
- getMaxMergeMBForForcedMerge() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
- 
Returns the largest segment (measured by total byte
  size of the segment's files, in MB) that may be merged
  with other segments during forceMerge. 
- getMaxNonCompetitiveBoost() - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
- 
This is the maximum boost that would not be competitive. 
- getMaxNonCompetitiveBoost() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-  
- getMaxPos() - Method in class org.apache.lucene.util.RollingBuffer
- 
Returns the maximum position looked up, or -1 if no
  position has been looked up sinc reset/init. 
- getMaxScore() - Method in class org.apache.lucene.search.TopDocs
- 
Returns the maximum score value encountered. 
- getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-  
- getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
-  
- getMaxSize() - Method in class org.apache.lucene.search.TopTermsRewrite
- 
return the maximum size of the priority queue (for boolean rewrites this is BooleanQuery#getMaxClauseCount). 
- getMaxTermFrequency() - Method in class org.apache.lucene.index.FieldInvertState
- 
Get the maximum term-frequency encountered for any term in the field. 
- getMaxThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Returns maxThreadCount.
 
- getMaxThreadStates() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getMaxThreadStates() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the max number of simultaneous threads that may be indexing
 documents at once in IndexWriter. 
- getMaxWriteMBPerSec(IOContext.Context) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
- 
- getMbPerSec() - Method in class org.apache.lucene.store.RateLimiter
- 
The current mb per second rate limit. 
- getMbPerSec() - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
- 
The current mb per second rate limit. 
- getMergedFieldInfos(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
- 
Call this to get the (merged) FieldInfos for a
  composite reader. 
- getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getMergedSegmentWarmer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the current merged segment warmer. 
- getMergeFactor() - Method in class org.apache.lucene.index.LogMergePolicy
- 
Returns the number of segments that are merged at
 once and also controls the total number of segments
 allowed to accumulate in the index. 
- getMergeInfo() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
- getMergePolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getMergePolicy() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the current MergePolicy in use by this writer. 
- getMergeReaders() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Expert: Get the list of readers to merge. 
- getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getMergeScheduler() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Create and return a new MergeThread 
- getMergeThreadPriority() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Return the priority that merge threads run at. 
- getMergingSegments() - Method in class org.apache.lucene.index.IndexWriter
- 
Expert: to be used by a  MergePolicy to avoid
  selecting merges for segments already being merged. 
- getMilliseconds() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- 
Get the timer value in milliseconds. 
- getMin() - Method in class org.apache.lucene.search.NumericRangeFilter
- 
Returns the lower value of this range filter 
- getMin() - Method in class org.apache.lucene.search.NumericRangeQuery
- 
Returns the lower value of this range query 
- getMin() - Method in class org.apache.lucene.util.automaton.Transition
- 
Returns minimum of this transition interval. 
- getMinimumNumberShouldMatch() - Method in class org.apache.lucene.search.BooleanQuery
- 
Gets the minimum number of the optional BooleanClauses
 which must be satisfied. 
- getMinMergeDocs() - Method in class org.apache.lucene.index.LogDocMergePolicy
- 
Get the minimum size for a segment to remain
  un-merged. 
- getMinMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
- 
Get the minimum size for a segment to remain
  un-merged. 
- getMinSimilarity() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- getMsg() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
- 
Description of hte insane behavior 
- getMu() - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
- 
Returns the μ parameter. 
- getMu() - Method in class org.apache.lucene.search.similarities.NormalizationH3
- 
Returns the parameter μ
 
- getMutable() - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- getMutable(int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Create a packed integer array with the given amount of values initialized
 to 0. 
- getMutable(int, int, PackedInts.Format) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getName() - Method in class org.apache.lucene.codecs.Codec
- 
Returns this codec's name 
- getName() - Method in class org.apache.lucene.codecs.DocValuesFormat
-  
- getName() - Method in class org.apache.lucene.codecs.PostingsFormat
- 
Returns this posting format's name 
- getName() - Method in class org.apache.lucene.index.FieldInvertState
- 
Return the field's name 
- getName() - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
-  
- getName() - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-  
- getName() - Method in interface org.apache.lucene.search.similarities.LMSimilarity.CollectionModel
- 
The name of the collection model strategy. 
- getName() - Method in class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
-  
- getName() - Method in class org.apache.lucene.search.similarities.LMSimilarity
- 
Returns the name of the LM method. 
- getName() - Method in class org.apache.lucene.store.CompoundFileDirectory
-  
- getName() - Method in interface org.apache.lucene.util.NamedSPILoader.NamedSPI
-  
- getNextDelGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns the next available generation number
 of the live docs file. 
- getNextFieldInfosGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns the next available generation number of the FieldInfos files. 
- getNextMerge() - Method in class org.apache.lucene.index.IndexWriter
- 
Expert: the  MergeScheduler calls this method to retrieve the next
 merge requested by the MergePolicy 
- getNextSegmentFileName() - Method in class org.apache.lucene.index.SegmentInfos
- 
Get the next segments_N filename that will be written. 
- getNoCFSRatio() - Method in class org.apache.lucene.index.MergePolicy
- 
Returns current noCFSRatio.
 
- getNodeCount() - Method in class org.apache.lucene.util.fst.FST
-  
- getNoLockFactory() - Static method in class org.apache.lucene.store.NoLockFactory
-  
- getNoOutput() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-  
- getNoOutput() - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-  
- getNoOutput() - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-  
- getNoOutput() - Method in class org.apache.lucene.util.fst.NoOutputs
-  
- getNoOutput() - Method in class org.apache.lucene.util.fst.Outputs
- 
NOTE: this output is compared with == so you must
  ensure that all methods return the single object if
  it's really no output 
- getNoOutput() - Method in class org.apache.lucene.util.fst.PairOutputs
-  
- getNoOutput() - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-  
- getNormalization() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
- 
Returns the second normalization 
- getNormalization() - Method in class org.apache.lucene.search.similarities.IBSimilarity
- 
Returns the term frequency normalization 
- getNormType() - Method in class org.apache.lucene.index.FieldInfo
- 
- getNormValues(String) - Method in class org.apache.lucene.index.AtomicReader
- 
- getNormValues(String) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getNormValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
- 
Returns a NumericDocValues for a reader's norms (potentially merging on-the-fly). 
- getNormValues(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getNormValues(String) - Method in class org.apache.lucene.index.SegmentReader
-  
- getNormValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getNumber() - Method in class org.apache.lucene.util.automaton.State
- 
Return this state's number. 
- getNumberedStates() - Method in class org.apache.lucene.util.automaton.Automaton
-  
- getNumberOfDocuments() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Returns the number of documents. 
- getNumberOfFieldTokens() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Returns the total number of tokens in the field. 
- getNumberOfStates() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns the number of states in this automaton. 
- getNumberOfTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns the number of transitions in this automaton. 
- getNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
- 
- getNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
-  
- getNumericDocValues(String) - Method in class org.apache.lucene.index.AtomicReader
- 
- getNumericDocValues(String) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getNumericDocValues(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getNumericDocValues(String) - Method in class org.apache.lucene.index.SegmentReader
-  
- getNumericDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getNumericValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
- 
Returns a NumericDocValues for a reader's docvalues (potentially merging on-the-fly) 
- getNumOverlap() - Method in class org.apache.lucene.index.FieldInvertState
- 
Get the number of terms with positionIncrement == 0.
 
- getNumSubs() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
- 
How many sub-readers we are merging. 
- getNumSubs() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
- 
How many sub-readers we are merging. 
- getNumSubs() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
- 
How many sub-readers we are merging. 
- getNumSubs() - Method in class org.apache.lucene.index.MultiDocsEnum
- 
How many sub-readers we are merging. 
- getNumWords() - Method in class org.apache.lucene.util.OpenBitSet
- 
Expert: gets the number of longs in the array that are in use 
- getOccur() - Method in class org.apache.lucene.search.BooleanClause
-  
- getOffset() - Method in class org.apache.lucene.index.FieldInvertState
- 
Get end offset of the last processed term. 
- getOffsetGap(String) - Method in class org.apache.lucene.analysis.Analyzer
- 
- getOffsetGap(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-  
- getOffsetLength() - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. 
- getOpenMode() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getOpenMode() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getOrd(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-  
- getOrd(int) - Method in class org.apache.lucene.index.SortedDocValues
- 
Returns the ordinal for the specified docID. 
- getOrdIndexInstance(IndexInput, FieldInfo, Lucene45DocValuesProducer.NumericEntry) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
- 
returns an address instance for sortedset ordinal lists 
- getOrdTermsEnum(AtomicReader) - Method in class org.apache.lucene.index.DocTermOrds
- 
Returns a TermsEnum that implements ord. 
- getParser() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Returns the current numeric parser (nullforTisString}
 
- getParser() - Method in class org.apache.lucene.search.SortField
- 
Returns the instance of a  FieldCache parser that fits to the given sort type. 
- getPause() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Returns true if this merge is paused. 
- getPayload() - Method in class org.apache.lucene.analysis.Token
- 
Returns this Token's payload. 
- getPayload() - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
- 
Returns this Token's payload. 
- getPayload() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-  
- getPayload() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- getPayload() - Method in class org.apache.lucene.index.DocsAndPositionsEnum
- 
Returns the payload at this position, or null if no
  payload was indexed. 
- getPayload() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- getPayload() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- getPayload() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- getPayload() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
- 
WARNING: The List is not necessarily in order of the the positions 
- getPayload() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- getPayload() - Method in class org.apache.lucene.search.spans.Spans
- 
Returns the payload data for the current span. 
- getPayload() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- getPayloadLength() - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. 
- getPayloads(Spans[]) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
-  
- getPayloadScore() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- 
The score for the payload 
- getPayloadsForQuery(Query) - Method in class org.apache.lucene.search.payloads.PayloadSpanUtil
- 
Query should be rewritten for wild/fuzzy support. 
- getPointer() - Method in class org.apache.lucene.util.PagedBytes
-  
- getPosition() - Method in class org.apache.lucene.index.FieldInvertState
- 
Get the last processed term position. 
- getPosition() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- getPosition() - Method in class org.apache.lucene.store.ByteArrayDataOutput
-  
- getPosition() - Method in class org.apache.lucene.util.fst.FST.BytesReader
- 
Get current read position. 
- getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
- 
Returns the current byte position. 
- getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
- 
Return the current byte position. 
- getPositionIncrement() - Method in class org.apache.lucene.analysis.Token
- 
Returns the position increment of this Token. 
- getPositionIncrement() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
- 
Returns the position increment of this Token. 
- getPositionIncrement() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-  
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.Analyzer
- 
Invoked before indexing a IndexableField instance if
 terms have already been added to that field. 
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-  
- getPositionLength() - Method in class org.apache.lucene.analysis.Token
- 
Returns the position length of this Token. 
- getPositionLength() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
- 
Returns the position length of this Token. 
- getPositionLength() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-  
- getPositions() - Method in class org.apache.lucene.search.MultiPhraseQuery
- 
Returns the relative positions of terms in this phrase. 
- getPositions() - Method in class org.apache.lucene.search.PhraseQuery
- 
Returns the relative positions of terms in this phrase. 
- getPostings() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. Returns the postings format that should be used for writing 
  new segments of field.
 
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. Returns the postings format that should be used for writing 
  new segments of field.
 
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. Returns the postings format that should be used for writing 
  new segments of field.
 
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. Returns the postings format that should be used for writing 
  new segments of field.
 
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
- 
Returns the postings format that should be used for writing 
  new segments of field.
 
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
- 
Returns the postings format that should be used for writing 
 new segments of field.
 
- getPrecisionStep() - Method in class org.apache.lucene.analysis.NumericTokenStream
- 
Returns the precision step. 
- getPrecisionStep() - Method in class org.apache.lucene.search.NumericRangeFilter
- 
Returns the precision step. 
- getPrecisionStep() - Method in class org.apache.lucene.search.NumericRangeQuery
- 
Returns the precision step. 
- getPrefix() - Method in class org.apache.lucene.search.PrefixFilter
-  
- getPrefix() - Method in class org.apache.lucene.search.PrefixQuery
- 
Returns the prefix of this query. 
- getPrefixCodedIntShift(BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
- 
Returns the shift value from a prefix encoded int.
 
- getPrefixCodedLongShift(BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
- 
Returns the shift value from a prefix encoded long.
 
- getPrefixLength() - Method in class org.apache.lucene.search.FuzzyQuery
- 
Returns the non-fuzzy prefix length. 
- getPrimaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
- 
Return the primary directory 
- getProxPointer() - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. 
- getQuery() - Method in class org.apache.lucene.search.BooleanClause
-  
- getQuery() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
-  
- getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery
- 
Returns the encapsulated query, returns nullif a filter is wrapped.
 
- getQuery() - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
- 
Return our associated DisjunctionMaxQuery 
- getQuery() - Method in class org.apache.lucene.search.FilteredQuery
- 
Returns this FilteredQuery's (unfiltered) Query 
- getQuery() - Method in class org.apache.lucene.search.QueryWrapperFilter
- 
returns the inner Query 
- getQuery() - Method in class org.apache.lucene.search.spans.SpanWeight
-  
- getQuery() - Method in class org.apache.lucene.search.Weight
- 
The query that this concerns. 
- getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getRAMBufferSizeMB() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getRAMPerThreadHardLimitMB() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getRAMPerThreadHardLimitMB() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the max amount of memory each DocumentsWriterPerThreadcan
 consume until forcefully flushed.
 
- getRawValue() - Method in interface org.apache.lucene.analysis.NumericTokenStream.NumericTermAttribute
- 
- getRawValue() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- getReadChunkSize() - Method in class org.apache.lucene.store.FSDirectory
- 
Deprecated.
This is no longer used since Lucene 4.5. 
 
- getReader(DataInput) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getReaderIterator(DataInput, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getReaderIteratorNoHeader(DataInput, PackedInts.Format, int, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
- getReaderKey() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-  
- getReaderNoHeader(DataInput, PackedInts.Format, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Expert: Restore a  PackedInts.Reader from a stream without reading metadata at
 the beginning of the stream. 
- getReaderNoHeader(DataInput, PackedInts.Header) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Expert: Restore a  PackedInts.Reader from a stream without reading metadata at
 the beginning of the stream. 
- getReaderPooling() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getReaderPooling() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getReaderTermsIndexDivisor() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getReaderTermsIndexDivisor() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the termInfosIndexDivisor.
 
- getReclaimDeletesWeight() - Method in class org.apache.lucene.index.TieredMergePolicy
- 
- getRefCount() - Method in class org.apache.lucene.index.IndexReader
- 
Expert: returns the current refCount for this reader 
- getRefCount(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-  
- getRefCount(G) - Method in class org.apache.lucene.search.ReferenceManager
- 
Returns the current reference count of the given reference. 
- getRefCount(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
-  
- getRefCount() - Method in class org.apache.lucene.util.RefCount
- 
Returns the current reference count. 
- getResolution() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- 
Return the timer resolution. 
- getReusableComponents(Analyzer, String) - Method in class org.apache.lucene.analysis.Analyzer.GlobalReuseStrategy
- 
Deprecated. 
- getReusableComponents(Analyzer, String) - Method in class org.apache.lucene.analysis.Analyzer.PerFieldReuseStrategy
- 
Deprecated. 
- getReusableComponents(Analyzer, String) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
- 
Gets the reusable TokenStreamComponents for the field with the given name. 
- getReuseStrategy() - Method in class org.apache.lucene.analysis.Analyzer
- 
- getReverse() - Method in class org.apache.lucene.search.SortField
- 
Returns whether the sort should be reversed. 
- getReverseMul() - Method in class org.apache.lucene.search.FieldValueHitQueue
-  
- getRewriteMethod() - Method in class org.apache.lucene.search.MultiTermQuery
-  
- getRewriteMethod() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- 
Expert: returns the rewriteMethod 
- getRunningMerge() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- 
Return the currently running merge. 
- getScaleFactor() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- getSearcher(SearcherFactory, IndexReader) - Static method in class org.apache.lucene.search.SearcherManager
- 
- getSecondaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
- 
Return the secondary directory 
- getSecondState() - Method in class org.apache.lucene.util.automaton.StatePair
- 
Returns second component of this pair. 
- getSegmentCount() - Method in class org.apache.lucene.index.IndexCommit
- 
Returns number of segments referenced by this commit. 
- getSegmentInfo() - Method in class org.apache.lucene.index.SegmentReader
- 
Return the SegmentInfoPerCommit of the segment this reader is reading. 
- getSegmentInfoReader() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- getSegmentInfoReader() - Method in class org.apache.lucene.codecs.lucene40.Lucene40SegmentInfoFormat
- 
Deprecated. 
- getSegmentInfoReader() - Method in class org.apache.lucene.codecs.lucene46.Lucene46SegmentInfoFormat
-  
- getSegmentInfoReader() - Method in class org.apache.lucene.codecs.SegmentInfoFormat
- 
- getSegmentInfoWriter() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- getSegmentInfoWriter() - Method in class org.apache.lucene.codecs.lucene40.Lucene40SegmentInfoFormat
- 
Deprecated. 
- getSegmentInfoWriter() - Method in class org.apache.lucene.codecs.lucene46.Lucene46SegmentInfoFormat
-  
- getSegmentInfoWriter() - Method in class org.apache.lucene.codecs.SegmentInfoFormat
- 
- getSegmentName() - Method in class org.apache.lucene.index.SegmentReader
- 
Return the name of the segment this reader is reading. 
- getSegmentsFileName() - Method in class org.apache.lucene.index.IndexCommit
- 
Get the segments file (segments_N) associated 
 with this commit point.
 
- getSegmentsFileName() - Method in class org.apache.lucene.index.SegmentInfos
- 
Get the segments_N filename in use by this segment infos. 
- getSegmentsPerTier() - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Returns the current segmentsPerTier setting. 
- getSentinelObject() - Method in class org.apache.lucene.util.PriorityQueue
- 
This method can be overridden by extending classes to return a sentinel
 object which will be used by the  PriorityQueue.PriorityQueue(int,boolean) 
 constructor to fill the queue, so that the code which uses that queue can always
 assume it's full and only change the top without attempting to insert any new
 object. 
 
 Those sentinel values should always compare worse than any non-sentinel
 value (i.e.,  PriorityQueue.lessThan(T, T) should always favor the
 non-sentinel values). 
 
 By default, this method returns false, which means the queue will not be
 filled with sentinel values. 
- getSequentialSubReaders() - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- getSequentialSubReaders() - Method in class org.apache.lucene.index.CompositeReader
- 
Expert: returns the sequential sub readers that this
  reader is logically composed of. 
- getShift() - Method in interface org.apache.lucene.analysis.NumericTokenStream.NumericTermAttribute
- 
Returns current shift value, undefined before first token 
- getShift() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- getShorts(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getShorts(AtomicReader, String, FieldCache.ShortParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
- getShrinkSize(int, int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- getSimilarity() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getSimilarity() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- getSimilarity() - Method in class org.apache.lucene.search.IndexSearcher
-  
- getSingleton() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns the singleton string for this automaton. 
- getSingleton() - Static method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-  
- getSingleton() - Static method in class org.apache.lucene.util.fst.CharSequenceOutputs
-  
- getSingleton() - Static method in class org.apache.lucene.util.fst.IntSequenceOutputs
-  
- getSingleton() - Static method in class org.apache.lucene.util.fst.NoOutputs
-  
- getSingleton() - Static method in class org.apache.lucene.util.fst.PositiveIntOutputs
-  
- getSize() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
- 
return the maximum priority queue size 
- getSize() - Method in class org.apache.lucene.search.TopTermsRewrite
- 
return the maximum priority queue size 
- getSize() - Method in class org.apache.lucene.util.automaton.RunAutomaton
- 
Returns number of states in automaton. 
- getSizeInBytes() - Method in class org.apache.lucene.store.RAMFile
-  
- getSlop() - Method in class org.apache.lucene.search.MultiPhraseQuery
- 
Sets the phrase slop for this query. 
- getSlop() - Method in class org.apache.lucene.search.PhraseQuery
- 
Returns the slop. 
- getSlop() - Method in class org.apache.lucene.search.spans.SpanNearQuery
- 
Return the maximum number of intervening unmatched positions permitted. 
- getSlot(int) - Method in class org.apache.lucene.util.SentinelIntSet
- 
(internal) Returns the slot for this key 
- getSnapshotCount() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Returns the total number of snapshots currently held. 
- getSnapshots() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Returns all IndexCommits held by at least one snapshot. 
- getSort() - Method in class org.apache.lucene.search.Sort
- 
Representation of the sort criteria. 
- getSorted(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
- 
- getSorted(FieldInfo) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
-  
- getSortedDocValues(String) - Method in class org.apache.lucene.index.AtomicReader
- 
- getSortedDocValues(String) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getSortedDocValues(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getSortedDocValues(String) - Method in class org.apache.lucene.index.SegmentReader
-  
- getSortedDocValues() - Method in class org.apache.lucene.index.SingletonSortedSetDocValues
- 
- getSortedDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getSortedSet(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
- 
- getSortedSet(FieldInfo) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
-  
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.AtomicReader
- 
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.SegmentReader
-  
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getSortedSetValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
- 
Returns a SortedSetDocValues for a reader's docvalues (potentially doing extremely slow things). 
- getSortedTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns a sorted array of transitions for each state (and sets state
 numbers). 
- getSortedValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
- 
Returns a SortedDocValues for a reader's docvalues (potentially doing extremely slow things). 
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-  
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-  
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-  
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-  
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-  
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanQuery
- 
Expert: Returns the matches for this query in an index. 
- getSpans(AtomicReaderContext, Bits, Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanTermQuery
-  
- getSpanScore() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
- 
Returns the SpanScorer score only. 
- getStart() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-  
- getStoredValue(Analyzer) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
- 
Returns the currently stored value. 
- getSubs() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
- 
Returns sub-readers we are merging. 
- getSubs() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
- 
Returns sub-readers we are merging. 
- getSubs() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
- 
Returns sub-readers we are merging. 
- getSubs() - Method in class org.apache.lucene.index.MultiDocsEnum
- 
Returns sub-readers we are merging. 
- getSubSpans() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- getSubSpans() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- getSumDocFreq() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
-  
- getSumDocFreq(String) - Method in class org.apache.lucene.index.AtomicReader
-  
- getSumDocFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- getSumDocFreq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
-  
- getSumDocFreq(String) - Method in class org.apache.lucene.index.IndexReader
- 
Returns the sum of  TermsEnum.docFreq() for all terms in this field,
 or -1 if this measure isn't stored by the codec. 
- getSumDocFreq() - Method in class org.apache.lucene.index.MultiTerms
-  
- getSumDocFreq() - Method in class org.apache.lucene.index.Terms
- 
Returns the sum of  TermsEnum.docFreq() for
  all terms in this field, or -1 if this measure isn't
  stored by the codec. 
- getSummary() - Method in class org.apache.lucene.search.ComplexExplanation
-  
- getSummary() - Method in class org.apache.lucene.search.Explanation
- 
A short one line summary which should contain all high level
 information about this Explanation, without the "Details" 
- getSumTotalTermFreq() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
-  
- getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.AtomicReader
-  
- getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- getSumTotalTermFreq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
-  
- getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.IndexReader
- 
Returns the sum of  TermsEnum.totalTermFreq() for all terms in this
 field, or -1 if this measure isn't stored by the codec (or if this fields
 omits term freq and positions). 
- getSumTotalTermFreq() - Method in class org.apache.lucene.index.MultiTerms
-  
- getSumTotalTermFreq() - Method in class org.apache.lucene.index.Terms
- 
Returns the sum of  TermsEnum.totalTermFreq() for
  all terms in this field, or -1 if this measure isn't
  stored by the codec (or if this fields omits term freq
  and positions). 
- getSupportedFeatures() - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Return the set of supported JVM features that improve the estimation. 
- getTargetLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-  
- getTargetLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-  
- getTerm() - Method in class org.apache.lucene.search.FuzzyQuery
- 
Returns the pattern term. 
- getTerm() - Method in class org.apache.lucene.search.spans.SpanTermQuery
- 
Return the term whose spans are matched. 
- getTerm() - Method in class org.apache.lucene.search.TermQuery
- 
Returns the term of this query. 
- getTerm() - Method in class org.apache.lucene.search.WildcardQuery
- 
Returns the pattern term. 
- getTermArrays() - Method in class org.apache.lucene.search.MultiPhraseQuery
- 
Returns a List of the terms in the multiphrase. 
- getTermCount() - Method in class org.apache.lucene.util.fst.Builder
-  
- getTermDocsEnum(IndexReader, Bits, String, BytesRef) - Static method in class org.apache.lucene.index.MultiFields
- 
Returns  DocsEnum for the specified field &
  term. 
- getTermDocsEnum(IndexReader, Bits, String, BytesRef, int) - Static method in class org.apache.lucene.index.MultiFields
- 
Returns  DocsEnum for the specified field &
  term, with control over whether freqs are required. 
- getTermIndexInterval() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getTermIndexInterval() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns the interval between indexed terms. 
- getTermInfosIndexDivisor() - Method in class org.apache.lucene.index.SegmentReader
- 
- getTermPositionsEnum(IndexReader, Bits, String, BytesRef) - Static method in class org.apache.lucene.index.MultiFields
- 
- getTermPositionsEnum(IndexReader, Bits, String, BytesRef, int) - Static method in class org.apache.lucene.index.MultiFields
- 
Returns  DocsAndPositionsEnum for the specified
  field & term, with control over whether offsets and payloads are
  required. 
- getTerms(IndexReader, String) - Static method in class org.apache.lucene.index.MultiFields
- 
This method may return null if the field does not exist. 
- getTerms(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
- 
Checks the internal cache for an appropriate entry, and if none
 is found, reads the term values in  field
 and returns a  BinaryDocValues instance, providing a
 method to retrieve the term (as a BytesRef) per document. 
- getTerms(AtomicReader, String, boolean, float) - Method in interface org.apache.lucene.search.FieldCache
- 
- getTerms() - Method in class org.apache.lucene.search.PhraseQuery
- 
Returns the set of terms in this phrase. 
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.AutomatonQuery
-  
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.FuzzyQuery
-  
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.MultiTermQuery
- 
Construct the enumeration to be used, expanding the
  pattern term. 
- getTermsEnum(Terms) - Method in class org.apache.lucene.search.MultiTermQuery
- 
Convenience method, if no attributes are needed:
 This simply passes empty attributes and is equal to:
 getTermsEnum(terms, new AttributeSource())
 
- getTermsEnum(MultiTermQuery, Terms, AttributeSource) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
- 
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.NumericRangeQuery
-  
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.PrefixQuery
-  
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.TermRangeQuery
-  
- getTermsEnum(Terms) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
-  
- getTermsIndex(AtomicReader, String) - Method in interface org.apache.lucene.search.FieldCache
- 
Checks the internal cache for an appropriate entry, and if none
 is found, reads the term values in  field
 and returns a  SortedDocValues instance,
 providing methods to retrieve sort ordinals and terms
 (as a ByteRef) per document. 
- getTermsIndex(AtomicReader, String, float) - Method in interface org.apache.lucene.search.FieldCache
- 
- getTermVector(int, String) - Method in class org.apache.lucene.index.IndexReader
- 
Retrieve term vector for this document and field, or
  null if term vectors were not indexed. 
- getTermVectors(int) - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- getTermVectors(int) - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- getTermVectors(int) - Method in class org.apache.lucene.index.IndexReader
- 
Retrieve term vectors for this document, or null if
  term vectors were not indexed. 
- getTermVectors(int) - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- getTermVectors(int) - Method in class org.apache.lucene.index.SegmentReader
-  
- getTermVectors(int) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- getTermVectorsReader() - Method in class org.apache.lucene.index.SegmentReader
- 
- getTieBreakerMultiplier() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-  
- getTimeAllowed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
- 
Returns allowed time (milliseconds). 
- getTimeElapsed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
- 
Returns elapsed time (milliseconds). 
- getTokenizer() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
- 
- getTokenStream() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
- 
- getTopLevelContext(IndexReaderContext) - Static method in class org.apache.lucene.index.ReaderUtil
- 
Walks up the reader tree and return the given context's top level reader
 context, or in other words the reader tree's root context. 
- getTopLevelQuery() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-  
- getTopLevelQuery() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
-  
- getTopReaderContext() - Method in class org.apache.lucene.search.IndexSearcher
- 
- getTotalBoost() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Returns the total boost. 
- getTotalHits() - Method in class org.apache.lucene.search.TopDocsCollector
- 
The total number of documents that matched this query. 
- getTotalHits() - Method in class org.apache.lucene.search.TotalHitCountCollector
- 
Returns how many hits matched the search. 
- getTotalTermFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Returns the total number of occurrences of this term across all documents. 
- getTotStateCount() - Method in class org.apache.lucene.util.fst.Builder
-  
- getTransitions() - Method in class org.apache.lucene.util.automaton.State
- 
Returns the set of outgoing transitions. 
- getTranspositions() - Method in class org.apache.lucene.search.FuzzyQuery
- 
Returns true if transpositions should be treated as a primitive edit operation. 
- getType() - Method in class org.apache.lucene.search.SortField
- 
Returns the type of contents in the field. 
- getType() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
- 
Type of insane behavior this object represents 
- getUniqueTermCount() - Method in class org.apache.lucene.index.FieldInvertState
- 
Return the number of unique terms encountered in this field. 
- getUniqueTermCount() - Method in class org.apache.lucene.index.Fields
- 
Deprecated.
iterate fields and add their size() instead. 
   this method is only provided as a transition mechanism
   to access this statistic for 3.x indexes, which do not
   have this statistic per-field. 
 
- getUnsupportedFeatures() - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Return the set of unsupported JVM features that improve the estimation. 
- getUpdatesFiles() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns the per generation updates files. 
- getUpperBits() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
- 
Expert. 
- getUpperTerm() - Method in class org.apache.lucene.search.TermRangeFilter
- 
Returns the upper value of this range filter 
- getUpperTerm() - Method in class org.apache.lucene.search.TermRangeQuery
- 
Returns the upper value of this range query 
- getUpperVal() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
- 
Returns the upper value of this range filter 
- getUpperVal() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Returns the upper value of this range filter 
- getUseCompoundFile() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns  true iff the  IndexWriter packs
 newly written segments in a compound file. 
- getUseCompoundFile() - Method in class org.apache.lucene.index.SegmentInfo
- 
Returns true if this segment is stored as a compound
 file; else, false. 
- getUserData() - Method in class org.apache.lucene.index.IndexCommit
- 
- getUserData() - Method in class org.apache.lucene.index.SegmentInfos
- 
Return userDatasaved with this commit.
 
- getUseUnmap() - Method in class org.apache.lucene.store.MMapDirectory
- 
Returns true, if the unmap workaround is enabled.
 
- getUTF16SortedAsUTF8Comparator() - Static method in class org.apache.lucene.util.CharsRef
- 
Deprecated.
This comparator is only a transition mechanism 
 
- getUTF8SortedAsUnicodeComparator() - Static method in class org.apache.lucene.util.BytesRef
-  
- getUTF8SortedAsUTF16Comparator() - Static method in class org.apache.lucene.util.BytesRef
- 
Deprecated.
This comparator is only a transition mechanism 
 
- getValue() - Method in class org.apache.lucene.search.Explanation
- 
The value assigned to this explanation node. 
- getValue() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-  
- getValueCount() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-  
- getValueCount() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-  
- getValueCount() - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
- 
Returns the total number of unique terms in global ord space. 
- getValueCount() - Method in class org.apache.lucene.index.SingletonSortedSetDocValues
-  
- getValueCount() - Method in class org.apache.lucene.index.SortedDocValues
- 
Returns the number of unique values. 
- getValueCount() - Method in class org.apache.lucene.index.SortedSetDocValues
- 
Returns the number of unique values. 
- getValueForNormalization() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- getValueForNormalization() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
-  
- getValueForNormalization() - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
- 
Compute the sub of squared weights of us applied to our subqueries. 
- getValueForNormalization() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
The square of the raw normalization value. 
- getValueForNormalization() - Method in class org.apache.lucene.search.similarities.Similarity.SimWeight
- 
The value for normalization of contained query clauses (e.g. 
- getValueForNormalization() - Method in class org.apache.lucene.search.spans.SpanWeight
-  
- getValueForNormalization() - Method in class org.apache.lucene.search.Weight
- 
The value for normalization of contained query clauses (e.g. 
- getValues(String) - Method in class org.apache.lucene.document.Document
- 
Returns an array of values of the field specified as the method parameter. 
- getValueSize() - Method in interface org.apache.lucene.analysis.NumericTokenStream.NumericTermAttribute
- 
Returns value size in bits (32 for float,int; 64 fordouble,long)
 
- getValueSize() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- getVersion() - Method in class org.apache.lucene.index.DirectoryReader
- 
Version number when this IndexReader was opened. 
- getVersion() - Method in class org.apache.lucene.index.FilterDirectoryReader
-  
- getVersion() - Method in class org.apache.lucene.index.SegmentInfo
- 
Returns the version of the code which wrote the segment. 
- getVersion() - Method in class org.apache.lucene.index.SegmentInfos
- 
version number when this SegmentInfos was generated. 
- getVersionComparator() - Static method in class org.apache.lucene.util.StringHelper
-  
- getWeight() - Method in class org.apache.lucene.search.Scorer
- 
returns parent Weight 
- getWrappedAnalyzer(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
- 
Retrieves the wrapped Analyzer appropriate for analyzing the field with
 the given name 
- getWrappedQuery() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- 
Returns the wrapped query 
- getWriteLockTimeout() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- getWriteLockTimeout() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Returns allowed timeout when acquiring the write lock. 
- getWriter(DataOutput, int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Create a packed integer array writer for the given output, format, value
 count, and number of bits per value. 
- getWriterNoHeader(DataOutput, PackedInts.Format, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Expert: Create a packed integer array writer for the given output, format,
 value count, and number of bits per value. 
- getZ() - Method in class org.apache.lucene.search.similarities.NormalizationZ
- 
Returns the parameter z
 
- GLOBAL_REUSE_STRATEGY - Static variable in class org.apache.lucene.analysis.Analyzer
- 
- grow(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(short[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(float[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(float[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(double[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(double[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(int[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(long[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(byte[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(boolean[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(boolean[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(char[]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(int[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(int[][]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(float[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(float[][]) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- grow(int) - Method in class org.apache.lucene.util.BytesRef
- 
Used to grow the reference array. 
- grow() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
- 
- grow() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-  
- grow(int) - Method in class org.apache.lucene.util.CharsRef
- 
Used to grow the reference array. 
- grow() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-  
- grow() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-  
- grow(int) - Method in class org.apache.lucene.util.IntsRef
- 
Used to grow the reference array. 
- grow(int) - Method in class org.apache.lucene.util.LongsRef
- 
Used to grow the reference array. 
- GrowableByteArrayDataOutput - Class in org.apache.lucene.util
- 
- GrowableByteArrayDataOutput(int) - Constructor for class org.apache.lucene.util.GrowableByteArrayDataOutput
- 
- GrowableWriter - Class in org.apache.lucene.util.packed
- 
Implements  PackedInts.Mutable, but grows the
 bit count of the underlying packed ints on-demand. 
- GrowableWriter(int, int, float) - Constructor for class org.apache.lucene.util.packed.GrowableWriter
-  
- IBSimilarity - Class in org.apache.lucene.search.similarities
- 
Provides a framework for the family of information-based models, as described
 in Stéphane Clinchant and Eric Gaussier. 
- IBSimilarity(Distribution, Lambda, Normalization) - Constructor for class org.apache.lucene.search.similarities.IBSimilarity
- 
Creates IBSimilarity from the three components. 
- id - Variable in enum org.apache.lucene.util.packed.PackedInts.Format
-  
- idf(long, long) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Implemented as log(1 + (numDocs - docFreq + 0.5)/(docFreq + 0.5)).
 
- idf(long, long) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Implemented as log(numDocs/(docFreq+1)) + 1.
 
- idf(long, long) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Computes a score factor based on a term's document frequency (the number
 of documents which contain the term). 
- idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Computes a score factor for a simple term and returns an explanation
 for that score factor. 
- idfExplain(CollectionStatistics, TermStatistics[]) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Computes a score factor for a phrase. 
- idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Computes a score factor for a simple term and returns an explanation
 for that score factor. 
- idfExplain(CollectionStatistics, TermStatistics[]) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Computes a score factor for a phrase. 
- in - Variable in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
- 
The underlying DocsAndPositionsEnum instance. 
- in - Variable in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
- 
The underlying DocsEnum instance. 
- in - Variable in class org.apache.lucene.index.FilterAtomicReader.FilterFields
- 
The underlying Fields instance. 
- in - Variable in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
- 
The underlying Terms instance. 
- in - Variable in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
- 
The underlying TermsEnum instance. 
- in - Variable in class org.apache.lucene.index.FilterAtomicReader
- 
The underlying AtomicReader. 
- in - Variable in class org.apache.lucene.index.FilterDirectoryReader
- 
The filtered DirectoryReader 
- in - Variable in class org.apache.lucene.store.FilterDirectory
-  
- includesLower() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
- 
Returns trueif the lower endpoint is inclusive
 
- includesLower() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Returns trueif the lower endpoint is inclusive
 
- includesLower() - Method in class org.apache.lucene.search.TermRangeFilter
- 
Returns trueif the lower endpoint is inclusive
 
- includesLower() - Method in class org.apache.lucene.search.TermRangeQuery
- 
Returns trueif the lower endpoint is inclusive
 
- includesMax() - Method in class org.apache.lucene.search.NumericRangeFilter
- 
Returns trueif the upper endpoint is inclusive
 
- includesMax() - Method in class org.apache.lucene.search.NumericRangeQuery
- 
Returns trueif the upper endpoint is inclusive
 
- includesMin() - Method in class org.apache.lucene.search.NumericRangeFilter
- 
Returns trueif the lower endpoint is inclusive
 
- includesMin() - Method in class org.apache.lucene.search.NumericRangeQuery
- 
Returns trueif the lower endpoint is inclusive
 
- includesUpper() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
- 
Returns trueif the upper endpoint is inclusive
 
- includesUpper() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Returns trueif the upper endpoint is inclusive
 
- includesUpper() - Method in class org.apache.lucene.search.TermRangeFilter
- 
Returns trueif the upper endpoint is inclusive
 
- includesUpper() - Method in class org.apache.lucene.search.TermRangeQuery
- 
Returns trueif the upper endpoint is inclusive
 
- incRef() - Method in class org.apache.lucene.index.IndexReader
- 
Expert: increments the refCount of this IndexReader
 instance. 
- incRef(IndexCommit) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
- incRef() - Method in class org.apache.lucene.util.RefCount
- 
Increments the reference count. 
- incrementToken() - Method in class org.apache.lucene.analysis.CachingTokenFilter
-  
- incrementToken() - Method in class org.apache.lucene.analysis.NumericTokenStream
-  
- incrementToken() - Method in class org.apache.lucene.analysis.TokenStream
- 
Consumers (i.e.,  IndexWriter) use this method to advance the stream to
 the next token. 
- incShift() - Method in interface org.apache.lucene.analysis.NumericTokenStream.NumericTermAttribute
- 
Don't call this method! 
- incShift() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- index - Variable in class org.apache.lucene.index.DocTermOrds
- 
Holds the per-document ords or a pointer to the ords. 
- INDEX_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
- 
This array contains all filename extensions used by
 Lucene's index files, with one exception, namely the
 extension made up from  .s+ a number.
 
- IndexableBinaryStringTools - Class in org.apache.lucene.util
- 
- IndexableField - Interface in org.apache.lucene.index
- 
Represents a single field for indexing. 
- IndexableFieldType - Interface in org.apache.lucene.index
- 
Describes the properties of a field. 
- indexArcCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
How many arcs in the index FST. 
- IndexCommit - Class in org.apache.lucene.index
- 
- IndexCommit() - Constructor for class org.apache.lucene.index.IndexCommit
- 
Sole constructor. 
- indexCommits - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Used to map gen to IndexCommit. 
- IndexDeletionPolicy - Class in org.apache.lucene.index
- 
- IndexDeletionPolicy() - Constructor for class org.apache.lucene.index.IndexDeletionPolicy
- 
Sole constructor, typically called by sub-classes constructors. 
- indexed() - Method in class org.apache.lucene.document.FieldType
- 
True if this field should be indexed (inverted) 
- indexed() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
True if this field should be indexed (inverted) 
- indexedTermsArray - Variable in class org.apache.lucene.index.DocTermOrds
- 
Holds the indexed (by default every 128th) terms. 
- indexerThreadPool - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
DocumentsWriterPerThreadPoolto control how
  threads are allocated toDocumentsWriterPerThread.
 
- indexExists(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
- 
Returns trueif an index likely exists at
 the specified directory.
 
- IndexFileNames - Class in org.apache.lucene.index
- 
This class contains useful constants representing filenames and extensions
 used by lucene, as well as convenience methods for querying whether a file
 name matches an extension ( matchesExtension), as well as generating file names from a segment name,
 generation and extension (
  fileNameFromGeneration,
  segmentFileName). 
- IndexFormatTooNewException - Exception in org.apache.lucene.index
- 
This exception is thrown when Lucene detects
 an index that is newer than this Lucene version. 
- IndexFormatTooNewException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
- 
Creates an IndexFormatTooNewException
 
- IndexFormatTooNewException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
- 
Creates an IndexFormatTooNewException
 
- IndexFormatTooOldException - Exception in org.apache.lucene.index
- 
This exception is thrown when Lucene detects
 an index that is too old for this Lucene version 
- IndexFormatTooOldException(String, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- 
Creates an IndexFormatTooOldException.
 
- IndexFormatTooOldException(DataInput, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- 
Creates an IndexFormatTooOldException.
 
- IndexFormatTooOldException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- 
Creates an IndexFormatTooOldException.
 
- IndexFormatTooOldException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
- 
Creates an IndexFormatTooOldException.
 
- indexingChain - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
DocumentsWriterPerThread.IndexingChainthat determines how documents are
  indexed.
 
- IndexInput - Class in org.apache.lucene.store
- 
Abstract base class for input from a file in a  Directory. 
- IndexInput(String) - Constructor for class org.apache.lucene.store.IndexInput
- 
resourceDescription should be a non-null, opaque string
  describing this resource; it's returned from
   IndexInput.toString(). 
- indexNodeCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
How many nodes in the index FST. 
- IndexNotFoundException - Exception in org.apache.lucene.index
- 
Signals that no index was found in the Directory. 
- IndexNotFoundException(String) - Constructor for exception org.apache.lucene.index.IndexNotFoundException
- 
Creates IndexFileNotFoundException with the
  description message. 
- indexNumBytes - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Byte size of the index. 
- indexOptions() - Method in class org.apache.lucene.document.FieldType
- 
- indexOptions() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
- INDEXORDER - Static variable in class org.apache.lucene.search.Sort
- 
Represents sorting by index order. 
- IndexOutput - Class in org.apache.lucene.store
- 
Abstract base class for output to a file in a Directory. 
- IndexOutput() - Constructor for class org.apache.lucene.store.IndexOutput
-  
- IndexReader - Class in org.apache.lucene.index
- 
IndexReader is an abstract class, providing an interface for accessing an
 index. 
- IndexReader.ReaderClosedListener - Interface in org.apache.lucene.index
- 
A custom listener that's invoked when the IndexReader
 is closed. 
- IndexReaderContext - Class in org.apache.lucene.index
- 
A struct like class that represents a hierarchical relationship between
  IndexReader instances. 
- IndexSearcher - Class in org.apache.lucene.search
- 
Implements search over a single IndexReader. 
- IndexSearcher(IndexReader) - Constructor for class org.apache.lucene.search.IndexSearcher
- 
Creates a searcher searching the provided index. 
- IndexSearcher(IndexReader, ExecutorService) - Constructor for class org.apache.lucene.search.IndexSearcher
- 
Runs searches for each segment separately, using the
  provided ExecutorService. 
- IndexSearcher(IndexReaderContext, ExecutorService) - Constructor for class org.apache.lucene.search.IndexSearcher
- 
- IndexSearcher(IndexReaderContext) - Constructor for class org.apache.lucene.search.IndexSearcher
- 
- IndexSearcher.LeafSlice - Class in org.apache.lucene.search
- 
A class holding a subset of the  IndexSearchers leaf contexts to be
 executed within a single thread. 
- IndexSearcher.LeafSlice(AtomicReaderContext...) - Constructor for class org.apache.lucene.search.IndexSearcher.LeafSlice
-  
- IndexUpgrader - Class in org.apache.lucene.index
- 
This is an easy-to-use tool that upgrades all segments of an index from previous Lucene versions
 to the current segment file format. 
- IndexUpgrader(Directory, Version) - Constructor for class org.apache.lucene.index.IndexUpgrader
- 
Creates index upgrader on the given directory, using an  IndexWriter using the given
  matchVersion. 
- IndexUpgrader(Directory, Version, PrintStream, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
- 
Creates index upgrader on the given directory, using an  IndexWriter using the given
  matchVersion. 
- IndexUpgrader(Directory, IndexWriterConfig, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
- 
Creates index upgrader on the given directory, using an  IndexWriter using the given
 config. 
- IndexWriter - Class in org.apache.lucene.index
- 
An IndexWritercreates and maintains an index.
 
- IndexWriter(Directory, IndexWriterConfig) - Constructor for class org.apache.lucene.index.IndexWriter
- 
Constructs a new IndexWriter per the settings given in conf.
 
- IndexWriter.IndexReaderWarmer - Class in org.apache.lucene.index
- 
If  DirectoryReader.open(IndexWriter,boolean) has
  been called (ie, this writer is in near real-time
  mode), then after a merge completes, this class can be
  invoked to warm the reader on the newly merged
  segment, before the merge commits. 
- IndexWriter.IndexReaderWarmer() - Constructor for class org.apache.lucene.index.IndexWriter.IndexReaderWarmer
- 
Sole constructor. 
- IndexWriterConfig - Class in org.apache.lucene.index
- 
Holds all the configuration that is used to create an  IndexWriter. 
- IndexWriterConfig(Version, Analyzer) - Constructor for class org.apache.lucene.index.IndexWriterConfig
- 
Creates a new config that with defaults that match the specified
  Version as well as the default  Analyzer. 
- IndexWriterConfig.OpenMode - Enum in org.apache.lucene.index
- 
- info - Variable in class org.apache.lucene.index.SegmentCommitInfo
- 
- info(int) - Method in class org.apache.lucene.index.SegmentInfos
- 
- infoStream - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- infoStream - Variable in class org.apache.lucene.index.MergeState
- 
InfoStream for debugging messages. 
- infoStream - Variable in class org.apache.lucene.index.SegmentWriteState
- 
- InfoStream - Class in org.apache.lucene.util
- 
- InfoStream() - Constructor for class org.apache.lucene.util.InfoStream
-  
- init(long, int, int, int) - Method in interface org.apache.lucene.analysis.NumericTokenStream.NumericTermAttribute
- 
Don't call this method! 
- init(long, int, int, int) - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- init(IndexInput) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. 
- init(long, long, long, int, boolean, boolean) - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. Per-term initialization. 
- init(IndexInput) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
-  
- init(IndexOutput) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- init(long, int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Initializes the reader, for reuse on a new term. 
- init() - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
- 
Allocates internal skip buffers. 
- init(IndexInput) - Method in class org.apache.lucene.codecs.PostingsReaderBase
- 
Performs any initialization, such as reading and
  verifying the header from the provided terms
  dictionary  IndexInput. 
- init(IndexOutput) - Method in class org.apache.lucene.codecs.PostingsWriterBase
- 
Called once after startup, before any terms have been
  added. 
- init() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
- 
Initializes the BytesStartArray. 
- init() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-  
- initialValue() - Method in class org.apache.lucene.util.CloseableThreadLocal
-  
- initReader(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
- 
Override this if you want to add a CharFilter chain. 
- initReader(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-  
- initSize - Variable in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-  
- inOrder - Variable in class org.apache.lucene.search.spans.SpanNearQuery
-  
- inPlaceAnd(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
- 
Perform an inplace AND with the doc ids from a given DocIdSetIterator,
 leaving only the bits set for which the doc ids are in common. 
- InPlaceMergeSorter - Class in org.apache.lucene.util
- 
Sorter implementation based on the merge-sort algorithm that merges
  in place (no extra memory will be allocated). 
- InPlaceMergeSorter() - Constructor for class org.apache.lucene.util.InPlaceMergeSorter
- 
- inPlaceNot(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
- 
Perform an inplace NOT with the doc ids from a given DocIdSetIterator,
 clearing all the bits for each such doc id. 
- inPlaceOr(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
- 
Perform an inplace OR with the doc ids from a given DocIdSetIterator,
 setting the bit for each such doc id. 
- inPlaceXor(DocIdSetIterator) - Method in class org.apache.lucene.util.OpenBitSetDISI
- 
Perform an inplace XOR with the doc ids from a given DocIdSetIterator,
 flipping all the bits for each such doc id. 
- input - Variable in class org.apache.lucene.analysis.CharFilter
- 
The underlying character-input stream. 
- input - Variable in class org.apache.lucene.analysis.TokenFilter
- 
The source of tokens for this filter. 
- input - Variable in class org.apache.lucene.analysis.Tokenizer
- 
The text source for this Tokenizer. 
- input - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
-  
- input - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
-  
- input - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-  
- input - Variable in class org.apache.lucene.util.fst.Util.MinResult
-  
- inputCount - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- InputStreamDataInput - Class in org.apache.lucene.store
- 
- InputStreamDataInput(InputStream) - Constructor for class org.apache.lucene.store.InputStreamDataInput
-  
- inputType - Variable in class org.apache.lucene.util.fst.FST
-  
- insertWithOverflow(T) - Method in class org.apache.lucene.util.PriorityQueue
- 
Adds an Object to a PriorityQueue in log(size) time. 
- INSTANCE - Static variable in class org.apache.lucene.index.NoDeletionPolicy
- 
The single instance of this class. 
- INSTANCE - Static variable in class org.apache.lucene.index.NoMergeScheduler
- 
- INT_BLOCK_MASK - Static variable in class org.apache.lucene.util.IntBlockPool
-  
- INT_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.IntBlockPool
-  
- INT_BLOCK_SIZE - Static variable in class org.apache.lucene.util.IntBlockPool
-  
- IntBlockPool - Class in org.apache.lucene.util
- 
- IntBlockPool() - Constructor for class org.apache.lucene.util.IntBlockPool
- 
- IntBlockPool(IntBlockPool.Allocator) - Constructor for class org.apache.lucene.util.IntBlockPool
- 
- IntBlockPool.Allocator - Class in org.apache.lucene.util
- 
Abstract class for allocating and freeing int
  blocks. 
- IntBlockPool.Allocator(int) - Constructor for class org.apache.lucene.util.IntBlockPool.Allocator
-  
- IntBlockPool.DirectAllocator - Class in org.apache.lucene.util
- 
- IntBlockPool.DirectAllocator() - Constructor for class org.apache.lucene.util.IntBlockPool.DirectAllocator
- 
- IntBlockPool.SliceReader - Class in org.apache.lucene.util
- 
- IntBlockPool.SliceReader(IntBlockPool) - Constructor for class org.apache.lucene.util.IntBlockPool.SliceReader
- 
- IntBlockPool.SliceWriter - Class in org.apache.lucene.util
- 
- IntBlockPool.SliceWriter(IntBlockPool) - Constructor for class org.apache.lucene.util.IntBlockPool.SliceWriter
-  
- IntDocValuesField - Class in org.apache.lucene.document
- 
- IntDocValuesField(String, int) - Constructor for class org.apache.lucene.document.IntDocValuesField
- 
Deprecated. Creates a new DocValues field with the specified 32-bit integer value 
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
-  
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.MultiTerms
-  
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.Terms
- 
Returns a TermsEnum that iterates over all terms that
  are accepted by the provided  CompiledAutomaton. 
- intersect(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
- 
this = this AND other 
- intersect(Collection<WAH8DocIdSet>) - Static method in class org.apache.lucene.util.WAH8DocIdSet
- 
- intersect(Collection<WAH8DocIdSet>, int) - Static method in class org.apache.lucene.util.WAH8DocIdSet
- 
Compute the intersection of the provided sets. 
- intersection(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
- 
- intersection(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns an automaton that accepts the intersection of the languages of the
 given automata. 
- INTERSECTION - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables intersection (&). 
- intersectionCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
- 
Returns the popcount or cardinality of the intersection of the two sets. 
- intersectionCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
- 
Returns the popcount or cardinality of the intersection of the two sets. 
- intersects(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
- 
returns true if the sets have any elements in common 
- intersects(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
- 
returns true if the sets have any elements in common 
- intersects(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
- 
returns true if the sets have any elements in common 
- INTERVAL - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables numerical intervals (
 <n-m>). 
- intField(FieldInfo, int) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-  
- IntField - Class in org.apache.lucene.document
- 
 Field that indexes intvalues
 for efficient range filtering and sorting.
 
- IntField(String, int, Field.Store) - Constructor for class org.apache.lucene.document.IntField
- 
- IntField(String, int, FieldType) - Constructor for class org.apache.lucene.document.IntField
- 
Expert: allows you to customize the  FieldType. 
- intField(FieldInfo, int) - Method in class org.apache.lucene.index.StoredFieldVisitor
- 
Process a int numeric field. 
- intOffset - Variable in class org.apache.lucene.util.IntBlockPool
- 
Current head offset 
- introSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
- 
- introSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
- 
- introSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
- 
Sorts the given array slice in natural order. 
- introSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
- 
Sorts the given array in natural order. 
- introSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
- 
- introSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
- 
Sorts the given random access  List in natural order. 
- IntroSorter - Class in org.apache.lucene.util
- 
Sorter implementation based on a variant of the quicksort algorithm
 called  introsort: when
 the recursion level exceeds the log of the length of the array to sort, it
 falls back to heapsort. 
- IntroSorter() - Constructor for class org.apache.lucene.util.IntroSorter
- 
- ints - Variable in class org.apache.lucene.util.IntsRef
- 
The contents of the IntsRef. 
- intsEquals(IntsRef) - Method in class org.apache.lucene.util.IntsRef
-  
- IntSequenceOutputs - Class in org.apache.lucene.util.fst
- 
An FST  Outputs implementation where each output
 is a sequence of ints. 
- IntsRef - Class in org.apache.lucene.util
- 
Represents int[], as a slice (offset + length) into an
  existing int[]. 
- IntsRef() - Constructor for class org.apache.lucene.util.IntsRef
- 
- IntsRef(int) - Constructor for class org.apache.lucene.util.IntsRef
- 
Create a IntsRef pointing to a new array of size capacity.
 
- IntsRef(int[], int, int) - Constructor for class org.apache.lucene.util.IntsRef
- 
This instance will directly reference ints w/o making a copy. 
- IntsRefFSTEnum<T> - Class in org.apache.lucene.util.fst
- 
Enumerates all input (IntsRef) + output pairs in an
  FST. 
- IntsRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum
- 
doFloor controls the behavior of advance: if it's true
  doFloor is true, advance positions to the biggest
  term before target. 
- IntsRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
- 
Holds a single input (IntsRef) + output pair. 
- IntsRefFSTEnum.InputOutput() - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
-  
- intToPrefixCoded(int, int, BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
- 
Returns prefix coded bits after reducing the precision by shiftbits.
 
- intToPrefixCodedBytes(int, int, BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
- 
Returns prefix coded bits after reducing the precision by shiftbits.
 
- intUpto - Variable in class org.apache.lucene.util.IntBlockPool
- 
Pointer to the current position in head buffer 
- IOContext - Class in org.apache.lucene.store
- 
IOContext holds additional details on the merge/search context. 
- IOContext() - Constructor for class org.apache.lucene.store.IOContext
-  
- IOContext(FlushInfo) - Constructor for class org.apache.lucene.store.IOContext
-  
- IOContext(IOContext.Context) - Constructor for class org.apache.lucene.store.IOContext
-  
- IOContext(MergeInfo) - Constructor for class org.apache.lucene.store.IOContext
-  
- IOContext(IOContext, boolean) - Constructor for class org.apache.lucene.store.IOContext
- 
This constructor is used to initialize a  IOContext instance with a new value for the readOnce variable. 
- IOContext.Context - Enum in org.apache.lucene.store
- 
Context is a enumerator which specifies the context in which the Directory
 is being used for. 
- IOUtils - Class in org.apache.lucene.util
- 
This class emulates the new Java 7 "Try-With-Resources" statement. 
- isAccept(int) - Method in class org.apache.lucene.util.automaton.RunAutomaton
- 
Returns acceptance status for given state. 
- isAccept() - Method in class org.apache.lucene.util.automaton.State
- 
Returns acceptance status. 
- isAnalyzed() - Method in enum org.apache.lucene.document.Field.Index
- 
Deprecated. 
- isCacheable() - Method in class org.apache.lucene.search.DocIdSet
- 
This method is a hint for  CachingWrapperFilter, if this  DocIdSet
 should be cached without copying it. 
- isCacheable() - Method in class org.apache.lucene.search.FieldCacheDocIdSet
- 
this DocIdSet is always cacheable (does not go back
 to the reader for iteration) 
- isCacheable() - Method in class org.apache.lucene.search.FilteredDocIdSet
- 
This DocIdSet implementation is cacheable if the inner set is cacheable. 
- isCacheable() - Method in class org.apache.lucene.util.DocIdBitSet
- 
This DocIdSet implementation is cacheable. 
- isCacheable() - Method in class org.apache.lucene.util.FixedBitSet
- 
This DocIdSet implementation is cacheable. 
- isCacheable() - Method in class org.apache.lucene.util.OpenBitSet
- 
This DocIdSet implementation is cacheable. 
- isCacheable() - Method in class org.apache.lucene.util.packed.EliasFanoDocIdSet
- 
This DocIdSet implementation is cacheable. 
- isCacheable() - Method in class org.apache.lucene.util.PForDeltaDocIdSet
-  
- isCacheable() - Method in class org.apache.lucene.util.WAH8DocIdSet
-  
- isCached() - Method in class org.apache.lucene.search.CachingCollector
-  
- isCompiled() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- isCoordDisabled() - Method in class org.apache.lucene.search.BooleanQuery
- 
- isCurrent() - Method in class org.apache.lucene.index.DirectoryReader
- 
Check whether any new changes have occurred to the
 index since this reader was opened. 
- isCurrent() - Method in class org.apache.lucene.index.FilterDirectoryReader
-  
- isDeleted() - Method in class org.apache.lucene.index.IndexCommit
- 
- isDeterministic() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns deterministic flag for this automaton. 
- isEmpty() - Method in class org.apache.lucene.index.DocTermOrds
- 
Returns trueif no terms were indexed.
 
- isEmpty(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns true if the given automaton accepts no strings. 
- isEmpty() - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns true if there are no set bits 
- isEmpty() - Method in class org.apache.lucene.util.WeakIdentityMap
- 
Returns trueif this map contains no key-value mappings.
 
- isEmptyString() - Method in class org.apache.lucene.util.automaton.Automaton
- 
- isEmptyString(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns true if the given automaton accepts the empty string and nothing
 else. 
- isEnabled(String) - Method in class org.apache.lucene.util.InfoStream
- 
- isEnabled(String) - Method in class org.apache.lucene.util.PrintStreamInfoStream
-  
- isExternal - Variable in class org.apache.lucene.store.MergeInfo
-  
- isFinal - Variable in class org.apache.lucene.util.fst.Builder.Arc
-  
- isFinal - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- isFinal() - Method in class org.apache.lucene.util.fst.FST.Arc
-  
- isFinite(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
- 
Returns true if the language of this automaton is finite. 
- isGreedy() - Method in class org.apache.lucene.search.TimeLimitingCollector
- 
Checks if this time limited collector is greedy in collecting the last hit. 
- isIndexed() - Method in enum org.apache.lucene.document.Field.Index
- 
Deprecated. 
- isIndexed() - Method in class org.apache.lucene.index.FieldInfo
- 
Returns true if this field is indexed. 
- isInOrder() - Method in class org.apache.lucene.search.spans.SpanNearQuery
- 
Return true if matches are required to be in-order. 
- isKeyword() - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
- 
Returns trueif the current token is a keyword, otherwisefalse
 
- isKeyword() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-  
- isLast() - Method in class org.apache.lucene.util.fst.FST.Arc
-  
- isLocked(Directory) - Static method in class org.apache.lucene.index.IndexWriter
- 
Returns trueiff the index in the named directory is
 currently locked.
 
- isLocked() - Method in class org.apache.lucene.store.Lock
- 
Returns true if the resource is currently locked. 
- isMatch() - Method in class org.apache.lucene.search.ComplexExplanation
- 
Indicates whether or not this Explanation models a good match. 
- isMatch() - Method in class org.apache.lucene.search.Explanation
- 
Indicates whether or not this Explanation models a good match. 
- isMerged(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.LogMergePolicy
- 
Returns true if the number of segments eligible for
  merging is less than or equal to the specified maxNumSegments.
 
- isMerged(SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy
- 
Returns true if this single info is already fully merged (has no
  pending deletes, is in the same dir as the
  writer, and matches the current compound file setting 
- isOpen - Variable in class org.apache.lucene.store.BaseDirectory
-  
- isOverriddenAsOf(Class<? extends C>) - Method in class org.apache.lucene.util.VirtualMethod
- 
Returns, if this method is overridden/implemented in the inheritance path between
 baseClassand the given subclasssubclazz.
 
- isParentClassLoader(ClassLoader, ClassLoader) - Static method in class org.apache.lucene.util.SPIClassIterator
- 
Utility method to check if some class loader is a (grand-)parent of or the same as another one. 
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.Spans
- 
Checks if a payload can be loaded at this position. 
- isPayloadAvailable() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- isProhibited() - Method in class org.apache.lucene.search.BooleanClause
-  
- isRequired() - Method in class org.apache.lucene.search.BooleanClause
-  
- isSearcherCurrent() - Method in class org.apache.lucene.search.SearcherManager
- 
Returns trueif no changes have occured since this searcher
 ie.
 
- isStored() - Method in enum org.apache.lucene.document.Field.TermVector
- 
Deprecated. 
- isSupported(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
- 
Tests whether the provided number of bits per value is supported by the
 format. 
- isSupportedJVM() - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns true, if the current JVM is fully supported by RamUsageEstimator.
 
- isSystemStream() - Method in class org.apache.lucene.util.PrintStreamInfoStream
-  
- isTopLevel - Variable in class org.apache.lucene.index.IndexReaderContext
- 
trueif this context struct represents the top level reader within the hierarchical context
 
- isTotal(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns true if the given automaton accepts all strings. 
- isValid() - Method in class org.apache.lucene.util.BytesRef
- 
Performs internal consistency checks. 
- isValid() - Method in class org.apache.lucene.util.CharsRef
- 
Performs internal consistency checks. 
- isValid() - Method in class org.apache.lucene.util.IntsRef
- 
Performs internal consistency checks. 
- isValid() - Method in class org.apache.lucene.util.LongsRef
- 
Performs internal consistency checks. 
- iterator(TermsEnum) - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
-  
- iterator() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
-  
- iterator() - Method in class org.apache.lucene.document.Document
-  
- iterator(AtomicReader) - Method in class org.apache.lucene.index.DocTermOrds
- 
Returns a SortedSetDocValues view of this instance 
- iterator() - Method in class org.apache.lucene.index.FieldInfos
- 
Returns an iterator over all the fieldinfo objects present,
 ordered by ascending field number 
- iterator() - Method in class org.apache.lucene.index.Fields
- 
Returns an iterator that will step through all fields
  names. 
- iterator() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterFields
-  
- iterator(TermsEnum) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
-  
- iterator() - Method in class org.apache.lucene.index.MultiFields
-  
- iterator(TermsEnum) - Method in class org.apache.lucene.index.MultiTerms
-  
- iterator() - Method in class org.apache.lucene.index.SegmentInfos
- 
Returns an  unmodifiableIterator of contained segments in order. 
- iterator(TermsEnum) - Method in class org.apache.lucene.index.Terms
- 
Returns an iterator that will step through all
  terms. 
- iterator() - Method in class org.apache.lucene.search.BooleanQuery
- 
Returns an iterator on the clauses in this query. 
- iterator() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-  
- iterator() - Method in class org.apache.lucene.search.DocIdSet
- 
- iterator() - Method in class org.apache.lucene.search.FieldCacheDocIdSet
-  
- iterator() - Method in class org.apache.lucene.search.FilteredDocIdSet
- 
Implementation of the contract to build a DocIdSetIterator. 
- iterator() - Method in class org.apache.lucene.util.DocIdBitSet
-  
- iterator() - Method in class org.apache.lucene.util.FixedBitSet
-  
- iterator() - Method in class org.apache.lucene.util.NamedSPILoader
-  
- iterator() - Method in class org.apache.lucene.util.OpenBitSet
-  
- iterator() - Method in class org.apache.lucene.util.packed.EliasFanoDocIdSet
- 
- iterator() - Method in class org.apache.lucene.util.PForDeltaDocIdSet
-  
- iterator() - Method in class org.apache.lucene.util.WAH8DocIdSet
-  
- L16_L - Static variable in class org.apache.lucene.util.BroadWord
-  
- L8_L - Static variable in class org.apache.lucene.util.BroadWord
- 
Lk denotes the constant whose ones are in position 0, k, 2k, . 
- L9_L - Static variable in class org.apache.lucene.util.BroadWord
-  
- label - Variable in class org.apache.lucene.util.fst.Builder.Arc
-  
- label - Variable in class org.apache.lucene.util.fst.FST.Arc
-  
- lambda - Variable in class org.apache.lucene.search.similarities.IBSimilarity
- 
The lambda (λw) parameter. 
- Lambda - Class in org.apache.lucene.search.similarities
- 
The lambda (λw) parameter in information-based
 models. 
- Lambda() - Constructor for class org.apache.lucene.search.similarities.Lambda
- 
Sole constructor. 
- lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.Lambda
- 
Computes the lambda parameter. 
- lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaDF
-  
- lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaTTF
-  
- LambdaDF - Class in org.apache.lucene.search.similarities
- 
Computes lambda as docFreq+1 / numberOfDocuments+1.
 
- LambdaDF() - Constructor for class org.apache.lucene.search.similarities.LambdaDF
- 
Sole constructor: parameter-free 
- LambdaTTF - Class in org.apache.lucene.search.similarities
- 
Computes lambda as totalTermFreq+1 / numberOfDocuments+1.
 
- LambdaTTF() - Constructor for class org.apache.lucene.search.similarities.LambdaTTF
- 
Sole constructor: parameter-free 
- lastCommit - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
- lastDocBase - Variable in class org.apache.lucene.search.CachingCollector
-  
- leafContexts - Variable in class org.apache.lucene.search.IndexSearcher
-  
- leafSlices - Variable in class org.apache.lucene.search.IndexSearcher
- 
used with executor - each slice holds a set of leafs executed within one thread 
- LEAP_FROG_FILTER_FIRST_STRATEGY - Static variable in class org.apache.lucene.search.FilteredQuery
- 
A filter strategy that uses a "leap-frog" approach (also called "zig-zag join"). 
- LEAP_FROG_QUERY_FIRST_STRATEGY - Static variable in class org.apache.lucene.search.FilteredQuery
- 
A filter strategy that uses a "leap-frog" approach (also called "zig-zag join"). 
- leaves() - Method in class org.apache.lucene.index.AtomicReaderContext
-  
- leaves() - Method in class org.apache.lucene.index.CompositeReaderContext
-  
- leaves() - Method in class org.apache.lucene.index.IndexReader
- 
Returns the reader's leaves, or itself if this reader is atomic. 
- leaves() - Method in class org.apache.lucene.index.IndexReaderContext
- 
Returns the context's leaves if this context is a top-level context. 
- length() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- length() - Method in class org.apache.lucene.codecs.DocValuesProducer.SortedDocsWithField
-  
- length() - Method in class org.apache.lucene.codecs.DocValuesProducer.SortedSetDocsWithField
-  
- length - Variable in class org.apache.lucene.index.ReaderSlice
- 
Number of documents in this slice. 
- length() - Method in class org.apache.lucene.store.BufferedIndexOutput
-  
- length() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- length() - Method in class org.apache.lucene.store.ChecksumIndexInput
-  
- length() - Method in class org.apache.lucene.store.ChecksumIndexOutput
-  
- length() - Method in class org.apache.lucene.store.FSDirectory.FSIndexInput
-  
- length() - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
-  
- length() - Method in class org.apache.lucene.store.IndexInput
- 
The number of bytes in the file. 
- length() - Method in class org.apache.lucene.store.IndexOutput
- 
The number of bytes in the file. 
- length() - Method in class org.apache.lucene.store.RAMInputStream
-  
- length() - Method in class org.apache.lucene.store.RAMOutputStream
-  
- length() - Method in interface org.apache.lucene.util.Bits
- 
Returns the number of bits in this set 
- length() - Method in class org.apache.lucene.util.Bits.MatchAllBits
-  
- length() - Method in class org.apache.lucene.util.Bits.MatchNoBits
-  
- length - Variable in class org.apache.lucene.util.BytesRef
- 
Length of used bytes. 
- length - Variable in class org.apache.lucene.util.CharsRef
- 
Length of used characters. 
- length() - Method in class org.apache.lucene.util.CharsRef
-  
- length() - Method in class org.apache.lucene.util.DocIdBitSet
-  
- length() - Method in class org.apache.lucene.util.FixedBitSet
-  
- length - Variable in class org.apache.lucene.util.GrowableByteArrayDataOutput
- 
The length 
- length - Variable in class org.apache.lucene.util.IntsRef
- 
Length of used ints. 
- length() - Method in class org.apache.lucene.util.LongBitSet
- 
Returns the number of bits stored in this bitset. 
- length - Variable in class org.apache.lucene.util.LongsRef
- 
Length of used longs. 
- length() - Method in class org.apache.lucene.util.OpenBitSet
-  
- lengthNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
- lengthNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Compute an index-time normalization value for this field instance. 
- Less(String, BytesRef) - Static method in class org.apache.lucene.search.TermRangeFilter
- 
Constructs a filter for field fieldNamematching
 less than or equal toupperTerm.
 
- lessThan(FieldValueHitQueue.Entry, FieldValueHitQueue.Entry) - Method in class org.apache.lucene.search.FieldValueHitQueue
-  
- lessThan(T, T) - Method in class org.apache.lucene.util.PriorityQueue
- 
Determines the ordering of objects in this priority queue. 
- LEVEL_LOG_SPAN - Static variable in class org.apache.lucene.index.LogMergePolicy
- 
Defines the allowed range of log(size) for each
  level. 
- LEVEL_SIZE_ARRAY - Static variable in class org.apache.lucene.util.ByteBlockPool
- 
An array holding the level sizes for byte slices. 
- LevenshteinAutomata - Class in org.apache.lucene.util.automaton
- 
Class to construct DFAs that match a word within some edit distance. 
- LevenshteinAutomata(String, boolean) - Constructor for class org.apache.lucene.util.automaton.LevenshteinAutomata
- 
Create a new LevenshteinAutomata for some input String. 
- LevenshteinAutomata(int[], int, boolean) - Constructor for class org.apache.lucene.util.automaton.LevenshteinAutomata
- 
Expert: specify a custom maximum possible symbol
 (alphaMax); default is Character.MAX_CODE_POINT. 
- LINUX - Static variable in class org.apache.lucene.util.Constants
- 
True iff running on Linux. 
- listAll() - Method in class org.apache.lucene.store.CompoundFileDirectory
- 
Returns an array of strings, one for each file in the directory. 
- listAll() - Method in class org.apache.lucene.store.Directory
- 
Returns an array of strings, one for each file in the directory. 
- listAll() - Method in class org.apache.lucene.store.FileSwitchDirectory
-  
- listAll() - Method in class org.apache.lucene.store.FilterDirectory
-  
- listAll(File) - Static method in class org.apache.lucene.store.FSDirectory
- 
Lists all files (not subdirectories) in the
  directory. 
- listAll() - Method in class org.apache.lucene.store.FSDirectory
- 
Lists all files (not subdirectories) in the
 directory. 
- listAll() - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- listAll() - Method in class org.apache.lucene.store.RAMDirectory
-  
- listCachedFiles() - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- listCommits(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
- 
Returns all commit points that exist in the Directory. 
- liveDocs - Variable in class org.apache.lucene.index.SegmentWriteState
- 
MutableBits recording live documents; this is
  only set if there is one or more deleted documents. 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.Codec
- 
Encodes/decodes live docs 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-  
- LiveDocsFormat - Class in org.apache.lucene.codecs
- 
Format for live/deleted documents 
- LiveDocsFormat() - Constructor for class org.apache.lucene.codecs.LiveDocsFormat
- 
Sole constructor. 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. 
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
-  
- LiveFieldValues<S,T> - Class in org.apache.lucene.search
- 
Tracks live field values across NRT reader reopens. 
- LiveFieldValues(ReferenceManager<S>, T) - Constructor for class org.apache.lucene.search.LiveFieldValues
-  
- LiveIndexWriterConfig - Class in org.apache.lucene.index
- 
Holds all the configuration used by  IndexWriter with few setters for
 settings that can be changed on an  IndexWriter instance "live". 
- LMDirichletSimilarity - Class in org.apache.lucene.search.similarities
- 
Bayesian smoothing using Dirichlet priors. 
- LMDirichletSimilarity(LMSimilarity.CollectionModel, float) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
- 
Instantiates the similarity with the provided μ parameter. 
- LMDirichletSimilarity(float) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
- 
Instantiates the similarity with the provided μ parameter. 
- LMDirichletSimilarity(LMSimilarity.CollectionModel) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
- 
Instantiates the similarity with the default μ value of 2000. 
- LMDirichletSimilarity() - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
- 
Instantiates the similarity with the default μ value of 2000. 
- LMJelinekMercerSimilarity - Class in org.apache.lucene.search.similarities
- 
Language model based on the Jelinek-Mercer smoothing method. 
- LMJelinekMercerSimilarity(LMSimilarity.CollectionModel, float) - Constructor for class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
- 
Instantiates with the specified collectionModel and λ parameter. 
- LMJelinekMercerSimilarity(float) - Constructor for class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
- 
Instantiates with the specified λ parameter. 
- LMSimilarity - Class in org.apache.lucene.search.similarities
- 
Abstract superclass for language modeling Similarities. 
- LMSimilarity(LMSimilarity.CollectionModel) - Constructor for class org.apache.lucene.search.similarities.LMSimilarity
- 
Creates a new instance with the specified collection language model. 
- LMSimilarity() - Constructor for class org.apache.lucene.search.similarities.LMSimilarity
- 
Creates a new instance with the default collection language model. 
- LMSimilarity.CollectionModel - Interface in org.apache.lucene.search.similarities
- 
A strategy for computing the collection language model. 
- LMSimilarity.DefaultCollectionModel - Class in org.apache.lucene.search.similarities
- 
Models p(w|C)as the number of occurrences of the term in the
 collection, divided by the total number of tokens+ 1.
 
- LMSimilarity.DefaultCollectionModel() - Constructor for class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
- 
Sole constructor: parameter-free 
- LMSimilarity.LMStats - Class in org.apache.lucene.search.similarities
- 
Stores the collection distribution of the current term. 
- LMSimilarity.LMStats(String, float) - Constructor for class org.apache.lucene.search.similarities.LMSimilarity.LMStats
- 
Creates LMStats for the provided field and query-time boost 
- loadDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
- 
Loads a specific Directory implementation 
- loadFSDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
- 
Loads a specific FSDirectory implementation 
- Lock - Class in org.apache.lucene.store
- 
An interprocess mutex lock. 
- Lock() - Constructor for class org.apache.lucene.store.Lock
-  
- Lock.With - Class in org.apache.lucene.store
- 
Utility class for executing code with exclusive access. 
- Lock.With(Lock, long) - Constructor for class org.apache.lucene.store.Lock.With
- 
Constructs an executor that will grab the named lock. 
- LOCK_OBTAIN_WAIT_FOREVER - Static variable in class org.apache.lucene.store.Lock
- 
- LOCK_POLL_INTERVAL - Static variable in class org.apache.lucene.store.Lock
- 
How long  Lock.obtain(long) waits, in milliseconds,
  in between attempts to acquire the lock. 
- lockDir - Variable in class org.apache.lucene.store.FSLockFactory
- 
Directory for the lock files. 
- lockFactory - Variable in class org.apache.lucene.store.BaseDirectory
- 
Holds the LockFactory instance (implements locking for
 this Directory instance). 
- LockFactory - Class in org.apache.lucene.store
- 
Base class for Locking implementation. 
- LockFactory() - Constructor for class org.apache.lucene.store.LockFactory
-  
- LockObtainFailedException - Exception in org.apache.lucene.store
- 
This exception is thrown when the write.lockcould not be acquired.
 
- LockObtainFailedException(String) - Constructor for exception org.apache.lucene.store.LockObtainFailedException
-  
- lockPrefix - Variable in class org.apache.lucene.store.LockFactory
-  
- LockReleaseFailedException - Exception in org.apache.lucene.store
- 
This exception is thrown when the write.lockcould not be released.
 
- LockReleaseFailedException(String) - Constructor for exception org.apache.lucene.store.LockReleaseFailedException
-  
- LockStressTest - Class in org.apache.lucene.store
- 
Simple standalone tool that forever acquires & releases a
 lock using a specific LockFactory. 
- LockStressTest() - Constructor for class org.apache.lucene.store.LockStressTest
-  
- LockVerifyServer - Class in org.apache.lucene.store
- 
- LockVerifyServer() - Constructor for class org.apache.lucene.store.LockVerifyServer
-  
- log(long, int) - Static method in class org.apache.lucene.util.MathUtil
- 
Returns x <= 0 ? 0 : Math.floor(Math.log(x) / Math.log(base))
 
- log(double, double) - Static method in class org.apache.lucene.util.MathUtil
- 
Calculates logarithm in a given base with doubles. 
- log2(double) - Static method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Returns the base two logarithm of x.
 
- LOG2_E - Static variable in class org.apache.lucene.search.similarities.BasicModelP
- 
log2(Math.E), precomputed.
 
- LogByteSizeMergePolicy - Class in org.apache.lucene.index
- 
This is a  LogMergePolicy that measures size of a
  segment as the total byte size of the segment's files. 
- LogByteSizeMergePolicy() - Constructor for class org.apache.lucene.index.LogByteSizeMergePolicy
- 
Sole constructor, setting all settings to their
  defaults. 
- LogDocMergePolicy - Class in org.apache.lucene.index
- 
This is a  LogMergePolicy that measures size of a
  segment as the number of documents (not taking deletions
  into account). 
- LogDocMergePolicy() - Constructor for class org.apache.lucene.index.LogDocMergePolicy
- 
Sole constructor, setting all settings to their
  defaults. 
- LogMergePolicy - Class in org.apache.lucene.index
- 
This class implements a  MergePolicy that tries
 to merge segments into levels of exponentially
 increasing size, where each level has fewer segments than
 the value of the merge factor. 
- LogMergePolicy() - Constructor for class org.apache.lucene.index.LogMergePolicy
- 
Sole constructor. 
- LongBitSet - Class in org.apache.lucene.util
- 
BitSet of fixed length (numBits), backed by accessible ( LongBitSet.getBits())
 long[], accessed with a long index. 
- LongBitSet(long) - Constructor for class org.apache.lucene.util.LongBitSet
-  
- LongBitSet(long[], long) - Constructor for class org.apache.lucene.util.LongBitSet
-  
- longBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
The minimum number of long blocks to encode in a single iteration, when
 using long encoding. 
- longBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
The minimum number of long blocks to encode in a single iteration, when
 using long encoding. 
- longCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
- 
Computes how many long blocks are needed to store valuesvalues of sizebitsPerValue.
 
- LongDocValuesField - Class in org.apache.lucene.document
- 
- LongDocValuesField(String, long) - Constructor for class org.apache.lucene.document.LongDocValuesField
- 
Deprecated. Creates a new DocValues field with the specified 64-bit long value 
- longField(FieldInfo, long) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-  
- LongField - Class in org.apache.lucene.document
- 
 Field that indexes longvalues
 for efficient range filtering and sorting.
 
- LongField(String, long, Field.Store) - Constructor for class org.apache.lucene.document.LongField
- 
- LongField(String, long, FieldType) - Constructor for class org.apache.lucene.document.LongField
- 
Expert: allows you to customize the  FieldType. 
- longField(FieldInfo, long) - Method in class org.apache.lucene.index.StoredFieldVisitor
- 
Process a long numeric field. 
- longHex(long) - Static method in class org.apache.lucene.util.ToStringUtils
-  
- longs - Variable in class org.apache.lucene.util.LongsRef
- 
The contents of the LongsRef. 
- longsEquals(LongsRef) - Method in class org.apache.lucene.util.LongsRef
-  
- LongsRef - Class in org.apache.lucene.util
- 
Represents long[], as a slice (offset + length) into an
  existing long[]. 
- LongsRef() - Constructor for class org.apache.lucene.util.LongsRef
- 
- LongsRef(int) - Constructor for class org.apache.lucene.util.LongsRef
- 
Create a LongsRef pointing to a new array of size capacity.
 
- LongsRef(long[], int, int) - Constructor for class org.apache.lucene.util.LongsRef
- 
This instance will directly reference longs w/o making a copy. 
- longToPrefixCoded(long, int, BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
- 
Returns prefix coded bits after reducing the precision by shiftbits.
 
- longToPrefixCodedBytes(long, int, BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
- 
Returns prefix coded bits after reducing the precision by shiftbits.
 
- longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
- 
- longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
- 
- LongValues - Class in org.apache.lucene.util
- 
Abstraction over an array of longs. 
- LongValues() - Constructor for class org.apache.lucene.util.LongValues
-  
- lookup(String) - Method in class org.apache.lucene.util.NamedSPILoader
-  
- lookupFromSearcher(S, String) - Method in class org.apache.lucene.search.LiveFieldValues
- 
This is called when the id/value was already flushed & opened
  in an NRT IndexSearcher. 
- lookupOrd(int, BytesRef) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-  
- lookupOrd(long, BytesRef) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-  
- lookupOrd(long, BytesRef) - Method in class org.apache.lucene.index.SingletonSortedSetDocValues
-  
- lookupOrd(int, BytesRef) - Method in class org.apache.lucene.index.SortedDocValues
- 
Retrieves the value for the specified ordinal. 
- lookupOrd(long, BytesRef) - Method in class org.apache.lucene.index.SortedSetDocValues
- 
Retrieves the value for the specified ordinal. 
- lookupTerm(TermsEnum, int) - Method in class org.apache.lucene.index.DocTermOrds
- 
Returns the term ( BytesRef) corresponding to
  the provided ordinal. 
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SingletonSortedSetDocValues
-  
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedDocValues
- 
If keyexists, returns its ordinal, else
  returns-insertionPoint-1, likeArrays.binarySearch.
 
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedSetDocValues
- 
If keyexists, returns its ordinal, else
  returns-insertionPoint-1, likeArrays.binarySearch.
 
- Lucene3xCodec - Class in org.apache.lucene.codecs.lucene3x
- 
Deprecated.
Only for reading existing 3.x indexes 
 
- Lucene3xCodec() - Constructor for class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- Lucene3xSegmentInfoFormat - Class in org.apache.lucene.codecs.lucene3x
- 
Deprecated.
(4.0) This is only used to read indexes created
 before 4.0. 
 
- Lucene3xSegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- Lucene3xSegmentInfoReader - Class in org.apache.lucene.codecs.lucene3x
- 
Deprecated.
Only for reading existing 3.x indexes 
 
- Lucene3xSegmentInfoReader() - Constructor for class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoReader
- 
Deprecated. 
- Lucene40Codec - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 segments 
 
- Lucene40Codec() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. Sole constructor. 
- Lucene40DocValuesFormat - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 and 4.1 segments 
 
- Lucene40DocValuesFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40DocValuesFormat
- 
Deprecated. Sole constructor. 
- Lucene40FieldInfosFormat - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 and 4.1 segments 
 
- Lucene40FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40FieldInfosFormat
- 
Deprecated. Sole constructor. 
- Lucene40LiveDocsFormat - Class in org.apache.lucene.codecs.lucene40
- 
Lucene 4.0 Live Documents Format. 
- Lucene40LiveDocsFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40LiveDocsFormat
- 
Sole constructor. 
- Lucene40NormsFormat - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 and 4.1 segments 
 
- Lucene40NormsFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40NormsFormat
- 
Deprecated. Sole constructor. 
- Lucene40PostingsBaseFormat - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 segments 
 
- Lucene40PostingsBaseFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40PostingsBaseFormat
- 
Deprecated. Sole constructor. 
- Lucene40PostingsFormat - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 segments 
 
- Lucene40PostingsFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
- 
Deprecated. Creates Lucene40PostingsFormatwith default
  settings.
 
- Lucene40PostingsReader - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 segments 
 
- Lucene40PostingsReader(Directory, FieldInfos, SegmentInfo, IOContext, String) - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. Sole constructor. 
- Lucene40SegmentInfoFormat - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0-4.5 segments, and supporting IndexWriter.addIndexes 
 
- Lucene40SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40SegmentInfoFormat
- 
Deprecated. Sole constructor. 
- Lucene40SegmentInfoReader - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0-4.5 segments 
 
- Lucene40SegmentInfoReader() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40SegmentInfoReader
- 
Deprecated. Sole constructor. 
- Lucene40SegmentInfoWriter - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated. 
- Lucene40SegmentInfoWriter() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40SegmentInfoWriter
- 
Deprecated. Sole constructor. 
- Lucene40SkipListReader - Class in org.apache.lucene.codecs.lucene40
- 
Deprecated.
Only for reading old 4.0 segments 
 
- Lucene40SkipListReader(IndexInput, int, int) - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. Sole constructor. 
- Lucene40StoredFieldsFormat - Class in org.apache.lucene.codecs.lucene40
- 
Lucene 4.0 Stored Fields Format. 
- Lucene40StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsFormat
- 
Sole constructor. 
- Lucene40StoredFieldsReader - Class in org.apache.lucene.codecs.lucene40
- 
Class responsible for access to stored document fields. 
- Lucene40StoredFieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
- 
Sole constructor. 
- Lucene40StoredFieldsWriter - Class in org.apache.lucene.codecs.lucene40
- 
Class responsible for writing stored document fields. 
- Lucene40StoredFieldsWriter(Directory, String, IOContext) - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
- 
Sole constructor. 
- Lucene40TermVectorsFormat - Class in org.apache.lucene.codecs.lucene40
- 
Lucene 4.0 Term Vectors format. 
- Lucene40TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsFormat
- 
Sole constructor. 
- Lucene40TermVectorsReader - Class in org.apache.lucene.codecs.lucene40
- 
Lucene 4.0 Term Vectors reader. 
- Lucene40TermVectorsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
- 
Sole constructor. 
- Lucene40TermVectorsWriter - Class in org.apache.lucene.codecs.lucene40
- 
Lucene 4.0 Term Vectors writer. 
- Lucene40TermVectorsWriter(Directory, String, IOContext) - Constructor for class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
- 
Sole constructor. 
- Lucene41Codec - Class in org.apache.lucene.codecs.lucene41
- 
Deprecated.
Only for reading old 4.0 segments 
 
- Lucene41Codec() - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. Sole constructor. 
- Lucene41PostingsBaseFormat - Class in org.apache.lucene.codecs.lucene41
- 
- Lucene41PostingsBaseFormat() - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41PostingsBaseFormat
- 
Sole constructor. 
- Lucene41PostingsFormat - Class in org.apache.lucene.codecs.lucene41
- 
Lucene 4.1 postings format, which encodes postings in packed integer blocks 
 for fast decode. 
- Lucene41PostingsFormat() - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
- 
Creates Lucene41PostingsFormatwith default
  settings.
 
- Lucene41PostingsFormat(int, int) - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
- 
Creates Lucene41PostingsFormatwith custom
  values forminBlockSizeandmaxBlockSizepassed to block terms dictionary.
 
- Lucene41PostingsReader - Class in org.apache.lucene.codecs.lucene41
- 
Concrete class that reads docId(maybe frq,pos,offset,payloads) list
 with postings format. 
- Lucene41PostingsReader(Directory, FieldInfos, SegmentInfo, IOContext, String) - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
- 
Sole constructor. 
- Lucene41PostingsWriter - Class in org.apache.lucene.codecs.lucene41
- 
Concrete class that writes docId(maybe frq,pos,offset,payloads) list
 with postings format. 
- Lucene41PostingsWriter(SegmentWriteState, float) - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
- 
Creates a postings writer with the specified PackedInts overhead ratio 
- Lucene41PostingsWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
- 
Creates a postings writer with PackedInts.COMPACT
 
- Lucene41StoredFieldsFormat - Class in org.apache.lucene.codecs.lucene41
- 
Lucene 4.1 stored fields format. 
- Lucene41StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.lucene41.Lucene41StoredFieldsFormat
- 
Sole constructor. 
- Lucene42Codec - Class in org.apache.lucene.codecs.lucene42
- 
Deprecated.
Only for reading old 4.2 segments 
 
- Lucene42Codec() - Constructor for class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. Sole constructor. 
- Lucene42DocValuesFormat - Class in org.apache.lucene.codecs.lucene42
- 
Deprecated.
Only for reading old 4.2 segments 
 
- Lucene42DocValuesFormat() - Constructor for class org.apache.lucene.codecs.lucene42.Lucene42DocValuesFormat
- 
Deprecated. 
- Lucene42DocValuesFormat(float) - Constructor for class org.apache.lucene.codecs.lucene42.Lucene42DocValuesFormat
- 
Deprecated. Creates a new Lucene42DocValuesFormat with the specified
 acceptableOverheadRatiofor NumericDocValues.
 
- Lucene42FieldInfosFormat - Class in org.apache.lucene.codecs.lucene42
- 
Deprecated.
Only for reading old 4.2-4.5 segments 
 
- Lucene42FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.lucene42.Lucene42FieldInfosFormat
- 
Deprecated. Sole constructor. 
- Lucene42NormsFormat - Class in org.apache.lucene.codecs.lucene42
- 
Lucene 4.2 score normalization format. 
- Lucene42NormsFormat() - Constructor for class org.apache.lucene.codecs.lucene42.Lucene42NormsFormat
- 
- Lucene42NormsFormat(float) - Constructor for class org.apache.lucene.codecs.lucene42.Lucene42NormsFormat
- 
Creates a new Lucene42DocValuesFormat with the specified
 acceptableOverheadRatiofor NumericDocValues.
 
- Lucene42TermVectorsFormat - Class in org.apache.lucene.codecs.lucene42
- 
- Lucene42TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene42.Lucene42TermVectorsFormat
- 
Sole constructor. 
- Lucene45Codec - Class in org.apache.lucene.codecs.lucene45
- 
Deprecated.
Only for reading old 4.3-4.5 segments 
 
- Lucene45Codec() - Constructor for class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. Sole constructor. 
- Lucene45DocValuesConsumer - Class in org.apache.lucene.codecs.lucene45
- 
- Lucene45DocValuesConsumer(SegmentWriteState, String, String, String, String) - Constructor for class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
expert: Creates a new writer 
- Lucene45DocValuesFormat - Class in org.apache.lucene.codecs.lucene45
- 
Lucene 4.5 DocValues format. 
- Lucene45DocValuesFormat() - Constructor for class org.apache.lucene.codecs.lucene45.Lucene45DocValuesFormat
- 
Sole Constructor 
- Lucene45DocValuesProducer - Class in org.apache.lucene.codecs.lucene45
- 
- Lucene45DocValuesProducer(SegmentReadState, String, String, String, String) - Constructor for class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
- 
expert: instantiates a new reader 
- Lucene45DocValuesProducer.BinaryEntry - Class in org.apache.lucene.codecs.lucene45
- 
metadata entry for a binary docvalues field 
- Lucene45DocValuesProducer.NumericEntry - Class in org.apache.lucene.codecs.lucene45
- 
metadata entry for a numeric docvalues field 
- Lucene45DocValuesProducer.SortedSetEntry - Class in org.apache.lucene.codecs.lucene45
- 
metadata entry for a sorted-set docvalues field 
- Lucene46Codec - Class in org.apache.lucene.codecs.lucene46
- 
Implements the Lucene 4.6 index format, with configurable per-field postings
 and docvalues formats. 
- Lucene46Codec() - Constructor for class org.apache.lucene.codecs.lucene46.Lucene46Codec
- 
Sole constructor. 
- Lucene46FieldInfosFormat - Class in org.apache.lucene.codecs.lucene46
- 
Lucene 4.6 Field Infos format. 
- Lucene46FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.lucene46.Lucene46FieldInfosFormat
- 
Sole constructor. 
- Lucene46SegmentInfoFormat - Class in org.apache.lucene.codecs.lucene46
- 
Lucene 4.6 Segment info format. 
- Lucene46SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene46.Lucene46SegmentInfoFormat
- 
Sole constructor. 
- Lucene46SegmentInfoReader - Class in org.apache.lucene.codecs.lucene46
- 
- Lucene46SegmentInfoReader() - Constructor for class org.apache.lucene.codecs.lucene46.Lucene46SegmentInfoReader
- 
Sole constructor. 
- Lucene46SegmentInfoWriter - Class in org.apache.lucene.codecs.lucene46
- 
- Lucene46SegmentInfoWriter() - Constructor for class org.apache.lucene.codecs.lucene46.Lucene46SegmentInfoWriter
- 
Sole constructor. 
- LUCENE_MAIN_VERSION - Static variable in class org.apache.lucene.util.Constants
- 
This is the internal Lucene version, recorded into each segment. 
- LUCENE_VERSION - Static variable in class org.apache.lucene.util.Constants
- 
This is the Lucene version for display purposes. 
- LucenePackage - Class in org.apache.lucene
- 
Lucene's package information, including version. 
- MAC_OS_X - Static variable in class org.apache.lucene.util.Constants
- 
True iff running on Mac OS X 
- main(String[]) - Static method in class org.apache.lucene.index.CheckIndex
- 
Command-line interface to check and fix an index. 
- main(String[]) - Static method in class org.apache.lucene.index.IndexUpgrader
- 
Main method to run {code IndexUpgrader} from the
  command-line. 
- main(String[]) - Static method in class org.apache.lucene.store.LockStressTest
-  
- main(String[]) - Static method in class org.apache.lucene.store.LockVerifyServer
-  
- makeAnyChar() - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic) automaton that accepts any single codepoint. 
- makeAnyString() - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic) automaton that accepts all strings. 
- makeChar(int) - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic) automaton that accepts a single codepoint of
 the given value. 
- makeCharRange(int, int) - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic) automaton that accepts a single codepoint whose
 value is in the given interval (including both end points). 
- makeEmpty() - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic) automaton with the empty language. 
- makeEmptyString() - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic) automaton that accepts only the empty string. 
- makeInterval(int, int, int) - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new automaton that accepts strings representing decimal
 non-negative integers in the given interval. 
- makeLock(String) - Method in class org.apache.lucene.store.BaseDirectory
-  
- makeLock(String) - Method in class org.apache.lucene.store.CompoundFileDirectory
- 
Not implemented 
- makeLock(String) - Method in class org.apache.lucene.store.Directory
- 
- makeLock(String) - Method in class org.apache.lucene.store.FilterDirectory
-  
- makeLock(String) - Method in class org.apache.lucene.store.LockFactory
- 
Return a new Lock instance identified by lockName. 
- makeLock(String) - Method in class org.apache.lucene.store.NativeFSLockFactory
-  
- makeLock(String) - Method in class org.apache.lucene.store.NoLockFactory
-  
- makeLock(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- makeLock(String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
-  
- makeLock(String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
-  
- makeLock(String) - Method in class org.apache.lucene.store.VerifyingLockFactory
-  
- makeString(String) - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic) automaton that accepts the single given
 string. 
- makeString(int[], int, int) - Static method in class org.apache.lucene.util.automaton.BasicAutomata
-  
- makeStringUnion(Collection<BytesRef>) - Static method in class org.apache.lucene.util.automaton.BasicAutomata
- 
Returns a new (deterministic and minimal) automaton that accepts the union
 of the given collection of  BytesRefs representing UTF-8 encoded
 strings. 
- map(int) - Method in class org.apache.lucene.index.MergePolicy.DocMap
- 
Return the new doc ID according to its old value. 
- MapOfSets<K,V> - Class in org.apache.lucene.util
- 
Helper class for keeping Lists of Objects associated with keys. 
- MapOfSets(Map<K, Set<V>>) - Constructor for class org.apache.lucene.util.MapOfSets
-  
- mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
- 
ordinal map mapping ords from valuesto global ord space
 
- mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
- 
ordinal map mapping ords from valuesto global ord space
 
- MappingMultiDocsAndPositionsEnum - Class in org.apache.lucene.codecs
- 
Exposes flex API, merged from flex API of sub-segments,
 remapping docIDs (this is used for segment merging). 
- MappingMultiDocsAndPositionsEnum() - Constructor for class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
- 
Sole constructor. 
- MappingMultiDocsEnum - Class in org.apache.lucene.codecs
- 
Exposes flex API, merged from flex API of sub-segments,
 remapping docIDs (this is used for segment merging). 
- MappingMultiDocsEnum() - Constructor for class org.apache.lucene.codecs.MappingMultiDocsEnum
- 
Sole constructor. 
- match(int) - Method in class org.apache.lucene.search.BitsFilteredDocIdSet
-  
- match(int) - Method in class org.apache.lucene.search.FilteredDocIdSet
- 
Validation method to determine whether a docid should be in the result set. 
- match(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
- 
Validation method to determine whether a docid should be in the result set. 
- match - Variable in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-  
- MatchAllDocsQuery - Class in org.apache.lucene.search
- 
A query that matches all documents. 
- MatchAllDocsQuery() - Constructor for class org.apache.lucene.search.MatchAllDocsQuery
-  
- matchDoc(int) - Method in class org.apache.lucene.search.FieldCacheDocIdSet
- 
this method checks, if a doc is a hit 
- matchedCount - Variable in class org.apache.lucene.index.MergeState
- 
- matchesExtension(String, String) - Static method in class org.apache.lucene.index.IndexFileNames
- 
Returns true if the given filename ends with the given extension. 
- matchingSegmentReaders - Variable in class org.apache.lucene.index.MergeState
- 
SegmentReaders that have identical field
 name/number mapping, so their stored fields and term
 vectors may be bulk merged. 
- matchVersion - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- MathUtil - Class in org.apache.lucene.util
- 
Math static utility methods. 
- MAX_ARRAY_LENGTH - Static variable in class org.apache.lucene.util.ArrayUtil
- 
Maximum length for an array; we set this to "a
  bit" below Integer.MAX_VALUE because the exact max
  allowed byte[] is JVM dependent, so we want to avoid
  a case where a large value worked during indexing on
  one JVM but failed later at search time with a
  different JVM. 
- MAX_BINARY_FIELD_LENGTH - Static variable in class org.apache.lucene.codecs.lucene40.Lucene40DocValuesFormat
- 
Deprecated. Maximum length for each binary doc values field. 
- MAX_BINARY_FIELD_LENGTH - Static variable in class org.apache.lucene.codecs.lucene42.Lucene42DocValuesFormat
- 
Deprecated. Maximum length for each binary doc values field. 
- MAX_TERM_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
- 
Absolute hard maximum length for a term, in bytes once
 encoded as UTF8. 
- maxBlockSize - Variable in class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
- 
Deprecated. maximum items (terms or sub-blocks) per block for BlockTree 
- maxBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-  
- maxBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-  
- maxCFSSegmentSize - Variable in class org.apache.lucene.index.MergePolicy
- 
If the size of the merged segment exceeds
  this value then it will not use compound file format. 
- maxCoord - Variable in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- maxDoc() - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- maxDoc() - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- maxDoc() - Method in class org.apache.lucene.index.IndexReader
- 
Returns one greater than the largest possible document number. 
- maxDoc() - Method in class org.apache.lucene.index.IndexWriter
- 
Returns total number of docs in this index, including
  docs not yet flushed (still in the RAM buffer),
  not counting deletions. 
- maxDoc() - Method in class org.apache.lucene.index.MergeState.DocMap
- 
Returns the total number of documents, ignoring
  deletions. 
- maxDoc() - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- maxDoc() - Method in class org.apache.lucene.index.SegmentReader
-  
- maxDoc() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- maxDoc() - Method in class org.apache.lucene.search.CollectionStatistics
- 
returns the total number of documents, regardless of 
 whether they all contain values for this field. 
- maxDoc - Variable in class org.apache.lucene.search.FieldCacheDocIdSet
-  
- maxDocsToCache - Variable in class org.apache.lucene.search.CachingCollector
-  
- maxEditDistanceChanged(BytesRef, int, boolean) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- maxEdits - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- MAXIMUM_SUPPORTED_DISTANCE - Static variable in class org.apache.lucene.util.automaton.LevenshteinAutomata
-  
- maxMergeDocs - Variable in class org.apache.lucene.index.LogMergePolicy
- 
If a segment has more than this many documents then it
  will never be merged. 
- maxMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
- 
If the size of a segment exceeds this value then it
  will never be merged. 
- maxMergeSizeForForcedMerge - Variable in class org.apache.lucene.index.LogMergePolicy
- 
- MaxNonCompetitiveBoostAttribute - Interface in org.apache.lucene.search
- 
- MaxNonCompetitiveBoostAttributeImpl - Class in org.apache.lucene.search
- 
- MaxNonCompetitiveBoostAttributeImpl() - Constructor for class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-  
- maxNumberOfSkipLevels - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
the maximum number of skip levels possible for this index 
- MaxPayloadFunction - Class in org.apache.lucene.search.payloads
- 
Returns the maximum payload score seen, else 1 if there are no payloads on the doc. 
- MaxPayloadFunction() - Constructor for class org.apache.lucene.search.payloads.MaxPayloadFunction
-  
- maxSegmentName - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
The greatest segment name. 
- maxTermDocFreq - Variable in class org.apache.lucene.index.DocTermOrds
- 
Don't uninvert terms that exceed this count. 
- maxValue(int) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Calculates the maximum unsigned long that can be expressed with the given
 number of bits. 
- maybeMerge() - Method in class org.apache.lucene.index.IndexWriter
- 
Expert: asks the mergePolicy whether any merges are
 necessary now and if so, runs the requested merges and
 then iterate (test again if merges are needed) until no
 more merges are returned by the mergePolicy. 
- maybeRefresh() - Method in class org.apache.lucene.search.ReferenceManager
- 
- maybeRefreshBlocking() - Method in class org.apache.lucene.search.ReferenceManager
- 
- merge(MergeState) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-  
- merge(MergeState) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- merge(MergeState, Fields) - Method in class org.apache.lucene.codecs.FieldsConsumer
- 
Called during merging to merge all  Fields from
  sub-readers. 
- merge(MergeState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
-  
- merge(MergeState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- merge(MergeState, FieldInfo.IndexOptions, DocsEnum, FixedBitSet) - Method in class org.apache.lucene.codecs.PostingsConsumer
- 
Default merge impl: append documents, mapping around
  deletes 
- merge(MergeState) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
- 
Merges in the stored fields from the readers in 
  mergeState.
 
- merge(MergeState, FieldInfo.IndexOptions, TermsEnum) - Method in class org.apache.lucene.codecs.TermsConsumer
- 
Default merge impl 
- merge(MergeState) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Merges in the term vectors from the readers in 
  mergeState.
 
- merge(IndexWriter) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-  
- merge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.IndexWriter
- 
Merges the indicated segments, replacing them in the stack with a
 single segment. 
- merge(IndexWriter) - Method in class org.apache.lucene.index.MergeScheduler
- 
- merge(IndexWriter) - Method in class org.apache.lucene.index.NoMergeScheduler
-  
- merge(IndexWriter) - Method in class org.apache.lucene.index.SerialMergeScheduler
- 
Just do the merges in sequence. 
- merge(Sort, int, TopDocs[]) - Static method in class org.apache.lucene.search.TopDocs
- 
Returns a new TopDocs, containing topN results across
  the provided TopDocs, sorting by the specified  Sort. 
- merge(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
-  
- merge(T, T) - Method in class org.apache.lucene.util.fst.Outputs
-  
- MERGE_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
- 
A buffer size for merges set to 4096. 
- mergeBinaryField(FieldInfo, MergeState, List<BinaryDocValues>, List<Bits>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Merges the binary docvalues from toMerge.
 
- MergedIterator<T extends Comparable<T>> - Class in org.apache.lucene.util
- 
Provides a merged sorted view from several sorted iterators. 
- MergedIterator(Iterator<T>...) - Constructor for class org.apache.lucene.util.MergedIterator
-  
- MergedIterator(boolean, Iterator<T>...) - Constructor for class org.apache.lucene.util.MergedIterator
-  
- mergeFactor - Variable in class org.apache.lucene.index.LogMergePolicy
- 
How many segments to merge at a time. 
- mergeInfo - Variable in class org.apache.lucene.store.IOContext
-  
- MergeInfo - Class in org.apache.lucene.store
- 
A MergeInfo provides information required for a MERGE context. 
- MergeInfo(int, long, boolean, int) - Constructor for class org.apache.lucene.store.MergeInfo
- 
- mergeMaxNumSegments - Variable in class org.apache.lucene.store.MergeInfo
-  
- mergeNumericField(FieldInfo, MergeState, List<NumericDocValues>, List<Bits>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Merges the numeric docvalues from toMerge.
 
- mergePolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- MergePolicy - Class in org.apache.lucene.index
- 
Expert: a MergePolicy determines the sequence of
 primitive merge operations. 
- MergePolicy() - Constructor for class org.apache.lucene.index.MergePolicy
- 
Creates a new merge policy instance. 
- MergePolicy(double, long) - Constructor for class org.apache.lucene.index.MergePolicy
- 
Creates a new merge policy instance with default settings for noCFSRatio
 and maxCFSSegmentSize. 
- MergePolicy.DocMap - Class in org.apache.lucene.index
- 
A map of doc IDs. 
- MergePolicy.DocMap() - Constructor for class org.apache.lucene.index.MergePolicy.DocMap
- 
Sole constructor, typically invoked from sub-classes constructors. 
- MergePolicy.MergeAbortedException - Exception in org.apache.lucene.index
- 
- MergePolicy.MergeAbortedException() - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
- 
- MergePolicy.MergeAbortedException(String) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
- 
- MergePolicy.MergeException - Exception in org.apache.lucene.index
- 
Exception thrown if there are any problems while
  executing a merge. 
- MergePolicy.MergeException(String, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
- 
Create a MergeException.
 
- MergePolicy.MergeException(Throwable, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
- 
Create a MergeException.
 
- MergePolicy.MergeSpecification - Class in org.apache.lucene.index
- 
A MergeSpecification instance provides the information
 necessary to perform multiple merges. 
- MergePolicy.MergeSpecification() - Constructor for class org.apache.lucene.index.MergePolicy.MergeSpecification
- 
Sole constructor. 
- MergePolicy.MergeTrigger - Enum in org.apache.lucene.index
- 
- MergePolicy.OneMerge - Class in org.apache.lucene.index
- 
OneMerge provides the information necessary to perform
  an individual primitive merge operation, resulting in
  a single new segment. 
- MergePolicy.OneMerge(List<SegmentCommitInfo>) - Constructor for class org.apache.lucene.index.MergePolicy.OneMerge
- 
Sole constructor. 
- merges - Variable in class org.apache.lucene.index.MergePolicy.MergeSpecification
- 
The subset of segments to be included in the primitive merge. 
- mergeScheduler - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- MergeScheduler - Class in org.apache.lucene.index
- 
Expert:  IndexWriter uses an instance
  implementing this interface to execute the merges
  selected by a  MergePolicy. 
- MergeScheduler() - Constructor for class org.apache.lucene.index.MergeScheduler
- 
Sole constructor. 
- mergeSortedField(FieldInfo, MergeState, List<SortedDocValues>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Merges the sorted docvalues from toMerge.
 
- mergeSortedSetField(FieldInfo, MergeState, List<SortedSetDocValues>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
- 
Merges the sortedset docvalues from toMerge.
 
- MergeState - Class in org.apache.lucene.index
- 
Holds common state used during segment merging. 
- MergeState.CheckAbort - Class in org.apache.lucene.index
- 
Class for recording units of work when merging segments. 
- MergeState.CheckAbort(MergePolicy.OneMerge, Directory) - Constructor for class org.apache.lucene.index.MergeState.CheckAbort
- 
Creates a #CheckAbort instance. 
- MergeState.DocMap - Class in org.apache.lucene.index
- 
Remaps docids around deletes during merge 
- mergeThreadCount - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
- mergeThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Returns the number of merge threads that are alive. 
- mergeThreads - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
- message(String) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
- message(String) - Method in class org.apache.lucene.index.LogMergePolicy
- 
- message(String, String) - Method in class org.apache.lucene.util.InfoStream
- 
prints a message 
- message(String, String) - Method in class org.apache.lucene.util.PrintStreamInfoStream
-  
- messageID - Variable in class org.apache.lucene.util.PrintStreamInfoStream
-  
- minBlockSize - Variable in class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
- 
Deprecated. minimum items (terms or sub-blocks) per block for BlockTree 
- MinimizationOperations - Class in org.apache.lucene.util.automaton
- 
Operations for minimizing automata. 
- minimize(Automaton) - Static method in class org.apache.lucene.util.automaton.Automaton
- 
- minimize(Automaton) - Static method in class org.apache.lucene.util.automaton.MinimizationOperations
- 
Minimizes (and determinizes if not already deterministic) the given
 automaton. 
- MINIMIZE_HOPCROFT - Static variable in class org.apache.lucene.util.automaton.Automaton
- 
Minimize using Hopcroft's O(n log n) algorithm. 
- minimizeHopcroft(Automaton) - Static method in class org.apache.lucene.util.automaton.MinimizationOperations
- 
Minimizes the given automaton using Hopcroft's algorithm. 
- minMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
- 
Any segments whose size is smaller than this value
  will be rounded up to this value. 
- minNrShouldMatch - Variable in class org.apache.lucene.search.BooleanQuery
-  
- MinPayloadFunction - Class in org.apache.lucene.search.payloads
- 
Calculates the minimum payload seen 
- MinPayloadFunction() - Constructor for class org.apache.lucene.search.payloads.MinPayloadFunction
-  
- minSimilarity - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- minus(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
- 
- minus(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns a (deterministic) automaton that accepts the intersection of the
 language of a1and the complement of the language ofa2.
 
- missingSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
True if we were unable to locate and load the segments_N file. 
- missingSegmentVersion - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
True if we were unable to read the version number from segments_N file. 
- missingValue - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
-  
- missingValue - Variable in class org.apache.lucene.search.SortField
-  
- mixedBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
The number of "internal" blocks (that have both
  terms and sub-blocks). 
- MMapDirectory - Class in org.apache.lucene.store
- 
- MMapDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.MMapDirectory
- 
Create a new MMapDirectory for the named location. 
- MMapDirectory(File) - Constructor for class org.apache.lucene.store.MMapDirectory
- 
- MMapDirectory(File, LockFactory, int) - Constructor for class org.apache.lucene.store.MMapDirectory
- 
Create a new MMapDirectory for the named location, specifying the 
 maximum chunk size used for memory mapping. 
- MonotonicAppendingLongBuffer - Class in org.apache.lucene.util.packed
- 
Utility class to buffer signed longs in memory, which is optimized for the
 case where the sequence is monotonic, although it can encode any sequence of
 arbitrary longs. 
- MonotonicAppendingLongBuffer(int, int, float) - Constructor for class org.apache.lucene.util.packed.MonotonicAppendingLongBuffer
-  
- MonotonicAppendingLongBuffer() - Constructor for class org.apache.lucene.util.packed.MonotonicAppendingLongBuffer
- 
- MonotonicAppendingLongBuffer(float) - Constructor for class org.apache.lucene.util.packed.MonotonicAppendingLongBuffer
- 
- MonotonicBlockPackedReader - Class in org.apache.lucene.util.packed
- 
- MonotonicBlockPackedReader(IndexInput, int, int, long, boolean) - Constructor for class org.apache.lucene.util.packed.MonotonicBlockPackedReader
- 
Sole constructor. 
- MonotonicBlockPackedWriter - Class in org.apache.lucene.util.packed
- 
A writer for large monotonically increasing sequences of positive longs. 
- MonotonicBlockPackedWriter(DataOutput, int) - Constructor for class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
- 
Sole constructor. 
- more - Variable in class org.apache.lucene.search.spans.SpanScorer
-  
- More(String, BytesRef) - Static method in class org.apache.lucene.search.TermRangeFilter
- 
Constructs a filter for field fieldNamematching
 greater than or equal tolowerTerm.
 
- MultiCollector - Class in org.apache.lucene.search
- 
- MultiDocsAndPositionsEnum - Class in org.apache.lucene.index
- 
Exposes flex API, merged from flex API of sub-segments. 
- MultiDocsAndPositionsEnum(MultiTermsEnum, int) - Constructor for class org.apache.lucene.index.MultiDocsAndPositionsEnum
- 
Sole constructor. 
- MultiDocsAndPositionsEnum.EnumWithSlice - Class in org.apache.lucene.index
- 
- MultiDocsEnum - Class in org.apache.lucene.index
- 
- MultiDocsEnum(MultiTermsEnum, int) - Constructor for class org.apache.lucene.index.MultiDocsEnum
- 
Sole constructor 
- MultiDocsEnum.EnumWithSlice - Class in org.apache.lucene.index
- 
- MultiDocValues - Class in org.apache.lucene.index
- 
A wrapper for CompositeIndexReader providing access to DocValues. 
- MultiDocValues.MultiSortedDocValues - Class in org.apache.lucene.index
- 
Implements SortedDocValues over n subs, using an OrdinalMap 
- MultiDocValues.MultiSortedSetDocValues - Class in org.apache.lucene.index
- 
Implements MultiSortedSetDocValues over n subs, using an OrdinalMap 
- MultiDocValues.OrdinalMap - Class in org.apache.lucene.index
- 
maps per-segment ordinals to/from global ordinal space 
- MultiDocValues.OrdinalMap(Object, TermsEnum[]) - Constructor for class org.apache.lucene.index.MultiDocValues.OrdinalMap
- 
Creates an ordinal map that allows mapping ords to/from a merged
 space from subs.
 
- MultiFields - Class in org.apache.lucene.index
- 
Exposes flex API, merged from flex API of sub-segments. 
- MultiFields(Fields[], ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiFields
- 
Expert: construct a new MultiFields instance directly. 
- MultiLevelSkipListReader - Class in org.apache.lucene.codecs
- 
This abstract class reads skip lists with multiple levels. 
- MultiLevelSkipListReader(IndexInput, int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Creates a MultiLevelSkipListReader.
 
- MultiLevelSkipListReader(IndexInput, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Creates a MultiLevelSkipListReader, whereskipIntervalandskipMultiplierare
  the same.
 
- MultiLevelSkipListWriter - Class in org.apache.lucene.codecs
- 
This abstract class writes skip lists with multiple levels. 
- MultiLevelSkipListWriter(int, int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListWriter
- 
Creates a MultiLevelSkipListWriter.
 
- MultiLevelSkipListWriter(int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListWriter
- 
Creates a MultiLevelSkipListWriter, whereskipIntervalandskipMultiplierare
  the same.
 
- MultiPhraseQuery - Class in org.apache.lucene.search
- 
- MultiPhraseQuery() - Constructor for class org.apache.lucene.search.MultiPhraseQuery
-  
- MultiReader - Class in org.apache.lucene.index
- 
- MultiReader(IndexReader...) - Constructor for class org.apache.lucene.index.MultiReader
- 
Construct a MultiReader aggregating the named set of (sub)readers. 
- MultiReader(IndexReader[], boolean) - Constructor for class org.apache.lucene.index.MultiReader
- 
Construct a MultiReader aggregating the named set of (sub)readers. 
- MultiSimilarity - Class in org.apache.lucene.search.similarities
- 
Implements the CombSUM method for combining evidence from multiple
 similarity values described in: Joseph A. 
- MultiSimilarity(Similarity[]) - Constructor for class org.apache.lucene.search.similarities.MultiSimilarity
- 
Creates a MultiSimilarity which will sum the scores
 of the provided sims.
 
- MultiTermQuery - Class in org.apache.lucene.search
- 
An abstract  Query that matches documents
 containing a subset of terms provided by a  FilteredTermsEnum enumeration. 
- MultiTermQuery(String) - Constructor for class org.apache.lucene.search.MultiTermQuery
- 
Constructs a query matching terms that cannot be represented with a single
 Term. 
- MultiTermQuery.ConstantScoreAutoRewrite - Class in org.apache.lucene.search
- 
A rewrite method that tries to pick the best
  constant-score rewrite method based on term and
  document counts from the query. 
- MultiTermQuery.ConstantScoreAutoRewrite() - Constructor for class org.apache.lucene.search.MultiTermQuery.ConstantScoreAutoRewrite
-  
- MultiTermQuery.RewriteMethod - Class in org.apache.lucene.search
- 
Abstract class that defines how the query is rewritten. 
- MultiTermQuery.RewriteMethod() - Constructor for class org.apache.lucene.search.MultiTermQuery.RewriteMethod
-  
- MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite - Class in org.apache.lucene.search
- 
A rewrite method that first translates each term into
  BooleanClause.Occur.SHOULD clause in a BooleanQuery, but the scores
 are only computed as the boost. 
- MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
- 
Create a TopTermsBoostOnlyBooleanQueryRewrite for 
 at most sizeterms.
 
- MultiTermQuery.TopTermsScoringBooleanQueryRewrite - Class in org.apache.lucene.search
- 
A rewrite method that first translates each term into
  BooleanClause.Occur.SHOULD clause in a BooleanQuery, and keeps the
 scores as computed by the query. 
- MultiTermQuery.TopTermsScoringBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
- 
Create a TopTermsScoringBooleanQueryRewrite for 
 at most sizeterms.
 
- MultiTermQueryWrapperFilter<Q extends MultiTermQuery> - Class in org.apache.lucene.search
- 
- MultiTermQueryWrapperFilter(Q) - Constructor for class org.apache.lucene.search.MultiTermQueryWrapperFilter
- 
- MultiTerms - Class in org.apache.lucene.index
- 
Exposes flex API, merged from flex API of
 sub-segments. 
- MultiTerms(Terms[], ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiTerms
- 
Sole constructor. 
- MultiTermsEnum - Class in org.apache.lucene.index
- 
- MultiTermsEnum(ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiTermsEnum
- 
Sole constructor. 
- MutableBits - Interface in org.apache.lucene.util
- 
Extension of Bits for live documents. 
- MutableValue - Class in org.apache.lucene.util.mutable
- 
Base class for all mutable values. 
- MutableValue() - Constructor for class org.apache.lucene.util.mutable.MutableValue
-  
- MutableValueBool - Class in org.apache.lucene.util.mutable
- 
- MutableValueBool() - Constructor for class org.apache.lucene.util.mutable.MutableValueBool
-  
- MutableValueDate - Class in org.apache.lucene.util.mutable
- 
- MutableValueDate() - Constructor for class org.apache.lucene.util.mutable.MutableValueDate
-  
- MutableValueDouble - Class in org.apache.lucene.util.mutable
- 
- MutableValueDouble() - Constructor for class org.apache.lucene.util.mutable.MutableValueDouble
-  
- MutableValueFloat - Class in org.apache.lucene.util.mutable
- 
- MutableValueFloat() - Constructor for class org.apache.lucene.util.mutable.MutableValueFloat
-  
- MutableValueInt - Class in org.apache.lucene.util.mutable
- 
- MutableValueInt() - Constructor for class org.apache.lucene.util.mutable.MutableValueInt
-  
- MutableValueLong - Class in org.apache.lucene.util.mutable
- 
- MutableValueLong() - Constructor for class org.apache.lucene.util.mutable.MutableValueLong
-  
- MutableValueStr - Class in org.apache.lucene.util.mutable
- 
- MutableValueStr() - Constructor for class org.apache.lucene.util.mutable.MutableValueStr
-  
- name - Variable in class org.apache.lucene.codecs.PostingsBaseFormat
- 
Unique name that's used to retrieve this codec when
  reading the index 
- name - Variable in class org.apache.lucene.document.Field
- 
Field's name 
- name() - Method in class org.apache.lucene.document.Field
-  
- name - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Name of the segment. 
- name - Variable in class org.apache.lucene.index.FieldInfo
- 
Field's name 
- name() - Method in interface org.apache.lucene.index.IndexableField
- 
Field name 
- name - Variable in class org.apache.lucene.index.SegmentInfo
- 
Unique segment name in the directory. 
- NamedSPILoader<S extends NamedSPILoader.NamedSPI> - Class in org.apache.lucene.util
- 
Helper class for loading named SPIs from classpath (e.g. 
- NamedSPILoader(Class<S>) - Constructor for class org.apache.lucene.util.NamedSPILoader
-  
- NamedSPILoader(Class<S>, ClassLoader) - Constructor for class org.apache.lucene.util.NamedSPILoader
-  
- NamedSPILoader.NamedSPI - Interface in org.apache.lucene.util
- 
- NamedThreadFactory - Class in org.apache.lucene.util
- 
A default  ThreadFactory implementation that accepts the name prefix
 of the created threads as a constructor argument. 
- NamedThreadFactory(String) - Constructor for class org.apache.lucene.util.NamedThreadFactory
- 
- NativeFSLockFactory - Class in org.apache.lucene.store
- 
- NativeFSLockFactory() - Constructor for class org.apache.lucene.store.NativeFSLockFactory
- 
Create a NativeFSLockFactory instance, with null (unset)
 lock directory. 
- NativeFSLockFactory(String) - Constructor for class org.apache.lucene.store.NativeFSLockFactory
- 
Create a NativeFSLockFactory instance, storing lock
 files into the specified lockDirName: 
- NativeFSLockFactory(File) - Constructor for class org.apache.lucene.store.NativeFSLockFactory
- 
Create a NativeFSLockFactory instance, storing lock
 files into the specified lockDir: 
- naturalComparator() - Static method in class org.apache.lucene.util.ArrayUtil
- 
Get the natural  Comparator for the provided object class. 
- NearSpansOrdered - Class in org.apache.lucene.search.spans
- 
A Spans that is formed from the ordered subspans of a SpanNearQuery
 where the subspans do not overlap and have a maximum slop between them. 
- NearSpansOrdered(SpanNearQuery, AtomicReaderContext, Bits, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.spans.NearSpansOrdered
-  
- NearSpansOrdered(SpanNearQuery, AtomicReaderContext, Bits, Map<Term, TermContext>, boolean) - Constructor for class org.apache.lucene.search.spans.NearSpansOrdered
-  
- NearSpansUnordered - Class in org.apache.lucene.search.spans
- 
- NearSpansUnordered(SpanNearQuery, AtomicReaderContext, Bits, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.spans.NearSpansUnordered
-  
- needsField(FieldInfo) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-  
- needsField(FieldInfo) - Method in class org.apache.lucene.index.StoredFieldVisitor
- 
Hook before processing a field. 
- needsScores() - Method in class org.apache.lucene.search.SortField
- 
Whether the relevance score is needed to sort documents. 
- negate() - Method in class org.apache.lucene.search.FieldValueFilter
- 
Returns trueiff this filter is negated, otherwisefalse
 
- newBooleanQuery(boolean) - Method in class org.apache.lucene.util.QueryBuilder
- 
Builds a new BooleanQuery instance. 
- newBuffer(byte[]) - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- newBuffer(byte[]) - Method in class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
-  
- newBuffer(int) - Method in class org.apache.lucene.store.RAMFile
- 
Expert: allocate a new buffer. 
- newByteRange(String, Byte, Byte, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Deprecated. 
- newByteRange(String, FieldCache.ByteParser, Byte, Byte, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Deprecated. 
- newBytesRefRange(String, BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.search.DocTermOrdsRangeFilter
- 
- newBytesRefRange(String, BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newComparator(String, int, int, boolean) - Method in class org.apache.lucene.search.FieldComparatorSource
- 
Creates a comparator for the field in the given index. 
- newCompressor() - Method in class org.apache.lucene.codecs.compressing.CompressionMode
- 
- newConcurrentHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
- 
- newConcurrentHashMap(boolean) - Static method in class org.apache.lucene.util.WeakIdentityMap
- 
- newCounter() - Static method in class org.apache.lucene.util.Counter
- 
Returns a new counter. 
- newCounter(boolean) - Static method in class org.apache.lucene.util.Counter
- 
Returns a new counter. 
- newDecompressor() - Method in class org.apache.lucene.codecs.compressing.CompressionMode
- 
- newDoubleRange(String, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newDoubleRange(String, FieldCache.DoubleParser, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newDoubleRange(String, int, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
Factory that creates a  NumericRangeFilter, that filters a  double
 range using the given  precisionStep. 
- newDoubleRange(String, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
- newDoubleRange(String, int, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
Factory that creates a  NumericRangeQuery, that queries a  double
 range using the given  precisionStep. 
- newDoubleRange(String, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
- newFloatRange(String, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newFloatRange(String, FieldCache.FloatParser, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newFloatRange(String, int, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
Factory that creates a  NumericRangeFilter, that filters a  float
 range using the given  precisionStep. 
- newFloatRange(String, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
- newFloatRange(String, int, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
Factory that creates a  NumericRangeQuery, that queries a  float
 range using the given  precisionStep. 
- newFloatRange(String, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
- newFSDirectory(String, File) - Static method in class org.apache.lucene.util.CommandLineUtil
- 
Creates a specific FSDirectory instance starting from its class name 
- newFSDirectory(Class<? extends FSDirectory>, File) - Static method in class org.apache.lucene.util.CommandLineUtil
- 
Creates a new specific FSDirectory instance 
- newHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
- 
Creates a new  WeakIdentityMap based on a non-synchronized  HashMap. 
- newHashMap(boolean) - Static method in class org.apache.lucene.util.WeakIdentityMap
- 
Creates a new  WeakIdentityMap based on a non-synchronized  HashMap. 
- newInstance() - Method in class org.apache.lucene.util.RollingBuffer
-  
- newIntRange(String, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newIntRange(String, FieldCache.IntParser, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newIntRange(String, int, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
Factory that creates a  NumericRangeFilter, that filters a  int
 range using the given  precisionStep. 
- newIntRange(String, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
- newIntRange(String, int, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
Factory that creates a  NumericRangeQuery, that queries a  int
 range using the given  precisionStep. 
- newIntRange(String, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
- newLiveDocs(int) - Method in class org.apache.lucene.codecs.LiveDocsFormat
- 
Creates a new MutableBits, with all bits set, for the specified size. 
- newLiveDocs(Bits) - Method in class org.apache.lucene.codecs.LiveDocsFormat
- 
Creates a new mutablebits of the same bits set and size of existing. 
- newLiveDocs(int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40LiveDocsFormat
-  
- newLiveDocs(Bits) - Method in class org.apache.lucene.codecs.lucene40.Lucene40LiveDocsFormat
-  
- newLongRange(String, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newLongRange(String, FieldCache.LongParser, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newLongRange(String, int, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
Factory that creates a  NumericRangeFilter, that filters a  long
 range using the given  precisionStep. 
- newLongRange(String, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
- 
- newLongRange(String, int, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
Factory that creates a  NumericRangeQuery, that queries a  long
 range using the given  precisionStep. 
- newLongRange(String, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeQuery
- 
- newMultiPhraseQuery() - Method in class org.apache.lucene.util.QueryBuilder
- 
Builds a new MultiPhraseQuery instance. 
- newMutable(int, int) - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
-  
- newMutable(int, int) - Method in class org.apache.lucene.util.packed.PagedMutable
-  
- newPair(A, B) - Method in class org.apache.lucene.util.fst.PairOutputs
- 
Create a new Pair 
- newPhraseQuery() - Method in class org.apache.lucene.util.QueryBuilder
- 
Builds a new PhraseQuery instance. 
- newRAMFile() - Method in class org.apache.lucene.store.RAMDirectory
- 
Returns a new  RAMFile for storing data. 
- newSearcher(IndexReader) - Method in class org.apache.lucene.search.SearcherFactory
- 
Returns a new IndexSearcher over the given reader. 
- newShortRange(String, Short, Short, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Deprecated. 
- newShortRange(String, FieldCache.ShortParser, Short, Short, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
Deprecated. 
- newSlice(int) - Method in class org.apache.lucene.util.ByteBlockPool
- 
Allocates a new slice with the given size. 
- newStats(String, float) - Method in class org.apache.lucene.search.similarities.LMSimilarity
-  
- newStats(String, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Factory method to return a custom stats object 
- newString(int[], int, int) - Static method in class org.apache.lucene.util.UnicodeUtil
- 
Cover JDK 1.5 API. 
- newStringRange(String, String, String, boolean, boolean) - Static method in class org.apache.lucene.search.FieldCacheRangeFilter
- 
- newStringRange(String, String, String, boolean, boolean) - Static method in class org.apache.lucene.search.TermRangeFilter
- 
Factory that creates a new TermRangeFilter using Strings for term text. 
- newStringRange(String, String, String, boolean, boolean) - Static method in class org.apache.lucene.search.TermRangeQuery
- 
Factory that creates a new TermRangeQuery using Strings for term text. 
- newTermQuery(Term) - Method in class org.apache.lucene.util.QueryBuilder
- 
Builds a new TermQuery instance. 
- newTermState() - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. 
- newTermState() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
-  
- newTermState() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- newTermState() - Method in class org.apache.lucene.codecs.PostingsReaderBase
- 
Return a newly created empty TermState 
- newTermState() - Method in class org.apache.lucene.codecs.PostingsWriterBase
- 
Return a newly created empty TermState 
- newThread(Runnable) - Method in class org.apache.lucene.util.NamedThreadFactory
- 
- newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopDocsCollector
- 
Returns a  TopDocs instance containing the given results. 
- newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopFieldCollector
-  
- newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopScoreDocCollector
-  
- newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
-  
- newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.PagedMutable
-  
- next() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- next() - Method in class org.apache.lucene.index.FilteredTermsEnum
-  
- next() - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- next() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- next() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- next() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- next() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- next() - Method in class org.apache.lucene.search.spans.Spans
- 
Move to the next match, returning true iff any such exists. 
- next() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- next() - Method in interface org.apache.lucene.util.BytesRefIterator
- 
Increments the iteration to the next  BytesRef in the iterator. 
- next() - Method in class org.apache.lucene.util.FilterIterator
-  
- next() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-  
- next() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-  
- next() - Method in class org.apache.lucene.util.MergedIterator
-  
- next() - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
- 
Read the next value. 
- next(int) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
- 
Read between 1 and countvalues.
 
- next() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
- 
Returns next value 
- next(int) - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
- 
Returns at least 1 and at most countnext values,
 the returned ref MUST NOT be modified
 
- next() - Method in class org.apache.lucene.util.SPIClassIterator
-  
- NEXT_LEVEL_ARRAY - Static variable in class org.apache.lucene.util.ByteBlockPool
- 
- nextBuffer() - Method in class org.apache.lucene.util.ByteBlockPool
- 
Advances the pool to its next buffer. 
- nextBuffer() - Method in class org.apache.lucene.util.IntBlockPool
- 
Advances the pool to its next buffer. 
- nextDoc() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- nextDoc() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
-  
- nextDoc() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- nextDoc() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
-  
- nextDoc() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- nextDoc() - Method in class org.apache.lucene.index.MultiDocsEnum
-  
- nextDoc() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- nextDoc() - Method in class org.apache.lucene.search.DocIdSetIterator
- 
Advances to the next document in the set and returns the doc it is
 currently on, or  DocIdSetIterator.NO_MORE_DOCS if there are no more docs in the
 set.
 
  NOTE: after the iterator has exhausted you should not call this
 method, as it may result in unpredicted behavior. 
- nextDoc() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-  
- nextDoc() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- nextDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
-  
- nextDoc() - Method in class org.apache.lucene.util.FixedBitSet.FixedBitSetIterator
-  
- nextDoc() - Method in class org.apache.lucene.util.OpenBitSetIterator
- 
alternate shift implementations
  // 32 bit shifts, but a long shift needed at the end
  private void shift2() {
    int y = (int)word;
    if (y==0) {wordShift +=32; y = (int)(word >>>32); }
    if ((y & 0x0000FFFF) == 0) { wordShift +=16; y>>>=16; }
    if ((y & 0x000000FF) == 0) { wordShift +=8; y>>>=8; }
    indexArray = bitlist[y & 0xff];
    word >>>= (wordShift +1);
  }
  private void shift3() {
    int lower = (int)word;
    int lowByte = lower & 0xff;
    if (lowByte != 0) {
      indexArray=bitlist[lowByte];
      return;
    }
    shift();
  } 
- nextFinalOutput - Variable in class org.apache.lucene.util.fst.Builder.Arc
-  
- nextFinalOutput - Variable in class org.apache.lucene.util.fst.FST.Arc
-  
- nextHighestPowerOfTwo(int) - Static method in class org.apache.lucene.util.BitUtil
- 
returns the next highest power of two, or the current value if it's already a power of two or zero 
- nextHighestPowerOfTwo(long) - Static method in class org.apache.lucene.util.BitUtil
- 
returns the next highest power of two, or the current value if it's already a power of two or zero 
- nextOrd() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-  
- nextOrd() - Method in class org.apache.lucene.index.SingletonSortedSetDocValues
-  
- nextOrd() - Method in class org.apache.lucene.index.SortedSetDocValues
- 
- nextPosition() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- nextPosition() - Method in class org.apache.lucene.index.DocsAndPositionsEnum
- 
Returns the next position. 
- nextPosition() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- nextPosition() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- nextSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
- nextSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
- 
Returns the index of the first set bit starting at the index specified. 
- nextSetBit(long) - Method in class org.apache.lucene.util.LongBitSet
- 
Returns the index of the first set bit starting at the index specified. 
- nextSetBit(int) - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns the index of the first set bit starting at the index specified. 
- nextSetBit(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns the index of the first set bit starting at the index specified. 
- nextValue() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
If another value is available after the current decoding index, return this value and
 and increase the decoding index by 1. 
- NGramPhraseQuery - Class in org.apache.lucene.search
- 
This is a  PhraseQuery which is optimized for n-gram phrase query. 
- NGramPhraseQuery(int) - Constructor for class org.apache.lucene.search.NGramPhraseQuery
- 
Constructor that takes gram size. 
- NIOFSDirectory - Class in org.apache.lucene.store
- 
An  FSDirectory implementation that uses java.nio's FileChannel's
 positional read, which allows multiple threads to read from the same file
 without synchronizing. 
- NIOFSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.NIOFSDirectory
- 
Create a new NIOFSDirectory for the named location. 
- NIOFSDirectory(File) - Constructor for class org.apache.lucene.store.NIOFSDirectory
- 
- NIOFSDirectory.NIOFSIndexInput - Class in org.apache.lucene.store
- 
- NIOFSDirectory.NIOFSIndexInput(File, IOContext) - Constructor for class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
-  
- NIOFSDirectory.NIOFSIndexInput(String, File, RandomAccessFile, FileChannel, long, long, int) - Constructor for class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
-  
- NO - Static variable in class org.apache.lucene.index.SegmentInfo
- 
Used by some member fields to mean not present (e.g.,
  norms, deletions). 
- NO_COMPOUND_FILES - Static variable in class org.apache.lucene.index.NoMergePolicy
- 
A singleton  NoMergePolicy which indicates the index does not use
 compound files. 
- NO_MORE_DOCS - Static variable in class org.apache.lucene.search.DocIdSetIterator
- 
- NO_MORE_ORDS - Static variable in class org.apache.lucene.index.SortedSetDocValues
- 
- NO_MORE_VALUES - Static variable in class org.apache.lucene.util.packed.EliasFanoDecoder
-  
- NO_OUTPUT - Static variable in class org.apache.lucene.util.InfoStream
- 
Instance of InfoStream that does no logging at all. 
- noCFSRatio - Variable in class org.apache.lucene.index.MergePolicy
- 
If the size of the merge segment exceeds this ratio of
  the total index size then it will remain in
  non-compound format 
- nodeCount - Variable in class org.apache.lucene.util.fst.FST
-  
- NoDeletionPolicy - Class in org.apache.lucene.index
- 
- NoLockFactory - Class in org.apache.lucene.store
- 
- NoMergePolicy - Class in org.apache.lucene.index
- 
A  MergePolicy which never returns merges to execute (hence it's
 name). 
- NoMergeScheduler - Class in org.apache.lucene.index
- 
- NONE - Static variable in class org.apache.lucene.util.automaton.RegExp
- 
Syntax flag, enables no optional regexp syntax. 
- nonFloorBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
The number of normal (non-floor) blocks in the terms file. 
- NoOutputs - Class in org.apache.lucene.util.fst
- 
A null FST  Outputs implementation; use this if
 you just want to build an FSA. 
- normalization - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
- 
The term frequency normalization. 
- normalization - Variable in class org.apache.lucene.search.similarities.IBSimilarity
- 
The term frequency normalization. 
- Normalization - Class in org.apache.lucene.search.similarities
- 
This class acts as the base class for the implementations of the term
 frequency normalization methods in the DFR framework. 
- Normalization() - Constructor for class org.apache.lucene.search.similarities.Normalization
- 
Sole constructor. 
- Normalization.NoNormalization - Class in org.apache.lucene.search.similarities
- 
Implementation used when there is no normalization. 
- Normalization.NoNormalization() - Constructor for class org.apache.lucene.search.similarities.Normalization.NoNormalization
- 
Sole constructor: parameter-free 
- NormalizationH1 - Class in org.apache.lucene.search.similarities
- 
Normalization model that assumes a uniform distribution of the term frequency. 
- NormalizationH1(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH1
- 
Creates NormalizationH1 with the supplied parameter c.
 
- NormalizationH1() - Constructor for class org.apache.lucene.search.similarities.NormalizationH1
- 
- NormalizationH2 - Class in org.apache.lucene.search.similarities
- 
Normalization model in which the term frequency is inversely related to the
 length. 
- NormalizationH2(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH2
- 
Creates NormalizationH2 with the supplied parameter c.
 
- NormalizationH2() - Constructor for class org.apache.lucene.search.similarities.NormalizationH2
- 
- NormalizationH3 - Class in org.apache.lucene.search.similarities
- 
Dirichlet Priors normalization 
- NormalizationH3() - Constructor for class org.apache.lucene.search.similarities.NormalizationH3
- 
- NormalizationH3(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH3
- 
Creates NormalizationH3 with the supplied parameter μ.
 
- NormalizationZ - Class in org.apache.lucene.search.similarities
- 
Pareto-Zipf Normalization 
- NormalizationZ() - Constructor for class org.apache.lucene.search.similarities.NormalizationZ
- 
- NormalizationZ(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationZ
- 
Creates NormalizationZ with the supplied parameter z.
 
- normalize(float, float) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- normalize(float, float) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
-  
- normalize(float, float) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
- 
Apply the computed normalization factor to our subqueries 
- normalize(float, float) - Method in class org.apache.lucene.search.similarities.BasicStats
- 
No normalization is done. 
- normalize(float, float) - Method in class org.apache.lucene.search.similarities.Similarity.SimWeight
- 
Assigns the query normalization factor and boost from parent queries to this. 
- normalize(float, float) - Method in class org.apache.lucene.search.spans.SpanWeight
-  
- normalize(float, float) - Method in class org.apache.lucene.search.Weight
- 
Assigns the query normalization factor and boost from parent queries to this. 
- NORMGEN_KEY - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- NORMGEN_PREFIX - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
- 
Deprecated. 
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40NormsFormat
- 
Deprecated. 
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene42.Lucene42NormsFormat
-  
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.NormsFormat
- 
- normsFormat() - Method in class org.apache.lucene.codecs.Codec
- 
Encodes/decodes document normalization values 
- normsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-  
- normsFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- normsFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. 
- normsFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. 
- normsFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. 
- normsFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. 
- normsFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
-  
- NormsFormat - Class in org.apache.lucene.codecs
- 
Encodes/decodes per-document score normalization values. 
- NormsFormat() - Constructor for class org.apache.lucene.codecs.NormsFormat
- 
Sole constructor. 
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40NormsFormat
- 
Deprecated. 
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene42.Lucene42NormsFormat
-  
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.NormsFormat
- 
- NoSuchDirectoryException - Exception in org.apache.lucene.store
- 
This exception is thrown when you try to list a
 non-existent directory. 
- NoSuchDirectoryException(String) - Constructor for exception org.apache.lucene.store.NoSuchDirectoryException
-  
- notEquals0_8(long) - Static method in class org.apache.lucene.util.BroadWord
- 
An unsigned bytewise not equals 0 operator. 
- NRTCachingDirectory - Class in org.apache.lucene.store
- 
Wraps a  RAMDirectory
 around any provided delegate directory, to
 be used during NRT search. 
- NRTCachingDirectory(Directory, double, double) - Constructor for class org.apache.lucene.store.NRTCachingDirectory
- 
We will cache a newly created output if 1) it's a
  flush or a merge and the estimated size of the merged segment is <=
  maxMergeSizeMB, and 2) the total cached bytes is <=
  maxCachedMB 
- NUM_BYTES_ARRAY_HEADER - Static variable in class org.apache.lucene.util.RamUsageEstimator
- 
Number of bytes to represent an array header (no content, but with alignments). 
- NUM_BYTES_BOOLEAN - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- NUM_BYTES_BYTE - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- NUM_BYTES_CHAR - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- NUM_BYTES_DOUBLE - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- NUM_BYTES_FLOAT - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- NUM_BYTES_INT - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- NUM_BYTES_LONG - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- NUM_BYTES_OBJECT_ALIGNMENT - Static variable in class org.apache.lucene.util.RamUsageEstimator
- 
A constant specifying the object alignment boundary inside the JVM. 
- NUM_BYTES_OBJECT_HEADER - Static variable in class org.apache.lucene.util.RamUsageEstimator
- 
Number of bytes to represent an object header (no fields, no alignments). 
- NUM_BYTES_OBJECT_REF - Static variable in class org.apache.lucene.util.RamUsageEstimator
- 
Number of bytes this jvm uses to represent an object reference. 
- NUM_BYTES_SHORT - Static variable in class org.apache.lucene.util.RamUsageEstimator
-  
- numArcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- numBadSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
How many bad segments were found. 
- number - Variable in class org.apache.lucene.index.FieldInfo
- 
Internal field number 
- numberOfDocuments - Variable in class org.apache.lucene.search.similarities.BasicStats
- 
The number of documents. 
- numberOfFieldTokens - Variable in class org.apache.lucene.search.similarities.BasicStats
- 
The total number of tokens in the field. 
- numberOfSkipLevels - Variable in class org.apache.lucene.codecs.MultiLevelSkipListWriter
- 
number of levels in this skip list 
- numBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-  
- numBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-  
- numBuffers() - Method in class org.apache.lucene.store.RAMFile
-  
- numDeleted - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Number of deleted documents. 
- numDeletedDocs() - Method in class org.apache.lucene.index.IndexReader
- 
Returns the number of deleted documents. 
- numDeletedDocs(SegmentCommitInfo) - Method in class org.apache.lucene.index.IndexWriter
- 
Obtain the number of deleted docs for a pooled reader. 
- numDeletedDocs() - Method in class org.apache.lucene.index.MergeState.DocMap
- 
Returns the number of deleted documents. 
- numDocs() - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- numDocs() - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- numDocs() - Method in class org.apache.lucene.index.IndexReader
- 
Returns the number of documents in this index. 
- numDocs() - Method in class org.apache.lucene.index.IndexWriter
- 
Returns total number of docs in this index, including
  docs not yet flushed (still in the RAM buffer), and
  including deletions. 
- numDocs() - Method in class org.apache.lucene.index.MergeState.DocMap
- 
Returns the number of not-deleted documents. 
- numDocs() - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- numDocs() - Method in class org.apache.lucene.index.SegmentReader
-  
- numDocs() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- numDocs - Variable in class org.apache.lucene.store.FlushInfo
-  
- numEncoded() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
The number of values encoded by the encoder. 
- NUMERIC_UTILS_DOUBLE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
A parser instance for double values encoded with  NumericUtils, e.g. 
- NUMERIC_UTILS_FLOAT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
A parser instance for float values encoded with  NumericUtils, e.g. 
- NUMERIC_UTILS_INT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
A parser instance for int values encoded by  NumericUtils, e.g. 
- NUMERIC_UTILS_LONG_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
- 
A parser instance for long values encoded by  NumericUtils, e.g. 
- NumericDocValues - Class in org.apache.lucene.index
- 
A per-document numeric value. 
- NumericDocValues() - Constructor for class org.apache.lucene.index.NumericDocValues
- 
Sole constructor. 
- NumericDocValuesField - Class in org.apache.lucene.document
- 
 Field that stores a per-document longvalue for scoring, 
 sorting or value retrieval.
 
- NumericDocValuesField(String, long) - Constructor for class org.apache.lucene.document.NumericDocValuesField
- 
Creates a new DocValues field with the specified 64-bit long value 
- numericPrecisionStep() - Method in class org.apache.lucene.document.FieldType
- 
Precision step for numeric field. 
- NumericRangeFilter<T extends Number> - Class in org.apache.lucene.search
- 
A  Filter that only accepts numeric values within
 a specified range. 
- NumericRangeQuery<T extends Number> - Class in org.apache.lucene.search
- 
A  Query that matches numeric values within a
 specified range. 
- NumericTokenStream - Class in org.apache.lucene.analysis
- 
- NumericTokenStream() - Constructor for class org.apache.lucene.analysis.NumericTokenStream
- 
- NumericTokenStream(int) - Constructor for class org.apache.lucene.analysis.NumericTokenStream
- 
Creates a token stream for numeric values with the specified
 precisionStep.
 
- NumericTokenStream(AttributeSource.AttributeFactory, int) - Constructor for class org.apache.lucene.analysis.NumericTokenStream
- 
- NumericTokenStream.NumericTermAttribute - Interface in org.apache.lucene.analysis
- 
Expert: Use this attribute to get the details of the currently generated token. 
- NumericTokenStream.NumericTermAttributeImpl - Class in org.apache.lucene.analysis
- 
- NumericTokenStream.NumericTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
- 
Creates, but does not yet initialize this attribute instance 
- numericType() - Method in class org.apache.lucene.document.FieldType
- 
NumericType: if non-null then the field's value will be indexed
 numerically so that  NumericRangeQuery can be used at 
 search time. 
- NumericUtils - Class in org.apache.lucene.util
- 
This is a helper class to generate prefix-encoded representations for numerical values
 and supplies converters to represent float/double values as sortable integers/longs. 
- NumericUtils.IntRangeBuilder - Class in org.apache.lucene.util
- 
- NumericUtils.IntRangeBuilder() - Constructor for class org.apache.lucene.util.NumericUtils.IntRangeBuilder
-  
- NumericUtils.LongRangeBuilder - Class in org.apache.lucene.util
- 
- NumericUtils.LongRangeBuilder() - Constructor for class org.apache.lucene.util.NumericUtils.LongRangeBuilder
-  
- numericValue() - Method in class org.apache.lucene.document.Field
-  
- numericValue() - Method in interface org.apache.lucene.index.IndexableField
- 
Non-null if this field has a numeric value 
- numFiles - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Number of files referenced by this segment. 
- numMatches - Variable in class org.apache.lucene.search.spans.SpanScorer
-  
- numRamDocs() - Method in class org.apache.lucene.index.IndexWriter
- 
Expert:  Return the number of documents currently
  buffered in RAM. 
- numSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
Number of segments in the index. 
- numTerms() - Method in class org.apache.lucene.index.DocTermOrds
- 
Returns the number of terms in this field 
- numTermsInField - Variable in class org.apache.lucene.index.DocTermOrds
- 
Number of terms in the field. 
- numTransitions - Variable in class org.apache.lucene.util.automaton.State
-  
- numTransitions() - Method in class org.apache.lucene.util.automaton.State
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.DocValuesProducer
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.codecs.FieldsProducer
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
- 
Deprecated. 
- ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
-  
- ramBytesUsed() - Method in class org.apache.lucene.codecs.PostingsReaderBase
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.codecs.StoredFieldsReader
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.codecs.TermVectorsReader
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
- 
Returns total byte size used by this ordinal map. 
- ramBytesUsed() - Method in class org.apache.lucene.index.SegmentReader
- 
Returns approximate RAM Bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.AppendingDeltaPackedLongBuffer
-  
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.BlockPackedReader
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.MonotonicAppendingLongBuffer
-  
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
- 
Returns the approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-  
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
- 
Return the in-memory size in bytes. 
- ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes
- 
Return approx RAM usage in bytes. 
- ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes.Reader
- 
Returns approximate RAM bytes used 
- ramBytesUsed() - Method in class org.apache.lucene.util.PForDeltaDocIdSet
- 
Return the memory usage of this instance. 
- ramBytesUsed() - Method in class org.apache.lucene.util.WAH8DocIdSet
- 
Return the memory usage of this class in bytes. 
- RAMDirectory - Class in org.apache.lucene.store
- 
- RAMDirectory() - Constructor for class org.apache.lucene.store.RAMDirectory
- 
- RAMDirectory(Directory, IOContext) - Constructor for class org.apache.lucene.store.RAMDirectory
- 
Creates a new RAMDirectoryinstance from a differentDirectoryimplementation.
 
- RAMFile - Class in org.apache.lucene.store
- 
Represents a file in RAM as a list of byte[] buffers. 
- RAMFile() - Constructor for class org.apache.lucene.store.RAMFile
-  
- RAMInputStream - Class in org.apache.lucene.store
- 
- RAMInputStream(String, RAMFile) - Constructor for class org.apache.lucene.store.RAMInputStream
-  
- RAMOutputStream - Class in org.apache.lucene.store
- 
- RAMOutputStream() - Constructor for class org.apache.lucene.store.RAMOutputStream
- 
Construct an empty output buffer. 
- RAMOutputStream(RAMFile) - Constructor for class org.apache.lucene.store.RAMOutputStream
-  
- ramSizeInBytes() - Method in class org.apache.lucene.index.IndexWriter
- 
Expert:  Return the total size of all index files currently cached in memory. 
- RamUsageEstimator - Class in org.apache.lucene.util
- 
Estimates the size (memory representation) of Java objects. 
- RamUsageEstimator.JvmFeature - Enum in org.apache.lucene.util
- 
JVM diagnostic features. 
- ramUsedInBytes() - Method in class org.apache.lucene.index.DocTermOrds
- 
Returns total bytes used. 
- RANDOM_ACCESS_FILTER_STRATEGY - Static variable in class org.apache.lucene.search.FilteredQuery
- 
- RateLimitedDirectoryWrapper - Class in org.apache.lucene.store
- 
- RateLimitedDirectoryWrapper(Directory) - Constructor for class org.apache.lucene.store.RateLimitedDirectoryWrapper
-  
- RateLimiter - Class in org.apache.lucene.store
- 
Abstract base class to rate limit IO. 
- RateLimiter() - Constructor for class org.apache.lucene.store.RateLimiter
-  
- RateLimiter.SimpleRateLimiter - Class in org.apache.lucene.store
- 
Simple class to rate limit IO. 
- RateLimiter.SimpleRateLimiter(double) - Constructor for class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
- 
mbPerSec is the MB/sec max IO rate 
- raw - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- rawDocs(int[], int, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
- 
Returns the length in bytes of each raw document in a
  contiguous range of length numDocs starting with
  startDocID. 
- rawNormalizationValue() - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Computes the raw normalization value. 
- read(Directory, String, String, IOContext) - Method in class org.apache.lucene.codecs.FieldInfosReader
- 
- read(Directory, String, IOContext) - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoReader
- 
Deprecated. 
- read(Directory, String, IOContext) - Method in class org.apache.lucene.codecs.lucene40.Lucene40SegmentInfoReader
- 
Deprecated. 
- read(Directory, String, IOContext) - Method in class org.apache.lucene.codecs.lucene46.Lucene46SegmentInfoReader
-  
- read(Directory, String, IOContext) - Method in class org.apache.lucene.codecs.SegmentInfoReader
- 
- read(Directory, String) - Method in class org.apache.lucene.index.SegmentInfos
- 
Read a particular segmentFileName. 
- read(Directory) - Method in class org.apache.lucene.index.SegmentInfos
- 
- READ - Static variable in class org.apache.lucene.store.IOContext
-  
- read(DataInput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-  
- read(DataInput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-  
- read(File, Outputs<T>) - Static method in class org.apache.lucene.util.fst.FST
- 
Reads an automaton from a file. 
- read(DataInput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-  
- read(DataInput) - Method in class org.apache.lucene.util.fst.NoOutputs
-  
- read(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
- 
- read(DataInput) - Method in class org.apache.lucene.util.fst.PairOutputs
-  
- read(DataInput) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-  
- readBufferSize - Variable in class org.apache.lucene.store.CompoundFileDirectory
-  
- readByte() - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readByte() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- readByte() - Method in class org.apache.lucene.store.ChecksumIndexInput
-  
- readByte() - Method in class org.apache.lucene.store.DataInput
- 
Reads and returns a single byte. 
- readByte() - Method in class org.apache.lucene.store.InputStreamDataInput
-  
- readByte() - Method in class org.apache.lucene.store.RAMInputStream
-  
- readByte() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-  
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ChecksumIndexInput
-  
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.DataInput
- 
Reads a specified number of bytes into an array at the specified offset. 
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.DataInput
- 
Reads a specified number of bytes into an array at the
 specified offset with control over whether the read
 should be buffered (callers who have their own buffer
 should pass in "false" for useBuffer). 
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.InputStreamDataInput
-  
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.RAMInputStream
-  
- readBytes(long, byte[], int, int) - Method in class org.apache.lucene.util.ByteBlockPool
- 
Reads bytes bytes out of the pool starting at the given offset with the given  
 length into the given byte array at offset off. 
- readBytes(byte[], int, int) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-  
- readCeilArc(int, FST<T>, FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Static method in class org.apache.lucene.util.fst.Util
- 
Reads the first arc greater or equal that the given label into the provided
 arc in place and returns it iff found, otherwise return null.
 
- reader() - Method in class org.apache.lucene.index.AtomicReaderContext
-  
- reader() - Method in class org.apache.lucene.index.CompositeReaderContext
-  
- reader() - Method in class org.apache.lucene.index.IndexReaderContext
- 
- readerBase(int) - Method in class org.apache.lucene.index.BaseCompositeReader
- 
Helper method for subclasses to get the docBase of the given sub-reader index. 
- readerContext - Variable in class org.apache.lucene.search.IndexSearcher
-  
- readerIndex(int) - Method in class org.apache.lucene.index.BaseCompositeReader
- 
Helper method for subclasses to get the corresponding reader for a doc ID 
- readerIndex - Variable in class org.apache.lucene.index.ReaderSlice
- 
Sub-reader index for this slice. 
- ReaderManager - Class in org.apache.lucene.index
- 
Utility class to safely share  DirectoryReader instances across
 multiple threads, while periodically reopening. 
- ReaderManager(IndexWriter, boolean) - Constructor for class org.apache.lucene.index.ReaderManager
- 
Creates and returns a new ReaderManager from the given
  IndexWriter. 
- ReaderManager(Directory) - Constructor for class org.apache.lucene.index.ReaderManager
- 
Creates and returns a new ReaderManager from the given  Directory. 
- readerPooling - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
True if readers should be pooled. 
- readers - Variable in class org.apache.lucene.index.MergeState
- 
Readers being merged. 
- ReaderSlice - Class in org.apache.lucene.index
- 
Subreader slice from a parent composite reader. 
- ReaderSlice(int, int, int) - Constructor for class org.apache.lucene.index.ReaderSlice
- 
Sole constructor. 
- ReaderUtil - Class in org.apache.lucene.index
- 
- readerValue() - Method in class org.apache.lucene.document.Field
- 
The value of the field as a Reader, or null. 
- readerValue() - Method in interface org.apache.lucene.index.IndexableField
- 
Non-null if this field has a Reader value 
- readFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
- 
- readFirstRealTargetArc(long, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-  
- readFirstTargetArc(FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
- 
Follow the followarc and read the first arc of its target;
 this changes the providedarc(2nd arg) in-place and returns
 it.
 
- readHeader(IndexInput) - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
- 
Reads terms file header. 
- readHeader(DataInput) - Static method in class org.apache.lucene.util.packed.PackedInts
- 
Expert: reads only the metadata from a stream. 
- readIndexHeader(IndexInput) - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
- 
Reads index file header. 
- readInt() - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readInt() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- readInt() - Method in class org.apache.lucene.store.DataInput
- 
Reads four bytes and returns an int. 
- readInt() - Method in class org.apache.lucene.util.IntBlockPool.SliceReader
- 
Reads the next int from the current slice and returns it. 
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
- 
Expert: implements buffer refill. 
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
-  
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
- 
IndexInput methods 
- readLastTargetArc(FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
- 
Follows the followarc and reads the last
  arc of its target; this changes the providedarc(2nd arg) in-place and returns it.
 
- readLegacyInfos(SegmentInfos, Directory, IndexInput, int) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoReader
- 
Deprecated. 
- readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.LiveDocsFormat
- 
Read live docs bits. 
- readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene40.Lucene40LiveDocsFormat
-  
- readLong() - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readLong() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- readLong() - Method in class org.apache.lucene.store.DataInput
- 
Reads eight bytes and returns a long. 
- readLong(int) - Method in class org.apache.lucene.util.packed.PackedDataInput
- 
Read the next long using exactly bitsPerValuebits.
 
- readNextArc(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
- 
In-place read; returns the arc. 
- readNextArcLabel(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
- 
Peeks at next arc's label; does not alter arc. 
- readNextRealArc(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
- 
Never returns null, but you should never call this if
  arc.isLast() is true. 
- readOnce - Variable in class org.apache.lucene.store.IOContext
-  
- READONCE - Static variable in class org.apache.lucene.store.IOContext
-  
- readPayload - Variable in class org.apache.lucene.search.spans.TermSpans
-  
- readRootArcs(FST.Arc<T>[]) - Method in class org.apache.lucene.util.fst.FST
-  
- readShort() - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readShort() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- readShort() - Method in class org.apache.lucene.store.DataInput
- 
Reads two bytes and returns a short. 
- readSkipData(int, IndexInput) - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. 
- readSkipData(int, IndexInput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Subclasses must implement the actual skip data encoding in this method. 
- readString() - Method in class org.apache.lucene.store.DataInput
- 
Reads a string. 
- readStringSet() - Method in class org.apache.lucene.store.DataInput
- 
- readStringStringMap() - Method in class org.apache.lucene.store.DataInput
- 
- readVInt() - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readVInt() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- readVInt() - Method in class org.apache.lucene.store.DataInput
- 
Reads an int stored in variable-length format. 
- readVLong() - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- readVLong() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- readVLong() - Method in class org.apache.lucene.store.DataInput
- 
Reads a long stored in variable-length format. 
- realPrefixLength - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- reap() - Method in class org.apache.lucene.util.WeakIdentityMap
- 
This method manually cleans up the reference queue to remove all garbage
 collected key/value pairs from the map. 
- record(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
- 
Records that you are now using this IndexSearcher. 
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
-  
- recycleByteBlocks(List<byte[]>) - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
-  
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectAllocator
-  
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-  
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-  
- recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.IntBlockPool.Allocator
-  
- recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.IntBlockPool.DirectAllocator
-  
- recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-  
- RecyclingByteBlockAllocator - Class in org.apache.lucene.util
- 
- RecyclingByteBlockAllocator(int, int, Counter) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
- 
- RecyclingByteBlockAllocator(int, int) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
- 
- RecyclingByteBlockAllocator() - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
- 
- RecyclingIntBlockAllocator - Class in org.apache.lucene.util
- 
- RecyclingIntBlockAllocator(int, int, Counter) - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
- 
- RecyclingIntBlockAllocator(int, int) - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
- 
- RecyclingIntBlockAllocator() - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
- 
- reduce() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Reduces this automaton. 
- reduce() - Method in class org.apache.lucene.util.automaton.State
- 
Reduces this state. 
- RefCount<T> - Class in org.apache.lucene.util
- 
Manages reference counting for a given object. 
- RefCount(T) - Constructor for class org.apache.lucene.util.RefCount
-  
- refCounts - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Records how many snapshots are held against each
  commit generation 
- ReferenceManager<G> - Class in org.apache.lucene.search
- 
Utility class to safely share instances of a certain type across multiple
 threads, while periodically refreshing them. 
- ReferenceManager() - Constructor for class org.apache.lucene.search.ReferenceManager
-  
- ReferenceManager.RefreshListener - Interface in org.apache.lucene.search
- 
Use to receive notification when a refresh has
  finished. 
- reflect(Class<? extends Attribute>, String, Object) - Method in interface org.apache.lucene.util.AttributeReflector
- 
- reflectAsString(boolean) - Method in class org.apache.lucene.util.AttributeImpl
- 
This method returns the current attribute values as a string in the following format
 by calling the  AttributeImpl.reflectWith(AttributeReflector) method:
 
 
  iffprependAttClass=true:"AttributeClass#key=value,AttributeClass#key=value"iffprependAttClass=false:"key=value,key=value"
- reflectAsString(boolean) - Method in class org.apache.lucene.util.AttributeSource
- 
This method returns the current attribute values as a string in the following format
 by calling the  AttributeSource.reflectWith(AttributeReflector) method:
 
 
  iffprependAttClass=true:"AttributeClass#key=value,AttributeClass#key=value"iffprependAttClass=false:"key=value,key=value"
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.Token
-  
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.util.AttributeImpl
- 
This method is for introspection of attributes, it should simply
 add the key/values this attribute holds to the given  AttributeReflector. 
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.util.AttributeSource
- 
This method is for introspection of attributes, it should simply
 add the key/values this AttributeSource holds to the given  AttributeReflector. 
- refreshIfNeeded(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-  
- refreshIfNeeded(G) - Method in class org.apache.lucene.search.ReferenceManager
- 
Refresh the given reference if needed. 
- refreshIfNeeded(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
-  
- RegExp - Class in org.apache.lucene.util.automaton
- 
Regular Expression extension to Automaton.
 
- RegExp(String) - Constructor for class org.apache.lucene.util.automaton.RegExp
- 
Constructs new RegExpfrom a string.
 
- RegExp(String, int) - Constructor for class org.apache.lucene.util.automaton.RegExp
- 
Constructs new RegExpfrom a string.
 
- RegexpQuery - Class in org.apache.lucene.search
- 
- RegexpQuery(Term) - Constructor for class org.apache.lucene.search.RegexpQuery
- 
Constructs a query for terms matching term.
 
- RegexpQuery(Term, int) - Constructor for class org.apache.lucene.search.RegexpQuery
- 
Constructs a query for terms matching term.
 
- RegexpQuery(Term, int, AutomatonProvider) - Constructor for class org.apache.lucene.search.RegexpQuery
- 
Constructs a query for terms matching term.
 
- register(TermState, int, int, long) - Method in class org.apache.lucene.index.TermContext
- 
Registers and associates a  TermState with an leaf ordinal. 
- registerParentReader(IndexReader) - Method in class org.apache.lucene.index.IndexReader
- 
Expert: This method is called by IndexReaders which wrap other readers
 (e.g.
 
- rehash() - Method in class org.apache.lucene.util.SentinelIntSet
- 
(internal) Rehashes by doubling int[] keyand filling with the old values.
 
- rehashCount - Variable in class org.apache.lucene.util.SentinelIntSet
- 
the count at which a rehash should be done 
- reinit(char[], int, int, int, int, String) - Method in class org.apache.lucene.analysis.Token
- 
- reinit(char[], int, int, int, int) - Method in class org.apache.lucene.analysis.Token
- 
- reinit(String, int, int, String) - Method in class org.apache.lucene.analysis.Token
- 
- reinit(String, int, int, int, int, String) - Method in class org.apache.lucene.analysis.Token
- 
- reinit(String, int, int) - Method in class org.apache.lucene.analysis.Token
- 
- reinit(String, int, int, int, int) - Method in class org.apache.lucene.analysis.Token
- 
- reinit(Token) - Method in class org.apache.lucene.analysis.Token
- 
Copy the prototype token's fields into this one. 
- reinit(Token, String) - Method in class org.apache.lucene.analysis.Token
- 
Copy the prototype token's fields into this one, with a different term. 
- reinit(Token, char[], int, int) - Method in class org.apache.lucene.analysis.Token
- 
Copy the prototype token's fields into this one, with a different term. 
- reinit() - Method in class org.apache.lucene.util.BytesRefHash
- 
- relationship - Variable in class org.apache.lucene.search.Scorer.ChildScorer
- 
An arbitrary string relating this scorer to the parent. 
- release(IndexCommit) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
- 
Deletes a snapshotted commit. 
- release(long) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
- 
Deletes a snapshotted commit by generation. 
- release(IndexCommit) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Release a snapshotted commit. 
- release(G) - Method in class org.apache.lucene.search.ReferenceManager
- 
- release(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
- 
- release() - Method in class org.apache.lucene.util.RefCount
- 
Called when reference counting hits 0. 
- releaseGen(long) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Release a snapshot by generation. 
- RELEVANCE - Static variable in class org.apache.lucene.search.Sort
- 
Represents sorting by computed relevance. 
- reload(ClassLoader) - Method in class org.apache.lucene.util.NamedSPILoader
- 
Reloads the internal SPI list from the given  ClassLoader. 
- reloadCodecs(ClassLoader) - Static method in class org.apache.lucene.codecs.Codec
- 
- reloadDocValuesFormats(ClassLoader) - Static method in class org.apache.lucene.codecs.DocValuesFormat
- 
Reloads the DocValues format list from the given  ClassLoader. 
- reloadPostingsFormats(ClassLoader) - Static method in class org.apache.lucene.codecs.PostingsFormat
- 
Reloads the postings format list from the given  ClassLoader. 
- remove(SegmentCommitInfo) - Method in class org.apache.lucene.index.SegmentInfos
- 
- remove() - Method in class org.apache.lucene.util.FilterIterator
-  
- remove() - Method in class org.apache.lucene.util.MergedIterator
-  
- remove(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
- 
Remove all elements set in other. 
- remove() - Method in class org.apache.lucene.util.SPIClassIterator
-  
- remove(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
- 
Removes the mapping for a key from this weak hash map if it is present. 
- removeCoreClosedListener(SegmentReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
- 
Expert: removes a CoreClosedListener from this reader's shared core 
- removeDeadTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
- 
- removeField(String) - Method in class org.apache.lucene.document.Document
- 
Removes field with the specified name from the document. 
- removeFields(String) - Method in class org.apache.lucene.document.Document
- 
Removes all fields with the given name from the document. 
- removeListener(ReferenceManager.RefreshListener) - Method in class org.apache.lucene.search.ReferenceManager
- 
- removeReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
- 
- renameFile(String, String) - Method in class org.apache.lucene.store.CompoundFileDirectory
- 
Not implemented 
- repeat() - Method in class org.apache.lucene.util.automaton.Automaton
- 
- repeat(int) - Method in class org.apache.lucene.util.automaton.Automaton
- 
- repeat(int, int) - Method in class org.apache.lucene.util.automaton.Automaton
- 
- repeat(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns an automaton that accepts the Kleene star (zero or more
 concatenated repetitions) of the language of the given automaton. 
- repeat(Automaton, int) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns an automaton that accepts minor more concatenated
 repetitions of the language of the given automaton.
 
- repeat(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns an automaton that accepts between minandmax(including both) concatenated repetitions of the language
 of the given automaton.
 
- replaceLast(int, Builder.Node, T, boolean) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- replay(Collector) - Method in class org.apache.lucene.search.CachingCollector
- 
Replays the cached doc IDs (and scores) to the given Collector. 
- reset() - Method in class org.apache.lucene.analysis.CachingTokenFilter
- 
Rewinds the iterator to the beginning of the cached list. 
- reset() - Method in class org.apache.lucene.analysis.NumericTokenStream
-  
- reset() - Method in class org.apache.lucene.analysis.TokenFilter
- 
- reset() - Method in class org.apache.lucene.analysis.Tokenizer
-  
- reset() - Method in class org.apache.lucene.analysis.TokenStream
- 
- reset(MultiDocsAndPositionsEnum.EnumWithSlice[], int) - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
- 
Rre-use and reset this instance on the provided slices. 
- reset(MultiTermsEnum.TermsEnumIndex[]) - Method in class org.apache.lucene.index.MultiTermsEnum
- 
- reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataOutput
-  
- reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
-  
- reset() - Method in class org.apache.lucene.store.RAMOutputStream
- 
Resets this to an empty file. 
- reset() - Method in class org.apache.lucene.util.ByteBlockPool
- 
- reset(boolean, boolean) - Method in class org.apache.lucene.util.ByteBlockPool
- 
Expert: Resets the pool to its initial state reusing the first buffer. 
- reset() - Method in class org.apache.lucene.util.IntBlockPool
- 
Resets the pool to its initial state reusing the first buffer. 
- reset(boolean, boolean) - Method in class org.apache.lucene.util.IntBlockPool
- 
Expert: Resets the pool to its initial state reusing the first buffer. 
- reset(int, int) - Method in class org.apache.lucene.util.IntBlockPool.SliceReader
- 
Resets the reader to a slice give the slices absolute start and end offset in the pool 
- reset(int) - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
-  
- reset(DataInput, long) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
- 
Reset the current reader to wrap a stream of valueCountvalues contained inin.
 
- reset() - Method in class org.apache.lucene.util.RollingBuffer
-  
- reset() - Method in interface org.apache.lucene.util.RollingBuffer.Resettable
-  
- resetSkip() - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
- 
Creates new buffers or empties the existing ones 
- resize(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- resizeBuffer(int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- 
Grows the termBuffer to at least size newSize, preserving the
  existing content. 
- resizeBuffer(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- restore(int, int) - Method in class org.apache.lucene.util.TimSorter
- 
Restore element jfrom the temporary storage into sloti.
 
- restoreInvariant() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Restores representation invariant. 
- restoreState(AttributeSource.State) - Method in class org.apache.lucene.util.AttributeSource
- 
Restores this state by copying the values of all attribute implementations
 that this state contains into the attributes implementations of the targetStream. 
- reThrow(Throwable) - Static method in class org.apache.lucene.util.IOUtils
- 
Simple utilty method that takes a previously caught
 Throwableand rethrows eitherIOExceptionor an unchecked exception.
 
- reverse(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
- 
Reverses the language of the given (non-singleton) automaton while returning
 the set of new initial states. 
- reversed() - Method in class org.apache.lucene.util.fst.FST.BytesReader
- 
Returns true if this reader uses reversed bytes
  under-the-hood. 
- reverseMul - Variable in class org.apache.lucene.search.FieldValueHitQueue
-  
- rewind() - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.BooleanQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.ConstantScoreQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
- 
Optimize our representation and our subqueries representations 
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.DocTermOrdsRewriteMethod
-  
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.FieldCacheRewriteMethod
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.FilteredQuery
- 
Rewrites the query. 
- rewrite(Query) - Method in class org.apache.lucene.search.IndexSearcher
- 
Expert: called to re-write queries into primitive queries. 
- rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiPhraseQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiTermQuery
- 
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.NGramPhraseQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.PhraseQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.Query
- 
Expert: called to re-write queries into primitive queries. 
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.ScoringRewrite
-  
- rewrite(IndexSearcher) - Method in class org.apache.lucene.search.Sort
- 
Rewrites the SortFields in this Sort, returning a new Sort if any of the fields
 changes during their rewriting. 
- rewrite(IndexSearcher) - Method in class org.apache.lucene.search.SortField
- 
Rewrites this SortField, returning a new SortField if a change is made. 
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-  
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.SpanRewriteMethod
-  
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-  
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-  
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.TopTermsRewrite
-  
- rewriteMethod - Variable in class org.apache.lucene.search.MultiTermQuery
-  
- rollback() - Method in class org.apache.lucene.index.IndexWriter
- 
Close the IndexWriterwithout committing
 any changes that have occurred since the last commit
 (or since it was opened, if commit hasn't been called).
 
- rollback() - Method in interface org.apache.lucene.index.TwoPhaseCommit
- 
Discards any changes that have occurred since the last commit. 
- RollingBuffer<T extends RollingBuffer.Resettable> - Class in org.apache.lucene.util
- 
Acts like forever growing T[], but internally uses a
  circular buffer to reuse instances of T. 
- RollingBuffer() - Constructor for class org.apache.lucene.util.RollingBuffer
-  
- RollingBuffer.Resettable - Interface in org.apache.lucene.util
- 
Implement to reset an instance 
- round(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
- 
Limit a date's resolution. 
- round(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
- 
Limit a date's resolution. 
- run() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
-  
- run() - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
- 
- run(IndexCommit) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
- 
- run() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
-  
- run() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-  
- run() - Method in class org.apache.lucene.store.Lock.With
- 
- run(Automaton, String) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns true if the given string is accepted by the automaton. 
- run(byte[], int, int) - Method in class org.apache.lucene.util.automaton.ByteRunAutomaton
- 
Returns true if the given byte array is accepted by this automaton 
- run(String) - Method in class org.apache.lucene.util.automaton.CharacterRunAutomaton
- 
Returns true if the given string is accepted by this automaton. 
- run(char[], int, int) - Method in class org.apache.lucene.util.automaton.CharacterRunAutomaton
- 
Returns true if the given string is accepted by this automaton 
- runAutomaton - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
- 
Matcher for quickly determining if a byte[] is accepted. 
- RunAutomaton - Class in org.apache.lucene.util.automaton
- 
Finite-state automaton with fast run operation. 
- RunAutomaton(Automaton, int, boolean) - Constructor for class org.apache.lucene.util.automaton.RunAutomaton
- 
Constructs a new RunAutomatonfrom a deterministicAutomaton.
 
- sameLanguage(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns true if these two automata accept exactly the
  same language. 
- save(DataOutput) - Method in class org.apache.lucene.util.fst.FST
-  
- save(File) - Method in class org.apache.lucene.util.fst.FST
- 
Writes an automaton to a file. 
- save(DataOutput) - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- save(DataOutput) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
- 
Save this mutable into out.
 
- save(int, int) - Method in class org.apache.lucene.util.TimSorter
- 
Save all elements between slots iandi+leninto the temporary storage.
 
- scale_factor - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- score(List<SegmentCommitInfo>, boolean, long) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Expert: scores one merge; subclasses can override. 
- score() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- score(Collector) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- score(Collector, int, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
-  
- score() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
-  
- score() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
-  
- score(Collector, int, int) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- score() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- score(Collector) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-  
- score - Variable in class org.apache.lucene.search.ScoreDoc
- 
The score of this document for the query. 
- score(Collector) - Method in class org.apache.lucene.search.Scorer
- 
Scores and collects all matching documents. 
- score(Collector, int, int) - Method in class org.apache.lucene.search.Scorer
- 
Expert: Collects matching documents in a range. 
- score() - Method in class org.apache.lucene.search.Scorer
- 
Returns the score of the current document matching the query. 
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect
- 
Returns the aftereffect score. 
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectB
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectL
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModel
- 
Returns the informative content score. 
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelBE
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelD
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelG
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIF
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIn
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIne
-  
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelP
-  
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-  
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Distribution
- 
Computes the score. 
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.DistributionLL
-  
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.DistributionSPL
-  
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.IBSimilarity
-  
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
-  
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-  
- score(int, float) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
- 
Score a single document 
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Scores the document doc.
 
- score() - Method in class org.apache.lucene.search.spans.SpanScorer
-  
- ScoreCachingWrappingScorer - Class in org.apache.lucene.search
- 
A  Scorer which wraps another scorer and caches the score of the
 current document. 
- ScoreCachingWrappingScorer(Scorer) - Constructor for class org.apache.lucene.search.ScoreCachingWrappingScorer
- 
Creates a new instance by wrapping the given scorer. 
- ScoreDoc - Class in org.apache.lucene.search
- 
- ScoreDoc(int, float) - Constructor for class org.apache.lucene.search.ScoreDoc
- 
Constructs a ScoreDoc. 
- ScoreDoc(int, float, int) - Constructor for class org.apache.lucene.search.ScoreDoc
- 
Constructs a ScoreDoc. 
- scoreDocs - Variable in class org.apache.lucene.search.TopDocs
- 
The top hits for the query. 
- scorePayload(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
The default implementation returns 1
 
- scorePayload(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
The default implementation returns 1
 
- scorePayload(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Calculate a scoring factor based on the data in the payload. 
- scorer(AtomicReaderContext, boolean, boolean, Bits) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- scorer(AtomicReaderContext, boolean, boolean, Bits) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
-  
- scorer(AtomicReaderContext, boolean, boolean, Bits) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
- 
Create the scorer used to score our associated DisjunctionMaxQuery 
- scorer(AtomicReaderContext, boolean, boolean, Bits) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
-  
- scorer(AtomicReaderContext, boolean, boolean, Bits) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight
-  
- Scorer - Class in org.apache.lucene.search
- 
Expert: Common scoring functionality for different types of queries. 
- Scorer(Weight) - Constructor for class org.apache.lucene.search.Scorer
- 
Constructs a Scorer 
- scorer(AtomicReaderContext, boolean, boolean, Bits) - Method in class org.apache.lucene.search.spans.SpanWeight
-  
- scorer(AtomicReaderContext, boolean, boolean, Bits) - Method in class org.apache.lucene.search.Weight
- 
Returns a  Scorer which scores documents in/out-of order according
 to  scoreDocsInOrder. 
- Scorer.ChildScorer - Class in org.apache.lucene.search
- 
A child Scorer and its relationship to its parent. 
- Scorer.ChildScorer(Scorer, String) - Constructor for class org.apache.lucene.search.Scorer.ChildScorer
- 
Creates a new ChildScorer node with the specified relationship. 
- scoresDocsOutOfOrder() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
-  
- scoresDocsOutOfOrder() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
-  
- scoresDocsOutOfOrder() - Method in class org.apache.lucene.search.Weight
- 
Returns true iff this implementation scores docs only out of order. 
- SCORING_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
- 
A rewrite method that first translates each term into
   BooleanClause.Occur.SHOULD clause in a
  BooleanQuery, and keeps the scores as computed by the
  query. 
- SCORING_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
- 
A rewrite method that first translates each term into
   BooleanClause.Occur.SHOULD clause in a
  BooleanQuery, and keeps the scores as computed by the
  query. 
- SCORING_SPAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- 
A rewrite method that first translates each term into a SpanTermQuery in a
  BooleanClause.Occur.SHOULD clause in a BooleanQuery, and keeps the
 scores as computed by the query. 
- ScoringRewrite<Q extends Query> - Class in org.apache.lucene.search
- 
Base rewrite method that translates each term into a query, and keeps
 the scores as computed by the query. 
- ScoringRewrite() - Constructor for class org.apache.lucene.search.ScoringRewrite
-  
- search(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Finds the top nhits forquery.
 
- search(Query, Filter, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Finds the top nhits forquery, applyingfilterif non-null.
 
- search(Query, Filter, Collector) - Method in class org.apache.lucene.search.IndexSearcher
- 
Lower-level search API. 
- search(Query, Collector) - Method in class org.apache.lucene.search.IndexSearcher
- 
Lower-level search API. 
- search(Query, Filter, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
- 
Search implementation with arbitrary sorting. 
- search(Query, Filter, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
- 
Search implementation with arbitrary sorting, plus
 control over whether hit scores and max score
 should be computed. 
- search(Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
- 
Search implementation with arbitrary sorting and no filter. 
- search(Weight, ScoreDoc, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Expert: Low-level search implementation. 
- search(List<AtomicReaderContext>, Weight, ScoreDoc, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Expert: Low-level search implementation. 
- search(Weight, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
- 
Expert: Low-level search implementation with arbitrary
 sorting and control over whether hit scores and max
 score should be computed. 
- search(Weight, FieldDoc, int, Sort, boolean, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
- 
- search(List<AtomicReaderContext>, Weight, FieldDoc, int, Sort, boolean, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
- 
- search(List<AtomicReaderContext>, Weight, Collector) - Method in class org.apache.lucene.search.IndexSearcher
- 
Lower-level search API. 
- search() - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-  
- searchAfter(ScoreDoc, Query, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Finds the top nhits forquerywhere all results are after a previous 
 result (after).
 
- searchAfter(ScoreDoc, Query, Filter, int) - Method in class org.apache.lucene.search.IndexSearcher
- 
Finds the top nhits forquery, applyingfilterif non-null,
 where all results are after a previous result (after).
 
- searchAfter(ScoreDoc, Query, Filter, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
- 
Finds the top nhits forquery, applyingfilterif non-null,
 where all results are after a previous result (after).
 
- searchAfter(ScoreDoc, Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
- 
Finds the top nhits forquerywhere all results are after a previous 
 result (after).
 
- searchAfter(ScoreDoc, Query, Filter, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
- 
Finds the top nhits forquerywhere all results are after a previous 
 result (after), allowing control over
 whether hit scores and max score should be computed.
 
- SearcherFactory - Class in org.apache.lucene.search
- 
- SearcherFactory() - Constructor for class org.apache.lucene.search.SearcherFactory
-  
- SearcherLifetimeManager - Class in org.apache.lucene.search
- 
Keeps track of current plus old IndexSearchers, closing
 the old ones once they have timed out. 
- SearcherLifetimeManager() - Constructor for class org.apache.lucene.search.SearcherLifetimeManager
-  
- SearcherLifetimeManager.PruneByAge - Class in org.apache.lucene.search
- 
Simple pruner that drops any searcher older by
  more than the specified seconds, than the newest
  searcher. 
- SearcherLifetimeManager.PruneByAge(double) - Constructor for class org.apache.lucene.search.SearcherLifetimeManager.PruneByAge
-  
- SearcherLifetimeManager.Pruner - Interface in org.apache.lucene.search
- 
- SearcherManager - Class in org.apache.lucene.search
- 
Utility class to safely share  IndexSearcher instances across multiple
 threads, while periodically reopening. 
- SearcherManager(IndexWriter, boolean, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
- 
Creates and returns a new SearcherManager from the given
  IndexWriter. 
- SearcherManager(Directory, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
- 
Creates and returns a new SearcherManager from the given  Directory. 
- seek(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-  
- seek(long) - Method in class org.apache.lucene.store.BufferedIndexOutput
-  
- seek(long) - Method in class org.apache.lucene.store.ChecksumIndexInput
-  
- seek(long) - Method in class org.apache.lucene.store.ChecksumIndexOutput
-  
- seek(long) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
- 
Random-access methods 
- seek(long) - Method in class org.apache.lucene.store.IndexInput
- 
Sets current position in this file, where the next read will occur. 
- seek(long) - Method in class org.apache.lucene.store.IndexOutput
- 
Deprecated.
(4.1) This method will be removed in Lucene 5.0 
 
- seek(long) - Method in class org.apache.lucene.store.RAMInputStream
-  
- seek(long) - Method in class org.apache.lucene.store.RAMOutputStream
-  
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
This enum does not support seeking! 
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.TermsEnum
- 
Seeks to the specified term, if it exists, or to the
  next (ceiling) term. 
- seekCeil(BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- seekCeil(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
- 
Seeks to smallest term that's >= target. 
- seekCeil(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
- 
Seeks to smallest term that's >= target. 
- seekChild(int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. 
- seekChild(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Seeks the skip entry on the given level 
- seekDir(IndexInput, long) - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
- 
Seek inputto the directory offset.
 
- seekExact(long) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- seekExact(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
This enum does not support seeking! 
- seekExact(long) - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
This enum does not support seeking! 
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
This enum does not support seeking! 
- seekExact(BytesRef) - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- seekExact(long) - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- seekExact(BytesRef) - Method in class org.apache.lucene.index.TermsEnum
- 
Attempts to seek to the exact term, returning
  true if the term is found. 
- seekExact(long) - Method in class org.apache.lucene.index.TermsEnum
- 
Seeks to the specified term by ordinal (position) as
  previously returned by  TermsEnum.ord(). 
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.TermsEnum
- 
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- seekExact(BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- seekExact(long) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- seekExact(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
- 
Seeks to exactly this term, returning null if the term
  doesn't exist. 
- seekExact(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
- 
Seeks to exactly this term, returning null if the term
  doesn't exist. 
- seekFloor(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
- 
Seeks to biggest term that's <= target. 
- seekFloor(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
- 
Seeks to biggest term that's <= target. 
- seekInternal(long) - Method in class org.apache.lucene.store.BufferedIndexInput
- 
Expert: implements seek. 
- seekInternal(long) - Method in class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
-  
- seekInternal(long) - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
-  
- segment - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Segment name. 
- SegmentCommitInfo - Class in org.apache.lucene.index
- 
Embeds a [read-only] SegmentInfo and adds per-commit
  fields. 
- SegmentCommitInfo(SegmentInfo, int, long, long) - Constructor for class org.apache.lucene.index.SegmentCommitInfo
- 
Sole constructor. 
- segmentFileName(String, String, String) - Static method in class org.apache.lucene.index.IndexFileNames
- 
Returns a file name that includes the given segment name, your own custom
 name and extension. 
- segmentInfo - Variable in class org.apache.lucene.index.MergeState
- 
- SegmentInfo - Class in org.apache.lucene.index
- 
Information about a segment such as it's name, directory, and files related
 to the segment. 
- SegmentInfo(Directory, String, String, int, boolean, Codec, Map<String, String>) - Constructor for class org.apache.lucene.index.SegmentInfo
- 
Construct a new complete SegmentInfo instance from input. 
- SegmentInfo(Directory, String, String, int, boolean, Codec, Map<String, String>, Map<String, String>) - Constructor for class org.apache.lucene.index.SegmentInfo
- 
Construct a new complete SegmentInfo instance from input. 
- segmentInfo - Variable in class org.apache.lucene.index.SegmentReadState
- 
- segmentInfo - Variable in class org.apache.lucene.index.SegmentWriteState
- 
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.Codec
- 
Encodes/decodes segment info file 
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-  
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. 
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. 
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. 
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. 
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
-  
- SegmentInfoFormat - Class in org.apache.lucene.codecs
- 
Expert: Controls the format of the 
  SegmentInfo (segment metadata file). 
- SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.SegmentInfoFormat
- 
Sole constructor. 
- SegmentInfoReader - Class in org.apache.lucene.codecs
- 
Specifies an API for classes that can read  SegmentInfo information. 
- SegmentInfoReader() - Constructor for class org.apache.lucene.codecs.SegmentInfoReader
- 
Sole constructor. 
- segmentInfos - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
- SegmentInfos - Class in org.apache.lucene.index
- 
A collection of segmentInfo objects with methods for operating on
 those segments in relation to the file system. 
- SegmentInfos() - Constructor for class org.apache.lucene.index.SegmentInfos
- 
Sole constructor. 
- SegmentInfos.FindSegmentsFile - Class in org.apache.lucene.index
- 
Utility class for executing code that needs to do
 something with the current segments file. 
- SegmentInfos.FindSegmentsFile(Directory) - Constructor for class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
- 
Sole constructor. 
- SegmentInfoWriter - Class in org.apache.lucene.codecs
- 
Specifies an API for classes that can write out  SegmentInfo data. 
- SegmentInfoWriter() - Constructor for class org.apache.lucene.codecs.SegmentInfoWriter
- 
Sole constructor. 
- SegmentReader - Class in org.apache.lucene.index
- 
IndexReader implementation over a single segment. 
- SegmentReader(SegmentCommitInfo, int, IOContext) - Constructor for class org.apache.lucene.index.SegmentReader
- 
Constructs a new SegmentReader with a new core. 
- SegmentReader.CoreClosedListener - Interface in org.apache.lucene.index
- 
Called when the shared core for this SegmentReader
 is closed. 
- SegmentReadState - Class in org.apache.lucene.index
- 
Holder class for common parameters used during read. 
- SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext, int) - Constructor for class org.apache.lucene.index.SegmentReadState
- 
Create a SegmentReadState.
 
- SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext, int, String) - Constructor for class org.apache.lucene.index.SegmentReadState
- 
Create a SegmentReadState.
 
- SegmentReadState(SegmentReadState, String) - Constructor for class org.apache.lucene.index.SegmentReadState
- 
Create a SegmentReadState.
 
- SEGMENTS - Static variable in class org.apache.lucene.index.IndexFileNames
- 
Name of the index segment file 
- segments - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Segments to be merged. 
- SEGMENTS_GEN - Static variable in class org.apache.lucene.index.IndexFileNames
- 
Name of the generation reference file name 
- segmentsChecked - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
Empty unless you passed specific segments list to check as optional 3rd argument. 
- segmentsFileName - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
Name of latest segments_N file in the index. 
- segmentSuffix - Variable in class org.apache.lucene.index.SegmentReadState
- 
Unique suffix for any postings files read for this
  segment. 
- segmentSuffix - Variable in class org.apache.lucene.index.SegmentWriteState
- 
Unique suffix for any postings files written for this
  segment. 
- SegmentWriteState - Class in org.apache.lucene.index
- 
Holder class for common parameters used during write. 
- SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, int, BufferedUpdates, IOContext) - Constructor for class org.apache.lucene.index.SegmentWriteState
- 
Sole constructor. 
- SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, int, BufferedUpdates, IOContext, String) - Constructor for class org.apache.lucene.index.SegmentWriteState
- 
Constructor which takes segment suffix. 
- SegmentWriteState(SegmentWriteState, String) - Constructor for class org.apache.lucene.index.SegmentWriteState
- 
- segString() - Method in class org.apache.lucene.index.IndexWriter
- 
Returns a string description of all segments, for
  debugging. 
- segString(Iterable<SegmentCommitInfo>) - Method in class org.apache.lucene.index.IndexWriter
- 
Returns a string description of the specified
  segments, for debugging. 
- segString(SegmentCommitInfo) - Method in class org.apache.lucene.index.IndexWriter
- 
Returns a string description of the specified
  segment, for debugging. 
- segString(Directory) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
- 
Returns a description of the merges in this
  specification. 
- segString(Directory) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Returns a readable description of the current merge
  state. 
- segUpdates - Variable in class org.apache.lucene.index.SegmentWriteState
- 
Deletes and updates to apply while we are flushing the segment. 
- select(long, int) - Static method in class org.apache.lucene.util.BroadWord
- 
Select a 1-bit from a long. 
- selectNaive(long, int) - Static method in class org.apache.lucene.util.BroadWord
- 
- SentinelIntSet - Class in org.apache.lucene.util
- 
A native int hash-based set where one value is reserved to mean "EMPTY" internally. 
- SentinelIntSet(int, int) - Constructor for class org.apache.lucene.util.SentinelIntSet
-  
- SerialMergeScheduler - Class in org.apache.lucene.index
- 
A  MergeScheduler that simply does each merge
  sequentially, using the current thread. 
- SerialMergeScheduler() - Constructor for class org.apache.lucene.index.SerialMergeScheduler
- 
Sole constructor. 
- set(T) - Method in class org.apache.lucene.util.CloseableThreadLocal
-  
- set(int) - Method in class org.apache.lucene.util.FixedBitSet
-  
- set(int, int) - Method in class org.apache.lucene.util.FixedBitSet
- 
Sets a range of bits 
- set(long) - Method in class org.apache.lucene.util.LongBitSet
-  
- set(long, long) - Method in class org.apache.lucene.util.LongBitSet
- 
Sets a range of bits 
- set(long) - Method in class org.apache.lucene.util.OpenBitSet
- 
sets a bit, expanding the set size if necessary 
- set(long, long) - Method in class org.apache.lucene.util.OpenBitSet
- 
Sets a range of bits, expanding the set size if necessary 
- set(int, long) - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- set(int, long[], int, int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- set(int, long) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
- 
Set the value at the given index in the array. 
- set(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
- 
Bulk set: set at least one and at most lenlongs starting
 atoffinarrinto this mutable, starting atindex.
 
- set(T) - Method in class org.apache.lucene.util.SetOnce
- 
Sets the given object. 
- setAccept(boolean) - Method in class org.apache.lucene.util.automaton.State
- 
Sets acceptance for this state. 
- setActualDocFreq(int, int) - Method in class org.apache.lucene.index.DocTermOrds
- 
- setAllowMutate(boolean) - Static method in class org.apache.lucene.util.automaton.Automaton
- 
Sets or resets allow mutate flag. 
- setAllowMutate(boolean) - Method in class org.apache.lucene.util.automaton.RegExp
- 
Sets or resets allow mutate flag. 
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.util.QueryBuilder
- 
Sets the analyzer used to tokenize text. 
- setAvgFieldLength(float) - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Sets the average field length. 
- setBaseline(long) - Method in class org.apache.lucene.search.TimeLimitingCollector
- 
Sets the baseline for this collector. 
- setBaseline() - Method in class org.apache.lucene.search.TimeLimitingCollector
- 
- setBoost(float) - Method in class org.apache.lucene.document.Field
- 
Sets the boost factor on this field. 
- setBoost(float) - Method in class org.apache.lucene.index.FieldInvertState
- 
Set boost value. 
- setBoost(float) - Method in interface org.apache.lucene.search.BoostAttribute
- 
Sets the boost in this attribute 
- setBoost(float) - Method in class org.apache.lucene.search.BoostAttributeImpl
-  
- setBoost(float) - Method in class org.apache.lucene.search.Query
- 
Sets the boost for this query clause to b.
 
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 
Deprecated. 
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-  
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-  
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-  
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-  
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-  
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-  
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator
- 
Set the bottom slot, ie the "weakest" (sorted last)
 entry in the queue. 
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- 
Deprecated. 
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- setBufferSize(int) - Method in class org.apache.lucene.store.BufferedIndexInput
- 
Change the buffer size used by this IndexInput 
- setBytesComparator(Comparator<BytesRef>) - Method in class org.apache.lucene.search.SortField
-  
- setBytesRef(BytesRef, int) - Method in class org.apache.lucene.util.ByteBlockPool
-  
- setBytesValue(byte[]) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setByteValue(byte) - Method in class org.apache.lucene.document.ByteDocValuesField
- 
Deprecated. 
- setByteValue(byte) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setCalibrateSizeByDeletes(boolean) - Method in class org.apache.lucene.index.LogMergePolicy
- 
Sets whether the segment size should be calibrated by
  the number of deletes when choosing segments for merge. 
- setCodec(Codec) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
- setCodec(Codec) - Method in class org.apache.lucene.index.SegmentInfo
- 
Can only be called once. 
- setCollectionProbability(float) - Method in class org.apache.lucene.search.similarities.LMSimilarity.LMStats
- 
Sets the probability that the current term is generated by the
 collection. 
- setCollector(Collector) - Method in class org.apache.lucene.search.TimeLimitingCollector
- 
This is so the same timer can be used with a multi-phase search process such as grouping. 
- setCommitData(Map<String, String>) - Method in class org.apache.lucene.index.IndexWriter
- 
Sets the commit user data map. 
- setComparator(int, FieldComparator<?>) - Method in class org.apache.lucene.search.FieldValueHitQueue
-  
- setCompetitiveTerm(BytesRef) - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
- 
This is the term or nullof the term that triggered the boost change.
 
- setCompetitiveTerm(BytesRef) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-  
- setCrossCheckTermVectors(boolean) - Method in class org.apache.lucene.index.CheckIndex
- 
If true, term vectors are compared against postings to
  make sure they are the same. 
- setCurrentLabel(int) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-  
- setCurrentLabel(int) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-  
- setDefault(Codec) - Static method in class org.apache.lucene.codecs.Codec
- 
- setDefault(InfoStream) - Static method in class org.apache.lucene.util.InfoStream
- 
Sets the default InfoStreamused
 by a newly instantiated classes.
 
- setDefaultGenLookaheadCount(int) - Static method in class org.apache.lucene.index.SegmentInfos
- 
Advanced: set how many times to try incrementing the
 gen when loading the segments file. 
- setDefaultWriteLockTimeout(long) - Static method in class org.apache.lucene.index.IndexWriterConfig
- 
Sets the default (for any instance) maximum time to wait for a write lock
 (in milliseconds). 
- setDescription(String) - Method in class org.apache.lucene.search.Explanation
- 
Sets the description of this explanation node. 
- setDeterministic(boolean) - Method in class org.apache.lucene.util.automaton.Automaton
- 
Sets deterministic flag for this automaton. 
- setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Sets whether overlap tokens (Tokens with 0 position increment) are 
  ignored when computing norm. 
- setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Determines whether overlap tokens (Tokens with
  0 position increment) are ignored when computing
  norm. 
- setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Determines whether overlap tokens (Tokens with
  0 position increment) are ignored when computing
  norm. 
- setDocFreq(int) - Method in class org.apache.lucene.index.TermContext
- 
expert: only available for queries that want to lie about docfreq 
- setDocFreq(long) - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Sets the document frequency. 
- setDocument(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-  
- setDocument(int) - Method in class org.apache.lucene.index.SingletonSortedSetDocValues
-  
- setDocument(int) - Method in class org.apache.lucene.index.SortedSetDocValues
- 
Sets iteration to the specified docID 
- setDocValuesGen(long) - Method in class org.apache.lucene.index.FieldInfo
- 
Sets the docValues generation of this field. 
- setDocValueType(FieldInfo.DocValuesType) - Method in class org.apache.lucene.document.FieldType
- 
Set's the field's DocValuesType 
- setDoubleValue(double) - Method in class org.apache.lucene.analysis.NumericTokenStream
- 
Initializes the token stream with the supplied doublevalue.
 
- setDoubleValue(double) - Method in class org.apache.lucene.document.DoubleDocValuesField
-  
- setDoubleValue(double) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setEmpty() - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- 
Sets the length of the termBuffer to zero. 
- setEmpty() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.util.QueryBuilder
- 
Set to trueto enable position increments in result query.
 
- setEnum(TermsEnum) - Method in class org.apache.lucene.search.FuzzyTermsEnum
- 
swap in a new actual enum to proxy to 
- setField(FieldInfo) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- setField(FieldInfo) - Method in class org.apache.lucene.codecs.PostingsWriterBase
- 
Sets the current field for writing, and returns the
 fixed length of long[] metadata (which is fixed per
 field), called when the writing switches to another field. 
- setFiles(Set<String>) - Method in class org.apache.lucene.index.SegmentInfo
- 
Sets the files written for this segment. 
- setFlags(int) - Method in class org.apache.lucene.analysis.Token
- 
Set the flags to a new bitset. 
- setFlags(int) - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute
- 
Set the flags to a new bitset. 
- setFlags(int) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-  
- setFloatValue(float) - Method in class org.apache.lucene.analysis.NumericTokenStream
- 
Initializes the token stream with the supplied floatvalue.
 
- setFloatValue(float) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setFloatValue(float) - Method in class org.apache.lucene.document.FloatDocValuesField
-  
- setFloorSegmentMB(double) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Segments smaller than this are "rounded up" to this
  size, ie treated as equal (floor) size for merge
  selection. 
- setForceMergeDeletesPctAllowed(double) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
When forceMergeDeletes is called, we only merge away a
  segment if its delete percentage is over this
  threshold. 
- setFreqCurrentDoc() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
-  
- setFreqCurrentDoc() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
-  
- setFreqCurrentDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
-  
- setGenUpdatesFiles(Map<Long, Set<String>>) - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Sets the updates file names per generation. 
- setGreedy(boolean) - Method in class org.apache.lucene.search.TimeLimitingCollector
- 
Sets whether this time limited collector is greedy. 
- setIndexCommit(IndexCommit) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Expert: allows to open a certain commit point. 
- setIndexDeletionPolicy(IndexDeletionPolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
- setIndexed(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to trueto index (invert) this field.
 
- setIndexInterval(int) - Method in class org.apache.lucene.util.PForDeltaDocIdSet.Builder
- 
Set the index interval. 
- setIndexInterval(int) - Method in class org.apache.lucene.util.WAH8DocIdSet.Builder
-  
- setIndexOptions(FieldInfo.IndexOptions) - Method in class org.apache.lucene.document.FieldType
- 
Sets the indexing options for the field: 
- setIndexWriter(IndexWriter) - Method in class org.apache.lucene.index.MergePolicy
- 
- setIndexWriter(IndexWriter) - Method in class org.apache.lucene.index.NoMergePolicy
-  
- setIndexWriter(IndexWriter) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-  
- setInfo(SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
- setInfo(Object) - Method in class org.apache.lucene.util.automaton.Automaton
- 
Associates extra information with this automaton. 
- setInfoStream(PrintStream, boolean) - Method in class org.apache.lucene.index.CheckIndex
- 
Set infoStream where messages should go. 
- setInfoStream(PrintStream) - Method in class org.apache.lucene.index.CheckIndex
- 
Set infoStream where messages should go. 
- setInfoStream(InfoStream) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Information about merges, deletes and a
 message when maxFieldLength is reached will be printed
 to this. 
- setInfoStream(PrintStream) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
- setInfoStream(PrintStream) - Static method in class org.apache.lucene.index.SegmentInfos
- 
If non-null, information about retries when loading
 the segments file will be printed to this. 
- setInfoStream(PrintStream) - Method in interface org.apache.lucene.search.FieldCache
- 
If non-null, FieldCacheImpl will warn whenever
 entries are created that are not sane according to
  FieldCacheSanityChecker. 
- setInitialSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
Use this method to set the initial  BytesRef
 to seek before iterating. 
- setIntValue(int) - Method in class org.apache.lucene.analysis.NumericTokenStream
- 
Initializes the token stream with the supplied intvalue.
 
- setIntValue(int) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setIntValue(int) - Method in class org.apache.lucene.document.IntDocValuesField
- 
Deprecated. 
- setKeyword(boolean) - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
- 
Marks the current token as keyword if set to true.
 
- setKeyword(boolean) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-  
- setLastOutput(int, T) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-  
- setLastSkipData(int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
- 
Deprecated. 
- setLastSkipData(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Copies the values of the last read skip entry on this level 
- setLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
- 
Set number of valid characters (length of the term) in
  the termBuffer array. 
- setLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- setLength(int) - Method in class org.apache.lucene.index.FieldInvertState
- 
Set length value. 
- setLength(long) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
-  
- setLength(long) - Method in class org.apache.lucene.store.IndexOutput
- 
Set the file length. 
- setLength(long) - Method in class org.apache.lucene.store.RAMFile
-  
- setLockDir(File) - Method in class org.apache.lucene.store.FSLockFactory
- 
Set the lock directory. 
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.BaseDirectory
-  
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.Directory
- 
Set the LockFactory that this Directory instance should
 use for its locking implementation. 
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.FilterDirectory
-  
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.FSDirectory
-  
- setLockFactory(LockFactory) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- setLockPrefix(String) - Method in class org.apache.lucene.store.LockFactory
- 
Set the prefix in use for all locks created in this
 LockFactory. 
- setLongValue(long) - Method in class org.apache.lucene.analysis.NumericTokenStream
- 
Initializes the token stream with the supplied longvalue.
 
- setLongValue(long) - Method in class org.apache.lucene.document.DoubleDocValuesField
-  
- setLongValue(long) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setLongValue(long) - Method in class org.apache.lucene.document.FloatDocValuesField
-  
- setMatch(Boolean) - Method in class org.apache.lucene.search.ComplexExplanation
- 
Sets the match status assigned to this explanation node. 
- setMaxBufferedDeleteTerms(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- setMaxBufferedDeleteTerms(int) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Determines the maximum number of delete-by-term operations that will be
 buffered before both the buffered in-memory delete terms and queries are
 applied and flushed. 
- setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Determines the minimal number of documents required before the buffered
 in-memory documents are flushed as a new Segment. 
- setMaxCFSSegmentSizeMB(double) - Method in class org.apache.lucene.index.MergePolicy
- 
If a merged segment will be more than this value,
  leave the segment as
  non-compound file even if compound file is enabled. 
- setMaxClauseCount(int) - Static method in class org.apache.lucene.search.BooleanQuery
- 
Set the maximum number of clauses permitted per BooleanQuery. 
- setMaxMergeAtOnce(int) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Maximum number of segments to be merged at a time
  during "normal" merging. 
- setMaxMergeAtOnceExplicit(int) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Maximum number of segments to be merged at a time,
  during forceMerge or forceMergeDeletes. 
- setMaxMergeDocs(int) - Method in class org.apache.lucene.index.LogMergePolicy
- 
Determines the largest segment (measured by
 document count) that may be merged with other segments. 
- setMaxMergedSegmentMB(double) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Maximum sized segment to produce during
  normal merging. 
- setMaxMergeMB(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
- 
Determines the largest segment (measured by total
  byte size of the segment's files, in MB) that may be
  merged with other segments. 
- setMaxMergeMBForForcedMerge(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
- 
Determines the largest segment (measured by total
  byte size of the segment's files, in MB) that may be
  merged with other segments during forceMerge. 
- setMaxMergesAndThreads(int, int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Sets the maximum number of merge threads and simultaneous merges allowed. 
- setMaxNonCompetitiveBoost(float) - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
- 
This is the maximum boost that would not be competitive. 
- setMaxNonCompetitiveBoost(float) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-  
- setMaxScore(float) - Method in class org.apache.lucene.search.TopDocs
- 
Sets the maximum score value encountered. 
- setMaxThreadStates(int) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Sets the max number of simultaneous threads that may be indexing documents
 at once in IndexWriter. 
- setMaxWriteMBPerSec(Double, IOContext.Context) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
- 
- setMbPerSec(double) - Method in class org.apache.lucene.store.RateLimiter
- 
Sets an updated mb per second rate limit. 
- setMbPerSec(double) - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
- 
Sets an updated mb per second rate limit. 
- setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Set the merged segment warmer. 
- setMergeFactor(int) - Method in class org.apache.lucene.index.LogMergePolicy
- 
Determines how often segment indices are merged by
 addDocument(). 
- setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Expert:  MergePolicy is invoked whenever there are changes to the
 segments in the index. 
- setMergeScheduler(MergeScheduler) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Expert: sets the merge scheduler used by this writer. 
- setMergeState(MergeState) - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
- 
Sets the  MergeState, which is used to re-map
  document IDs. 
- setMergeState(MergeState) - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
- 
Sets the  MergeState, which is used to re-map
  document IDs. 
- setMergeThreadPriority(int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Set the base priority that merge threads run at. 
- setMinimization(int) - Static method in class org.apache.lucene.util.automaton.Automaton
- 
Selects minimization algorithm (default: MINIMIZE_HOPCROFT).
 
- setMinimizeAlways(boolean) - Static method in class org.apache.lucene.util.automaton.Automaton
- 
Sets or resets minimize always flag. 
- setMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.search.BooleanQuery
- 
Specifies a minimum number of the optional BooleanClauses
 which must be satisfied. 
- setMinMergeDocs(int) - Method in class org.apache.lucene.index.LogDocMergePolicy
- 
Sets the minimum size for the lowest level segments. 
- setMinMergeMB(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
- 
Sets the minimum size for the lowest level segments. 
- setMissingValue(Object) - Method in class org.apache.lucene.search.SortField
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.CachingCollector
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.Collector
- 
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 
Deprecated. 
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.NumericComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator
- 
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- 
Deprecated. 
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.MultiCollector
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.TimeLimitingCollector
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.TopScoreDocCollector
-  
- setNextReader(AtomicReaderContext) - Method in class org.apache.lucene.search.TotalHitCountCollector
-  
- setNoCFSRatio(double) - Method in class org.apache.lucene.index.MergePolicy
- 
If a merged segment will be more than this percentage
  of the total size of the index, leave the segment as
  non-compound file even if compound file is enabled. 
- setNumberedStates(State[]) - Method in class org.apache.lucene.util.automaton.Automaton
-  
- setNumberedStates(State[], int) - Method in class org.apache.lucene.util.automaton.Automaton
-  
- setNumberOfDocuments(long) - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Sets the number of documents. 
- setNumberOfFieldTokens(long) - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Sets the total number of tokens in the field. 
- setNumericPrecisionStep(int) - Method in class org.apache.lucene.document.FieldType
- 
Sets the numeric precision step for the field. 
- setNumericType(FieldType.NumericType) - Method in class org.apache.lucene.document.FieldType
- 
Specifies the field's numeric type. 
- setNumOverlap(int) - Method in class org.apache.lucene.index.FieldInvertState
- 
Set number of terms with positionIncrement ==
  0.
 
- setOccur(BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanClause
-  
- setOffset(int, int) - Method in class org.apache.lucene.analysis.Token
- 
Set the starting and ending offset. 
- setOffset(int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
- 
Set the starting and ending offset. 
- setOffset(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-  
- setOmitNorms(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to trueto omit normalization values for the field.
 
- SetOnce<T> - Class in org.apache.lucene.util
- 
A convenient class which offers a semi-immutable object wrapper
 implementation which allows one to set the value of an object exactly once,
 and retrieve it many times. 
- SetOnce() - Constructor for class org.apache.lucene.util.SetOnce
- 
A default constructor which does not set the internal object, and allows
 setting it by calling  SetOnce.set(Object). 
- SetOnce(T) - Constructor for class org.apache.lucene.util.SetOnce
- 
Creates a new instance with the internal object set to the given object. 
- SetOnce.AlreadySetException - Exception in org.apache.lucene.util
- 
- SetOnce.AlreadySetException() - Constructor for exception org.apache.lucene.util.SetOnce.AlreadySetException
-  
- setOpenMode(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
- setPause(boolean) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Set or clear whether this merge is paused paused (for example
   ConcurrentMergeScheduler will pause merges
  if too many are running). 
- setPayload(BytesRef) - Method in class org.apache.lucene.analysis.Token
- 
Sets this Token's payload. 
- setPayload(BytesRef) - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
- 
Sets this Token's payload. 
- setPayload(BytesRef) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-  
- setPivot(int) - Method in class org.apache.lucene.util.IntroSorter
- 
- setPosition(int) - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- setPosition(long) - Method in class org.apache.lucene.util.fst.FST.BytesReader
- 
Set current read position. 
- setPosition(long) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
- 
- setPositionIncrement(int) - Method in class org.apache.lucene.analysis.Token
- 
Set the position increment. 
- setPositionIncrement(int) - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
- 
Set the position increment. 
- setPositionIncrement(int) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-  
- setPositionLength(int) - Method in class org.apache.lucene.analysis.Token
- 
Set the position length of this Token. 
- setPositionLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
- 
Set the position length of this Token. 
- setPositionLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-  
- setPreservePositionIncrements(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
- 
Whether to generate holes in the automaton for missing positions, trueby default.
 
- setQuery(Query) - Method in class org.apache.lucene.search.BooleanClause
-  
- setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Determines the amount of RAM that may be used for buffering added documents
 and deletions before they are flushed to the Directory. 
- setRAMPerThreadHardLimitMB(int) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Expert: Sets the maximum memory consumption per thread triggering a forced
 flush if exceeded. 
- setRamUsageEstimator(boolean) - Method in class org.apache.lucene.util.FieldCacheSanityChecker
- 
If set, estimate size for all CacheEntry objects will be calculateed. 
- setRateLimiter(RateLimiter, IOContext.Context) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
- 
Sets the rate limiter to be used to limit (approx) MB/sec allowed by all IO
 performed with the given  context. 
- setReadChunkSize(int) - Method in class org.apache.lucene.store.FSDirectory
- 
Deprecated.
This is no longer used since Lucene 4.5. 
 
- setReader(Reader) - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
- 
Resets the encapsulated components with the given reader. 
- setReader(Reader) - Method in class org.apache.lucene.analysis.Tokenizer
- 
Expert: Set a new reader on the Tokenizer. 
- setReaderPooling(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
- setReaderTermsIndexDivisor(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- setReaderTermsIndexDivisor(int) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- setReaderValue(Reader) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setReclaimDeletesWeight(double) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Controls how aggressively merges that reclaim more
  deletions are favored. 
- setResolution(long) - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- 
Set the timer resolution. 
- setReusableComponents(Analyzer, String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.Analyzer.GlobalReuseStrategy
- 
Deprecated. 
- setReusableComponents(Analyzer, String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.Analyzer.PerFieldReuseStrategy
- 
Deprecated. 
- setReusableComponents(Analyzer, String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
- 
Stores the given TokenStreamComponents as the reusable components for the
 field with the give name. 
- setRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.search.MultiTermQuery
- 
Sets the rewrite method to be used when executing the
 query. 
- setRewriteMethod(SpanMultiTermQueryWrapper.SpanRewriteMethod) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- 
Expert: sets the rewrite method. 
- setRunningMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- 
Record the currently running merge. 
- setScorer(Scorer) - Method in class org.apache.lucene.search.Collector
- 
- setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-  
- setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator
- 
Sets the Scorer to use in case a document's score is
  needed. 
- setScorer(Scorer) - Method in class org.apache.lucene.search.MultiCollector
-  
- setScorer(Scorer) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
-  
- setScorer(Scorer) - Method in class org.apache.lucene.search.TimeLimitingCollector
-  
- setScorer(Scorer) - Method in class org.apache.lucene.search.TopScoreDocCollector
-  
- setScorer(Scorer) - Method in class org.apache.lucene.search.TotalHitCountCollector
-  
- setSegmentsPerTier(double) - Method in class org.apache.lucene.index.TieredMergePolicy
- 
Sets the allowed number of segments per tier. 
- setShift(int) - Method in interface org.apache.lucene.analysis.NumericTokenStream.NumericTermAttribute
- 
Don't call this method! 
- setShift(int) - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
-  
- setShortValue(short) - Method in class org.apache.lucene.document.Field
- 
Expert: change the value of this field. 
- setShortValue(short) - Method in class org.apache.lucene.document.ShortDocValuesField
- 
Deprecated. 
- setSimilarity(Similarity) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Expert: set the  Similarity implementation used by this IndexWriter. 
- setSimilarity(Similarity) - Method in class org.apache.lucene.search.IndexSearcher
- 
Expert: Set the Similarity implementation used by this IndexSearcher. 
- setSlop(int) - Method in class org.apache.lucene.search.MultiPhraseQuery
- 
Sets the phrase slop for this query. 
- setSlop(int) - Method in class org.apache.lucene.search.PhraseQuery
- 
Sets the number of other words permitted between words in query phrase. 
- setSort(SortField) - Method in class org.apache.lucene.search.Sort
- 
Sets the sort to the given criteria. 
- setSort(SortField...) - Method in class org.apache.lucene.search.Sort
- 
Sets the sort to the given criteria in succession. 
- setStored(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to trueto store this field.
 
- setStoredValue(Analyzer, Object) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
- 
Sets the stored value. 
- setStoreTermVectorOffsets(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to trueto also store token character offsets into the term
 vector for this field.
 
- setStoreTermVectorPayloads(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to trueto also store token payloads into the term
 vector for this field.
 
- setStoreTermVectorPositions(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to trueto also store token positions into the term
 vector for this field.
 
- setStoreTermVectors(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to trueif this field's indexed form should be also stored 
 into term vectors.
 
- setStringValue(String) - Method in class org.apache.lucene.document.Field
- 
 Expert: change the value of this field. 
- setTermIndexInterval(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- setTermIndexInterval(int) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Expert: set the interval between indexed terms. 
- setThreadPriority(int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
- 
Set the priority of this thread. 
- setTokenized(boolean) - Method in class org.apache.lucene.document.FieldType
- 
Set to  true to tokenize this field's contents via the 
 configured  Analyzer. 
- setTokenStream(TokenStream) - Method in class org.apache.lucene.document.Field
- 
Expert: sets the token stream to be used for indexing and causes
 isIndexed() and isTokenized() to return true. 
- setTopValue(Byte) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
- 
Deprecated. 
- setTopValue(Integer) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-  
- setTopValue(Double) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-  
- setTopValue(Float) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-  
- setTopValue(Integer) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-  
- setTopValue(Long) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-  
- setTopValue(Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-  
- setTopValue(T) - Method in class org.apache.lucene.search.FieldComparator
- 
- setTopValue(Short) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
- 
Deprecated. 
- setTopValue(BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-  
- setTopValue(BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-  
- setTotalTermFreq(long) - Method in class org.apache.lucene.search.similarities.BasicStats
- 
Sets the total number of occurrences of this term across all documents. 
- setTransitions(Transition[]) - Method in class org.apache.lucene.util.automaton.State
-  
- setType(String) - Method in class org.apache.lucene.analysis.Token
- 
Set the lexical type. 
- setType(String) - Method in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
- 
Set the lexical type. 
- setType(String) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-  
- setUnicodeArcs(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
- 
Whether to make transition labels Unicode code points instead of UTF8 bytes, 
  falseby default
 
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
- 
Sets if the  IndexWriter should pack newly written segments in a
 compound file. 
- setUseUnmap(boolean) - Method in class org.apache.lucene.store.MMapDirectory
- 
This method enables the workaround for unmapping the buffers
 from address space after closing  IndexInput, that is
 mentioned in the bug report. 
- setValue(float) - Method in class org.apache.lucene.search.Explanation
- 
Sets the value assigned to this explanation node. 
- setVersion(String) - Method in class org.apache.lucene.index.SegmentInfo
- 
Used by DefaultSegmentInfosReader to upgrade a 3.0 segment to record its
 version is "3.0". 
- setWriteLockTimeout(long) - Method in class org.apache.lucene.index.IndexWriterConfig
- 
Sets the maximum time to wait for a write lock (in milliseconds) for this
 instance. 
- shallowSizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Estimates a "shallow" memory usage of the given object. 
- shallowSizeOfInstance(Class<?>) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the shallow instance size in bytes an instance of the given class would occupy. 
- shardIndex - Variable in class org.apache.lucene.search.ScoreDoc
- 
- SHIFT_START_INT - Static variable in class org.apache.lucene.util.NumericUtils
- 
Integers are stored at lower precision by shifting off lower bits. 
- SHIFT_START_LONG - Static variable in class org.apache.lucene.util.NumericUtils
- 
Longs are stored at lower precision by shifting off lower bits. 
- ShortDocValuesField - Class in org.apache.lucene.document
- 
- ShortDocValuesField(String, short) - Constructor for class org.apache.lucene.document.ShortDocValuesField
- 
Deprecated. Creates a new DocValues field with the specified 16-bit short value 
- shortestPaths(FST<T>, FST.Arc<T>, T, Comparator<T>, int, boolean) - Static method in class org.apache.lucene.util.fst.Util
- 
Starting from node, find the top N min cost 
  completions to a final node. 
- shouldUpgradeSegment(SegmentCommitInfo) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
- 
Returns if the given segment should be upgraded. 
- shrink(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- shrink(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- shrink(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- shrink(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- shrink(boolean[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- shrink(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- shrink(int[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- shrink(float[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- SI_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene40.Lucene40SegmentInfoFormat
- 
Deprecated. 
- SI_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene46.Lucene46SegmentInfoFormat
- 
- similarity - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
- 
- similarity - Variable in class org.apache.lucene.search.BooleanQuery.BooleanWeight
- 
The Similarity implementation. 
- Similarity - Class in org.apache.lucene.search.similarities
- 
Similarity defines the components of Lucene scoring. 
- Similarity() - Constructor for class org.apache.lucene.search.similarities.Similarity
- 
Sole constructor. 
- similarity - Variable in class org.apache.lucene.search.spans.SpanWeight
-  
- Similarity.SimScorer - Class in org.apache.lucene.search.similarities
- 
- Similarity.SimScorer() - Constructor for class org.apache.lucene.search.similarities.Similarity.SimScorer
- 
Sole constructor. 
- Similarity.SimWeight - Class in org.apache.lucene.search.similarities
- 
Stores the weight for a query across the indexed collection. 
- Similarity.SimWeight() - Constructor for class org.apache.lucene.search.similarities.Similarity.SimWeight
- 
Sole constructor. 
- SimilarityBase - Class in org.apache.lucene.search.similarities
- 
A subclass of Similaritythat provides a simplified API for its
 descendants.
 
- SimilarityBase() - Constructor for class org.apache.lucene.search.similarities.SimilarityBase
- 
Sole constructor. 
- SimpleFSDirectory - Class in org.apache.lucene.store
- 
A straightforward implementation of  FSDirectory
  using java.io.RandomAccessFile. 
- SimpleFSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
- 
Create a new SimpleFSDirectory for the named location. 
- SimpleFSDirectory(File) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
- 
- SimpleFSDirectory.SimpleFSIndexInput - Class in org.apache.lucene.store
- 
- SimpleFSDirectory.SimpleFSIndexInput(String, File, IOContext) - Constructor for class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
-  
- SimpleFSDirectory.SimpleFSIndexInput(String, RandomAccessFile, long, long, int) - Constructor for class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
-  
- SimpleFSLockFactory - Class in org.apache.lucene.store
- 
- SimpleFSLockFactory() - Constructor for class org.apache.lucene.store.SimpleFSLockFactory
- 
Create a SimpleFSLockFactory instance, with null (unset)
 lock directory. 
- SimpleFSLockFactory(File) - Constructor for class org.apache.lucene.store.SimpleFSLockFactory
- 
Instantiate using the provided directory (as a File instance). 
- SimpleFSLockFactory(String) - Constructor for class org.apache.lucene.store.SimpleFSLockFactory
- 
Instantiate using the provided directory name (String). 
- SimpleMergedSegmentWarmer - Class in org.apache.lucene.index
- 
A very simple merged segment warmer that just ensures 
 data structures are initialized. 
- SimpleMergedSegmentWarmer(InfoStream) - Constructor for class org.apache.lucene.index.SimpleMergedSegmentWarmer
- 
Creates a new SimpleMergedSegmentWarmer 
- sims - Variable in class org.apache.lucene.search.similarities.MultiSimilarity
- 
the sub-similarities used to create the combined score 
- simScorer(Similarity.SimWeight, AtomicReaderContext) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-  
- simScorer(Similarity.SimWeight, AtomicReaderContext) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
-  
- simScorer(Similarity.SimWeight, AtomicReaderContext) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-  
- simScorer(Similarity.SimWeight, AtomicReaderContext) - Method in class org.apache.lucene.search.similarities.Similarity
- 
Creates a new  Similarity.SimScorer to score matching documents from a segment of the inverted index. 
- simScorer(Similarity.SimWeight, AtomicReaderContext) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-  
- simScorer(Similarity.SimWeight, AtomicReaderContext) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-  
- SingleInstanceLockFactory - Class in org.apache.lucene.store
- 
Implements  LockFactory for a single in-process instance,
 meaning all locking will take place through this one instance. 
- SingleInstanceLockFactory() - Constructor for class org.apache.lucene.store.SingleInstanceLockFactory
-  
- SingleTermsEnum - Class in org.apache.lucene.index
- 
Subclass of FilteredTermsEnum for enumerating a single term. 
- SingleTermsEnum(TermsEnum, BytesRef) - Constructor for class org.apache.lucene.index.SingleTermsEnum
- 
Creates a new SingleTermsEnum.
 
- SingletonSortedSetDocValues - Class in org.apache.lucene.index
- 
Exposes multi-valued view over a single-valued instance. 
- SingletonSortedSetDocValues(SortedDocValues) - Constructor for class org.apache.lucene.index.SingletonSortedSetDocValues
- 
Creates a multi-valued view over the provided SortedDocValues 
- sink - Variable in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
- 
Sink tokenstream, such as the outer tokenfilter decorating
 the chain. 
- size() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
-  
- size() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
-  
- size() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
- 
Returns number of documents. 
- size() - Method in class org.apache.lucene.index.FieldInfos
- 
Returns the number of fields 
- size() - Method in class org.apache.lucene.index.Fields
- 
Returns the number of fields or -1 if the number of
 distinct field names is unknown. 
- size() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterFields
-  
- size() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
-  
- size(SegmentCommitInfo) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-  
- size(SegmentCommitInfo) - Method in class org.apache.lucene.index.LogDocMergePolicy
-  
- size(SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy
- 
Return the byte size of the provided  SegmentCommitInfo, pro-rated by percentage of
  non-deleted documents is set. 
- size() - Method in class org.apache.lucene.index.MultiFields
-  
- size() - Method in class org.apache.lucene.index.MultiTerms
-  
- size(SegmentCommitInfo) - Method in class org.apache.lucene.index.NoMergePolicy
-  
- size() - Method in class org.apache.lucene.index.SegmentInfos
- 
- size() - Method in class org.apache.lucene.index.Terms
- 
Returns the number of terms for this field, or -1 if this 
  measure isn't stored by the codec. 
- size() - Method in class org.apache.lucene.search.LiveFieldValues
- 
Returns the [approximate] number of id/value pairs
  buffered in RAM. 
- size() - Method in class org.apache.lucene.util.BytesRefHash
- 
- size() - Method in class org.apache.lucene.util.OpenBitSet
- 
Returns the current capacity of this set. 
- size() - Method in class org.apache.lucene.util.packed.GrowableWriter
-  
- size() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
- 
Returns the number of values 
- size() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-  
- size() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
-  
- size() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
- 
Returns number of values 
- size() - Method in class org.apache.lucene.util.PriorityQueue
- 
Returns the number of elements currently stored in the PriorityQueue. 
- size() - Method in class org.apache.lucene.util.SentinelIntSet
- 
The number of integers in this set. 
- size() - Method in class org.apache.lucene.util.WeakIdentityMap
- 
Returns the number of key-value mappings in this map. 
- sizeBytes(SegmentCommitInfo) - Method in class org.apache.lucene.index.LogMergePolicy
- 
- sizeDocs(SegmentCommitInfo) - Method in class org.apache.lucene.index.LogMergePolicy
- 
- sizeInBytes() - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns total size in bytes of all files for this
  segment. 
- sizeInBytes() - Method in class org.apache.lucene.search.CachingWrapperFilter
- 
Returns total byte size used by cached filters. 
- sizeInBytes() - Method in class org.apache.lucene.store.NRTCachingDirectory
- 
Returns how many bytes are being used by the
  RAMDirectory cache 
- sizeInBytes - Variable in class org.apache.lucene.store.RAMDirectory
-  
- sizeInBytes() - Method in class org.apache.lucene.store.RAMDirectory
- 
Return total size in bytes of all files in this directory. 
- sizeInBytes - Variable in class org.apache.lucene.store.RAMFile
-  
- sizeInBytes() - Method in class org.apache.lucene.store.RAMOutputStream
- 
Returns byte usage of all buffers. 
- sizeInBytes() - Method in class org.apache.lucene.util.fst.FST
- 
Returns bytes used to represent the FST 
- sizeMB - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Net size (MB) of the files referenced by this
  segment. 
- sizeOf(byte[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the byte[] object. 
- sizeOf(boolean[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the boolean[] object. 
- sizeOf(char[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the char[] object. 
- sizeOf(short[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the short[] object. 
- sizeOf(int[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the int[] object. 
- sizeOf(float[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the float[] object. 
- sizeOf(long[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the long[] object. 
- sizeOf(double[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Returns the size in bytes of the double[] object. 
- sizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
- 
Estimates the RAM usage by the given object. 
- sizeOfIndexedStrings - Variable in class org.apache.lucene.index.DocTermOrds
- 
Total bytes (sum of term lengths) for all indexed terms. 
- skip(long) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
- 
Skip exactly countvalues.
 
- skipBytes(int) - Method in class org.apache.lucene.store.ByteArrayDataInput
-  
- skipBytes(int) - Method in class org.apache.lucene.util.fst.FST.BytesReader
- 
Skips bytes. 
- skipDoc - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Doc id of current skip entry per level. 
- skipTo(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
- 
Skips entries to the first beyond the current whose document number is
  greater than or equal to target. 
- skipTo(int) - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- skipTo(int) - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- skipTo(int) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- skipTo(int) - Method in class org.apache.lucene.search.spans.Spans
- 
Skips to the first match beyond the current, whose document number is
 greater than or equal to target. 
- skipTo(int) - Method in class org.apache.lucene.search.spans.TermSpans
-  
- skipToNextByte() - Method in class org.apache.lucene.util.packed.PackedDataInput
- 
If there are pending bits (at most 7), they will be ignored and the next
 value will be read starting at the next byte. 
- slice - Variable in class org.apache.lucene.index.MultiDocsAndPositionsEnum.EnumWithSlice
- 
ReaderSlice describing how this sub-reader
  fits into the composite reader. 
- slice - Variable in class org.apache.lucene.index.MultiDocsEnum.EnumWithSlice
- 
ReaderSlice describing how this sub-reader
  fits into the composite reader. 
- slices(List<AtomicReaderContext>) - Method in class org.apache.lucene.search.IndexSearcher
- 
Expert: Creates an array of leaf slices each holding a subset of the given leaves. 
- slop - Variable in class org.apache.lucene.search.spans.SpanNearQuery
-  
- sloppyFreq(int) - Method in class org.apache.lucene.search.similarities.BM25Similarity
- 
Implemented as 1 / (distance + 1).
 
- sloppyFreq(int) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Implemented as 1 / (distance + 1).
 
- sloppyFreq(int) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Computes the amount of a sloppy phrase match, based on an edit distance. 
- sloppyFreq() - Method in class org.apache.lucene.search.spans.SpanScorer
- 
Returns the intermediate "sloppy freq" adjusted for edit distance 
- SloppyMath - Class in org.apache.lucene.util
- 
Math functions that trade off accuracy for speed. 
- SloppyMath() - Constructor for class org.apache.lucene.util.SloppyMath
-  
- slot - Variable in class org.apache.lucene.search.FieldValueHitQueue.Entry
-  
- slowAdvance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
- 
- SlowCompositeReaderWrapper - Class in org.apache.lucene.index
- 
- smalleru_8(long, long) - Static method in class org.apache.lucene.util.BroadWord
- 
An unsigned bytewise smaller <8 operator. 
- smallerUpto15_16(long, long) - Static method in class org.apache.lucene.util.BroadWord
- 
A bytewise smaller <16 operator. 
- smallerUpTo7_8(long, long) - Static method in class org.apache.lucene.util.BroadWord
- 
A signed bytewise smaller <8 operator, for operands 0L<= x, y <=0x7L. 
- SmallFloat - Class in org.apache.lucene.util
- 
Floating point numbers smaller than 32 bits. 
- snapshot() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
- 
Snapshots the last commit. 
- snapshot() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
- 
Snapshots the last commit and returns it. 
- SnapshotDeletionPolicy - Class in org.apache.lucene.index
- 
- SnapshotDeletionPolicy(IndexDeletionPolicy) - Constructor for class org.apache.lucene.index.SnapshotDeletionPolicy
- 
- SNAPSHOTS_PREFIX - Static variable in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
- 
Prefix used for the save file. 
- Sort - Class in org.apache.lucene.search
- 
Encapsulates sort criteria for returned hits. 
- Sort() - Constructor for class org.apache.lucene.search.Sort
- 
Sorts by computed relevance. 
- Sort(SortField) - Constructor for class org.apache.lucene.search.Sort
- 
Sorts by the criteria in the given SortField. 
- Sort(SortField...) - Constructor for class org.apache.lucene.search.Sort
- 
Sorts in succession by the criteria in each SortField. 
- sort(Comparator<BytesRef>) - Method in class org.apache.lucene.util.BytesRefHash
- 
Returns the values array sorted by the referenced byte values. 
- sort(int, int) - Method in class org.apache.lucene.util.InPlaceMergeSorter
-  
- sort(int, int) - Method in class org.apache.lucene.util.IntroSorter
-  
- sort(int, int) - Method in class org.apache.lucene.util.Sorter
- 
Sort the slice which starts at from(inclusive) and ends atto(exclusive).
 
- sort(int, int) - Method in class org.apache.lucene.util.TimSorter
-  
- sortableIntToFloat(int) - Static method in class org.apache.lucene.util.NumericUtils
- 
Converts a sortable intback to afloat.
 
- sortableLongToDouble(long) - Static method in class org.apache.lucene.util.NumericUtils
- 
Converts a sortable longback to adouble.
 
- SORTED_SET_SINGLE_VALUED_SORTED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Single-valued sorted set values, encoded as sorted values, so no level
  of indirection: docId -> ord. 
- SORTED_SET_WITH_ADDRESSES - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Standard storage for sorted set values with 1 level of indirection:
  docId -> address -> ord. 
- SortedBytesDocValuesField - Class in org.apache.lucene.document
- 
- SortedBytesDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.SortedBytesDocValuesField
- 
Deprecated. Create a new fixed or variable-length sorted DocValues field. 
- SortedBytesDocValuesField(String, BytesRef, boolean) - Constructor for class org.apache.lucene.document.SortedBytesDocValuesField
- 
Deprecated. Create a new fixed or variable length sorted DocValues field. 
- SortedDocValues - Class in org.apache.lucene.index
- 
A per-document byte[] with presorted values. 
- SortedDocValues() - Constructor for class org.apache.lucene.index.SortedDocValues
- 
Sole constructor. 
- SortedDocValuesField - Class in org.apache.lucene.document
- 
 Field that stores
 a per-document  BytesRef value, indexed for
 sorting. 
- SortedDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.SortedDocValuesField
- 
Create a new sorted DocValues field. 
- SortedSetDocValues - Class in org.apache.lucene.index
- 
A per-document set of presorted byte[] values. 
- SortedSetDocValues() - Constructor for class org.apache.lucene.index.SortedSetDocValues
- 
Sole constructor. 
- SortedSetDocValuesField - Class in org.apache.lucene.document
- 
 Field that stores
 a set of per-document  BytesRef values, indexed for
 faceting,grouping,joining. 
- SortedSetDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.SortedSetDocValuesField
- 
Create a new sorted DocValues field. 
- sortedTransitions - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
- 
Two dimensional array of transitions, indexed by state
 number for traversal. 
- Sorter - Class in org.apache.lucene.util
- 
Base class for sorting algorithms implementations. 
- Sorter() - Constructor for class org.apache.lucene.util.Sorter
- 
Sole constructor, used for inheritance. 
- SortField - Class in org.apache.lucene.search
- 
Stores information about how to sort documents by terms in an individual
 field. 
- SortField(String, SortField.Type) - Constructor for class org.apache.lucene.search.SortField
- 
Creates a sort by terms in the given field with the type of term
 values explicitly given. 
- SortField(String, SortField.Type, boolean) - Constructor for class org.apache.lucene.search.SortField
- 
Creates a sort, possibly in reverse, by terms in the given field with the
 type of term values explicitly given. 
- SortField(String, FieldCache.Parser) - Constructor for class org.apache.lucene.search.SortField
- 
Creates a sort by terms in the given field, parsed
 to numeric values using a custom  FieldCache.Parser. 
- SortField(String, FieldCache.Parser, boolean) - Constructor for class org.apache.lucene.search.SortField
- 
Creates a sort, possibly in reverse, by terms in the given field, parsed
 to numeric values using a custom  FieldCache.Parser. 
- SortField(String, FieldComparatorSource) - Constructor for class org.apache.lucene.search.SortField
- 
Creates a sort with a custom comparison function. 
- SortField(String, FieldComparatorSource, boolean) - Constructor for class org.apache.lucene.search.SortField
- 
Creates a sort, possibly in reverse, with a custom comparison function. 
- SortField.Type - Enum in org.apache.lucene.search
- 
Specifies the type of the terms to be sorted, or special types such as CUSTOM 
- sortMissingLast - Variable in class org.apache.lucene.search.SortField
-  
- sortTransitions(Comparator<Transition>) - Method in class org.apache.lucene.util.automaton.State
- 
Sorts transitions array in-place. 
- source - Variable in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
- 
Original source of the tokens. 
- SOURCE - Static variable in class org.apache.lucene.index.IndexWriter
- 
- SOURCE_ADDINDEXES_READERS - Static variable in class org.apache.lucene.index.IndexWriter
- 
- SOURCE_FLUSH - Static variable in class org.apache.lucene.index.IndexWriter
- 
Source of a segment which results from a flush. 
- SOURCE_MERGE - Static variable in class org.apache.lucene.index.IndexWriter
- 
Source of a segment which results from a merge of other segments. 
- SpanFirstQuery - Class in org.apache.lucene.search.spans
- 
Matches spans near the beginning of a field. 
- SpanFirstQuery(SpanQuery, int) - Constructor for class org.apache.lucene.search.spans.SpanFirstQuery
- 
Construct a SpanFirstQuery matching spans in matchwhose end
 position is less than or equal toend.
 
- SpanMultiTermQueryWrapper<Q extends MultiTermQuery> - Class in org.apache.lucene.search.spans
- 
- SpanMultiTermQueryWrapper(Q) - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
- 
Create a new SpanMultiTermQueryWrapper. 
- SpanMultiTermQueryWrapper.SpanRewriteMethod - Class in org.apache.lucene.search.spans
- 
Abstract class that defines how the query is rewritten. 
- SpanMultiTermQueryWrapper.SpanRewriteMethod() - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.SpanRewriteMethod
-  
- SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite - Class in org.apache.lucene.search.spans
- 
A rewrite method that first translates each term into a SpanTermQuery in a
  BooleanClause.Occur.SHOULD clause in a BooleanQuery, and keeps the
 scores as computed by the query. 
- SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
- 
Create a TopTermsSpanBooleanQueryRewrite for 
 at most sizeterms.
 
- SpanNearPayloadCheckQuery - Class in org.apache.lucene.search.spans
- 
Only return those matches that have a specific payload at
 the given position. 
- SpanNearPayloadCheckQuery(SpanNearQuery, Collection<byte[]>) - Constructor for class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
-  
- SpanNearQuery - Class in org.apache.lucene.search.spans
- 
Matches spans which are near one another. 
- SpanNearQuery(SpanQuery[], int, boolean) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery
- 
Construct a SpanNearQuery. 
- SpanNearQuery(SpanQuery[], int, boolean, boolean) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery
-  
- SpanNotQuery - Class in org.apache.lucene.search.spans
- 
Removes matches which overlap with another SpanQuery or 
 within a x tokens before or y tokens after another SpanQuery. 
- SpanNotQuery(SpanQuery, SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
- 
Construct a SpanNotQuery matching spans from includewhich
 have no overlap with spans fromexclude.
 
- SpanNotQuery(SpanQuery, SpanQuery, int) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
- 
Construct a SpanNotQuery matching spans from includewhich
 have no overlap with spans fromexcludewithindisttokens ofinclude.
 
- SpanNotQuery(SpanQuery, SpanQuery, int, int) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
- 
Construct a SpanNotQuery matching spans from includewhich
 have no overlap with spans fromexcludewithinpretokens before orposttokens ofinclude.
 
- SpanOrQuery - Class in org.apache.lucene.search.spans
- 
Matches the union of its clauses. 
- SpanOrQuery(SpanQuery...) - Constructor for class org.apache.lucene.search.spans.SpanOrQuery
- 
Construct a SpanOrQuery merging the provided clauses. 
- SpanPayloadCheckQuery - Class in org.apache.lucene.search.spans
- 
Only return those matches that have a specific payload at
  the given position. 
- SpanPayloadCheckQuery(SpanQuery, Collection<byte[]>) - Constructor for class org.apache.lucene.search.spans.SpanPayloadCheckQuery
-  
- SpanPositionCheckQuery - Class in org.apache.lucene.search.spans
- 
Base class for filtering a SpanQuery based on the position of a match. 
- SpanPositionCheckQuery(SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanPositionCheckQuery
-  
- SpanPositionCheckQuery.AcceptStatus - Enum in org.apache.lucene.search.spans
- 
- SpanPositionCheckQuery.PositionCheckSpan - Class in org.apache.lucene.search.spans
-  
- SpanPositionCheckQuery.PositionCheckSpan(AtomicReaderContext, Bits, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- SpanPositionRangeQuery - Class in org.apache.lucene.search.spans
- 
- SpanPositionRangeQuery(SpanQuery, int, int) - Constructor for class org.apache.lucene.search.spans.SpanPositionRangeQuery
-  
- SpanQuery - Class in org.apache.lucene.search.spans
- 
Base class for span-based queries. 
- SpanQuery() - Constructor for class org.apache.lucene.search.spans.SpanQuery
-  
- Spans - Class in org.apache.lucene.search.spans
- 
Expert: an enumeration of span matches. 
- Spans() - Constructor for class org.apache.lucene.search.spans.Spans
-  
- spans - Variable in class org.apache.lucene.search.spans.SpanScorer
-  
- SpanScorer - Class in org.apache.lucene.search.spans
- 
Public for extension only. 
- SpanScorer(Spans, Weight, Similarity.SimScorer) - Constructor for class org.apache.lucene.search.spans.SpanScorer
-  
- SpanTermQuery - Class in org.apache.lucene.search.spans
- 
Matches spans containing a term. 
- SpanTermQuery(Term) - Constructor for class org.apache.lucene.search.spans.SpanTermQuery
- 
Construct a SpanTermQuery matching the named term's spans. 
- SpanWeight - Class in org.apache.lucene.search.spans
- 
Expert-only. 
- SpanWeight(SpanQuery, IndexSearcher) - Constructor for class org.apache.lucene.search.spans.SpanWeight
-  
- SpecialOperations - Class in org.apache.lucene.util.automaton
- 
Special automata operations. 
- SPIClassIterator<S> - Class in org.apache.lucene.util
- 
Helper class for loading SPI classes from classpath (META-INF files). 
- splitIntRange(NumericUtils.IntRangeBuilder, int, int, int) - Static method in class org.apache.lucene.util.NumericUtils
- 
Splits an int range recursively. 
- splitLongRange(NumericUtils.LongRangeBuilder, int, long, long) - Static method in class org.apache.lucene.util.NumericUtils
- 
Splits a long range recursively. 
- staleFiles - Variable in class org.apache.lucene.store.FSDirectory
-  
- start - Variable in class org.apache.lucene.index.ReaderSlice
- 
Document ID this slice starts from. 
- start() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- start() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- start() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- start - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-  
- start() - Method in class org.apache.lucene.search.spans.Spans
- 
Returns the start position of the current match. 
- start() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- startDoc(int, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- startDoc(int, int) - Method in class org.apache.lucene.codecs.PostingsConsumer
- 
Adds a new doc in this term. 
- startDocument(int) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-  
- startDocument(int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- startDocument(int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
-  
- startDocument(int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- startDocument(int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
- 
Called before writing the stored fields of the document. 
- startDocument(int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Called before writing the term vectors of the document. 
- startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Called before writing the terms of the field. 
- startNewSlice() - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
- 
starts a new slice and returns the start offset. 
- startOffset() - Method in class org.apache.lucene.analysis.Token
- 
Returns this Token's starting offset, the position of the first character
 corresponding to this token in the source text. 
- startOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
- 
Returns this Token's starting offset, the position of the first character
 corresponding to this token in the source text. 
- startOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-  
- startOffset() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
-  
- startOffset() - Method in class org.apache.lucene.index.DocsAndPositionsEnum
- 
Returns start offset for the current position, or -1
  if offsets were not indexed. 
- startOffset() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
-  
- startOffset() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- startsWith(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
- 
Returns trueiff the ref starts with the given prefix.
 
- startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-  
- startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
-  
- startTerm() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
-  
- startTerm() - Method in class org.apache.lucene.codecs.PostingsWriterBase
- 
Start a new term. 
- startTerm(BytesRef) - Method in class org.apache.lucene.codecs.TermsConsumer
- 
Starts a new term in this field; this may be called
  with no corresponding call to finish if the term had
  no docs. 
- startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
- 
Adds a term and its term frequency freq.
 
- State - Class in org.apache.lucene.util.automaton
- 
Automaton state. 
- State() - Constructor for class org.apache.lucene.util.automaton.State
- 
Constructs a new state. 
- StatePair - Class in org.apache.lucene.util.automaton
- 
Pair of states. 
- StatePair(State, State) - Constructor for class org.apache.lucene.util.automaton.StatePair
- 
Constructs a new state pair. 
- stats - Variable in class org.apache.lucene.search.spans.SpanWeight
-  
- step(int, int) - Method in class org.apache.lucene.util.automaton.RunAutomaton
- 
Returns the state obtained by reading the given char from the given state. 
- step(int) - Method in class org.apache.lucene.util.automaton.State
- 
Performs lookup in transitions, assuming determinism. 
- step(int, Collection<State>) - Method in class org.apache.lucene.util.automaton.State
- 
Performs lookup in transitions, allowing nondeterminism. 
- stopTimer() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
- 
Stops the timer thread 
- stored() - Method in class org.apache.lucene.document.FieldType
- 
True if the field's value should be stored 
- stored() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
True if the field's value should be stored 
- StoredField - Class in org.apache.lucene.document
- 
- StoredField(String, byte[]) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given binary value. 
- StoredField(String, byte[], int, int) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given binary value. 
- StoredField(String, BytesRef) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given binary value. 
- StoredField(String, String) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given string value. 
- StoredField(String, int) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given integer value. 
- StoredField(String, float) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given float value. 
- StoredField(String, long) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given long value. 
- StoredField(String, double) - Constructor for class org.apache.lucene.document.StoredField
- 
Create a stored-only field with the given double value. 
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.Codec
- 
Encodes/decodes stored fields 
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-  
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. 
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. 
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. 
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. 
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
-  
- StoredFieldsFormat - Class in org.apache.lucene.codecs
- 
Controls the format of stored fields 
- StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.StoredFieldsFormat
- 
Sole constructor. 
- StoredFieldsReader - Class in org.apache.lucene.codecs
- 
Codec API for reading stored fields. 
- StoredFieldsReader() - Constructor for class org.apache.lucene.codecs.StoredFieldsReader
- 
Sole constructor. 
- storedFieldStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Status for testing of stored fields (null if stored fields could not be tested). 
- StoredFieldsWriter - Class in org.apache.lucene.codecs
- 
Codec API for writing stored fields: 
- StoredFieldsWriter() - Constructor for class org.apache.lucene.codecs.StoredFieldsWriter
- 
Sole constructor. 
- StoredFieldVisitor - Class in org.apache.lucene.index
- 
Expert: provides a low-level means of accessing the stored field
 values in an index. 
- StoredFieldVisitor() - Constructor for class org.apache.lucene.index.StoredFieldVisitor
- 
Sole constructor. 
- StoredFieldVisitor.Status - Enum in org.apache.lucene.index
- 
- storeTermVectorOffsets() - Method in class org.apache.lucene.document.FieldType
- 
True if this field's token character offsets should also
 be stored into term vectors. 
- storeTermVectorOffsets() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
True if this field's token character offsets should also
 be stored into term vectors. 
- storeTermVectorPayloads() - Method in class org.apache.lucene.document.FieldType
- 
True if this field's token payloads should also be stored
 into the term vectors. 
- storeTermVectorPayloads() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
True if this field's token payloads should also be stored
 into the term vectors. 
- storeTermVectorPositions() - Method in class org.apache.lucene.document.FieldType
- 
True if this field's token positions should also be stored
 into the term vectors. 
- storeTermVectorPositions() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
True if this field's token positions should also be stored
 into the term vectors. 
- storeTermVectors() - Method in class org.apache.lucene.document.FieldType
- 
True if this field's indexed form should be also stored 
 into term vectors. 
- storeTermVectors() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
True if this field's indexed form should be also stored 
 into term vectors. 
- StraightBytesDocValuesField - Class in org.apache.lucene.document
- 
- StraightBytesDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.StraightBytesDocValuesField
- 
Deprecated. Create a new fixed or variable length DocValues field. 
- StraightBytesDocValuesField(String, BytesRef, boolean) - Constructor for class org.apache.lucene.document.StraightBytesDocValuesField
- 
Deprecated. Create a new fixed or variable length direct DocValues field. 
- stream - Variable in class org.apache.lucene.util.PrintStreamInfoStream
-  
- STRING_FIRST - Static variable in class org.apache.lucene.search.SortField
- 
- STRING_LAST - Static variable in class org.apache.lucene.search.SortField
- 
- stringField(FieldInfo, String) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-  
- StringField - Class in org.apache.lucene.document
- 
A field that is indexed but not tokenized: the entire
  String value is indexed as a single token. 
- StringField(String, String, Field.Store) - Constructor for class org.apache.lucene.document.StringField
- 
Creates a new StringField. 
- stringField(FieldInfo, String) - Method in class org.apache.lucene.index.StoredFieldVisitor
- 
Process a string field 
- StringHelper - Class in org.apache.lucene.util
- 
Methods for manipulating strings. 
- stringToDate(String) - Static method in class org.apache.lucene.document.DateTools
- 
Converts a string produced by timeToStringordateToStringback to a time, represented as a
 Date object.
 
- stringToTime(String) - Static method in class org.apache.lucene.document.DateTools
- 
Converts a string produced by timeToStringordateToStringback to a time, represented as the
 number of milliseconds since January 1, 1970, 00:00:00 GMT.
 
- stringValue() - Method in class org.apache.lucene.document.Field
- 
The value of the field as a String, or null. 
- stringValue() - Method in interface org.apache.lucene.index.IndexableField
- 
Non-null if this field has a string value 
- stripExtension(String) - Static method in class org.apache.lucene.index.IndexFileNames
- 
Removes the extension (anything after the first '.'),
 otherwise returns the original filename. 
- stripSegmentName(String) - Static method in class org.apache.lucene.index.IndexFileNames
- 
Strips the segment name out of the given file name. 
- subBlocksOnlyBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
The number of "internal" blocks that do not contain
  terms (have only sub-blocks). 
- subIndex(int, int[]) - Static method in class org.apache.lucene.index.ReaderUtil
- 
Returns index of the searcher/reader for document nin the
 array used to construct this searcher/reader.
 
- subIndex(int, List<AtomicReaderContext>) - Static method in class org.apache.lucene.index.ReaderUtil
- 
Returns index of the searcher/reader for document nin the
 array used to construct this searcher/reader.
 
- SUBREADER - Static variable in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
- 
Indicates an overlap in cache usage on a given field 
 in sub/super readers. 
- subSequence(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-  
- subSequence(int, int) - Method in class org.apache.lucene.util.CharsRef
-  
- subsetOf(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
- 
- subsetOf(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
- 
Returns true if the language of a1is a subset of the language
 ofa2.
 
- subtract(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-  
- subtract(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-  
- subtract(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-  
- subtract(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
-  
- subtract(T, T) - Method in class org.apache.lucene.util.fst.Outputs
- 
Eg subtract("foobar", "foo") -> "bar" 
- subtract(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
-  
- subtract(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-  
- sufficientlySmallerThanBitSet(long, long) - Static method in class org.apache.lucene.util.packed.EliasFanoDocIdSet
- 
- sufficientlySmallerThanBitSet(long, long) - Static method in class org.apache.lucene.util.packed.EliasFanoEncoder
- 
- sumDocFreq() - Method in class org.apache.lucene.search.CollectionStatistics
- 
returns the total number of postings for this field 
- sumTotalTermFreq() - Method in class org.apache.lucene.search.CollectionStatistics
- 
returns the total number of tokens for this field 
- SUN_OS - Static variable in class org.apache.lucene.util.Constants
- 
True iff running on SunOS. 
- swap(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
- 
Swap values stored in slots iandj
 
- swap(int, int) - Method in class org.apache.lucene.util.Sorter
- 
Swap values at slots iandj.
 
- sync() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
- 
Wait for any running merge threads to finish. 
- sync(Collection<String>) - Method in class org.apache.lucene.store.CompoundFileDirectory
-  
- sync(Collection<String>) - Method in class org.apache.lucene.store.Directory
- 
Ensure that any writes to these files are moved to
 stable storage. 
- sync(Collection<String>) - Method in class org.apache.lucene.store.FileSwitchDirectory
-  
- sync(Collection<String>) - Method in class org.apache.lucene.store.FilterDirectory
-  
- sync(Collection<String>) - Method in class org.apache.lucene.store.FSDirectory
-  
- sync(Collection<String>) - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- sync(Collection<String>) - Method in class org.apache.lucene.store.RAMDirectory
-  
- TABLE_COMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
- 
Compressed by giving IDs to unique values. 
- target - Variable in class org.apache.lucene.util.fst.Builder.Arc
-  
- target - Variable in class org.apache.lucene.util.fst.FST.Arc
- 
To node (ord or address) 
- targetHasArcs(FST.Arc<T>) - Static method in class org.apache.lucene.util.fst.FST
- 
returns true if the node at this address has any
  outgoing arcs 
- term() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- term() - Method in class org.apache.lucene.index.FilteredTermsEnum
-  
- term() - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- Term - Class in org.apache.lucene.index
- 
A Term represents a word from text. 
- Term(String, BytesRef) - Constructor for class org.apache.lucene.index.Term
- 
Constructs a Term with the given field and bytes. 
- Term(String, String) - Constructor for class org.apache.lucene.index.Term
- 
Constructs a Term with the given field and text. 
- Term(String) - Constructor for class org.apache.lucene.index.Term
- 
Constructs a Term with the given field and empty text. 
- term() - Method in class org.apache.lucene.index.TermsEnum
- 
Returns current term. 
- term - Variable in class org.apache.lucene.search.AutomatonQuery
- 
term containing the field, and possibly some pattern structure 
- term() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- term - Variable in class org.apache.lucene.search.spans.SpanTermQuery
-  
- term - Variable in class org.apache.lucene.search.spans.TermSpans
-  
- term() - Method in class org.apache.lucene.search.TermStatistics
- 
returns the term text 
- term - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
- 
- termBlockOrd - Variable in class org.apache.lucene.codecs.BlockTermState
- 
the term's ord in the current block 
- TermContext - Class in org.apache.lucene.index
- 
- TermContext(IndexReaderContext) - Constructor for class org.apache.lucene.index.TermContext
- 
- TermContext(IndexReaderContext, TermState, int, int, long) - Constructor for class org.apache.lucene.index.TermContext
- 
- termContexts - Variable in class org.apache.lucene.search.spans.SpanWeight
-  
- termCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
- 
Number of terms with at least one live doc. 
- termDocsEnum(Term) - Method in class org.apache.lucene.index.AtomicReader
- 
Returns  DocsEnum for the specified term. 
- termIndexInterval - Variable in class org.apache.lucene.index.SegmentWriteState
- 
Expert: The fraction of terms in the "dictionary" which should be stored
 in RAM. 
- termIndexStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Status for testing of indexed terms (null if indexed terms could not be tested). 
- termInstances - Variable in class org.apache.lucene.index.DocTermOrds
- 
Total number of references to term numbers. 
- termLength - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- termPositionsEnum(Term) - Method in class org.apache.lucene.index.AtomicReader
- 
- TermQuery - Class in org.apache.lucene.search
- 
A Query that matches documents containing a term. 
- TermQuery(Term) - Constructor for class org.apache.lucene.search.TermQuery
- 
Constructs a query for the term t.
 
- TermQuery(Term, int) - Constructor for class org.apache.lucene.search.TermQuery
- 
Expert: constructs a TermQuery that will use the
  provided docFreq instead of looking up the docFreq
  against the searcher. 
- TermQuery(Term, TermContext) - Constructor for class org.apache.lucene.search.TermQuery
- 
Expert: constructs a TermQuery that will use the
  provided docFreq instead of looking up the docFreq
  against the searcher. 
- TermRangeFilter - Class in org.apache.lucene.search
- 
A Filter that restricts search results to a range of term
 values in a given field. 
- TermRangeFilter(String, BytesRef, BytesRef, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeFilter
-  
- TermRangeQuery - Class in org.apache.lucene.search
- 
A Query that matches documents within an range of terms. 
- TermRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeQuery
- 
Constructs a query selecting all terms greater/equal than lowerTermbut less/equal thanupperTerm.
 
- TermRangeTermsEnum - Class in org.apache.lucene.search
- 
Subclass of FilteredTermEnum for enumerating all terms that match the
 specified range parameters. 
- TermRangeTermsEnum(TermsEnum, BytesRef, BytesRef, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeTermsEnum
- 
Enumerates all terms greater/equal than lowerTermbut less/equal thanupperTerm.
 
- terms(String) - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
-  
- terms(String) - Method in class org.apache.lucene.index.AtomicReader
- 
This may return null if the field does not exist. 
- terms(String) - Method in class org.apache.lucene.index.Fields
- 
Get the  Terms for this field. 
- terms(String) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterFields
-  
- terms(String) - Method in class org.apache.lucene.index.MultiFields
-  
- Terms - Class in org.apache.lucene.index
- 
Access to the terms in a specific field. 
- Terms() - Constructor for class org.apache.lucene.index.Terms
- 
Sole constructor. 
- terms - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- TERMS_INDEX_VERSION_APPEND_ONLY - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Append-only 
- TERMS_INDEX_VERSION_CURRENT - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Current index format. 
- TERMS_INDEX_VERSION_META_ARRAY - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Meta data as array 
- TERMS_INDEX_VERSION_START - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Initial index format. 
- TERMS_VERSION_APPEND_ONLY - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Append-only 
- TERMS_VERSION_CURRENT - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Current terms format. 
- TERMS_VERSION_META_ARRAY - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Meta data as array 
- TERMS_VERSION_START - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
- 
Initial terms format. 
- TermsConsumer - Class in org.apache.lucene.codecs
- 
Abstract API that consumes terms for an individual field. 
- TermsConsumer() - Constructor for class org.apache.lucene.codecs.TermsConsumer
- 
Sole constructor. 
- termsEnum() - Method in class org.apache.lucene.index.SortedDocValues
- 
- termsEnum() - Method in class org.apache.lucene.index.SortedSetDocValues
- 
- TermsEnum - Class in org.apache.lucene.index
- 
- TermsEnum() - Constructor for class org.apache.lucene.index.TermsEnum
- 
Sole constructor. 
- termsEnum(Terms) - Method in interface org.apache.lucene.search.FieldCache.Parser
- 
- TermsEnum.SeekStatus - Enum in org.apache.lucene.index
- 
- termsIndexDivisor - Variable in class org.apache.lucene.index.SegmentReadState
- 
The  termInfosIndexDivisor to use, if
  appropriate (not all  PostingsFormats support
  it; in particular the current default does not). 
- termsOnlyBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
The number of "leaf" blocks (blocks that have only
  terms). 
- TermSpans - Class in org.apache.lucene.search.spans
- 
Expert:
 Public for extension only 
- TermSpans(DocsAndPositionsEnum, Term) - Constructor for class org.apache.lucene.search.spans.TermSpans
-  
- termState() - Method in class org.apache.lucene.index.FilteredTermsEnum
- 
Returns the filtered enums term state 
- termState() - Method in class org.apache.lucene.index.TermsEnum
- 
Expert: Returns the TermsEnums internal state to position the TermsEnum
 without re-seeking the term dictionary. 
- TermState - Class in org.apache.lucene.index
- 
Encapsulates all required internal state to position the associated
  TermsEnum without re-seeking. 
- TermState() - Constructor for class org.apache.lucene.index.TermState
- 
Sole constructor. 
- termState() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- termStatistics(Term, TermContext) - Method in class org.apache.lucene.search.IndexSearcher
- 
- TermStatistics - Class in org.apache.lucene.search
- 
Contains statistics for a specific term 
- TermStatistics(BytesRef, long, long) - Constructor for class org.apache.lucene.search.TermStatistics
-  
- TermStats - Class in org.apache.lucene.codecs
- 
Holder for per-term statistics. 
- TermStats(int, long) - Constructor for class org.apache.lucene.codecs.TermStats
- 
Sole constructor. 
- termText - Variable in class org.apache.lucene.search.FuzzyTermsEnum
-  
- TermToBytesRefAttribute - Interface in org.apache.lucene.analysis.tokenattributes
- 
This attribute is requested by TermsHashPerField to index the contents. 
- termVectorsFormat() - Method in class org.apache.lucene.codecs.Codec
- 
Encodes/decodes term vectors 
- termVectorsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-  
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
- 
Deprecated. 
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
- 
Deprecated. 
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
- 
Deprecated. 
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
- 
Deprecated. 
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
- 
Deprecated. 
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
-  
- TermVectorsFormat - Class in org.apache.lucene.codecs
- 
Controls the format of term vectors 
- TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.TermVectorsFormat
- 
Sole constructor. 
- TermVectorsReader - Class in org.apache.lucene.codecs
- 
Codec API for reading term vectors: 
- TermVectorsReader() - Constructor for class org.apache.lucene.codecs.TermVectorsReader
- 
Sole constructor. 
- termVectorStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
- 
Status for testing of term vectors (null if term vectors could not be tested). 
- TermVectorsWriter - Class in org.apache.lucene.codecs
- 
Codec API for writing term vectors: 
- TermVectorsWriter() - Constructor for class org.apache.lucene.codecs.TermVectorsWriter
- 
Sole constructor. 
- testDocValues(AtomicReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
- 
Test docvalues. 
- testFieldNorms(AtomicReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
- 
Test field norms. 
- testPostings(AtomicReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
- 
Test the term index. 
- testPostings(AtomicReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
- 
Test the term index. 
- testStoredFields(AtomicReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
- 
Test stored fields. 
- testTermVectors(AtomicReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
- 
Test term vectors. 
- testTermVectors(AtomicReader, PrintStream, boolean, boolean) - Static method in class org.apache.lucene.index.CheckIndex
- 
Test term vectors. 
- text() - Method in class org.apache.lucene.index.Term
- 
Returns the text of this term. 
- TextField - Class in org.apache.lucene.document
- 
A field that is indexed and tokenized, without term
  vectors. 
- TextField(String, Reader) - Constructor for class org.apache.lucene.document.TextField
- 
Creates a new un-stored TextField with Reader value. 
- TextField(String, String, Field.Store) - Constructor for class org.apache.lucene.document.TextField
- 
Creates a new TextField with String value. 
- TextField(String, TokenStream) - Constructor for class org.apache.lucene.document.TextField
- 
Creates a new un-stored TextField with TokenStream value. 
- tf(float) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
- 
Implemented as sqrt(freq).
 
- tf(float) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Computes a score factor based on a term or phrase's frequency in a
 document. 
- TFIDFSimilarity - Class in org.apache.lucene.search.similarities
- 
Implementation of  Similarity with the Vector Space Model. 
- TFIDFSimilarity() - Constructor for class org.apache.lucene.search.similarities.TFIDFSimilarity
- 
Sole constructor. 
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
-  
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization
- 
Returns the normalized term frequency. 
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationH1
-  
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationH2
-  
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationH3
-  
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationZ
-  
- THREAD_NAME - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-  
- ThreadInterruptedException - Exception in org.apache.lucene.util
- 
Thrown by lucene on detecting that Thread.interrupt() had
 been called. 
- ThreadInterruptedException(InterruptedException) - Constructor for exception org.apache.lucene.util.ThreadInterruptedException
-  
- TieredMergePolicy - Class in org.apache.lucene.index
- 
Merges segments of approximately equal size, subject to
  an allowed number of segments per tier. 
- TieredMergePolicy() - Constructor for class org.apache.lucene.index.TieredMergePolicy
- 
Sole constructor, setting all settings to their
  defaults. 
- TieredMergePolicy.MergeScore - Class in org.apache.lucene.index
- 
Holds score and explanation for a single candidate
  merge. 
- TieredMergePolicy.MergeScore() - Constructor for class org.apache.lucene.index.TieredMergePolicy.MergeScore
- 
Sole constructor. 
- TimeLimitingCollector - Class in org.apache.lucene.search
- 
The  TimeLimitingCollector is used to timeout search requests that
 take longer than the maximum allowed search time limit. 
- TimeLimitingCollector(Collector, Counter, long) - Constructor for class org.apache.lucene.search.TimeLimitingCollector
- 
Create a TimeLimitedCollector wrapper over another  Collector with a specified timeout. 
- TimeLimitingCollector.TimeExceededException - Exception in org.apache.lucene.search
- 
Thrown when elapsed search time exceeds allowed search time. 
- TimeLimitingCollector.TimerThread - Class in org.apache.lucene.search
- 
Thread used to timeout search requests. 
- TimeLimitingCollector.TimerThread(long, Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-  
- TimeLimitingCollector.TimerThread(Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-  
- timeToString(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
- 
Converts a millisecond time to a string suitable for indexing. 
- timSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
- 
- timSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
- 
- timSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
- 
Sorts the given array slice in natural order. 
- timSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
- 
Sorts the given array in natural order. 
- timSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
- 
- timSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
- 
Sorts the given random access  List in natural order. 
- TimSorter - Class in org.apache.lucene.util
- 
- TimSorter(int) - Constructor for class org.apache.lucene.util.TimSorter
- 
- tnums - Variable in class org.apache.lucene.index.DocTermOrds
- 
Holds term ords for documents. 
- toAfterSequence() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
Set the decoding index to just after the last encoded value. 
- toAutomaton(TokenStream) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
- 
Pulls the graph (including  PositionLengthAttribute) from the provided  TokenStream, and creates the corresponding
  automaton where arcs are bytes (or Unicode code points 
  if unicodeArcs = true) from each term. 
- toAutomaton(Term) - Static method in class org.apache.lucene.search.WildcardQuery
- 
Convert Lucene wildcard syntax into an automaton. 
- toAutomaton(int) - Method in class org.apache.lucene.util.automaton.LevenshteinAutomata
- 
Compute a DFA that accepts all strings within an edit distance of n.
 
- toAutomaton() - Method in class org.apache.lucene.util.automaton.RegExp
- 
Constructs new Automatonfrom thisRegExp.
 
- toAutomaton(AutomatonProvider) - Method in class org.apache.lucene.util.automaton.RegExp
- 
Constructs new Automatonfrom thisRegExp.
 
- toAutomaton(Map<String, Automaton>) - Method in class org.apache.lucene.util.automaton.RegExp
- 
Constructs new Automatonfrom thisRegExp.
 
- toBeforeSequence() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
- 
Set the decoding index to just before the first encoded value. 
- toBytesRef(IntsRef, BytesRef) - Static method in class org.apache.lucene.util.fst.Util
- 
Just converts IntsRef to BytesRef; you must ensure the
  int values fit into a byte. 
- toDot() - Method in class org.apache.lucene.util.automaton.Automaton
- 
- toDot() - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
-  
- toDot(FST<T>, Writer, boolean, boolean) - Static method in class org.apache.lucene.util.fst.Util
- 
Dumps an  FST to a GraphViz's  dot language description
 for visualization. 
- toHexString(String) - Static method in class org.apache.lucene.util.UnicodeUtil
-  
- toHtml() - Method in class org.apache.lucene.search.Explanation
- 
Render an explanation as HTML. 
- toIndex(boolean, boolean) - Static method in enum org.apache.lucene.document.Field.Index
- 
Deprecated. Get the best representation of the index given the flags. 
- toIndex(boolean, boolean, boolean) - Static method in enum org.apache.lucene.document.Field.Index
- 
Deprecated. Expert: Get the best representation of the index given the flags. 
- toIntArray(Collection<Integer>) - Static method in class org.apache.lucene.util.ArrayUtil
-  
- toIntsRef(BytesRef, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
- 
Just takes unsigned byte values from the BytesRef and
  converts into an IntsRef. 
- Token - Class in org.apache.lucene.analysis
- 
A Token is an occurrence of a term from the text of a field. 
- Token() - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token will null text. 
- Token(int, int) - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token with null text and start & end
  offsets. 
- Token(int, int, String) - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token with null text and start & end
  offsets plus the Token type. 
- Token(int, int, int) - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token with null text and start & end
  offsets plus flags. 
- Token(String, int, int) - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token with the given term text, and start
  & end offsets. 
- Token(String, int, int, String) - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token with the given text, start and end
  offsets, & type. 
- Token(String, int, int, int) - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token with the given text, start and end
  offsets, & type. 
- Token(char[], int, int, int, int) - Constructor for class org.apache.lucene.analysis.Token
- 
Constructs a Token with the given term buffer (offset
  & length), start and end
  offsets 
- Token.TokenAttributeFactory - Class in org.apache.lucene.analysis
- 
Expert: Creates a TokenAttributeFactory returning  Token as instance for the basic attributes
 and for all other attributes calls the given delegate factory. 
 
- Token.TokenAttributeFactory(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.analysis.Token.TokenAttributeFactory
- 
Expert: Creates an AttributeFactory returning  Token as instance for the basic attributes
 and for all other attributes calls the given delegate factory. 
 
- TOKEN_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.analysis.Token
- 
Convenience factory that returns Tokenas implementation for the basic
 attributes and return the default impl (with "Impl" appended) for all other
 attributes.
 
- TOKEN_TYPE_FULL_PREC - Static variable in class org.apache.lucene.analysis.NumericTokenStream
- 
The full precision token gets this token type assigned. 
- TOKEN_TYPE_LOWER_PREC - Static variable in class org.apache.lucene.analysis.NumericTokenStream
- 
The lower precision tokens gets this token type assigned. 
- TokenFilter - Class in org.apache.lucene.analysis
- 
A TokenFilter is a TokenStream whose input is another TokenStream. 
- TokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.TokenFilter
- 
Construct a token stream filtering the given input. 
- tokenized() - Method in class org.apache.lucene.document.FieldType
- 
True if this field's value should be analyzed by the
  Analyzer. 
- tokenized() - Method in interface org.apache.lucene.index.IndexableFieldType
- 
True if this field's value should be analyzed by the
  Analyzer. 
- Tokenizer - Class in org.apache.lucene.analysis
- 
A Tokenizer is a TokenStream whose input is a Reader. 
- Tokenizer(Reader) - Constructor for class org.apache.lucene.analysis.Tokenizer
- 
Construct a token stream processing the given input. 
- Tokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.Tokenizer
- 
Construct a token stream processing the given input using the given AttributeFactory. 
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
- 
Returns a TokenStream suitable for fieldName, tokenizing
 the contents ofreader.
 
- tokenStream(String, String) - Method in class org.apache.lucene.analysis.Analyzer
- 
Returns a TokenStream suitable for fieldName, tokenizing
 the contents oftext.
 
- TokenStream - Class in org.apache.lucene.analysis
- 
A  TokenStream enumerates the sequence of tokens, either from
  Fields of a  Document or from query text. 
- TokenStream() - Constructor for class org.apache.lucene.analysis.TokenStream
- 
A TokenStream using the default attribute factory. 
- TokenStream(AttributeSource) - Constructor for class org.apache.lucene.analysis.TokenStream
- 
A TokenStream that uses the same attributes as the supplied one. 
- TokenStream(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.analysis.TokenStream
- 
A TokenStream using the supplied AttributeFactory for creating new  Attribute instances. 
- tokenStream - Variable in class org.apache.lucene.document.Field
- 
Pre-analyzed tokenStream for indexed fields; this is
 separate from fieldsData because you are allowed to
 have both; eg maybe field has a String value but you
 customize how it's tokenized 
- tokenStream(Analyzer) - Method in class org.apache.lucene.document.Field
-  
- tokenStream(Analyzer) - Method in interface org.apache.lucene.index.IndexableField
- 
Creates the TokenStream used for indexing this field. 
- TokenStreamToAutomaton - Class in org.apache.lucene.analysis
- 
Consumes a TokenStream and creates an  Automaton
  where the transition labels are UTF8 bytes (or Unicode 
  code points if unicodeArcs is true) from the  TermToBytesRefAttribute. 
- TokenStreamToAutomaton() - Constructor for class org.apache.lucene.analysis.TokenStreamToAutomaton
- 
Sole constructor. 
- tokenStreamValue() - Method in class org.apache.lucene.document.Field
- 
The TokenStream for this field to be used when indexing, or null. 
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueBool
-  
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueDate
-  
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-  
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-  
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueInt
-  
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueLong
-  
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueStr
-  
- toolOutOfDate - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
True if the index was created with a newer version of Lucene than the CheckIndex tool. 
- top() - Method in class org.apache.lucene.util.PriorityQueue
- 
Returns the least element of the PriorityQueue in constant time. 
- TopDocs - Class in org.apache.lucene.search
- 
- TopDocs(int, ScoreDoc[], float) - Constructor for class org.apache.lucene.search.TopDocs
-  
- topDocs() - Method in class org.apache.lucene.search.TopDocsCollector
- 
Returns the top docs that were collected by this collector. 
- topDocs(int) - Method in class org.apache.lucene.search.TopDocsCollector
- 
Returns the documents in the rage [start .. 
- topDocs(int, int) - Method in class org.apache.lucene.search.TopDocsCollector
- 
Returns the documents in the rage [start .. 
- TopDocsCollector<T extends ScoreDoc> - Class in org.apache.lucene.search
- 
A base class for all collectors that return a  TopDocs output. 
- TopDocsCollector(PriorityQueue<T>) - Constructor for class org.apache.lucene.search.TopDocsCollector
-  
- topDocsSize() - Method in class org.apache.lucene.search.TopDocsCollector
- 
The number of valid PQ entries 
- TopFieldCollector - Class in org.apache.lucene.search
- 
- TopFieldDocs - Class in org.apache.lucene.search
- 
- TopFieldDocs(int, ScoreDoc[], SortField[], float) - Constructor for class org.apache.lucene.search.TopFieldDocs
- 
Creates one of these objects. 
- topLevelBoost - Variable in class org.apache.lucene.search.similarities.BasicStats
- 
Any outer query's boost. 
- topReaderContext - Variable in class org.apache.lucene.index.TermContext
- 
- TopScoreDocCollector - Class in org.apache.lucene.search
- 
A  Collector implementation that collects the top-scoring hits,
 returning them as a  TopDocs. 
- TopTermsRewrite<Q extends Query> - Class in org.apache.lucene.search
- 
Base rewrite method for collecting only the top terms
 via a priority queue. 
- TopTermsRewrite(int) - Constructor for class org.apache.lucene.search.TopTermsRewrite
- 
Create a TopTermsBooleanQueryRewrite for 
 at most sizeterms.
 
- toString() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
- 
Returns solely the term text as specified by the
  CharSequence interface. 
- toString() - Method in class org.apache.lucene.codecs.BlockTermState
-  
- toString() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
-  
- toString() - Method in class org.apache.lucene.codecs.Codec
- 
returns the codec's name. 
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-  
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
-  
- toString() - Method in class org.apache.lucene.codecs.DocValuesFormat
-  
- toString() - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
- 
Deprecated. 
- toString() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
-  
- toString() - Method in class org.apache.lucene.codecs.PostingsFormat
-  
- toString() - Method in enum org.apache.lucene.document.DateTools.Resolution
- 
this method returns the name of the resolution
 in lowercase (for backwards compatibility) 
- toString() - Method in class org.apache.lucene.document.Document
- 
Prints the fields of a document for human consumption. 
- toString() - Method in class org.apache.lucene.document.Field
- 
Prints a Field for human consumption. 
- toString() - Method in class org.apache.lucene.document.FieldType
- 
Prints a Field for human consumption. 
- toString() - Method in class org.apache.lucene.index.CompositeReader
-  
- toString() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-  
- toString() - Method in class org.apache.lucene.index.FilterAtomicReader
-  
- toString() - Method in class org.apache.lucene.index.IndexWriterConfig
-  
- toString() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-  
- toString() - Method in class org.apache.lucene.index.LogMergePolicy
-  
- toString() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum.EnumWithSlice
-  
- toString() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
-  
- toString() - Method in class org.apache.lucene.index.MultiDocsEnum.EnumWithSlice
-  
- toString() - Method in class org.apache.lucene.index.MultiDocsEnum
-  
- toString() - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- toString() - Method in class org.apache.lucene.index.NoMergePolicy
-  
- toString() - Method in class org.apache.lucene.index.OrdTermState
-  
- toString() - Method in class org.apache.lucene.index.ParallelAtomicReader
-  
- toString() - Method in class org.apache.lucene.index.ReaderSlice
-  
- toString(Directory, int) - Method in class org.apache.lucene.index.SegmentCommitInfo
- 
Returns a description of this segment. 
- toString() - Method in class org.apache.lucene.index.SegmentCommitInfo
-  
- toString() - Method in class org.apache.lucene.index.SegmentInfo
-  
- toString(Directory, int) - Method in class org.apache.lucene.index.SegmentInfo
- 
Used for debugging. 
- toString(Directory) - Method in class org.apache.lucene.index.SegmentInfos
- 
Returns readable description of this segment. 
- toString() - Method in class org.apache.lucene.index.SegmentReader
-  
- toString() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
-  
- toString(BytesRef) - Static method in class org.apache.lucene.index.Term
- 
Returns human-readable form of the term text. 
- toString() - Method in class org.apache.lucene.index.Term
-  
- toString() - Method in class org.apache.lucene.index.TermState
-  
- toString() - Method in class org.apache.lucene.index.TieredMergePolicy
-  
- toString() - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-  
- toString(String) - Method in class org.apache.lucene.search.AutomatonQuery
-  
- toString() - Method in class org.apache.lucene.search.BooleanClause
-  
- toString(String) - Method in class org.apache.lucene.search.BooleanQuery
- 
Prints a user-readable version of this query. 
- toString() - Method in class org.apache.lucene.search.CachingWrapperFilter
-  
- toString(String) - Method in class org.apache.lucene.search.ConstantScoreQuery
-  
- toString(String) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
- 
Prettyprint us. 
- toString() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
-  
- toString() - Method in class org.apache.lucene.search.Explanation
- 
Render an explanation as text. 
- toString(int) - Method in class org.apache.lucene.search.Explanation
-  
- toString() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
-  
- toString() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
-  
- toString() - Method in class org.apache.lucene.search.FieldDoc
-  
- toString() - Method in class org.apache.lucene.search.FieldValueFilter
-  
- toString() - Method in class org.apache.lucene.search.FieldValueHitQueue.Entry
-  
- toString(String) - Method in class org.apache.lucene.search.FilteredQuery
- 
Prints a user-readable version of this query. 
- toString(String) - Method in class org.apache.lucene.search.FuzzyQuery
-  
- toString() - Method in class org.apache.lucene.search.IndexSearcher
-  
- toString(String) - Method in class org.apache.lucene.search.MatchAllDocsQuery
-  
- toString(String) - Method in class org.apache.lucene.search.MultiPhraseQuery
- 
Prints a user-readable version of this query. 
- toString() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
-  
- toString(String) - Method in class org.apache.lucene.search.NumericRangeQuery
-  
- toString(String) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
-  
- toString(String) - Method in class org.apache.lucene.search.PhraseQuery
- 
Prints a user-readable version of this query. 
- toString() - Method in class org.apache.lucene.search.PrefixFilter
- 
Prints a user-readable version of this query. 
- toString(String) - Method in class org.apache.lucene.search.PrefixQuery
- 
Prints a user-readable version of this query. 
- toString(String) - Method in class org.apache.lucene.search.Query
- 
Prints a query to a string, with fieldassumed to be the 
 default field and omitted.
 
- toString() - Method in class org.apache.lucene.search.Query
- 
Prints a query to a string. 
- toString() - Method in class org.apache.lucene.search.QueryWrapperFilter
-  
- toString(String) - Method in class org.apache.lucene.search.RegexpQuery
- 
Prints a user-readable version of this query. 
- toString() - Method in class org.apache.lucene.search.ScoreDoc
-  
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
-  
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffect
- 
Subclasses must override this method to return the code of the
 after effect formula. 
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffectB
-  
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffectL
-  
- toString() - Method in class org.apache.lucene.search.similarities.BasicModel
- 
Subclasses must override this method to return the code of the
 basic model formula. 
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelBE
-  
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelD
-  
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelG
-  
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelIF
-  
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelIn
-  
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelIne
-  
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelP
-  
- toString() - Method in class org.apache.lucene.search.similarities.BM25Similarity
-  
- toString() - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
-  
- toString() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-  
- toString() - Method in class org.apache.lucene.search.similarities.Distribution
- 
Subclasses must override this method to return the name of the
 distribution. 
- toString() - Method in class org.apache.lucene.search.similarities.DistributionLL
-  
- toString() - Method in class org.apache.lucene.search.similarities.DistributionSPL
-  
- toString() - Method in class org.apache.lucene.search.similarities.IBSimilarity
- 
The name of IB methods follow the pattern
 IB <distribution> <lambda><normalization>.
 
- toString() - Method in class org.apache.lucene.search.similarities.Lambda
- 
Subclasses must override this method to return the code of the lambda
 formula. 
- toString() - Method in class org.apache.lucene.search.similarities.LambdaDF
-  
- toString() - Method in class org.apache.lucene.search.similarities.LambdaTTF
-  
- toString() - Method in class org.apache.lucene.search.similarities.LMSimilarity
- 
Returns the name of the LM method. 
- toString() - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
-  
- toString() - Method in class org.apache.lucene.search.similarities.Normalization
- 
Subclasses must override this method to return the code of the
 normalization formula. 
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationH1
-  
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationH2
-  
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationH3
-  
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationZ
-  
- toString() - Method in class org.apache.lucene.search.similarities.SimilarityBase
- 
Subclasses must override this method to return the name of the Similarity
 and preferably the values of parameters (if any) as well. 
- toString() - Method in class org.apache.lucene.search.Sort
-  
- toString() - Method in class org.apache.lucene.search.SortField
-  
- toString(String) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-  
- toString() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-  
- toString() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
-  
- toString() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-  
- toString(String) - Method in class org.apache.lucene.search.spans.SpanTermQuery
-  
- toString() - Method in class org.apache.lucene.search.spans.TermSpans
-  
- toString(String) - Method in class org.apache.lucene.search.TermQuery
- 
Prints a user-readable version of this query. 
- toString(String) - Method in class org.apache.lucene.search.TermRangeQuery
- 
Prints a user-readable version of this query. 
- toString(String) - Method in class org.apache.lucene.search.WildcardQuery
- 
Prints a user-readable version of this query. 
- toString() - Method in class org.apache.lucene.store.CompoundFileDirectory
-  
- toString() - Method in class org.apache.lucene.store.Directory
-  
- toString() - Method in class org.apache.lucene.store.FilterDirectory
-  
- toString() - Method in class org.apache.lucene.store.FlushInfo
-  
- toString() - Method in class org.apache.lucene.store.FSDirectory
- 
For debug output. 
- toString() - Method in class org.apache.lucene.store.FSLockFactory
-  
- toString() - Method in class org.apache.lucene.store.IndexInput
-  
- toString() - Method in class org.apache.lucene.store.IOContext
-  
- toString() - Method in class org.apache.lucene.store.MergeInfo
-  
- toString() - Method in class org.apache.lucene.store.NRTCachingDirectory
-  
- toString() - Method in class org.apache.lucene.util.AttributeSource
- 
Returns a string consisting of the class's simple name, the hex representation of the identity hash code,
 and the current reflection of all attributes. 
- toString() - Method in class org.apache.lucene.util.automaton.Automaton
- 
Returns a string representation of this automaton. 
- toString() - Method in class org.apache.lucene.util.automaton.RegExp
- 
Constructs string from parsed regular expression. 
- toString() - Method in class org.apache.lucene.util.automaton.RunAutomaton
- 
Returns a string representation of this automaton. 
- toString() - Method in class org.apache.lucene.util.automaton.State
- 
Returns string describing this state. 
- toString() - Method in class org.apache.lucene.util.automaton.Transition
- 
Returns a string describing this state. 
- toString() - Method in class org.apache.lucene.util.BytesRef
- 
Returns hex encoded bytes, eg [0x6c 0x75 0x63 0x65 0x6e 0x65] 
- toString() - Method in class org.apache.lucene.util.CharsRef
-  
- toString() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
- 
Multi-Line representation of this Insanity object, starting with 
 the Type and Msg, followed by each CacheEntry.toString() on it's 
 own line prefaced by a tab character 
- toString() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
-  
- toString() - Method in class org.apache.lucene.util.fst.FST.Arc
-  
- toString() - Method in class org.apache.lucene.util.fst.PairOutputs
-  
- toString() - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-  
- toString() - Method in class org.apache.lucene.util.fst.Util.FSTPath
-  
- toString() - Method in class org.apache.lucene.util.IntsRef
-  
- toString() - Method in class org.apache.lucene.util.LongsRef
-  
- toString() - Method in class org.apache.lucene.util.mutable.MutableValue
-  
- toString() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
-  
- toString() - Method in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
-  
- toString() - Method in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
-  
- ToStringUtils - Class in org.apache.lucene.util
- 
- total_time - Variable in class org.apache.lucene.index.DocTermOrds
- 
Total time to uninvert the field. 
- totalBinaryFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
- 
Total number of binary fields 
- totalBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Total number of blocks. 
- totalBlockOtherBytes - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Total bytes stored by the  PostingsBaseFormat,
  plus the other few vInts stored in the frame. 
- totalBlockStatsBytes - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Total number of bytes used to store term stats (not
  including what the  PostingsBaseFormat
  stores. 
- totalBlockSuffixBytes - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Total number of bytes used to store term suffixes. 
- totalBoost - Variable in class org.apache.lucene.search.similarities.BasicStats
- 
For most Similarities, the immediate and the top level query boosts are
 not handled differently. 
- totalBytesSize() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Returns the total size in bytes of this merge. 
- totalDocCount - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Number of documents in the merged segment. 
- totalDocCount() - Method in class org.apache.lucene.index.SegmentInfos
- 
Returns sum of all segment's docCounts. 
- totalDocCount - Variable in class org.apache.lucene.store.MergeInfo
-  
- TotalHitCountCollector - Class in org.apache.lucene.search
- 
Just counts the total number of hits. 
- TotalHitCountCollector() - Constructor for class org.apache.lucene.search.TotalHitCountCollector
-  
- totalHits - Variable in class org.apache.lucene.search.TopDocs
- 
The total number of hits for the query. 
- totalHits - Variable in class org.apache.lucene.search.TopDocsCollector
- 
The total number of documents that the collector encountered. 
- totalNumDocs() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
- 
Returns the total number of documents that are included with this merge. 
- totalNumericFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
- 
Total number of numeric fields 
- totalSortedFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
- 
Total number of sorted fields 
- totalSortedSetFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
- 
Total number of sortedset fields 
- totalTermBytes - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Total number of bytes (sum of term lengths) across all terms in the field. 
- totalTermCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
- 
Total number of terms in the field. 
- totalTermFreq - Variable in class org.apache.lucene.codecs.BlockTermState
- 
total number of occurrences of this term 
- totalTermFreq - Variable in class org.apache.lucene.codecs.TermStats
- 
Total number of times this term occurs across all
  documents in the field. 
- totalTermFreq(Term) - Method in class org.apache.lucene.index.AtomicReader
- 
Returns the number of documents containing the term
 t.
 
- totalTermFreq(Term) - Method in class org.apache.lucene.index.BaseCompositeReader
-  
- totalTermFreq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
-  
- totalTermFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
-  
- totalTermFreq(Term) - Method in class org.apache.lucene.index.IndexReader
- 
Returns the total number of occurrences of termacross all
 documents (the sum of the freq() for each doc that has this term).
 
- totalTermFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
-  
- totalTermFreq() - Method in class org.apache.lucene.index.TermContext
- 
- totalTermFreq() - Method in class org.apache.lucene.index.TermsEnum
- 
Returns the total number of occurrences of this term
  across all documents (the sum of the freq() for each
  doc that has this term). 
- totalTermFreq() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-  
- totalTermFreq - Variable in class org.apache.lucene.search.similarities.BasicStats
- 
The total number of occurrences of this term across all documents. 
- totalTermFreq() - Method in class org.apache.lucene.search.TermStatistics
- 
returns the total number of occurrences of this term 
- totalValueFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
- 
Total number of docValues tested. 
- toTermVector(boolean, boolean, boolean) - Static method in enum org.apache.lucene.document.Field.TermVector
- 
Deprecated. Get the best representation of a TermVector given the flags. 
- totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
- 
Number of fields successfully tested 
- totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
- 
Total number of stored fields tested. 
- totFreq - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
- 
Total frequency across all terms. 
- totLoseDocCount - Variable in class org.apache.lucene.index.CheckIndex.Status
- 
How many documents will be lost to bad segments. 
- totPos - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
- 
Total number of positions. 
- totVectors - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
- 
Total number of term vectors tested. 
- toUTF16(CharSequence, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
- 
Just maps each UTF16 unit (char) to the ints in an
  IntsRef. 
- toUTF32(CharSequence, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
- 
Decodes the Unicode codepoints from the provided
  CharSequence and places them in the provided scratch
  IntsRef, which must not be null, returning it. 
- toUTF32(char[], int, int, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
- 
Decodes the Unicode codepoints from the provided
  char[] and places them in the provided scratch
  IntsRef, which must not be null, returning it. 
- TrackingDirectoryWrapper - Class in org.apache.lucene.store
- 
A delegating Directory that records which files were
  written to and deleted. 
- TrackingDirectoryWrapper(Directory) - Constructor for class org.apache.lucene.store.TrackingDirectoryWrapper
-  
- TrackingIndexWriter - Class in org.apache.lucene.index
- 
- TrackingIndexWriter(IndexWriter) - Constructor for class org.apache.lucene.index.TrackingIndexWriter
- 
Create a  TrackingIndexWriter wrapping the
  provided  IndexWriter. 
- Transition - Class in org.apache.lucene.util.automaton
- 
Automaton transition. 
- Transition(int, State) - Constructor for class org.apache.lucene.util.automaton.Transition
- 
Constructs a new singleton interval transition. 
- Transition(int, int, State) - Constructor for class org.apache.lucene.util.automaton.Transition
- 
Constructs a new transition. 
- transitionsArray - Variable in class org.apache.lucene.util.automaton.State
-  
- translateFieldType(Field.Store, Field.Index, Field.TermVector) - Static method in class org.apache.lucene.document.Field
- 
Deprecated.
This is here only to ease transition from
 the pre-4.0 APIs. 
 
- trimTrailingZeros() - Method in class org.apache.lucene.util.OpenBitSet
- 
Lowers numWords, the number of words in use,
 by checking for trailing zero words. 
- trimTransitionsArray() - Method in class org.apache.lucene.util.automaton.State
- 
Downsizes transitionArray to numTransitions 
- tryDeleteDocument(IndexReader, int) - Method in class org.apache.lucene.index.IndexWriter
- 
- tryDeleteDocument(IndexReader, int) - Method in class org.apache.lucene.index.TrackingIndexWriter
- 
- tryIncRef() - Method in class org.apache.lucene.index.IndexReader
- 
Expert: increments the refCount of this IndexReader
 instance only if the IndexReader has not been closed yet
 and returns trueiff the refCount was
 successfully incremented, otherwisefalse.
 
- tryIncRef(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-  
- tryIncRef(G) - Method in class org.apache.lucene.search.ReferenceManager
- 
Try to increment reference counting on the given reference. 
- tryIncRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
-  
- TwoPhaseCommit - Interface in org.apache.lucene.index
- 
An interface for implementations that support 2-phase commit. 
- TwoPhaseCommitTool - Class in org.apache.lucene.index
- 
A utility for executing 2-phase commit on several objects. 
- TwoPhaseCommitTool.CommitFailException - Exception in org.apache.lucene.index
- 
- TwoPhaseCommitTool.CommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.CommitFailException
- 
Sole constructor. 
- TwoPhaseCommitTool.PrepareCommitFailException - Exception in org.apache.lucene.index
- 
- TwoPhaseCommitTool.PrepareCommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.PrepareCommitFailException
- 
Sole constructor. 
- type() - Method in class org.apache.lucene.analysis.Token
- 
Returns this Token's lexical type. 
- type() - Method in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
- 
Returns this Token's lexical type. 
- type() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-  
- TYPE - Static variable in class org.apache.lucene.document.BinaryDocValuesField
- 
Type for straight bytes DocValues. 
- type - Variable in class org.apache.lucene.document.Field
- 
Field's type 
- TYPE - Static variable in class org.apache.lucene.document.NumericDocValuesField
- 
Type for numeric DocValues. 
- TYPE - Static variable in class org.apache.lucene.document.SortedDocValuesField
- 
Type for sorted bytes DocValues 
- TYPE - Static variable in class org.apache.lucene.document.SortedSetDocValuesField
- 
Type for sorted bytes DocValues 
- TYPE - Static variable in class org.apache.lucene.document.StoredField
- 
Type for a stored-only field. 
- type - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-  
- TYPE_FIXED_LEN - Static variable in class org.apache.lucene.document.DerefBytesDocValuesField
- 
Deprecated. Type for bytes DocValues: all with the same length 
- TYPE_FIXED_LEN - Static variable in class org.apache.lucene.document.SortedBytesDocValuesField
- 
Deprecated. Type for sorted bytes DocValues: all with the same length 
- TYPE_FIXED_LEN - Static variable in class org.apache.lucene.document.StraightBytesDocValuesField
- 
Deprecated. Type for direct bytes DocValues: all with the same length 
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.DoubleField
- 
Type for a DoubleField that is not stored:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.FloatField
- 
Type for a FloatField that is not stored:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.IntField
- 
Type for an IntField that is not stored:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.LongField
- 
Type for a LongField that is not stored:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.StringField
- 
Indexed, not tokenized, omits norms, indexes
  DOCS_ONLY, not stored. 
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.TextField
- 
Indexed, tokenized, not stored. 
- TYPE_STORED - Static variable in class org.apache.lucene.document.DoubleField
- 
Type for a stored DoubleField:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_STORED - Static variable in class org.apache.lucene.document.FloatField
- 
Type for a stored FloatField:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_STORED - Static variable in class org.apache.lucene.document.IntField
- 
Type for a stored IntField:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_STORED - Static variable in class org.apache.lucene.document.LongField
- 
Type for a stored LongField:
 normalization factors, frequencies, and positions are omitted. 
- TYPE_STORED - Static variable in class org.apache.lucene.document.StringField
- 
Indexed, not tokenized, omits norms, indexes
  DOCS_ONLY, stored 
- TYPE_STORED - Static variable in class org.apache.lucene.document.TextField
- 
Indexed, tokenized, stored. 
- TYPE_VAR_LEN - Static variable in class org.apache.lucene.document.DerefBytesDocValuesField
- 
Deprecated. Type for bytes DocValues: can have variable lengths 
- TYPE_VAR_LEN - Static variable in class org.apache.lucene.document.SortedBytesDocValuesField
- 
Deprecated. Type for sorted bytes DocValues: can have variable lengths 
- TYPE_VAR_LEN - Static variable in class org.apache.lucene.document.StraightBytesDocValuesField
- 
Deprecated. Type for direct bytes DocValues: can have variable lengths 
- TypeAttribute - Interface in org.apache.lucene.analysis.tokenattributes
- 
A Token's lexical type. 
- TypeAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
- 
- TypeAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- 
- TypeAttributeImpl(String) - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
- 
Initialize this attribute with type