Skip navigation links
Lucene Core 5.3.1.redhat-2
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

A

ABSOLUTE_MIN_SORT_BUFFER_SIZE - Static variable in class org.apache.lucene.util.OfflineSorter
Absolute minimum required buffer size for sorting.
accept(BytesRef) - Method in class org.apache.lucene.index.AutomatonTermsEnum
Returns true if the term matches the automaton.
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(Spans) - Method in class org.apache.lucene.search.spans.FilterSpans
Returns YES if the candidate should be an accepted match, NO if it should not, and NO_MORE_IN_CURRENT_DOC if iteration should move on to the next document.
acceptDocs - Variable in class org.apache.lucene.search.DocValuesDocIdSet
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
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(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
acceptResult(IntsRef, T) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
Accountable - Interface in org.apache.lucene.util
An object whose RAM usage can be computed.
Accountables - Class in org.apache.lucene.util
Helper methods for constructing nested resource descriptions and debugging RAM usage.
accumulateStatistics(int, long) - Method in class org.apache.lucene.index.TermContext
Expert: Accumulate term statistics.
acosh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic cosine of a double value.
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
actualTerm - Variable in class org.apache.lucene.index.FilteredTermsEnum
Which term the enum is currently positioned to.
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
Adds the provided MergePolicy.OneMerge to this specification.
add(Term) - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
add a term
add(SegmentCommitInfo) - Method in class org.apache.lucene.index.SegmentInfos
Appends the provided SegmentCommitInfo.
add(Term) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Add a new Term to this builder, with a default boost of 1.
add(Term, float) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Add a Term with the provided boost.
add(Term, float, TermContext) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Expert: Add a Term with the provided boost and context.
add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery
Deprecated.
Boolean queries should be created once with BooleanQuery.Builder and then considered immutable. See BooleanQuery.Builder.add(org.apache.lucene.search.BooleanClause).
add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery
Deprecated.
Boolean queries should be created once with BooleanQuery.Builder and then considered immutable. See BooleanQuery.Builder.add(org.apache.lucene.search.BooleanClause).
add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery.Builder
Add a clause to the BooleanQuery.
add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery.Builder
Add a clause to the BooleanQuery.
add(DisiWrapper<Iter>) - Method in class org.apache.lucene.search.DisiPriorityQueue
 
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
Deprecated.
Phrase queries should be created once with PhraseQuery.Builder and then considered immutable. See PhraseQuery.Builder.add(Term).
add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery
Deprecated.
Phrase queries should be created once with PhraseQuery.Builder and then considered immutable. See PhraseQuery.Builder.add(Term, int).
add(Term) - Method in class org.apache.lucene.search.PhraseQuery.Builder
Adds a term to the end of the query phrase.
add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery.Builder
Adds a term to the end of the query phrase.
add(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef
add(DocIdSetIterator) - Method in class org.apache.lucene.util.DocIdSetBuilder
Add the content of the provided DocIdSetIterator to this builder.
add(int) - Method in class org.apache.lucene.util.DocIdSetBuilder
Add a document to this builder.
add(int) - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
Add a new item to this ring buffer, potentially removing the oldest entry from this buffer if it is already full.
add(IntsRef, T) - Method in class org.apache.lucene.util.fst.Builder
Add the next input/output pair.
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.DirectWriter
Adds a value to this writer
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(long) - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
Add a new element to this 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.RoaringDocIdSet.Builder
Add a new doc-id to this builder.
add(DocIdSetIterator) - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
Add the content of the provided DocIdSetIterator.
addAll(Iterable<SegmentCommitInfo>) - Method in class org.apache.lucene.index.SegmentInfos
Appends the provided SegmentCommitInfos.
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.
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(BlendedTermQuery.Builder, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
 
addClause(BooleanQuery.Builder, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
addClause(BooleanQuery.Builder, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
addClause(SpanQuery) - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
Add a new clause
addClause(SpanQuery) - Method in class org.apache.lucene.search.spans.SpanOrQuery
Adds a clause to this query
addCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.FilterCodecReader
 
addCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.FilterLeafReader
 
addCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.LeafReader
Expert: adds a CoreClosedListener to this reader's shared core
addCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.ParallelLeafReader
 
addCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
 
addCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
addCoreClosedListenerAsReaderClosedListener(IndexReader, LeafReader.CoreClosedListener) - Static method in class org.apache.lucene.index.LeafReader
addDocument(Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index.
addDocument(Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.addDocument(Iterable) and returns the generation that reflects this change.
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>>) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.addDocuments(Iterable) and returns the generation that reflects this change.
addEpsilon(int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Add a [virtual] epsilon transition between source and dest.
addEpsilon(int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Add a [virtual] epsilon transition between source and dest.
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.
addGap(int) - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
Add a gap after the previous clause of a defined width
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(CodecReader...) - 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
Calls IndexWriter.addIndexes(Directory...) and returns the generation that reflects this change.
addIndexes(CodecReader...) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.addIndexes(CodecReader...) and returns the generation that reflects this change.
addListener(ReferenceManager.RefreshListener) - Method in class org.apache.lucene.search.ReferenceManager
Adds a listener, to be notified when a reference is refreshed/swapped.
addNormsField(FieldInfo, Iterable<Number>) - Method in class org.apache.lucene.codecs.NormsConsumer
Writes normalization values for a field.
addNumericField(FieldInfo, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes numeric docvalues for a field.
addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Add a new position and 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.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.
addReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
addSortedField(FieldInfo, Iterable<BytesRef>, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted binary docvalues for a field.
addSortedNumericField(FieldInfo, Iterable<Number>, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted numeric docvalues for a field
addSortedSetField(FieldInfo, Iterable<BytesRef>, Iterable<Number>, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted set docvalues for a field
addStartPaths(FST.Arc<T>, T, boolean, IntsRefBuilder) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
addStartPaths(FST.Arc<T>, T, boolean, IntsRefBuilder, float, CharSequence) - 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.
addTransition(int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Add a new transition with min = max = label.
addTransition(int, int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Add a new transition with the specified source, dest, min, max.
addTransition(int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Add a new transition with min = max = label.
addTransition(int, int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Add a new transition with the specified source, dest, min, max.
advance(int) - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
advance(int) - Method in class org.apache.lucene.index.MultiPostingsEnum
 
advance(int) - Method in class org.apache.lucene.search.ConjunctionDISI
 
advance(int) - Method in class org.apache.lucene.search.ConstantScoreScorer
 
advance(int) - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
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.FilterScorer
 
advance(int) - Method in class org.apache.lucene.search.spans.FilterSpans
 
advance(int) - Method in class org.apache.lucene.search.spans.SpanScorer
 
advance(int) - Method in class org.apache.lucene.search.spans.TermSpans
 
advance(int) - Method in class org.apache.lucene.util.BitSetIterator
 
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.
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
Aligns an object size to be the next multiple of RamUsageEstimator.NUM_BYTES_OBJECT_ALIGNMENT.
ALL - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) to get positions, payloads and offsets in the returned enum
all(int) - Static method in class org.apache.lucene.search.DocIdSetIterator
A DocIdSetIterator that matches all documents up to maxDoc - 1.
ALL - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables all optional regexp syntax.
Allocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.Allocator
 
Allocator(int) - Constructor for class org.apache.lucene.util.IntBlockPool.Allocator
 
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
 
AlreadyClosedException(String, Throwable) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
 
AlreadySetException() - Constructor for exception org.apache.lucene.util.SetOnce.AlreadySetException
 
ALWAYS_CACHE - Static variable in interface org.apache.lucene.search.FilterCachingPolicy
Deprecated.
A simple policy that caches all the provided filters on all segments.
ALWAYS_CACHE - Static variable in interface org.apache.lucene.search.QueryCachingPolicy
A simple policy that caches all the provided filters on all segments.
Analyzer - Class in org.apache.lucene.analysis
An Analyzer builds TokenStreams, which analyze text.
Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
Create a new Analyzer, reusing the same set of components per-thread across calls to Analyzer.tokenStream(String, Reader).
Analyzer(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.Analyzer
Expert: create a new Analyzer with a custom Analyzer.ReuseStrategy.
Analyzer.ReuseStrategy - Class in org.apache.lucene.analysis
Strategy defining how TokenStreamComponents are reused per call to Analyzer.tokenStream(String, java.io.Reader).
Analyzer.TokenStreamComponents - Class in org.apache.lucene.analysis
This class encapsulates the outer components of a token stream.
AnalyzerWrapper - Class in org.apache.lucene.analysis
Extension to Analyzer suitable for Analyzers which wrap other Analyzers.
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.BitDocIdSet.Builder
Deprecated.
and(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
Deprecated.
and(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
 
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(DocIdSetIterator) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.BitDocIdSet.Builder
Deprecated.
andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
Deprecated.
andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
 
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
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))".
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 String to this character sequence.
append(StringBuilder) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the specified StringBuilder to this character sequence.
append(CharTermAttribute) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the contents of the other CharTermAttribute to this character sequence.
append(CharSequence) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(char) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(String) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(StringBuilder) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharTermAttribute) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(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.BytesRefArray
Appends a copy of the given BytesRef to this BytesRefArray.
append(byte) - Method in class org.apache.lucene.util.BytesRefBuilder
Append a single byte to this builder.
append(byte[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Append the provided bytes to this builder.
append(BytesRef) - Method in class org.apache.lucene.util.BytesRefBuilder
Append the provided bytes to this builder.
append(BytesRefBuilder) - Method in class org.apache.lucene.util.BytesRefBuilder
Append the provided bytes to this builder.
append(CharSequence) - Method in class org.apache.lucene.util.CharsRefBuilder
 
append(CharSequence, int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
 
append(char) - Method in class org.apache.lucene.util.CharsRefBuilder
 
append(char[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
Appends the given array to this CharsRef
append(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Append the provided int to this buffer.
appendAnyChar(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Automata
Accept any single character starting from the specified state, returning the new state
appendChar(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Automata
Appends the specified character to the specified state, returning a new state.
approximateCardinality() - Method in class org.apache.lucene.util.BitSet
Return an approximation of the cardinality of this set.
approximateCardinality() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
approximation - Variable in class org.apache.lucene.search.DisiWrapper
 
approximation() - Method in class org.apache.lucene.search.TwoPhaseDocIdSetIterator
Return an approximation.
approximation - Variable in class org.apache.lucene.search.TwoPhaseIterator
 
approximation() - Method in class org.apache.lucene.search.TwoPhaseIterator
Return an approximation.
Arc() - Constructor for class org.apache.lucene.util.fst.Builder.Arc
 
Arc() - Constructor for class org.apache.lucene.util.fst.FST.Arc
 
arc - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
arcIdx - Variable in class org.apache.lucene.util.fst.FST.Arc
Where we are in the array; only valid if bytesPerArc != 0.
arcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
ArrayUtil - Class in org.apache.lucene.util
Methods for manipulating arrays.
asDocIdSetIterator(TwoPhaseDocIdSetIterator) - Static method in class org.apache.lucene.search.TwoPhaseDocIdSetIterator
Return a DocIdSetIterator view of the provided TwoPhaseDocIdSetIterator.
asDocIdSetIterator(TwoPhaseIterator) - Static method in class org.apache.lucene.search.TwoPhaseIterator
Return a DocIdSetIterator view of the provided TwoPhaseIterator.
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 double value.
asList() - Method in class org.apache.lucene.index.SegmentInfos
Returns all contained segments as an unmodifiable List view.
assertUnpositioned(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
Assert that the current doc is -1.
asTwoPhaseIterator() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
asTwoPhaseIterator() - Method in class org.apache.lucene.search.FilterScorer
 
asTwoPhaseIterator() - Method in class org.apache.lucene.search.Scorer
Optional method: Return a TwoPhaseIterator view of this Scorer.
asTwoPhaseIterator() - Method in class org.apache.lucene.search.spans.FilterSpans
 
asTwoPhaseIterator() - Method in class org.apache.lucene.search.spans.Spans
Optional method: Return a TwoPhaseIterator view of this Spans.
asTwoPhaseIterator() - Method in class org.apache.lucene.search.spans.SpanScorer
 
asTwoPhaseIterator(DocIdSetIterator) - Static method in class org.apache.lucene.search.TwoPhaseIterator
Returns a TwoPhaseIterator for this DocIdSetIterator when available * otherwise returns null.
atanh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic tangent of a double value.
atLeast(SpanWeight.Postings) - Method in enum org.apache.lucene.search.spans.SpanWeight.Postings
 
Attribute - Interface in org.apache.lucene.util
Base interface for attributes.
AttributeFactory - Class in org.apache.lucene.util
An AttributeFactory creates instances of AttributeImpls.
AttributeFactory() - Constructor for class org.apache.lucene.util.AttributeFactory
 
AttributeFactory.StaticImplementationAttributeFactory<A extends AttributeImpl> - Class in org.apache.lucene.util
Expert: AttributeFactory returning an instance of the given clazz for the attributes it implements.
AttributeImpl - Class in org.apache.lucene.util
Base class for Attributes that can be added to a AttributeSource.
AttributeImpl() - Constructor for class org.apache.lucene.util.AttributeImpl
 
AttributeReflector - Interface in org.apache.lucene.util
This interface is used to reflect contents of AttributeSource or AttributeImpl.
attributes() - Method in class org.apache.lucene.index.FieldInfo
Returns internal codec attributes map.
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.FilterLeafReader.FilterPostingsEnum
 
attributes() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
attributes() - Method in class org.apache.lucene.index.PostingsEnum
Returns the related attributes.
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
An AttributeSource using the default attribute factory AttributeFactory.DEFAULT_ATTRIBUTE_FACTORY.
AttributeSource(AttributeSource) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource that uses the same attributes as the supplied one.
AttributeSource(AttributeFactory) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the supplied AttributeFactory for creating new Attribute instances.
AttributeSource.State - Class in org.apache.lucene.util
This class holds the state of an AttributeSource.
AUTO_DETECT_MERGES_AND_THREADS - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Dynamic default for maxThreadCount and maxMergeCount, used to detect whether the index is backed by an SSD or rotational disk and set maxThreadCount accordingly.
automata() - Method in interface org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttribute
 
automata() - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
 
Automata - Class in org.apache.lucene.util.automaton
Construction of basic automata.
automatic() - Static method in class org.apache.lucene.util.OfflineSorter.BufferSize
Approximately half of the currently available free heap, but no less than OfflineSorter.ABSOLUTE_MIN_SORT_BUFFER_SIZE.
automaton - Variable in class org.apache.lucene.search.AutomatonQuery
the automaton to match index terms against
Automaton - Class in org.apache.lucene.util.automaton
Represents an automaton and all its states and transitions.
Automaton() - Constructor for class org.apache.lucene.util.automaton.Automaton
Sole constructor; creates an automaton with no states.
Automaton(int, int) - Constructor for class org.apache.lucene.util.automaton.Automaton
Constructor which creates an automaton with enough space for the given number of states and transitions.
automaton - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Two dimensional array of transitions, indexed by state number for traversal.
AUTOMATON - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables named automata (<identifier>).
Automaton.Builder - Class in org.apache.lucene.util.automaton
Records new states and transitions and then Automaton.Builder.finish() creates the Automaton.
AutomatonProvider - Interface in org.apache.lucene.util.automaton
Automaton provider for RegExp. RegExp.toAutomaton(AutomatonProvider,int)
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.
AutomatonQuery(Term, Automaton, int) - Constructor for class org.apache.lucene.search.AutomatonQuery
Create a new AutomatonQuery from an Automaton.
AutomatonQuery(Term, Automaton, int, boolean) - Constructor for class org.apache.lucene.search.AutomatonQuery
Create a new AutomatonQuery from an Automaton.
AutomatonTermsEnum - Class in org.apache.lucene.index
A FilteredTermsEnum that enumerates terms based upon what is accepted by a DFA.
AutomatonTermsEnum(TermsEnum, CompiledAutomaton) - Constructor for class org.apache.lucene.index.AutomatonTermsEnum
Construct an enumerator based upon an automaton, enumerating the specified field, working on a supplied TermsEnum
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 returns 1 if the index does not store sumTotalTermFreq: any field that omits frequency information).

B

base - Variable in class org.apache.lucene.index.UpgradeIndexMergePolicy
Wrapped MergePolicy.
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 BaseCompositeReader on the given subReaders.
BaseDirectory - Class in org.apache.lucene.store
Base implementation for a concrete Directory that uses a LockFactory for locking.
BaseDirectory(LockFactory) - 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
 
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
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.
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.codecs.StoredFieldsWriter.MergeVisitor
 
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.codecs.StoredFieldsWriter.MergeVisitor
 
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
BIT_ARC_HAS_OUTPUT - Static variable in class org.apache.lucene.util.fst.FST
This flag is set if the arc has an output.
bitCount(byte) - Static method in class org.apache.lucene.util.BitUtil
Deprecated.
BitDocIdSet - Class in org.apache.lucene.util
Implementation of the DocIdSet interface on top of a BitSet.
BitDocIdSet(BitSet, long) - Constructor for class org.apache.lucene.util.BitDocIdSet
Wrap the given BitSet as a DocIdSet.
BitDocIdSet(BitSet) - Constructor for class org.apache.lucene.util.BitDocIdSet
BitDocIdSet.Builder - Class in org.apache.lucene.util
A builder of DocIdSets that supports random access.
bitList(byte) - Static method in class org.apache.lucene.util.BitUtil
Deprecated.
do not use.
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.DocValuesDocIdSet
 
bits() - Method in class org.apache.lucene.search.FilteredDocIdSet
 
bits() - Method in class org.apache.lucene.util.BitDocIdSet
 
Bits - Interface in org.apache.lucene.util
Interface for Bitset-like structures.
bits() - Method in class org.apache.lucene.util.NotDocIdSet
 
Bits.MatchAllBits - Class in org.apache.lucene.util
Bits impl of the specified length with all bits set.
Bits.MatchNoBits - Class in org.apache.lucene.util
Bits impl of the specified length with no bits set.
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
BitSet - Class in org.apache.lucene.util
Base implementation for a bit set.
BitSet() - Constructor for class org.apache.lucene.util.BitSet
 
BitSetIterator - Class in org.apache.lucene.util
A DocIdSetIterator which iterates over set bits in a bit set.
BitSetIterator(BitSet, long) - Constructor for class org.apache.lucene.util.BitSetIterator
Sole constructor.
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.DirectWriter
Returns how many bits are required to hold values up to and including maxValue
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 NOTE: This method returns at least 1.
BitUtil - Class in org.apache.lucene.util
A variety of high efficiency bit twiddling routines.
BlendedTermQuery - Class in org.apache.lucene.search
A Query that blends index statistics across multiple terms.
BlendedTermQuery.Builder - Class in org.apache.lucene.search
A Builder for BlendedTermQuery.
BlendedTermQuery.DisjunctionMaxRewrite - Class in org.apache.lucene.search
A BlendedTermQuery.RewriteMethod that creates a DisjunctionMaxQuery out of the sub queries.
BlendedTermQuery.RewriteMethod - Class in org.apache.lucene.search
A BlendedTermQuery.RewriteMethod defines how queries for individual terms should be merged.
BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
Fixed packed block size, number of integers encoded in a single packed block.
blockCountByPrefixLen - Variable in class org.apache.lucene.codecs.blocktree.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
Provides random access to a stream written with BlockPackedWriter.
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
Reader for sequences of longs written with BlockPackedWriter.
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.util.ByteBlockPool.Allocator
 
blockSize - Variable in class org.apache.lucene.util.IntBlockPool.Allocator
 
BlockTermState - Class in org.apache.lucene.codecs
Holds all state required for PostingsReaderBase to produce a PostingsEnum without re-seeking the terms dict.
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.blocktree
A block-based terms index and dictionary that assigns terms to variable length blocks according to how they share prefixes.
BlockTreeTermsReader(PostingsReaderBase, SegmentReadState) - Constructor for class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
Sole constructor.
BlockTreeTermsWriter - Class in org.apache.lucene.codecs.blocktree
Block-based terms index and dictionary writer.
BlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int) - Constructor for class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
Create a new writer, using default values for auto-prefix terms.
BlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int, int, int) - Constructor for class org.apache.lucene.codecs.blocktree.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.
BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.BlendedTermQuery
A BlendedTermQuery.RewriteMethod that adds all sub queries to a BooleanQuery which has coords disabled.
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
Deprecated.
Use the BooleanQuery.Builder class to build boolean queries.
BooleanQuery(boolean) - Constructor for class org.apache.lucene.search.BooleanQuery
Deprecated.
Use the BooleanQuery.Builder class to build boolean queries.
BooleanQuery.Builder - Class in org.apache.lucene.search
A builder for boolean queries.
BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
Thrown when an attempt is made to add more than BooleanQuery.getMaxClauseCount() clauses.
boost() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
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 - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
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
Add this Attribute to a TermsEnum returned by MultiTermQuery.getTermsEnum(Terms,AttributeSource) and update the boost on each returned term.
BoostAttributeImpl - Class in org.apache.lucene.search
Implementation class for BoostAttribute.
BoostAttributeImpl() - Constructor for class org.apache.lucene.search.BoostAttributeImpl
 
BUF_SIZE_INT - Static variable in class org.apache.lucene.util.NumericUtils
The maximum term length (used for byte[] buffer size) for encoding int values.
BUF_SIZE_LONG - Static variable in class org.apache.lucene.util.NumericUtils
The maximum term length (used for byte[] buffer size) for encoding long values.
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.
BufferedChecksum - Class in org.apache.lucene.store
Wraps another Checksum with an internal buffer to speed up checksum calculations.
BufferedChecksum(Checksum) - Constructor for class org.apache.lucene.store.BufferedChecksum
Create a new BufferedChecksum with BufferedChecksum.DEFAULT_BUFFERSIZE
BufferedChecksum(Checksum, int) - Constructor for class org.apache.lucene.store.BufferedChecksum
Create a new BufferedChecksum with the specified bufferSize
BufferedChecksumIndexInput - Class in org.apache.lucene.store
Simple implementation of ChecksumIndexInput that wraps another input and delegates calls.
BufferedChecksumIndexInput(IndexInput) - Constructor for class org.apache.lucene.store.BufferedChecksumIndexInput
Creates a new BufferedChecksumIndexInput
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
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
bufferSize - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
read buffer size (in bytes)
bufferSkip(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Writes the current skip data to the buffers.
bugfix - Variable in class org.apache.lucene.util.Version
Bugfix number, incremented on release branches
build(CodecReader) - Static method in class org.apache.lucene.index.MergeState.DocMap
Creates a MergeState.DocMap instance appropriate for this reader.
build(Object, SortedDocValues[], float) - Static method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
Create an ordinal map that uses the number of unique values of each SortedDocValues instance as a weight.
build(Object, SortedSetDocValues[], float) - Static method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
Create an ordinal map that uses the number of unique values of each SortedSetDocValues instance as a weight.
build(Object, TermsEnum[], long[], float) - Static method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
Creates an ordinal map that allows mapping ords to/from a merged space from subs.
build(IndexReaderContext, Term) - Static method in class org.apache.lucene.index.TermContext
Creates a TermContext from a top-level IndexReaderContext and the given Term.
build() - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Build the BlendedTermQuery.
build() - Method in class org.apache.lucene.search.BooleanQuery.Builder
Create a new BooleanQuery based on the parameters that have been set on this builder.
build(BlendedTermQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
 
build(BooleanQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
build(BooleanQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
build() - Method in class org.apache.lucene.search.PhraseQuery.Builder
Build a phrase query based on the terms that have been added.
build() - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
Build the query
build() - Method in class org.apache.lucene.util.BitDocIdSet.Builder
Build a DocIdSet that contains all doc ids that have been added.
build() - Method in class org.apache.lucene.util.DocIdSetBuilder
Build a DocIdSet from the accumulated doc IDs.
build(long) - Method in class org.apache.lucene.util.DocIdSetBuilder
Expert: build a DocIdSet with a hint on the cost that the resulting DocIdSet would have.
build() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
Build a PackedLongValues instance that contains values that have been added to this builder.
build() - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
Build an instance.
builder - Variable in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
May be used by subclasses to convert to different charsets / encodings for implementing CharTermAttributeImpl.getBytesRef().
Builder() - Constructor for class org.apache.lucene.index.PrefixCodedTerms.Builder
Sole constructor.
Builder() - Constructor for class org.apache.lucene.search.BlendedTermQuery.Builder
Sole constructor.
Builder() - Constructor for class org.apache.lucene.search.BooleanQuery.Builder
Sole constructor.
Builder() - Constructor for class org.apache.lucene.search.PhraseQuery.Builder
Sole constructor.
Builder(String, boolean) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery.Builder
Construct a new builder
Builder() - Constructor for class org.apache.lucene.util.automaton.Automaton.Builder
Default constructor, pre-allocating for 16 states and transitions.
Builder(int, int) - Constructor for class org.apache.lucene.util.automaton.Automaton.Builder
Constructor which creates a builder with enough space for the given number of states and transitions.
Builder(int, boolean) - Constructor for class org.apache.lucene.util.BitDocIdSet.Builder
Create a new instance that can hold maxDoc documents and is optionally full.
Builder(int) - Constructor for class org.apache.lucene.util.BitDocIdSet.Builder
Create a new empty instance.
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>, 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(int) - Constructor for class org.apache.lucene.util.RoaringDocIdSet.Builder
Sole constructor.
Builder.Arc<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) arc.
Builder.UnCompiledNode<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) Node.
BulkScorer - Class in org.apache.lucene.search
This class is used to score a range of documents at once, and is returned by Weight.bulkScorer(org.apache.lucene.index.LeafReaderContext).
BulkScorer() - Constructor for class org.apache.lucene.search.BulkScorer
 
bulkScorer(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
Optional method, to return a BulkScorer to score the query and send hits to a Collector.
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
 
byteAt(int) - Method in class org.apache.lucene.util.BytesRefBuilder
Return the byte at the given offset.
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.DirectAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles.
ByteBlockPool.DirectTrackingAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles, but tracks how much total RAM is in use.
byteCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Computes how many byte blocks are needed to store values values of size bitsPerValue.
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
Converts incoming automaton to byte-based (UTF32ToUTF8) first
ByteRunAutomaton(Automaton, boolean, int) - 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() - Method in class org.apache.lucene.util.BytesRefBuilder
Return a reference to the bytes of this builder.
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 (from the start of each).
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.
ByteSequencesReader(Path) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
Constructs a ByteSequencesReader from the provided Path
ByteSequencesReader(DataInput) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
Constructs a ByteSequencesReader from the provided DataInput
ByteSequencesWriter(Path) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Constructs a ByteSequencesWriter to the provided Path
ByteSequencesWriter(DataOutput) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Constructs a ByteSequencesWriter to the provided DataOutput
bytesPerArc - Variable in class org.apache.lucene.util.fst.FST.Arc
Non-zero if this arc is part of an array, which means all arcs for the node are encoded with a fixed number of bytes so that we can random access by index.
BytesReader() - Constructor for class org.apache.lucene.util.fst.FST.BytesReader
 
BytesRef - Class in org.apache.lucene.util
Represents byte[], as a slice (offset + length) into an existing byte[].
BytesRef() - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef with BytesRef.EMPTY_BYTES
BytesRef(byte[], int, int) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(byte[]) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(int) - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef pointing to a new array of size capacity.
BytesRef(CharSequence) - Constructor for class org.apache.lucene.util.BytesRef
Initialize the byte[] from the UTF8 bytes for the provided String.
BytesRefArray - Class in org.apache.lucene.util
A simple append only random-access BytesRef array that stores full copies of the appended bytes in a ByteBlockPool.
BytesRefArray(Counter) - Constructor for class org.apache.lucene.util.BytesRefArray
Creates a new BytesRefArray with a counter to track allocated bytes
BytesRefBuilder - Class in org.apache.lucene.util
A builder for BytesRef instances.
BytesRefBuilder() - Constructor for class org.apache.lucene.util.BytesRefBuilder
Sole constructor.
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.
BytesRefHash - Class in org.apache.lucene.util
BytesRefHash is a special purpose hash-map like data-structure optimized for BytesRef instances.
BytesRefHash() - Constructor for class org.apache.lucene.util.BytesRefHash
BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash.BytesStartArray - Class in org.apache.lucene.util
Manages allocation of the per-term addresses.
BytesRefHash.DirectBytesStartArray - Class in org.apache.lucene.util
A simple BytesRefHash.BytesStartArray that tracks memory allocation using a private Counter instance.
BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
Thrown if a BytesRef exceeds the BytesRefHash limit of ByteBlockPool.BYTE_BLOCK_SIZE-2.
BytesRefIterator - Interface in org.apache.lucene.util
A simple iterator interface for BytesRef iteration.
BytesStartArray() - Constructor for class org.apache.lucene.util.BytesRefHash.BytesStartArray
 
byteStart(int) - Method in class org.apache.lucene.util.BytesRefHash
Returns the bytesStart offset into the internally used ByteBlockPool for the given bytesID
BytesTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
This attribute can be used if you have the raw term bytes to be indexed.
BytesTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Implementation class for BytesTermAttribute.
BytesTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
Initialize this attribute with no bytes.
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
A Counter reference holding the number of bytes used by this 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
The number of values that can be stored in PackedInts.Decoder.byteBlockCount() byte blocks.
byteValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
The number of values that can be stored in PackedInts.Encoder.byteBlockCount() byte blocks.

C

cacheImpl(DocIdSetIterator, LeafReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
Default cache implementation: uses RoaringDocIdSet.
cacheImpl(DocIdSetIterator, LeafReader) - Method in class org.apache.lucene.search.CachingWrapperQuery
Default cache implementation: uses RoaringDocIdSet.
cacheImpl(DocIdSetIterator, LeafReader) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Default cache implementation: uses RoaringDocIdSet.
cacheImpl(DocIdSetIterator, LeafReader) - Method in class org.apache.lucene.search.LRUQueryCache
Default cache implementation: uses RoaringDocIdSet.
CacheOnLargeSegments(float) - Constructor for class org.apache.lucene.search.FilterCachingPolicy.CacheOnLargeSegments
Deprecated.
Create a FilterCachingPolicy.CacheOnLargeSegments instance that only caches on a given segment if its number of documents divided by the total number of documents in the index is greater than or equal to minSizeRatio.
CacheOnLargeSegments(int, float) - Constructor for class org.apache.lucene.search.QueryCachingPolicy.CacheOnLargeSegments
Create a QueryCachingPolicy.CacheOnLargeSegments instance that only caches on a given segment if the total number of documents in the index is greater than minIndexSize and the number of documents in the segment divided by the total number of documents in the index is greater than or equal to minSizeRatio.
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.
CachingWrapperFilter - Class in org.apache.lucene.search
Deprecated.
CachingWrapperFilter(Filter, FilterCachingPolicy) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
Wraps another filter's result and caches it according to the provided policy.
CachingWrapperFilter(Filter) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
CachingWrapperQuery - Class in org.apache.lucene.search
Wraps another Query's result and caches it when scores are not needed.
CachingWrapperQuery(Query, QueryCachingPolicy) - Constructor for class org.apache.lucene.search.CachingWrapperQuery
Wraps another query's result and caches it according to the provided policy.
CachingWrapperQuery(Query) - Constructor for class org.apache.lucene.search.CachingWrapperQuery
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.MultiPostingsEnum
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.
captureState() - Method in class org.apache.lucene.util.AttributeSource
Captures the state of all Attributes.
cardinality() - Method in class org.apache.lucene.index.RandomAccessOrds
Returns the cardinality for the current document (previously set by SortedSetDocValues.setDocument(int).
cardinality() - Method in class org.apache.lucene.util.BitSet
Return the number of bits that are set.
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.RoaringDocIdSet
Return the exact number of documents that are contained in this set.
cardinality() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
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 and 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
Construct with a default number of maxDeterminizedStates.
CharacterRunAutomaton(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.CharacterRunAutomaton
Construct specifying maxDeterminizedStates.
charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
charAt(int) - Method in class org.apache.lucene.util.CharsRef
 
charAt(int) - Method in class org.apache.lucene.util.CharsRefBuilder
Return the char at the given offset.
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.
chars() - Method in class org.apache.lucene.util.CharsRefBuilder
Return a reference to the chars of this builder.
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
Deprecated.
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
CharsRefBuilder - Class in org.apache.lucene.util
A builder for CharsRef instances.
CharsRefBuilder() - Constructor for class org.apache.lucene.util.CharsRefBuilder
Sole constructor.
CharTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The term text of a Token.
CharTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of CharTermAttribute.
CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
Initialize this attribute with empty term text
checkAbort() - Method in class org.apache.lucene.index.MergeRateLimiter
Throws MergePolicy.MergeAbortedException if this merge was aborted.
checkConsistency() - Method in class org.apache.lucene.index.FieldInfo
Performs internal consistency checks.
checkEOF(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Deprecated.
Use CodecUtil.checkFooter(org.apache.lucene.store.ChecksumIndexInput) instead, this should only used for files without checksums
checkFooter(ChecksumIndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Validates the codec footer previously written by CodecUtil.writeFooter(org.apache.lucene.store.IndexOutput).
checkFooter(ChecksumIndexInput, Throwable) - Static method in class org.apache.lucene.codecs.CodecUtil
Validates the codec footer previously written by CodecUtil.writeFooter(org.apache.lucene.store.IndexOutput), optionally passing an unexpected exception that has already occurred.
checkHeader(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
Reads and validates a header previously written with CodecUtil.writeHeader(DataOutput, String, int).
checkHeaderNoMagic(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
Like CodecUtil.checkHeader(DataInput,String,int,int) except this version assumes the first int has already been read and validated from the input.
checkIfFrozen() - Method in class org.apache.lucene.document.FieldType
Throws an exception if this FieldType is frozen.
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(Directory, Lock) - Constructor for class org.apache.lucene.index.CheckIndex
Expert: create a directory with the specified lock.
checkIndex() - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
checkIndex(List<String>) - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
CheckIndex.Status - Class in org.apache.lucene.index
Returned from CheckIndex.checkIndex() detailing the health and status of the index.
CheckIndex.Status.DocValuesStatus - Class in org.apache.lucene.index
Status from testing DocValues
CheckIndex.Status.FieldInfoStatus - Class in org.apache.lucene.index
Status from testing field infos.
CheckIndex.Status.FieldNormStatus - Class in org.apache.lucene.index
Status from testing field norms.
CheckIndex.Status.LiveDocStatus - Class in org.apache.lucene.index
Status from testing livedocs
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.
checkIndexHeader(DataInput, String, int, int, byte[], String) - Static method in class org.apache.lucene.codecs.CodecUtil
Reads and validates a header previously written with CodecUtil.writeIndexHeader(DataOutput, String, int, byte[], String).
checkIndexHeaderID(DataInput, byte[]) - Static method in class org.apache.lucene.codecs.CodecUtil
Expert: just reads and verifies the object ID of an index header
checkIndexHeaderSuffix(DataInput, String) - Static method in class org.apache.lucene.codecs.CodecUtil
Expert: just reads and verifies the suffix of an index header
checkIntegrity() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.DocValuesProducer
Checks consistency of this producer
checkIntegrity() - Method in class org.apache.lucene.codecs.FieldsProducer
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.NormsProducer
Checks consistency of this producer
checkIntegrity() - Method in class org.apache.lucene.codecs.PostingsReaderBase
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.StoredFieldsReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.TermVectorsReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.index.CodecReader
 
checkIntegrity() - Method in class org.apache.lucene.index.FilterLeafReader
 
checkIntegrity() - Method in class org.apache.lucene.index.LeafReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.index.ParallelLeafReader
 
checkIntegrity() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
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.
checkPayloads(Collection<byte[]>) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
Check to see if the collected payloads match the required set.
checkServiceName(String) - Static method in class org.apache.lucene.util.NamedSPILoader
Validates that a service name meets the requirements of NamedSPILoader.NamedSPI
checksumEntireFile(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Clones the provided input, reads all bytes from the file, and calls CodecUtil.checkFooter(org.apache.lucene.store.ChecksumIndexInput)
ChecksumIndexInput - Class in org.apache.lucene.store
Extension of IndexInput, computing checksum as it goes.
ChecksumIndexInput(String) - Constructor for class org.apache.lucene.store.ChecksumIndexInput
resourceDescription should be a non-null, opaque string describing this resource; it's returned from IndexInput.toString().
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.CompositeReaderContext
 
children() - Method in class org.apache.lucene.index.IndexReaderContext
Returns the context's children iff this context is a composite context otherwise null.
children() - Method in class org.apache.lucene.index.LeafReaderContext
 
ChildScorer(Scorer, String) - Constructor for class org.apache.lucene.search.Scorer.ChildScorer
Creates a new ChildScorer node with the specified relationship.
clauses() - Method in class org.apache.lucene.search.BooleanQuery
Return a list of the clauses of this BooleanQuery.
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
Deprecated.
Resets the term text, payload, flags, positionIncrement, positionLength, startOffset, endOffset and token type to default.
clear() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
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.PackedTokenAttributeImpl
Resets the attributes
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 all SegmentCommitInfos.
clear() - Method in class org.apache.lucene.index.TermContext
Clears the TermContext internal state and removes all registered TermStates
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.LRUFilterCache
Deprecated.
Clear the content of this cache.
clear() - Method in class org.apache.lucene.search.LRUQueryCache
Clear the content of this cache.
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(int, int) - Method in class org.apache.lucene.util.BitSet
Clears a range of bits.
clear() - Method in class org.apache.lucene.util.BytesRefArray
Clears this BytesRefArray
clear() - Method in class org.apache.lucene.util.BytesRefBuilder
Reset this builder to the empty state.
clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
clears the BytesRefHash.BytesStartArray and returns the cleared instance.
clear(boolean) - Method in class org.apache.lucene.util.BytesRefHash
Clears the BytesRef which maps to the given BytesRef
clear() - Method in class org.apache.lucene.util.BytesRefHash
 
clear() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
clear() - Method in class org.apache.lucene.util.CharsRefBuilder
Reset this builder to the empty state.
clear(int) - Method in class org.apache.lucene.util.FixedBitSet
 
clear(int, int) - Method in class org.apache.lucene.util.FixedBitSet
 
clear() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
clear() - Method in class org.apache.lucene.util.IntsRefBuilder
Empty this builder.
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 index to false.
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(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
Clear the bit at index i.
clear(int, int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
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.
clearCoreCacheKey(Object) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Remove all cache entries for the given core cache key.
clearCoreCacheKey(Object) - Method in class org.apache.lucene.search.LRUQueryCache
Remove all cache entries for the given core cache key.
clearFilter(Filter) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Remove all cache entries for the given filter.
clearQuery(Query) - Method in class org.apache.lucene.search.LRUQueryCache
Remove all cache entries for the given query.
clone() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.Token
Deprecated.
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
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.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.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.TermState
 
clone() - Method in class org.apache.lucene.search.BooleanQuery
 
clone() - Method in class org.apache.lucene.search.CachingWrapperQuery
 
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
Deprecated.
 
clone() - Method in class org.apache.lucene.search.payloads.SpanNearPayloadCheckQuery
Deprecated.
 
clone() - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
clone() - Method in class org.apache.lucene.search.Query
Returns a clone of this query.
clone() - Method in class org.apache.lucene.search.spans.SpanContainingQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
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.SpanPositionRangeQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanWithinQuery
 
clone() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
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.IndexInput
Returns a clone of this stream.
clone() - Method in class org.apache.lucene.util.AttributeImpl
In most cases the clone is, and should be, deep in order to be able to properly capture the state of all attributes.
clone() - Method in class org.apache.lucene.util.AttributeSource.State
 
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.FixedBitSet
 
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.PagedBytes.PagedBytesDataInput
 
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.blocktree.BlockTreeTermsReader
 
close() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
 
close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexWriter
 
close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
Close the underlying IndexInputs.
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
 
close() - Method in class org.apache.lucene.codecs.FieldsProducer
 
close() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
 
close() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
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.CheckIndex
 
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
Closes all open resources and releases the write lock.
close() - Method in class org.apache.lucene.index.MergeScheduler
Close this MergeScheduler.
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.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 this to future searching; any searches still in process in other threads won't be affected, and they should still call SearcherLifetimeManager.release(org.apache.lucene.search.IndexSearcher) after they are done.
close() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
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.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.OutputStreamIndexOutput
 
close() - Method in class org.apache.lucene.store.RAMDirectory
Closes the store to future operations, releasing associated memory.
close() - Method in class org.apache.lucene.store.RAMInputStream
 
close() - Method in class org.apache.lucene.store.RAMOutputStream
 
close() - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
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.OfflineSorter.ByteSequencesReader
Closes the provided DataInput if it is Closeable.
close() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Closes the provided DataOutput if it is Closeable.
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(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
 
CodecReader - Class in org.apache.lucene.index
LeafReader implemented by codec APIs.
CodecReader() - Constructor for class org.apache.lucene.index.CodecReader
Sole constructor.
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.FilterLeafCollector
 
collect(int) - Method in interface org.apache.lucene.search.LeafCollector
Called once for every document matching a query, with the unbased document number.
collect(int) - Method in class org.apache.lucene.search.SimpleCollector
 
collect(SpanCollector) - Method in class org.apache.lucene.search.spans.FilterSpans
 
collect(SpanCollector) - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
collect(SpanCollector) - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
collect(SpanCollector) - Method in class org.apache.lucene.search.spans.Spans
Collect postings data from the leaves of the current Spans.
collect(SpanCollector) - Method in class org.apache.lucene.search.spans.TermSpans
 
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
Returns CollectionStatistics for a field.
CollectionTerminatedException - Exception in org.apache.lucene.search
Throw this exception in LeafCollector.collect(int) to prematurely terminate collection of the current leaf.
CollectionTerminatedException() - Constructor for exception org.apache.lucene.search.CollectionTerminatedException
Sole constructor.
CollectionUtil - Class in org.apache.lucene.util
Methods for manipulating (sorting) collections.
collectLeaf(PostingsEnum, int, Term) - Method in class org.apache.lucene.search.payloads.PayloadSpanCollector
 
collectLeaf(PostingsEnum, int, Term) - Method in interface org.apache.lucene.search.spans.SpanCollector
Collect information from postings
Collector - Interface 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.
CollectorManager<C extends Collector,T> - Interface in org.apache.lucene.search
A manager of collectors.
combine(float, boolean, float) - Method in class org.apache.lucene.search.QueryRescorer
Implement this in a subclass to combine the first pass and second pass scores.
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 and 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
IndexCommit that IndexWriter is opened on.
commit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
The second phase of a 2-phase commit.
CommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.CommitFailException
Sole constructor.
commitOnClose - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
True if calls to IndexWriter.close() should first do a 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
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.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 i and j.
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.TermOrdValComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compareBottom(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
Compare the bottom of the queue with this doc.
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(ConcurrentMergeScheduler.MergeThread) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
 
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(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.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.TermOrdValComparator
 
compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compareTop(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
Compare the top value with this doc.
compareValues(T, T) - Method in class org.apache.lucene.search.FieldComparator
Returns a negative integer if first is less than second, 0 if they are equal and a positive integer otherwise.
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
Create this, passing simplify=true and finite=null, so that we try to simplify the automaton and determine if it is finite.
CompiledAutomaton(Automaton, Boolean, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
Create this.
CompiledAutomaton(Automaton, Boolean, boolean, int, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
Create this.
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(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
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 (~).
CompositeReader - Class in org.apache.lucene.index
Instances of this reader type can only be used to get stored fields from the underlying LeafReaders, 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.
compoundFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes compound files
CompoundFormat - Class in org.apache.lucene.codecs
Encodes/decodes compound files
CompoundFormat() - Constructor for class org.apache.lucene.codecs.CompoundFormat
Sole constructor.
compoundFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
compoundFormat() - Method in class org.apache.lucene.codecs.lucene53.Lucene53Codec
 
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
COMPRESSED_REFS_ENABLED - Static variable in class org.apache.lucene.util.RamUsageEstimator
True, iff compressed references (oops) are enabled by this JVM
CompressingStoredFieldsFormat - Class in org.apache.lucene.codecs.compressing
A StoredFieldsFormat that compresses documents in chunks in order to improve the compression ratio.
CompressingStoredFieldsFormat(String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
Create a new CompressingStoredFieldsFormat with an empty segment suffix.
CompressingStoredFieldsFormat(String, String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
CompressingStoredFieldsIndexReader - Class in org.apache.lucene.codecs.compressing
Random-access reader for CompressingStoredFieldsIndexWriter.
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, int, 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, 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, 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
Encodes the document length in the same way as TFIDFSimilarity.
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.
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, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
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.Operations
Returns an automaton that accepts the concatenation of the languages of the given automata.
ConcurrentMergeScheduler - Class in org.apache.lucene.index
A MergeScheduler that runs each merge using a separate thread.
ConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler
Sole constructor, with all settings set to default values.
ConcurrentMergeScheduler.MergeThread - Class in org.apache.lucene.index
Runs a merge thread to execute a single merge, then exits.
ConjunctionDISI - Class in org.apache.lucene.search
A conjunction of DocIdSetIterators.
CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
CONSTANT_SCORE_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
Like MultiTermQuery.SCORING_BOOLEAN_REWRITE except scores are not computed.
CONSTANT_SCORE_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
Like ScoringRewrite.SCORING_BOOLEAN_REWRITE except scores are not computed.
CONSTANT_SCORE_FILTER_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
Deprecated.
CONSTANT_SCORE_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.
ConstantBulkScorer(BulkScorer, Weight, float) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
 
Constants - Class in org.apache.lucene.util
Some useful constants.
ConstantScoreQuery - Class in org.apache.lucene.search
A query that wraps another query and simply returns a constant score equal to the query boost for every document that matches the query.
ConstantScoreQuery(Query) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Strips off scores from the passed in Query.
ConstantScoreQuery.ConstantBulkScorer - Class in org.apache.lucene.search
We return this as our BulkScorer so that if the CSQ wraps a query with its own optimized top-level scorer (e.g.
ConstantScoreScorer - Class in org.apache.lucene.search
A constant-scoring Scorer.
ConstantScoreScorer(Weight, float, DocIdSetIterator) - Constructor for class org.apache.lucene.search.ConstantScoreScorer
Constructor based on a DocIdSetIterator which will be used to drive iteration.
ConstantScoreScorer(Weight, float, TwoPhaseIterator) - Constructor for class org.apache.lucene.search.ConstantScoreScorer
Constructor based on a TwoPhaseIterator.
ConstantScoreWeight - Class in org.apache.lucene.search
A Weight that has a constant score equal to the boost of the wrapped query.
ConstantScoreWeight(Query) - Constructor for class org.apache.lucene.search.ConstantScoreWeight
 
containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
Returns true if 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
IOContext for all writes; you should pass this to Directory.createOutput(String,IOContext).
context - Variable in class org.apache.lucene.store.IOContext
An object of a enumerator Context type
context - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
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.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.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.TermOrdValComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
copy(int, int) - Method in interface org.apache.lucene.search.LeafFieldComparator
This method is called when a new hit is competitive.
copy(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Copies over all states/transitions from other.
copy(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
Copies over all states/transitions from other.
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] into dest[destPos:destPos+len] using at most mem bytes.
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 src to slot dest.
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(byte[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this builder with the provided bytes.
copyBytes(BytesRef) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this builder with the provided bytes.
copyBytes(BytesRefBuilder) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this builder with the provided bytes.
copyChars(CharSequence) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this buffer with UTF-8 encoded bytes that would represent the provided text.
copyChars(CharSequence, int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this buffer with UTF-8 encoded bytes that would represent the provided text.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this buffer with UTF-8 encoded bytes that would represent the provided text.
copyChars(CharsRef) - Method in class org.apache.lucene.util.CharsRefBuilder
Copies the given CharsRef referenced content into this instance.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
Copies the given array into this instance.
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(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.Directory
Copies the file src in from to this directory under the new file name dest.
copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
copyFrom(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST.Arc
Returns this
copyInts(int[], int, int) - Method in class org.apache.lucene.util.IntsRefBuilder
Copies the given array into this instance.
copyInts(IntsRef) - Method in class org.apache.lucene.util.IntsRefBuilder
Copies the given array into this instance.
copyStates(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Copies over all states from other.
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.Token
Deprecated.
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
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.PackedTokenAttributeImpl
 
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 AttributeSource to the given target AttributeSource.
copyUsingLengthPrefix(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy bytes in, writing the length as a 1 or 2 byte vInt prefix.
copyUTF8Bytes(byte[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
Copy the provided bytes, interpreted as UTF-8 bytes.
copyUTF8Bytes(BytesRef) - Method in class org.apache.lucene.util.CharsRefBuilder
Copy the provided bytes, interpreted as UTF-8 bytes.
copyUTF8Bytes(BytesRef) - Method in class org.apache.lucene.util.IntsRefBuilder
Copy the given UTF-8 bytes into this builder.
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, DataInput) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with a message only
CorruptIndexException(String, DataOutput) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with a message only
CorruptIndexException(String, DataInput, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with message and root cause.
CorruptIndexException(String, DataOutput, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with message and root cause.
CorruptIndexException(String, String) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with a message only
CorruptIndexException(String, String, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with message and root cause.
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.index.FilterLeafReader.FilterPostingsEnum
 
cost() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
cost() - Method in class org.apache.lucene.search.BulkScorer
Same as DocIdSetIterator.cost() for bulk scorers.
cost() - Method in class org.apache.lucene.search.ConjunctionDISI
 
cost() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
 
cost() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
cost - Variable in class org.apache.lucene.search.DisiWrapper
 
cost() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
cost() - Method in class org.apache.lucene.search.DocIdSetIterator
Returns the estimated cost of this DocIdSetIterator.
cost() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
cost() - Method in class org.apache.lucene.search.FilterScorer
 
cost() - Method in class org.apache.lucene.search.spans.FilterSpans
 
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.search.Weight.DefaultBulkScorer
 
cost() - Method in class org.apache.lucene.util.BitSetIterator
 
cost - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
count() - Method in class org.apache.lucene.index.SortedNumericDocValues
Retrieves the count of values for the current document.
count(Query) - Method in class org.apache.lucene.search.IndexSearcher
Count how many documents match the given query.
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, double) - Static method in class org.apache.lucene.search.CachingCollector
Creates a CachingCollector which does not wrap another collector.
create(Collector, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
Create a new CachingCollector that wraps the given collector and caches documents and scores up to the specified RAM threshold.
create(Collector, boolean, int) - Static method in class org.apache.lucene.search.CachingCollector
Create a new CachingCollector that wraps the given collector and caches documents and scores up to the specified max docs threshold.
create(SortField[], int) - Static method in class org.apache.lucene.search.FieldValueHitQueue
Creates a hit queue sorted by the given list of fields.
create(Sort, int, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
Creates a new TopFieldCollector from the given arguments.
create(Sort, int, FieldDoc, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
Creates a new TopFieldCollector from the given arguments.
create(int) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect and whether documents are scored in order by the input Scorer to LeafCollector.setScorer(Scorer).
create(int, ScoreDoc) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect, the bottom of the previous page, and whether documents are scored in order by the input Scorer to LeafCollector.setScorer(Scorer).
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeFactory
Returns an AttributeImpl for the supplied Attribute interface class.
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
 
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) - Method in class org.apache.lucene.analysis.Analyzer
Creates a new Analyzer.TokenStreamComponents instance for this analyzer.
createComponents(String) - 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.
createInstance() - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
Creates an instance of A.
createMinShouldMatchQuery(String, String, float) - Method in class org.apache.lucene.util.QueryBuilder
Creates a minimum-should-match query from the query text.
createNormalizedWeight(Query, boolean) - 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.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.LockValidatingDirectoryWrapper
 
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.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.
createState() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Create a new state.
createState() - Method in class org.apache.lucene.util.automaton.Automaton
Create a new state.
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.BooleanQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.CachingWrapperQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create the Weight used to score us
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.FieldValueQuery
 
createWeight(Query, boolean) - Method in class org.apache.lucene.search.IndexSearcher
Creates a Weight for the given query, potentially adding caching if possible and configured.
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
Deprecated.
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.payloads.PayloadScoreQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
Deprecated.
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.PhraseQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.Query
Expert: Constructs an appropriate Weight implementation for this query.
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanContainingQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanQuery
Create a SpanWeight for this query
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.spans.SpanWithinQuery
 
createWeight(IndexSearcher, boolean) - Method in class org.apache.lucene.search.TermQuery
 
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
 
currentReaderValues - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
 
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

D

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(long[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
Read iterations * blockCount() blocks from blocks, decode them and write iterations * valueCount() values into values.
decode(byte[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
Read 8 * iterations * blockCount() blocks from blocks, decode them and write iterations * valueCount() values into values.
decode(long[], int, int[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
Read iterations * blockCount() blocks from blocks, decode them and write iterations * valueCount() values into values.
decode(byte[], int, int[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
Read 8 * iterations * blockCount() blocks from blocks, decode them and write iterations * valueCount() values into values.
decodeDelta(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
decodeNormValue(byte) - Method in class org.apache.lucene.search.similarities.BM25Similarity
The default implementation returns 1 / f2 where f is SmallFloat.byte315ToFloat(byte).
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.lucene50.Lucene50PostingsReader
 
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 offset and offset+length in the original stream from the compressed stream in to bytes.
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 LongsRef that points to a copy of the longs from other
DEFAULT - Static variable in class org.apache.lucene.search.FilterCachingPolicy.CacheOnLargeSegments
Deprecated.
FilterCachingPolicy.CacheOnLargeSegments instance that only caches on segments that account for more than 3% of the total index size.
DEFAULT - Static variable in class org.apache.lucene.search.QueryCachingPolicy.CacheOnLargeSegments
QueryCachingPolicy.CacheOnLargeSegments instance that only caches on segments that account for more than 3% of the total index size.
DEFAULT - Static variable in class org.apache.lucene.store.IOContext
 
DEFAULT - Static variable in class org.apache.lucene.util.packed.PackedInts
At most 25% memory overhead.
DEFAULT_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.util.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.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_BUFFERSIZE - Static variable in class org.apache.lucene.store.BufferedChecksum
Default buffer size: 256
DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
 
DEFAULT_COMMIT_ON_CLOSE - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value for whether calls to IndexWriter.close() include a commit.
DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.util.OfflineSorter
Default comparator: sorts in binary (codepoint) order
DEFAULT_CPU_CORE_COUNT_PROPERTY - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Used for testing.
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.blocktree.BlockTreeTermsWriter
Suggested default value for the maxItemsInBlock parameter to BlockTreeTermsWriter.BlockTreeTermsWriter(SegmentWriteState,PostingsWriterBase,int,int).
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_CHUNK_SIZE - Static variable in class org.apache.lucene.store.MMapDirectory
Default max chunk size.
DEFAULT_MAX_DETERMINIZED_STATES - Static variable in class org.apache.lucene.util.automaton.Operations
Default maximum number of states that Operations.determinize(org.apache.lucene.util.automaton.Automaton, int) should create.
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_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.blocktree.BlockTreeTermsWriter
Suggested default value for the minItemsInBlock parameter to BlockTreeTermsWriter.BlockTreeTermsWriter(SegmentWriteState,PostingsWriterBase,int,int).
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_POLL_INTERVAL - Static variable in class org.apache.lucene.store.SleepingLockWrapper
How long SleepingLockWrapper.obtainLock(java.lang.String) waits, in milliseconds, in between attempts to acquire the lock.
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_READER_POOLING - Static variable in class org.apache.lucene.index.IndexWriterConfig
DEFAULT_RESOLUTION - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
DEFAULT_SPINS_PROPERTY - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Used for testing.
DEFAULT_TOKEN_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.analysis.TokenStream
Default AttributeFactory instance that should be used for TokenStreams.
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).
DefaultBulkScorer(Scorer) - Constructor for class org.apache.lucene.search.Weight.DefaultBulkScorer
Sole constructor.
DefaultCollectionModel() - Constructor for class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
Sole constructor: parameter-free
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
defaultTempDir() - Static method in class org.apache.lucene.util.OfflineSorter
Returns the default temporary directory.
defaultTranspositions - Static variable in class org.apache.lucene.search.FuzzyQuery
 
deinterleave(long) - Static method in class org.apache.lucene.util.BitUtil
Deinterleaves long value back to two concatenated 32bit values
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.
DelegatingAnalyzerWrapper - Class in org.apache.lucene.analysis
An analyzer wrapper, that doesn't allow to wrap components or readers.
DelegatingAnalyzerWrapper(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
Constructor.
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
Calls IndexWriter.deleteAll() and returns the generation that reflects this change.
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 any of the provided queries.
deleteDocuments(Term) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.deleteDocuments(Term...) and returns the generation that reflects this change.
deleteDocuments(Term...) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.deleteDocuments(Term...) and returns the generation that reflects this change.
deleteDocuments(Query) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.deleteDocuments(Query...) and returns the generation that reflects this change.
deleteDocuments(Query...) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.deleteDocuments(Query...) and returns the generation that reflects this change.
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.LockValidatingDirectoryWrapper
 
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
 
deleteFilesIfExist(Path...) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given Paths, if they exist.
deleteFilesIfExist(Collection<? extends Path>) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given Paths, if they exist.
deleteFilesIgnoringExceptions(Directory, String...) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteFilesIgnoringExceptions(Path...) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteFilesIgnoringExceptions(Collection<? extends Path>) - 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.
delGen() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
 
delPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
IndexDeletionPolicy controlling when commit points are deleted.
deltaPackedBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
Return a new PackedLongValues.Builder that will compress efficiently integers that are close to each other.
deltaPackedBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
 
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.
dest - Variable in class org.apache.lucene.util.automaton.Transition
Destination state.
determinize(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
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.SegmentInfo
Where this segment resides.
DirectAllocator() - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
DirectAllocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
DirectAllocator() - Constructor for class org.apache.lucene.util.IntBlockPool.DirectAllocator
Creates a new IntBlockPool.DirectAllocator with a default block size
DirectBytesStartArray(int, Counter) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
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 where this segment is read from.
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
 
DirectoryReader - Class in org.apache.lucene.index
DirectoryReader is an implementation of CompositeReader that can read indexes in a Directory.
DirectoryReader(Directory, LeafReader[]) - Constructor for class org.apache.lucene.index.DirectoryReader
Expert: Constructs a DirectoryReader on the given subReaders.
DirectReader - Class in org.apache.lucene.util.packed
Retrieves an instance previously written by DirectWriter
DirectReader() - Constructor for class org.apache.lucene.util.packed.DirectReader
 
DirectTrackingAllocator(Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
DirectTrackingAllocator(int, Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
DirectWriter - Class in org.apache.lucene.util.packed
Class for writing packed integers to be directly read from Directory.
DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriterConfig
Denotes a flush trigger is disabled.
disableAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Turn off auto IO throttling.
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.
DisiPriorityQueue<Iter extends DocIdSetIterator> - Class in org.apache.lucene.search
A priority queue of DocIdSetIterators that orders by current doc ID.
DisiPriorityQueue(int) - Constructor for class org.apache.lucene.search.DisiPriorityQueue
 
DisiWrapper<Iter extends DocIdSetIterator> - Class in org.apache.lucene.search
Wrapper used in DisiPriorityQueue.
DisiWrapper(Iter) - Constructor for class org.apache.lucene.search.DisiWrapper
 
DISJUNCTION_MAX_REWRITE - Static variable in class org.apache.lucene.search.BlendedTermQuery
BlendedTermQuery.DisjunctionMaxRewrite instance with a tie-breaker of 0.01.
DisjunctionDISIApproximation<Iter extends DocIdSetIterator> - Class in org.apache.lucene.search
A DocIdSetIterator which is a disjunction of the approximations of the provided iterators.
DisjunctionDISIApproximation(DisiPriorityQueue<Iter>) - Constructor for class org.apache.lucene.search.DisjunctionDISIApproximation
 
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.
DisjunctionMaxRewrite(float) - Constructor for class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
This BlendedTermQuery.RewriteMethod will create DisjunctionMaxQuery instances that have the provided tie breaker.
DisjunctionMaxWeight(IndexSearcher, boolean) - 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.
doc - Variable in class org.apache.lucene.search.DisiWrapper
 
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 - Variable in class org.apache.lucene.search.spans.TermSpans
 
DOC_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
Filename extension for document number, frequencies, and skip data.
doCache(Filter, FilterCachingPolicy) - Method in interface org.apache.lucene.search.FilterCache
Deprecated.
Return a wrapper around the provided filter that will cache DocIdSets per-segment accordingly to the given policy.
doCache(Filter, FilterCachingPolicy) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
 
doCache(Weight, QueryCachingPolicy) - Method in class org.apache.lucene.search.LRUQueryCache
 
doCache(Weight, QueryCachingPolicy) - Method in interface org.apache.lucene.search.QueryCache
Return a wrapper around the provided weight that will cache matching docs per-segment accordingly to the given policy.
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.LeafReaderContext
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
DocComparator(int) - Constructor for class org.apache.lucene.search.FieldComparator.DocComparator
Creates a new comparator based on document ids for numHits
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.BaseCompositeReader
 
docFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
docFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
docFreq(Term) - Method in class org.apache.lucene.index.IndexReader
Returns the number of documents containing the term.
docFreq(Term) - Method in class org.apache.lucene.index.LeafReader
 
docFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
 
docFreq() - Method in class org.apache.lucene.index.TermContext
Returns the accumulated document frequency of all TermState instances passed to TermContext.register(TermState, int, int, long).
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.index.FilterLeafReader.FilterPostingsEnum
 
docID() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
docID() - Method in class org.apache.lucene.search.ConjunctionDISI
 
docID() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
docID() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
docID() - Method in class org.apache.lucene.search.DocIdSetIterator
Returns the following: -1 if DocIdSetIterator.nextDoc() or DocIdSetIterator.advance(int) were not called yet.
docID() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
docID() - Method in class org.apache.lucene.search.FilterScorer
 
docID() - Method in class org.apache.lucene.search.spans.FilterSpans
 
docID() - Method in class org.apache.lucene.search.spans.SpanScorer
 
docID() - Method in class org.apache.lucene.search.spans.TermSpans
 
docID() - Method in class org.apache.lucene.util.BitSetIterator
 
DocIdSet - Class in org.apache.lucene.search
A DocIdSet contains a set of doc ids.
DocIdSet() - Constructor for class org.apache.lucene.search.DocIdSet
 
DocIdSetBuilder - Class in org.apache.lucene.util
A builder of DocIdSets.
DocIdSetBuilder(int) - Constructor for class org.apache.lucene.util.DocIdSetBuilder
Create a builder that can contain doc IDs between 0 and maxDoc.
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, LeafReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
Provide the DocIdSet to be cached, using the DocIdSet provided by the wrapped Filter.
docIdSetToCache(DocIdSet, LeafReader) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Provide the DocIdSet to be cached, using the DocIdSet provided by the wrapped Filter.
doClose() - Method in class org.apache.lucene.index.CodecReader
 
doClose() - Method in class org.apache.lucene.index.FilterDirectoryReader
 
doClose() - Method in class org.apache.lucene.index.FilterLeafReader
 
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.ParallelCompositeReader
 
doClose() - Method in class org.apache.lucene.index.ParallelLeafReader
 
doClose() - Method in class org.apache.lucene.index.SegmentReader
 
doClose() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
DocMap() - Constructor for class org.apache.lucene.index.MergePolicy.DocMap
Sole constructor, typically invoked from sub-classes constructors.
docMaps - Variable in class org.apache.lucene.index.MergeState
Maps docIDs around deletions.
docs(Bits, DocsEnum) - Method in class org.apache.lucene.index.TermsEnum
Deprecated.
docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
Deprecated.
docsAndPositions(Bits, DocsAndPositionsEnum) - Method in class org.apache.lucene.index.TermsEnum
Deprecated.
docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
Deprecated.
DocsAndPositionsEnum - Class in org.apache.lucene.index
Deprecated.
Use PostingsEnum instead.
DocsAndPositionsEnum() - Constructor for class org.apache.lucene.index.DocsAndPositionsEnum
Deprecated.
Sole constructor.
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
similarity used in default score impl
DocsEnum - Class in org.apache.lucene.index
Deprecated.
Use PostingsEnum instead.
DocsEnum() - Constructor for class org.apache.lucene.index.DocsEnum
Deprecated.
Sole constructor.
docStarts - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
docbase for each leaf: parallel with MultiDocValues.MultiSortedDocValues.values
docStarts - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
docbase for each leaf: parallel with MultiDocValues.MultiSortedSetDocValues.values
docsWithField - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
 
docsWithValue(SortedDocValues, int) - Static method in class org.apache.lucene.index.DocValues
Returns a Bits representing all documents from dv that have a value.
docsWithValue(SortedSetDocValues, int) - Static method in class org.apache.lucene.index.DocValues
Returns a Bits representing all documents from dv that have a value.
docsWithValue(SortedNumericDocValues, int) - Static method in class org.apache.lucene.index.DocValues
Returns a Bits representing all documents from dv that have a value.
DocTermOrdsRewriteMethod - Class in org.apache.lucene.search
Deprecated.
DocTermOrdsRewriteMethod() - Constructor for class org.apache.lucene.search.DocTermOrdsRewriteMethod
Deprecated.
 
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.CodecReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.FilterLeafReader
 
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 nth Document in this index.
document(int, Set<String>) - Method in class org.apache.lucene.index.IndexReader
Like IndexReader.document(int) but only loads the specified fields.
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.ParallelLeafReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
DocumentStoredFieldVisitor - Class in org.apache.lucene.document
A StoredFieldVisitor that creates a Document containing all stored fields, or only specific requested fields provided to DocumentStoredFieldVisitor.DocumentStoredFieldVisitor(Set).
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.
doCurrentSpans() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
Deprecated.
 
doCurrentSpans() - Method in class org.apache.lucene.search.spans.SpanScorer
Called each time the scorer's Spans is advanced during frequency calculation
DocValues - Class in org.apache.lucene.index
This class contains utility methods and constants for DocValues
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.
DocValuesDocIdSet - Class in org.apache.lucene.search
Base class for DocIdSet to be used with DocValues.
DocValuesDocIdSet(int, Bits) - Constructor for class org.apache.lucene.search.DocValuesDocIdSet
 
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.lucene53.Lucene53Codec
 
DocValuesProducer - Class in org.apache.lucene.codecs
Abstract API that produces numeric, binary, sorted, sortedset, and sortednumeric docvalues.
DocValuesProducer() - Constructor for class org.apache.lucene.codecs.DocValuesProducer
Sole constructor.
docValuesProducers - Variable in class org.apache.lucene.index.MergeState
DocValues producers being merged
DocValuesRewriteMethod - Class in org.apache.lucene.search
Rewrites MultiTermQueries into a filter, using DocValues for term enumeration.
DocValuesRewriteMethod() - Constructor for class org.apache.lucene.search.DocValuesRewriteMethod
 
docValuesStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of DocValues (null if DocValues could not be tested).
docValuesType() - Method in class org.apache.lucene.document.FieldType
DocValues DocValuesType: how the field's value will be indexed into docValues.
DocValuesType - Enum in org.apache.lucene.index
DocValues types.
docValuesType() - Method in interface org.apache.lucene.index.IndexableFieldType
DocValues DocValuesType: how the field's value will be indexed into docValues.
doMerge(IndexWriter, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
doOpenIfChanged() - Method in class org.apache.lucene.index.DirectoryReader
Implement this method to support DirectoryReader.openIfChanged(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.
doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.NumericComparator
 
doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleCollector
This method is called before collecting context.
doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleFieldComparator
This method is called before collecting context.
doStall() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Called from ConcurrentMergeScheduler.maybeStall(org.apache.lucene.index.IndexWriter) to pause the calling thread for a bit.
doStartCurrentDoc() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
Deprecated.
 
doStartCurrentDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
Called before the current doc's frequency is calculated
DoubleComparator(int, String, Double) - Constructor for class org.apache.lucene.search.FieldComparator.DoubleComparator
Creates a new comparator based on Double.compare(double, double) for numHits.
DoubleDocValuesField - Class in org.apache.lucene.document
Syntactic sugar for encoding doubles as NumericDocValues via Double.doubleToRawLongBits(double).
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.codecs.StoredFieldsWriter.MergeVisitor
 
doubleField(FieldInfo, double) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
DoubleField - Class in org.apache.lucene.document
Field that indexes double values for efficient range filtering and sorting.
DoubleField(String, double, Field.Store) - Constructor for class org.apache.lucene.document.DoubleField
Creates a stored or un-stored DoubleField with the provided value and default precisionStep NumericUtils.PRECISION_STEP_DEFAULT (16).
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 double value to a sortable signed long.
doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.ExitableDirectoryReader
 
doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.FilterDirectoryReader
Called by the doOpenIfChanged() methods to return a new wrapped DirectoryReader.
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
 

E

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.
EMPTY - Static variable in class org.apache.lucene.codecs.PostingsFormat
Zero-length PostingsFormat array.
EMPTY - Static variable in class org.apache.lucene.index.TermsEnum
An empty TermsEnum for quickly returning an empty instance e.g.
EMPTY - Static variable in class org.apache.lucene.search.DocIdSet
An empty DocIdSet instance
empty() - Static method in class org.apache.lucene.search.DocIdSetIterator
An empty DocIdSetIterator instance
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 Fields array.
EMPTY_ARRAY - Static variable in class org.apache.lucene.index.ReaderSlice
Zero-length ReaderSlice array.
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_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_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.
emptyBinary() - Static method in class org.apache.lucene.index.DocValues
An empty BinaryDocValues which returns BytesRef.EMPTY_BYTES for every document
emptyNumeric() - Static method in class org.apache.lucene.index.DocValues
An empty NumericDocValues which returns zero for every document
emptySorted() - Static method in class org.apache.lucene.index.DocValues
An empty SortedDocValues which returns BytesRef.EMPTY_BYTES for every document
emptySortedNumeric(int) - Static method in class org.apache.lucene.index.DocValues
An empty SortedNumericDocValues which returns zero values for every document
emptySortedSet() - Static method in class org.apache.lucene.index.DocValues
An empty SortedDocValues which returns SortedSetDocValues.NO_MORE_ORDS for every document
emptyVal - Variable in class org.apache.lucene.util.SentinelIntSet
 
enableAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Turn on dynamic IO throttling, to adaptively rate limit writes bytes/sec to the minimal rate necessary so merges do not fall behind.
encode(long[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
Read iterations * valueCount() values from values, encode them and write iterations * blockCount() blocks into blocks.
encode(long[], int, byte[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
Read iterations * valueCount() values from values, encode them and write 8 * iterations * blockCount() blocks into blocks.
encode(int[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
Read iterations * valueCount() values from values, encode them and write iterations * blockCount() blocks into blocks.
encode(int[], int, byte[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
Read iterations * valueCount() values from values, encode them and write 8 * iterations * blockCount() blocks into blocks.
encodeNormValue(float, int) - Method in class org.apache.lucene.search.similarities.BM25Similarity
The default implementation encodes boost / sqrt(length) with SmallFloat.floatToByte315(float).
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.lucene50.Lucene50PostingsWriter
 
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 - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
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 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.analysis.tokenattributes.PackedTokenAttributeImpl
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.index.DocsAndPositionsEnum
Deprecated.
Returns end offset for the current position, or -1 if offsets were not indexed.
endOffset() - Method in class org.apache.lucene.index.DocsEnum
Deprecated.
 
endOffset() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
endOffset() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
endOffset() - Method in class org.apache.lucene.index.PostingsEnum
Returns end offset for the current position, or -1 if offsets were not indexed.
endOfSlice() - Method in class org.apache.lucene.util.IntBlockPool.SliceReader
Returns true iff the current slice is fully read.
endPosition() - Method in class org.apache.lucene.search.spans.FilterSpans
 
endPosition() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
endPosition() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
endPosition() - Method in class org.apache.lucene.search.spans.Spans
Returns the end position for the current start position, or -1 when Spans.nextStartPosition() was not yet called on the current doc.
endPosition() - Method in class org.apache.lucene.search.spans.TermSpans
 
endsWith(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns true iff 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+1, 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+1, returns the given bits, otherwise returns a new LongBitSet which can hold the requested number of bits.
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
 
ensureValid() - Method in class org.apache.lucene.store.Lock
Best effort check that this lock is still valid.
Entry(int, int, float) - Constructor for class org.apache.lucene.search.FieldValueHitQueue.Entry
 
eof() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
equals(Object) - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.Token
Deprecated.
 
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.PackedTokenAttributeImpl
 
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.document.FieldType
 
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.PrefixCodedTerms
 
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.BlendedTermQuery.DisjunctionMaxRewrite
 
equals(Object) - Method in class org.apache.lucene.search.BlendedTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.BooleanClause
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.BooleanQuery
 
equals(Object) - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
 
equals(Object) - Method in class org.apache.lucene.search.CachingWrapperQuery
 
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.DocTermOrdsRewriteMethod
Deprecated.
 
equals(Object) - Method in class org.apache.lucene.search.DocValuesRewriteMethod
 
equals(Object) - Method in class org.apache.lucene.search.FieldValueFilter
Deprecated.
 
equals(Object) - Method in class org.apache.lucene.search.FieldValueQuery
 
equals(Object) - Method in class org.apache.lucene.search.FilteredQuery
Deprecated.
Returns true iff o is 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.MultiPhraseQuery
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.MultiTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
 
equals(Object) - Method in class org.apache.lucene.search.NGramPhraseQuery
 
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
Deprecated.
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadScoreQuery
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
Deprecated.
 
equals(Object) - Method in class org.apache.lucene.search.payloads.SpanNearPayloadCheckQuery
Deprecated.
 
equals(Object) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
equals(Object) - Method in class org.apache.lucene.search.PhraseQuery
Returns true iff o is 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 o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.SortedNumericSortField
 
equals(Object) - Method in class org.apache.lucene.search.SortedSetSortField
 
equals(Object) - Method in class org.apache.lucene.search.SortField
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
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.SpanNearQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.spans.SpanNotQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
Returns true iff o is equal to this.
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 o is 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(Object) - Method in class org.apache.lucene.store.RAMFile
 
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.AttributeFactory.StaticImplementationAttributeFactory
 
equals(Object) - Method in class org.apache.lucene.util.AttributeSource
 
equals(Object) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
 
equals(Object) - Method in class org.apache.lucene.util.automaton.RunAutomaton
 
equals(Object) - Method in class org.apache.lucene.util.automaton.StatePair
Checks for equality.
equals(Object) - Method in class org.apache.lucene.util.BytesRef
 
equals(Object) - Method in class org.apache.lucene.util.BytesRefBuilder
 
equals(Object) - Method in class org.apache.lucene.util.CharsRef
 
equals(Object) - Method in class org.apache.lucene.util.CharsRefBuilder
 
equals(Object) - Method in class org.apache.lucene.util.FixedBitSet
 
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.IntsRefBuilder
 
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(String, String) - Static method in class org.apache.lucene.util.StringHelper
 
equals(Object) - Method in class org.apache.lucene.util.Version
 
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.FieldInfoStatus
Exception thrown during term index 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.LiveDocStatus
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
 
execute(TwoPhaseCommit...) - Static method in class org.apache.lucene.index.TwoPhaseCommitTool
Executes a 2-phase commit algorithm by first TwoPhaseCommit.prepareCommit() all objects and only if all succeed, it proceeds with TwoPhaseCommit.commit().
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?
ExitableDirectoryReader - Class in org.apache.lucene.index
The ExitableDirectoryReader wraps a real index DirectoryReader and allows for a QueryTimeout implementation object to be checked periodically to see if the thread should exit or not.
ExitableDirectoryReader(DirectoryReader, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader
Constructor
ExitableDirectoryReader.ExitableFields - Class in org.apache.lucene.index
Wrapper class for another Fields implementation that is used by the ExitableFilterAtomicReader.
ExitableDirectoryReader.ExitableFilterAtomicReader - Class in org.apache.lucene.index
Wrapper class for another FilterAtomicReader.
ExitableDirectoryReader.ExitableSubReaderWrapper - Class in org.apache.lucene.index
Wrapper class for a SubReaderWrapper that is used by the ExitableDirectoryReader.
ExitableDirectoryReader.ExitableTerms - Class in org.apache.lucene.index
Wrapper class for another Terms implementation that is used by ExitableFields.
ExitableDirectoryReader.ExitableTermsEnum - Class in org.apache.lucene.index
Wrapper class for TermsEnum that is used by ExitableTerms for implementing an exitable enumeration of terms.
ExitableDirectoryReader.ExitingReaderException - Exception in org.apache.lucene.index
Exception that is thrown to prematurely terminate a term enumeration.
ExitableFields(Fields, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableFields
Constructor
ExitableFilterAtomicReader(LeafReader, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
Constructor
ExitableSubReaderWrapper(QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableSubReaderWrapper
Constructor
ExitableTerms(Terms, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
Constructor
ExitableTermsEnum(TermsEnum, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableTermsEnum
Constructor
exorciseIndex(CheckIndex.Status) - Method in class org.apache.lucene.index.CheckIndex
Repairs the index using previously returned result from CheckIndex.checkIndex().
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.ConstantScoreWeight
 
explain(LeafReaderContext, 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 doc scored against query.
explain(Weight, int) - Method in class org.apache.lucene.search.IndexSearcher
Expert: low-level implementation method Returns an Explanation that describes how doc scored against weight.
explain(int, String, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
 
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
Deprecated.
 
explain(IndexSearcher, Explanation, int) - Method in class org.apache.lucene.search.QueryRescorer
 
explain(IndexSearcher, Explanation, int) - Method in class org.apache.lucene.search.Rescorer
Explains how the score for the specified document was computed.
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(List<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(List<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(List<Explanation>, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
 
explain(List<Explanation>, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
 
explain(List<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(List<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(IndexSearcher, Explanation, int) - Method in class org.apache.lucene.search.SortRescorer
 
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.spans.SpanWeight
 
explain(LeafReaderContext, 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.
extractTermContexts(Map<Term, TermContext>) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
 
extractTermContexts(Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanNearQuery.SpanNearWeight
 
extractTermContexts(Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanNotQuery.SpanNotWeight
 
extractTermContexts(Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanOrQuery.SpanOrWeight
 
extractTermContexts(Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.SpanPositionCheckWeight
 
extractTermContexts(Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanTermQuery.SpanTermWeight
 
extractTermContexts(Map<Term, TermContext>) - Method in class org.apache.lucene.search.spans.SpanWeight
Collect all TermContexts used by this Weight
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.ConstantScoreWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNearQuery.SpanNearWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNotQuery.SpanNotWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanOrQuery.SpanOrWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.SpanPositionCheckWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanTermQuery.SpanTermWeight
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.Weight
Expert: adds all terms occurring in this query to the terms set.

F

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.
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.
featureRequested(int, short) - Static method in class org.apache.lucene.index.PostingsEnum
Returns true if the given feature is requested in the flags, false otherwise.
field - Variable in class org.apache.lucene.codecs.blocktree.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
Deprecated.
Use StringField, TextField instead.
Field(String, String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Use StringField, TextField instead.
Field(String, Reader) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Use TextField instead.
Field(String, Reader, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Use TextField instead.
Field(String, TokenStream) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Use TextField instead
Field(String, TokenStream, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Use TextField instead
Field(String, byte[]) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Use StoredField instead.
Field(String, byte[], int, int) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Use StoredField instead.
field() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
 
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
Deprecated.
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 - Variable in class org.apache.lucene.search.spans.SpanWeight
 
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).
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.DocComparator - Class in org.apache.lucene.search
Sorts by ascending docID
FieldComparator.DoubleComparator - Class in org.apache.lucene.search
Parses field's values as double (using LeafReader.getNumericDocValues(java.lang.String) and sorts by ascending value
FieldComparator.FloatComparator - Class in org.apache.lucene.search
Parses field's values as float (using LeafReader.getNumericDocValues(String) and sorts by ascending value
FieldComparator.IntComparator - Class in org.apache.lucene.search
Parses field's values as int (using LeafReader.getNumericDocValues(String) and sorts by ascending value
FieldComparator.LongComparator - Class in org.apache.lucene.search
Parses field's values as long (using LeafReader.getNumericDocValues(String) and sorts by ascending value
FieldComparator.NumericComparator<T extends Number> - Class in org.apache.lucene.search
Base FieldComparator class for numeric types
FieldComparator.RelevanceComparator - Class in org.apache.lucene.search
Sorts by descending relevance.
FieldComparator.TermOrdValComparator - Class in org.apache.lucene.search
Sorts by field's natural Term sort order, using ordinals.
FieldComparator.TermValComparator - Class in org.apache.lucene.search
Sorts by field's natural Term sort order.
FieldComparatorSource - Class in org.apache.lucene.search
Provides a FieldComparator for custom field sorting.
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 - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
FieldInfo of current field being written.
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, int, boolean, boolean, boolean, IndexOptions, DocValuesType, long, 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.
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 being merged
fieldInfos - Variable in class org.apache.lucene.index.SegmentReadState
FieldInfos describing all fields in this segment.
fieldInfos - Variable in class org.apache.lucene.index.SegmentWriteState
FieldInfos describing all fields in this segment.
fieldInfosFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes field infos file
FieldInfosFormat - Class in org.apache.lucene.codecs
Encodes/decodes FieldInfos
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.lucene53.Lucene53Codec
 
fieldInfoStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of field infos
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
Deprecated.
 
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).
FieldReader - Class in org.apache.lucene.codecs.blocktree
BlockTree's implementation of Terms.
fields() - Method in class org.apache.lucene.index.CodecReader
 
fields() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
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.FilterLeafReader
 
fields() - Method in class org.apache.lucene.index.LeafReader
Returns Fields for this reader.
fields() - Method in class org.apache.lucene.index.ParallelLeafReader
 
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.compressing.CompressingStoredFieldsWriter
Extension of stored fields file
FIELDS_INDEX_EXTENSION - Static variable in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
Extension of stored fields index file
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.DocValuesFormat
Returns a DocValuesConsumer to write docvalues to the index.
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.lucene50.Lucene50DocValuesFormat
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
 
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
Returns a DocValuesProducer to read docvalues from the index.
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.lucene50.Lucene50DocValuesFormat
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
 
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.
fieldsProducers - Variable in class org.apache.lucene.index.MergeState
Postings to merge
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.lucene50.Lucene50StoredFieldsFormat
 
fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
Returns a StoredFieldsReader to load stored fields.
fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
 
fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
 
fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
Returns a StoredFieldsWriter to write stored fields.
fieldType() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
fieldType() - Method in class org.apache.lucene.document.Field
Returns the FieldType for this 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
IndexableFieldType describing the properties of this field.
FieldType.NumericType - Enum in org.apache.lucene.document
Data type of the numeric value
FieldValueFilter - Class in org.apache.lucene.search
Deprecated.
Use FieldValueQuery instead
FieldValueFilter(String) - Constructor for class org.apache.lucene.search.FieldValueFilter
Deprecated.
Creates a new FieldValueFilter
FieldValueFilter(String, boolean) - Constructor for class org.apache.lucene.search.FieldValueFilter
Deprecated.
Creates a new 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
Extension of ScoreDoc to also store the FieldComparator slot.
FieldValueQuery - Class in org.apache.lucene.search
A Query that matches documents that have a value for a given field as reported by LeafReader.getDocsWithField(String).
FieldValueQuery(String) - Constructor for class org.apache.lucene.search.FieldValueQuery
Create a query that will match that have a value for the given field.
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
 
fileNameExists(String) - Method 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
Records all files in use by this SegmentCommitInfo into the files argument.
files(SegmentCommitInfo, Collection<String>) - Method in class org.apache.lucene.codecs.lucene50.Lucene50LiveDocsFormat
 
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
Deprecated.
files(boolean) - Method in class org.apache.lucene.index.SegmentInfos
Returns all file names referenced by SegmentInfo.
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) to toIndex (exclusive) with val.
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 BasicStats in stats.
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 - Class in org.apache.lucene.search
Convenient base class for building queries that only perform matching, but no scoring.
Filter() - Constructor for class org.apache.lucene.search.Filter
 
FilterCache - Interface in org.apache.lucene.search
Deprecated.
Use QueryCache instead
FilterCachingPolicy - Interface in org.apache.lucene.search
Deprecated.
Use QueryCachingPolicy instead
FilterCachingPolicy.CacheOnLargeSegments - Class in org.apache.lucene.search
Deprecated.
A simple policy that only caches on the largest segments of an index.
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.
FilterCodecReader - Class in org.apache.lucene.index
A FilterCodecReader contains another CodecReader, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterCodecReader(CodecReader) - Constructor for class org.apache.lucene.index.FilterCodecReader
Creates a new FilterCodecReader.
FilterCollector - Class in org.apache.lucene.search
Collector delegator.
FilterCollector(Collector) - Constructor for class org.apache.lucene.search.FilterCollector
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, 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.SubReaderWrapper - Class in org.apache.lucene.index
Factory class passed to FilterDirectoryReader constructor that allows subclasses to wrap the filtered DirectoryReader's subreaders.
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
Deprecated.
FilteredQuery will be removed in Lucene 6.0. It should be replaced with a BooleanQuery with one BooleanClause.Occur.MUST clause for the query and one BooleanClause.Occur.FILTER clause for the filter.
FilteredQuery(Query, Filter) - Constructor for class org.apache.lucene.search.FilteredQuery
Deprecated.
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
Deprecated.
Expert: Constructs a new query which applies a filter to the results of the original query.
FilteredQuery.FilterStrategy - Class in org.apache.lucene.search
Deprecated.
Abstract class that defines how the filter (DocIdSet) applied during document collection.
FilteredQuery.RandomAccessFilterStrategy - Class in org.apache.lucene.search
Deprecated.
A FilteredQuery.FilterStrategy that conditionally uses a random access filter if the given DocIdSet supports random access (returns a non-null value from DocIdSet.bits()) and FilteredQuery.RandomAccessFilterStrategy.useRandomAccess(Bits, long) returns true.
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.
FilterFields(Fields) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterFields
Creates a new FilterFields.
FilterIterator<T,InnerT extends T> - Class in org.apache.lucene.util
An Iterator implementation that filters elements with a boolean predicate.
FilterIterator(Iterator<InnerT>) - Constructor for class org.apache.lucene.util.FilterIterator
 
FilterLeafCollector - Class in org.apache.lucene.search
LeafCollector delegator.
FilterLeafCollector(LeafCollector) - Constructor for class org.apache.lucene.search.FilterLeafCollector
Sole constructor.
FilterLeafReader - Class in org.apache.lucene.index
A FilterLeafReader contains another LeafReader, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterLeafReader(LeafReader) - Constructor for class org.apache.lucene.index.FilterLeafReader
Construct a FilterLeafReader based on the specified base reader.
FilterLeafReader.FilterFields - Class in org.apache.lucene.index
Base class for filtering Fields implementations.
FilterLeafReader.FilterPostingsEnum - Class in org.apache.lucene.index
Base class for filtering PostingsEnum implementations.
FilterLeafReader.FilterTerms - Class in org.apache.lucene.index
Base class for filtering Terms implementations.
FilterLeafReader.FilterTermsEnum - Class in org.apache.lucene.index
Base class for filtering TermsEnum implementations.
FilterPostingsEnum(PostingsEnum) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
Create a new FilterPostingsEnum
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.
FilterScorer - Class in org.apache.lucene.search
A FilterScorer contains another Scorer, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterScorer(Scorer) - Constructor for class org.apache.lucene.search.FilterScorer
Create a new FilterScorer
FilterScorer(Scorer, Weight) - Constructor for class org.apache.lucene.search.FilterScorer
Create a new FilterScorer with a specific weight
FilterSpans - Class in org.apache.lucene.search.spans
A Spans implementation wrapping another spans instance, allowing to filter spans matches easily by implementing FilterSpans.accept(org.apache.lucene.search.spans.Spans)
FilterSpans(Spans) - Constructor for class org.apache.lucene.search.spans.FilterSpans
Wrap the given Spans.
FilterSpans.AcceptStatus - Enum in org.apache.lucene.search.spans
Status returned from FilterSpans.accept(Spans) that indicates whether a candidate match should be accepted, rejected, or rejected and move on to the next document.
FilterStrategy() - Constructor for class org.apache.lucene.search.FilteredQuery.FilterStrategy
Deprecated.
 
FilterTerms(Terms) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterTerms
Creates a new FilterTerms
FilterTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
Creates a new FilterTermsEnum
find(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Returns the id of the given BytesRef.
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, IndexWriter) - Method in class org.apache.lucene.index.LogMergePolicy
Finds merges necessary to force-merge all deletes from the index.
findForcedDeletesMerges(SegmentInfos, IndexWriter) - 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, IndexWriter) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedDeletesMerges(SegmentInfos, IndexWriter) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedDeletesMerges(SegmentInfos, IndexWriter) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, IndexWriter) - 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>, IndexWriter) - 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>, IndexWriter) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, IndexWriter) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, IndexWriter) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, IndexWriter) - Method in class org.apache.lucene.index.LogMergePolicy
Checks if any merges are now necessary and returns a MergePolicy.MergeSpecification if so.
findMerges(MergeTrigger, SegmentInfos, IndexWriter) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations are now necessary on the index.
findMerges(MergeTrigger, SegmentInfos, IndexWriter) - Method in class org.apache.lucene.index.NoMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, IndexWriter) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, IndexWriter) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
FindSegmentsFile(Directory) - Constructor for class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
Sole constructor.
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.StoredFieldsWriter
Called before StoredFieldsWriter.close(), passing in the number of documents that were written.
finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called before TermVectorsWriter.close(), passing in the number of documents that were written.
finish() - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
return finalized form
finish() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Compiles all added states and transitions into a new Automaton and returns it.
finish() - Method in class org.apache.lucene.util.fst.Builder
Returns final FST.
finish() - Method in class org.apache.lucene.util.packed.DirectWriter
finishes writing
finish() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
Perform end-of-stream operations.
finishDoc() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
finishDoc() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Called when we are done adding positions and 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.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.
finishState() - Method in class org.apache.lucene.util.automaton.Automaton
Finishes the current state; call this once you are done adding transitions for a state.
finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
Called when we are done adding docs to this term
finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Finishes the current term.
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.
FiniteStringsIterator - Class in org.apache.lucene.util.automaton
Iterates all accepted strings.
FiniteStringsIterator(Automaton) - Constructor for class org.apache.lucene.util.automaton.FiniteStringsIterator
Constructor.
FIRST_LEVEL_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
The first level size for new slices
FixedBitSet - Class in org.apache.lucene.util
BitSet of fixed length (numBits), backed by accessible (FixedBitSet.getBits()) long[], accessed with an int index, implementing Bits and DocIdSet.
FixedBitSet(int) - Constructor for class org.apache.lucene.util.FixedBitSet
Creates a new LongBitSet.
FixedBitSet(long[], int) - Constructor for class org.apache.lucene.util.FixedBitSet
Creates a new LongBitSet using the provided long[] array as backing store.
FLAG_FREQS - Static variable in class org.apache.lucene.index.DocsEnum
Deprecated.
Flag to pass to TermsEnum.docs(Bits,DocsEnum,int) if you require term frequencies in the returned enum.
FLAG_NONE - Static variable in class org.apache.lucene.index.DocsEnum
Deprecated.
Flag to pass to TermsEnum.docs(Bits,DocsEnum,int) if you don't require term frequencies in the returned enum.
FLAG_OFFSETS - Static variable in class org.apache.lucene.index.DocsAndPositionsEnum
Deprecated.
Flag to pass to TermsEnum.docsAndPositions(Bits,DocsAndPositionsEnum,int) if you require offsets in the returned enum.
FLAG_PAYLOADS - Static variable in class org.apache.lucene.index.DocsAndPositionsEnum
Deprecated.
Flag to pass to TermsEnum.docsAndPositions(Bits,DocsAndPositionsEnum,int) if you require payloads in the returned enum.
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
Default implementation of FlagsAttribute.
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(int) - Method in class org.apache.lucene.util.FixedBitSet
Flip the bit at the provided index.
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.LongBitSet
Flip the bit at the provided index.
flipFlop(long) - Static method in class org.apache.lucene.util.BitUtil
flip flops odd with even bits
FloatComparator(int, String, Float) - Constructor for class org.apache.lucene.search.FieldComparator.FloatComparator
Creates a new comparator based on Float.compare(float, float) for numHits.
FloatDocValuesField - Class in org.apache.lucene.document
Syntactic sugar for encoding floats as NumericDocValues via Float.floatToRawIntBits(float).
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.codecs.StoredFieldsWriter.MergeVisitor
 
floatField(FieldInfo, float) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
FloatField - Class in org.apache.lucene.document
Field that indexes float values for efficient range filtering and sorting.
FloatField(String, float, Field.Store) - Constructor for class org.apache.lucene.document.FloatField
Creates a stored or un-stored FloatField with the provided value and default precisionStep NumericUtils.PRECISION_STEP_DEFAULT_32 (8).
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 float value to a sortable signed int.
floor(BytesRef, BytesRefBuilder) - 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.blocktree.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.blocktree.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.RAMOutputStream
Forces any buffered output to be written.
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
Flush pending bits to the underlying DataOutput.
flushBuffer(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
Flushes the in-memory buffer to the given output, copying at most numBytes.
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
Creates a new FlushInfo instance from the values required for a FLUSH IOContext context.
flushInfo - Variable in class org.apache.lucene.store.IOContext
 
flushPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
FlushPolicy to control when segments are flushed.
FOOTER_MAGIC - Static variable in class org.apache.lucene.codecs.CodecUtil
Constant to identify the start of a codec footer.
footerLength() - Static method in class org.apache.lucene.codecs.CodecUtil
Computes the length of a codec footer.
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
Just like IndexWriter.forceMerge(int), except you can specify whether the call should block until all merging completes.
forceMergeDeletes(boolean) - Method in class org.apache.lucene.index.IndexWriter
Just like IndexWriter.forceMergeDeletes(), except you can specify whether the call should block until the operation completes.
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
 
FormatAndBits(PackedInts.Format, int) - Constructor for class org.apache.lucene.util.packed.PackedInts.FormatAndBits
 
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(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.index.FilterLeafReader.FilterPostingsEnum
 
freq() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
freq() - Method in class org.apache.lucene.index.PostingsEnum
Returns term frequency in the current document, or 1 if the field was indexed with IndexOptions.DOCS.
freq() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
freq() - Method in class org.apache.lucene.search.FilterScorer
 
freq() - Method in class org.apache.lucene.search.Scorer
Returns the freq of this Scorer on the current document
freq - Variable in class org.apache.lucene.search.spans.SpanScorer
accumulated sloppy freq (computed in setFreqCurrentDoc)
freq() - Method in class org.apache.lucene.search.spans.SpanScorer
 
freq - Variable in class org.apache.lucene.search.spans.TermSpans
 
FREQS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require term frequencies in the returned enum.
frequency(int) - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
Returns the frequency of the provided key in the ring buffer.
FrequencyTrackingRingBuffer - Class in org.apache.lucene.util
A ring buffer that tracks the frequency of the integers that it contains.
FrequencyTrackingRingBuffer(int, int) - Constructor for class org.apache.lucene.util.FrequencyTrackingRingBuffer
Create a new ring buffer that will contain at most maxSize items.
fromBits(int, int, int) - Static method in class org.apache.lucene.util.Version
Returns a new version based on raw numbers
FSDirectory - Class in org.apache.lucene.store
Base class for Directory implementations that store index files in the file system.
FSDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.FSDirectory
Create a new FSDirectory for the named location (ctor for subclasses).
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.BytesReader - Class in org.apache.lucene.util.fst
Reads bytes stored in an FST.
FST.INPUT_TYPE - Enum in org.apache.lucene.util.fst
Specifies allowed range of each int input label for this FST.
FSTPath(T, FST.Arc<T>, IntsRefBuilder) - Constructor for class org.apache.lucene.util.fst.Util.FSTPath
Sole constructor
FSTPath(T, FST.Arc<T>, IntsRefBuilder, float, CharSequence) - Constructor for class org.apache.lucene.util.fst.Util.FSTPath
 
fstRamBytesUsed() - Method in class org.apache.lucene.util.fst.Builder
 
fsync(String) - Method in class org.apache.lucene.store.FSDirectory
 
fsync(Path, boolean) - Static method in class org.apache.lucene.util.IOUtils
Ensure that any writes to the given file is written to the storage device that contains it.
function - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
Deprecated.
 
function - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery
Deprecated.
 
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 maxEdits to term.
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 reader which share a prefix of length prefixLength with term and 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)

G

GB - Static variable in class org.apache.lucene.util.OfflineSorter
Convenience constant for gigabytes
gcd(long, long) - Static method in class org.apache.lucene.util.MathUtil
Return the greatest common divisor of a and b, consistently with BigInteger.gcd(BigInteger).
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.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) - 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) - 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(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
Returns a Similarity for scoring a field.
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(BytesRefBuilder, int) - Method in class org.apache.lucene.util.BytesRefArray
Returns the n'th element of this BytesRefArray
get() - Method in class org.apache.lucene.util.BytesRefBuilder
Return a BytesRef that points to the internal content of this builder.
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.CharsRefBuilder
Return a CharsRef that points to the internal content of this builder.
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.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() - Method in class org.apache.lucene.util.IntsRefBuilder
Return a IntsRef that points to the internal content of this builder.
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(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 len longs starting from index into arr[off:off+len] and return the actual number of values that have been read.
get(long) - Method in class org.apache.lucene.util.packed.PackedLongValues
 
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
Returns the object set by SetOnce.set(Object).
get(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
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.
getAbort() - Method in class org.apache.lucene.index.MergeRateLimiter
Returns true if this merge was aborted.
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
 
getArcCount() - Method in class org.apache.lucene.util.fst.Builder
 
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
Get a codec attribute value, or null if it does not exist
getAttribute(Class<T>) - Method in class org.apache.lucene.util.AttributeSource
Returns the instance of the passed in Attribute contained in this AttributeSource
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.
getAttributes() - Method in class org.apache.lucene.index.SegmentInfo
Returns the internal codec attributes map.
getAttributeSource() - Method in class org.apache.lucene.index.FieldInvertState
Returns the AttributeSource from the TokenStream that provided the indexed tokens for this field.
getAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns true if auto IO throttling is currently enabled.
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.
getAutomaton() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Returns the automaton that caused this exception, if any.
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 b parameter
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
Returns BinaryDocValues for this field.
getBinary(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns BinaryDocValues for the field, or DocValues.emptyBinary() if it has none.
getBinaryDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns BinaryDocValues for this field, or null if no BinaryDocValues were indexed for this field.
getBinaryDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getBinaryDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
Retrieves the BinaryDocValues for the field in this segment
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)
getBits() - Method in class org.apache.lucene.util.FixedBitSet
Expert.
getBits() - Method in class org.apache.lucene.util.LongBitSet
Expert.
getBitsPerValue() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
 
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.CachingWrapperQuery
 
getBoost() - Method in class org.apache.lucene.search.NGramPhraseQuery
 
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.
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>, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Expert: like Util.getByOutput(FST, long) except reusing BytesReader, initial and scratch Arc, and result.
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
 
getBytesComparator() - Method in class org.apache.lucene.search.SortField
 
getBytesReader() - Method in class org.apache.lucene.util.fst.FST
Returns a FST.BytesReader for this FST, positioned at position 0.
getBytesRef() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
getBytesRef() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
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 c parameter.
getC() - Method in class org.apache.lucene.search.similarities.NormalizationH2
Returns the c parameter.
getCacheCount() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Return the total number of cache entries that have been generated and put in the cache.
getCacheCount() - Method in class org.apache.lucene.search.LRUQueryCache
Return the total number of cache entries that have been generated and put in the cache.
getCacheSize() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Return the total number of DocIdSets which are currently stored in the cache.
getCacheSize() - Method in class org.apache.lucene.search.LRUQueryCache
Return the total number of DocIdSets which are currently stored in the cache.
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.BufferedChecksumIndexInput
 
getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexInput
Returns the current checksum value
getChecksum() - Method in class org.apache.lucene.store.IndexOutput
Returns the current checksum of bytes written so far
getChecksum() - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
getChecksum() - Method in class org.apache.lucene.store.RAMOutputStream
 
getChecksum() - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
getChecksumsOnly() - Method in class org.apache.lucene.index.CheckIndex
getChildren() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
getChildren() - Method in class org.apache.lucene.search.Scorer
Returns child sub-scorers
getChildResources() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
 
getChildResources() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
getChildResources() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexReader
 
getChildResources() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
 
getChildResources() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
 
getChildResources() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
 
getChildResources() - Method in class org.apache.lucene.index.CodecReader
 
getChildResources() - Method in class org.apache.lucene.index.IndexWriter
 
getChildResources() - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
 
getChildResources() - Method in class org.apache.lucene.index.PrefixCodedTerms
 
getChildResources() - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
 
getChildResources() - Method in class org.apache.lucene.search.CachingWrapperQuery
 
getChildResources() - Method in class org.apache.lucene.search.DocIdSet
 
getChildResources() - Method in class org.apache.lucene.search.FilteredDocIdSet
 
getChildResources() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
 
getChildResources() - Method in class org.apache.lucene.search.LRUQueryCache
 
getChildResources() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
getChildResources() - Method in class org.apache.lucene.store.RAMDirectory
 
getChildResources() - Method in class org.apache.lucene.store.RAMFile
 
getChildResources() - Method in class org.apache.lucene.store.RAMOutputStream
 
getChildResources() - Method in interface org.apache.lucene.util.Accountable
Returns nested resources of this class.
getChildResources() - Method in class org.apache.lucene.util.automaton.Automaton
 
getChildResources() - Method in class org.apache.lucene.util.BitSet
 
getChildResources() - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
 
getChildResources() - Method in class org.apache.lucene.util.fst.FST
 
getChildResources() - Method in class org.apache.lucene.util.packed.BlockPackedReader
 
getChildResources() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
getChildResources() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
 
getChildResources() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
 
getChildResources() - Method in class org.apache.lucene.util.packed.PackedLongValues
 
getChildResources() - Method in class org.apache.lucene.util.PagedBytes
 
getChildResources() - Method in class org.apache.lucene.util.PagedBytes.Reader
 
getClauses() - Method in class org.apache.lucene.search.BooleanQuery
Deprecated.
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.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getCombinedCoreAndDeletesKey() - Method in class org.apache.lucene.index.IndexReader
Expert: Returns a key for this IndexReader that also includes deletions, so 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
Returns the commit user data map that was last committed, or the one that was set on IndexWriter.setCommitData(Map).
getCommitLuceneVersion() - Method in class org.apache.lucene.index.SegmentInfos
Returns which Lucene Version wrote this commit, or null if the version this index was written with did not directly record the version.
getCommitOnClose() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns true if IndexWriter.close() should first commit before closing.
getCommonPrefix(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
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.Operations
Returns the longest BytesRef that is a prefix of all accepted strings and visits each state at most once.
getCommonSuffixBytesRef(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns the longest BytesRef that is a suffix of all accepted strings.
getComparator(int, int) - Method in class org.apache.lucene.search.SortedNumericSortField
 
getComparator(int, int) - Method in class org.apache.lucene.search.SortedSetSortField
 
getComparator(int, int) - Method in class org.apache.lucene.search.SortField
Returns the FieldComparator to use for sorting.
getComparator() - Method in class org.apache.lucene.util.OfflineSorter
Returns the comparator in use to sort entries
getComparators() - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getComparators(LeafReaderContext) - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getComparatorSource() - Method in class org.apache.lucene.search.SortField
Returns the FieldComparatorSource used for custom sorting
getCompetitiveTerm() - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
This is the term or null of the term that triggered the boost change.
getCompetitiveTerm() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
getCompoundReader(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.CompoundFormat
Returns a Directory view (read-only) for the compound files in this segment
getCompoundReader(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50CompoundFormat
 
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.CompositeReader
 
getContext() - Method in class org.apache.lucene.index.IndexReader
Expert: Returns the root IndexReaderContext for this IndexReader's sub-reader tree.
getContext() - Method in class org.apache.lucene.index.LeafReader
 
getCoreCacheKey() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getCoreCacheKey() - Method in class org.apache.lucene.index.IndexReader
Expert: Returns a key for this IndexReader, so 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
 
getCurrentOffset() - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
Returns the offset of the currently written slice.
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.
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
Wrapping the given InputStream in a reader using a CharsetDecoder.
getDecodingReader(Class<?>, String, Charset) - Static method in class org.apache.lucene.util.IOUtils
Opens a Reader for the given resource using a CharsetDecoder.
getDefault() - Static method in class org.apache.lucene.codecs.Codec
expert: returns the default codec used for newly created IndexWriterConfigs.
getDefault() - Static method in class org.apache.lucene.store.FSLockFactory
Returns the default locking implementation for this platform.
getDefault() - Static method in class org.apache.lucene.util.InfoStream
The default InfoStream used by a newly instantiated classes.
getDefaultQueryCache() - Static method in class org.apache.lucene.search.IndexSearcher
Expert: Get the default QueryCache or null if the cache is disabled.
getDefaultQueryCachingPolicy() - Static method in class org.apache.lucene.search.IndexSearcher
Expert: Get the default QueryCachingPolicy.
getDefaultSimilarity() - Static method in class org.apache.lucene.search.IndexSearcher
Expert: returns a default Similarity instance.
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.index.FilterDirectoryReader
Returns the wrapped DirectoryReader.
getDelegate() - Method in class org.apache.lucene.index.FilterLeafReader
Returns the wrapped LeafReader.
getDelegate() - Method in class org.apache.lucene.search.FilteredDocIdSet
Return the wrapped DocIdSet.
getDelegate() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
Return the wrapped DocIdSetIterator.
getDelegate() - Method in class org.apache.lucene.store.FilterDirectory
Return the wrapped Directory.
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.
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
Returns the Directory for the index.
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.FSDirectory
 
getDirectReader(IndexInput) - Static method in class org.apache.lucene.util.packed.PackedInts
Construct a direct PackedInts.Reader from an IndexInput.
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.
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
Returns the id of the doc to which the last call of MultiLevelSkipListReader.skipTo(int) has skipped.
getDocCount() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
getDocCount(String) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getDocCount() - Method in class org.apache.lucene.index.FilterLeafReader.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(String) - Method in class org.apache.lucene.index.LeafReader
 
getDocCount() - Method in class org.apache.lucene.index.MultiTerms
 
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(LeafReaderContext, Bits) - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
 
getDocIdSet(LeafReaderContext, Bits) - Method in class org.apache.lucene.search.FieldValueFilter
Deprecated.
 
getDocIdSet(LeafReaderContext, Bits) - Method in class org.apache.lucene.search.Filter
Creates a DocIdSet enumerating the documents that should be permitted in search results.
getDocIdSet(LeafReaderContext, Bits) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
Returns a DocIdSet with documents that should be permitted in search results.
getDocIdSet(LeafReaderContext, 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.
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(String) - Method in class org.apache.lucene.index.CodecReader
 
getDocsWithField(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns Bits for the field, or Bits matching nothing if it has none.
getDocsWithField(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getDocsWithField(String) - Method in class org.apache.lucene.index.LeafReader
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(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.ParallelLeafReader
 
getDocsWithField(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getDocsWithField(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
Retrieves the set of documents that have a value in this segment
getDocsWithValue(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.NumericComparator
Retrieves a Bits instance representing documents that have a value in this segment.
getDocument() - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
Retrieve the visited document.
getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene53.Lucene53Codec
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.
getDocValuesGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the generation number of the DocValues file or -1 if there are no doc-values updates yet.
getDocValuesReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying DocValuesProducer
getDocValuesReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getDocValuesReader() - Method in class org.apache.lucene.index.SegmentReader
 
getDocValuesType() - Method in class org.apache.lucene.index.FieldInfo
Returns DocValuesType of the docValues; this is DocValuesType.NONE if the field has no docvalues.
getDocValuesUpdatesFiles() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the per-field DocValues updates files.
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.
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
 
getEvictionCount() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Return the number of cache entries that have been removed from the cache either in order to stay under the maximum configured size/ram usage, or because a segment has been closed.
getEvictionCount() - Method in class org.apache.lucene.search.LRUQueryCache
Return the number of cache entries that have been removed from the cache either in order to stay under the maximum configured size/ram usage, or because a segment has been closed.
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.index.IndexFileNames
Return the extension (anything after the first '.'), or null if there is no '.' in the file name.
getExtension(String) - Static method in class org.apache.lucene.store.FileSwitchDirectory
Utility method to return a file's extension.
getFailFast() - Method in class org.apache.lucene.index.CheckIndex
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.MultiTermQuery
Returns the field name for this query
getField() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
Returns the field name for this query
getField() - Method in class org.apache.lucene.search.payloads.PayloadScoreQuery
 
getField() - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
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
 
getFieldInfos() - Method in class org.apache.lucene.index.FilterCodecReader
 
getFieldInfos() - Method in class org.apache.lucene.index.FilterLeafReader
 
getFieldInfos() - Method in class org.apache.lucene.index.LeafReader
Get the FieldInfos describing all fields in this reader.
getFieldInfos() - Method in class org.apache.lucene.index.ParallelLeafReader
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
 
getFieldInfosFiles() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the FieldInfos file names.
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.
getFields(String) - Method in class org.apache.lucene.document.Document
Returns an array of IndexableFields with the given name.
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.CodecReader
Expert: retrieve thread-private StoredFieldsReader
getFieldsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
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.BufferedChecksumIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexInput
 
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.OutputStreamIndexOutput
 
getFilePointer() - Method in class org.apache.lucene.store.RAMInputStream
 
getFilePointer() - Method in class org.apache.lucene.store.RAMOutputStream
 
getFilePointer() - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
getFilter() - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
Gets the contained filter.
getFilter() - Method in class org.apache.lucene.search.FilteredQuery
Deprecated.
Returns this FilteredQuery's filter
getFilterStrategy() - Method in class org.apache.lucene.search.FilteredQuery
Deprecated.
Returns this FilteredQuery's FilteredQuery.FilterStrategy
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
Given global ordinal, returns the ordinal of the first segment which contains this ordinal (the corresponding to the segment return MultiDocValues.OrdinalMap.getFirstSegmentNumber(long)).
getFixedBitSetOrNull(DocIdSetIterator) - Static method in class org.apache.lucene.util.BitSetIterator
If the provided iterator wraps a FixedBitSet, returns it, otherwise returns null.
getFlags() - Method in class org.apache.lucene.analysis.Token
Deprecated.
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
 
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.
getForceMergeMBPerSec() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Get the per-merge IO throttle rate for forced merges.
getFormat() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
The format used to serialize values.
getFullSliceDescription(String) - Method in class org.apache.lucene.store.IndexInput
Subclasses call this to get the String for resourceDescription of a slice of this IndexInput.
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
getGlobalOrds(int) - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
Given a segment number, return a LongValues instance that maps segment ordinals to global ordinals.
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[].
getHitCount() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Over the total number of times that a filter has been looked up, return how many times a cached DocIdSet has been found and returned.
getHitCount() - Method in class org.apache.lucene.search.LRUQueryCache
Over the total number of times that a query has been looked up, return how many times a cached DocIdSet has been found and returned.
getId() - Method in class org.apache.lucene.index.SegmentInfo
Return the id that uniquely identifies this segment.
getId() - Method in class org.apache.lucene.index.SegmentInfos
Since Lucene 5.0, every commit (segments_N) writes a unique id.
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 baseClass in which this method is overridden/implemented in the inheritance path between baseClass and the given subclass subclazz.
getInclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
Return the SpanQuery whose matches are filtered.
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
Returns the IndexCommit as specified in IndexWriterConfig.setIndexCommit(IndexCommit) or the default, null which specifies to open the latest index commit point.
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 IndexOptions.NONE if the field is not indexed
getIndexReader() - Method in class org.apache.lucene.search.IndexSearcher
Return the IndexReader this searches.
getIndexWriter() - Method in class org.apache.lucene.index.TrackingIndexWriter
Return the wrapped IndexWriter.
getInfoStream() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getInfoStream() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns InfoStream used for debugging.
getInfoStream() - Static method in class org.apache.lucene.index.SegmentInfos
Returns infoStream.
getInitialState() - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns initial state.
getInputType() - Method in class org.apache.lucene.util.fst.FST
 
getInstance(RandomAccessInput, int) - Static method in class org.apache.lucene.util.packed.DirectReader
Retrieves an instance from the specified slice written decoding bitsPerValue for each value
getInstance(IndexOutput, long, int) - Static method in class org.apache.lucene.util.packed.DirectWriter
Returns an instance suitable for encoding numValues using bitsPerValue
getIntBlock() - Method in class org.apache.lucene.util.IntBlockPool.Allocator
 
getIntBlock() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
getIORateLimitMBPerSec() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns the currently set per-merge IO writes rate limit, if ConcurrentMergeScheduler.enableAutoIOThrottle() was called, else Double.POSITIVE_INFINITY.
getK1() - Method in class org.apache.lucene.search.similarities.BM25Similarity
Returns the k1 parameter
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.
getLeafCollector(LeafReaderContext) - Method in interface org.apache.lucene.search.Collector
Create a new collector to collect the given context.
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.FilterCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.MultiCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.TimeLimitingCollector
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator
Get a per-segment LeafFieldComparator to collect the given LeafReaderContext.
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleFieldComparator
 
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.FilterCodecReader
 
getLiveDocs() - Method in class org.apache.lucene.index.FilterLeafReader
 
getLiveDocs() - Method in class org.apache.lucene.index.LeafReader
Returns the Bits representing live (not deleted) docs.
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.ParallelLeafReader
 
getLiveDocs() - Method in class org.apache.lucene.index.SegmentReader
 
getLiveDocs() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getLowerTerm() - Method in class org.apache.lucene.search.TermRangeFilter
Deprecated.
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
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.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.
getMatchingDocs(LeafReaderContext) - Method in class org.apache.lucene.search.RandomAccessWeight
Return a Bits instance representing documents that match this weight on the given context.
getMax() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
getMax() - Method in class org.apache.lucene.index.MultiTerms
 
getMax() - Method in class org.apache.lucene.index.Terms
Returns the largest term (in lexicographic order) in the field.
getMax() - Method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
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
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.
getMaxDeterminizedStates() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Get the maximum number of allowed determinized states.
getMaxEdits() - Method in class org.apache.lucene.search.FuzzyQuery
 
getMaxInt(Terms) - Static method in class org.apache.lucene.util.NumericUtils
Returns the maximum int value indexed into this numeric field or null if no terms exist.
getMaxLong(Terms) - Static method in class org.apache.lucene.util.NumericUtils
Returns the maximum long value indexed into this numeric field or null if no terms exist.
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.TopTermsBlendedFreqScoringRewrite
 
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.
getMaxVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
Returns the maximum version accepted
getMaxVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns the maximum version accepted.
getMBPerSec() - Method in class org.apache.lucene.index.MergeRateLimiter
 
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
Returns the SegmentCommitInfo for the merged segment, or null if it hasn't been set yet.
getMergeInstance() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
 
getMergeInstance() - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.FieldsProducer
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.NormsProducer
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.StoredFieldsReader
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.TermVectorsReader
Returns an instance optimized for merging.
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
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.codecs.blocktree.FieldReader
 
getMin() - Method in class org.apache.lucene.index.MultiTerms
 
getMin() - Method in class org.apache.lucene.index.Terms
Returns the smallest term (in lexicographic order) in the field.
getMin() - Method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
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
getMinimumNumberShouldMatch() - Method in class org.apache.lucene.search.BooleanQuery
Gets the minimum number of the optional BooleanClauses which must be satisfied.
getMinInt(Terms) - Static method in class org.apache.lucene.util.NumericUtils
Returns the minimum int value indexed into this numeric field or null if no terms exist.
getMinLong(Terms) - Static method in class org.apache.lucene.util.NumericUtils
Returns the minimum long value indexed into this numeric field or null if no terms exist.
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.
getMinPauseCheckBytes() - Method in class org.apache.lucene.index.MergeRateLimiter
 
getMinPauseCheckBytes() - Method in class org.apache.lucene.store.RateLimiter
How many bytes caller should add up itself before invoking RateLimiter.pause(long).
getMinPauseCheckBytes() - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
 
getMinSegmentLuceneVersion() - Method in class org.apache.lucene.index.SegmentInfos
Returns the version of the oldest segment, or null if there are no segments.
getMinSimilarity() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
getMinVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
Returns the minimum version accepted
getMinVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns the minimum version accepted This method will return null if an alternative IndexFormatTooOldException.getReason() is provided.
getMissCount() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Over the total number of times that a filter has been looked up, return how many times this filter was not contained in the cache.
getMissCount() - Method in class org.apache.lucene.search.LRUQueryCache
Over the total number of times that a query has been looked up, return how many times this query was not contained in the cache.
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
Same as PackedInts.getMutable(int, int, float) with a pre-computed number of bits per value and format.
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 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.
getNextDocValuesGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the next available generation number of the DocValues files.
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
getNextTransition(Transition) - Method in class org.apache.lucene.util.automaton.Automaton
Iterate to the next transition after the provided one
getNoCFSRatio() - Method in class org.apache.lucene.index.MergePolicy
Returns current noCFSRatio.
getNodeCount() - Method in class org.apache.lucene.util.fst.Builder
 
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
getNorms(FieldInfo) - Method in class org.apache.lucene.codecs.NormsProducer
Returns NumericDocValues for this field.
getNormsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying NormsProducer
getNormsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getNormsReader() - Method in class org.apache.lucene.index.SegmentReader
 
getNormValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getNormValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getNormValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns NumericDocValues representing norms for this field, or null if no NumericDocValues were indexed.
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.ParallelLeafReader
 
getNormValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
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.
getNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns NumericDocValues for this field.
getNumeric(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns NumericDocValues for the field, or DocValues.emptyNumeric() if it has none.
getNumericDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getNumericDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getNumericDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns NumericDocValues for this field, or null if no NumericDocValues were indexed for this field.
getNumericDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getNumericDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getNumericDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.NumericComparator
Retrieves the NumericDocValues for the field in this segment
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.
getNumStates() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
How many states this automaton has.
getNumStates() - Method in class org.apache.lucene.util.automaton.Automaton
How many states this automaton has.
getNumSubs() - Method in class org.apache.lucene.index.MultiPostingsEnum
How many sub-readers we are merging.
getNumTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
How many transitions this automaton has.
getNumTransitions(int) - Method in class org.apache.lucene.util.automaton.Automaton
How many transitions this state has.
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
Just like Analyzer.getPositionIncrementGap(java.lang.String), except for Token offsets instead.
getOffsetGap(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
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.
getOriginalMessage() - Method in exception org.apache.lucene.index.CorruptIndexException
Returns the original exception message without the corrupted file description.
getOriginalString() - Method in class org.apache.lucene.util.automaton.RegExp
The string that was used to construct the regex.
getParallelReaders() - Method in class org.apache.lucene.index.ParallelLeafReader
Returns the LeafReaders that were passed on init.
getPayload() - Method in class org.apache.lucene.analysis.Token
Deprecated.
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.index.DocsAndPositionsEnum
Deprecated.
Returns the payload at this position, or null if no payload was indexed.
getPayload() - Method in class org.apache.lucene.index.DocsEnum
Deprecated.
 
getPayload() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
getPayload() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
getPayload() - Method in class org.apache.lucene.index.PostingsEnum
Returns the payload at this position, or null if no payload was indexed.
getPayloads() - Method in class org.apache.lucene.search.payloads.PayloadSpanCollector
 
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.tokenattributes.PackedTokenAttributeImpl
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.tokenattributes.PackedTokenAttributeImpl
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.NGramPhraseQuery
Return the list of relative positions that each term should appear at.
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.lucene53.Lucene53Codec
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.
getPostingsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying FieldsProducer
getPostingsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getPostingsReader() - Method in class org.apache.lucene.index.SegmentReader
 
getPrecisionStep() - Method in class org.apache.lucene.analysis.NumericTokenStream
Returns the precision step.
getPrecisionStep() - Method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
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
Deprecated.
 
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.
getPreload() - Method in class org.apache.lucene.store.MMapDirectory
Returns true if mapped pages should be loaded.
getPrimaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
Return the primary directory
getQuery() - Method in class org.apache.lucene.search.BooleanClause
 
getQuery() - Method in class org.apache.lucene.search.CachingWrapperQuery
Gets the contained query.
getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery
Returns the encapsulated query.
getQuery() - Method in class org.apache.lucene.search.FilteredQuery
Deprecated.
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.Weight
The query that this concerns.
getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getRAMBufferSizeMB() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the value set by LiveIndexWriterConfig.setRAMBufferSizeMB(double) if enabled.
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 DocumentsWriterPerThread can consume until forcefully flushed.
getRawValue() - Method in interface org.apache.lucene.analysis.NumericTokenStream.NumericTermAttribute
Returns current token's raw value as long with all NumericTokenStream.NumericTermAttribute.getShift() applied, undefined before first token
getRawValue() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
getReader(DataInput) - Static method in class org.apache.lucene.util.packed.PackedInts
Restore a PackedInts.Reader from a stream.
getReaderIterator(DataInput, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Retrieve PackedInts as a PackedInts.ReaderIterator
getReaderIteratorNoHeader(DataInput, PackedInts.Format, int, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Expert: Restore a PackedInts.ReaderIterator from a stream without reading metadata at the beginning of the stream.
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.
getReaderPooling() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getReaderPooling() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns true if IndexWriter should pool readers even if DirectoryReader.open(IndexWriter, boolean) has not been called.
getReason() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns an optional reason for this exception if the version information was not available.
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.
getRegExp() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Return the RegExp that caused this exception if any.
getRequiredPostings() - Method in enum org.apache.lucene.search.spans.SpanWeight.Postings
 
getResolution() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Return the timer resolution.
getResourceDescription() - Method in exception org.apache.lucene.index.CorruptIndexException
Returns a description of the file that was corrupted
getResourceDescription() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
Returns a description of the file that was too new
getResourceDescription() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns a description of the file that was too old
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
Returns the used Analyzer.ReuseStrategy.
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
getScaleFactor() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
getSearcher(SearcherFactory, IndexReader, IndexReader) - Static method in class org.apache.lucene.search.SearcherManager
Expert: creates a searcher from the provided IndexReader using the provided SearcherFactory.
getSecondaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
Return the secondary directory
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.
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.
getSelector() - Method in class org.apache.lucene.search.SortedNumericSortField
Returns the selector in use for this sort
getSelector() - Method in class org.apache.lucene.search.SortedSetSortField
Returns the selector in use for this sort
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 null, 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
 
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
Expert: returns the Similarity implementation used by this IndexWriter.
getSimilarity(boolean) - Method in class org.apache.lucene.search.IndexSearcher
Expert: Get the Similarity to use to compute scores.
getSimScorer(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanWeight
 
getSingleton(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
If this automaton accepts a single input, return it.
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.
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
Return the slop for this PhraseQuery.
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
Returns SortedDocValues for this field.
getSorted(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns SortedDocValues for the field, or DocValues.emptySorted() if it has none.
getSortedDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getSortedDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getSortedDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns SortedDocValues for this field, or null if no SortedDocValues were indexed for this field.
getSortedDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getSortedDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getSortedDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
Retrieves the SortedDocValues for the field in this segment
getSortedNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns SortedNumericDocValues for this field.
getSortedNumeric(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns SortedNumericDocValues for the field, or DocValues.emptySortedNumeric(int) if it has none.
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns SortedNumericDocValues for this field, or null if no SortedNumericDocValues were indexed for this field.
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getSortedNumericValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a SortedNumericDocValues for a reader's docvalues (potentially merging on-the-fly)
getSortedSet(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns SortedSetDocValues for this field.
getSortedSet(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns SortedSetDocValues for the field, or DocValues.emptySortedSet() if it has none.
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns SortedSetDocValues for this field, or null if no SortedSetDocValues were indexed for this field.
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
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
Sugar to get all transitions for all states.
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(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
 
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanContainingQuery.SpanContainingWeight
Return spans from big that contain at least one spans from little.
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanNearQuery.SpanNearWeight
 
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanNotQuery.SpanNotWeight
 
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanOrQuery.SpanOrWeight
 
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.SpanPositionCheckWeight
 
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanTermQuery.SpanTermWeight
 
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanWeight
Expert: Return a Spans object iterating over matches from this Weight
getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanWithinQuery.SpanWithinWeight
Return spans from little that are contained in a spans from big.
getSparseFixedBitSetOrNull(DocIdSetIterator) - Static method in class org.apache.lucene.util.BitSetIterator
If the provided iterator wraps a SparseFixedBitSet, returns it, otherwise returns null.
getStart() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
getStaticImplementation(AttributeFactory, Class<A>) - Static method in class org.apache.lucene.util.AttributeFactory
Returns an AttributeFactory returning an instance of the given clazz for the attributes it implements.
getStats() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
For debugging -- used by CheckIndex too
getStats() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
getStats() - Method in class org.apache.lucene.index.Terms
Expert: returns additional information about this Terms instance for debugging purposes.
getStoredValue(Analyzer) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Returns the currently stored value.
getStoreMergeInfo() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Return MergeInfo describing this merge.
getSubs() - Method in class org.apache.lucene.index.MultiPostingsEnum
Returns sub-readers we are merging.
getSubSlices() - Method in class org.apache.lucene.index.MultiTerms
Expert: returns pointers to the sub-readers corresponding to the Terms being merged.
getSubTerms() - Method in class org.apache.lucene.index.MultiTerms
Expert: returns the Terms being merged.
getSumDocFreq() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
getSumDocFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getSumDocFreq() - Method in class org.apache.lucene.index.FilterLeafReader.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(String) - Method in class org.apache.lucene.index.LeafReader
 
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.
getSumTotalTermFreq() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getSumTotalTermFreq() - Method in class org.apache.lucene.index.FilterLeafReader.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(String) - Method in class org.apache.lucene.index.LeafReader
 
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).
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.
getTermContexts(SpanWeight...) - Static method in class org.apache.lucene.search.spans.SpanQuery
Build a map of terms to termcontexts, for use in constructing SpanWeights
getTermContexts(Collection<SpanWeight>) - Static method in class org.apache.lucene.search.spans.SpanQuery
Build a map of terms to termcontexts, for use in constructing SpanWeights
getTermCount() - Method in class org.apache.lucene.util.fst.Builder
 
getTermDocsEnum(IndexReader, String, BytesRef) - Static method in class org.apache.lucene.index.MultiFields
Returns PostingsEnum for the specified field and term.
getTermDocsEnum(IndexReader, String, BytesRef, int) - Static method in class org.apache.lucene.index.MultiFields
Returns PostingsEnum for the specified field and term, with control over whether freqs are required.
getTermPositionsEnum(IndexReader, String, BytesRef) - Static method in class org.apache.lucene.index.MultiFields
Returns PostingsEnum for the specified field and term.
getTermPositionsEnum(IndexReader, String, BytesRef, int) - Static method in class org.apache.lucene.index.MultiFields
Returns PostingsEnum for the specified field and 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() - Method in class org.apache.lucene.search.NGramPhraseQuery
Return the list of terms.
getTerms() - Method in class org.apache.lucene.search.PhraseQuery
Returns the list 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) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
Return a TermsEnum intersecting the provided Terms with the terms accepted by this automaton.
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.CodecReader
 
getTermVectors(int) - Method in class org.apache.lucene.index.FilterLeafReader
 
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.ParallelLeafReader
 
getTermVectors(int) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getTermVectorsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve thread-private TermVectorsReader
getTermVectorsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
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).
getTimeoutAt() - Method in class org.apache.lucene.index.QueryTimeoutImpl
Returns time at which to time out, in nanoseconds relative to the (JVM-specific) epoch for System.nanoTime(), to compare with the value returned by nanoTime().
getTimestamp() - Method in class org.apache.lucene.util.PrintStreamInfoStream
Returns the current time as string for insertion into log messages.
getTokenizer() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Returns the component's Tokenizer
getTokenStream() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Returns the sink TokenStream
getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
 
getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
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.
getTopReaderContext() - Method in class org.apache.lucene.search.IndexSearcher
Returns this searchers the top-level IndexReaderContext.
getTotalBoost() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the total boost.
getTotalBytesWritten() - Method in class org.apache.lucene.index.MergeRateLimiter
Returns total bytes written by this merge.
getTotalCount() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Return the total number of times that a Filter has been looked up in this FilterCache.
getTotalCount() - Method in class org.apache.lucene.search.LRUQueryCache
Return the total number of times that a Query has been looked up in this QueryCache.
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.
getTotalPausedNS() - Method in class org.apache.lucene.index.MergeRateLimiter
Total NS merge was paused to rate limit IO.
getTotalStoppedNS() - Method in class org.apache.lucene.index.MergeRateLimiter
Total NS merge was stopped.
getTotalTermFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the total number of occurrences of this term across all documents.
getTragicException() - Method in class org.apache.lucene.index.IndexWriter
If this IndexWriter was closed as a side-effect of a tragic exception, e.g.
getTransition(int, int, Transition) - Method in class org.apache.lucene.util.automaton.Automaton
Fill the provided Transition with the index'th transition leaving the specified state.
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.
getUniqueTermCount() - Method in class org.apache.lucene.index.FieldInvertState
Return the number of unique terms encountered in this field.
getUpperTerm() - Method in class org.apache.lucene.search.TermRangeFilter
Deprecated.
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
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
Returns userData, previously passed to IndexWriter.setCommitData(Map) for this commit.
getUserData() - Method in class org.apache.lucene.index.SegmentInfos
Return userData saved 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.store.BufferedChecksum
 
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.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.ConstantScoreWeight
 
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 for double, long)
getValueSize() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
getVersion() - Method in class org.apache.lucene.analysis.Analyzer
Return the version of Lucene this analyzer will mimic the behavior of for analysis.
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 exception org.apache.lucene.index.IndexFormatTooNewException
Returns the version of the file that was too new
getVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns the version of the file that was too old.
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.
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
Deprecated.
Use SleepingLockWrapper if you want sleeping.
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
A predefined Analyzer.ReuseStrategy that reuses the same components for every field.
GOOD_FAST_HASH_SEED - Static variable in class org.apache.lucene.util.StringHelper
grow(T[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
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.BytesRefBuilder
Ensure that this builder can hold at least capacity bytes without resizing.
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.CharsRefBuilder
Used to grow the reference array.
grow(int) - Method in class org.apache.lucene.util.DocIdSetBuilder
Reserve space so that this builder can hold numDocs MORE documents.
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.IntsRefBuilder
Used to grow the reference array.
GrowableByteArrayDataOutput - Class in org.apache.lucene.util
A DataOutput that can be used to build a byte[].
GrowableByteArrayDataOutput(int) - Constructor for class org.apache.lucene.util.GrowableByteArrayDataOutput
Create a GrowableByteArrayDataOutput with the given initial capacity.
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
 

H

handleMergeException(Directory, Throwable) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Called when an exception is hit in a background merge thread
hasAttribute(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource
The caller must pass in a Class<? extends Attribute> value.
hasAttributes() - Method in class org.apache.lucene.util.AttributeSource
Returns true, iff this AttributeSource has any attributes
hasDeadStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if this automaton has any states that cannot be reached from the initial state or cannot reach an accept state.
hasDeadStatesFromInitial(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if there are dead states reachable from an initial state.
hasDeadStatesToAccept(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if there are dead states that reach an accept state.
hasDeletions - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if this segment has pending deletions.
hasDeletions() - Method in class org.apache.lucene.index.IndexReader
Returns true if any documents have been deleted.
hasDeletions() - Method in class org.apache.lucene.index.IndexWriter
Returns true if this index has deletions (including buffered deletions).
hasDeletions() - Method in class org.apache.lucene.index.MergeState.DocMap
Returns true if there are any deletions.
hasDeletions() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns true if there are any deletions for the segment at this commit.
hasDocValues() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have DocValues
hasFieldUpdates() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns true if there are any field updates for the segment in this commit.
hasFreq() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have freqs
hasFreqs() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
hasFreqs() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasFreqs() - Method in class org.apache.lucene.index.MultiTerms
 
hasFreqs() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store per-document term frequency (PostingsEnum.freq()).
hash(int) - Method in class org.apache.lucene.util.SentinelIntSet
(internal) Return the hash for the key.
hashCode() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.Token
Deprecated.
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
hashCode() - Method in class org.apache.lucene.document.FieldType
 
hashCode() - Method in class org.apache.lucene.index.IndexCommit
 
hashCode() - Method in class org.apache.lucene.index.IndexReader
hashCode() - Method in class org.apache.lucene.index.PrefixCodedTerms
 
hashCode() - Method in class org.apache.lucene.index.SegmentInfo
 
hashCode() - Method in class org.apache.lucene.index.Term
 
hashCode() - Method in class org.apache.lucene.search.AutomatonQuery
 
hashCode() - Method in class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
 
hashCode() - Method in class org.apache.lucene.search.BlendedTermQuery
 
hashCode() - Method in class org.apache.lucene.search.BooleanClause
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.BooleanQuery
 
hashCode() - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
 
hashCode() - Method in class org.apache.lucene.search.CachingWrapperQuery
 
hashCode() - Method in class org.apache.lucene.search.ConstantScoreQuery
 
hashCode() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Compute a hash code for hashing us
hashCode() - Method in class org.apache.lucene.search.DocTermOrdsRewriteMethod
Deprecated.
 
hashCode() - Method in class org.apache.lucene.search.DocValuesRewriteMethod
 
hashCode() - Method in class org.apache.lucene.search.FieldValueFilter
Deprecated.
 
hashCode() - Method in class org.apache.lucene.search.FieldValueQuery
 
hashCode() - Method in class org.apache.lucene.search.FilteredQuery
Deprecated.
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.FuzzyQuery
 
hashCode() - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
 
hashCode() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.MultiTermQuery
 
hashCode() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
 
hashCode() - Method in class org.apache.lucene.search.NGramPhraseQuery
 
hashCode() - Method in class org.apache.lucene.search.NumericRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.PayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
Deprecated.
 
hashCode() - Method in class org.apache.lucene.search.payloads.PayloadScoreQuery
 
hashCode() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
Deprecated.
 
hashCode() - Method in class org.apache.lucene.search.payloads.SpanNearPayloadCheckQuery
Deprecated.
 
hashCode() - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
hashCode() - Method in class org.apache.lucene.search.PhraseQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.PrefixQuery
 
hashCode() - Method in class org.apache.lucene.search.Query
 
hashCode() - Method in class org.apache.lucene.search.QueryWrapperFilter
 
hashCode() - Method in class org.apache.lucene.search.Sort
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.SortedNumericSortField
 
hashCode() - Method in class org.apache.lucene.search.SortedSetSortField
 
hashCode() - Method in class org.apache.lucene.search.SortField
Returns true if o is equal to this.
hashCode() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
hashCode() - Method in class org.apache.lucene.search.TermQuery
 
hashCode() - Method in class org.apache.lucene.search.TermRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.TopTermsRewrite
 
hashCode() - Method in class org.apache.lucene.store.FlushInfo
 
hashCode() - Method in class org.apache.lucene.store.IOContext
 
hashCode() - Method in class org.apache.lucene.store.MergeInfo
 
hashCode() - Method in class org.apache.lucene.store.RAMFile
 
hashCode(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns hash of chars in range start (inclusive) to end (inclusive)
hashCode(byte[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns hash of bytes in range start (inclusive) to end (inclusive)
hashCode() - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
 
hashCode() - Method in class org.apache.lucene.util.AttributeSource
 
hashCode() - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
 
hashCode() - Method in class org.apache.lucene.util.automaton.RunAutomaton
 
hashCode() - Method in class org.apache.lucene.util.automaton.StatePair
Returns hash code.
hashCode() - Method in class org.apache.lucene.util.BytesRef
Calculates the hash code as required by TermsHash during indexing.
hashCode() - Method in class org.apache.lucene.util.BytesRefBuilder
 
hashCode() - Method in class org.apache.lucene.util.CharsRef
 
hashCode() - Method in class org.apache.lucene.util.CharsRefBuilder
 
hashCode() - Method in class org.apache.lucene.util.FixedBitSet
 
hashCode() - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
 
hashCode() - Method in class org.apache.lucene.util.IntsRef
 
hashCode() - Method in class org.apache.lucene.util.IntsRefBuilder
 
hashCode() - Method in class org.apache.lucene.util.LongBitSet
 
hashCode() - Method in class org.apache.lucene.util.LongsRef
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValue
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
hashCode() - Method in class org.apache.lucene.util.Version
 
hasNext() - Method in class org.apache.lucene.util.FilterIterator
 
hasNext() - Method in class org.apache.lucene.util.MergedIterator
 
hasNext() - Method in class org.apache.lucene.util.packed.PackedLongValues.Iterator
Whether or not there are remaining values.
hasNext() - Method in class org.apache.lucene.util.SPIClassIterator
 
hasNorms() - Method in class org.apache.lucene.index.FieldInfo
Returns true if this field actually has any norms.
hasNorms() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have norms
hasOffsets() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
hasOffsets() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have offsets
hasOffsets() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasOffsets() - Method in class org.apache.lucene.index.MultiTerms
 
hasOffsets() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store offsets.
hasOnlyRealTerms() - Method in class org.apache.lucene.index.TermContext
Returns true if all terms stored here are real (e.g., not auto-prefix terms).
hasPayloads() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
hasPayloads() - Method in class org.apache.lucene.index.FieldInfo
Returns true if any payloads exist for this field.
hasPayloads() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have payloads
hasPayloads() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasPayloads() - Method in class org.apache.lucene.index.MultiTerms
 
hasPayloads() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store payloads.
hasPendingMerges() - Method in class org.apache.lucene.index.IndexWriter
Expert: returns true if there are merges waiting to be scheduled.
hasPositions() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
hasPositions() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasPositions() - Method in class org.apache.lucene.index.MultiTerms
 
hasPositions() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store positions.
hasProx() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have positions
hasUncommittedChanges() - Method in class org.apache.lucene.index.IndexWriter
Returns true if there may be changes that have not been committed.
hasVectors() - Method in class org.apache.lucene.index.FieldInfo
Returns true if any term vectors exist for this field.
hasVectors() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have vectors
haversin(double, double, double, double) - Static method in class org.apache.lucene.util.SloppyMath
Returns the distance in kilometers between two points specified in decimal degrees (latitude/longitude).
headerLength(String) - Static method in class org.apache.lucene.codecs.CodecUtil
Computes the length of a codec header.
HIGH_COMPRESSION - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
A compression mode that trades speed for compression ratio.
HOLE - Static variable in class org.apache.lucene.analysis.TokenStreamToAutomaton
We add this arc to represent a hole.
humanReadableUnits(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns size in human-readable units (GB, MB, KB or bytes).
humanReadableUnits(long, DecimalFormat) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns size in human-readable units (GB, MB, KB or bytes).

I

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
 
ID_LENGTH - Static variable in class org.apache.lucene.util.StringHelper
length in bytes of an ID
IDENTITY - Static variable in class org.apache.lucene.util.LongValues
An instance that returns the provided value.
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.
idToString(byte[]) - Static method in class org.apache.lucene.util.StringHelper
Helper method to render an ID as a string, for debugging
in - Variable in class org.apache.lucene.index.FilterCodecReader
The underlying CodecReader instance.
in - Variable in class org.apache.lucene.index.FilterDirectoryReader
The filtered DirectoryReader
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterFields
The underlying Fields instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
The underlying PostingsEnum instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterTerms
The underlying Terms instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
The underlying TermsEnum instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader
The underlying LeafReader.
in - Variable in class org.apache.lucene.search.FilterCollector
 
in - Variable in class org.apache.lucene.search.FilterLeafCollector
 
in - Variable in class org.apache.lucene.search.FilterScorer
 
in - Variable in class org.apache.lucene.search.spans.FilterSpans
The wrapped spans instance.
in - Variable in class org.apache.lucene.store.FilterDirectory
 
includesLower() - Method in class org.apache.lucene.search.TermRangeFilter
Deprecated.
Returns true if the lower endpoint is inclusive
includesLower() - Method in class org.apache.lucene.search.TermRangeQuery
Returns true if the lower endpoint is inclusive
includesMax() - Method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
Returns true if the upper endpoint is inclusive
includesMax() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns true if the upper endpoint is inclusive
includesMin() - Method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
Returns true if the lower endpoint is inclusive
includesMin() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns true if the lower endpoint is inclusive
includesUpper() - Method in class org.apache.lucene.search.TermRangeFilter
Deprecated.
Returns true if the upper endpoint is inclusive
includesUpper() - Method in class org.apache.lucene.search.TermRangeQuery
Returns true if 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
Increments the refCount for this IndexCommit.
incRef() - Method in class org.apache.lucene.util.RefCount
Increments the reference count.
incrementToken() - Method in class org.apache.lucene.analysis.CachingTokenFilter
The first time called, it'll read and cache all tokens from the input.
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
 
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.
IndexCommit - Class in org.apache.lucene.index
Expert: represents a single commit into an index as seen by the IndexDeletionPolicy or IndexReader.
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
Expert: policy for deletion of stale index commits.
IndexDeletionPolicy() - Constructor for class org.apache.lucene.index.IndexDeletionPolicy
Sole constructor, typically called by sub-classes constructors.
indexerThreadPool - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
DocumentsWriterPerThreadPool to control how threads are allocated to DocumentsWriterPerThread.
indexExists(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
Returns true if 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.
indexHeaderLength(String, String) - Static method in class org.apache.lucene.codecs.CodecUtil
Computes the length of an index header.
indexingChain - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
DocumentsWriterPerThread.IndexingChain that 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().
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.blocktree.Stats
Byte size of the index.
indexOptions - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
IndexOptions of current field being written
indexOptions() - Method in class org.apache.lucene.document.FieldType
IndexOptions, describing what should be recorded into the inverted index
indexOptions() - Method in interface org.apache.lucene.index.IndexableFieldType
IndexOptions, describing what should be recorded into the inverted index
IndexOptions - Enum in org.apache.lucene.index
Controls how much information is stored in the postings lists.
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(String) - Constructor for class org.apache.lucene.store.IndexOutput
Sole constructor.
IndexReader - Class in org.apache.lucene.index
IndexReader is an abstract class, providing an interface for accessing a point-in-time view of 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.
IndexReaderWarmer() - Constructor for class org.apache.lucene.index.IndexWriter.IndexReaderWarmer
Sole constructor.
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
Creates a searcher searching the provided top-level IndexReaderContext.
IndexSearcher(IndexReaderContext) - Constructor for class org.apache.lucene.search.IndexSearcher
Creates a searcher searching the provided top-level IndexReaderContext.
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.
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) - Constructor for class org.apache.lucene.index.IndexUpgrader
Creates index upgrader on the given directory, using an IndexWriter using the given matchVersion.
IndexUpgrader(Directory, InfoStream, 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 IndexWriter creates 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.
IndexWriterConfig - Class in org.apache.lucene.index
Holds all the configuration that is used to create an IndexWriter.
IndexWriterConfig(Analyzer) - Constructor for class org.apache.lucene.index.IndexWriterConfig
Creates a new config that with the default Analyzer.
IndexWriterConfig.OpenMode - Enum in org.apache.lucene.index
Specifies the open mode for IndexWriter.
info - Variable in class org.apache.lucene.index.SegmentCommitInfo
The SegmentInfo that we wrap.
info(int) - Method in class org.apache.lucene.index.SegmentInfos
Returns SegmentCommitInfo at the provided index.
infoStream - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
InfoStream for debugging messages.
infoStream - Variable in class org.apache.lucene.index.MergeScheduler
For messages about merge scheduling
infoStream - Variable in class org.apache.lucene.index.MergeState
InfoStream for debugging messages.
infoStream - Variable in class org.apache.lucene.index.SegmentWriteState
InfoStream used for debugging messages.
InfoStream - Class in org.apache.lucene.util
Debugging API for Lucene classes such as IndexWriter and SegmentInfos.
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, SegmentReadState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
 
init(IndexOutput, SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
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, SegmentReadState) - 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, SegmentWriteState) - 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
 
initTransition(int, Transition) - Method in class org.apache.lucene.util.automaton.Automaton
Initialize the provided Transition to iterate through all transitions leaving the specified state.
inOrder - Variable in class org.apache.lucene.search.spans.SpanNearQuery
 
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
Create a new InPlaceMergeSorter
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.Result
 
inputCount - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
InputOutput() - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
InputOutput() - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
 
InputStreamDataInput - Class in org.apache.lucene.store
A DataInput wrapping a plain InputStream.
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.NoMergePolicy
Singleton instance.
INSTANCE - Static variable in class org.apache.lucene.index.NoMergeScheduler
The single instance of NoMergeScheduler
INSTANCE - Static variable in class org.apache.lucene.store.NativeFSLockFactory
Singleton instance
INSTANCE - Static variable in class org.apache.lucene.store.NoLockFactory
The singleton
INSTANCE - Static variable in class org.apache.lucene.store.SimpleFSLockFactory
Singleton instance
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
 
intAt(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Return the int at the given offset.
IntBlockPool - Class in org.apache.lucene.util
A pool for int blocks similar to ByteBlockPool
IntBlockPool() - Constructor for class org.apache.lucene.util.IntBlockPool
Creates a new IntBlockPool with a default IntBlockPool.Allocator.
IntBlockPool(IntBlockPool.Allocator) - Constructor for class org.apache.lucene.util.IntBlockPool
Creates a new IntBlockPool with the given IntBlockPool.Allocator.
IntBlockPool.Allocator - Class in org.apache.lucene.util
Abstract class for allocating and freeing int blocks.
IntBlockPool.DirectAllocator - Class in org.apache.lucene.util
A simple IntBlockPool.Allocator that never recycles.
IntBlockPool.SliceReader - Class in org.apache.lucene.util
A IntBlockPool.SliceReader that can read int slices written by a IntBlockPool.SliceWriter
IntBlockPool.SliceWriter - Class in org.apache.lucene.util
A IntBlockPool.SliceWriter that allows to write multiple integer slices into a given IntBlockPool.
IntComparator(int, String, Integer) - Constructor for class org.apache.lucene.search.FieldComparator.IntComparator
Creates a new comparator based on Integer.compare(int, int) for numHits.
interleave(long, long) - Static method in class org.apache.lucene.util.BitUtil
Interleaves the first 32 bits of each long value Adapted from: http://graphics.stanford.edu/~seander/bithacks.html#InterleaveBMN
intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
 
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 and documents that are accepted by the provided CompiledAutomaton.
intersect(List<? extends DocIdSetIterator>) - Static method in class org.apache.lucene.search.ConjunctionDISI
Create a conjunction over the provided iterators, taking advantage of TwoPhaseIterator.
intersection(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
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.
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
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.codecs.StoredFieldsWriter.MergeVisitor
 
intField(FieldInfo, int) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
IntField - Class in org.apache.lucene.document
Field that indexes int values for efficient range filtering and sorting.
IntField(String, int, Field.Store) - Constructor for class org.apache.lucene.document.IntField
Creates a stored or un-stored IntField with the provided value and default precisionStep NumericUtils.PRECISION_STEP_DEFAULT_32 (8).
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
IntRangeBuilder() - Constructor for class org.apache.lucene.util.NumericUtils.IntRangeBuilder
 
introSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array slice using the Comparator.
introSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array using the Comparator.
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
Sorts the given random access List using the Comparator.
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
Create a new IntroSorter.
ints - Variable in class org.apache.lucene.util.IntsRef
The contents of the IntsRef.
ints() - Method in class org.apache.lucene.util.IntsRefBuilder
Return a reference to the ints of this builder.
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
Create a IntsRef with IntsRef.EMPTY_INTS
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.
IntsRefBuilder - Class in org.apache.lucene.util
A builder for IntsRef instances.
IntsRefBuilder() - Constructor for class org.apache.lucene.util.IntsRefBuilder
Sole constructor.
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.
intsRefToBytesRef(IntsRef) - Static method in class org.apache.lucene.util.StringHelper
Just converts each int in the incoming IntsRef to each byte in the returned BytesRef, throwing IllegalArgumentException if any int value is out of bounds for a byte.
intToPrefixCoded(int, int, BytesRefBuilder) - Static method in class org.apache.lucene.util.NumericUtils
Returns prefix coded bits after reducing the precision by shift bits.
intToPrefixCodedBytes(int, int, BytesRefBuilder) - Static method in class org.apache.lucene.util.NumericUtils
Returns prefix coded bits after reducing the precision by shift bits.
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.Automaton.Builder
Returns true if this state is an accept state.
isAccept(int) - Method in class org.apache.lucene.util.automaton.Automaton
Returns true if this state is an accept state.
isAccept(int) - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns acceptance status for given state.
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.FilteredDocIdSet
This DocIdSet implementation is cacheable if the inner set is cacheable.
isCacheable() - Method in class org.apache.lucene.util.BitDocIdSet
This DocIdSet implementation is cacheable.
isCacheable() - Method in class org.apache.lucene.util.NotDocIdSet
 
isCacheable() - Method in class org.apache.lucene.util.RoaringDocIdSet
 
isCached() - Method in class org.apache.lucene.analysis.CachingTokenFilter
If the underlying token stream was consumed and cached.
isCached() - Method in class org.apache.lucene.search.CachingCollector
Return true is this collector is able to replay collection.
isCompiled() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
isComplete - Variable in class org.apache.lucene.util.fst.Util.TopResults
true iff this is a complete result ie.
isCoordDisabled() - Method in class org.apache.lucene.search.BooleanQuery
Return whether the coord factor is disabled.
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
 
isDefinitelyEmpty() - Method in class org.apache.lucene.util.BitDocIdSet.Builder
Is this builder definitely empty? If so, BitDocIdSet.Builder.build() will return null.
isDeleted() - Method in class org.apache.lucene.index.IndexCommit
Returns true if this commit should be deleted; this is only used by IndexWriter after invoking the IndexDeletionPolicy.
isDeterministic() - Method in class org.apache.lucene.util.automaton.Automaton
Returns true if this automaton is deterministic (for ever state there is only one transition for each label).
isEmpty(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given automaton accepts no strings.
isEmpty() - Method in class org.apache.lucene.util.WeakIdentityMap
Returns true if this map contains no key-value mappings.
isEnabled(String) - Method in class org.apache.lucene.util.InfoStream
returns true if messages are enabled and should be posted to InfoStream.message(java.lang.String, java.lang.String).
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.Operations
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.
 
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 true if the current token is a keyword, otherwise false
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
Deprecated.
Use of this method can only lead to race conditions. Try to actually obtain a lock instead.
isMatch() - Method in class org.apache.lucene.search.Explanation
Indicates whether or not this Explanation models a match.
isMerged(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, IndexWriter) - 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(SegmentInfos, SegmentCommitInfo, IndexWriter) - 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
isNull(int, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
Check whether the given value represents null.
isOpen() - Method in class org.apache.lucene.index.IndexWriter
Returns true if this IndexWriter is still open.
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 baseClass and the given subclass subclazz.
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.
isProhibited() - Method in class org.apache.lucene.search.BooleanClause
 
isRealTerm - Variable in class org.apache.lucene.codecs.BlockTermState
True if this term is "real" (e.g., not an auto-prefix term or some other "secret" term; currently only BlockTreeTermsReader sets this).
isRealTerm() - Method in class org.apache.lucene.codecs.BlockTermState
 
isRealTerm() - Method in class org.apache.lucene.index.TermState
Returns true if this term is real (e.g., not an auto-prefix term).
isRequired() - Method in class org.apache.lucene.search.BooleanClause
 
isScoring() - Method in class org.apache.lucene.search.BooleanClause
 
isSearcherCurrent() - Method in class org.apache.lucene.search.SearcherManager
Returns true if no changes have occured since this searcher ie.
isSingleValued(Iterable<Number>) - Static method in class org.apache.lucene.codecs.DocValuesConsumer
Helper: returns true if the given docToValue count contains only at most one value
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.
isSystemStream() - Method in class org.apache.lucene.util.PrintStreamInfoStream
 
isTopLevel - Variable in class org.apache.lucene.index.IndexReaderContext
true if this context struct represents the top level reader within the hierarchical context
isTotal(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given automaton accepts all strings.
isTotal(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given automaton accepts all strings for the specified min/max range of the alphabet.
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() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
 
iterator() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
iterator() - Method in class org.apache.lucene.document.Document
 
iterator() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
 
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.FilterLeafReader.FilterFields
 
iterator() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
iterator() - Method in class org.apache.lucene.index.MultiFields
 
iterator() - Method in class org.apache.lucene.index.MultiTerms
 
iterator() - Method in class org.apache.lucene.index.PrefixCodedTerms
Return an iterator over the terms stored in this PrefixCodedTerms.
iterator() - Method in class org.apache.lucene.index.SegmentInfos
Returns an unmodifiable Iterator of contained segments in order.
iterator() - 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.DisiPriorityQueue
 
iterator - Variable in class org.apache.lucene.search.DisiWrapper
 
iterator() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
 
iterator() - Method in class org.apache.lucene.search.DocIdSet
Provides a DocIdSetIterator to access the set.
iterator() - Method in class org.apache.lucene.search.DocValuesDocIdSet
 
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.BitDocIdSet
 
iterator() - Method in class org.apache.lucene.util.BytesRefArray
sugar for BytesRefArray.iterator(Comparator) with a null comparator
iterator(Comparator<BytesRef>) - Method in class org.apache.lucene.util.BytesRefArray
Returns a BytesRefIterator with point in time semantics.
iterator() - Method in class org.apache.lucene.util.fst.Util.TopResults
 
iterator() - Method in class org.apache.lucene.util.NamedSPILoader
 
iterator() - Method in class org.apache.lucene.util.NotDocIdSet
 
iterator() - Method in class org.apache.lucene.util.packed.PackedLongValues
Return an iterator over the values of this array.
iterator() - Method in class org.apache.lucene.util.RoaringDocIdSet
 

J

JAVA_VENDOR - Static variable in class org.apache.lucene.util.Constants
 
JAVA_VERSION - Static variable in class org.apache.lucene.util.Constants
The value of System.getProperty("java.version").
JRE_IS_64BIT - Static variable in class org.apache.lucene.util.Constants
True iff running on a 64bit JVM
JRE_IS_MINIMUM_JAVA8 - Static variable in class org.apache.lucene.util.Constants
 
JRE_IS_MINIMUM_JAVA9 - Static variable in class org.apache.lucene.util.Constants
 
JVM_NAME - Static variable in class org.apache.lucene.util.Constants
 
JVM_SPEC_VERSION - Static variable in class org.apache.lucene.util.Constants
 
JVM_VENDOR - Static variable in class org.apache.lucene.util.Constants
JVM vendor info.
JVM_VERSION - Static variable in class org.apache.lucene.util.Constants
 

K

KeepOnlyLastCommitDeletionPolicy - Class in org.apache.lucene.index
This IndexDeletionPolicy implementation that keeps only the most recent commit and immediately removes all prior commits after a new commit is done.
KeepOnlyLastCommitDeletionPolicy() - Constructor for class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
Sole constructor.
keyIterator() - Method in class org.apache.lucene.util.WeakIdentityMap
Returns an iterator over all weak keys of this map.
keys - Variable in class org.apache.lucene.util.SentinelIntSet
A power-of-2 over-sized array holding the integers in the set along with empty values.
KeywordAttribute - Interface in org.apache.lucene.analysis.tokenattributes
This attribute can be used to mark a token as a keyword.
KeywordAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of KeywordAttribute.
KeywordAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
Initialize this attribute with the keyword value as false.

L

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
lastApproxMatchDoc - Variable in class org.apache.lucene.search.DisiWrapper
 
lastApproxNonMatchDoc - Variable in class org.apache.lucene.search.DisiWrapper
 
lastCommit - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
Most recently committed IndexCommit.
LATEST - Static variable in class org.apache.lucene.util.Version
WARNING: if you use this setting, and then upgrade to a newer release of Lucene, sizable changes may happen.
LeafCollector - Interface in org.apache.lucene.search
Collector decouples the score from the collected doc: the score computation is skipped entirely if it's not needed.
leafContexts - Variable in class org.apache.lucene.search.IndexSearcher
 
LeafFieldComparator - Interface in org.apache.lucene.search
Expert: comparator that gets instantiated on each leaf from a top-level FieldComparator instance.
LeafReader - Class in org.apache.lucene.index
LeafReader is an abstract class, providing an interface for accessing an index.
LeafReader() - Constructor for class org.apache.lucene.index.LeafReader
Sole constructor.
LeafReader.CoreClosedListener - Interface in org.apache.lucene.index
Called when the shared core for this LeafReader is closed.
LeafReaderContext - Class in org.apache.lucene.index
LeafSlice(LeafReaderContext...) - Constructor for class org.apache.lucene.search.IndexSearcher.LeafSlice
 
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
Deprecated.
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
Deprecated.
A filter strategy that uses a "leap-frog" approach (also called "zig-zag join").
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.
leaves() - Method in class org.apache.lucene.index.LeafReaderContext
 
length() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
length - Variable in class org.apache.lucene.index.ReaderSlice
Number of documents in this slice.
length() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
length() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
length() - Method in class org.apache.lucene.store.IndexInput
The number of bytes in the file.
length() - Method in class org.apache.lucene.store.RAMInputStream
 
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() - Method in class org.apache.lucene.util.BytesRefBuilder
Return the number of bytes in this buffer.
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.CharsRefBuilder
Return the number of chars in this buffer.
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.IntsRefBuilder
Return the number of ints in this buffer.
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.SparseFixedBitSet
 
lengthNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
Implemented as state.getBoost()*lengthNorm(numTerms), where numTerms is FieldInvertState.getLength() if DefaultSimilarity.setDiscountOverlaps(boolean) is false, else it's FieldInvertState.getLength() - FieldInvertState.getNumOverlap().
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
Deprecated.
Constructs a filter for field fieldName matching less than or equal to upperTerm.
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.
LevenshteinAutomataAttributeImpl() - Constructor for class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
 
LimitedFiniteStringsIterator - Class in org.apache.lucene.util.automaton
FiniteStringsIterator which limits the number of iterated accepted strings.
LimitedFiniteStringsIterator(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
Constructor.
lines - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
number of lines of data read
LINUX - Static variable in class org.apache.lucene.util.Constants
True iff running on Linux.
listAll() - Method in class org.apache.lucene.store.Directory
Returns an array of strings, one for each entry in the directory.
listAll() - Method in class org.apache.lucene.store.FileSwitchDirectory
 
listAll() - Method in class org.apache.lucene.store.FilterDirectory
 
listAll(Path) - Static method in class org.apache.lucene.store.FSDirectory
Lists all files (including subdirectories) in the directory.
listAll() - Method in class org.apache.lucene.store.FSDirectory
 
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.MergeState
Live docs for each reader
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.lucene53.Lucene53Codec
 
liveDocStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of livedocs
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
The missingValue must be non-null.
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.LMStats - Class in org.apache.lucene.search.similarities
Stores the collection distribution of the current term.
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_OBTAIN_WAIT_FOREVER - Static variable in class org.apache.lucene.store.SleepingLockWrapper
Pass this lockWaitTimeout to try forever to obtain the lock.
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.lock could not be acquired.
LockObtainFailedException(String) - Constructor for exception org.apache.lucene.store.LockObtainFailedException
 
LockObtainFailedException(String, Throwable) - Constructor for exception org.apache.lucene.store.LockObtainFailedException
 
LockReleaseFailedException - Exception in org.apache.lucene.store
This exception is thrown when the write.lock could not be released.
LockReleaseFailedException(String) - Constructor for exception org.apache.lucene.store.LockReleaseFailedException
 
LockReleaseFailedException(String, Throwable) - Constructor for exception org.apache.lucene.store.LockReleaseFailedException
 
LockStressTest - Class in org.apache.lucene.store
Simple standalone tool that forever acquires and releases a lock using a specific LockFactory.
LockStressTest() - Constructor for class org.apache.lucene.store.LockStressTest
 
LockValidatingDirectoryWrapper - Class in org.apache.lucene.store
This class makes a best-effort check that a provided Lock is valid before any destructive filesystem operation.
LockValidatingDirectoryWrapper(Directory, Lock) - Constructor for class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
LockVerifyServer - Class in org.apache.lucene.store
Simple standalone server that must be running when you use VerifyingLockFactory.
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
Creates a new LongBitSet.
LongBitSet(long[], long) - Constructor for class org.apache.lucene.util.LongBitSet
Creates a new LongBitSet using the provided long[] array as backing store.
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.
LongComparator(int, String, Long) - Constructor for class org.apache.lucene.search.FieldComparator.LongComparator
Creates a new comparator based on Long.compare(long, long) for numHits.
longCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Computes how many long blocks are needed to store values values of size bitsPerValue.
longField(FieldInfo, long) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
longField(FieldInfo, long) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
LongField - Class in org.apache.lucene.document
Field that indexes long values for efficient range filtering and sorting.
LongField(String, long, Field.Store) - Constructor for class org.apache.lucene.document.LongField
Creates a stored or un-stored LongField with the provided value and default precisionStep NumericUtils.PRECISION_STEP_DEFAULT (16).
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
 
LongRangeBuilder() - Constructor for class org.apache.lucene.util.NumericUtils.LongRangeBuilder
 
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
Create a LongsRef with LongsRef.EMPTY_LONGS
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, BytesRefBuilder) - Static method in class org.apache.lucene.util.NumericUtils
Returns prefix coded bits after reducing the precision by shift bits.
longToPrefixCodedBytes(long, int, BytesRefBuilder) - Static method in class org.apache.lucene.util.NumericUtils
Returns prefix coded bits after reducing the precision by shift bits.
longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
The number of values that can be stored in PackedInts.Decoder.longBlockCount() long blocks.
longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
The number of values that can be stored in PackedInts.Encoder.longBlockCount() long blocks.
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 and opened in an NRT IndexSearcher.
lookupOrd(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
lookupOrd(long) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
lookupOrd(int) - Method in class org.apache.lucene.index.SortedDocValues
Retrieves the value for the specified ordinal.
lookupOrd(long) - Method in class org.apache.lucene.index.SortedSetDocValues
Retrieves the value for the specified ordinal.
lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedDocValues
If key exists, returns its ordinal, else returns -insertionPoint-1, like Arrays.binarySearch.
lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedSetDocValues
If key exists, returns its ordinal, else returns -insertionPoint-1, like Arrays.binarySearch.
LRUFilterCache - Class in org.apache.lucene.search
Deprecated.
Use LRUQueryCache instead
LRUFilterCache(int, long) - Constructor for class org.apache.lucene.search.LRUFilterCache
Deprecated.
Create a new instance that will cache at most maxSize filters with at most maxRamBytesUsed bytes of memory.
LRUQueryCache - Class in org.apache.lucene.search
A QueryCache that evicts queries using a LRU (least-recently-used) eviction policy in order to remain under a given maximum size and number of bytes used.
LRUQueryCache(int, long) - Constructor for class org.apache.lucene.search.LRUQueryCache
Create a new instance that will cache at most maxSize queries with at most maxRamBytesUsed bytes of memory.
Lucene50CompoundFormat - Class in org.apache.lucene.codecs.lucene50
Lucene 5.0 compound file format
Lucene50CompoundFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50CompoundFormat
Sole constructor.
Lucene50DocValuesFormat - Class in org.apache.lucene.codecs.lucene50
Lucene 5.0 DocValues format.
Lucene50DocValuesFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50DocValuesFormat
Sole Constructor
Lucene50FieldInfosFormat - Class in org.apache.lucene.codecs.lucene50
Lucene 5.0 Field Infos format.
Lucene50FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50FieldInfosFormat
Sole constructor.
Lucene50LiveDocsFormat - Class in org.apache.lucene.codecs.lucene50
Lucene 5.0 live docs format
Lucene50LiveDocsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50LiveDocsFormat
Sole constructor.
Lucene50PostingsFormat - Class in org.apache.lucene.codecs.lucene50
Lucene 5.0 postings format, which encodes postings in packed integer blocks for fast decode.
Lucene50PostingsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
Creates Lucene50PostingsFormat with default settings.
Lucene50PostingsFormat(int, int) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
Creates Lucene50PostingsFormat with custom values for minBlockSize and maxBlockSize passed to block terms dictionary.
Lucene50PostingsReader - Class in org.apache.lucene.codecs.lucene50
Concrete class that reads docId(maybe frq,pos,offset,payloads) list with postings format.
Lucene50PostingsReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
Sole constructor.
Lucene50PostingsWriter - Class in org.apache.lucene.codecs.lucene50
Concrete class that writes docId(maybe frq,pos,offset,payloads) list with postings format.
Lucene50PostingsWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
Creates a postings writer
Lucene50SegmentInfoFormat - Class in org.apache.lucene.codecs.lucene50
Lucene 5.0 Segment info format.
Lucene50SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50SegmentInfoFormat
Sole constructor.
Lucene50StoredFieldsFormat - Class in org.apache.lucene.codecs.lucene50
Lucene 5.0 stored fields format.
Lucene50StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
Stored fields format with default options
Lucene50StoredFieldsFormat(Lucene50StoredFieldsFormat.Mode) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
Stored fields format with specified mode
Lucene50StoredFieldsFormat.Mode - Enum in org.apache.lucene.codecs.lucene50
Configuration option for stored fields.
Lucene50TermVectorsFormat - Class in org.apache.lucene.codecs.lucene50
Lucene50TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50TermVectorsFormat
Sole constructor.
Lucene53Codec - Class in org.apache.lucene.codecs.lucene53
Implements the Lucene 5.3 index format, with configurable per-field postings and docvalues formats.
Lucene53Codec() - Constructor for class org.apache.lucene.codecs.lucene53.Lucene53Codec
Instantiates a new codec.
Lucene53Codec(Lucene50StoredFieldsFormat.Mode) - Constructor for class org.apache.lucene.codecs.lucene53.Lucene53Codec
Instantiates a new codec, specifying the stored fields compression mode to use.
Lucene53NormsFormat - Class in org.apache.lucene.codecs.lucene53
Lucene 5.3 Score normalization format.
Lucene53NormsFormat() - Constructor for class org.apache.lucene.codecs.lucene53.Lucene53NormsFormat
Sole Constructor
LUCENE_4_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_0_0 instead (this constant actually points to Version.LUCENE_4_0_0_ALPHA to match whole 4.0 series).
LUCENE_4_0_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_0_0_ALPHA - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_0_0_BETA - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_1_0 instead.
LUCENE_4_10_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_10_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_10_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_10_3 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_10_4 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_1_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_2_0 instead.
LUCENE_4_2_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_2_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_3 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_3_0 instead.
LUCENE_4_3_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_3_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_4 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_4_0 instead.
LUCENE_4_4_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_5 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_5_0 instead.
LUCENE_4_5_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_5_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_6 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_6_0 instead.
LUCENE_4_6_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_6_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_7 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_7_0 instead.
LUCENE_4_7_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_7_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_7_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_8 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_8_0 instead.
LUCENE_4_8_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_8_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_9 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Bad naming of constant; use Version.LUCENE_4_9_0 instead.
LUCENE_4_9_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_4_9_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.0) Use latest
LUCENE_5_0_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.1.0) Use latest
LUCENE_5_1_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.2.0) Use latest
LUCENE_5_2_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.3.0) Use latest
LUCENE_5_2_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_5_3_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(5.3.1) Use latest
LUCENE_5_3_1 - Static variable in class org.apache.lucene.util.Version
Match settings and bugs in Lucene's 5.3.1 release.
LUCENE_CURRENT - Static variable in class org.apache.lucene.util.Version
Deprecated.
LUCENE_MAIN_VERSION - Static variable in class org.apache.lucene.util.Constants
Deprecated.
LUCENE_VERSION - Static variable in class org.apache.lucene.util.Constants
Deprecated.
LucenePackage - Class in org.apache.lucene
Lucene's package information, including version.

M

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 exorcise corrupt segments from 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
 
major - Variable in class org.apache.lucene.util.Version
Major version, the difference between stable and trunk
makeAnyBinary() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts all binary terms.
makeAnyChar() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts any single codepoint.
makeAnyString() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts all strings.
makeBinary(BytesRef) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts the single given binary term.
makeBinaryInterval(BytesRef, boolean, BytesRef, boolean) - Static method in class org.apache.lucene.util.automaton.Automata
Creates a new deterministic, minimal automaton accepting all binary terms in the specified interval.
makeChar(int) - Static method in class org.apache.lucene.util.automaton.Automata
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.Automata
Returns a new (deterministic) automaton that accepts a single codepoint whose value is in the given interval (including both end points).
makeDecimalInterval(int, int, int) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new automaton that accepts strings representing decimal (base 10) non-negative integers in the given interval.
makeEmpty() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton with the empty language.
makeEmptyString() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts only the empty string.
makeString(String) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts the single given string.
makeString(int[], int, int) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts the single given string from the specified unicode code points.
makeStringUnion(Collection<BytesRef>) - Static method in class org.apache.lucene.util.automaton.Automata
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
 
MappedMultiFields - Class in org.apache.lucene.index
A Fields implementation that merges multiple Fields into one, and maps around deleted documents.
MappedMultiFields(MergeState, MultiFields) - Constructor for class org.apache.lucene.index.MappedMultiFields
Create a new MappedMultiFields for merging, based on the supplied mergestate and merged view of terms.
mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
ordinal map mapping ords from values to global ord space
mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
ordinal map mapping ords from values to global ord space
match(int) - Method in class org.apache.lucene.search.BitsFilteredDocIdSet
 
match(float, String, Collection<Explanation>) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a match.
match(float, String, Explanation...) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a match.
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.payloads.SpanPayloadCheckQuery
 
match - Variable in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
MatchAllBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchAllBits
 
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.DocValuesDocIdSet
this method checks, if a doc is a hit
matchEnd - Variable in class org.apache.lucene.search.spans.NearSpansOrdered
 
matches() - Method in class org.apache.lucene.search.ConjunctionDISI
 
matches() - Method in class org.apache.lucene.search.TwoPhaseDocIdSetIterator
Return whether the current doc ID that the iterator is on matches.
matches() - Method in class org.apache.lucene.search.TwoPhaseIterator
Return whether the current doc ID that the iterator is on matches.
matchesExtension(String, String) - Static method in class org.apache.lucene.index.IndexFileNames
Returns true if the given filename ends with the given extension.
MatchNoBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchNoBits
 
MatchNoDocsQuery - Class in org.apache.lucene.search
A query that matches no documents.
MatchNoDocsQuery() - Constructor for class org.apache.lucene.search.MatchNoDocsQuery
 
matchStart - Variable in class org.apache.lucene.search.spans.NearSpansOrdered
 
matchWidth - Variable in class org.apache.lucene.search.spans.NearSpansOrdered
 
MathUtil - Class in org.apache.lucene.util
Math static utility methods.
max - Variable in class org.apache.lucene.util.automaton.Transition
Maximum accepted label (inclusive).
MAX_ARRAY_LENGTH - Static variable in class org.apache.lucene.util.ArrayUtil
Maximum length for an array (Integer.MAX_VALUE - RamUsageEstimator.NUM_BYTES_ARRAY_HEADER).
MAX_DOCS - Static variable in class org.apache.lucene.index.IndexWriter
Hard limit on maximum number of documents that may be added to the index.
MAX_POSITION - Static variable in class org.apache.lucene.index.IndexWriter
Maximum value of the token position in an indexed field.
MAX_TEMPFILES - Static variable in class org.apache.lucene.util.OfflineSorter
Maximum number of temporary files before doing an intermediate merge.
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.
MAX_UTF8_BYTES_PER_CHAR - Static variable in class org.apache.lucene.util.UnicodeUtil
Maximum number of UTF8 bytes per UTF16 character.
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.
maxDoc() - Method in class org.apache.lucene.index.BaseCompositeReader
 
maxDoc - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Document count (does not take deletions into account).
maxDoc() - Method in class org.apache.lucene.index.FilterCodecReader
 
maxDoc() - Method in class org.apache.lucene.index.FilterLeafReader
 
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.ParallelLeafReader
 
maxDoc() - Method in class org.apache.lucene.index.SegmentInfo
Returns number of documents in this segment (deletions are not taken into account).
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.DocValuesDocIdSet
 
maxDocs - Variable in class org.apache.lucene.index.MergeState
Max docs per reader
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
Maximum edit distance this class can generate an automaton for.
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
If the size of a segment exceeds this value then it will never be merged during IndexWriter.forceMerge(int).
MaxNonCompetitiveBoostAttribute - Interface in org.apache.lucene.search
MaxNonCompetitiveBoostAttributeImpl - Class in org.apache.lucene.search
Implementation class for MaxNonCompetitiveBoostAttribute.
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.
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
You must call this (or ReferenceManager.maybeRefreshBlocking()), periodically, if you want that ReferenceManager.acquire() will return refreshed instances.
maybeRefreshBlocking() - Method in class org.apache.lucene.search.ReferenceManager
You must call this (or ReferenceManager.maybeRefresh()), periodically, if you want that ReferenceManager.acquire() will return refreshed instances.
maybeStall(IndexWriter) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
This is invoked by ConcurrentMergeScheduler.merge(org.apache.lucene.index.IndexWriter, org.apache.lucene.index.MergeTrigger, boolean) to possibly stall the incoming thread when there are too many merges running or pending.
MB - Static variable in class org.apache.lucene.util.OfflineSorter
Convenience constant for megabytes
megabytes(long) - Static method in class org.apache.lucene.util.OfflineSorter.BufferSize
Creates a OfflineSorter.BufferSize in MB.
merge(MergeState) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
 
merge(MergeState) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
merge(MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges in the fields from the readers in mergeState.
merge(MergeState) - Method in class org.apache.lucene.codecs.FieldsConsumer
Merges in the fields from the readers in mergeState.
merge(MergeState) - Method in class org.apache.lucene.codecs.NormsConsumer
Merges in the fields from the readers in mergeState.
merge(MergeState) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Merges in the stored fields from the readers in mergeState.
merge(MergeState) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Merges in the term vectors from the readers in mergeState.
merge(IndexWriter, MergeTrigger, boolean) - 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, MergeTrigger, boolean) - Method in class org.apache.lucene.index.MergeScheduler
Run the merges provided by IndexWriter.getNextMerge().
merge(IndexWriter, MergeTrigger, boolean) - Method in class org.apache.lucene.index.NoMergeScheduler
 
merge(IndexWriter, MergeTrigger, boolean) - Method in class org.apache.lucene.index.SerialMergeScheduler
Just do the merges in sequence.
merge(int, TopDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Returns a new TopDocs, containing topN results across the provided TopDocs, sorting by score.
merge(int, int, TopDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Same as TopDocs.merge(int, TopDocs[]) but also ignores the top start top docs.
merge(Sort, int, TopFieldDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Returns a new TopFieldDocs, containing topN results across the provided TopFieldDocs, sorting by the specified Sort.
merge(Sort, int, int, TopFieldDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Same as TopDocs.merge(Sort, int, TopFieldDocs[]) but also ignores the top start top docs.
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.
MergeAbortedException() - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
MergeAbortedException(String) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
Create a MergePolicy.MergeAbortedException with a specified message.
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
 
MergeException(String, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
Create a MergeException.
MergeException(Throwable, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
Create a MergeException.
mergeFactor - Variable in class org.apache.lucene.index.LogMergePolicy
How many segments to merge at a time.
mergeFieldInfos - Variable in class org.apache.lucene.index.MergeState
FieldInfos of the newly merged segment.
mergeFinished() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Called by IndexWriter after the merge is done and all readers have been closed.
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
Creates a new MergeInfo instance from the values required for a MERGE IOContext context.
mergeMaxNumSegments - Variable in class org.apache.lucene.store.MergeInfo
 
mergeNormsField(FieldInfo, MergeState, List<NumericDocValues>) - Method in class org.apache.lucene.codecs.NormsConsumer
Merges the norms from toMerge.
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 for selecting merges.
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.MergeAbortedException - Exception in org.apache.lucene.index
Thrown when a merge was explicity aborted because IndexWriter.abortMerges() was called.
MergePolicy.MergeException - Exception in org.apache.lucene.index
Exception thrown if there are any problems while executing a merge.
MergePolicy.MergeSpecification - Class in org.apache.lucene.index
A MergeSpecification instance provides the information necessary to perform multiple merges.
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.
MergeRateLimiter - Class in org.apache.lucene.index
This is the RateLimiter that IndexWriter assigns to each running merge, to give MergeSchedulers ionice like control.
MergeRateLimiter(MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.MergeRateLimiter
Sole constructor.
mergeRounds - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
number of partition merges
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 to use for running merges.
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.
MergeScore() - Constructor for class org.apache.lucene.index.TieredMergePolicy.MergeScore
Sole constructor.
mergeSortedField(FieldInfo, MergeState, List<SortedDocValues>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges the sorted docvalues from toMerge.
mergeSortedNumericField(FieldInfo, MergeState, List<SortedNumericDocValues>) - 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.
MergeSpecification() - Constructor for class org.apache.lucene.index.MergePolicy.MergeSpecification
Sole constructor.
MergeState - Class in org.apache.lucene.index
Holds common state used during segment merging.
MergeState.DocMap - Class in org.apache.lucene.index
Remaps docids around deletes during merge
MergeThread(IndexWriter, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
Sole constructor.
mergeThreadCount - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
How many ConcurrentMergeScheduler.MergeThreads have kicked off (this is use to name them).
mergeThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns the number of merge threads that are alive, ignoring the calling thread if it is a merge thread.
mergeThreads - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
List of currently active ConcurrentMergeScheduler.MergeThreads.
mergeTime - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
time spent merging sorted partitions (in milliseconds)
MergeTrigger - Enum in org.apache.lucene.index
MergeTrigger is passed to MergePolicy.findMerges(MergeTrigger, org.apache.lucene.index.SegmentInfos, IndexWriter) to indicate the event that triggered the merge.
MergeVisitor(MergeState, int) - Constructor for class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
Create new merge visitor.
message(String, IndexWriter) - Method in class org.apache.lucene.index.LogMergePolicy
Print a debug message to IndexWriter's infoStream.
message(String) - Method in class org.apache.lucene.index.MergeScheduler
Outputs the given message - this method assumes MergeScheduler.verbose() was called and returned true.
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
 
min - Variable in class org.apache.lucene.util.automaton.Transition
Minimum accepted label (inclusive).
MIN_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
Minimum buffer size allowed
MIN_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.util.OfflineSorter
Minimum recommended buffer size for sorting.
minFrequencyToCache(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
For a given query, return how many times it should appear in the history before being cached.
MinimizationOperations - Class in org.apache.lucene.util.automaton
Operations for minimizing automata.
minimize(Automaton, int) - Static method in class org.apache.lucene.util.automaton.MinimizationOperations
Minimizes (and determinizes if not already deterministic) the given automaton using Hopcroft's algorighm.
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.
minor - Variable in class org.apache.lucene.util.Version
Minor version, incremented within the stable branch
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, Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns a (deterministic) automaton that accepts the intersection of the language of a1 and the complement of the language of a2.
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.blocktree.Stats
The number of "internal" blocks (that have both terms and sub-blocks).
MMapDirectory - Class in org.apache.lucene.store
File-based Directory implementation that uses mmap for reading, and FSDirectory.FSIndexOutput for writing.
MMapDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.MMapDirectory
Create a new MMapDirectory for the named location.
MMapDirectory(Path) - Constructor for class org.apache.lucene.store.MMapDirectory
Create a new MMapDirectory for the named location and FSLockFactory.getDefault().
MMapDirectory(Path, int) - Constructor for class org.apache.lucene.store.MMapDirectory
Create a new MMapDirectory for the named location and FSLockFactory.getDefault().
MMapDirectory(Path, 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.
MODE_KEY - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
Attribute key for compression mode.
MonotonicBlockPackedReader - Class in org.apache.lucene.util.packed
Provides random access to a stream written with MonotonicBlockPackedWriter.
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.
monotonicBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
Return a new PackedLongValues.Builder that will compress efficiently integers that would be a monotonic function of their index.
monotonicBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
 
More(String, BytesRef) - Static method in class org.apache.lucene.search.TermRangeFilter
Deprecated.
Constructs a filter for field fieldName matching greater than or equal to lowerTerm.
MultiCollector - Class in org.apache.lucene.search
A Collector which allows running a search with several Collectors.
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
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, where skipInterval and skipMultiplier are 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, where skipInterval and skipMultiplier are the same.
MultiPhraseQuery - Class in org.apache.lucene.search
MultiPhraseQuery is a generalized version of PhraseQuery, with an added method MultiPhraseQuery.add(Term[]).
MultiPhraseQuery() - Constructor for class org.apache.lucene.search.MultiPhraseQuery
 
MultiPostingsEnum - Class in org.apache.lucene.index
Exposes PostingsEnum, merged from PostingsEnum API of sub-segments.
MultiPostingsEnum(MultiTermsEnum, int) - Constructor for class org.apache.lucene.index.MultiPostingsEnum
Sole constructor.
MultiPostingsEnum.EnumWithSlice - Class in org.apache.lucene.index
Holds a PostingsEnum along with the corresponding ReaderSlice.
MultiReader - Class in org.apache.lucene.index
A CompositeReader which reads multiple indexes, appending their content.
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.RewriteMethod - Class in org.apache.lucene.search
Abstract class that defines how the query is rewritten.
MultiTermQuery.TopTermsBlendedFreqScoringRewrite - Class in org.apache.lucene.search
A rewrite method that first translates each term into BooleanClause.Occur.SHOULD clause in a BooleanQuery, but adjusts the frequencies used for scoring to be blended across the terms, otherwise the rarest term typically ranks highest (often not useful eg in the set of expanded terms in a FuzzyQuery).
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.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.
MultiTermQueryWrapperFilter<Q extends MultiTermQuery> - Class in org.apache.lucene.search
Deprecated.
Use MultiTermQueryConstantScoreWrapper instead
MultiTermQueryWrapperFilter(Q) - Constructor for class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
Wrap a MultiTermQuery as a Filter.
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
Exposes TermsEnum API, merged from TermsEnum API of sub-segments.
MultiTermsEnum(ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiTermsEnum
Sole constructor.
murmurhash3_x86_32(byte[], int, int, int) - Static method in class org.apache.lucene.util.StringHelper
Returns the MurmurHash3_x86_32 hash.
murmurhash3_x86_32(BytesRef, int) - Static method in class org.apache.lucene.util.StringHelper
 
Mutable() - Constructor for class org.apache.lucene.util.packed.PackedInts.Mutable
 
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
MutableValue implementation of type boolean.
MutableValueBool() - Constructor for class org.apache.lucene.util.mutable.MutableValueBool
 
MutableValueDate - Class in org.apache.lucene.util.mutable
MutableValue implementation of type Date.
MutableValueDate() - Constructor for class org.apache.lucene.util.mutable.MutableValueDate
 
MutableValueDouble - Class in org.apache.lucene.util.mutable
MutableValue implementation of type double.
MutableValueDouble() - Constructor for class org.apache.lucene.util.mutable.MutableValueDouble
 
MutableValueFloat - Class in org.apache.lucene.util.mutable
MutableValue implementation of type float.
MutableValueFloat() - Constructor for class org.apache.lucene.util.mutable.MutableValueFloat
 
MutableValueInt - Class in org.apache.lucene.util.mutable
MutableValue implementation of type int.
MutableValueInt() - Constructor for class org.apache.lucene.util.mutable.MutableValueInt
 
MutableValueLong - Class in org.apache.lucene.util.mutable
MutableValue implementation of type long.
MutableValueLong() - Constructor for class org.apache.lucene.util.mutable.MutableValueLong
 
MutableValueStr - Class in org.apache.lucene.util.mutable
MutableValue implementation of type String.
MutableValueStr() - Constructor for class org.apache.lucene.util.mutable.MutableValueStr
 

N

name() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
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.
namedAccountable(String, Accountable) - Static method in class org.apache.lucene.util.Accountables
Augments an existing accountable with the provided description.
namedAccountable(String, long) - Static method in class org.apache.lucene.util.Accountables
Returns an accountable with the provided description and bytes.
namedAccountable(String, Collection<Accountable>, long) - Static method in class org.apache.lucene.util.Accountables
Returns an accountable with the provided description, children and bytes.
namedAccountables(String, Map<?, ? extends Accountable>) - Static method in class org.apache.lucene.util.Accountables
Converts a map of resources to a collection.
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
Interface to support NamedSPILoader.lookup(String) by name.
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
Creates a new NamedThreadFactory instance
NativeFSLockFactory - Class in org.apache.lucene.store
Implements LockFactory using native OS file locks.
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, List<Spans>) - Constructor for class org.apache.lucene.search.spans.NearSpansOrdered
 
NearSpansUnordered - Class in org.apache.lucene.search.spans
Similar to NearSpansOrdered, but for the unordered case.
NearSpansUnordered(SpanNearQuery, List<Spans>) - Constructor for class org.apache.lucene.search.spans.NearSpansUnordered
 
needsField(FieldInfo) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
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 interface org.apache.lucene.search.Collector
Indicates if document scores are needed by this collector.
needsScores() - Method in class org.apache.lucene.search.FilterCollector
 
needsScores() - Method in class org.apache.lucene.search.MultiCollector
 
needsScores() - Method in class org.apache.lucene.search.Sort
Returns true if the relevance score is needed to sort documents.
needsScores() - Method in class org.apache.lucene.search.SortField
Whether the relevance score is needed to sort documents.
needsScores() - Method in class org.apache.lucene.search.TimeLimitingCollector
 
needsScores() - Method in class org.apache.lucene.search.TopFieldCollector
 
needsScores() - Method in class org.apache.lucene.search.TopScoreDocCollector
 
needsScores() - Method in class org.apache.lucene.search.TotalHitCountCollector
 
negate() - Method in class org.apache.lucene.search.FieldValueFilter
Deprecated.
Returns true iff this filter is negated, otherwise false
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(int) - Method in class org.apache.lucene.store.RAMFile
Expert: allocate a new buffer.
newCollector() - Method in interface org.apache.lucene.search.CollectorManager
Return a new Collector.
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
Create a new Compressor instance.
newConcurrentHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
Creates a new WeakIdentityMap based on a ConcurrentHashMap.
newConcurrentHashMap(boolean) - Static method in class org.apache.lucene.util.WeakIdentityMap
Creates a new WeakIdentityMap based on a ConcurrentHashMap.
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
Create a new Decompressor instance.
newDoubleRange(String, int, Double, Double, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
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
Deprecated.
Factory that creates a NumericRangeFilter, that queries a double range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT (16).
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
Factory that creates a NumericRangeQuery, that queries a double range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT (16).
newFloatRange(String, int, Float, Float, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
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
Deprecated.
Factory that creates a NumericRangeFilter, that queries a float range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT_32 (8).
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
Factory that creates a NumericRangeQuery, that queries a float range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT_32 (8).
newFSDirectory(String, Path) - Static method in class org.apache.lucene.util.CommandLineUtil
Creates a specific FSDirectory instance starting from its class name, using the default lock factory
newFSDirectory(String, Path, LockFactory) - Static method in class org.apache.lucene.util.CommandLineUtil
Creates a specific FSDirectory instance starting from its class name
newFSDirectory(Class<? extends FSDirectory>, Path) - Static method in class org.apache.lucene.util.CommandLineUtil
Creates a new specific FSDirectory instance
newFSDirectory(Class<? extends FSDirectory>, Path, LockFactory) - 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, int, Integer, Integer, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
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
Deprecated.
Factory that creates a NumericRangeFilter, that queries a int range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT_32 (8).
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
Factory that creates a NumericRangeQuery, that queries a int range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT_32 (8).
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.lucene50.Lucene50LiveDocsFormat
 
newLiveDocs(Bits) - Method in class org.apache.lucene.codecs.lucene50.Lucene50LiveDocsFormat
 
newLongRange(String, int, Long, Long, boolean, boolean) - Static method in class org.apache.lucene.search.NumericRangeFilter
Deprecated.
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
Deprecated.
Factory that creates a NumericRangeFilter, that queries a long range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT (16).
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
Factory that creates a NumericRangeQuery, that queries a long range using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT (16).
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
 
newOrderedNearQuery(String) - Static method in class org.apache.lucene.search.spans.SpanNearQuery
Returns a SpanNearQuery.Builder for an ordered query on a particular field
newPair(A, B) - Method in class org.apache.lucene.util.fst.PairOutputs
Create a new Pair
newPath(T, IntsRefBuilder) - Method in class org.apache.lucene.util.fst.Util.FSTPath
 
newRAMFile() - Method in class org.apache.lucene.store.RAMDirectory
Returns a new RAMFile for storing data.
newSearcher(IndexReader, IndexReader) - Method in class org.apache.lucene.search.SearcherFactory
Returns a new IndexSearcher over the given reader.
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.TermRangeFilter
Deprecated.
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.lucene50.Lucene50PostingsReader
 
newTermState() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
newTermState() - Method in class org.apache.lucene.codecs.PostingsReaderBase
Return a newly created empty TermState
newTermState() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Return a newly created empty TermState
newThread(Runnable) - Method in class org.apache.lucene.util.NamedThreadFactory
Creates a new Thread
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
 
newUnorderedNearQuery(String) - Static method in class org.apache.lucene.search.spans.SpanNearQuery
Returns a SpanNearQuery.Builder for an unordered query on a particular field
next() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTermsEnum
 
next() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
next() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
next() - Method in class org.apache.lucene.index.MultiTermsEnum
 
next() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
 
next - Variable in class org.apache.lucene.search.DisiWrapper
 
next() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
next() - Method in class org.apache.lucene.util.automaton.FiniteStringsIterator
Generate next finite string.
next() - Method in class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
 
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 count values.
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 count next values, the returned ref MUST NOT be modified
next() - Method in class org.apache.lucene.util.packed.PackedLongValues.Iterator
Return the next long in the buffer.
next() - Method in class org.apache.lucene.util.SPIClassIterator
 
NEXT_LEVEL_ARRAY - Static variable in class org.apache.lucene.util.ByteBlockPool
An array holding the offset into the ByteBlockPool.LEVEL_SIZE_ARRAY to quickly navigate to the next slice level.
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.index.FilterLeafReader.FilterPostingsEnum
 
nextDoc() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
nextDoc() - Method in class org.apache.lucene.search.ConjunctionDISI
 
nextDoc() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
nextDoc() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
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.FilterScorer
 
nextDoc() - Method in class org.apache.lucene.search.spans.FilterSpans
 
nextDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
 
nextDoc() - Method in class org.apache.lucene.search.spans.TermSpans
 
nextDoc() - Method in class org.apache.lucene.util.BitSetIterator
 
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.SortedSetDocValues
Returns the next ordinal for the current document (previously set by SortedSetDocValues.setDocument(int).
nextPosition() - Method in class org.apache.lucene.index.DocsAndPositionsEnum
Deprecated.
Returns the next position.
nextPosition() - Method in class org.apache.lucene.index.DocsEnum
Deprecated.
 
nextPosition() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
nextPosition() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
nextPosition() - Method in class org.apache.lucene.index.PostingsEnum
Returns the next position, or -1 if positions were not indexed.
nextSeekTerm(BytesRef) - Method in class org.apache.lucene.index.AutomatonTermsEnum
 
nextSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
On the first call to FilteredTermsEnum.next() or if FilteredTermsEnum.accept(org.apache.lucene.util.BytesRef) returns FilteredTermsEnum.AcceptStatus.YES_AND_SEEK or FilteredTermsEnum.AcceptStatus.NO_AND_SEEK, this method will be called to eventually seek the underlying TermsEnum to a new position.
nextSetBit(int) - Method in class org.apache.lucene.util.BitSet
Returns the index of the first set bit starting at the index specified.
nextSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
 
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.SparseFixedBitSet
 
nextStartPosition() - Method in class org.apache.lucene.search.spans.FilterSpans
 
nextStartPosition() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
nextStartPosition() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
nextStartPosition() - Method in class org.apache.lucene.search.spans.Spans
Returns the next start position for the current doc.
nextStartPosition() - Method in class org.apache.lucene.search.spans.TermSpans
 
NGramPhraseQuery - Class in org.apache.lucene.search
This is a PhraseQuery which is optimized for n-gram phrase query.
NGramPhraseQuery(int, PhraseQuery) - 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(Path, LockFactory) - Constructor for class org.apache.lucene.store.NIOFSDirectory
Create a new NIOFSDirectory for the named location.
NIOFSDirectory(Path) - Constructor for class org.apache.lucene.store.NIOFSDirectory
Create a new NIOFSDirectory for the named location and FSLockFactory.getDefault().
NO - Static variable in class org.apache.lucene.index.SegmentInfo
Used by some member fields to mean not present (e.g., norms, deletions).
NO_MORE_DOCS - Static variable in class org.apache.lucene.search.DocIdSetIterator
When returned by DocIdSetIterator.nextDoc(), DocIdSetIterator.advance(int) and DocIdSetIterator.docID() it means there are no more docs in the iterator.
NO_MORE_ORDS - Static variable in class org.apache.lucene.index.SortedSetDocValues
When returned by SortedSetDocValues.nextOrd() it means there are no more ordinals for the document.
NO_MORE_POSITIONS - Static variable in class org.apache.lucene.search.spans.Spans
 
NO_OUTPUT - Static variable in class org.apache.lucene.util.InfoStream
Instance of InfoStream that does no logging at all.
NoAfterEffect() - Constructor for class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
Sole constructor: parameter-free
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
NoDeletionPolicy - Class in org.apache.lucene.index
An IndexDeletionPolicy which keeps all index commits around, never deleting them.
NoLockFactory - Class in org.apache.lucene.store
Use this LockFactory to disable locking entirely.
noMatch(String, Collection<Explanation>) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a document which does not match.
noMatch(String, Explanation...) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a document which does not match.
NoMergePolicy - Class in org.apache.lucene.index
A MergePolicy which never returns merges to execute.
NoMergeScheduler - Class in org.apache.lucene.index
A MergeScheduler which never executes any merges.
NONE - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you don't require per-document postings in the returned enum.
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.blocktree.Stats
The number of normal (non-floor) blocks in the terms file.
NoNormalization() - Constructor for class org.apache.lucene.search.similarities.Normalization.NoNormalization
Sole constructor: parameter-free
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.
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.ConstantScoreWeight
 
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.
normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene53.Lucene53NormsFormat
 
NormsConsumer - Class in org.apache.lucene.codecs
Abstract API that consumes normalization values.
NormsConsumer() - Constructor for class org.apache.lucene.codecs.NormsConsumer
Sole constructor.
normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.NormsFormat
Returns a NormsConsumer to write norms to the index.
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.lucene53.Lucene53Codec
 
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.lucene53.Lucene53NormsFormat
 
normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.NormsFormat
Returns a NormsProducer to read norms from the index.
NormsProducer - Class in org.apache.lucene.codecs
Abstract API that produces field normalization values
NormsProducer() - Constructor for class org.apache.lucene.codecs.NormsProducer
Sole constructor.
normsProducers - Variable in class org.apache.lucene.index.MergeState
Norms producers being merged
NotDocIdSet - Class in org.apache.lucene.util
This DocIdSet encodes the negation of another DocIdSet.
NotDocIdSet(int, DocIdSet) - Constructor for class org.apache.lucene.util.NotDocIdSet
Sole constructor.
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
NullReader(int) - Constructor for class org.apache.lucene.util.packed.PackedInts.NullReader
Sole constructor.
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
 
numArcs - Variable in class org.apache.lucene.util.fst.FST.Arc
How many arcs in the array; only valid if bytesPerArc != 0.
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.LiveDocStatus
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.FilterCodecReader
 
numDocs() - Method in class org.apache.lucene.index.FilterLeafReader
 
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.ParallelLeafReader
 
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
 
NumericComparator(String, T) - Constructor for class org.apache.lucene.search.FieldComparator.NumericComparator
 
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 long value 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
Deprecated.
NumericRangeQuery<T extends Number> - Class in org.apache.lucene.search
A Query that matches numeric values within a specified range.
NumericTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
Creates, but does not yet initialize this attribute instance
NumericTokenStream - Class in org.apache.lucene.analysis
Expert: This class provides a TokenStream for indexing numeric values that can be used by NumericRangeQuery.
NumericTokenStream() - Constructor for class org.apache.lucene.analysis.NumericTokenStream
Creates a token stream for numeric values using the default precisionStep NumericUtils.PRECISION_STEP_DEFAULT (16).
NumericTokenStream(int) - Constructor for class org.apache.lucene.analysis.NumericTokenStream
Creates a token stream for numeric values with the specified precisionStep.
NumericTokenStream(AttributeFactory, int) - Constructor for class org.apache.lucene.analysis.NumericTokenStream
Expert: Creates a token stream for numeric values with the specified precisionStep using the given AttributeFactory.
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
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.LongRangeBuilder - Class in org.apache.lucene.util
numericValue() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
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
number of matches (computed in setFreqCurrentDoc)
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.

O

object - Variable in class org.apache.lucene.util.RefCount
 
obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.FSLockFactory
Implement this method to obtain a lock for a FSDirectory instance.
obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.NativeFSLockFactory
 
obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
 
obtainLock(String) - Method in class org.apache.lucene.store.BaseDirectory
 
obtainLock(String) - Method in class org.apache.lucene.store.Directory
Returns an obtained Lock.
obtainLock(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
obtainLock(String) - Method in class org.apache.lucene.store.FilterDirectory
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.FSLockFactory
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.LockFactory
Return a new obtained Lock instance identified by lockName.
obtainLock(Directory, String) - Method in class org.apache.lucene.store.NoLockFactory
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
 
obtainLock(String) - Method in class org.apache.lucene.store.SleepingLockWrapper
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.VerifyingLockFactory
 
of(DocIdSetIterator, int) - Static method in class org.apache.lucene.util.BitSet
Build a BitSet from the content of the provided DocIdSetIterator.
of(IndexInput, int, int, long, boolean) - Static method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
Sole constructor.
OfflineSorter - Class in org.apache.lucene.util
On-disk sorting of byte arrays.
OfflineSorter() - Constructor for class org.apache.lucene.util.OfflineSorter
Defaults constructor.
OfflineSorter(Comparator<BytesRef>) - Constructor for class org.apache.lucene.util.OfflineSorter
Defaults constructor with a custom comparator.
OfflineSorter(Comparator<BytesRef>, OfflineSorter.BufferSize, Path, int) - Constructor for class org.apache.lucene.util.OfflineSorter
All-details constructor.
OfflineSorter.BufferSize - Class in org.apache.lucene.util
A bit more descriptive unit for constructors.
OfflineSorter.ByteSequencesReader - Class in org.apache.lucene.util
Utility class to read length-prefixed byte[] entries from an input.
OfflineSorter.ByteSequencesWriter - Class in org.apache.lucene.util
Utility class to emit length-prefixed byte[] entries to an output stream for sorting.
OfflineSorter.SortInfo - Class in org.apache.lucene.util
Sort info (debugging mostly).
offset - Variable in class org.apache.lucene.util.BytesRef
Offset of first valid byte.
offset - Variable in class org.apache.lucene.util.CharsRef
Offset of first valid character.
offset - Variable in class org.apache.lucene.util.IntsRef
Offset of first valid integer.
offset - Variable in class org.apache.lucene.util.LongsRef
Offset of first valid long.
OffsetAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The start and end character offset of a Token.
OffsetAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of OffsetAttribute.
OffsetAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
Initialize this attribute with startOffset and endOffset of 0.
OFFSETS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require offsets in the returned enum.
OLD_NULL_SEMANTICS - Static variable in class org.apache.lucene.index.DocsAndPositionsEnum
Deprecated.
only for internal use.
OLD_SEGMENTS_GEN - Static variable in class org.apache.lucene.index.IndexFileNames
Name of the generation reference file name
omitNorms() - Method in enum org.apache.lucene.document.Field.Index
Deprecated.
 
omitNorms() - Method in class org.apache.lucene.document.FieldType
True if normalization values should be omitted for the field.
omitNorms() - Method in interface org.apache.lucene.index.IndexableFieldType
True if normalization values should be omitted for the field.
omitsNorms() - Method in class org.apache.lucene.index.FieldInfo
Returns true if norms are explicitly omitted for this field
onClear() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Expert: callback when the cache is completely cleared.
onClear() - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when the cache is completely cleared.
onClose(IndexReader) - Method in interface org.apache.lucene.index.IndexReader.ReaderClosedListener
Invoked when the IndexReader is closed.
onClose(Object) - Method in interface org.apache.lucene.index.LeafReader.CoreClosedListener
Invoked when the shared core of the original SegmentReader has closed.
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.IndexDeletionPolicy
This is called each time the writer completed a commit.
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
Deletes all commits except the most recent one.
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.NoDeletionPolicy
 
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
 
onDocIdSetCache(Object, long) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Expert: callback when a DocIdSet is added to this cache.
onDocIdSetCache(Object, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when a DocIdSet is added to this cache.
onDocIdSetEviction(Object, int, long) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Expert: callback when one or more DocIdSets are removed from this cache.
onDocIdSetEviction(Object, int, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when one or more DocIdSets are removed from this cache.
ONE_GB - Static variable in class org.apache.lucene.util.RamUsageEstimator
One gigabyte bytes.
ONE_KB - Static variable in class org.apache.lucene.util.RamUsageEstimator
One kilobyte bytes.
ONE_MB - Static variable in class org.apache.lucene.util.RamUsageEstimator
One megabyte bytes.
OneMerge(List<SegmentCommitInfo>) - Constructor for class org.apache.lucene.index.MergePolicy.OneMerge
Sole constructor.
onFilterCache(Filter, long) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Expert: callback when a filter is added to this cache.
onFilterEviction(Filter, long) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Expert: callback when a filter is evicted from this cache.
onHit(Object, Filter) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Expert: callback when there is a cache hit on a given filter.
onHit(Object, Query) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when there is a cache hit on a given query.
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.IndexDeletionPolicy
This is called once when a writer is first instantiated to give the policy a chance to remove old commit points.
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
Deletes all commits except the most recent one.
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.NoDeletionPolicy
 
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
 
onMiss(Object, Filter) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Expert: callback when there is a cache miss on a given filter.
onMiss(Object, Query) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when there is a cache miss on a given query.
onOrAfter(Version) - Method in class org.apache.lucene.util.Version
Returns true if this version is the same or after the version from the argument.
onQueryCache(Query, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when a query is added to this cache.
onQueryEviction(Query, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when a query is evicted from this cache.
onUse(Filter) - Method in class org.apache.lucene.search.FilterCachingPolicy.CacheOnLargeSegments
Deprecated.
 
onUse(Filter) - Method in interface org.apache.lucene.search.FilterCachingPolicy
Deprecated.
Callback that is called every time that a cached filter is used.
onUse(Query) - Method in class org.apache.lucene.search.QueryCachingPolicy.CacheOnLargeSegments
 
onUse(Query) - Method in interface org.apache.lucene.search.QueryCachingPolicy
Callback that is called every time that a cached filter is used.
onUse(Filter) - Method in class org.apache.lucene.search.UsageTrackingFilterCachingPolicy
 
onUse(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
 
open(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
Returns a IndexReader reading the index in the given Directory
open(IndexWriter, boolean) - Static method in class org.apache.lucene.index.DirectoryReader
Open a near real time IndexReader from the IndexWriter.
open(IndexCommit) - Static method in class org.apache.lucene.index.DirectoryReader
Expert: returns an IndexReader reading the index in the given IndexCommit.
open(Path) - Static method in class org.apache.lucene.store.FSDirectory
Creates an FSDirectory instance, trying to pick the best implementation given the current environment.
open(Path, LockFactory) - Static method in class org.apache.lucene.store.FSDirectory
Just like FSDirectory.open(Path), but allows you to also specify a custom LockFactory.
openChecksumInput(String, IOContext) - Method in class org.apache.lucene.store.Directory
Returns a stream reading an existing file, computing checksum as it reads
openIfChanged(DirectoryReader) - Static method in class org.apache.lucene.index.DirectoryReader
If the index has changed since the provided reader was opened, open and return a new reader; else, return null.
openIfChanged(DirectoryReader, IndexCommit) - Static method in class org.apache.lucene.index.DirectoryReader
If the IndexCommit differs from what the provided reader is searching, open and return a new reader; else, return null.
openIfChanged(DirectoryReader, IndexWriter, boolean) - Static method in class org.apache.lucene.index.DirectoryReader
Expert: If there changes (committed or not) in the IndexWriter versus what the provided reader is searching, then open and return a new IndexReader searching both committed and uncommitted changes from the writer; else, return null (though, the current implementation never returns null).
openInput(String, IOContext) - Method in class org.apache.lucene.store.Directory
Returns a stream reading an existing file.
openInput(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
openInput(String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
 
openInput(String, IOContext) - Method in class org.apache.lucene.store.MMapDirectory
Creates an IndexInput for the file with the given name.
openInput(String, IOContext) - Method in class org.apache.lucene.store.NIOFSDirectory
Creates an IndexInput for the file with the given name.
openInput(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
openInput(String, IOContext) - Method in class org.apache.lucene.store.RAMDirectory
Returns a stream reading an existing file.
openInput(String, IOContext) - Method in class org.apache.lucene.store.SimpleFSDirectory
Creates an IndexInput for the file with the given name.
openMode - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
openReaderPassed - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if we were able to open a CodecReader on this segment.
Operations - Class in org.apache.lucene.util.automaton
Automata operations.
optional(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the union of the empty string and the language of the given automaton.
or(DocIdSetIterator) - Method in class org.apache.lucene.util.BitDocIdSet.Builder
Add the content of the provided DocIdSetIterator to this builder.
or(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
Does in-place OR of the bits provided by the iterator.
or(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
 
or(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this OR other
or(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
this = this OR other
or(DocIdSetIterator) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
ord() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
ord() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
ord - Variable in class org.apache.lucene.index.LeafReaderContext
The readers ord in the top-level's leaves array
ord() - Method in class org.apache.lucene.index.MultiTermsEnum
 
ord - Variable in class org.apache.lucene.index.OrdTermState
Term ordinal, i.e.
ord() - Method in class org.apache.lucene.index.TermsEnum
Returns ordinal position for current term.
ord() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
ord() - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
Return the offset of the next value to read.
ord() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
Returns the current position
ord() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
Returns the current ord in the stream (number of values that have been written so far minus one).
ordAt(int) - Method in class org.apache.lucene.index.RandomAccessOrds
Retrieve the ordinal for the current document (previously set by SortedSetDocValues.setDocument(int) at the specified index.
ordInParent - Variable in class org.apache.lucene.index.IndexReaderContext
the ord for this reader in the parent, 0 if parent is null
OrdTermState - Class in org.apache.lucene.index
An ordinal based TermState
OrdTermState() - Constructor for class org.apache.lucene.index.OrdTermState
Sole constructor.
org.apache.lucene - package org.apache.lucene
Top-level package.
org.apache.lucene.analysis - package org.apache.lucene.analysis
Text analysis.
org.apache.lucene.analysis.tokenattributes - package org.apache.lucene.analysis.tokenattributes
General-purpose attributes for text analysis.
org.apache.lucene.codecs - package org.apache.lucene.codecs
Codecs API: API for customization of the encoding and structure of the index.
org.apache.lucene.codecs.blocktree - package org.apache.lucene.codecs.blocktree
BlockTree terms dictionary.
org.apache.lucene.codecs.compressing - package org.apache.lucene.codecs.compressing
StoredFieldsFormat that allows cross-document and cross-field compression of stored fields.
org.apache.lucene.codecs.lucene50 - package org.apache.lucene.codecs.lucene50
Components from the Lucene 5.0 index format See org.apache.lucene.codecs.lucene53 for an overview of the index format.
org.apache.lucene.codecs.lucene53 - package org.apache.lucene.codecs.lucene53
Lucene 5.3 file format.
org.apache.lucene.codecs.perfield - package org.apache.lucene.codecs.perfield
Postings format that can delegate to different formats per-field.
org.apache.lucene.document - package org.apache.lucene.document
The logical representation of a Document for indexing and searching.
org.apache.lucene.index - package org.apache.lucene.index
Code to maintain and access indices.
org.apache.lucene.search - package org.apache.lucene.search
Code to search indices.
org.apache.lucene.search.payloads - package org.apache.lucene.search.payloads
The payloads package provides Query mechanisms for finding and using payloads.
org.apache.lucene.search.similarities - package org.apache.lucene.search.similarities
This package contains the various ranking models that can be used in Lucene.
org.apache.lucene.search.spans - package org.apache.lucene.search.spans
The calculus of spans.
org.apache.lucene.store - package org.apache.lucene.store
Binary i/o API, used for all index data.
org.apache.lucene.util - package org.apache.lucene.util
Some utility classes.
org.apache.lucene.util.automaton - package org.apache.lucene.util.automaton
Finite-state automaton for regular expressions.
org.apache.lucene.util.fst - package org.apache.lucene.util.fst
Finite state transducers
org.apache.lucene.util.mutable - package org.apache.lucene.util.mutable
Comparable object wrappers
org.apache.lucene.util.packed - package org.apache.lucene.util.packed
Packed integer arrays and streams.
OS_ARCH - Static variable in class org.apache.lucene.util.Constants
 
OS_NAME - Static variable in class org.apache.lucene.util.Constants
The value of System.getProperty("os.name").
OS_VERSION - Static variable in class org.apache.lucene.util.Constants
 
out - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
output - Variable in class org.apache.lucene.util.fst.Builder.Arc
 
output - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
output - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
output - Variable in class org.apache.lucene.util.fst.FST.Arc
 
output - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
 
output - Variable in class org.apache.lucene.util.fst.Util.Result
 
output1 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
 
output2 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
 
outputs - Variable in class org.apache.lucene.util.fst.FST
 
Outputs<T> - Class in org.apache.lucene.util.fst
Represents the outputs for an FST, providing the basic algebra required for building and traversing the FST.
Outputs() - Constructor for class org.apache.lucene.util.fst.Outputs
 
OutputStreamDataOutput - Class in org.apache.lucene.store
A DataOutput wrapping a plain OutputStream.
OutputStreamDataOutput(OutputStream) - Constructor for class org.apache.lucene.store.OutputStreamDataOutput
 
OutputStreamIndexOutput - Class in org.apache.lucene.store
Implementation class for buffered IndexOutput that writes to an OutputStream.
OutputStreamIndexOutput(String, OutputStream, int) - Constructor for class org.apache.lucene.store.OutputStreamIndexOutput
Creates a new OutputStreamIndexOutput with the given buffer size.
outputToString(BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
outputToString(CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
outputToString(IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
outputToString(Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
outputToString(T) - Method in class org.apache.lucene.util.fst.Outputs
 
outputToString(PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
outputToString(Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
overheadPerValue(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the overhead per value, in bits.
overheadRatio(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the overhead ratio (overhead per value / bits per value).
oversize(int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array size >= minTargetSize, generally over-allocating exponentially to achieve amortized linear-time cost as the array grows.

P

packedBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
Return a new PackedLongValues.Builder that will compress efficiently positive integers.
packedBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
 
PackedDataInput - Class in org.apache.lucene.util.packed
A DataInput wrapper to read unaligned, variable-length packed integers.
PackedDataInput(DataInput) - Constructor for class org.apache.lucene.util.packed.PackedDataInput
Create a new instance that wraps in.
PackedDataOutput - Class in org.apache.lucene.util.packed
A DataOutput wrapper to write unaligned, variable-length packed integers.
PackedDataOutput(DataOutput) - Constructor for class org.apache.lucene.util.packed.PackedDataOutput
Create a new instance that wraps out.
PackedInts - Class in org.apache.lucene.util.packed
Simplistic compression for array of unsigned long values.
PackedInts() - Constructor for class org.apache.lucene.util.packed.PackedInts
 
PackedInts.Decoder - Interface in org.apache.lucene.util.packed
A decoder for packed integers.
PackedInts.Encoder - Interface in org.apache.lucene.util.packed
An encoder for packed integers.
PackedInts.Format - Enum in org.apache.lucene.util.packed
A format to write packed ints.
PackedInts.FormatAndBits - Class in org.apache.lucene.util.packed
Simple class that holds a format and a number of bits per value.
PackedInts.Mutable - Class in org.apache.lucene.util.packed
A packed integer array that can be modified.
PackedInts.NullReader - Class in org.apache.lucene.util.packed
A PackedInts.Reader which has all its values equal to 0 (bitsPerValue = 0).
PackedInts.Reader - Class in org.apache.lucene.util.packed
A read-only random access array of positive integers.
PackedInts.ReaderIterator - Interface in org.apache.lucene.util.packed
Run-once iterator interface, to decode previously saved PackedInts.
PackedInts.Writer - Class in org.apache.lucene.util.packed
A write-once Writer.
PackedLongValues - Class in org.apache.lucene.util.packed
Utility class to compress integers into a LongValues instance.
PackedLongValues.Builder - Class in org.apache.lucene.util.packed
A Builder for a PackedLongValues instance.
PackedLongValues.Iterator - Class in org.apache.lucene.util.packed
An iterator over long values.
PackedTokenAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of the common attributes used by Lucene: CharTermAttribute TypeAttribute PositionIncrementAttribute PositionLengthAttribute OffsetAttribute
PackedTokenAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Constructs the attribute implementation.
PagedBytes - Class in org.apache.lucene.util
Represents a logical byte[] as a series of pages.
PagedBytes(int) - Constructor for class org.apache.lucene.util.PagedBytes
1<<blockBits must be bigger than biggest single BytesRef slice that will be pulled
PagedBytes.PagedBytesDataInput - Class in org.apache.lucene.util
 
PagedBytes.PagedBytesDataOutput - Class in org.apache.lucene.util
 
PagedBytes.Reader - Class in org.apache.lucene.util
Provides methods to read BytesRefs from a frozen PagedBytes.
PagedBytesDataOutput() - Constructor for class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
 
PagedGrowableWriter - Class in org.apache.lucene.util.packed
PagedGrowableWriter(long, int, int, float) - Constructor for class org.apache.lucene.util.packed.PagedGrowableWriter
Create a new PagedGrowableWriter instance.
PagedMutable - Class in org.apache.lucene.util.packed
PagedMutable(long, int, int, float) - Constructor for class org.apache.lucene.util.packed.PagedMutable
Create a new PagedMutable instance.
PairOutputs<A,B> - Class in org.apache.lucene.util.fst
An FST Outputs implementation, holding two other outputs.
PairOutputs(Outputs<A>, Outputs<B>) - Constructor for class org.apache.lucene.util.fst.PairOutputs
 
PairOutputs.Pair<A,B> - Class in org.apache.lucene.util.fst
Holds a single pair of two outputs.
ParallelCompositeReader - Class in org.apache.lucene.index
An CompositeReader which reads multiple, parallel indexes.
ParallelCompositeReader(CompositeReader...) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
Create a ParallelCompositeReader based on the provided readers; auto-closes the given readers on IndexReader.close().
ParallelCompositeReader(boolean, CompositeReader...) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
Create a ParallelCompositeReader based on the provided readers.
ParallelCompositeReader(boolean, CompositeReader[], CompositeReader[]) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
Expert: create a ParallelCompositeReader based on the provided readers and storedFieldReaders; when a document is loaded, only storedFieldsReaders will be used.
ParallelLeafReader - Class in org.apache.lucene.index
An LeafReader which reads multiple, parallel indexes.
ParallelLeafReader(LeafReader...) - Constructor for class org.apache.lucene.index.ParallelLeafReader
Create a ParallelLeafReader based on the provided readers; auto-closes the given readers on IndexReader.close().
ParallelLeafReader(boolean, LeafReader...) - Constructor for class org.apache.lucene.index.ParallelLeafReader
Create a ParallelLeafReader based on the provided readers.
ParallelLeafReader(boolean, LeafReader[], LeafReader[]) - Constructor for class org.apache.lucene.index.ParallelLeafReader
Expert: create a ParallelLeafReader based on the provided readers and storedFieldReaders; when a document is loaded, only storedFieldsReaders will be used.
parent - Variable in class org.apache.lucene.index.IndexReaderContext
The reader context for this reader's immediate parent, or null if none
parentQuery - Variable in class org.apache.lucene.search.Weight
 
parse(String) - Static method in class org.apache.lucene.util.Version
Parse a version number of the form "major.minor.bugfix.prerelease".
parseGeneration(String) - Static method in class org.apache.lucene.index.IndexFileNames
Returns the generation from this file name, or 0 if there is no generation.
parseInt(char[]) - Static method in class org.apache.lucene.util.ArrayUtil
Parses the string argument as if it was an int value and returns the result.
parseInt(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Parses a char array into an int.
parseInt(char[], int, int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Parses the string argument as if it was an int value and returns the result.
parseLeniently(String) - Static method in class org.apache.lucene.util.Version
Parse the given version number as a constant or dot based version.
parseSegmentName(String) - Static method in class org.apache.lucene.index.IndexFileNames
Parses the segment name out of the given file name.
partial - Variable in class org.apache.lucene.index.CheckIndex.Status
True if we checked only specific segments (CheckIndex.checkIndex(List)) was called with non-null argument).
pause(long) - Method in class org.apache.lucene.index.MergeRateLimiter
 
pause(long) - Method in class org.apache.lucene.store.RateLimiter
Pauses, if necessary, to keep the instantaneous IO rate at or below the target.
pause(long) - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
Pauses, if necessary, to keep the instantaneous IO rate at or below the target.
PAY_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
Filename extension for payloads and offsets.
PayloadAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The payload of a Token.
PayloadAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of PayloadAttribute.
PayloadAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Initialize this attribute with no payload.
PayloadAttributeImpl(BytesRef) - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Initialize this attribute with the given payload.
PayloadFunction - Class in org.apache.lucene.search.payloads
An abstract class that defines a way for Payload*Query instances to transform the cumulative effects of payload scores for a document.
PayloadFunction() - Constructor for class org.apache.lucene.search.payloads.PayloadFunction
 
PayloadNearQuery - Class in org.apache.lucene.search.payloads
Deprecated.
PayloadNearQuery(SpanQuery[], int, boolean) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery
Deprecated.
 
PayloadNearQuery(SpanQuery[], int, boolean, PayloadFunction) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery
Deprecated.
 
PayloadNearQuery.PayloadNearSpanScorer - Class in org.apache.lucene.search.payloads
Deprecated.
 
PayloadNearQuery.PayloadNearSpanWeight - Class in org.apache.lucene.search.payloads
Deprecated.
 
PayloadNearSpanScorer(Spans, SpanWeight, Similarity.SimScorer) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
Deprecated.
 
PayloadNearSpanWeight(List<SpanWeight>, IndexSearcher, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
Deprecated.
 
PAYLOADS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require payloads in the returned enum.
payloadScore - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
Deprecated.
 
PayloadScoreQuery - Class in org.apache.lucene.search.payloads
A Query class that uses a PayloadFunction to modify the score of a wrapped SpanQuery NOTE: In order to take advantage of this with the default scoring implementation (DefaultSimilarity), you must override DefaultSimilarity.scorePayload(int, int, int, BytesRef), which returns 1 by default.
PayloadScoreQuery(SpanQuery, PayloadFunction) - Constructor for class org.apache.lucene.search.payloads.PayloadScoreQuery
Creates a new PayloadScoreQuery
PayloadSpanCollector - Class in org.apache.lucene.search.payloads
SpanCollector for collecting payloads
PayloadSpanCollector() - Constructor for class org.apache.lucene.search.payloads.PayloadSpanCollector
 
PayloadSpanUtil - Class in org.apache.lucene.search.payloads
Experimental class to get set of payloads for most standard Lucene queries.
PayloadSpanUtil(IndexReaderContext) - Constructor for class org.apache.lucene.search.payloads.PayloadSpanUtil
 
PayloadTermQuery - Class in org.apache.lucene.search.payloads
Deprecated.
PayloadTermQuery(Term, PayloadFunction) - Constructor for class org.apache.lucene.search.payloads.PayloadTermQuery
Deprecated.
 
PayloadTermQuery(Term, PayloadFunction, boolean) - Constructor for class org.apache.lucene.search.payloads.PayloadTermQuery
Deprecated.
 
payloadToMatch - Variable in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
PENDING_SEGMENTS - Static variable in class org.apache.lucene.index.IndexFileNames
Name of pending index segment file
PER_FIELD_FORMAT_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
FieldInfo attribute name used to store the format name for each field.
PER_FIELD_FORMAT_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
FieldInfo attribute name used to store the format name for each field.
PER_FIELD_NAME - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
Name of this PostingsFormat.
PER_FIELD_NAME - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
Name of this PostingsFormat.
PER_FIELD_REUSE_STRATEGY - Static variable in class org.apache.lucene.analysis.Analyzer
A predefined Analyzer.ReuseStrategy that reuses components per-field by maintaining a Map of TokenStreamComponent per field name.
PER_FIELD_SUFFIX_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
FieldInfo attribute name used to store the segment suffix name for each field.
PER_FIELD_SUFFIX_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
FieldInfo attribute name used to store the segment suffix name for each field.
PerFieldDocValuesFormat - Class in org.apache.lucene.codecs.perfield
Enables per field docvalues support.
PerFieldDocValuesFormat() - Constructor for class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
Sole constructor.
PerFieldPostingsFormat - Class in org.apache.lucene.codecs.perfield
Enables per field postings support.
PerFieldPostingsFormat() - Constructor for class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
Sole constructor.
PerFieldSimilarityWrapper - Class in org.apache.lucene.search.similarities
Provides the ability to use a different Similarity for different fields.
PerFieldSimilarityWrapper() - Constructor for class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
Sole constructor.
PersistentSnapshotDeletionPolicy - Class in org.apache.lucene.index
A SnapshotDeletionPolicy which adds a persistence layer so that snapshots can be maintained across the life of an application.
PersistentSnapshotDeletionPolicy(IndexDeletionPolicy, Directory) - Constructor for class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
PersistentSnapshotDeletionPolicy wraps another IndexDeletionPolicy to enable flexible snapshotting, passing IndexWriterConfig.OpenMode.CREATE_OR_APPEND by default.
PersistentSnapshotDeletionPolicy(IndexDeletionPolicy, Directory, IndexWriterConfig.OpenMode) - Constructor for class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
PersistentSnapshotDeletionPolicy wraps another IndexDeletionPolicy to enable flexible snapshotting.
perThreadHardLimitMB - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Sets the hard upper bound on RAM usage for a single segment, after which the segment is forced to flush.
PhraseQuery - Class in org.apache.lucene.search
A Query that matches documents containing a particular sequence of terms.
PhraseQuery(int, String, String...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field, and at a maximum edit distance of slop.
PhraseQuery(String, String...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field.
PhraseQuery(int, String, BytesRef...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field, and at a maximum edit distance of slop.
PhraseQuery(String, BytesRef...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field.
PhraseQuery() - Constructor for class org.apache.lucene.search.PhraseQuery
Deprecated.
Use the PhraseQuery.Builder class to build phrase queries.
PhraseQuery.Builder - Class in org.apache.lucene.search
A builder for phrase queries.
pop() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
pop() - Method in class org.apache.lucene.util.PriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.
pop_andnot(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
Returns the popcount or cardinality of A & ~B.
pop_array(long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
Returns the number of set bits in an array of longs.
pop_intersect(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
Returns the popcount or cardinality of the two sets after an intersection.
pop_union(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
Returns the popcount or cardinality of the union of two sets.
pop_xor(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
Returns the popcount or cardinality of A ^ B Neither array is modified.
populateResults(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopDocsCollector
Populates the results array with the ScoreDoc instances.
populateResults(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopFieldCollector
 
POS_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
Filename extension for positions.
POS_SEP - Static variable in class org.apache.lucene.analysis.TokenStreamToAutomaton
We create transition between two adjacent tokens.
posArcsStart - Variable in class org.apache.lucene.util.fst.FST.Arc
Where the first arc in the array starts; only valid if bytesPerArc != 0
position - Variable in class org.apache.lucene.search.spans.TermSpans
 
PositionIncrementAttribute - Interface in org.apache.lucene.analysis.tokenattributes
Determines the position of this token relative to the previous Token in a TokenStream, used in phrase searching.
PositionIncrementAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of PositionIncrementAttribute.
PositionIncrementAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
Initialize this attribute with position increment of 1
PositionLengthAttribute - Interface in org.apache.lucene.analysis.tokenattributes
Determines how many positions this token spans.
PositionLengthAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of PositionLengthAttribute.
PositionLengthAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
Initializes this attribute with position length of 1.
POSITIONS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require term positions in the returned enum.
PositiveIntOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a non-negative long value.
PositiveScoresOnlyCollector - Class in org.apache.lucene.search
A Collector implementation which wraps another Collector and makes sure only documents with scores > 0 are collected.
PositiveScoresOnlyCollector(Collector) - Constructor for class org.apache.lucene.search.PositiveScoresOnlyCollector
 
postings(FieldInfo, BlockTermState, PostingsEnum, int) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
 
postings(FieldInfo, BlockTermState, PostingsEnum, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
Must fully consume state, since after this call that TermState may be reused.
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.FilteredTermsEnum
 
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
postings(Term, int) - Method in class org.apache.lucene.index.LeafReader
Returns PostingsEnum for the specified term.
postings(Term) - Method in class org.apache.lucene.index.LeafReader
Returns PostingsEnum for the specified term with PostingsEnum.FREQS.
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.MultiTermsEnum
 
postings(PostingsEnum) - Method in class org.apache.lucene.index.TermsEnum
Get PostingsEnum for the current term.
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
Get PostingsEnum for the current term, with control over whether freqs, positions, offsets or payloads are required.
postings(PostingsEnum, int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
postings - Variable in class org.apache.lucene.search.spans.TermSpans
 
postingsEnum - Variable in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
PostingsEnum for this sub-reader.
PostingsEnum - Class in org.apache.lucene.index
Iterates through the postings.
PostingsEnum() - Constructor for class org.apache.lucene.index.PostingsEnum
Sole constructor.
postingsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes postings
postingsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
postingsFormat() - Method in class org.apache.lucene.codecs.lucene53.Lucene53Codec
 
PostingsFormat - Class in org.apache.lucene.codecs
Encodes/decodes terms, postings, and proximity data.
PostingsFormat(String) - Constructor for class org.apache.lucene.codecs.PostingsFormat
Creates a new postings format.
PostingsReaderBase - Class in org.apache.lucene.codecs
The core terms dictionaries (BlockTermsReader, BlockTreeTermsReader) interact with a single instance of this class to manage creation of PostingsEnum and PostingsEnum instances.
PostingsReaderBase() - Constructor for class org.apache.lucene.codecs.PostingsReaderBase
Sole constructor.
PostingsWriterBase - Class in org.apache.lucene.codecs
Class that plugs into term dictionaries, such as BlockTreeTermsWriter, and handles writing postings.
PostingsWriterBase() - Constructor for class org.apache.lucene.codecs.PostingsWriterBase
Sole constructor.
pq - Variable in class org.apache.lucene.search.TopDocsCollector
The priority queue which holds the top documents.
PRECISION_STEP_DEFAULT - Static variable in class org.apache.lucene.util.NumericUtils
The default precision step used by LongField, DoubleField, NumericTokenStream, NumericRangeQuery.
PRECISION_STEP_DEFAULT_32 - Static variable in class org.apache.lucene.util.NumericUtils
The default precision step used by IntField and FloatField.
predicateFunction(InnerT) - Method in class org.apache.lucene.util.FilterIterator
returns true, if this element should be returned by FilterIterator.next().
PrefixCodedTerms - Class in org.apache.lucene.index
Prefix codes term instances (prefixes are shared)
PrefixCodedTerms.Builder - Class in org.apache.lucene.index
Builds a PrefixCodedTerms: call add repeatedly, then finish.
PrefixCodedTerms.TermIterator - Class in org.apache.lucene.index
An iterator over the list of terms stored in a PrefixCodedTerms.
prefixCodedToInt(BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
Returns an int from prefixCoded bytes.
prefixCodedToLong(BytesRef) - Static method in class org.apache.lucene.util.NumericUtils
Returns a long from prefixCoded bytes.
PrefixFilter - Class in org.apache.lucene.search
Deprecated.
Use PrefixQuery and BooleanClause.Occur.FILTER clauses instead.
PrefixFilter(Term) - Constructor for class org.apache.lucene.search.PrefixFilter
Deprecated.
 
PrefixQuery - Class in org.apache.lucene.search
A Query that matches documents containing terms with a specified prefix.
PrefixQuery(Term) - Constructor for class org.apache.lucene.search.PrefixQuery
Constructs a query for terms starting with prefix.
prepareCommit() - Method in class org.apache.lucene.index.IndexWriter
Expert: prepare for commit.
prepareCommit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
The first stage of a 2-phase commit.
PrepareCommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.PrepareCommitFailException
Sole constructor.
prependOutput(T) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
prerelease - Variable in class org.apache.lucene.util.Version
Prerelease version, currently 0 (alpha), 1 (beta), or 2 (final)
prevSetBit(int) - Method in class org.apache.lucene.util.BitSet
Returns the index of the last set bit before or on the index specified.
prevSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
 
prevSetBit(long) - Method in class org.apache.lucene.util.LongBitSet
Returns the index of the last set bit before or on the index specified.
prevSetBit(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
PrintStreamInfoStream - Class in org.apache.lucene.util
InfoStream implementation over a PrintStream such as System.out.
PrintStreamInfoStream(PrintStream) - Constructor for class org.apache.lucene.util.PrintStreamInfoStream
 
PrintStreamInfoStream(PrintStream, int) - Constructor for class org.apache.lucene.util.PrintStreamInfoStream
 
PriorityQueue<T> - Class in org.apache.lucene.util
A PriorityQueue maintains a partial ordering of its elements such that the least element can always be found in constant time.
PriorityQueue(int) - Constructor for class org.apache.lucene.util.PriorityQueue
 
PriorityQueue(int, boolean) - Constructor for class org.apache.lucene.util.PriorityQueue
 
processPayloads(Collection<byte[]>, int, int) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
Deprecated.
By default, uses the PayloadFunction to score the payloads, but can be overridden to do other things.
prune(SearcherLifetimeManager.Pruner) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Calls provided SearcherLifetimeManager.Pruner to prune entries.
PruneByAge(double) - Constructor for class org.apache.lucene.search.SearcherLifetimeManager.PruneByAge
 
PushPostingsWriterBase - Class in org.apache.lucene.codecs
Extension of PostingsWriterBase, adding a push API for writing each element of the postings.
PushPostingsWriterBase() - Constructor for class org.apache.lucene.codecs.PushPostingsWriterBase
Sole constructor.
put(K, V) - Method in class org.apache.lucene.util.MapOfSets
Adds val to the Set associated with key in the Map.
put(int) - Method in class org.apache.lucene.util.SentinelIntSet
Puts this integer (key) in the set, and returns the slot index it was added to.
put(K, V) - Method in class org.apache.lucene.util.WeakIdentityMap
Associates the specified value with the specified key in this map.
putAll(K, Collection<? extends V>) - Method in class org.apache.lucene.util.MapOfSets
Adds multiple vals to the Set associated with key in the Map.
putAttribute(String, String) - Method in class org.apache.lucene.index.FieldInfo
Puts a codec attribute value.
putAttribute(String, String) - Method in class org.apache.lucene.index.SegmentInfo
Puts a codec attribute value.

Q

query - Variable in class org.apache.lucene.search.ConstantScoreQuery
 
query - Variable in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
 
Query - Class in org.apache.lucene.search
The abstract base class for queries.
Query() - Constructor for class org.apache.lucene.search.Query
 
query - Variable in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
QUERY_FIRST_FILTER_STRATEGY - Static variable in class org.apache.lucene.search.FilteredQuery
Deprecated.
A filter strategy that advances the Query or rather its Scorer first and consults the filter DocIdSet for each matched document.
queryBoost - Variable in class org.apache.lucene.search.similarities.BasicStats
Query's inner boost.
QueryBuilder - Class in org.apache.lucene.util
Creates queries from the Analyzer chain.
QueryBuilder(Analyzer) - Constructor for class org.apache.lucene.util.QueryBuilder
Creates a new QueryBuilder using the given analyzer.
QueryCache - Interface in org.apache.lucene.search
A cache for queries.
QueryCachingPolicy - Interface in org.apache.lucene.search
A policy defining which filters should be cached.
QueryCachingPolicy.CacheOnLargeSegments - Class in org.apache.lucene.search
A simple policy that only caches on the largest segments of an index.
queryNorm(float) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
Implemented as 1/sqrt(sumOfSquaredWeights).
queryNorm(float) - Method in class org.apache.lucene.search.similarities.Similarity
Computes the normalization value for a query given the sum of the normalized weights Similarity.SimWeight.getValueForNormalization() of each of the query terms.
queryNorm(float) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Computes the normalization value for a query given the sum of the squared weights of each of the query terms.
QueryRescorer - Class in org.apache.lucene.search
A Rescorer that uses a provided Query to assign scores to the first-pass hits.
QueryRescorer(Query) - Constructor for class org.apache.lucene.search.QueryRescorer
Sole constructor, passing the 2nd pass query to assign scores to the 1st pass hits.
QueryTimeout - Interface in org.apache.lucene.index
Base for query timeout implementations, which will provide a shouldExit() method, used with ExitableDirectoryReader.
QueryTimeoutImpl - Class in org.apache.lucene.index
An implementation of QueryTimeout that can be used by the ExitableDirectoryReader class to time out and exit out when a query takes a long time to rewrite.
QueryTimeoutImpl(long) - Constructor for class org.apache.lucene.index.QueryTimeoutImpl
Sets the time at which to time out by adding the given timeAllowed to the current time.
QueryWrapperFilter - Class in org.apache.lucene.search
Constrains search results to only match those which also match a provided query.
QueryWrapperFilter(Query) - Constructor for class org.apache.lucene.search.QueryWrapperFilter
Constructs a filter which only matches documents matching query.

R

ramBytesUsed() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexReader
 
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.lucene50.Lucene50PostingsReader
 
ramBytesUsed() - Method in class org.apache.lucene.index.CodecReader
 
ramBytesUsed() - Method in class org.apache.lucene.index.IndexWriter
 
ramBytesUsed() - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
 
ramBytesUsed() - Method in class org.apache.lucene.index.PrefixCodedTerms
 
ramBytesUsed() - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
 
ramBytesUsed() - Method in class org.apache.lucene.search.CachingWrapperQuery
 
ramBytesUsed() - Method in class org.apache.lucene.search.DocValuesDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.search.FilteredDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
 
ramBytesUsed(Filter) - Method in class org.apache.lucene.search.LRUFilterCache
Deprecated.
Return the number of bytes used by the given filter.
ramBytesUsed() - Method in class org.apache.lucene.search.LRUQueryCache
 
ramBytesUsed(Query) - Method in class org.apache.lucene.search.LRUQueryCache
Return the number of bytes used by the given query.
ramBytesUsed() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
ramBytesUsed() - Method in class org.apache.lucene.store.RAMDirectory
Return total size in bytes of all files in this directory.
ramBytesUsed() - Method in class org.apache.lucene.store.RAMFile
 
ramBytesUsed() - Method in class org.apache.lucene.store.RAMOutputStream
Returns byte usage of all buffers.
ramBytesUsed() - Method in interface org.apache.lucene.util.Accountable
Return the memory usage of this object in bytes.
ramBytesUsed() - Method in class org.apache.lucene.util.automaton.Automaton
 
ramBytesUsed() - Method in class org.apache.lucene.util.BitDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.FixedBitSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
 
ramBytesUsed(BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
ramBytesUsed(CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
ramBytesUsed() - Method in class org.apache.lucene.util.fst.FST
 
ramBytesUsed(IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
ramBytesUsed(Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
ramBytesUsed(T) - Method in class org.apache.lucene.util.fst.Outputs
Return memory usage for the provided output.
ramBytesUsed(PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
ramBytesUsed(Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
ramBytesUsed() - Method in class org.apache.lucene.util.NotDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.BlockPackedReader
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedLongValues
 
ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes
 
ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes.Reader
 
ramBytesUsed() - Method in class org.apache.lucene.util.RoaringDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.SentinelIntSet
Return the memory footprint of this class in bytes.
ramBytesUsed() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
RAMDirectory - Class in org.apache.lucene.store
A memory-resident Directory implementation.
RAMDirectory() - Constructor for class org.apache.lucene.store.RAMDirectory
Constructs an empty Directory.
RAMDirectory(LockFactory) - Constructor for class org.apache.lucene.store.RAMDirectory
Constructs an empty Directory with the given LockFactory.
RAMDirectory(FSDirectory, IOContext) - Constructor for class org.apache.lucene.store.RAMDirectory
Creates a new RAMDirectory instance from a different Directory implementation.
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
A memory-resident IndexInput implementation.
RAMInputStream(String, RAMFile) - Constructor for class org.apache.lucene.store.RAMInputStream
 
RAMOutputStream - Class in org.apache.lucene.store
A memory-resident IndexOutput implementation.
RAMOutputStream() - Constructor for class org.apache.lucene.store.RAMOutputStream
Construct an empty output buffer.
RAMOutputStream(RAMFile, boolean) - Constructor for class org.apache.lucene.store.RAMOutputStream
Creates this, with no name.
RAMOutputStream(String, RAMFile, boolean) - Constructor for class org.apache.lucene.store.RAMOutputStream
Creates this, with specified name.
RamUsageEstimator - Class in org.apache.lucene.util
Estimates the size (memory representation) of Java objects.
RANDOM_ACCESS_FILTER_STRATEGY - Static variable in class org.apache.lucene.search.FilteredQuery
Deprecated.
A FilteredQuery.FilterStrategy that conditionally uses a random access filter if the given DocIdSet supports random access (returns a non-null value from DocIdSet.bits()) and FilteredQuery.RandomAccessFilterStrategy.useRandomAccess(Bits, long) returns true.
RandomAccessFilterStrategy() - Constructor for class org.apache.lucene.search.FilteredQuery.RandomAccessFilterStrategy
Deprecated.
 
RandomAccessInput - Interface in org.apache.lucene.store
Random Access Index API.
RandomAccessOrds - Class in org.apache.lucene.index
Extension of SortedSetDocValues that supports random access to the ordinals of a document.
RandomAccessOrds() - Constructor for class org.apache.lucene.index.RandomAccessOrds
Sole constructor.
randomAccessSlice(long, long) - Method in class org.apache.lucene.store.IndexInput
Creates a random-access slice of this index input, with the given offset and length.
RandomAccessWeight - Class in org.apache.lucene.search
Base class to build Weights that are based on random-access structures such as live docs or doc values.
RandomAccessWeight(Query) - Constructor for class org.apache.lucene.search.RandomAccessWeight
Sole constructor.
randomId() - Static method in class org.apache.lucene.util.StringHelper
Generates a non-cryptographic globally unique id.
RateLimitedIndexOutput - Class in org.apache.lucene.store
RateLimitedIndexOutput(RateLimiter, IndexOutput) - Constructor for class org.apache.lucene.store.RateLimitedIndexOutput
 
rateLimiter - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
A private RateLimiter for this merge, used to rate limit writes and abort.
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.
raw - Variable in class org.apache.lucene.search.FuzzyTermsEnum
 
rawNormalizationValue() - Method in class org.apache.lucene.search.similarities.BasicStats
Computes the raw normalization value.
read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.FieldInfosFormat
read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50FieldInfosFormat
 
read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50SegmentInfoFormat
 
read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.SegmentInfoFormat
Read SegmentInfo data from a directory.
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(Path, 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
Decode an output value previously written with Outputs.write(Object, DataOutput).
read(DataInput) - Method in class org.apache.lucene.util.fst.PairOutputs
 
read(DataInput) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
read(BytesRefBuilder) - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
Reads the next entry into the provided BytesRef.
read() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
Reads the next entry and returns it if successful.
readByte() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
readByte() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readByte(long) - 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.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(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads a byte at the given position in the file
readByte() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
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.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.
readCommit(Directory, String) - Static method in class org.apache.lucene.index.SegmentInfos
Read a particular segmentFileName.
readCRC(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Reads CRC32 value as a 64-bit long from the input.
reader() - Method in class org.apache.lucene.index.CompositeReaderContext
 
reader() - Method in class org.apache.lucene.index.IndexReaderContext
Returns the IndexReader, this context represents.
reader() - Method in class org.apache.lucene.index.LeafReaderContext
 
Reader() - Constructor for class org.apache.lucene.util.packed.PackedInts.Reader
 
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.
ReaderManager(DirectoryReader) - Constructor for class org.apache.lucene.index.ReaderManager
Creates and returns a new ReaderManager from the given already-opened DirectoryReader, stealing the incoming reference.
readerPooling - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
True if readers should be pooled.
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
Common util methods for dealing with IndexReaders and IndexReaderContexts.
readerValue() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
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
Decode an output value previously written with Outputs.writeFinalOutput(Object, DataOutput).
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 follow arc and read the first arc of its target; this changes the provided arc (2nd arg) in-place and returns it.
readInt() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readInt(long) - 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(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads an integer at the given position in the file
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.
readLabel(DataInput) - Method in class org.apache.lucene.util.fst.FST
Reads one BYTE1/2/4 label from the provided DataInput.
readLastTargetArc(FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
Follows the follow arc and reads the last arc of its target; this changes the provided arc (2nd arg) in-place and returns it.
readLatestCommit(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
Find the latest commit (segments_N file) and load all SegmentCommitInfos.
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.lucene50.Lucene50LiveDocsFormat
 
readLong() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readLong(long) - 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(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads a long at the given position in the file
readLong(int) - Method in class org.apache.lucene.util.packed.PackedDataInput
Read the next long using exactly bitsPerValue bits.
readMapOfStrings() - Method in class org.apache.lucene.store.DataInput
Reads a Map<String,String> previously written with DataOutput.writeMapOfStrings(Map).
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
 
readSetOfStrings() - Method in class org.apache.lucene.store.DataInput
Reads a Set<String> previously written with DataOutput.writeSetOfStrings(Set).
readShort() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readShort(long) - 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.
readShort(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads a short at the given position in the file
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
Deprecated.
Only for reading existing formats. Encode maps with DataOutput.writeSetOfStrings(Set) instead.
readStringStringMap() - Method in class org.apache.lucene.store.DataInput
Deprecated.
Only for reading existing formats. Encode maps with DataOutput.writeMapOfStrings(Map) instead.
readTime - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
time spent in i/o read (in milliseconds)
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.
readZInt() - Method in class org.apache.lucene.store.DataInput
Read a zig-zag-encoded variable-length integer.
readZLong() - Method in class org.apache.lucene.store.DataInput
Read a zig-zag-encoded variable-length integer.
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
A ByteBlockPool.Allocator implementation that recycles unused byte blocks in a buffer and reuses them in subsequent calls to RecyclingByteBlockAllocator.getByteBlock().
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
A IntBlockPool.Allocator implementation that recycles unused int blocks in a buffer and reuses them in subsequent calls to RecyclingIntBlockAllocator.getIntBlock().
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
Creates a new RecyclingIntBlockAllocator with a block size of IntBlockPool.INT_BLOCK_SIZE, upper buffered docs limit of RecyclingIntBlockAllocator.DEFAULT_BUFFERED_BLOCKS (64).
reduce(Collection<C>) - Method in interface org.apache.lucene.search.CollectorManager
Reduce the results of individual collectors into a meaningful result.
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
This method gets called for every property in an AttributeImpl/AttributeSource passing the class name of the Attribute, a key and the actual value.
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: iff prependAttClass=true: "AttributeClass#key=value,AttributeClass#key=value" iff prependAttClass=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: iff prependAttClass=true: "AttributeClass#key=value,AttributeClass#key=value" iff prependAttClass=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
Deprecated.
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.BoostAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
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 RegExp from a string.
RegExp(String, int) - Constructor for class org.apache.lucene.util.automaton.RegExp
Constructs new RegExp from a string.
RegexpQuery - Class in org.apache.lucene.search
A fast regular expression query based on the org.apache.lucene.util.automaton package.
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, int) - Constructor for class org.apache.lucene.search.RegexpQuery
Constructs a query for terms matching term.
RegexpQuery(Term, int, AutomatonProvider, int) - 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.
register(TermState, int) - Method in class org.apache.lucene.index.TermContext
Expert: 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[] key and filling with the old values.
rehashCount - Variable in class org.apache.lucene.util.SentinelIntSet
the count at which a rehash should be done
reinit(Token) - Method in class org.apache.lucene.analysis.Token
Deprecated.
Copy the prototype token's fields into this one.
reinit() - Method in class org.apache.lucene.util.BytesRefHash
reinitializes the BytesRefHash after a previous BytesRefHash.clear() call.
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 the reference previously obtained via ReferenceManager.acquire().
release(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Release a searcher previously obtained from SearcherLifetimeManager.acquire(long).
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.
RelevanceComparator(int) - Constructor for class org.apache.lucene.search.FieldComparator.RelevanceComparator
Creates a new comparator based on relevance for numHits.
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
Reloads the codec list from the given ClassLoader.
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 the provided SegmentCommitInfo.
remove() - Method in class org.apache.lucene.util.FilterIterator
 
remove() - Method in class org.apache.lucene.util.MergedIterator
 
remove(T) - Method in class org.apache.lucene.util.PriorityQueue
Removes an existing element currently stored in the PriorityQueue.
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(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.FilterCodecReader
 
removeCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.FilterLeafReader
 
removeCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.LeafReader
Expert: removes a CoreClosedListener from this reader's shared core
removeCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.ParallelLeafReader
 
removeCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
 
removeCoreClosedListener(LeafReader.CoreClosedListener) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
removeCoreClosedListenerAsReaderClosedListener(IndexReader, LeafReader.CoreClosedListener) - Static method in class org.apache.lucene.index.LeafReader
removeDeadStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Removes transitions to dead states (a state is "dead" if it is not reachable from the initial state or no accept state is reachable from it.)
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
Remove a listener added with ReferenceManager.addListener(RefreshListener).
removeReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
Expert: remove a previously added IndexReader.ReaderClosedListener.
renameFile(String, String) - Method in class org.apache.lucene.store.Directory
Renames source to dest as an atomic operation, where dest does not yet exist in the directory.
renameFile(String, String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
renameFile(String, String) - Method in class org.apache.lucene.store.FilterDirectory
 
renameFile(String, String) - Method in class org.apache.lucene.store.FSDirectory
 
renameFile(String, String) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
renameFile(String, String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
renameFile(String, String) - Method in class org.apache.lucene.store.RAMDirectory
 
renameFile(String, String) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
repeat(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
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.Operations
Returns an automaton that accepts min or more concatenated repetitions of the language of the given automaton.
repeat(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts between min and max (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.
rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.QueryRescorer
 
rescore(IndexSearcher, TopDocs, Query, double, int) - Static method in class org.apache.lucene.search.QueryRescorer
Sugar API, calling {#rescore} using a simple linear combination of firstPassScore + weight * secondPassScore
rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.Rescorer
Rescore an initial first-pass TopDocs.
rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.SortRescorer
 
Rescorer - Class in org.apache.lucene.search
Re-scores the topN results (TopDocs) from an original query.
Rescorer() - Constructor for class org.apache.lucene.search.Rescorer
 
reset() - Method in class org.apache.lucene.analysis.CachingTokenFilter
Propagates reset if incrementToken has not yet been called.
reset() - Method in class org.apache.lucene.analysis.NumericTokenStream
 
reset() - Method in class org.apache.lucene.analysis.TokenFilter
This method is called by a consumer before it begins consumption using TokenStream.incrementToken().
reset() - Method in class org.apache.lucene.analysis.Tokenizer
 
reset() - Method in class org.apache.lucene.analysis.TokenStream
This method is called by a consumer before it begins consumption using TokenStream.incrementToken().
reset(MultiPostingsEnum.EnumWithSlice[], int) - Method in class org.apache.lucene.index.MultiPostingsEnum
Rre-use and reset this instance on the provided slices.
reset(MultiTermsEnum.TermsEnumIndex[]) - Method in class org.apache.lucene.index.MultiTermsEnum
The terms array must be newly created TermsEnum, ie BytesRefIterator.next() has not yet been called.
reset() - Method in class org.apache.lucene.index.QueryTimeoutImpl
Reset the timeout value.
reset() - Method in class org.apache.lucene.search.payloads.PayloadSpanCollector
 
reset() - Method in interface org.apache.lucene.search.spans.SpanCollector
Call to indicate that the driving Spans has moved to a new position
reset() - Method in class org.apache.lucene.store.BufferedChecksum
 
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
Resets the pool to its initial state reusing the first buffer and fills all buffers with 0 bytes before they reused or passed to ByteBlockPool.Allocator.recycleByteBlocks(byte[][], int, int).
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 valueCount values contained in in.
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 j from the temporary storage into slot i.
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.
Result(IntsRef, T) - Constructor for class org.apache.lucene.util.fst.Util.Result
 
reThrow(Throwable) - Static method in class org.apache.lucene.util.IOUtils
Simple utility method that takes a previously caught Throwable and rethrows either IOException or an unchecked exception.
reThrowUnchecked(Throwable) - Static method in class org.apache.lucene.util.IOUtils
Simple utility method that takes a previously caught Throwable and rethrows it as an unchecked exception.
retrieveChecksum(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Returns (but does not validate) the checksum previously written by CodecUtil.checkFooter(org.apache.lucene.store.ChecksumIndexInput).
ReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Sole constructor.
reverse(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton accepting the reverse language.
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(Query[]) - Method in class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
 
rewrite(IndexReader) - Method in class org.apache.lucene.search.BlendedTermQuery
 
rewrite(Query[]) - Method in class org.apache.lucene.search.BlendedTermQuery.RewriteMethod
Merge the provided sub queries into a single Query object.
rewrite(IndexReader) - Method in class org.apache.lucene.search.BooleanQuery
 
rewrite(IndexReader) - Method in class org.apache.lucene.search.CachingWrapperQuery
 
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
Deprecated.
 
rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.DocValuesRewriteMethod
 
rewrite(IndexReader) - Method in class org.apache.lucene.search.Filter
 
rewrite(Filter) - Method in class org.apache.lucene.search.FilteredQuery.FilterStrategy
Deprecated.
Rewrite the filter.
rewrite(Filter) - Method in class org.apache.lucene.search.FilteredQuery.RandomAccessFilterStrategy
Deprecated.
 
rewrite(IndexReader) - Method in class org.apache.lucene.search.FilteredQuery
Deprecated.
 
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.MatchNoDocsQuery
 
rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiTermQuery
To rewrite to a simpler form, instead return a simpler enum from MultiTermQuery.getTermsEnum(Terms, AttributeSource).
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) - Method in class org.apache.lucene.search.QueryWrapperFilter
 
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() - Constructor for class org.apache.lucene.search.BlendedTermQuery.RewriteMethod
Sole constructor
rewriteMethod - Variable in class org.apache.lucene.search.MultiTermQuery
 
RewriteMethod() - Constructor for class org.apache.lucene.search.MultiTermQuery.RewriteMethod
 
rm(Path...) - Static method in class org.apache.lucene.util.IOUtils
Deletes one or more files or directories (and everything underneath it).
RoaringDocIdSet - Class in org.apache.lucene.util
DocIdSet implementation inspired from http://roaringbitmap.org/ The space is divided into blocks of 2^16 bits and each block is encoded independently.
RoaringDocIdSet.Builder - Class in org.apache.lucene.util
A builder of RoaringDocIdSets.
rollback() - Method in class org.apache.lucene.index.IndexWriter
Close the IndexWriter without 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
Locate the most recent segments file and run SegmentInfos.FindSegmentsFile.doBody(java.lang.String) on it.
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(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
run(Automaton, String) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given string is accepted by the automaton.
run(Automaton, IntsRef) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given string (expressed as unicode codepoints) is accepted by the 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 RunAutomaton from a deterministic Automaton.
RunAutomaton(Automaton, int, boolean, int) - Constructor for class org.apache.lucene.util.automaton.RunAutomaton
Constructs a new RunAutomaton from a deterministic Automaton.

S

sameLanguage(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if these two automata accept exactly the same language.
save(DataOutput) - Method in class org.apache.lucene.util.fst.FST
 
save(Path) - 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 i and i+len into the temporary storage.
scale_factor - Variable in class org.apache.lucene.search.FuzzyTermsEnum
 
scanIsEmpty() - Method in class org.apache.lucene.util.FixedBitSet
Scans the backing store to check if all bits are clear.
scanIsEmpty() - Method in class org.apache.lucene.util.LongBitSet
Scans the backing store to check if all bits are clear.
score(List<SegmentCommitInfo>, boolean, long, IndexWriter) - Method in class org.apache.lucene.index.TieredMergePolicy
Expert: scores one merge; subclasses can override.
score(LeafCollector, Bits) - Method in class org.apache.lucene.search.BulkScorer
Scores and collects all matching documents.
score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.BulkScorer
Collects matching documents in a range and return an estimation of the next matching document which is on or after max.
score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
 
score() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
score() - Method in class org.apache.lucene.search.ConstantScoreWeight
Return the score produced by this Weight.
score() - Method in class org.apache.lucene.search.FilterScorer
 
score() - 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() - 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
 
score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.Weight.DefaultBulkScorer
 
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.
scoreCurrentDoc() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
Deprecated.
 
scoreCurrentDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
Score the current doc.
ScoreDoc - Class in org.apache.lucene.search
Holds one hit in TopDocs.
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(LeafReaderContext) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Create the scorer used to score our associated DisjunctionMaxQuery
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
Deprecated.
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.RandomAccessWeight
 
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(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanWeight
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
Returns a Scorer which can iterate in order over all matching documents and assign them a score.
Scorer.ChildScorer - Class in org.apache.lucene.search
A child Scorer and its relationship to its parent.
SCORING_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
SCORING_BOOLEAN_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_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<B> - 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 n hits for query.
search(Query, Filter, int) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
search(Query, Filter, Collector) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
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
Deprecated.
search(Query, Filter, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
search(Query, 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(Query, CollectorManager<C, T>) - Method in class org.apache.lucene.search.IndexSearcher
Lower-level search API.
search(List<LeafReaderContext>, 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 n hits for query where all results are after a previous result (after).
searchAfter(ScoreDoc, Query, Filter, int) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
searchAfter(ScoreDoc, Query, Filter, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
searchAfter(ScoreDoc, Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
Finds the top n hits for query where all results are after a previous result (after).
searchAfter(ScoreDoc, Query, Filter, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
searchAfter(ScoreDoc, Query, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
Finds the top n hits for query where 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
Factory class used by SearcherManager to create new IndexSearchers.
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.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.
SearcherManager(DirectoryReader, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
Creates and returns a new SearcherManager from an existing DirectoryReader.
seek(long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
seek(long) - Method in class org.apache.lucene.store.ChecksumIndexInput
Sets current position in this file, where the next read will occur.
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.RAMInputStream
 
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.FilterLeafReader.FilterTermsEnum
 
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.MultiLevelSkipListReader
Seeks the skip entry on the given level
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(long) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
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
Expert: Seeks a specific position by TermState previously obtained from TermsEnum.termState().
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.
segment - Variable in class org.apache.lucene.codecs.blocktree.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, 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 of the newly merged segment.
SegmentInfo - Class in org.apache.lucene.index
Information about a segment such as its name, directory, and files related to the segment.
SegmentInfo(Directory, Version, String, int, boolean, Codec, Map<String, String>, byte[], 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 describing this segment.
segmentInfo - Variable in class org.apache.lucene.index.SegmentWriteState
SegmentInfo describing this segment.
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.lucene53.Lucene53Codec
 
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.
segmentInfos - Variable in class org.apache.lucene.index.CheckIndex.Status
List of CheckIndex.Status.SegmentInfoStatus instances, detailing status of each segment.
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<T> - Class in org.apache.lucene.index
Utility class for executing code that needs to do something with the current segments file.
SegmentReader - Class in org.apache.lucene.index
IndexReader implementation over a single segment.
SegmentReader(SegmentCommitInfo, IOContext) - Constructor for class org.apache.lucene.index.SegmentReader
Constructs a new SegmentReader with a new core.
SegmentReadState - Class in org.apache.lucene.index
Holder class for common parameters used during read.
SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext) - Constructor for class org.apache.lucene.index.SegmentReadState
Create a SegmentReadState.
SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext, 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.
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, BufferedUpdates, IOContext) - Constructor for class org.apache.lucene.index.SegmentWriteState
Sole constructor.
SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, 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
Create a shallow copy of SegmentWriteState with a new segment suffix.
segString(Directory) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
Returns a description of the merges in this specification.
segString() - 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.
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(int) - Method in class org.apache.lucene.util.BitSet
Set the bit at i.
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(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 len longs starting at off in arr into this mutable, starting at index.
set(T) - Method in class org.apache.lucene.util.SetOnce
Sets the given object.
set(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
Set the bit at index i.
setAbort() - Method in class org.apache.lucene.index.MergeRateLimiter
Mark this merge aborted.
setAccept(int, boolean) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Set or clear this state as an accept state.
setAccept(int, boolean) - Method in class org.apache.lucene.util.automaton.Automaton
Set or clear this state as an accept state.
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
Syntactic sugar for TimeLimitingCollector.setBaseline(long) using Counter.get() on the clock passed to the constructor.
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.CachingWrapperQuery
 
setBoost(float) - Method in class org.apache.lucene.search.NGramPhraseQuery
 
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.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.TermOrdValComparator
 
setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
setBottom(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
Set the bottom slot, ie the "weakest" (sorted last) entry in the queue.
setBufferSize(int) - Method in class org.apache.lucene.store.BufferedIndexInput
Change the buffer size used by this IndexInput
setByteAt(int, byte) - Method in class org.apache.lucene.util.BytesRefBuilder
Set a byte.
setBytesComparator(Comparator<BytesRef>) - Method in class org.apache.lucene.search.SortField
 
setBytesRef(BytesRef) - Method in interface org.apache.lucene.analysis.tokenattributes.BytesTermAttribute
Sets the BytesRef of the term
setBytesRef(BytesRef) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
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.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.
setCharAt(int, char) - Method in class org.apache.lucene.util.CharsRefBuilder
Set a char.
setChecksumsOnly(boolean) - Method in class org.apache.lucene.index.CheckIndex
If true, only validate physical integrity for all files.
setCodec(Codec) - Method in class org.apache.lucene.index.IndexWriterConfig
Set the Codec.
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.
setCommitOnClose(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
Sets if calls IndexWriter.close() should first commit before closing.
setCompetitiveTerm(BytesRef) - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
This is the term or null of 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
expert: sets the default codec used for newly created IndexWriterConfigs.
setDefault(InfoStream) - Static method in class org.apache.lucene.util.InfoStream
Sets the default InfoStream used by a newly instantiated classes.
setDefaultMaxMergesAndThreads(boolean) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Sets max merges and threads to proper defaults for rotational or non-rotational storage.
setDefaultQueryCache(QueryCache) - Static method in class org.apache.lucene.search.IndexSearcher
Expert: set the default QueryCache instance.
setDefaultQueryCachingPolicy(QueryCachingPolicy) - Static method in class org.apache.lucene.search.IndexSearcher
Expert: set the default QueryCachingPolicy instance.
setDelGen(long) - Method in class org.apache.lucene.index.PrefixCodedTerms
Records del gen for this packet.
setDisableCoord(boolean) - Method in class org.apache.lucene.search.BooleanQuery.Builder
Similarity.coord(int,int) may be disabled in scoring, as appropriate.
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(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.SortedNumericDocValues
Positions to the specified document
setDocument(int) - Method in class org.apache.lucene.index.SortedSetDocValues
Sets iteration to the specified docID
setDocValuesType(DocValuesType) - Method in class org.apache.lucene.document.FieldType
Sets the field's DocValuesType
setDocValuesUpdatesFiles(Map<Integer, Set<String>>) - Method in class org.apache.lucene.index.SegmentCommitInfo
Sets the DocValues updates file names, per field number.
setDoubleValue(double) - Method in class org.apache.lucene.analysis.NumericTokenStream
Initializes the token stream with the supplied double value.
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 true to 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
setFailFast(boolean) - Method in class org.apache.lucene.index.CheckIndex
If true, just throw the original exception immediately when corruption is detected, rather than continuing to iterate to other segments looking for more corruption.
setField(FieldInfo) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
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.
setField(FieldInfo) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
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.
setFieldInfosFiles(Set<String>) - Method in class org.apache.lucene.index.SegmentCommitInfo
Sets the FieldInfos file names.
setFiles(Collection<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
Deprecated.
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 float value.
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.
setForceMergeMBPerSec(double) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Set the per-merge IO throttle rate for forced merges (default: Double.POSITIVE_INFINITY).
setFreqCurrentDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
Sets SpanScorer.freq and SpanScorer.numMatches for the current document.
setGenUpdatesFiles(Map<Long, Set<String>>) - Method in class org.apache.lucene.index.SegmentCommitInfo
Deprecated.
required to support 4.6-4.8 indexes.
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
Expert: allows an optional IndexDeletionPolicy implementation to be specified.
setIndexOptions(IndexOptions) - Method in class org.apache.lucene.document.FieldType
Sets the indexing options for the field:
setIndexOptions(IndexOptions) - Method in class org.apache.lucene.index.FieldInfo
Record the IndexOptions to use with this field.
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
Convenience method that uses PrintStreamInfoStream.
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.
setInitialSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
Use this method to set the initial BytesRef to seek before iterating.
setIntAt(int, int) - Method in class org.apache.lucene.util.IntsRefBuilder
Set an int.
setIntValue(int) - Method in class org.apache.lucene.analysis.NumericTokenStream
Initializes the token stream with the supplied int value.
setIntValue(int) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
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.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.RAMFile
 
setLength(int) - Method in class org.apache.lucene.util.BytesRefBuilder
Set the length.
setLength(int) - Method in class org.apache.lucene.util.CharsRefBuilder
Set the length.
setLength(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Set the length.
setLongValue(long) - Method in class org.apache.lucene.analysis.NumericTokenStream
Initializes the token stream with the supplied long value.
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
 
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
Expert: directly set 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.
setMBPerSec(double) - Method in class org.apache.lucene.index.MergeRateLimiter
 
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().
setMergeInfo(SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Expert: Sets the SegmentCommitInfo of the merged segment.
setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
 
setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
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.
setMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.search.BooleanQuery.Builder
Specifies a minimum number of the optional BooleanClauses which must be satisfied.
setMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.search.BooleanQuery
Deprecated.
Boolean queries should be created once with BooleanQuery.Builder and then considered immutable. See BooleanQuery.Builder.setMinimumNumberShouldMatch(int).
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.SortedNumericSortField
 
setMissingValue(Object) - Method in class org.apache.lucene.search.SortedSetSortField
Set how missing values (the empty set) are sorted.
setMissingValue(Object) - Method in class org.apache.lucene.search.SortField
 
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.
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
Deprecated.
BooleanClause will be immutable in 6.0.
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
 
setOffset(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Set the starting and ending offset.
setOmitNorms(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to omit normalization values for the field.
setOmitsNorms() - Method in class org.apache.lucene.index.FieldInfo
Omit norms for this 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
Thrown when SetOnce.set(Object) is called more than once.
setOpenMode(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.index.IndexWriterConfig
Specifies IndexWriterConfig.OpenMode of the index.
setPayload(BytesRef) - Method in class org.apache.lucene.analysis.Token
Deprecated.
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
Save the value at slot i so that it can later be used as a pivot, see IntroSorter.comparePivot(int).
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
Seek to a position previously obtained from PagedBytes.PagedBytesDataInput.getPosition().
setPositionIncrement(int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
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.tokenattributes.PackedTokenAttributeImpl
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
 
setPreload(boolean) - Method in class org.apache.lucene.store.MMapDirectory
Set to true to ask mapped pages to be loaded into physical memory on init.
setPreservePositionIncrements(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
Whether to generate holes in the automaton for missing positions, true by default.
setQuery(Query) - Method in class org.apache.lucene.search.BooleanClause
Deprecated.
BooleanClause will be immutable in 6.0.
setQueryCache(QueryCache) - Method in class org.apache.lucene.search.IndexSearcher
Set the QueryCache to use when scores are not needed.
setQueryCachingPolicy(QueryCachingPolicy) - Method in class org.apache.lucene.search.IndexSearcher
Set the QueryCachingPolicy to use for query caching.
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.
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
By default, IndexWriter does not pool the SegmentReaders it must open for deletions and merging, unless a near-real-time reader has been obtained by calling DirectoryReader.open(IndexWriter, boolean).
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.ReuseStrategy
Stores the given TokenStreamComponents as the reusable components for the field with the give name.
setRewriteMethod(BlendedTermQuery.RewriteMethod) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
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.
setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
setScorer(Scorer) - Method in class org.apache.lucene.search.FilterLeafCollector
 
setScorer(Scorer) - Method in interface org.apache.lucene.search.LeafCollector
Called before successive calls to LeafCollector.collect(int).
setScorer(Scorer) - Method in interface org.apache.lucene.search.LeafFieldComparator
Sets the Scorer to use in case a document's score is needed.
setScorer(Scorer) - Method in class org.apache.lucene.search.SimpleCollector
 
setScorer(Scorer) - Method in class org.apache.lucene.search.SimpleFieldComparator
 
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.
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.Builder
Set the slop.
setSlop(int) - Method in class org.apache.lucene.search.PhraseQuery
Deprecated.
Phrase queries should be created once with PhraseQuery.Builder and then considered immutable. See PhraseQuery.Builder.setSlop(int).
setSlop(int) - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
Set the slop for this query
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: the first SortField is checked first, but if it produces a tie, then the second SortField is used to break the tie, etc.
setStored(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to 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 true to also store token character offsets into the term vector for this field.
setStoreTermVectorPayloads(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to also store token payloads into the term vector for this field.
setStoreTermVectorPositions(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to also store token positions into the term vector for this field.
setStoreTermVectors(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true if 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.
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(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
Record the top value, for future calls to LeafFieldComparator.compareTop(int).
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.
setType(String) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
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, false by 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.
setVersion(Version) - Method in class org.apache.lucene.analysis.Analyzer
Set the version of Lucene this analyzer should mimic the behavior for for analysis.
setWriteLockTimeout(long) - Method in class org.apache.lucene.index.IndexWriterConfig
Deprecated.
Use SleepingLockWrapper if you want sleeping.
shallowSizeOf(Object[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the shallow size in bytes of the Object[] object.
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.
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.
shouldCache(Filter, LeafReaderContext, DocIdSet) - Method in class org.apache.lucene.search.FilterCachingPolicy.CacheOnLargeSegments
Deprecated.
 
shouldCache(Filter, LeafReaderContext, DocIdSet) - Method in interface org.apache.lucene.search.FilterCachingPolicy
Deprecated.
Whether the given DocIdSet should be cached on a given segment.
shouldCache(Query, LeafReaderContext) - Method in class org.apache.lucene.search.QueryCachingPolicy.CacheOnLargeSegments
 
shouldCache(Query, LeafReaderContext) - Method in interface org.apache.lucene.search.QueryCachingPolicy
Whether the given DocIdSet should be cached on a given segment.
shouldCache(Filter, LeafReaderContext, DocIdSet) - Method in class org.apache.lucene.search.UsageTrackingFilterCachingPolicy
 
shouldCache(Query, LeafReaderContext) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
 
shouldExit() - Method in interface org.apache.lucene.index.QueryTimeout
Called from ExitableDirectoryReader.ExitableTermsEnum.next() to determine whether to stop processing a query.
shouldExit() - Method in class org.apache.lucene.index.QueryTimeoutImpl
Return true if QueryTimeoutImpl.reset() has not been called and the elapsed time has exceeded the time allowed.
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.lucene50.Lucene50SegmentInfoFormat
File extension used to store SegmentInfo.
similarity - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Similarity to use when encoding norms.
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
API for scoring "sloppy" queries such as TermQuery, SpanQuery, and PhraseQuery.
Similarity.SimWeight - Class in org.apache.lucene.search.similarities
Stores the weight for a query across the indexed collection.
SimilarityBase - Class in org.apache.lucene.search.similarities
A subclass of Similarity that provides a simplified API for its descendants.
SimilarityBase() - Constructor for class org.apache.lucene.search.similarities.SimilarityBase
Sole constructor.
SimpleCollector - Class in org.apache.lucene.search
Base Collector implementation that is used to collect all contexts.
SimpleCollector() - Constructor for class org.apache.lucene.search.SimpleCollector
 
SimpleFieldComparator<T> - Class in org.apache.lucene.search
Base FieldComparator implementation that is used for all contexts.
SimpleFieldComparator() - Constructor for class org.apache.lucene.search.SimpleFieldComparator
 
SimpleFSDirectory - Class in org.apache.lucene.store
A straightforward implementation of FSDirectory using Files.newByteChannel(Path, java.nio.file.OpenOption...).
SimpleFSDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
Create a new SimpleFSDirectory for the named location.
SimpleFSDirectory(Path) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
Create a new SimpleFSDirectory for the named location and FSLockFactory.getDefault().
SimpleFSLockFactory - Class in org.apache.lucene.store
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
SimpleRateLimiter(double) - Constructor for class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
mbPerSec is the MB/sec max IO rate
sims - Variable in class org.apache.lucene.search.similarities.MultiSimilarity
the sub-similarities used to create the combined score
simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.BM25Similarity
 
simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
 
simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
 
simScorer(Similarity.SimWeight, LeafReaderContext) - 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() - Constructor for class org.apache.lucene.search.similarities.Similarity.SimScorer
Sole constructor.
simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.SimilarityBase
 
simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
 
SimWeight() - Constructor for class org.apache.lucene.search.similarities.Similarity.SimWeight
Sole constructor.
simWeight - Variable in class org.apache.lucene.search.spans.SpanWeight
 
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.
singleton(SortedDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns a multi-valued view over the provided SortedDocValues
singleton(NumericDocValues, Bits) - Static method in class org.apache.lucene.index.DocValues
Returns a multi-valued view over the provided NumericDocValues
singletonView(Iterable<Number>, Iterable<Number>, Number) - Static method in class org.apache.lucene.codecs.DocValuesConsumer
Helper: returns single-valued view, using missingValue when count is zero
sink - Variable in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Sink tokenstream, such as the outer tokenfilter decorating the chain.
sinkState - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Which state, if any, accepts all suffixes, else -1.
size() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
 
size() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
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.FilterLeafReader.FilterFields
 
size() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
size(SegmentCommitInfo, IndexWriter) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
 
size(SegmentCommitInfo, IndexWriter) - Method in class org.apache.lucene.index.LogDocMergePolicy
 
size(SegmentCommitInfo, IndexWriter) - 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, IndexWriter) - Method in class org.apache.lucene.index.NoMergePolicy
 
size() - Method in class org.apache.lucene.index.PrefixCodedTerms
Return the number of terms stored in this PrefixCodedTerms.
size() - Method in class org.apache.lucene.index.SegmentInfos
Returns number of SegmentCommitInfos.
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.DisiPriorityQueue
 
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.automaton.LimitedFiniteStringsIterator
Number of iterated finite strings.
size() - Method in class org.apache.lucene.util.BytesRefArray
Returns the current size of this BytesRefArray
size() - Method in class org.apache.lucene.util.BytesRefHash
Returns the number of BytesRef values in this BytesRefHash.
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.packed.PackedLongValues.Builder
Return the number of elements that have been added to this builder.
size() - Method in class org.apache.lucene.util.packed.PackedLongValues
Get the number of values in this array.
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, IndexWriter) - Method in class org.apache.lucene.index.LogMergePolicy
Return the byte size of the provided SegmentCommitInfo, pro-rated by percentage of non-deleted documents if LogMergePolicy.setCalibrateSizeByDeletes(boolean) is set.
sizeDocs(SegmentCommitInfo, IndexWriter) - Method in class org.apache.lucene.index.LogMergePolicy
Return the number of documents in the provided SegmentCommitInfo, pro-rated by percentage of non-deleted documents if LogMergePolicy.setCalibrateSizeByDeletes(boolean) is set.
sizeInBytes() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns total size in bytes of all files for this segment.
sizeInBytes - Variable in class org.apache.lucene.store.RAMDirectory
 
sizeInBytes - Variable in class org.apache.lucene.store.RAMFile
 
sizeMB - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Net size (MB) of the files referenced by this segment.
sizeOf(Long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the size of the provided Long object, returning 0 if it is cached by the JVM and its shallow size otherwise.
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(Accountable[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the size of the provided array of Accountables by summing up the shallow size of the array and the memory usage reported by each Accountable.
skip(long) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
Skip exactly count values.
skipBytes(long) - Method in class org.apache.lucene.store.ByteArrayDataInput
 
skipBytes(long) - Method in class org.apache.lucene.store.DataInput
Skip over numBytes bytes.
skipDoc - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
Doc id of current skip entry per level.
skipFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
Skip the output previously written with Outputs.writeFinalOutput(T, org.apache.lucene.store.DataOutput); defaults to just calling Outputs.readFinalOutput(org.apache.lucene.store.DataInput) and discarding the result.
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
Skip the output; defaults to just calling Outputs.read(org.apache.lucene.store.DataInput) and discarding the result.
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.PairOutputs
 
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.
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.
SleepingLockWrapper - Class in org.apache.lucene.store
Directory that wraps another, and that sleeps and retries if obtaining the lock fails.
SleepingLockWrapper(Directory, long) - Constructor for class org.apache.lucene.store.SleepingLockWrapper
Create a new SleepingLockFactory
SleepingLockWrapper(Directory, long, long) - Constructor for class org.apache.lucene.store.SleepingLockWrapper
Create a new SleepingLockFactory
slice - Variable in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
ReaderSlice describing how this sub-reader fits into the composite reader.
slice(String, long, long) - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
slice(String, long, long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
slice(String, long, long) - Method in class org.apache.lucene.store.IndexInput
Creates a slice of this index input, with the given description, offset, and length.
slice(String, long, long) - Method in class org.apache.lucene.store.RAMInputStream
 
SliceReader(IntBlockPool) - Constructor for class org.apache.lucene.util.IntBlockPool.SliceReader
Creates a new IntBlockPool.SliceReader on the given pool
slices(List<LeafReaderContext>) - Method in class org.apache.lucene.search.IndexSearcher
Expert: Creates an array of leaf slices each holding a subset of the given leaves.
SliceWriter(IntBlockPool) - Constructor for class org.apache.lucene.util.IntBlockPool.SliceWriter
 
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
Slow (linear) implementation of DocIdSetIterator.advance(int) relying on DocIdSetIterator.nextDoc() to advance beyond the target position.
SlowCodecReaderWrapper - Class in org.apache.lucene.index
Wraps arbitrary readers for merging.
SlowCompositeReaderWrapper - Class in org.apache.lucene.index
This class forces a composite reader (eg a MultiReader or DirectoryReader) to emulate a LeafReader.
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
An IndexDeletionPolicy that wraps any other IndexDeletionPolicy and adds the ability to hold and later release snapshots of an index.
SnapshotDeletionPolicy(IndexDeletionPolicy) - Constructor for class org.apache.lucene.index.SnapshotDeletionPolicy
Sole constructor, taking the incoming IndexDeletionPolicy to wrap.
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
Sets the sort to the given criteria in succession: the first SortField is checked first, but if it produces a tie, then the second SortField is used to break the tie, etc.
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(Path, Path) - Method in class org.apache.lucene.util.OfflineSorter
Sort input to output, explicit hint for the buffer size.
sort(int, int) - Method in class org.apache.lucene.util.Sorter
Sort the slice which starts at from (inclusive) and ends at to (exclusive).
sort(int, int) - Method in class org.apache.lucene.util.TimSorter
 
sortableDoubleBits(long) - Static method in class org.apache.lucene.util.NumericUtils
Converts IEEE 754 representation of a double to sortable order (or back to the original)
sortableFloatBits(int) - Static method in class org.apache.lucene.util.NumericUtils
Converts IEEE 754 representation of a float to sortable order (or back to the original)
sortableIntToFloat(int) - Static method in class org.apache.lucene.util.NumericUtils
Converts a sortable int back to a float.
sortableLongToDouble(long) - Static method in class org.apache.lucene.util.NumericUtils
Converts a sortable long back to a double.
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.
SortedNumericDocValues - Class in org.apache.lucene.index
A list of per-document numeric values, sorted according to Long.compare(long, long).
SortedNumericDocValues() - Constructor for class org.apache.lucene.index.SortedNumericDocValues
Sole constructor.
SortedNumericDocValuesField - Class in org.apache.lucene.document
Field that stores a per-document long values for scoring, sorting or value retrieval.
SortedNumericDocValuesField(String, long) - Constructor for class org.apache.lucene.document.SortedNumericDocValuesField
Creates a new DocValues field with the specified 64-bit long value
SortedNumericSelector - Class in org.apache.lucene.search
Selects a value from the document's list to use as the representative value
SortedNumericSelector() - Constructor for class org.apache.lucene.search.SortedNumericSelector
 
SortedNumericSelector.Type - Enum in org.apache.lucene.search
Type of selection to perform.
SortedNumericSortField - Class in org.apache.lucene.search
SortField for SortedNumericDocValues.
SortedNumericSortField(String, SortField.Type) - Constructor for class org.apache.lucene.search.SortedNumericSortField
Creates a sort, by the minimum value in the set for the document.
SortedNumericSortField(String, SortField.Type, boolean) - Constructor for class org.apache.lucene.search.SortedNumericSortField
Creates a sort, possibly in reverse, by the minimum value in the set for the document.
SortedNumericSortField(String, SortField.Type, boolean, SortedNumericSelector.Type) - Constructor for class org.apache.lucene.search.SortedNumericSortField
Creates a sort, possibly in reverse, specifying how the sort value from the document's set is selected.
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.
SortedSetSelector - Class in org.apache.lucene.search
Selects a value from the document's set to use as the representative value
SortedSetSelector() - Constructor for class org.apache.lucene.search.SortedSetSelector
 
SortedSetSelector.Type - Enum in org.apache.lucene.search
Type of selection to perform.
SortedSetSortField - Class in org.apache.lucene.search
SortField for SortedSetDocValues.
SortedSetSortField(String, boolean) - Constructor for class org.apache.lucene.search.SortedSetSortField
Creates a sort, possibly in reverse, by the minimum value in the set for the document.
SortedSetSortField(String, boolean, SortedSetSelector.Type) - Constructor for class org.apache.lucene.search.SortedSetSortField
Creates a sort, possibly in reverse, specifying how the sort value from the document's set is selected.
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, 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
SortInfo() - Constructor for class org.apache.lucene.util.OfflineSorter.SortInfo
create a new SortInfo (with empty statistics) for debugging
sortKeyLength(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns the length of currentTerm needed for use as a sort key.
sortPartition(int) - Method in class org.apache.lucene.util.OfflineSorter
Sort a single partition in-memory.
SortRescorer - Class in org.apache.lucene.search
A Rescorer that re-sorts according to a provided Sort.
SortRescorer(Sort) - Constructor for class org.apache.lucene.search.SortRescorer
Sole constructor.
sortTime - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
time spent sorting data (in milliseconds)
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
Key for the source of a segment in the diagnostics.
source - Variable in class org.apache.lucene.util.automaton.Transition
Source state.
SOURCE_ADDINDEXES_READERS - Static variable in class org.apache.lucene.index.IndexWriter
Source of a segment which results from a call to IndexWriter.addIndexes(CodecReader...).
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.
SpanCollector - Interface in org.apache.lucene.search.spans
An interface defining the collection of postings information from the leaves of a Spans
SpanContainingQuery - Class in org.apache.lucene.search.spans
Keep matches that contain another Spans.
SpanContainingQuery(SpanQuery, SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanContainingQuery
Construct a SpanContainingQuery matching spans from big that contain at least one spans from little.
SpanContainingQuery.SpanContainingWeight - Class in org.apache.lucene.search.spans
 
SpanContainingWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight, SpanWeight) - Constructor for class org.apache.lucene.search.spans.SpanContainingQuery.SpanContainingWeight
 
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 match whose end position is less than or equal to end.
SpanMultiTermQueryWrapper<Q extends MultiTermQuery> - Class in org.apache.lucene.search.spans
Wraps any MultiTermQuery as a SpanQuery, so it can be nested within other SpanQuery classes.
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.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.
SpanNearPayloadCheckQuery - Class in org.apache.lucene.search.payloads
Deprecated.
SpanNearPayloadCheckQuery(SpanNearQuery, Collection<byte[]>) - Constructor for class org.apache.lucene.search.payloads.SpanNearPayloadCheckQuery
Deprecated.
 
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
SpanNearQuery.Builder - Class in org.apache.lucene.search.spans
A builder for SpanNearQueries
SpanNearQuery.SpanNearWeight - Class in org.apache.lucene.search.spans
 
SpanNearWeight(List<SpanWeight>, IndexSearcher, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery.SpanNearWeight
 
SpanNotQuery - Class in org.apache.lucene.search.spans
Removes matches which overlap with another SpanQuery or which are within 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 include which have no overlap with spans from exclude.
SpanNotQuery(SpanQuery, SpanQuery, int) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
Construct a SpanNotQuery matching spans from include which have no overlap with spans from exclude within dist tokens of include.
SpanNotQuery(SpanQuery, SpanQuery, int, int) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
Construct a SpanNotQuery matching spans from include which have no overlap with spans from exclude within pre tokens before or post tokens of include.
SpanNotQuery.SpanNotWeight - Class in org.apache.lucene.search.spans
 
SpanNotWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight, SpanWeight) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery.SpanNotWeight
 
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.
SpanOrQuery.SpanOrWeight - Class in org.apache.lucene.search.spans
 
SpanOrWeight(IndexSearcher, Map<Term, TermContext>, List<SpanWeight>) - Constructor for class org.apache.lucene.search.spans.SpanOrQuery.SpanOrWeight
 
SpanPayloadCheckQuery - Class in org.apache.lucene.search.payloads
Only return those matches that have a specific payload at the given position.
SpanPayloadCheckQuery(SpanQuery, Collection<byte[]>) - Constructor for class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
SpanPayloadCheckQuery.SpanPayloadCheckWeight - Class in org.apache.lucene.search.payloads
Weight that pulls its Spans using a PayloadSpanCollector
SpanPayloadCheckWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight) - Constructor for class org.apache.lucene.search.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
 
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.SpanPositionCheckWeight - Class in org.apache.lucene.search.spans
 
SpanPositionCheckWeight(SpanWeight, IndexSearcher, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.spans.SpanPositionCheckQuery.SpanPositionCheckWeight
 
SpanPositionRangeQuery - Class in org.apache.lucene.search.spans
Checks to see if the SpanPositionCheckQuery.getMatch() lies between a start and end position See SpanFirstQuery for a derivation that is optimized for the case where start position is 0.
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
 
SpanRewriteMethod() - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.SpanRewriteMethod
 
Spans - Class in org.apache.lucene.search.spans
Iterates through combinations of start/end positions per-doc.
Spans() - Constructor for class org.apache.lucene.search.spans.Spans
 
spans - Variable in class org.apache.lucene.search.spans.SpanScorer
underlying spans we are scoring from
SpanScorer - Class in org.apache.lucene.search.spans
Public for extension only.
SpanScorer(Spans, SpanWeight, Similarity.SimScorer) - Constructor for class org.apache.lucene.search.spans.SpanScorer
Creates a new 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.
SpanTermQuery(Term, TermContext) - Constructor for class org.apache.lucene.search.spans.SpanTermQuery
Expert: Construct a SpanTermQuery matching the named term's spans, using the provided TermContext
SpanTermQuery.SpanTermWeight - Class in org.apache.lucene.search.spans
 
SpanTermWeight(TermContext, IndexSearcher, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.spans.SpanTermQuery.SpanTermWeight
 
SpanWeight - Class in org.apache.lucene.search.spans
Expert-only.
SpanWeight(SpanQuery, IndexSearcher, Map<Term, TermContext>) - Constructor for class org.apache.lucene.search.spans.SpanWeight
Create a new SpanWeight
SpanWeight.Postings - Enum in org.apache.lucene.search.spans
Enumeration defining what postings information should be retrieved from the index for a given Spans
SpanWithinQuery - Class in org.apache.lucene.search.spans
Keep matches that are contained within another Spans.
SpanWithinQuery(SpanQuery, SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanWithinQuery
Construct a SpanWithinQuery matching spans from little that are inside of big.
SpanWithinQuery.SpanWithinWeight - Class in org.apache.lucene.search.spans
 
SpanWithinWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight, SpanWeight) - Constructor for class org.apache.lucene.search.spans.SpanWithinQuery.SpanWithinWeight
 
SparseFixedBitSet - Class in org.apache.lucene.util
A bit set that only stores longs that have at least one bit which is set.
SparseFixedBitSet(int) - Constructor for class org.apache.lucene.util.SparseFixedBitSet
Create a SparseFixedBitSet that can contain bits between 0 included and length excluded.
SPIClassIterator<S> - Class in org.apache.lucene.util
Helper class for loading SPI classes from classpath (META-INF files).
spins(Directory) - Static method in class org.apache.lucene.util.IOUtils
If the dir is an FSDirectory or wraps one via possibly nested FilterDirectory or FileSwitchDirectory, this returns IOUtils.spins(Path) for the wrapped directory, else, true.
spins(Path) - Static method in class org.apache.lucene.util.IOUtils
Rough Linux-only heuristics to determine whether the provided Path is backed by spinning storage.
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.
start - Variable in class org.apache.lucene.index.ReaderSlice
Document ID this slice starts from.
start - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
startDoc(int, int) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
startDoc(int, int) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Adds a new doc in this term.
startDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
 
startDocument(int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
startDocument() - 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.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 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.analysis.tokenattributes.PackedTokenAttributeImpl
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.index.DocsAndPositionsEnum
Deprecated.
Returns start offset for the current position, or -1 if offsets were not indexed.
startOffset() - Method in class org.apache.lucene.index.DocsEnum
Deprecated.
 
startOffset() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
startOffset() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
startOffset() - Method in class org.apache.lucene.index.PostingsEnum
Returns start offset for the current position, or -1 if offsets were not indexed.
startPosition() - Method in class org.apache.lucene.search.spans.FilterSpans
 
startPosition() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
startPosition() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
startPosition() - Method in class org.apache.lucene.search.spans.Spans
Returns the start position in the current doc, or -1 when Spans.nextStartPosition() was not yet called on the current doc.
startPosition() - Method in class org.apache.lucene.search.spans.TermSpans
 
startsWith(byte[], BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns true iff the ref starts with the given prefix.
startsWith(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns true iff the ref starts with the given prefix.
startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
startTerm() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
 
startTerm() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Start a new term.
startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Adds a term and its term frequency freq.
State() - Constructor for class org.apache.lucene.util.AttributeSource.State
 
StatePair - Class in org.apache.lucene.util.automaton
Pair of states.
StatePair(int, int) - Constructor for class org.apache.lucene.util.automaton.StatePair
Constructs a new state pair.
StaticImplementationAttributeFactory(AttributeFactory, Class<A>) - Constructor for class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
Expert: Creates an AttributeFactory returning clazz as instance for the attributes it implements and for all other attributes calls the given delegate factory.
Stats - Class in org.apache.lucene.codecs.blocktree
BlockTree statistics for a single field returned by FieldReader.getStats().
step(int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Performs lookup in transitions, assuming determinism.
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.
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
A field whose value is stored so that IndexSearcher.doc(int) and IndexReader.document(int, org.apache.lucene.index.StoredFieldVisitor) will return the field and its value.
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.lucene53.Lucene53Codec
 
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.
storedFieldsReaders - Variable in class org.apache.lucene.index.MergeState
Stored field producers being merged
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: For every document, StoredFieldsWriter.startDocument() is called, informing the Codec that a new document has started.
StoredFieldsWriter() - Constructor for class org.apache.lucene.codecs.StoredFieldsWriter
Sole constructor.
StoredFieldsWriter.MergeVisitor - Class in org.apache.lucene.codecs
A visitor that adds every field it sees.
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
Enumeration of possible return values for StoredFieldVisitor.needsField(org.apache.lucene.index.FieldInfo).
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.
stream - Variable in class org.apache.lucene.util.PrintStreamInfoStream
 
STRING_FIRST - Static variable in class org.apache.lucene.search.SortField
Pass this to SortField.setMissingValue(java.lang.Object) to have missing string values sort first.
STRING_LAST - Static variable in class org.apache.lucene.search.SortField
Pass this to SortField.setMissingValue(java.lang.Object) to have missing string values sort last.
stringField(FieldInfo, byte[]) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
stringField(FieldInfo, byte[]) - 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 textual StringField, indexing the provided String value as a single token.
StringField(String, BytesRef, Field.Store) - Constructor for class org.apache.lucene.document.StringField
Creates a new binary StringField, indexing the provided binary (BytesRef) value as a single token.
stringField(FieldInfo, byte[]) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a string field; the provided byte[] value is a UTF-8 encoded string value.
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 timeToString or dateToString back to a time, represented as a Date object.
stringToTime(String) - Static method in class org.apache.lucene.document.DateTools
Converts a string produced by timeToString or dateToString back to a time, represented as the number of milliseconds since January 1, 1970, 00:00:00 GMT.
stringValue() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
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.blocktree.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 n in the array used to construct this searcher/reader.
subIndex(int, List<LeafReaderContext>) - Static method in class org.apache.lucene.index.ReaderUtil
Returns index of the searcher/reader for document n in the array used to construct this searcher/reader.
SubReaderWrapper() - Constructor for class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
Constructor
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, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the language of a1 is a subset of the language of a2.
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
 
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.
SuppressForbidden - Annotation Type in org.apache.lucene.util
Annotation to suppress forbidden-apis errors inside a whole class, a method, or a field.
swap(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Swap values stored in slots i and j
swap(int, int) - Method in class org.apache.lucene.util.Sorter
Swap values at slots i and j.
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.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.LockValidatingDirectoryWrapper
 
sync(Collection<String>) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
sync(Collection<String>) - Method in class org.apache.lucene.store.RAMDirectory
 

T

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
targetMBPerSec - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Current IO writes throttle rate
targetMBPerSecChanged() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Subclass can override to tweak targetMBPerSec.
tempMergeFiles - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
number of temporary files created when merging partitions
tenum - Variable in class org.apache.lucene.index.FilteredTermsEnum
The delegate TermsEnum.
term() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
term() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
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
For CompiledAutomaton.AUTOMATON_TYPE.SINGLE this is the singleton term.
termBlockOrd - Variable in class org.apache.lucene.codecs.BlockTermState
the term's ord in the current block
TermContext - Class in org.apache.lucene.index
Maintains a IndexReader TermState view over IndexReader instances containing a single term.
TermContext(IndexReaderContext) - Constructor for class org.apache.lucene.index.TermContext
Creates an empty TermContext from a IndexReaderContext
TermContext(IndexReaderContext, TermState, int, int, long) - Constructor for class org.apache.lucene.index.TermContext
Creates a TermContext with an initial TermState, IndexReader pair.
termContext - Variable in class org.apache.lucene.search.spans.SpanTermQuery
 
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.LeafReader
Deprecated.
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).
termLength - Variable in class org.apache.lucene.search.FuzzyTermsEnum
 
TermOrdValComparator(int, String) - Constructor for class org.apache.lucene.search.FieldComparator.TermOrdValComparator
Creates this, sorting missing values first.
TermOrdValComparator(int, String, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.TermOrdValComparator
Creates this, with control over how missing values are sorted.
termPositionsEnum(Term) - Method in class org.apache.lucene.index.LeafReader
Deprecated.
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, 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
Deprecated.
TermRangeFilter(String, BytesRef, BytesRef, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeFilter
Deprecated.
 
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 lowerTerm but less/equal than upperTerm.
terms(String) - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
 
terms(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFields
 
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.FilterLeafReader.FilterFields
 
terms(String) - Method in class org.apache.lucene.index.LeafReader
This may return null if the field does not exist.
terms(String) - Method in class org.apache.lucene.index.MappedMultiFields
 
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
 
termsEnum() - Method in class org.apache.lucene.index.SortedDocValues
Returns a TermsEnum over the values.
termsEnum() - Method in class org.apache.lucene.index.SortedSetDocValues
Returns a TermsEnum over the values.
TermsEnum - Class in org.apache.lucene.index
TermsEnum() - Constructor for class org.apache.lucene.index.TermsEnum
Sole constructor.
TermsEnum.SeekStatus - Enum in org.apache.lucene.index
termsOnlyBlockCount - Variable in class org.apache.lucene.codecs.blocktree.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(PostingsEnum, 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
Returns TermStatistics for a term.
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.
TermValComparator(int, String, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.TermValComparator
Sole constructor.
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.lucene53.Lucene53Codec
 
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.
termVectorsReaders - Variable in class org.apache.lucene.index.MergeState
Term vector producers being merged
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: For every document, TermVectorsWriter.startDocument(int) is called, informing the Codec how many fields will be written.
TermVectorsWriter() - Constructor for class org.apache.lucene.codecs.TermVectorsWriter
Sole constructor.
testDocValues(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test docvalues.
testFieldInfos(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test field infos.
testFieldNorms(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test field norms.
testLiveDocs(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test live docs.
testPostings(CodecReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
Test the term index.
testPostings(CodecReader, PrintStream, boolean, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test the term index.
testStoredFields(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test stored fields.
testTermVectors(CodecReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
Test term vectors.
testTermVectors(CodecReader, PrintStream, boolean, 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.
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.
TimerThread(long, Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
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
Sorts the given array slice using the Comparator.
timSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array using the Comparator.
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
Sorts the given random access List using the Comparator.
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
Sorter implementation based on the TimSort algorithm.
TimSorter(int) - Constructor for class org.apache.lucene.util.TimSorter
Create a new TimSorter.
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(BytesRef) - Static method in class org.apache.lucene.search.PrefixQuery
Build an automaton accepting all terms with the specified prefix.
toAutomaton(BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.search.TermRangeQuery
 
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(int, String) - Method in class org.apache.lucene.util.automaton.LevenshteinAutomata
Compute a DFA that accepts all strings within an edit distance of n, matching the specified exact prefix.
toAutomaton() - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toAutomaton(int) - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toAutomaton(AutomatonProvider, int) - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toAutomaton(Map<String, Automaton>, int) - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toBytesRef() - Method in class org.apache.lucene.util.BytesRefBuilder
Build a new BytesRef that has the same content as this buffer.
toBytesRef(IntsRef, BytesRefBuilder) - 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.
toCharsRef() - Method in class org.apache.lucene.util.CharsRefBuilder
Build a new CharsRef that has the same content as this builder.
toDot() - Method in class org.apache.lucene.util.automaton.Automaton
Returns the dot (graphviz) representation of this automaton.
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, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Just takes unsigned byte values from the BytesRef and converts into an IntsRef.
toIntsRef() - Method in class org.apache.lucene.util.IntsRefBuilder
Build a new CharsRef that has the same content as this builder.
Token - Class in org.apache.lucene.analysis
Deprecated.
This class is outdated and no longer used since Lucene 2.9. Nuke it finally!
Token() - Constructor for class org.apache.lucene.analysis.Token
Deprecated.
Constructs a Token will null text.
Token(CharSequence, int, int) - Constructor for class org.apache.lucene.analysis.Token
Deprecated.
Constructs a Token with the given term text, start and end offsets.
TOKEN_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.analysis.Token
Deprecated.
Convenience factory that returns Token as 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() - Constructor for class org.apache.lucene.analysis.Tokenizer
Construct a tokenizer with no input, awaiting a call to Tokenizer.setReader(java.io.Reader) to provide input.
Tokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.Tokenizer
Construct a tokenizer with no input, awaiting a call to Tokenizer.setReader(java.io.Reader) to provide input.
tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
Returns a TokenStream suitable for fieldName, tokenizing the contents of reader.
tokenStream(String, String) - Method in class org.apache.lucene.analysis.Analyzer
Returns a TokenStream suitable for fieldName, tokenizing the contents of text.
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(AttributeFactory) - Constructor for class org.apache.lucene.analysis.TokenStream
A TokenStream using the supplied AttributeFactory for creating new Attribute instances.
tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
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, TokenStream) - Method in class org.apache.lucene.document.Field
 
tokenStream(Analyzer, TokenStream) - Method in interface org.apache.lucene.index.IndexableField
Creates the TokenStream used for indexing this field.
TokenStreamComponents(Tokenizer, TokenStream) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Creates a new Analyzer.TokenStreamComponents instance.
TokenStreamComponents(Tokenizer) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Creates a new Analyzer.TokenStreamComponents instance.
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
 
TooComplexToDeterminizeException - Exception in org.apache.lucene.util.automaton
This exception is thrown when determinizing an automaton would result in one has too many states.
TooComplexToDeterminizeException(RegExp, TooComplexToDeterminizeException) - Constructor for exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Use this constructor when the RegExp failed to convert to an automaton.
TooComplexToDeterminizeException(Automaton, int) - Constructor for exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Use this constructor when the automaton failed to determinize.
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.
TooManyClauses() - Constructor for exception org.apache.lucene.search.BooleanQuery.TooManyClauses
 
top() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
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
Represents hits returned by IndexSearcher.search(Query,int).
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 range [start ..
topDocs(int, int) - Method in class org.apache.lucene.search.TopDocsCollector
Returns the documents in the range [start ..
topDocs() - Method in class org.apache.lucene.search.TopFieldCollector
 
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
A Collector that sorts by SortField using FieldComparators.
TopFieldDocs - Class in org.apache.lucene.search
Represents hits returned by IndexSearcher.search(Query,int,Sort).
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.
topList() - Method in class org.apache.lucene.search.DisiPriorityQueue
Get the list of scorers which are on the current doc.
topN - Variable in class org.apache.lucene.util.fst.Util.TopResults
The top results
TopNSearcher(FST<T>, int, int, Comparator<T>) - Constructor for class org.apache.lucene.util.fst.Util.TopNSearcher
Creates an unbounded TopNSearcher
TopNSearcher(FST<T>, int, int, Comparator<T>, Comparator<Util.FSTPath<T>>) - Constructor for class org.apache.lucene.util.fst.Util.TopNSearcher
 
topoSortStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns the topological sort of all states reachable from the initial state.
topReaderContext - Variable in class org.apache.lucene.index.TermContext
Holds the IndexReaderContext of the top-level IndexReader, used internally only for asserting.
TopScoreDocCollector - Class in org.apache.lucene.search
A Collector implementation that collects the top-scoring hits, returning them as a TopDocs.
TopTermsBlendedFreqScoringRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
Create a TopTermsBlendedScoringBooleanQueryRewrite for at most size terms.
TopTermsBoostOnlyBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
Create a TopTermsBoostOnlyBooleanQueryRewrite for at most size terms.
TopTermsRewrite<B> - 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 size terms.
TopTermsScoringBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
Create a TopTermsScoringBooleanQueryRewrite for at most size terms.
TopTermsSpanBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
Create a TopTermsSpanBooleanQueryRewrite for at most size terms.
toString() - Method in class org.apache.lucene.analysis.NumericTokenStream
 
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.blocktree.BlockTreeTermsReader
 
toString() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
 
toString() - Method in class org.apache.lucene.codecs.blocktree.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.CompressingStoredFieldsIndexReader
 
toString() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
 
toString() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
 
toString() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
 
toString() - Method in class org.apache.lucene.codecs.DocValuesFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
 
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.ExitableDirectoryReader
 
toString() - Method in class org.apache.lucene.index.FilterLeafReader
 
toString() - Method in class org.apache.lucene.index.IndexWriterConfig
 
toString() - Method in class org.apache.lucene.index.LeafReaderContext
 
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.MultiPostingsEnum.EnumWithSlice
 
toString() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
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.ParallelLeafReader
 
toString() - Method in class org.apache.lucene.index.QueryTimeoutImpl
 
toString() - Method in class org.apache.lucene.index.ReaderSlice
 
toString(Directory, int) - Method in class org.apache.lucene.index.SegmentCommitInfo
Deprecated.
toString(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
Deprecated.
toString(int) - Method in class org.apache.lucene.index.SegmentInfo
Used for debugging.
toString(Directory) - Method in class org.apache.lucene.index.SegmentInfos
Deprecated.
toString() - 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.TermContext
 
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(String) - Method in class org.apache.lucene.search.BlendedTermQuery
 
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(String) - Method in class org.apache.lucene.search.CachingWrapperFilter
Deprecated.
 
toString(String) - Method in class org.apache.lucene.search.CachingWrapperQuery
 
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.Explanation
Render an explanation as text.
toString() - Method in class org.apache.lucene.search.FieldDoc
 
toString(String) - Method in class org.apache.lucene.search.FieldValueFilter
Deprecated.
 
toString() - Method in class org.apache.lucene.search.FieldValueHitQueue.Entry
 
toString(String) - Method in class org.apache.lucene.search.FieldValueQuery
 
toString() - Method in class org.apache.lucene.search.FilterCollector
 
toString(String) - Method in class org.apache.lucene.search.FilteredQuery
Deprecated.
Prints a user-readable version of this query.
toString() - Method in class org.apache.lucene.search.FilterLeafCollector
 
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.MatchNoDocsQuery
 
toString(String) - Method in class org.apache.lucene.search.MultiPhraseQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
 
toString(String) - Method in class org.apache.lucene.search.NGramPhraseQuery
 
toString(String) - Method in class org.apache.lucene.search.NumericRangeQuery
 
toString(String) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
Deprecated.
 
toString(String) - Method in class org.apache.lucene.search.payloads.PayloadScoreQuery
 
toString(String) - Method in class org.apache.lucene.search.payloads.SpanNearPayloadCheckQuery
Deprecated.
 
toString(String) - Method in class org.apache.lucene.search.payloads.SpanPayloadCheckQuery
 
toString(String) - Method in class org.apache.lucene.search.PhraseQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.PrefixFilter
Deprecated.
Prints a user-readable version of this filter.
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 field assumed to be the default field and omitted.
toString() - Method in class org.apache.lucene.search.Query
Prints a query to a string.
toString(String) - 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.SortedNumericSortField
 
toString() - Method in class org.apache.lucene.search.SortedSetSortField
 
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.FilterSpans
 
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.SpanContainingQuery
 
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.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.SpanPositionRangeQuery
 
toString() - Method in class org.apache.lucene.search.spans.Spans
 
toString(String) - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
toString(String) - Method in class org.apache.lucene.search.spans.SpanWithinQuery
 
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.BaseDirectory
 
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.IndexInput
 
toString() - Method in class org.apache.lucene.store.IndexOutput
 
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.store.RAMFile
 
toString() - Method in class org.apache.lucene.store.SleepingLockWrapper
 
toString(Accountable) - Static method in class org.apache.lucene.util.Accountables
Returns a String description of an Accountable and any nested resources.
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.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.StatePair
 
toString() - Method in class org.apache.lucene.util.automaton.Transition
 
toString() - Method in class org.apache.lucene.util.BitDocIdSet
 
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.CharsRefBuilder
 
toString() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
toString() - Method in class org.apache.lucene.util.fst.FST.Arc
 
toString() - Method in class org.apache.lucene.util.fst.FST
 
toString() - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
toString() - Method in class org.apache.lucene.util.fst.NoOutputs
 
toString() - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
 
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.OfflineSorter.SortInfo
 
toString() - Method in class org.apache.lucene.util.packed.BlockPackedReader
 
toString() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
toString() - Method in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
 
toString() - Method in class org.apache.lucene.util.PagedBytes.Reader
 
toString() - Method in class org.apache.lucene.util.RoaringDocIdSet
 
toString() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
toString() - Method in class org.apache.lucene.util.Version
 
toStringTree() - Method in class org.apache.lucene.util.automaton.RegExp
Like to string, but more verbose (shows the higherchy more clearly).
ToStringUtils - Class in org.apache.lucene.util
Helper methods to ease implementing Object.toString().
totalBinaryFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of binary fields
totalBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
Total number of blocks.
totalBlockOtherBytes - Variable in class org.apache.lucene.codecs.blocktree.Stats
Total bytes stored by the PostingsReaderBase, plus the other few vInts stored in the frame.
totalBlockStatsBytes - Variable in class org.apache.lucene.codecs.blocktree.Stats
Total number of bytes used to store term stats (not including what the PostingsReaderBase stores.
totalBlockSuffixBytes - Variable in class org.apache.lucene.codecs.blocktree.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.
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.
totalMaxDoc - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
Total number of documents in segments to be merged, not accounting for deletions.
totalMaxDoc() - Method in class org.apache.lucene.index.SegmentInfos
Returns sum of all segment's maxDocs.
totalMaxDoc - Variable in class org.apache.lucene.store.MergeInfo
 
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
totalSortedNumericFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of sortednumeric 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.blocktree.Stats
Total number of bytes (sum of term lengths) across all terms in the field.
totalTermCount - Variable in class org.apache.lucene.codecs.blocktree.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.BaseCompositeReader
 
totalTermFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
totalTermFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
totalTermFreq(Term) - Method in class org.apache.lucene.index.IndexReader
Returns the total number of occurrences of term across all documents (the sum of the freq() for each doc that has this term).
totalTermFreq(Term) - Method in class org.apache.lucene.index.LeafReader
Returns the number of documents containing the term t.
totalTermFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
 
totalTermFreq() - Method in class org.apache.lucene.index.TermContext
Returns the accumulated term frequency of all TermState instances passed to TermContext.register(TermState, int, int, long).
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
totalTime - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
total time spent (in milliseconds)
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.FieldInfoStatus
Number of fields successfully tested
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, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Just maps each UTF16 unit (char) to the ints in an IntsRef.
toUTF32(CharSequence, IntsRefBuilder) - 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, IntsRefBuilder) - 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
Class that tracks changes to a delegated IndexWriter, used by ControlledRealTimeReopenThread to ensure specific changes are visible.
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
Holds one transition from an Automaton.
Transition() - Constructor for class org.apache.lucene.util.automaton.Transition
Sole constructor.
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.
tryDeleteDocument(IndexReader, int) - Method in class org.apache.lucene.index.IndexWriter
Expert: attempts to delete by document ID, as long as the provided reader is a near-real-time reader (from DirectoryReader.open(IndexWriter,boolean)).
tryDeleteDocument(IndexReader, int) - Method in class org.apache.lucene.index.TrackingIndexWriter
Cals IndexWriter.tryDeleteDocument(IndexReader,int) and returns the generation that reflects this change.
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 true iff the refCount was successfully incremented, otherwise false.
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
Thrown by TwoPhaseCommitTool.execute(TwoPhaseCommit...) when an object fails to commit().
TwoPhaseCommitTool.PrepareCommitFailException - Exception in org.apache.lucene.index
Thrown by TwoPhaseCommitTool.execute(TwoPhaseCommit...) when an object fails to prepareCommit().
TwoPhaseDocIdSetIterator - Class in org.apache.lucene.search
An approximation of a DocIdSetIterator.
TwoPhaseDocIdSetIterator() - Constructor for class org.apache.lucene.search.TwoPhaseDocIdSetIterator
 
TwoPhaseIterator - Class in org.apache.lucene.search
Returned by Scorer.asTwoPhaseIterator() and Spans.asTwoPhaseIterator() to expose an approximation of a DocIdSetIterator.
TwoPhaseIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.TwoPhaseIterator
Takes the approximation to be returned by TwoPhaseIterator.approximation.
twoPhaseView - Variable in class org.apache.lucene.search.DisiWrapper
 
type() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
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.SortedNumericDocValuesField
Type for sorted numeric 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
If simplify is true this will be the "simplified" type; else, this is NORMAL
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.
TypeAttribute - Interface in org.apache.lucene.analysis.tokenattributes
A Token's lexical type.
TypeAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of TypeAttribute.
TypeAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
Initialize this attribute with TypeAttribute.DEFAULT_TYPE
TypeAttributeImpl(String) - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
Initialize this attribute with type

U

UnCompiledNode(Builder<T>, int) - Constructor for class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
UNI_REPLACEMENT_CHAR - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_HIGH_END - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_HIGH_START - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_LOW_END - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_LOW_START - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UnicodeUtil - Class in org.apache.lucene.util
Class to encode java's UTF16 char[] into UTF8 byte[] without always allocating a new byte[] as String.getBytes(StandardCharsets.UTF_8) does.
union(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the union of the languages of the given automata.
union(Collection<Automaton>) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the union of the languages of the given automata.
unionCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
Returns the popcount or cardinality of the union of the two sets.
UNMAP_SUPPORTED - Static variable in class org.apache.lucene.store.MMapDirectory
true, if this platform supports unmapping mmapped files.
unsignedBitsRequired(long) - Static method in class org.apache.lucene.util.packed.DirectWriter
Returns how many bits are required to hold values up to and including maxValue, interpreted as an unsigned value.
unsignedBitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
Returns how many bits are required to store bits, interpreted as an unsigned value.
unwrap(DirectoryReader) - Static method in class org.apache.lucene.index.FilterDirectoryReader
Get the wrapped instance by reader as long as this reader is an instance of FilterDirectoryReader.
unwrap(LeafReader) - Static method in class org.apache.lucene.index.FilterLeafReader
Get the wrapped instance by reader as long as this reader is an instance of FilterLeafReader.
unwrap(Directory) - Static method in class org.apache.lucene.store.FilterDirectory
Get the wrapped instance by dir as long as this reader is an instance of FilterDirectory.
unwrapSingleton(SortedSetDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns a single-valued view of the SortedSetDocValues, if it was previously wrapped with DocValues.singleton(SortedDocValues), or null.
unwrapSingleton(SortedNumericDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns a single-valued view of the SortedNumericDocValues, if it was previously wrapped with DocValues.singleton(NumericDocValues, Bits), or null.
unwrapSingletonBits(SortedNumericDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns the documents with a value for the SortedNumericDocValues, if it was previously wrapped with DocValues.singleton(NumericDocValues, Bits), or null.
update(int) - Method in class org.apache.lucene.store.BufferedChecksum
 
update(byte[], int, int) - Method in class org.apache.lucene.store.BufferedChecksum
 
updateBinaryDocValue(Term, String, BytesRef) - Method in class org.apache.lucene.index.IndexWriter
Updates a document's BinaryDocValues for field to the given value.
updateDocument(Term, Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.IndexWriter
Updates a document by first deleting the document(s) containing term and then adding the new document.
updateDocument(Term, Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.updateDocument(Term,Iterable) and returns the generation that reflects this change.
updateDocuments(Term, Iterable<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.IndexWriter
Atomically deletes documents matching the provided delTerm and adds a block of documents with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
updateDocuments(Term, Iterable<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.updateDocuments(Term,Iterable) and returns the generation that reflects this change.
updateDocValues(Term, Field...) - Method in class org.apache.lucene.index.IndexWriter
Updates documents' DocValues fields to the given values.
updateMergeThreads() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Called whenever the running merges have changed, to set merge IO limits.
updateNumericDocValue(Term, String, long) - Method in class org.apache.lucene.index.IndexWriter
Updates a document's NumericDocValues for field to the given value.
updateTop() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
updateTop() - Method in class org.apache.lucene.util.PriorityQueue
Should be called when the Object at top changes values.
updateTop(T) - Method in class org.apache.lucene.util.PriorityQueue
Replace the top of the pq with newTop and run PriorityQueue.updateTop().
upgrade() - Method in class org.apache.lucene.index.IndexUpgrader
Perform the upgrade.
UpgradeIndexMergePolicy - Class in org.apache.lucene.index
This MergePolicy is used for upgrading all existing segments of an index when calling IndexWriter.forceMerge(int).
UpgradeIndexMergePolicy(MergePolicy) - Constructor for class org.apache.lucene.index.UpgradeIndexMergePolicy
Wrap the given MergePolicy and intercept forceMerge requests to only upgrade segments written with previous Lucene versions.
UsageTrackingFilterCachingPolicy - Class in org.apache.lucene.search
A FilterCachingPolicy that tracks usage statistics of recently-used filters in order to decide on which filters are worth caching.
UsageTrackingFilterCachingPolicy(float, int, int, int, int) - Constructor for class org.apache.lucene.search.UsageTrackingFilterCachingPolicy
Create a new instance.
UsageTrackingFilterCachingPolicy() - Constructor for class org.apache.lucene.search.UsageTrackingFilterCachingPolicy
Create a new instance with sensible defaults.
UsageTrackingQueryCachingPolicy - Class in org.apache.lucene.search
A QueryCachingPolicy that tracks usage statistics of recently-used filters in order to decide on which filters are worth caching.
UsageTrackingQueryCachingPolicy(int, float, int) - Constructor for class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
Create a new instance.
UsageTrackingQueryCachingPolicy() - Constructor for class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
Create a new instance with an history size of 256.
useCompoundFile - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
True if segment flushes should use compound file format
useCompoundFile(SegmentInfos, SegmentCommitInfo, IndexWriter) - Method in class org.apache.lucene.index.MergePolicy
Returns true if a new segment (regardless of its origin) should use the compound file format.
useCompoundFile(SegmentInfos, SegmentCommitInfo, IndexWriter) - Method in class org.apache.lucene.index.NoMergePolicy
 
useCompoundFile(SegmentInfos, SegmentCommitInfo, IndexWriter) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
useRandomAccess(Bits, long) - Method in class org.apache.lucene.search.FilteredQuery.RandomAccessFilterStrategy
Deprecated.
Expert: decides if a filter should be executed as "random-access" or not.
userData - Variable in class org.apache.lucene.index.CheckIndex.Status
Holds the userData of the last commit in the index
userData - Variable in class org.apache.lucene.index.SegmentInfos
Opaque Map<String, String> that user can specify during IndexWriter.commit
UTF16toUTF8(char[], int, int, byte[]) - Static method in class org.apache.lucene.util.UnicodeUtil
Encode characters from a char[] source, starting at offset for length chars.
UTF16toUTF8(CharSequence, int, int, byte[]) - Static method in class org.apache.lucene.util.UnicodeUtil
Encode characters from this String, starting at offset for length characters.
UTF32ToUTF8 - Class in org.apache.lucene.util.automaton
Converts UTF-32 automata to the equivalent UTF-8 representation.
UTF32ToUTF8() - Constructor for class org.apache.lucene.util.automaton.UTF32ToUTF8
Sole constructor.
utf8ToString() - Method in class org.apache.lucene.util.BytesRef
Interprets stored bytes as UTF8 bytes, returning the resulting string
UTF8toUTF16(byte[], int, int, char[]) - Static method in class org.apache.lucene.util.UnicodeUtil
Interprets the given byte array as UTF-8 and converts to UTF-16.
UTF8toUTF16(BytesRef, char[]) - Static method in class org.apache.lucene.util.UnicodeUtil
UTF8toUTF32(BytesRef, int[]) - Static method in class org.apache.lucene.util.UnicodeUtil
This method assumes valid UTF8 input.
UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
UTF-8 charset string.
Util - Class in org.apache.lucene.util.fst
Static helper methods.
Util.FSTPath<T> - Class in org.apache.lucene.util.fst
Represents a path in TopNSearcher.
Util.Result<T> - Class in org.apache.lucene.util.fst
Holds a single input (IntsRef) + output, returned by shortestPaths().
Util.TopNSearcher<T> - Class in org.apache.lucene.util.fst
Utility class to find top N shortest paths from start point(s).
Util.TopResults<T> - Class in org.apache.lucene.util.fst
Holds the results for a top N search using Util.TopNSearcher

V

validateAutoPrefixSettings(int, int) - Static method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
Throws IllegalArgumentException if any of these settings is invalid.
validateSettings(int, int) - Static method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
Throws IllegalArgumentException if any of these settings is invalid.
validCounter - Variable in class org.apache.lucene.index.CheckIndex.Status
Whether the SegmentInfos.counter is greater than any of the segments' names.
validUTF16String(CharSequence) - Static method in class org.apache.lucene.util.UnicodeUtil
 
validUTF16String(char[], int) - Static method in class org.apache.lucene.util.UnicodeUtil
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator
Return the actual value in the slot.
value - Variable in class org.apache.lucene.util.mutable.MutableValueBool
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueDouble
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueFloat
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueInt
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueLong
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueStr
 
valueAt(int) - Method in class org.apache.lucene.index.SortedNumericDocValues
Retrieve the value for the current document at the specified index.
valueCount - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
valueIterator() - Method in class org.apache.lucene.util.WeakIdentityMap
Returns an iterator over all values of this map.
valueOf(String) - Static method in enum org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.DateTools.Resolution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.Field.Index
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.Field.Store
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.Field.TermVector
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.FieldType.NumericType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.DocValuesType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.IndexOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.IndexWriterConfig.OpenMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.MergeTrigger
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.StoredFieldVisitor.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.TermsEnum.SeekStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.BooleanClause.Occur
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.SortedNumericSelector.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.SortedSetSelector.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.SortField.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.spans.FilterSpans.AcceptStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.spans.SpanWeight.Postings
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.store.IOContext.Context
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.fst.FST.INPUT_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.DateTools.Resolution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.Field.Index
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.Field.Store
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.Field.TermVector
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.FieldType.NumericType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.DocValuesType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.IndexOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.IndexWriterConfig.OpenMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.MergeTrigger
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
leaf values
values - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
leaf values
values() - Static method in enum org.apache.lucene.index.StoredFieldVisitor.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.TermsEnum.SeekStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.BooleanClause.Occur
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.SortedNumericSelector.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.SortedSetSelector.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.SortField.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.spans.FilterSpans.AcceptStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.spans.SpanWeight.Postings
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.store.IOContext.Context
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.util.fst.FST.INPUT_TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns an array containing the constants of this enum type, in the order they are declared.
vectorsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
 
vectorsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.TermVectorsFormat
Returns a TermVectorsReader to read term vectors.
vectorsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
 
vectorsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.TermVectorsFormat
Returns a TermVectorsWriter to write term vectors.
verbose(IndexWriter) - Method in class org.apache.lucene.index.LogMergePolicy
Returns true if LMP is enabled in IndexWriter's infoStream.
verbose() - Method in class org.apache.lucene.index.MergeScheduler
Returns true if infoStream messages are enabled.
VerifyingLockFactory - Class in org.apache.lucene.store
A LockFactory that wraps another LockFactory and verifies that each lock obtain/release is "correct" (never results in two processes holding the lock at the same time).
VerifyingLockFactory(LockFactory, InputStream, OutputStream) - Constructor for class org.apache.lucene.store.VerifyingLockFactory
 
version - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Version the segment was written with
version - Variable in class org.apache.lucene.index.SegmentInfos
Counts how often the index has been changed.
Version - Class in org.apache.lucene.util
Use by certain classes to match version compatibility across releases of Lucene.
VERSION_40 - Static variable in class org.apache.lucene.index.SegmentInfos
The file format version for the segments_N codec header, up to 4.5.
VERSION_46 - Static variable in class org.apache.lucene.index.SegmentInfos
The file format version for the segments_N codec header, since 4.6+.
VERSION_48 - Static variable in class org.apache.lucene.index.SegmentInfos
The file format version for the segments_N codec header, since 4.8+
VERSION_49 - Static variable in class org.apache.lucene.index.SegmentInfos
The file format version for the segments_N codec header, since 4.9+
VERSION_50 - Static variable in class org.apache.lucene.index.SegmentInfos
The file format version for the segments_N codec header, since 5.0+
VERSION_51 - Static variable in class org.apache.lucene.index.SegmentInfos
The file format version for the segments_N codec header, since 5.1+
VERSION_53 - Static variable in class org.apache.lucene.index.SegmentInfos
Adds the Version that committed this segments_N file, as well as the Version of the oldest segment, since 5.3+
VERSION_AUTO_PREFIX_TERMS - Static variable in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
Auto-prefix terms.
VERSION_AUTO_PREFIX_TERMS_COND - Static variable in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
Conditional auto-prefix terms: we record at write time whether this field did write any auto-prefix terms.
VERSION_BYTE_ALIGNED - Static variable in class org.apache.lucene.util.packed.PackedInts
 
VERSION_CURRENT - Static variable in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
Current terms format.
VERSION_CURRENT - Static variable in class org.apache.lucene.util.packed.PackedInts
 
VERSION_MONOTONIC_WITHOUT_ZIGZAG - Static variable in class org.apache.lucene.util.packed.PackedInts
 
VERSION_START - Static variable in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
Initial terms format.
VERSION_START - Static variable in class org.apache.lucene.util.packed.PackedInts
 
VirtualMethod<C> - Class in org.apache.lucene.util
A utility for keeping backwards compatibility on previously abstract methods (or similar replacements).
VirtualMethod(Class<C>, String, Class<?>...) - Constructor for class org.apache.lucene.util.VirtualMethod
Creates a new instance for the given baseClass and method declaration.
visitDocument(int, StoredFieldVisitor) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
 
visitDocument(int, StoredFieldVisitor) - Method in class org.apache.lucene.codecs.StoredFieldsReader
Visit the stored fields for document docID

W

waitForGeneration(long) - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
Waits for the target generation to become visible in the searcher.
waitForGeneration(long, int) - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
Waits for the target generation to become visible in the searcher, up to a maximum specified milli-seconds.
warm(LeafReader) - Method in class org.apache.lucene.index.IndexWriter.IndexReaderWarmer
Invoked on the LeafReader for the newly merged segment, before that segment is made visible to near-real-time readers.
warm(LeafReader) - Method in class org.apache.lucene.index.SimpleMergedSegmentWarmer
 
WeakIdentityMap<K,V> - Class in org.apache.lucene.util
Implements a combination of WeakHashMap and IdentityHashMap.
weight - Variable in class org.apache.lucene.search.Scorer
the Scorer's parent Weight.
Weight - Class in org.apache.lucene.search
Expert: Calculate query weights and build query scorers.
Weight(Query) - Constructor for class org.apache.lucene.search.Weight
Sole constructor, typically invoked by sub-classes.
Weight.DefaultBulkScorer - Class in org.apache.lucene.search
Just wraps a Scorer and performs top scoring using it.
weights - Variable in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
The Weights for our subqueries, in 1-1 correspondence with disjuncts
width() - Method in class org.apache.lucene.search.spans.FilterSpans
 
width() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
width() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
width() - Method in class org.apache.lucene.search.spans.Spans
Return the width of the match, which is typically used to compute the slop factor.
width() - Method in class org.apache.lucene.search.spans.TermSpans
 
WILDCARD_CHAR - Static variable in class org.apache.lucene.search.WildcardQuery
Char equality with support for wildcards
WILDCARD_ESCAPE - Static variable in class org.apache.lucene.search.WildcardQuery
Escape character
WILDCARD_STRING - Static variable in class org.apache.lucene.search.WildcardQuery
String equality with support for wildcards
WildcardQuery - Class in org.apache.lucene.search
Implements the wildcard search query.
WildcardQuery(Term) - Constructor for class org.apache.lucene.search.WildcardQuery
Constructs a query for terms matching term.
WildcardQuery(Term, int) - Constructor for class org.apache.lucene.search.WildcardQuery
Constructs a query for terms matching term.
WINDOWS - Static variable in class org.apache.lucene.util.Constants
True iff running on Windows.
withOffsets() - Method in enum org.apache.lucene.document.Field.TermVector
Deprecated.
 
withPositions() - Method in enum org.apache.lucene.document.Field.TermVector
Deprecated.
 
wrap(LeafReader) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableSubReaderWrapper
 
wrap(DirectoryReader, QueryTimeout) - Static method in class org.apache.lucene.index.ExitableDirectoryReader
Wraps a provided DirectoryReader.
wrap(LeafReader) - Method in class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
Wrap one of the parent DirectoryReader's subreaders
wrap(LeafReader) - Static method in class org.apache.lucene.index.SlowCodecReaderWrapper
Returns a CodecReader view of reader.
wrap(IndexReader) - Static method in class org.apache.lucene.index.SlowCompositeReaderWrapper
This method is sugar for getting an LeafReader from an IndexReader of any kind.
wrap(DocIdSet, Bits) - Static method in class org.apache.lucene.search.BitsFilteredDocIdSet
Convenience wrapper method: If acceptDocs == null it returns the original set without wrapping.
wrap(Collector...) - Static method in class org.apache.lucene.search.MultiCollector
wrap(Iterable<? extends Collector>) - Static method in class org.apache.lucene.search.MultiCollector
Wraps a list of Collectors with a MultiCollector.
wrap(SortedNumericDocValues, SortedNumericSelector.Type, SortField.Type) - Static method in class org.apache.lucene.search.SortedNumericSelector
Wraps a multi-valued SortedNumericDocValues as a single-valued view, using the specified selector and numericType.
wrap(SortedSetDocValues, SortedSetSelector.Type) - Static method in class org.apache.lucene.search.SortedSetSelector
Wraps a multi-valued SortedSetDocValues as a single-valued view, using the specified selector
wrap(String, IndexInput, long, long) - Static method in class org.apache.lucene.store.BufferedIndexInput
Wraps a portion of another IndexInput with buffering.
wrapComponents(String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
Wraps / alters the given TokenStreamComponents, taken from the wrapped Analyzer, to form new components.
wrapComponents(String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
 
wrapFilter(Query, Filter) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
wrapReader(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
Wraps / alters the given Reader.
wrapReader(String, Reader) - Method in class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
 
write(Fields) - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
 
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.CompoundFormat
Packs the provided segment's files into a compound format.
write(Directory, SegmentInfo, String, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.FieldInfosFormat
Writes the provided FieldInfos to the directory.
write(Fields) - Method in class org.apache.lucene.codecs.FieldsConsumer
Write all fields, terms and postings.
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50CompoundFormat
 
write(Directory, SegmentInfo, String, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50FieldInfosFormat
 
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50SegmentInfoFormat
 
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.SegmentInfoFormat
Write SegmentInfo data.
write(BytesRef, DataOutput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
write(CharsRef, DataOutput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
write(IntsRef, DataOutput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
write(Object, DataOutput) - Method in class org.apache.lucene.util.fst.NoOutputs
 
write(T, DataOutput) - Method in class org.apache.lucene.util.fst.Outputs
Encode an output value into a DataOutput.
write(PairOutputs.Pair<A, B>, DataOutput) - Method in class org.apache.lucene.util.fst.PairOutputs
 
write(Long, DataOutput) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
write(BytesRef) - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Writes a BytesRef.
write(byte[]) - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Writes a byte array.
write(byte[], int, int) - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Writes a byte array.
WRITE_LOCK_NAME - Static variable in class org.apache.lucene.index.IndexWriter
Name of the write lock in the index.
WRITE_LOCK_TIMEOUT - Static variable in class org.apache.lucene.index.IndexWriterConfig
Deprecated.
Use SleepingLockWrapper if you want sleeping.
writeByte(byte) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.DataOutput
Writes a single byte.
writeByte(byte) - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.RAMOutputStream
 
writeByte(byte) - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
writeByte(byte) - Method in class org.apache.lucene.util.GrowableByteArrayDataOutput
 
writeByte(byte) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
writeBytes(byte[], int) - Method in class org.apache.lucene.store.DataOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.DataOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.RAMOutputStream
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.util.GrowableByteArrayDataOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
 
writeCRC(IndexOutput) - Static method in class org.apache.lucene.codecs.CodecUtil
Writes CRC32 value as a 64-bit long to the output.
writeField(FieldInfo, IndexableField) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
 
writeField(FieldInfo, IndexableField) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a single stored field.
writeFinalOutput(T, DataOutput) - Method in class org.apache.lucene.util.fst.Outputs
Encode an final node output value into a DataOutput.
writeFooter(IndexOutput) - Static method in class org.apache.lucene.codecs.CodecUtil
Writes a codec footer, which records both a checksum algorithm ID and a checksum.
writeFreqs - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes freqs.
writeHeader(DataOutput, String, int) - Static method in class org.apache.lucene.codecs.CodecUtil
Writes a codec header, which records both a string to identify the file and a version number.
writeIndexHeader(DataOutput, String, int, byte[], String) - Static method in class org.apache.lucene.codecs.CodecUtil
Writes a codec header for an index file, which records both a string to identify the format of the file, a version number, and data to identify the file instance (ID and auxiliary suffix such as generation).
writeInt(int) - Method in class org.apache.lucene.store.DataOutput
Writes an int as four bytes.
writeInt(int) - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
Writes the given value into the slice and resizes the slice if needed
writeLiveDocs(MutableBits, Directory, SegmentCommitInfo, int, IOContext) - Method in class org.apache.lucene.codecs.LiveDocsFormat
Persist live docs bits.
writeLiveDocs(MutableBits, Directory, SegmentCommitInfo, int, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50LiveDocsFormat
 
writeLockTimeout - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Deprecated.
Use SleepingLockWrapper if you want sleeping.
writeLong(long) - Method in class org.apache.lucene.store.DataOutput
Writes a long as eight bytes.
writeLong(long, int) - Method in class org.apache.lucene.util.packed.PackedDataOutput
Write a value using exactly bitsPerValue bits.
writeMapOfStrings(Map<String, String>) - Method in class org.apache.lucene.store.DataOutput
Writes a String map.
writeOffsets - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes offsets.
writePayloads - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes payloads.
writePositions - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes positions.
Writer(DataOutput, int, int) - Constructor for class org.apache.lucene.util.packed.PackedInts.Writer
 
writeSetOfStrings(Set<String>) - Method in class org.apache.lucene.store.DataOutput
Writes a String set.
writeShort(short) - Method in class org.apache.lucene.store.DataOutput
Writes a short as two bytes.
writeSkip(IndexOutput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Writes the buffered skip lists to the given output.
writeSkipData(int, IndexOutput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Subclasses must implement the actual skip data encoding in this method.
writeString(String) - Method in class org.apache.lucene.store.DataOutput
Writes a string.
writeStringSet(Set<String>) - Method in class org.apache.lucene.store.DataOutput
Deprecated.
writeStringStringMap(Map<String, String>) - Method in class org.apache.lucene.store.DataOutput
Deprecated.
writeTerm(BytesRef, TermsEnum, FixedBitSet) - Method in class org.apache.lucene.codecs.PostingsWriterBase
Write all postings for one term; use the provided TermsEnum to pull a PostingsEnum.
writeTerm(BytesRef, TermsEnum, FixedBitSet) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
 
writeTo(DataOutput) - Method in class org.apache.lucene.store.RAMOutputStream
Copy the current contents of this buffer to the named output.
writeTo(byte[], int) - Method in class org.apache.lucene.store.RAMOutputStream
Copy the current contents of this buffer to output byte array
writeVInt(int) - Method in class org.apache.lucene.store.DataOutput
Writes an int in a variable-length format.
writeVLong(long) - Method in class org.apache.lucene.store.DataOutput
Writes an long in a variable-length format.
writeZInt(int) - Method in class org.apache.lucene.store.DataOutput
Write a zig-zag-encoded variable-length integer.
writeZLong(long) - Method in class org.apache.lucene.store.DataOutput
Write a zig-zag-encoded variable-length long.

X

xor(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this XOR other
xor(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place XOR of the bits provided by the iterator.
xor(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
this = this XOR other

Y

YES - Static variable in class org.apache.lucene.index.SegmentInfo
Used by some member fields to mean present (e.g., norms, deletions).

Z

zigZagDecode(int) - Static method in class org.apache.lucene.util.BitUtil
Decode an int previously encoded with BitUtil.zigZagEncode(int).
zigZagDecode(long) - Static method in class org.apache.lucene.util.BitUtil
Decode a long previously encoded with BitUtil.zigZagEncode(long).
zigZagEncode(int) - Static method in class org.apache.lucene.util.BitUtil
Same as BitUtil.zigZagEncode(long) but on integers.
zigZagEncode(long) - Static method in class org.apache.lucene.util.BitUtil
Zig-zag encode the provided long.

_

_innerIter - Variable in class org.apache.lucene.search.FilteredDocIdSetIterator
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links
Lucene Core 5.3.1.redhat-2

Copyright © 2000–2017 The Apache Software Foundation. All rights reserved.