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

A

abort() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
 
abort() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
abort() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
 
abort() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
 
abort() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Aborts writing entirely, implementation should remove any partially-written files, etc.
abort() - Method in class org.apache.lucene.codecs.TermVectorsWriter
Aborts writing entirely, implementation should remove any partially-written files, etc.
accept(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
Return if term is accepted, not accepted or the iteration should ended (and possibly seek).
accept(BytesRef) - Method in class org.apache.lucene.index.SingleTermsEnum
 
accept(BytesRef) - Method in class org.apache.lucene.search.PrefixTermsEnum
 
accept(BytesRef) - Method in class org.apache.lucene.search.TermRangeTermsEnum
 
acceptDocs - Variable in class org.apache.lucene.search.FieldCacheDocIdSet
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
Implementing classes are required to return whether the current position is a match for the passed in "match" SpanQuery.
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
acceptResult(IntsRef, T) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CachingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.Collector
Return true if this collector does not require the matching docIDs to be delivered in int sort order (smallest to largest) to Collector.collect(int).
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.MultiCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TimeLimitingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TopFieldCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TotalHitCountCollector
 
acosh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic cosine of a 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
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(SegmentCommitInfo) - Method in class org.apache.lucene.index.SegmentInfos
Appends the provided SegmentCommitInfo.
add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery
Adds a clause to a boolean query.
add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery
Adds a clause to a boolean query.
add(Query) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Add a subquery to this disjunction
add(Collection<Query>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Add a collection of disjuncts to this disjunction via Iterable<Query>
add(String, T) - Method in class org.apache.lucene.search.LiveFieldValues
Call this after you've successfully added a document to the index, to record what value you just set the field to.
add(Term) - Method in class org.apache.lucene.search.MultiPhraseQuery
Add a single term at the next position in the phrase.
add(Term[]) - Method in class org.apache.lucene.search.MultiPhraseQuery
Add multiple terms at the next position in the phrase.
add(Term[], int) - Method in class org.apache.lucene.search.MultiPhraseQuery
Allows to specify the relative position of terms within the phrase.
add(Term) - Method in class org.apache.lucene.search.PhraseQuery
Adds a term to the end of the query phrase.
add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery
Adds a term to the end of the query phrase.
add(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef
add(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef with a pre-calculated hash code.
add(IntsRef, T) - Method in class org.apache.lucene.util.fst.Builder
It's OK to add the same input twice in a row with different outputs, as long as outputs impls the merge method.
add(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
add(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
add(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
add(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
add(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg add("foo", "bar") -> "foobar"
add(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
add(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
add(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
 
add(long) - Method in class org.apache.lucene.util.packed.PackedInts.Writer
Add a value to the stream.
add(int) - Method in class org.apache.lucene.util.PForDeltaDocIdSet.Builder
Add a document to this builder.
add(DocIdSetIterator) - Method in class org.apache.lucene.util.PForDeltaDocIdSet.Builder
Convenience method to add the content of a DocIdSetIterator 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.WAH8DocIdSet.Builder
Add a document to this builder.
add(DocIdSetIterator) - Method in class org.apache.lucene.util.WAH8DocIdSet.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.
addBinaryField(FieldInfo, Iterable<BytesRef>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
 
addBuffer(int) - Method in class org.apache.lucene.store.RAMFile
 
addByPoolOffset(int) - Method in class org.apache.lucene.util.BytesRefHash
Adds a "arbitrary" int offset instead of a BytesRef term.
addClause(BooleanQuery, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
addClause(BooleanQuery, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
addClause(SpanQuery) - Method in class org.apache.lucene.search.spans.SpanOrQuery
Adds a clause to this query
addCoreClosedListener(SegmentReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
Expert: adds a CoreClosedListener to this reader's shared core
addDetail(Explanation) - Method in class org.apache.lucene.search.Explanation
Adds a sub-node to this explanation node.
addDocument(Iterable<? extends IndexableField>, FieldInfos) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
sugar method for startDocument() + writeField() for every stored field in the document
addDocument(Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index.
addDocument(Iterable<? extends IndexableField>, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index, using the provided analyzer instead of the value of IndexWriter.getAnalyzer().
addDocument(Iterable<? extends IndexableField>, Analyzer) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.addDocument(Iterable,Analyzer) and returns the generation that reflects this change.
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>>, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
Atomically adds a block of documents, analyzed using the provided analyzer, with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
addDocuments(Iterable<? extends Iterable<? extends IndexableField>>, Analyzer) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.addDocuments(Iterable,Analyzer) and returns the generation that reflects this change.
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.
addEpsilons(Automaton, Collection<StatePair>) - Static method in class org.apache.lucene.util.automaton.BasicOperations
Adds epsilon transitions to the given automaton.
addField(FieldInfo) - Method in class org.apache.lucene.codecs.BlockTreeTermsWriter
 
addField(FieldInfo) - Method in class org.apache.lucene.codecs.FieldsConsumer
Add a new field
addFile(String) - Method in class org.apache.lucene.index.SegmentInfo
Add this file to the set of files written for this segment.
addFiles(Collection<String>) - Method in class org.apache.lucene.index.SegmentInfo
Add these files to the set of files written for this segment.
addIfCompetitive(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
addIndexes(Directory...) - Method in class org.apache.lucene.index.IndexWriter
Adds all segments from an array of indexes into this index.
addIndexes(IndexReader...) - Method in class org.apache.lucene.index.IndexWriter
Merges the provided indexes into this index.
addIndexes(Directory...) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.addIndexes(Directory...) and returns the generation that reflects this change.
addIndexes(IndexReader...) - Method in class org.apache.lucene.index.TrackingIndexWriter
Calls IndexWriter.addIndexes(IndexReader...) 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.
addNumericField(FieldInfo, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes numeric docvalues for a field.
addNumericField(FieldInfo, Iterable<Number>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
 
addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
 
addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
Add a new position & payload
addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.PostingsConsumer
Add a new position & payload, and start/end offset.
addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Adds a term position and offsets
addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
 
addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called by IndexWriter when writing new segments.
addRange(BytesRef, BytesRef) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRange(int, int, int) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
Overwrite this method, if you like to receive the raw int range bounds.
addRange(BytesRef, BytesRef) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRange(long, long, int) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
Overwrite this method, if you like to receive the raw long range bounds.
addRawDocuments(IndexInput, int[], int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
Bulk write a contiguous series of documents.
addReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
addressesOffset - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
offset to the addressing data that maps a value to its slice of the byte[]
addressInterval - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
interval of shared prefix chunks (when using prefix-compressed binary)
addSortedField(FieldInfo, Iterable<BytesRef>, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted binary docvalues for a field.
addSortedField(FieldInfo, Iterable<BytesRef>, Iterable<Number>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
 
addSortedSetField(FieldInfo, Iterable<BytesRef>, Iterable<Number>, Iterable<Number>) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted set docvalues for a field
addSortedSetField(FieldInfo, Iterable<BytesRef>, Iterable<Number>, Iterable<Number>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
 
addStartPaths(FST.Arc<T>, T, boolean, IntsRef) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
Adds all leaving arcs, including 'finished' arc, if the node is final, from this node into the queue.
addTermsDict(FieldInfo, Iterable<BytesRef>) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
expert: writes a value dictionary for a sorted/sortedset field
addTransition(Transition) - Method in class org.apache.lucene.util.automaton.State
Adds an outgoing transition.
advance(int) - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
 
advance(int) - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
 
advance(int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
 
advance(int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
 
advance(int) - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
 
advance(int) - Method in class org.apache.lucene.index.MultiDocsEnum
 
advance(int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
advance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
Advances to the first beyond the current whose document number is greater than or equal to target, and returns the document number itself.
advance(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
advance(int) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
advance(int) - Method in class org.apache.lucene.search.spans.SpanScorer
 
advance(int) - Method in class org.apache.lucene.util.OpenBitSetIterator
 
advanceToIndex(long) - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
Advance the decoding index to a given index.
advanceToValue(long) - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
Given a target value, advance the decoding index to the first bigger or equal value and return it if it is available.
afterClose() - Method in class org.apache.lucene.search.ReferenceManager
Called after close(), so subclass can free any resources.
AfterEffect - Class in org.apache.lucene.search.similarities
This class acts as the base class for the implementations of the first normalization of the informative content in the DFR framework.
AfterEffect() - Constructor for class org.apache.lucene.search.similarities.AfterEffect
Sole constructor.
afterEffect - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
The first normalization of the information content.
AfterEffect.NoAfterEffect - Class in org.apache.lucene.search.similarities
Implementation used when there is no aftereffect.
AfterEffect.NoAfterEffect() - Constructor for class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
Sole constructor: parameter-free
AfterEffectB - Class in org.apache.lucene.search.similarities
Model of the information gain based on the ratio of two Bernoulli processes.
AfterEffectB() - Constructor for class org.apache.lucene.search.similarities.AfterEffectB
Sole constructor: parameter-free
AfterEffectL - Class in org.apache.lucene.search.similarities
Model of the information gain based on Laplace's law of succession.
AfterEffectL() - Constructor for class org.apache.lucene.search.similarities.AfterEffectL
Sole constructor: parameter-free
afterMaybeRefresh() - Method in class org.apache.lucene.search.ReferenceManager
Called after a refresh was attempted, regardless of whether a new reference was in fact created.
afterRefresh(boolean) - Method in class org.apache.lucene.search.LiveFieldValues
 
afterRefresh(boolean) - Method in interface org.apache.lucene.search.ReferenceManager.RefreshListener
Called after the attempted refresh; if the refresh did open a new reference then didRefresh will be true and ReferenceManager.acquire() is guaranteed to return the new reference.
alignObjectSize(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Aligns an object size to be the next multiple of RamUsageEstimator.NUM_BYTES_OBJECT_ALIGNMENT.
ALL - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables all optional regexp syntax.
allocSlice(byte[], int) - Method in class org.apache.lucene.util.ByteBlockPool
Creates a new byte slice with the given starting size and returns the slices offset in the pool.
AlreadyClosedException - Exception in org.apache.lucene.store
This exception is thrown when there is an attempt to access something that has already been closed.
AlreadyClosedException(String) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
 
Analyzer - Class in org.apache.lucene.analysis
An Analyzer builds TokenStreams, which analyze text.
Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
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.GlobalReuseStrategy - Class in org.apache.lucene.analysis
Deprecated.
This implementation class will be hidden in Lucene 5.0. Use Analyzer.GLOBAL_REUSE_STRATEGY instead!
Analyzer.GlobalReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.GlobalReuseStrategy
Deprecated.
Don't create instances of this class, use Analyzer.GLOBAL_REUSE_STRATEGY
Analyzer.PerFieldReuseStrategy - Class in org.apache.lucene.analysis
Deprecated.
This implementation class will be hidden in Lucene 5.0. Use Analyzer.PER_FIELD_REUSE_STRATEGY instead!
Analyzer.PerFieldReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.PerFieldReuseStrategy
Deprecated.
Don't create instances of this class, use Analyzer.PER_FIELD_REUSE_STRATEGY
Analyzer.ReuseStrategy - Class in org.apache.lucene.analysis
Strategy defining how TokenStreamComponents are reused per call to Analyzer.tokenStream(String, java.io.Reader).
Analyzer.ReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Sole constructor.
Analyzer.TokenStreamComponents - Class in org.apache.lucene.analysis
This class encapsulates the outer components of a token stream.
Analyzer.TokenStreamComponents(Tokenizer, TokenStream) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Creates a new Analyzer.TokenStreamComponents instance.
Analyzer.TokenStreamComponents(Tokenizer) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Creates a new Analyzer.TokenStreamComponents instance.
AnalyzerWrapper - Class in org.apache.lucene.analysis
Extension to Analyzer suitable for Analyzers which wrap other Analyzers.
AnalyzerWrapper() - Constructor for class org.apache.lucene.analysis.AnalyzerWrapper
Deprecated.
Use AnalyzerWrapper.AnalyzerWrapper(Analyzer.ReuseStrategy) and specify a valid Analyzer.ReuseStrategy, probably retrieved from the wrapped analyzer using Analyzer.getReuseStrategy().
AnalyzerWrapper(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.AnalyzerWrapper
Creates a new AnalyzerWrapper with the given reuse strategy.
and(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place AND of the bits provided by the iterator.
and(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND other
and(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
 
andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place AND NOT of the bits provided by the iterator.
andNot(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND NOT other
andNot(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
 
andNotCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
Returns the popcount or cardinality of "a and not b" or "intersection(a, not(b))".
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.BytesRef
Appends the bytes from the given BytesRef
append(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
Appends the given array to this CharsRef
AppendingDeltaPackedLongBuffer - Class in org.apache.lucene.util.packed
Utility class to buffer a list of signed longs in memory.
AppendingDeltaPackedLongBuffer(int, int, float) - Constructor for class org.apache.lucene.util.packed.AppendingDeltaPackedLongBuffer
AppendingDeltaPackedLongBuffer() - Constructor for class org.apache.lucene.util.packed.AppendingDeltaPackedLongBuffer
Create an AppendingDeltaPackedLongBuffer with initialPageCount=16, pageSize=1024 and acceptableOverheadRatio=PackedInts.DEFAULT
AppendingDeltaPackedLongBuffer(float) - Constructor for class org.apache.lucene.util.packed.AppendingDeltaPackedLongBuffer
Create an AppendingDeltaPackedLongBuffer with initialPageCount=16, pageSize=1024
AppendingPackedLongBuffer - Class in org.apache.lucene.util.packed
Utility class to buffer a list of signed longs in memory.
AppendingPackedLongBuffer(int, int, float) - Constructor for class org.apache.lucene.util.packed.AppendingPackedLongBuffer
AppendingPackedLongBuffer() - Constructor for class org.apache.lucene.util.packed.AppendingPackedLongBuffer
Create an AppendingPackedLongBuffer with initialPageCount=16, pageSize=1024 and acceptableOverheadRatio=PackedInts.DEFAULT
AppendingPackedLongBuffer(float) - Constructor for class org.apache.lucene.util.packed.AppendingPackedLongBuffer
Create an AppendingPackedLongBuffer with initialPageCount=16, pageSize=1024
arc - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
arcCount - Variable in class org.apache.lucene.util.fst.FST
 
arcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
arcWithOutputCount - Variable in class org.apache.lucene.util.fst.FST
 
ArrayUtil - Class in org.apache.lucene.util
Methods for manipulating arrays.
asin(double) - Static method in class org.apache.lucene.util.SloppyMath
Returns the arc sine of a value.
asinh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic sine of a double value.
asList() - Method in class org.apache.lucene.index.SegmentInfos
Returns all contained segments as an unmodifiable List view.
atanh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic tangent of a double value.
AtomicReader - Class in org.apache.lucene.index
AtomicReader is an abstract class, providing an interface for accessing an index.
AtomicReader() - Constructor for class org.apache.lucene.index.AtomicReader
Sole constructor.
AtomicReaderContext - Class in org.apache.lucene.index
Attribute - Interface in org.apache.lucene.util
Base interface for attributes.
AttributeImpl - Class in org.apache.lucene.util
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.DocsEnum
Returns the related attributes.
attributes() - Method in class org.apache.lucene.index.FieldInfo
Returns internal codec attributes map.
attributes() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
 
attributes() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
 
attributes() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
 
attributes() - Method in class org.apache.lucene.index.FilteredTermsEnum
Returns the related attributes, the returned AttributeSource is shared with the delegate TermsEnum.
attributes() - Method in class org.apache.lucene.index.SegmentInfo
Deprecated.
no longer supported
attributes() - Method in class org.apache.lucene.index.TermsEnum
Returns the related attributes.
AttributeSource - Class in org.apache.lucene.util
An AttributeSource contains a list of different AttributeImpls, and methods to add and get them.
AttributeSource() - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the default attribute factory AttributeSource.AttributeFactory.DEFAULT_ATTRIBUTE_FACTORY.
AttributeSource(AttributeSource) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource that uses the same attributes as the supplied one.
AttributeSource(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the supplied AttributeSource.AttributeFactory for creating new Attribute instances.
AttributeSource.AttributeFactory - Class in org.apache.lucene.util
An AttributeFactory creates instances of AttributeImpls.
AttributeSource.AttributeFactory() - Constructor for class org.apache.lucene.util.AttributeSource.AttributeFactory
 
AttributeSource.State - Class in org.apache.lucene.util
This class holds the state of an AttributeSource.
AttributeSource.State() - Constructor for class org.apache.lucene.util.AttributeSource.State
 
automata() - Method in interface org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttribute
 
automata() - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
 
automaton - Variable in class org.apache.lucene.search.AutomatonQuery
the automaton to match index terms against
Automaton - Class in org.apache.lucene.util.automaton
Finite-state automaton with regular expression operations.
Automaton(State) - Constructor for class org.apache.lucene.util.automaton.Automaton
Constructs a new automaton that accepts the empty language.
Automaton() - Constructor for class org.apache.lucene.util.automaton.Automaton
 
AUTOMATON - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables named automata (<identifier>).
AutomatonProvider - Interface in org.apache.lucene.util.automaton
Automaton provider for RegExp. RegExp.toAutomaton(AutomatonProvider)
AutomatonQuery - Class in org.apache.lucene.search
A Query that will match terms against a finite-state machine.
AutomatonQuery(Term, Automaton) - Constructor for class org.apache.lucene.search.AutomatonQuery
Create a new AutomatonQuery from an Automaton.
availableCodecs() - Static method in class org.apache.lucene.codecs.Codec
returns a list of all available codec names
availableDocValuesFormats() - Static method in class org.apache.lucene.codecs.DocValuesFormat
returns a list of all available format names
availablePostingsFormats() - Static method in class org.apache.lucene.codecs.PostingsFormat
returns a list of all available format names
availableServices() - Method in class org.apache.lucene.util.NamedSPILoader
 
AveragePayloadFunction - Class in org.apache.lucene.search.payloads
Calculate the final score as the average score of all payloads seen.
AveragePayloadFunction() - Constructor for class org.apache.lucene.search.payloads.AveragePayloadFunction
 
avgFieldLength - Variable in class org.apache.lucene.search.similarities.BasicStats
The average field length.
avgFieldLength(CollectionStatistics) - Method in class org.apache.lucene.search.similarities.BM25Similarity
The default implementation computes the average as sumTotalTermFreq / maxDoc, or returns 1 if the index does not store sumTotalTermFreq (Lucene 3.x indexes or any field that omits frequency information).

B

backToValue(long) - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
Given a target value, go back to the first smaller or equal value and return it if it is available.
base - Variable in class org.apache.lucene.index.UpgradeIndexMergePolicy
Wrapped MergePolicy.
base - Variable in class org.apache.lucene.search.CachingCollector
 
BaseCompositeReader<R extends IndexReader> - Class in org.apache.lucene.index
Base class for implementing CompositeReaders based on an array of sub-readers.
BaseCompositeReader(R[]) - Constructor for class org.apache.lucene.index.BaseCompositeReader
Constructs a BaseCompositeReader on the given subReaders.
BaseDirectory - Class in org.apache.lucene.store
Base implementation for a concrete Directory.
BaseDirectory() - Constructor for class org.apache.lucene.store.BaseDirectory
Sole constructor.
baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
 
baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedMutable
 
BasicAutomata - Class in org.apache.lucene.util.automaton
Construction of basic automata.
BasicModel - Class in org.apache.lucene.search.similarities
This class acts as the base class for the specific basic model implementations in the DFR framework.
BasicModel() - Constructor for class org.apache.lucene.search.similarities.BasicModel
Sole constructor.
basicModel - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
The basic model for information content.
BasicModelBE - Class in org.apache.lucene.search.similarities
Limiting form of the Bose-Einstein model.
BasicModelBE() - Constructor for class org.apache.lucene.search.similarities.BasicModelBE
Sole constructor: parameter-free
BasicModelD - Class in org.apache.lucene.search.similarities
Implements the approximation of the binomial model with the divergence for DFR.
BasicModelD() - Constructor for class org.apache.lucene.search.similarities.BasicModelD
Sole constructor: parameter-free
BasicModelG - Class in org.apache.lucene.search.similarities
Geometric as limiting form of the Bose-Einstein model.
BasicModelG() - Constructor for class org.apache.lucene.search.similarities.BasicModelG
Sole constructor: parameter-free
BasicModelIF - Class in org.apache.lucene.search.similarities
An approximation of the I(ne) model.
BasicModelIF() - Constructor for class org.apache.lucene.search.similarities.BasicModelIF
Sole constructor: parameter-free
BasicModelIn - Class in org.apache.lucene.search.similarities
The basic tf-idf model of randomness.
BasicModelIn() - Constructor for class org.apache.lucene.search.similarities.BasicModelIn
Sole constructor: parameter-free
BasicModelIne - Class in org.apache.lucene.search.similarities
Tf-idf model of randomness, based on a mixture of Poisson and inverse document frequency.
BasicModelIne() - Constructor for class org.apache.lucene.search.similarities.BasicModelIne
Sole constructor: parameter-free
BasicModelP - Class in org.apache.lucene.search.similarities
Implements the Poisson approximation for the binomial model for DFR.
BasicModelP() - Constructor for class org.apache.lucene.search.similarities.BasicModelP
Sole constructor: parameter-free
BasicOperations - Class in org.apache.lucene.util.automaton
Basic automata operations.
BasicStats - Class in org.apache.lucene.search.similarities
Stores all statistics commonly used ranking methods.
BasicStats(String, float) - Constructor for class org.apache.lucene.search.similarities.BasicStats
Constructor.
beforeRefresh() - Method in class org.apache.lucene.search.LiveFieldValues
 
beforeRefresh() - Method in interface org.apache.lucene.search.ReferenceManager.RefreshListener
Called right before a refresh attempt starts.
BIG_TERM - Static variable in class org.apache.lucene.util.UnicodeUtil
A binary term consisting of a number of 0xff bytes, likely to be bigger than other terms one would normally encounter, and definitely bigger than any UTF-8 terms.
BINARY_FIXED_UNCOMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
Uncompressed binary, written directly (fixed length).
BINARY_PREFIX_COMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
Compressed binary with shared prefixes
BINARY_VARIABLE_UNCOMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
Uncompressed binary, written directly (variable length).
BinaryDocValues - Class in org.apache.lucene.index
A per-document byte[]
BinaryDocValues() - Constructor for class org.apache.lucene.index.BinaryDocValues
Sole constructor.
BinaryDocValuesField - Class in org.apache.lucene.document
Field that stores a per-document BytesRef value.
BinaryDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.BinaryDocValuesField
Create a new binary DocValues field.
binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a binary field.
binaryValue() - Method in class org.apache.lucene.document.Field
 
binaryValue() - Method in interface org.apache.lucene.index.IndexableField
Non-null if this field has a binary value
bitCount(byte) - Static method in class org.apache.lucene.util.BitUtil
Return the number of bits sets in b.
bitList(byte) - Static method in class org.apache.lucene.util.BitUtil
Return the list of bits which are set in b encoded as followed: (i >>> (4 * n)) & 0x0F is the offset of the n-th set bit of the given byte plus one, or 0 if there are n or less bits set in the given byte.
bits() - Method in class org.apache.lucene.search.DocIdSet
Optionally provides a Bits interface for random access to matching documents.
bits() - Method in class org.apache.lucene.search.FieldCacheDocIdSet
 
bits() - Method in class org.apache.lucene.search.FilteredDocIdSet
 
Bits - Interface in org.apache.lucene.util
Interface for Bitset-like structures.
bits() - Method in class org.apache.lucene.util.DocIdBitSet
 
bits() - Method in class org.apache.lucene.util.FixedBitSet
 
bits - Variable in class org.apache.lucene.util.OpenBitSet
 
bits() - Method in class org.apache.lucene.util.OpenBitSet
 
Bits.MatchAllBits - Class in org.apache.lucene.util
Bits impl of the specified length with all bits set.
Bits.MatchAllBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchAllBits
 
Bits.MatchNoBits - Class in org.apache.lucene.util
Bits impl of the specified length with no bits set.
Bits.MatchNoBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchNoBits
 
bits2words(int) - Static method in class org.apache.lucene.util.FixedBitSet
returns the number of 64 bit words it would take to hold numBits
bits2words(long) - Static method in class org.apache.lucene.util.OpenBitSet
returns the number of 64 bit words it would take to hold numBits
BitsFilteredDocIdSet - Class in org.apache.lucene.search
This implementation supplies a filtered DocIdSet, that excludes all docids which are not in a Bits instance.
BitsFilteredDocIdSet(DocIdSet, Bits) - Constructor for class org.apache.lucene.search.BitsFilteredDocIdSet
Constructor.
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
 
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
bitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
The number of bits per value.
bitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
Returns how many bits are required to hold values up to and including maxValue
BitUtil - Class in org.apache.lucene.util
A variety of high efficiency bit twiddling routines.
BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
Fixed packed block size, number of integers encoded in a single packed block.
blockCountByPrefixLen - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
Number of blocks at each prefix depth.
blockFilePointer - Variable in class org.apache.lucene.codecs.BlockTermState
fp into the terms dict primary file (_X.tim) that holds this term
BlockPackedReader - Class in org.apache.lucene.util.packed
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.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
packed ints blocksize
blockSize - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.NumericEntry
packed ints blocksize
blockSize - Variable in class org.apache.lucene.util.ByteBlockPool.Allocator
 
blockSize - Variable in class org.apache.lucene.util.IntBlockPool.Allocator
 
BlockTermState - Class in org.apache.lucene.codecs
Holds all state required for PostingsReaderBase to produce a DocsEnum 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
A block-based terms index and dictionary that assigns terms to variable length blocks according to how they share prefixes.
BlockTreeTermsReader(Directory, FieldInfos, SegmentInfo, PostingsReaderBase, IOContext, String, int) - Constructor for class org.apache.lucene.codecs.BlockTreeTermsReader
Sole constructor.
BlockTreeTermsReader.FieldReader - Class in org.apache.lucene.codecs
BlockTree's implementation of Terms.
BlockTreeTermsReader.Stats - Class in org.apache.lucene.codecs
BlockTree statistics for a single field returned by BlockTreeTermsReader.FieldReader.computeStats().
BlockTreeTermsWriter - Class in org.apache.lucene.codecs
Block-based terms index and dictionary writer.
BlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int) - Constructor for class org.apache.lucene.codecs.BlockTreeTermsWriter
Create a new writer.
BM25Similarity - Class in org.apache.lucene.search.similarities
BM25 Similarity.
BM25Similarity(float, float) - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
BM25 with the supplied parameter values.
BM25Similarity() - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
BM25 with these default values: k1 = 1.2, b = 0.75.
BooleanClause - Class in org.apache.lucene.search
A clause in a BooleanQuery.
BooleanClause(Query, BooleanClause.Occur) - Constructor for class org.apache.lucene.search.BooleanClause
Constructs a BooleanClause.
BooleanClause.Occur - Enum in org.apache.lucene.search
Specifies how clauses are to occur in matching documents.
BooleanQuery - Class in org.apache.lucene.search
A Query that matches documents matching boolean combinations of other queries, e.g.
BooleanQuery() - Constructor for class org.apache.lucene.search.BooleanQuery
Constructs an empty boolean query.
BooleanQuery(boolean) - Constructor for class org.apache.lucene.search.BooleanQuery
Constructs an empty boolean query.
BooleanQuery.BooleanWeight - Class in org.apache.lucene.search
Expert: the Weight for BooleanQuery, used to normalize, score and explain these queries.
BooleanQuery.BooleanWeight(IndexSearcher, boolean) - Constructor for class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
Thrown when an attempt is made to add more than BooleanQuery.getMaxClauseCount() clauses.
BooleanQuery.TooManyClauses() - Constructor for exception org.apache.lucene.search.BooleanQuery.TooManyClauses
 
boost - Variable in class org.apache.lucene.document.Field
Field's boost
boost() - Method in class org.apache.lucene.document.Field
Returns the field's index-time boost.
boost() - Method in interface org.apache.lucene.index.IndexableField
Returns the field's index-time boost.
boost(float) - Static method in class org.apache.lucene.util.ToStringUtils
for printing boost only if not 1.0
BoostAttribute - Interface in org.apache.lucene.search
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
 
BroadWord - Class in org.apache.lucene.util
Methods and constants inspired by the article "Broadword Implementation of Rank/Select Queries" by Sebastiano Vigna, January 30, 2012: algorithm 1: BroadWord.bitCount(long), count of set bits in a long algorithm 2: BroadWord.select(long, int), selection of a set bit in a long, bytewise signed smaller <8 operator: BroadWord.smallerUpTo7_8(long,long).
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.
BufferedIndexInput - Class in org.apache.lucene.store
Base implementation class for buffered IndexInput.
BufferedIndexInput(String) - Constructor for class org.apache.lucene.store.BufferedIndexInput
 
BufferedIndexInput(String, IOContext) - Constructor for class org.apache.lucene.store.BufferedIndexInput
 
BufferedIndexInput(String, int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
Inits BufferedIndexInput with a specific bufferSize
BufferedIndexOutput - Class in org.apache.lucene.store
Base implementation class for buffered IndexOutput.
BufferedIndexOutput() - Constructor for class org.apache.lucene.store.BufferedIndexOutput
Creates a new BufferedIndexOutput with the default buffer size (16384 bytes see BufferedIndexOutput.DEFAULT_BUFFER_SIZE)
BufferedIndexOutput(int) - Constructor for class org.apache.lucene.store.BufferedIndexOutput
Creates a new BufferedIndexOutput with the given buffer size.
buffers - Variable in class org.apache.lucene.store.RAMFile
 
buffers - Variable in class org.apache.lucene.util.ByteBlockPool
array of buffers currently used in the pool.
buffers - Variable in class org.apache.lucene.util.IntBlockPool
array of buffers currently used in the pool.
bufferSize(IOContext) - Static method in class org.apache.lucene.store.BufferedIndexInput
Returns default buffer sizes for the given IOContext
bufferSkip(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Writes the current skip data to the buffers.
build(AtomicReader) - Static method in class org.apache.lucene.index.MergeState.DocMap
Creates a MergeState.DocMap instance appropriate for this reader.
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.util.PForDeltaDocIdSet.Builder
Build the PForDeltaDocIdSet instance.
build() - Method in class org.apache.lucene.util.WAH8DocIdSet.Builder
 
Builder<T> - Class in org.apache.lucene.util.fst
Builds a minimal FST (maps an IntsRef term to an arbitrary output) from pre-sorted terms with outputs.
Builder(FST.INPUT_TYPE, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.Builder
Instantiates an FST/FSA builder without any pruning.
Builder(FST.INPUT_TYPE, int, int, boolean, boolean, int, Outputs<T>, Builder.FreezeTail<T>, boolean, float, boolean, int) - Constructor for class org.apache.lucene.util.fst.Builder
Instantiates an FST/FSA builder with all the possible tuning and construction tweaks.
Builder.Arc<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) arc.
Builder.Arc() - Constructor for class org.apache.lucene.util.fst.Builder.Arc
 
Builder.FreezeTail<T> - Class in org.apache.lucene.util.fst
Expert: this is invoked by Builder whenever a suffix is serialized.
Builder.FreezeTail() - Constructor for class org.apache.lucene.util.fst.Builder.FreezeTail
 
Builder.UnCompiledNode<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) Node.
Builder.UnCompiledNode(Builder<T>, int) - Constructor for class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
byId(int) - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
Get a format according to its ID.
byte315ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
byteToFloat(b, mantissaBits=3, zeroExponent=15)
byte52ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
byteToFloat(b, mantissaBits=5, zeroExponent=2)
BYTE_BLOCK_MASK - Static variable in class org.apache.lucene.util.ByteBlockPool
 
BYTE_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.ByteBlockPool
 
BYTE_BLOCK_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
 
byteArray(StringBuilder, byte[]) - Static method in class org.apache.lucene.util.ToStringUtils
 
ByteArrayDataInput - Class in org.apache.lucene.store
DataInput backed by a byte array.
ByteArrayDataInput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput() - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataOutput - Class in org.apache.lucene.store
DataOutput backed by a byte array.
ByteArrayDataOutput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput() - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
byteBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
The minimum number of byte blocks to encode in a single iteration, when using byte encoding.
byteBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
The minimum number of byte blocks to encode in a single iteration, when using byte encoding.
ByteBlockPool - Class in org.apache.lucene.util
Class that Posting and PostingVector use to write byte streams into shared fixed-size byte[] arrays.
ByteBlockPool(ByteBlockPool.Allocator) - Constructor for class org.apache.lucene.util.ByteBlockPool
 
ByteBlockPool.Allocator - Class in org.apache.lucene.util
Abstract class for allocating and freeing byte blocks.
ByteBlockPool.Allocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.Allocator
 
ByteBlockPool.DirectAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles.
ByteBlockPool.DirectAllocator() - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
ByteBlockPool.DirectAllocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
ByteBlockPool.DirectTrackingAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles, but tracks how much total RAM is in use.
ByteBlockPool.DirectTrackingAllocator(Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
ByteBlockPool.DirectTrackingAllocator(int, Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
byteCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Computes how many byte blocks are needed to store values values of size bitsPerValue.
ByteDocValuesField - Class in org.apache.lucene.document
Deprecated.
ByteDocValuesField(String, byte) - Constructor for class org.apache.lucene.document.ByteDocValuesField
Deprecated.
Creates a new DocValues field with the specified 8-bit byte value
byteOffset - Variable in class org.apache.lucene.util.ByteBlockPool
Current head offset
ByteRunAutomaton - Class in org.apache.lucene.util.automaton
Automaton representation for matching UTF-8 byte[].
ByteRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
 
ByteRunAutomaton(Automaton, boolean) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
expert: if utf8 is true, the input is already byte-based
bytes() - Method in class org.apache.lucene.index.Term
Returns the bytes of this term.
bytes - Variable in class org.apache.lucene.util.BytesRef
The contents of the BytesRef.
bytes - Variable in class org.apache.lucene.util.GrowableByteArrayDataOutput
The bytes
bytesDifference(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Compares two BytesRef, element by element, and returns the number of elements common to both arrays.
bytesEquals(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Expert: compares the bytes against another BytesRef, returning true if the bytes are equal.
ByteSequenceOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a sequence of bytes.
BytesRef - Class in org.apache.lucene.util
Represents byte[], as a slice (offset + length) into an existing byte[].
BytesRef() - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef with BytesRef.EMPTY_BYTES
BytesRef(byte[], int, int) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(byte[]) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(int) - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef pointing to a new array of size capacity.
BytesRef(CharSequence) - Constructor for class org.apache.lucene.util.BytesRef
Initialize the byte[] from the UTF8 bytes for the provided String.
BytesRefFSTEnum<T> - Class in org.apache.lucene.util.fst
Enumerates all input (BytesRef) + output pairs in an FST.
BytesRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum
doFloor controls the behavior of advance: if it's true doFloor is true, advance positions to the biggest term before target.
BytesRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
Holds a single input (BytesRef) + output pair.
BytesRefFSTEnum.InputOutput() - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
BytesRefHash - Class in org.apache.lucene.util
BytesRefHash is a special purpose hash-map like data-structure optimized for BytesRef instances.
BytesRefHash() - Constructor for class org.apache.lucene.util.BytesRefHash
BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash.BytesStartArray - Class in org.apache.lucene.util
Manages allocation of the per-term addresses.
BytesRefHash.BytesStartArray() - Constructor for class org.apache.lucene.util.BytesRefHash.BytesStartArray
 
BytesRefHash.DirectBytesStartArray - Class in org.apache.lucene.util
A simple BytesRefHash.BytesStartArray that tracks memory allocation using a private Counter instance.
BytesRefHash.DirectBytesStartArray(int, Counter) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
BytesRefHash.DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
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.
byteStart(int) - Method in class org.apache.lucene.util.BytesRefHash
Returns the bytesStart offset into the internally used ByteBlockPool for the given bytesID
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
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

cachedDocs - Variable in class org.apache.lucene.search.CachingCollector
 
cachedSegs - Variable in class org.apache.lucene.search.CachingCollector
 
cacheImpl(DocIdSetIterator, AtomicReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
Default cache implementation: uses WAH8DocIdSet.
CachingCollector - Class in org.apache.lucene.search
Caches all docs, and optionally also scores, coming from a search, and is then able to replay them to another collector.
CachingTokenFilter - Class in org.apache.lucene.analysis
This class can be used if the token attributes of a TokenStream are intended to be consumed more than once.
CachingTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.CachingTokenFilter
Create a new CachingTokenFilter around input, caching its token attributes, which can be replayed again after a call to CachingTokenFilter.reset().
CachingWrapperFilter - Class in org.apache.lucene.search
Wraps another Filter's result and caches it.
CachingWrapperFilter(Filter) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
Wraps another filter's result and caches it.
calibrateSizeByDeletes - Variable in class org.apache.lucene.index.LogMergePolicy
If true, we pro-rate a segment's size by the percentage of non-deleted documents.
canReuse(MultiTermsEnum) - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
Returns true if this instance can be reused by the provided MultiTermsEnum.
canReuse(MultiTermsEnum) - Method in class org.apache.lucene.index.MultiDocsEnum
Returns true if this instance can be reused by the provided MultiTermsEnum.
cantOpenSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
True if we were unable to open the segments_N file.
capacity() - Method in class org.apache.lucene.util.OpenBitSet
Returns the current capacity in bits (1 greater than the index of the last bit)
captureState() - Method in class org.apache.lucene.util.AttributeSource
Captures the state of all Attributes.
cardinality() - Method in class org.apache.lucene.util.FixedBitSet
Returns number of set bits.
cardinality() - Method in class org.apache.lucene.util.OpenBitSet
 
cardinality() - Method in class org.apache.lucene.util.PForDeltaDocIdSet
Return the number of documents in this DocIdSet in constant time.
cardinality() - Method in class org.apache.lucene.util.WAH8DocIdSet
Return the number of documents in this DocIdSet in constant time.
changed() - Method in class org.apache.lucene.index.SegmentInfos
Call this before committing if changes have been made to the segments.
changeToken(BytesRef) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
Subclass & implement this if you need to change the token (such as escaping certain bytes) before it's turned into a graph.
CharacterRunAutomaton - Class in org.apache.lucene.util.automaton
Automaton representation for matching char[].
CharacterRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CharacterRunAutomaton
 
charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
charAt(int) - Method in class org.apache.lucene.util.CharsRef
 
CharFilter - Class in org.apache.lucene.analysis
Subclasses of CharFilter can be chained to filter a Reader They can be used as Reader with additional offset correction.
CharFilter(Reader) - Constructor for class org.apache.lucene.analysis.CharFilter
Create a new CharFilter wrapping the provided reader.
chars - Variable in class org.apache.lucene.util.CharsRef
The contents of the CharsRef.
charsEquals(CharsRef) - Method in class org.apache.lucene.util.CharsRef
 
CharSequenceOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a sequence of characters.
CHARSET_UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
UTF-8 Charset instance to prevent repeated Charset.forName(String) lookups
CharsRef - Class in org.apache.lucene.util
Represents char[], as a slice (offset + length) into an existing char[].
CharsRef() - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized an empty array zero-length
CharsRef(int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with an array of the given capacity
CharsRef(char[], int, int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given array, offset and length
CharsRef(String) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given Strings character array
CharTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The term text of a Token.
CharTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of CharTermAttribute.
CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
Initialize this attribute with empty term text
check(FieldCache.CacheEntry...) - Method in class org.apache.lucene.util.FieldCacheSanityChecker
Tests a CacheEntry[] for indication of "insane" cache usage.
checkAbort - Variable in class org.apache.lucene.index.MergeState
Holds the CheckAbort instance, which is invoked periodically to see if the merge has been aborted.
checkAborted(Directory) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Called periodically by IndexWriter while merging to see if the merge is aborted.
checkHeader(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
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.
CheckIndex - Class in org.apache.lucene.index
Basic tool and API to check the health of an index and write a new segments file that removes reference to problematic segments.
CheckIndex(Directory) - Constructor for class org.apache.lucene.index.CheckIndex
Create a new CheckIndex on the directory.
checkIndex() - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
checkIndex(List<String>) - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
CheckIndex.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.FieldNormStatus - Class in org.apache.lucene.index
Status from testing field norms.
CheckIndex.Status.SegmentInfoStatus - Class in org.apache.lucene.index
Holds the status of each segment in the index.
CheckIndex.Status.StoredFieldStatus - Class in org.apache.lucene.index
Status from testing stored fields.
CheckIndex.Status.TermIndexStatus - Class in org.apache.lucene.index
Status from testing term index.
CheckIndex.Status.TermVectorStatus - Class in org.apache.lucene.index
Status from testing stored fields.
checkMaxClauseCount(int) - Method in class org.apache.lucene.search.ScoringRewrite
This method is called after every new term to check if the number of max clauses (e.g.
checkSanity(FieldCache) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
Quick and dirty convenience method
checkSanity(FieldCache.CacheEntry...) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
Quick and dirty convenience method that instantiates an instance with "good defaults" and uses it to test the CacheEntrys
checkServiceName(String) - Static method in class org.apache.lucene.util.NamedSPILoader
Validates that a service name meets the requirements of NamedSPILoader.NamedSPI
ChecksumIndexInput - Class in org.apache.lucene.store
Reads bytes through to a primary IndexInput, computing checksum as it goes.
ChecksumIndexInput(IndexInput) - Constructor for class org.apache.lucene.store.ChecksumIndexInput
 
ChecksumIndexOutput - Class in org.apache.lucene.store
Writes bytes through to a primary IndexOutput, computing checksum.
ChecksumIndexOutput(IndexOutput) - Constructor for class org.apache.lucene.store.ChecksumIndexOutput
 
checkVersion(int) - Static method in class org.apache.lucene.util.packed.PackedInts
Check the validity of a version number.
child - Variable in class org.apache.lucene.search.Scorer.ChildScorer
Child Scorer.
children() - Method in class org.apache.lucene.index.AtomicReaderContext
 
children() - Method in class org.apache.lucene.index.CompositeReaderContext
 
children() - Method in class org.apache.lucene.index.IndexReaderContext
Returns the context's children iff this context is a composite context otherwise null.
clauses() - Method in class org.apache.lucene.search.BooleanQuery
Returns the list of clauses in this query.
clauses - Variable in class org.apache.lucene.search.spans.SpanNearQuery
 
clean - Variable in class org.apache.lucene.index.CheckIndex.Status
True if no problems were found with the index.
clear() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.Token
Resets the term text, payload, flags, and positionIncrement, startOffset, endOffset and token type to default.
clear() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
clear() - Method in class org.apache.lucene.index.SegmentInfos
Clear 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.MaxNonCompetitiveBoostAttributeImpl
 
clear() - Method in class org.apache.lucene.util.AttributeImpl
Clears the values in this AttributeImpl and resets it to its default value.
clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
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(int) - Method in class org.apache.lucene.util.FixedBitSet
 
clear(int, int) - Method in class org.apache.lucene.util.FixedBitSet
Clears a range of bits.
clear() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
clear(int) - Method in interface org.apache.lucene.util.MutableBits
Sets the bit specified by index to false.
clear(long) - Method in class org.apache.lucene.util.OpenBitSet
clears a bit, allowing access beyond the current set size without changing the size.
clear(int, int) - Method in class org.apache.lucene.util.OpenBitSet
Clears a range of bits.
clear(long, long) - Method in class org.apache.lucene.util.OpenBitSet
Clears a range of bits.
clear() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
clear() - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
Sets all values to 0.
clear() - Method in class org.apache.lucene.util.PriorityQueue
Removes all entries from the PriorityQueue.
clear() - Method in class org.apache.lucene.util.SentinelIntSet
 
clear() - Method in class org.apache.lucene.util.WeakIdentityMap
Removes all of the mappings from this map.
clearAttributes() - Method in class org.apache.lucene.util.AttributeSource
Resets all Attributes in this AttributeSource by calling AttributeImpl.clear() on each Attribute implementation.
clearLock(String) - Method in class org.apache.lucene.store.BaseDirectory
 
clearLock(String) - Method in class org.apache.lucene.store.Directory
Attempt to clear (forcefully unlock and remove) the specified lock.
clearLock(String) - Method in class org.apache.lucene.store.FilterDirectory
 
clearLock(String) - Method in class org.apache.lucene.store.LockFactory
Attempt to clear (forcefully unlock and remove) the specified lock.
clearLock(String) - Method in class org.apache.lucene.store.NativeFSLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.NoLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
clearLock(String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.VerifyingLockFactory
 
clearNumberedStates() - Method in class org.apache.lucene.util.automaton.Automaton
 
clone() - Method in class org.apache.lucene.analysis.Token
 
clone(char[], int, int, int, int) - Method in class org.apache.lucene.analysis.Token
Makes a clone, but replaces the term buffer & start/end offset in the process.
clone() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clone() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexReader
 
clone() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
 
clone() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
 
clone() - Method in class org.apache.lucene.codecs.compressing.Decompressor
 
clone() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
Returns a cloned FieldsReader that shares open IndexInputs with the original one.
clone() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
 
clone() - Method in class org.apache.lucene.codecs.StoredFieldsReader
 
clone() - Method in class org.apache.lucene.codecs.TermVectorsReader
Create a clone that one caller at a time may use to read term vectors.
clone() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
clone() - Method in class org.apache.lucene.index.IndexDeletionPolicy
 
clone() - Method in class org.apache.lucene.index.IndexWriterConfig
 
clone() - Method in class org.apache.lucene.index.MergePolicy
 
clone() - Method in class org.apache.lucene.index.MergeScheduler
 
clone() - Method in class org.apache.lucene.index.NoDeletionPolicy
 
clone() - Method in class org.apache.lucene.index.NoMergeScheduler
 
clone() - Method in class org.apache.lucene.index.SegmentCommitInfo
 
clone() - Method in class org.apache.lucene.index.SegmentInfos
Returns a copy of this instance, also copying each SegmentInfo.
clone() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
 
clone() - Method in class org.apache.lucene.index.TermState
 
clone() - Method in class org.apache.lucene.search.BooleanQuery
 
clone() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create a shallow copy of us -- used in rewriting if necessary
clone() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
clone() - Method in class org.apache.lucene.search.Query
Returns a clone of this query.
clone() - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
clone() - Method in class org.apache.lucene.store.BufferedIndexInput
 
clone() - Method in class org.apache.lucene.store.DataInput
Returns a clone of this stream.
clone() - Method in class org.apache.lucene.store.FSDirectory.FSIndexInput
 
clone() - Method in class org.apache.lucene.store.IndexInput
Returns a clone of this stream.
clone() - Method in class org.apache.lucene.util.AttributeImpl
Shallow clone.
clone() - Method in class org.apache.lucene.util.AttributeSource.State
 
clone() - Method in class org.apache.lucene.util.automaton.Automaton
Returns a clone of this automaton.
clone() - Method in class org.apache.lucene.util.automaton.Transition
Clones this transition.
clone() - Method in class org.apache.lucene.util.BytesRef
Returns a shallow clone of this instance (the underlying bytes are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.CharsRef
Returns a shallow clone of this instance (the underlying characters are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
 
clone() - Method in class org.apache.lucene.util.FixedBitSet
 
clone() - Method in class org.apache.lucene.util.InfoStream
 
clone() - Method in class org.apache.lucene.util.IntsRef
Returns a shallow clone of this instance (the underlying ints are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.LongsRef
Returns a shallow clone of this instance (the underlying longs are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.OpenBitSet
 
clone() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
clone() - Method in class org.apache.lucene.util.SetOnce
 
cloneAttributes() - Method in class org.apache.lucene.util.AttributeSource
Performs a clone of all AttributeImpl instances returned in a new AttributeSource instance.
close() - Method in class org.apache.lucene.analysis.Analyzer
Frees persistent resources used by this Analyzer
close() - Method in class org.apache.lucene.analysis.CharFilter
Closes the underlying input stream.
close() - Method in class org.apache.lucene.analysis.TokenFilter
Releases resources associated with this stream.
close() - Method in class org.apache.lucene.analysis.Tokenizer
Releases resources associated with this stream.
close() - Method in class org.apache.lucene.analysis.TokenStream
Releases resources associated with this stream.
close() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader
 
close() - Method in class org.apache.lucene.codecs.BlockTreeTermsWriter
 
close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexWriter
 
close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
Close 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
Called when we are done adding everything.
close() - Method in class org.apache.lucene.codecs.FieldsProducer
 
close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
Deprecated.
 
close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsReader
Closes the underlying IndexInput streams.
close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
 
close() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
Close all streams.
close() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
 
close() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
 
close() - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
 
close() - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
 
close() - Method in class org.apache.lucene.codecs.PostingsReaderBase
 
close() - Method in class org.apache.lucene.codecs.PostingsWriterBase
 
close() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
 
close() - Method in class org.apache.lucene.codecs.TermVectorsWriter
 
close() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
close() - Method in class org.apache.lucene.index.IndexReader
Closes files associated with this index.
close() - Method in class org.apache.lucene.index.IndexWriter
Commits all changes to an index, waits for pending merges to complete, and closes all associated files.
close(boolean) - Method in class org.apache.lucene.index.IndexWriter
Closes the index with or without waiting for currently running merges to finish.
close() - Method in class org.apache.lucene.index.LogMergePolicy
 
close() - Method in class org.apache.lucene.index.MergePolicy
Release all resources for the policy.
close() - Method in class org.apache.lucene.index.MergeScheduler
Close this MergeScheduler.
close() - Method in class org.apache.lucene.index.NoMergePolicy
 
close() - Method in class org.apache.lucene.index.NoMergeScheduler
 
close() - Method in class org.apache.lucene.index.SerialMergeScheduler
 
close() - Method in class org.apache.lucene.index.TieredMergePolicy
 
close() - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
close() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
 
close() - Method in class org.apache.lucene.search.LiveFieldValues
 
close() - Method in class org.apache.lucene.search.ReferenceManager
Closes this ReferenceManager to prevent future acquiring.
close() - Method in class org.apache.lucene.search.SearcherLifetimeManager
Close 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.BufferedIndexOutput
 
close() - Method in class org.apache.lucene.store.ChecksumIndexInput
 
close() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
close() - Method in class org.apache.lucene.store.CompoundFileDirectory
 
close() - Method in class org.apache.lucene.store.Directory
Closes the store.
close() - Method in class org.apache.lucene.store.FileSwitchDirectory
 
close() - Method in class org.apache.lucene.store.FilterDirectory
 
close() - Method in class org.apache.lucene.store.FSDirectory
Closes the store to future operations.
close() - Method in class org.apache.lucene.store.FSDirectory.FSIndexInput
 
close() - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
 
close() - Method in class org.apache.lucene.store.IndexInput
Closes the stream to further operations.
close() - Method in class org.apache.lucene.store.IndexOutput
Closes this stream to further operations.
close() - Method in class org.apache.lucene.store.InputStreamDataInput
 
close() - Method in class org.apache.lucene.store.NRTCachingDirectory
Close this directory, which flushes any cached files to the delegate and then closes the delegate.
close() - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
close() - Method in class org.apache.lucene.store.RAMDirectory
Closes the store to future operations, releasing associated memory.
close() - Method in class org.apache.lucene.store.RAMInputStream
 
close() - Method in class org.apache.lucene.store.RAMOutputStream
 
close() - Method in class org.apache.lucene.util.BytesRefHash
Closes the BytesRefHash and releases all internally used memory
close() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
close(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables.
close(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables.
close() - Method in class org.apache.lucene.util.PrintStreamInfoStream
 
CloseableThreadLocal<T> - Class in org.apache.lucene.util
Java's builtin ThreadLocal has a serious flaw: it can take an arbitrarily long amount of time to dereference the things you had stored in it, even once the ThreadLocal instance itself is no longer referenced.
CloseableThreadLocal() - Constructor for class org.apache.lucene.util.CloseableThreadLocal
 
closeWhileHandlingException(E, Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(E, Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
Codec - Class in org.apache.lucene.codecs
Encodes/decodes an inverted index segment.
Codec(String) - Constructor for class org.apache.lucene.codecs.Codec
Creates a new codec.
codec - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Codec used to read this segment.
codec - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Codec used to write new segments.
CODEC_FILE_PATTERN - Static variable in class org.apache.lucene.index.IndexFileNames
All files created by codecs much match this pattern (checked in SegmentInfo).
CODEC_MAGIC - Static variable in class org.apache.lucene.codecs.CodecUtil
Constant to identify the start of a codec header.
CODEC_NAME - Static variable in class org.apache.lucene.util.packed.PackedInts
 
CodecUtil - Class in org.apache.lucene.codecs
Utility class for reading and writing versioned headers.
codePointCount(BytesRef) - Static method in class org.apache.lucene.util.UnicodeUtil
Returns the number of code points in this UTF8 sequence.
collect(int) - Method in class org.apache.lucene.search.Collector
Called once for every document matching a query, with the unbased document number.
collect(int) - Method in class org.apache.lucene.search.MultiCollector
 
collect(int) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
collect(int) - Method in class org.apache.lucene.search.TimeLimitingCollector
Calls Collector.collect(int) on the decorated Collector unless the allowed time has passed, in which case it throws an exception.
collect(int) - Method in class org.apache.lucene.search.TotalHitCountCollector
 
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 Collector.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.
Collector - Class in org.apache.lucene.search
Expert: Collectors are primarily meant to be used to gather raw results from a search, and implement sorting or custom result filtering, collation, etc.
Collector() - Constructor for class org.apache.lucene.search.Collector
 
CommandLineUtil - Class in org.apache.lucene.util
Class containing some useful methods used by command line tools
commit() - Method in class org.apache.lucene.index.IndexWriter
Commits all pending changes (added & deleted documents, segment merges, added indexes, etc.) to the index, and syncs all referenced index files, such that a reader will see the changes and the index updates will survive an OS or machine crash or power loss.
commit - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
IndexCommit that IndexWriter is opened on.
commit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
The second phase of a 2-phase commit.
common(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
common(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
common(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
common(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
common(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg common("foo", "foobar") -> "foo"
common(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
common(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
commonSuffixRef - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Shared common suffix accepted by the automaton.
COMPACT - Static variable in class org.apache.lucene.util.packed.PackedInts
No memory overhead at all, but the returned implementation may be slow.
comparators - Variable in class org.apache.lucene.search.FieldValueHitQueue
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
Deprecated.
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator
Compare hit at slot1 with hit at slot2.
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
Deprecated.
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compare(int, int) - Method in class org.apache.lucene.util.Sorter
Compare entries found in slots i and j.
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
Deprecated.
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator
Compare the bottom of the queue with doc.
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
Deprecated.
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
CompareByDestThenMinMax - Static variable in class org.apache.lucene.util.automaton.Transition
 
compareByMergeDocCount - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Sorts ConcurrentMergeScheduler.MergeThreads; larger merges come first.
CompareByMinMaxThenDest - Static variable in class org.apache.lucene.util.automaton.Transition
 
compareDocToValue(int, Byte) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
Deprecated.
 
compareDocToValue(int, T) - Method in class org.apache.lucene.search.FieldComparator
Returns negative result if the doc's value is less than the provided value.
compareDocToValue(int, Integer) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
compareDocToValue(int, Double) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
compareDocToValue(int, Float) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
compareDocToValue(int, Integer) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
compareDocToValue(int, Long) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
compareDocToValue(int, Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareDocToValue(int, Short) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
Deprecated.
 
compareDocToValue(int, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
compareDocToValue(int, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compareImplementationDistance(Class<? extends C>, VirtualMethod<C>, VirtualMethod<C>) - Static method in class org.apache.lucene.util.VirtualMethod
Utility method that compares the implementation/override distance of two methods.
comparePivot(int) - Method in class org.apache.lucene.util.IntroSorter
Compare the pivot with the slot at j, similarly to compare(i, j).
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
compareSaved(int, int) - Method in class org.apache.lucene.util.TimSorter
Compare element i from the temporary storage with element j from the slice to sort, similarly to Sorter.compare(int, int).
compareTo(IndexCommit) - Method in class org.apache.lucene.index.IndexCommit
 
compareTo(Term) - Method in class org.apache.lucene.index.Term
Compares two terms, returning a negative integer if this term belongs before the argument, zero if this term is equal to the argument, and a positive integer if this term belongs after the argument.
compareTo(State) - Method in class org.apache.lucene.util.automaton.State
Compares this object with the specified object for order.
compareTo(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Unsigned byte order comparison
compareTo(CharsRef) - Method in class org.apache.lucene.util.CharsRef
Signed int order comparison
compareTo(IntsRef) - Method in class org.apache.lucene.util.IntsRef
Signed int order comparison
compareTo(LongsRef) - Method in class org.apache.lucene.util.LongsRef
Signed int order comparison
compareTo(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValue
 
compareValues(T, T) - Method in class org.apache.lucene.search.FieldComparator
Returns -1 if first is less than second.
compareValues(Float, Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareValues(BytesRef, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compiled - Variable in class org.apache.lucene.search.AutomatonQuery
 
CompiledAutomaton - Class in org.apache.lucene.util.automaton
Immutable class holding compiled details for a given Automaton.
CompiledAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
 
CompiledAutomaton(Automaton, Boolean, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
 
CompiledAutomaton.AUTOMATON_TYPE - Enum in org.apache.lucene.util.automaton
Automata are compiled into different internal forms for the most efficient execution depending upon the language they accept.
complement() - Method in class org.apache.lucene.util.automaton.Automaton
complement(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
Returns a (deterministic) automaton that accepts the complement of the language of the given automaton.
COMPLEMENT - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables complement (~).
ComplexExplanation - Class in org.apache.lucene.search
Expert: Describes the score computation for document and query, and can distinguish a match independent of a positive value.
ComplexExplanation() - Constructor for class org.apache.lucene.search.ComplexExplanation
 
ComplexExplanation(boolean, float, String) - Constructor for class org.apache.lucene.search.ComplexExplanation
 
CompositeReader - Class in org.apache.lucene.index
Instances of this reader type can only be used to get stored fields from the underlying AtomicReaders, but it is not possible to directly retrieve postings.
CompositeReader() - Constructor for class org.apache.lucene.index.CompositeReader
Sole constructor.
CompositeReaderContext - Class in org.apache.lucene.index
compound - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if segment is compound file format.
COMPOUND_FILE_ENTRIES_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of compound file entries
COMPOUND_FILE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of compound file
COMPOUND_FILES - Static variable in class org.apache.lucene.index.NoMergePolicy
A singleton NoMergePolicy which indicates the index uses compound files.
CompoundFileDirectory - Class in org.apache.lucene.store
Class for accessing a compound stream.
CompoundFileDirectory(Directory, String, IOContext, boolean) - Constructor for class org.apache.lucene.store.CompoundFileDirectory
Create a new CompoundFileDirectory.
CompoundFileDirectory.FileEntry - Class in org.apache.lucene.store
Offset/Length for a slice inside of a compound file
CompoundFileDirectory.FileEntry() - Constructor for class org.apache.lucene.store.CompoundFileDirectory.FileEntry
 
compress(byte[], int, int, DataOutput) - Method in class org.apache.lucene.codecs.compressing.Compressor
Compress bytes into out.
compress(byte[], int, int, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the specified byte range using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
compress(byte[], int, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the specified byte range, with default BEST_COMPRESSION level
compress(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
Compresses all bytes in the array, with default BEST_COMPRESSION level
CompressingStoredFieldsFormat - Class in org.apache.lucene.codecs.compressing
A StoredFieldsFormat that is very similar to Lucene40StoredFieldsFormat but compresses documents in chunks in order to improve the compression ratio.
CompressingStoredFieldsFormat(String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
Create a new CompressingStoredFieldsFormat with an empty segment suffix.
CompressingStoredFieldsFormat(String, String, CompressionMode, 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) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
Sole constructor.
CompressingTermVectorsFormat - Class in org.apache.lucene.codecs.compressing
A TermVectorsFormat that compresses chunks of documents together in order to improve the compression ratio.
CompressingTermVectorsFormat(String, String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
CompressingTermVectorsReader - Class in org.apache.lucene.codecs.compressing
CompressingTermVectorsReader(Directory, SegmentInfo, String, FieldInfos, IOContext, String, CompressionMode) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
Sole constructor.
CompressingTermVectorsWriter - Class in org.apache.lucene.codecs.compressing
CompressingTermVectorsWriter(Directory, SegmentInfo, String, IOContext, String, CompressionMode, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
Sole constructor.
CompressionMode - Class in org.apache.lucene.codecs.compressing
A compression mode.
CompressionMode() - Constructor for class org.apache.lucene.codecs.compressing.CompressionMode
Sole constructor.
CompressionTools - Class in org.apache.lucene.document
Simple utility class providing static methods to compress and decompress binary data for stored fields.
Compressor - Class in org.apache.lucene.codecs.compressing
A data compressor.
Compressor() - Constructor for class org.apache.lucene.codecs.compressing.Compressor
Sole constructor, typically called from sub-classes.
compressString(String) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the String value, with default BEST_COMPRESSION level
compressString(String, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the String value using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.BM25Similarity
 
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
 
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
 
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.Similarity
Computes the normalization value for a field, given the accumulated state of term processing for this field (see FieldInvertState).
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.SimilarityBase
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.
computeStats() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
For debugging -- used by CheckIndex too
computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.BM25Similarity
 
computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
 
computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
 
computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.Similarity
Compute any collection-level weight (e.g.
computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.SimilarityBase
 
computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
 
concatenate(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
concatenate(List<Automaton>) - Static method in class org.apache.lucene.util.automaton.Automaton
concatenate(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
Returns an automaton that accepts the concatenation of the languages of the given automata.
concatenate(List<Automaton>) - Static method in class org.apache.lucene.util.automaton.BasicOperations
Returns an automaton that accepts the concatenation of the languages of the given automata.
ConcurrentMergeScheduler - Class in org.apache.lucene.index
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, which may run one or more merges in sequence.
ConcurrentMergeScheduler.MergeThread(IndexWriter, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
Sole constructor.
CONSTANT_SCORE_AUTO_REWRITE_DEFAULT - Static variable in class org.apache.lucene.search.MultiTermQuery
Read-only default instance of MultiTermQuery.ConstantScoreAutoRewrite, with ConstantScoreAutoRewrite.setTermCountCutoff(int) set to ConstantScoreAutoRewrite.DEFAULT_TERM_COUNT_CUTOFF and ConstantScoreAutoRewrite.setDocCountPercent(double) set to ConstantScoreAutoRewrite.DEFAULT_DOC_COUNT_PERCENT.
CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
Like MultiTermQuery.SCORING_BOOLEAN_QUERY_REWRITE except scores are not computed.
CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
Like ScoringRewrite.SCORING_BOOLEAN_QUERY_REWRITE except scores are not computed.
CONSTANT_SCORE_FILTER_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
A rewrite method that first creates a private Filter, by visiting each term in sequence and marking all docs for that term.
Constants - Class in org.apache.lucene.util
Some useful constants.
ConstantScoreQuery - Class in org.apache.lucene.search
A query that wraps another query or a filter and simply returns a constant score equal to the query boost for every document that matches the filter or query.
ConstantScoreQuery(Query) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Strips off scores from the passed in Query.
ConstantScoreQuery(Filter) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Wraps a Filter as a Query.
ConstantScoreQuery.ConstantScorer - Class in org.apache.lucene.search
 
ConstantScoreQuery.ConstantScorer(DocIdSetIterator, Weight, float) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
ConstantScoreQuery.ConstantWeight - Class in org.apache.lucene.search
 
ConstantScoreQuery.ConstantWeight(IndexSearcher) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
 
containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
Returns 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
ControlledRealTimeReopenThread<T> - Class in org.apache.lucene.search
Utility class that runs a thread to manage periodicc reopens of a ReferenceManager, with methods to wait for a specific index changes to become visible.
ControlledRealTimeReopenThread(TrackingIndexWriter, ReferenceManager<T>, double, double) - Constructor for class org.apache.lucene.search.ControlledRealTimeReopenThread
Create ControlledRealTimeReopenThread, to periodically reopen the a ReferenceManager.
convert(Automaton) - Method in class org.apache.lucene.util.automaton.UTF32ToUTF8
Converts an incoming utf32 automaton to an equivalent utf8 one.
coord(int, int) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
coord(int, int) - Method in class org.apache.lucene.search.similarities.DefaultSimilarity
Implemented as overlap / maxOverlap.
coord(int, int) - Method in class org.apache.lucene.search.similarities.Similarity
Hook to integrate coordinate-level matching.
coord(int, int) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Computes a score factor based on the fraction of all query terms that a document contains.
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
Deprecated.
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator
This method is called when a new hit is competitive.
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
Deprecated.
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
copy(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.Directory
Copies the file src to Directory to under the new file name dest.
copy(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
 
copy(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
copy(File, File) - Static method in class org.apache.lucene.util.IOUtils
Copy one file's contents to another file.
copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValue
 
copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
copy(PackedInts.Reader, int, PackedInts.Mutable, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Copy src[srcPos:srcPos+len] 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(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Copies the bytes from the given BytesRef
copyChars(CharSequence) - Method in class org.apache.lucene.util.BytesRef
Copies the UTF8 bytes for this string.
copyChars(CharsRef) - Method in class org.apache.lucene.util.CharsRef
Copies the given CharsRef referenced content into this instance.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
Copies the given array into this CharsRef.
copyFrom(TermState) - Method in class org.apache.lucene.codecs.BlockTermState
 
copyFrom(TermState) - Method in class org.apache.lucene.index.OrdTermState
 
copyFrom(TermState) - Method in class org.apache.lucene.index.TermState
Copies the content of the given TermState to this instance
copyFrom(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST.Arc
Returns this
copyInts(IntsRef) - Method in class org.apache.lucene.util.IntsRef
 
copyLongs(LongsRef) - Method in class org.apache.lucene.util.LongsRef
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.Token
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.search.BoostAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.util.AttributeImpl
Copies the values from this Attribute into the passed-in target attribute.
copyTo(AttributeSource) - Method in class org.apache.lucene.util.AttributeSource
Copies the contents of this 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.
correct(int) - Method in class org.apache.lucene.analysis.CharFilter
Subclasses override to correct the current offset.
correctOffset(int) - Method in class org.apache.lucene.analysis.CharFilter
Chains the corrected offset through the input CharFilter(s).
correctOffset(int) - Method in class org.apache.lucene.analysis.Tokenizer
Return the corrected offset.
CorruptIndexException - Exception in org.apache.lucene.index
This exception is thrown when Lucene detects an inconsistency in the index.
CorruptIndexException(String) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Sole constructor.
cos(double) - Static method in class org.apache.lucene.util.SloppyMath
Returns the trigonometric cosine of an angle.
cost() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
 
cost() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
 
cost() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
 
cost() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
 
cost() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
 
cost() - Method in class org.apache.lucene.index.MultiDocsEnum
 
cost() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
cost() - Method in class org.apache.lucene.search.DocIdSetIterator
Returns the estimated cost of this DocIdSetIterator.
cost() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
cost() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
cost() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
cost() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
cost() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
cost() - Method in class org.apache.lucene.search.spans.Spans
Returns the estimated cost of this spans.
cost() - Method in class org.apache.lucene.search.spans.SpanScorer
 
cost() - Method in class org.apache.lucene.search.spans.TermSpans
 
cost - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
cost() - Method in class org.apache.lucene.util.OpenBitSetIterator
 
count - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.BinaryEntry
count of values written
count - Variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer.NumericEntry
count of values written
count - Variable in class org.apache.lucene.search.spans.TermSpans
 
count - Variable in class org.apache.lucene.util.SentinelIntSet
 
counter - Variable in class org.apache.lucene.index.SegmentInfos
Used to name new segments.
Counter - Class in org.apache.lucene.util
Simple counter class
Counter() - Constructor for class org.apache.lucene.util.Counter
 
create(boolean, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
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, 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, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
Creates a new TopFieldCollector from the given arguments.
create(int, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect and whether documents are scored in order by the input Scorer to TopScoreDocCollector.setScorer(Scorer).
create(int, ScoreDoc, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect, the bottom of the previous page, and whether documents are scored in order by the input Scorer to TopScoreDocCollector.setScorer(Scorer).
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
 
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource.AttributeFactory
returns an AttributeImpl for the supplied Attribute interface class.
createBooleanQuery(String, String) - Method in class org.apache.lucene.util.QueryBuilder
Creates a boolean query from the query text.
createBooleanQuery(String, String, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
Creates a boolean query from the query text.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
Creates a new Analyzer.TokenStreamComponents instance for this analyzer.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
createFieldQuery(Analyzer, BooleanClause.Occur, String, String, boolean, int) - Method in class org.apache.lucene.util.QueryBuilder
Creates a query from the analysis chain.
createMinShouldMatchQuery(String, String, float) - Method in class org.apache.lucene.util.QueryBuilder
Creates a minimum-should-match query from the query text.
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.IndexSearcher
Creates a normalized weight for a top-level Query.
createOutput(String, IOContext) - Method in class org.apache.lucene.store.CompoundFileDirectory
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.Directory
Creates a new, empty file in the directory with the given name.
createOutput(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.FSDirectory
Creates an IndexOutput for the file with the given name.
createOutput(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.RAMDirectory
Creates a new, empty file in the directory with the given name.
createOutput(String, IOContext) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
createPhraseQuery(String, String) - Method in class org.apache.lucene.util.QueryBuilder
Creates a phrase query from the query text.
createPhraseQuery(String, String, int) - Method in class org.apache.lucene.util.QueryBuilder
Creates a phrase query from the query text.
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.CompoundFileDirectory
 
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.Directory
Creates an Directory.IndexInputSlicer for the given file name.
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.MMapDirectory
 
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.NIOFSDirectory
 
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
 
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.SimpleFSDirectory
 
createSlicer(String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.BooleanQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create the Weight used to score us
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.FilteredQuery
Returns a Weight that applies the filter to the enclosed query's Weight.
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.PhraseQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.Query
Expert: Constructs an appropriate Weight implementation for this query.
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.spans.SpanQuery
 
createWeight(IndexSearcher) - Method in class org.apache.lucene.search.TermQuery
 
curDocs - Variable in class org.apache.lucene.search.CachingCollector
 
current - Variable in class org.apache.lucene.search.ReferenceManager
 
current() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
current() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
currentIndex() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
The current decoding index.
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
Calculate the score up to this point for this doc and field
currentValue() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
The value at the current decoding index.

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(char[], int, int, byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Decodes the input char sequence into the output byte sequence.
decode(long[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
Read iterations * blockCount() blocks 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.
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.
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 IntsRef that points to a copy of the longs from other
DEFAULT - Static variable in interface org.apache.lucene.search.FieldCache
Expert: The cache used internally by sorting and range query classes.
DEFAULT - Static variable in class org.apache.lucene.store.IOContext
 
DEFAULT - Static variable in class org.apache.lucene.util.packed.PackedInts
At most 20% memory overhead.
DEFAULT_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.util.AttributeSource.AttributeFactory
This is the default factory that creates AttributeImpls using the class name of the supplied Attribute interface class by appending Impl to it.
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexOutput
The default buffer size in bytes (16384).
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.lucene.util.packed.PackedInts
Default amount of memory to use for bulk operations.
DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
DEFAULT_BYTE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
Deprecated.
DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
 
DEFAULT_DOUBLE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
Deprecated.
DEFAULT_FLOAT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
Deprecated.
DEFAULT_INDEX_INTERVAL - Static variable in class org.apache.lucene.util.packed.EliasFanoEncoder
The default index interval for zero upper bits.
DEFAULT_INDEX_INTERVAL - Static variable in class org.apache.lucene.util.WAH8DocIdSet
Default index interval.
DEFAULT_INDEX_INTERVAL_BITS - Static variable in class org.apache.lucene.index.DocTermOrds
Every 128th term is indexed, by default.
DEFAULT_INT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
Deprecated.
DEFAULT_LONG_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
Deprecated.
DEFAULT_MAX_BLOCK_BITS - Static variable in class org.apache.lucene.util.fst.FST
 
DEFAULT_MAX_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
Suggested default value for the maxItemsInBlock parameter to BlockTreeTermsWriter.BlockTreeTermsWriter(SegmentWriteState,PostingsWriterBase,int,int).
DEFAULT_MAX_BUFF - Static variable in class org.apache.lucene.store.MMapDirectory
Default max chunk size.
DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_CFS_SEGMENT_SIZE - Static variable in class org.apache.lucene.index.MergePolicy
Default max segment size in order to use compound file system.
DEFAULT_MAX_MERGE_COUNT - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Default maxMergeCount.
DEFAULT_MAX_MERGE_DOCS - Static variable in class org.apache.lucene.index.LogMergePolicy
Default maximum segment size.
DEFAULT_MAX_MERGE_MB - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
Default maximum segment size.
DEFAULT_MAX_MERGE_MB_FOR_FORCED_MERGE - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
Default maximum segment size.
DEFAULT_MAX_THREAD_COUNT - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Default maxThreadCount.
DEFAULT_MAX_THREAD_STATES - Static variable in class org.apache.lucene.index.IndexWriterConfig
The maximum number of simultaneous threads that may be indexing documents at once in IndexWriter; if more than this many threads arrive they will wait for others to finish.
DEFAULT_MERGE_FACTOR - Static variable in class org.apache.lucene.index.LogMergePolicy
Default merge factor, which is how many segments are merged at a time
DEFAULT_MIN_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.BlockTreeTermsWriter
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_RAM_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 16 MB (which means flush when buffered docs consume approximately 16 MB RAM).
DEFAULT_RAM_PER_THREAD_HARD_LIMIT_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 1945.
DEFAULT_READ_CHUNK_SIZE - Static variable in class org.apache.lucene.store.FSDirectory
Deprecated.
This constant is no longer used since Lucene 4.5.
DEFAULT_READER_POOLING - Static variable in class org.apache.lucene.index.IndexWriterConfig
DEFAULT_READER_TERMS_INDEX_DIVISOR - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 1.
DEFAULT_RESOLUTION - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
DEFAULT_SHORT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
Deprecated.
DEFAULT_TERM_INDEX_INTERVAL - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 32.
DEFAULT_TERMS_INDEX_DIVISOR - Static variable in class org.apache.lucene.index.DirectoryReader
Default termInfosIndexDivisor.
DEFAULT_TYPE - Static variable in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
the default type
DEFAULT_USE_COMPOUND_FILE_SYSTEM - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value for compound file system for newly written segments (set to true).
defaultMaxEdits - Static variable in class org.apache.lucene.search.FuzzyQuery
 
defaultMaxExpansions - Static variable in class org.apache.lucene.search.FuzzyQuery
 
defaultMinSimilarity - Static variable in class org.apache.lucene.search.FuzzyQuery
Deprecated.
pass integer edit distances instead.
defaultPrefixLength - Static variable in class org.apache.lucene.search.FuzzyQuery
 
DefaultSimilarity - Class in org.apache.lucene.search.similarities
Expert: Default scoring implementation which encodes norm values as a single byte before being stored.
DefaultSimilarity() - Constructor for class org.apache.lucene.search.similarities.DefaultSimilarity
Sole constructor: parameter-free
defaultTranspositions - Static variable in class org.apache.lucene.search.FuzzyQuery
 
delCountOnFlush - Variable in class org.apache.lucene.index.SegmentWriteState
Number of deleted documents set while flushing the segment.
delegate - Variable in class org.apache.lucene.codecs.FilterCodec
The codec to filter.
delete() - Method in class org.apache.lucene.index.IndexCommit
Delete this commit point.
delete(String) - Method in class org.apache.lucene.search.LiveFieldValues
Call this after you've successfully deleted a document from the index.
deleteAll() - Method in class org.apache.lucene.index.IndexWriter
Delete all documents in the index.
deleteAll() - Method in class org.apache.lucene.index.TrackingIndexWriter
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 term.
deleteDocuments(Term...) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) containing any of the terms.
deleteDocuments(Query) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) matching the provided query.
deleteDocuments(Query...) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) matching any of the provided queries.
deleteDocuments(Term) - Method in class org.apache.lucene.index.TrackingIndexWriter
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.CompoundFileDirectory
Not implemented
deleteFile(String) - Method in class org.apache.lucene.store.Directory
Removes an existing file in the directory.
deleteFile(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
deleteFile(String) - Method in class org.apache.lucene.store.FilterDirectory
 
deleteFile(String) - Method in class org.apache.lucene.store.FSDirectory
Removes an existing file in the directory.
deleteFile(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
deleteFile(String) - Method in class org.apache.lucene.store.RAMDirectory
Removes an existing file in the directory.
deleteFile(String) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
deleteFilesIgnoringExceptions(Directory, String...) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteLast(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
deleteUnusedFiles() - Method in class org.apache.lucene.index.IndexWriter
Expert: remove any index files that are no longer used.
deletionsGen - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Current deletions generation.
delPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
IndexDeletionPolicy controlling when commit points are deleted.
DELTA_COMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
Compressed using packed blocks of ints.
delTermCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Number of terms with zero live docs docs.
depth - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
This node's depth, starting from the automaton root.
DerefBytesDocValuesField - Class in org.apache.lucene.document
Deprecated.
DerefBytesDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.DerefBytesDocValuesField
Deprecated.
Create a new fixed or variable-length DocValues field.
DerefBytesDocValuesField(String, BytesRef, boolean) - Constructor for class org.apache.lucene.document.DerefBytesDocValuesField
Deprecated.
Create a new fixed or variable length DocValues field.
description - Variable in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
 
determinize() - Method in class org.apache.lucene.util.automaton.Automaton
determinize(Automaton) - Static method in class org.apache.lucene.util.automaton.BasicOperations
Determinizes the given automaton.
DFRSimilarity - Class in org.apache.lucene.search.similarities
Implements the divergence from randomness (DFR) framework introduced in Gianni Amati and Cornelis Joost Van Rijsbergen.
DFRSimilarity(BasicModel, AfterEffect, Normalization) - Constructor for class org.apache.lucene.search.similarities.DFRSimilarity
Creates DFRSimilarity from the three components.
diagnostics - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Map that includes certain debugging details that IndexWriter records into each segment it creates
dir - Variable in class org.apache.lucene.index.CheckIndex.Status
Directory index is in.
dir - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Directory that holds the index.
dir - Variable in class org.apache.lucene.index.SegmentInfo
Where this segment resides.
directory - Variable in class org.apache.lucene.index.DirectoryReader
The index directory.
directory() - Method in class org.apache.lucene.index.DirectoryReader
Returns the directory this index resides in.
directory() - Method in class org.apache.lucene.index.SegmentReader
Returns the directory this index resides in.
directory - Variable in class org.apache.lucene.index.SegmentReadState
Directory 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
 
Directory.IndexInputSlicer - Class in org.apache.lucene.store
Allows to create one or more sliced IndexInput instances from a single file handle.
Directory.IndexInputSlicer() - Constructor for class org.apache.lucene.store.Directory.IndexInputSlicer
 
DirectoryReader - Class in org.apache.lucene.index
DirectoryReader is an implementation of CompositeReader that can read indexes in a Directory.
DirectoryReader(Directory, AtomicReader[]) - Constructor for class org.apache.lucene.index.DirectoryReader
Expert: Constructs a DirectoryReader on the given subReaders.
DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriterConfig
Denotes a flush trigger is disabled.
discountOverlaps - Variable in class org.apache.lucene.search.similarities.BM25Similarity
True if overlap tokens (tokens with a position of increment of zero) are discounted from the document's length.
discountOverlaps - Variable in class org.apache.lucene.search.similarities.DefaultSimilarity
True if overlap tokens (tokens with a position of increment of zero) are discounted from the document's length.
discountOverlaps - Variable in class org.apache.lucene.search.similarities.SimilarityBase
True if overlap tokens (tokens with a position of increment of zero) are discounted from the document's length.
DisjunctionMaxQuery - Class in org.apache.lucene.search
A query that generates the union of documents produced by its subqueries, and that scores each document with the maximum score for that document as produced by any subquery, plus a tie breaking increment for any additional matching subqueries.
DisjunctionMaxQuery(float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
Creates a new empty DisjunctionMaxQuery.
DisjunctionMaxQuery(Collection<Query>, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
Creates a new DisjunctionMaxQuery
DisjunctionMaxQuery.DisjunctionMaxWeight - Class in org.apache.lucene.search
Expert: the Weight for DisjunctionMaxQuery, used to normalize, score and explain these queries.
DisjunctionMaxQuery.DisjunctionMaxWeight(IndexSearcher) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Construct the Weight for this Query searched by searcher.
Distribution - Class in org.apache.lucene.search.similarities
The probabilistic distribution used to model term occurrence in information-based models.
Distribution() - Constructor for class org.apache.lucene.search.similarities.Distribution
Sole constructor.
distribution - Variable in class org.apache.lucene.search.similarities.IBSimilarity
The probabilistic distribution used to model term occurrence.
DistributionLL - Class in org.apache.lucene.search.similarities
Log-logistic distribution.
DistributionLL() - Constructor for class org.apache.lucene.search.similarities.DistributionLL
Sole constructor: parameter-free
DistributionSPL - Class in org.apache.lucene.search.similarities
The smoothed power-law (SPL) distribution for the information-based framework that is described in the original paper.
DistributionSPL() - Constructor for class org.apache.lucene.search.similarities.DistributionSPL
Sole constructor: parameter-free
doAfterFlush() - Method in class org.apache.lucene.index.IndexWriter
A hook for extending classes to execute operations after pending added and deleted documents have been flushed to the Directory but before the change is committed (new segments_N file written).
doBeforeFlush() - Method in class org.apache.lucene.index.IndexWriter
A hook for extending classes to execute operations before pending added and deleted documents are flushed to the Directory.
doBody(String) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
Subclass must implement this.
doBody() - Method in class org.apache.lucene.store.Lock.With
Code to execute with exclusive access.
doc(int) - Method in class org.apache.lucene.search.IndexSearcher
Sugar for .getIndexReader().document(docID)
doc(int, StoredFieldVisitor) - Method in class org.apache.lucene.search.IndexSearcher
Sugar for .getIndexReader().document(docID, fieldVisitor)
doc(int, Set<String>) - Method in class org.apache.lucene.search.IndexSearcher
Sugar for .getIndexReader().document(docID, fieldsToLoad)
doc - Variable in class org.apache.lucene.search.ScoreDoc
A hit document's number.
doc() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
doc() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
doc() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
doc() - Method in class org.apache.lucene.search.spans.Spans
Returns the document number of the current match.
doc - Variable in class org.apache.lucene.search.spans.SpanScorer
 
doc - Variable in class org.apache.lucene.search.spans.TermSpans
 
doc() - Method in class org.apache.lucene.search.spans.TermSpans
 
DOC_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
Filename extension for document number, frequencies, and skip data.
doCacheWrite(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
Subclass can override this to customize logic; return true if this file should be written to the RAMDirectory.
docBase - Variable in class org.apache.lucene.index.AtomicReaderContext
The readers absolute doc base
docBase - Variable in class org.apache.lucene.index.MergeState
New docID base per reader.
docBaseInParent - Variable in class org.apache.lucene.index.IndexReaderContext
the doc base for this reader in the parent, 0 if parent is null
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Document count (does not take deletions into account).
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
Number of documents tested.
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
Number of documents tested.
docCount() - Method in class org.apache.lucene.search.CollectionStatistics
returns the total number of documents that have at least one term for this field.
docFreq - Variable in class org.apache.lucene.codecs.BlockTermState
how many docs have this term
docFreq - Variable in class org.apache.lucene.codecs.TermStats
How many documents have at least one occurrence of this term.
docFreq(Term) - Method in class org.apache.lucene.index.AtomicReader
 
docFreq(Term) - Method in class org.apache.lucene.index.BaseCompositeReader
 
docFreq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
 
docFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
docFreq(Term) - Method in class org.apache.lucene.index.IndexReader
Returns the number of documents containing the term.
docFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
 
docFreq() - Method in class org.apache.lucene.index.TermContext
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.codecs.MappingMultiDocsAndPositionsEnum
 
docID() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
 
docID() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
 
docID() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
 
docID() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
 
docID() - Method in class org.apache.lucene.index.MultiDocsEnum
 
docID() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
docID() - Method in class org.apache.lucene.search.DocIdSetIterator
Returns the following: -1 or DocIdSetIterator.NO_MORE_DOCS 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.ScoreCachingWrappingScorer
 
docID() - Method in class org.apache.lucene.search.spans.SpanScorer
 
docID() - Method in class org.apache.lucene.util.OpenBitSetIterator
 
DocIdBitSet - Class in org.apache.lucene.util
Simple DocIdSet and DocIdSetIterator backed by a BitSet
DocIdBitSet(BitSet) - Constructor for class org.apache.lucene.util.DocIdBitSet
 
DocIdSet - Class in org.apache.lucene.search
A DocIdSet contains a set of doc ids.
DocIdSet() - Constructor for class org.apache.lucene.search.DocIdSet
 
DocIdSetIterator - Class in org.apache.lucene.search
This abstract class defines methods to iterate over a set of non-decreasing doc ids.
DocIdSetIterator() - Constructor for class org.apache.lucene.search.DocIdSetIterator
 
docIdSetToCache(DocIdSet, AtomicReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
Provide the DocIdSet to be cached, using the DocIdSet provided by the wrapped Filter.
doClose() - Method in class org.apache.lucene.index.FilterAtomicReader
 
doClose() - Method in class org.apache.lucene.index.FilterDirectoryReader
 
doClose() - Method in class org.apache.lucene.index.IndexReader
Implements close.
doClose() - Method in class org.apache.lucene.index.MultiReader
 
doClose() - Method in class org.apache.lucene.index.ParallelAtomicReader
 
doClose() - Method in class org.apache.lucene.index.ParallelCompositeReader
 
doClose() - Method in class org.apache.lucene.index.SegmentReader
 
doClose() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
docMaps - Variable in class org.apache.lucene.index.MergeState
Maps docIDs around deletions.
docs(FieldInfo, BlockTermState, Bits, DocsEnum, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
Deprecated.
 
docs(FieldInfo, BlockTermState, Bits, DocsEnum, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
 
docs(FieldInfo, BlockTermState, Bits, DocsEnum, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
Must fully consume state, since after this call that TermState may be reused.
docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
 
docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.FilteredTermsEnum
 
docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.MultiTermsEnum
 
docs(Bits, DocsEnum) - Method in class org.apache.lucene.index.TermsEnum
Get DocsEnum for the current term.
docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
Get DocsEnum for the current term, with control over whether freqs are required.
docs(Bits, DocsEnum, int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
docsAndPositions(FieldInfo, BlockTermState, Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsReader
Deprecated.
 
docsAndPositions(FieldInfo, BlockTermState, Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsReader
 
docsAndPositions(FieldInfo, BlockTermState, Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
Must fully consume state, since after this call that TermState may be reused.
docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
 
docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.FilteredTermsEnum
 
docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.MultiTermsEnum
 
docsAndPositions(Bits, DocsAndPositionsEnum) - Method in class org.apache.lucene.index.TermsEnum
Get DocsAndPositionsEnum for the current term.
docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
Get DocsAndPositionsEnum for the current term, with control over whether offsets and payloads are required.
docsAndPositions(Bits, DocsAndPositionsEnum, int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
DocsAndPositionsEnum - Class in org.apache.lucene.index
Also iterates through positions.
DocsAndPositionsEnum() - Constructor for class org.apache.lucene.index.DocsAndPositionsEnum
Sole constructor.
docsAndPositionsEnum - Variable in class org.apache.lucene.index.MultiDocsAndPositionsEnum.EnumWithSlice
DocsAndPositionsEnum for this sub-reader.
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
Calculate the final score for all the payloads seen so far for this doc/field
docScorer - Variable in class org.apache.lucene.search.spans.SpanScorer
 
DocsEnum - Class in org.apache.lucene.index
Iterates through the documents and term freqs.
DocsEnum() - Constructor for class org.apache.lucene.index.DocsEnum
Sole constructor.
docsEnum - Variable in class org.apache.lucene.index.DocTermOrds
Used while uninverting.
docsEnum - Variable in class org.apache.lucene.index.MultiDocsEnum.EnumWithSlice
DocsEnum of this sub-reader.
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
docStoreCompoundFile - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if the shared doc store files are compound file format.
docStoreOffset - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Doc store offset, if this segment shares the doc store files (stored fields and term vectors) with other segments.
docStoreSegment - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
String of the shared doc store segment, or null if this segment does not share the doc store files.
docsWithField - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
 
DocTermOrds - Class in org.apache.lucene.index
This class enables fast access to multiple term ords for a specified field across all docIDs.
DocTermOrds(AtomicReader, Bits, String) - Constructor for class org.apache.lucene.index.DocTermOrds
Inverts all terms
DocTermOrds(AtomicReader, Bits, String, BytesRef) - Constructor for class org.apache.lucene.index.DocTermOrds
Inverts only terms starting w/ prefix
DocTermOrds(AtomicReader, Bits, String, BytesRef, int) - Constructor for class org.apache.lucene.index.DocTermOrds
Inverts only terms starting w/ prefix, and only terms whose docFreq (not taking deletions into account) is <= maxTermDocFreq
DocTermOrds(AtomicReader, Bits, String, BytesRef, int, int) - Constructor for class org.apache.lucene.index.DocTermOrds
Inverts only terms starting w/ prefix, and only terms whose docFreq (not taking deletions into account) is <= maxTermDocFreq, with a custom indexing interval (default is every 128nd term).
DocTermOrds(String, int, int) - Constructor for class org.apache.lucene.index.DocTermOrds
Subclass inits w/ this, but be sure you then call uninvert, only once
DocTermOrdsRangeFilter - Class in org.apache.lucene.search
A range filter built on top of a cached multi-valued term field (in FieldCache).
DocTermOrdsRewriteMethod - Class in org.apache.lucene.search
Rewrites MultiTermQueries into a filter, using DocTermOrds for term enumeration.
DocTermOrdsRewriteMethod() - Constructor for class org.apache.lucene.search.DocTermOrdsRewriteMethod
 
Document - Class in org.apache.lucene.document
Documents are the unit of indexing and search.
Document() - Constructor for class org.apache.lucene.document.Document
Constructs a new document with no fields.
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.BaseCompositeReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.FilterAtomicReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.IndexReader
Expert: visits the fields of a stored document, for custom processing/loading of each field.
document(int) - Method in class org.apache.lucene.index.IndexReader
Returns the stored fields of the 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.ParallelAtomicReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.SegmentReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
document(int, Set<String>) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
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.
DocValuesConsumer - Class in org.apache.lucene.codecs
Abstract API that consumes numeric, binary and sorted docvalues.
DocValuesConsumer() - Constructor for class org.apache.lucene.codecs.DocValuesConsumer
Sole constructor.
docValuesFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes docvalues
DocValuesFormat - Class in org.apache.lucene.codecs
Encodes/decodes per-document values.
DocValuesFormat(String) - Constructor for class org.apache.lucene.codecs.DocValuesFormat
Creates a new docvalues format.
docValuesFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
docValuesFormat() - Method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
Deprecated.
 
docValuesFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
Deprecated.
 
docValuesFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
Deprecated.
 
docValuesFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
Deprecated.
 
docValuesFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
Deprecated.
 
docValuesFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
 
DocValuesProducer - Class in org.apache.lucene.codecs
Abstract API that produces numeric, binary and sorted docvalues.
DocValuesProducer() - Constructor for class org.apache.lucene.codecs.DocValuesProducer
Sole constructor.
DocValuesProducer.SortedDocsWithField - Class in org.apache.lucene.codecs
A simple implementation of DocValuesProducer.getDocsWithField(org.apache.lucene.index.FieldInfo) that returns true if a document has an ordinal >= 0
DocValuesProducer.SortedDocsWithField(SortedDocValues, int) - Constructor for class org.apache.lucene.codecs.DocValuesProducer.SortedDocsWithField
Creates a Bits returning true if the document has a value
DocValuesProducer.SortedSetDocsWithField - Class in org.apache.lucene.codecs
A simple implementation of DocValuesProducer.getDocsWithField(org.apache.lucene.index.FieldInfo) that returns true if a document has any ordinals.
DocValuesProducer.SortedSetDocsWithField(SortedSetDocValues, int) - Constructor for class org.apache.lucene.codecs.DocValuesProducer.SortedSetDocsWithField
Creates a Bits returning true if the document has a value
docValuesStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of DocValues (null if DocValues could not be tested).
docValueType() - Method in class org.apache.lucene.document.FieldType
DocValues FieldInfo.DocValuesType: if non-null then the field's value will be indexed into docValues.
docValueType() - Method in interface org.apache.lucene.index.IndexableFieldType
DocValues FieldInfo.DocValuesType: if non-null then the field's value will be indexed into docValues.
doMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
doNext() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
doOpenIfChanged() - Method in class org.apache.lucene.index.DirectoryReader
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.
DoubleBarrelLRUCache<K extends DoubleBarrelLRUCache.CloneableKey,V> - Class in org.apache.lucene.util
Simple concurrent LRU cache, using a "double barrel" approach where two ConcurrentHashMaps record entries.
DoubleBarrelLRUCache(int) - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache
 
DoubleBarrelLRUCache.CloneableKey - Class in org.apache.lucene.util
Object providing clone(); the key class must subclass this.
DoubleBarrelLRUCache.CloneableKey() - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
 
DoubleDocValuesField - Class in org.apache.lucene.document
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.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 (4).
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.FilterDirectoryReader
Called by the doOpenIfChanged() methods to return a new wrapped DirectoryReader.
DS_COMPOUND_KEY - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
 
DS_NAME_KEY - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
 
DS_OFFSET_KEY - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValue
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueDate
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueStr
 

E

EliasFanoDecoder - Class in org.apache.lucene.util.packed
A decoder for an EliasFanoEncoder.
EliasFanoDecoder(EliasFanoEncoder) - Constructor for class org.apache.lucene.util.packed.EliasFanoDecoder
Construct a decoder for a given EliasFanoEncoder.
EliasFanoDocIdSet - Class in org.apache.lucene.util.packed
A DocIdSet in Elias-Fano encoding.
EliasFanoDocIdSet(int, int) - Constructor for class org.apache.lucene.util.packed.EliasFanoDocIdSet
Construct an EliasFanoDocIdSet.
EliasFanoEncoder - Class in org.apache.lucene.util.packed
Encode a non decreasing sequence of non negative whole numbers in the Elias-Fano encoding that was introduced in the 1970's by Peter Elias and Robert Fano.
EliasFanoEncoder(long, long, long) - Constructor for class org.apache.lucene.util.packed.EliasFanoEncoder
Construct an Elias-Fano encoder.
EliasFanoEncoder(long, long) - Constructor for class org.apache.lucene.util.packed.EliasFanoEncoder
Construct an Elias-Fano encoder using EliasFanoEncoder.DEFAULT_INDEX_INTERVAL.
EMPTY - Static variable in class org.apache.lucene.codecs.PostingsFormat
Zero-length PostingsFormat array.
EMPTY - Static variable in class org.apache.lucene.index.BinaryDocValues
An empty BinaryDocValues which returns BytesRef.EMPTY_BYTES for every document
EMPTY - Static variable in class org.apache.lucene.index.NumericDocValues
An empty NumericDocValues which returns zero for every document
EMPTY - Static variable in class org.apache.lucene.index.SortedDocValues
An empty SortedDocValues which returns BytesRef.EMPTY_BYTES for every document
EMPTY - Static variable in class org.apache.lucene.index.SortedSetDocValues
An empty SortedDocValues which returns SortedSetDocValues.NO_MORE_ORDS for every document
EMPTY - Static variable in class org.apache.lucene.index.TermsEnum
An empty TermsEnum for quickly returning an empty instance e.g.
empty() - Static method in class org.apache.lucene.search.DocIdSetIterator
An empty DocIdSetIterator instance
EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Bytes
Zero value for every document
EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Doubles
Zero value for every document
EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Floats
Zero value for every document
EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Ints
Zero value for every document
EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Longs
Zero value for every document
EMPTY - Static variable in class org.apache.lucene.search.FieldCache.Shorts
Zero value for every document
EMPTY - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables empty language (#).
EMPTY - Static variable in interface org.apache.lucene.util.BytesRefIterator
Singleton BytesRefIterator that iterates over 0 BytesRefs.
EMPTY_ARRAY - Static variable in class org.apache.lucene.index.Fields
Zero-length 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_DOCIDSET - Static variable in class org.apache.lucene.search.CachingWrapperFilter
An empty DocIdSet instance
EMPTY_INTS - Static variable in class org.apache.lucene.util.IntsRef
An empty integer array for convenience
EMPTY_LONGS - Static variable in class org.apache.lucene.util.LongsRef
An empty long array for convenience
EMPTY_TERM_SPANS - Static variable in class org.apache.lucene.search.spans.TermSpans
 
EMPTY_TOPDOCS - Static variable in class org.apache.lucene.search.TopDocsCollector
This is used in case topDocs() is called with illegal parameters, or there simply aren't (enough) results.
emptyVal - Variable in class org.apache.lucene.util.SentinelIntSet
 
encode(byte[], int, int, char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Encodes the input byte sequence into the output char sequence.
encode(long[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
Read iterations * valueCount() values 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.
encodeFromDisi(DocIdSetIterator) - Method in class org.apache.lucene.util.packed.EliasFanoDocIdSet
Encode the document ids from a DocIdSetIterator.
encodeNext(long) - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
Call at most numValues times to encode a non decreasing sequence of non negative numbers.
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.
end() - Method in class org.apache.lucene.analysis.CachingTokenFilter
 
end() - Method in class org.apache.lucene.analysis.TokenFilter
This method is called by the consumer after the last token has been consumed, after TokenStream.incrementToken() returned false (using the new TokenStream API).
end() - Method in class org.apache.lucene.analysis.TokenStream
This method is called by the consumer after the last token has been consumed, after TokenStream.incrementToken() returned false (using the new TokenStream API).
end() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
end() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
end() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
end - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
end() - Method in class org.apache.lucene.search.spans.Spans
Returns the end position of the current match.
end() - Method in class org.apache.lucene.search.spans.TermSpans
 
end - Variable in class org.apache.lucene.store.FSDirectory.FSIndexInput
end offset (start+length)
END_LABEL - Static variable in class org.apache.lucene.util.fst.FST
If arc has this label then that arc is final/accepted
endOffset() - Method in class org.apache.lucene.analysis.Token
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
endOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
endOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
endOffset() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
 
endOffset() - Method in class org.apache.lucene.index.DocsAndPositionsEnum
Returns end offset for the current position, or -1 if offsets were not indexed.
endOffset() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
 
endOffset() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
 
endOfSlice() - Method in class org.apache.lucene.util.IntBlockPool.SliceReader
Returns true iff the current slice is fully read.
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(long) - Method in class org.apache.lucene.util.OpenBitSet
Ensure that the long[] is big enough to hold numBits, expanding it if necessary.
ensureCapacityWords(int) - Method in class org.apache.lucene.util.OpenBitSet
Expand the long[] with the size given as a number of words (64 bit longs).
ensureOpen() - Method in class org.apache.lucene.index.IndexReader
Throws AlreadyClosedException if this IndexReader or any of its child readers is closed, otherwise returns.
ensureOpen(boolean) - Method in class org.apache.lucene.index.IndexWriter
Used internally to throw an AlreadyClosedException if this IndexWriter has been closed or is in the process of closing.
ensureOpen() - Method in class org.apache.lucene.index.IndexWriter
Used internally to throw an AlreadyClosedException if this IndexWriter has been closed (closed=true) or is in the process of closing (closing=true).
ensureOpen() - Method in class org.apache.lucene.store.BaseDirectory
 
ensureOpen() - Method in class org.apache.lucene.store.Directory
 
eof() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
equals(Object) - Method in class org.apache.lucene.analysis.Token
 
equals(Object) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.index.IndexCommit
Two IndexCommits are equal if both their Directory and versions are equal.
equals(Object) - Method in class org.apache.lucene.index.IndexReader
equals(Object) - Method in class org.apache.lucene.index.SegmentInfo
We consider another SegmentInfo instance equal if it has the same dir and same name.
equals(Object) - Method in class org.apache.lucene.index.Term
 
equals(Object) - Method in class org.apache.lucene.search.AutomatonQuery
 
equals(Object) - Method in class org.apache.lucene.search.BooleanClause
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.BooleanQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.CachingWrapperFilter
 
equals(Object) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
equals(Object) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Return true iff we represent the same query as o
equals(Object) - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
 
equals(Object) - Method in class org.apache.lucene.search.DocTermOrdsRewriteMethod
 
equals(Object) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
 
equals(Object) - Method in class org.apache.lucene.search.FieldCacheRewriteMethod
 
equals(Object) - Method in class org.apache.lucene.search.FieldValueFilter
 
equals(Object) - Method in class org.apache.lucene.search.FilteredQuery
Returns true iff 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.MatchAllDocsQuery
 
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
 
equals(Object) - Method in class org.apache.lucene.search.NGramPhraseQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.NumericRangeQuery
 
equals(Object) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.PhraseQuery
Returns true iff 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.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.SpanFirstQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearQuery
Returns true iff 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.SpanPayloadCheckQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.TermQuery
Returns true iff 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(char[], int, char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
See if two array slices are the same.
equals(byte[], int, byte[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
See if two array slices are the same.
equals(int[], int, int[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
See if two array slices are the same.
equals(Object) - Method in class org.apache.lucene.util.AttributeSource
 
equals(Object) - Method in class org.apache.lucene.util.automaton.Automaton
 
equals(Object) - Method in class org.apache.lucene.util.automaton.StatePair
Checks for equality.
equals(Object) - Method in class org.apache.lucene.util.automaton.Transition
Checks for equality.
equals(Object) - Method in class org.apache.lucene.util.BytesRef
 
equals(Object) - Method in class org.apache.lucene.util.CharsRef
 
equals(Object) - Method in class org.apache.lucene.util.FixedBitSet
returns true if both sets have the same bits set
equals(Object) - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
 
equals(Object) - Method in class org.apache.lucene.util.IntsRef
 
equals(Object) - Method in class org.apache.lucene.util.LongsRef
 
equals(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
 
equals(Object) - Method in class org.apache.lucene.util.OpenBitSet
returns true if both sets have the same bits set
equals(Object) - Method in class org.apache.lucene.util.packed.EliasFanoDocIdSet
 
equals(Object) - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
 
equals(String, String) - Static method in class org.apache.lucene.util.StringHelper
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
error - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Exception thrown during doc values test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
Exception thrown during stored fields test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
Exception thrown during term vector test (null on success)
estimatedMergeBytes - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
Estimated size in bytes of the merged segment.
estimatedMergeBytes - Variable in class org.apache.lucene.store.MergeInfo
 
estimatedSegmentSize - Variable in class org.apache.lucene.store.FlushInfo
 
estimateSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
Computes (and stores) the estimated size of the cache Value
execute(TwoPhaseCommit...) - Static method in class org.apache.lucene.index.TwoPhaseCommitTool
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?
expandingWordNum(long) - Method in class org.apache.lucene.util.OpenBitSet
 
expandSingleton() - Method in class org.apache.lucene.util.automaton.Automaton
Expands singleton representation to normal representation.
EXPECTED - Static variable in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
Indicates an expected bit of "insanity".
explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
 
explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Explain the score we computed for doc
explain(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
Returns an Explanation that describes how 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(AtomicReaderContext, int) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanWeight
 
explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight
 
explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect
Returns an explanation for the score.
explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
 
explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectB
 
explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectL
 
explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModel
Returns an explanation for the score.
explain(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIn
 
explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.DFRSimilarity
 
explain(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Distribution
Explains the score.
explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.IBSimilarity
 
explain(BasicStats) - Method in class org.apache.lucene.search.similarities.Lambda
Explains the lambda parameter.
explain(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaDF
 
explain(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaTTF
 
explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
 
explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
 
explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.LMSimilarity
 
explain(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization
Returns an explanation for the normalized term frequency.
explain(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
 
explain(int, Explanation) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
Explain the score for a single document
explain(Explanation, BasicStats, int, float, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
Subclasses should implement this method to explain the score.
explain(BasicStats, int, Explanation, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
Explains the score.
explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.spans.SpanWeight
 
explain(AtomicReaderContext, int) - Method in class org.apache.lucene.search.Weight
An explanation of the score computation for the named document.
Explanation - Class in org.apache.lucene.search
Expert: Describes the score computation for document and query.
Explanation() - Constructor for class org.apache.lucene.search.Explanation
 
Explanation(float, String) - Constructor for class org.apache.lucene.search.Explanation
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.BooleanQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.FilteredQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.PhraseQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.Query
Expert: adds all terms occurring in this query to the terms set.
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.TermQuery
 

F

failureReason - Variable in class org.apache.lucene.store.Lock
If a lock obtain called, this failureReason may be set with the "root cause" Exception as to why the lock was not obtained.
FAST - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
A compression mode that trades compression ratio for speed.
FAST - Static variable in class org.apache.lucene.util.packed.PackedInts
At most 50% memory overhead, always select a reasonably fast implementation.
FAST_DECOMPRESSION - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
This compression mode is similar to CompressionMode.FAST but it spends more time compressing in order to improve the compression ratio.
fastClear(int) - Method in class org.apache.lucene.util.OpenBitSet
clears a bit.
fastClear(long) - Method in class org.apache.lucene.util.OpenBitSet
clears a bit.
FASTEST - Static variable in class org.apache.lucene.util.packed.PackedInts
At most 700% memory overhead, always select a direct implementation.
fastestFormatAndBits(int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
Try to find the PackedInts.Format and number of bits per value that would restore from disk the fastest reader whose overhead is less than acceptableOverheadRatio.
fastFlip(int) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit.
fastFlip(long) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit.
fastGet(int) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index.
fastGet(long) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index.
fastSet(int) - Method in class org.apache.lucene.util.OpenBitSet
Sets the bit at the specified index.
fastSet(long) - Method in class org.apache.lucene.util.OpenBitSet
Sets the bit at the specified index.
field - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
Field name.
Field - Class in org.apache.lucene.document
Expert: directly create a field for a document.
Field(String, FieldType) - Constructor for class org.apache.lucene.document.Field
Expert: creates a field with no initial value.
Field(String, Reader, FieldType) - Constructor for class org.apache.lucene.document.Field
Create field with Reader value.
Field(String, TokenStream, FieldType) - Constructor for class org.apache.lucene.document.Field
Create field with TokenStream value.
Field(String, byte[], FieldType) - Constructor for class org.apache.lucene.document.Field
Create field with binary value.
Field(String, byte[], int, int, FieldType) - Constructor for class org.apache.lucene.document.Field
Create field with binary value.
Field(String, BytesRef, FieldType) - Constructor for class org.apache.lucene.document.Field
Create field with binary value.
Field(String, String, FieldType) - Constructor for class org.apache.lucene.document.Field
Create field with String value.
Field(String, String, Field.Store, Field.Index) - Constructor for class org.apache.lucene.document.Field
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 - Variable in class org.apache.lucene.index.DocTermOrds
Field we are uninverting.
field() - Method in class org.apache.lucene.index.Term
Returns the field of this term.
field() - Method in class org.apache.lucene.search.CollectionStatistics
returns the field name
field - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
 
field() - Method in class org.apache.lucene.search.FieldValueFilter
Returns the field this filter is applied on.
field - Variable in class org.apache.lucene.search.MultiTermQuery
 
field - Variable in class org.apache.lucene.search.spans.SpanNearQuery
 
Field.Index - Enum in org.apache.lucene.document
Deprecated.
This is here only to ease transition from the pre-4.0 APIs.
Field.Store - Enum in org.apache.lucene.document
Specifies whether and how a field should be stored.
Field.TermVector - Enum in org.apache.lucene.document
Deprecated.
This is here only to ease transition from the pre-4.0 APIs.
FIELD_DOC - Static variable in class org.apache.lucene.search.SortField
Represents sorting by document number (index order).
FIELD_SCORE - Static variable in class org.apache.lucene.search.SortField
Represents sorting by document score (relevance).
FieldCache - Interface in org.apache.lucene.search
Expert: Maintains caches of term values.
FieldCache.ByteParser - Interface in org.apache.lucene.search
Deprecated.
FieldCache.Bytes - Class in org.apache.lucene.search
Field values as 8-bit signed bytes
FieldCache.Bytes() - Constructor for class org.apache.lucene.search.FieldCache.Bytes
 
FieldCache.CacheEntry - Class in org.apache.lucene.search
EXPERT: A unique Identifier/Description for each item in the FieldCache.
FieldCache.CacheEntry(Object, String, Class<?>, Object, Object) - Constructor for class org.apache.lucene.search.FieldCache.CacheEntry
 
FieldCache.CreationPlaceholder - Class in org.apache.lucene.search
Placeholder indicating creation of this cache is currently in-progress.
FieldCache.CreationPlaceholder() - Constructor for class org.apache.lucene.search.FieldCache.CreationPlaceholder
 
FieldCache.DoubleParser - Interface in org.apache.lucene.search
Interface to parse doubles from document fields.
FieldCache.Doubles - Class in org.apache.lucene.search
Field values as 64-bit doubles
FieldCache.Doubles() - Constructor for class org.apache.lucene.search.FieldCache.Doubles
 
FieldCache.FloatParser - Interface in org.apache.lucene.search
Interface to parse floats from document fields.
FieldCache.Floats - Class in org.apache.lucene.search
Field values as 32-bit floats
FieldCache.Floats() - Constructor for class org.apache.lucene.search.FieldCache.Floats
 
FieldCache.IntParser - Interface in org.apache.lucene.search
Interface to parse ints from document fields.
FieldCache.Ints - Class in org.apache.lucene.search
Field values as 32-bit signed integers
FieldCache.Ints() - Constructor for class org.apache.lucene.search.FieldCache.Ints
 
FieldCache.LongParser - Interface in org.apache.lucene.search
Interface to parse long from document fields.
FieldCache.Longs - Class in org.apache.lucene.search
Field values as 64-bit signed long integers
FieldCache.Longs() - Constructor for class org.apache.lucene.search.FieldCache.Longs
 
FieldCache.Parser - Interface in org.apache.lucene.search
Marker interface as super-interface to all parsers.
FieldCache.ShortParser - Interface in org.apache.lucene.search
Deprecated.
FieldCache.Shorts - Class in org.apache.lucene.search
Field values as 16-bit signed shorts
FieldCache.Shorts() - Constructor for class org.apache.lucene.search.FieldCache.Shorts
 
FieldCacheDocIdSet - Class in org.apache.lucene.search
Base class for DocIdSet to be used with FieldCache.
FieldCacheDocIdSet(int, Bits) - Constructor for class org.apache.lucene.search.FieldCacheDocIdSet
 
FieldCacheRangeFilter<T> - Class in org.apache.lucene.search
A range filter built on top of a cached single term field (in FieldCache).
FieldCacheRewriteMethod - Class in org.apache.lucene.search
Rewrites MultiTermQueries into a filter, using the FieldCache for term enumeration.
FieldCacheRewriteMethod() - Constructor for class org.apache.lucene.search.FieldCacheRewriteMethod
 
FieldCacheSanityChecker - Class in org.apache.lucene.util
Provides methods for sanity checking that entries in the FieldCache are not wasteful or inconsistent.
FieldCacheSanityChecker() - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker
 
FieldCacheSanityChecker.Insanity - Class in org.apache.lucene.util
Simple container for a collection of related CacheEntry objects that in conjunction with each other represent some "insane" usage of the FieldCache.
FieldCacheSanityChecker.Insanity(FieldCacheSanityChecker.InsanityType, String, FieldCache.CacheEntry...) - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
 
FieldCacheSanityChecker.InsanityType - Class in org.apache.lucene.util
An Enumeration of the different types of "insane" behavior that may be detected in a FieldCache.
FieldCacheTermsFilter - Class in org.apache.lucene.search
A Filter that only accepts documents whose single term value in the specified field is contained in the provided set of allowed terms.
FieldCacheTermsFilter(String, BytesRef...) - Constructor for class org.apache.lucene.search.FieldCacheTermsFilter
 
FieldCacheTermsFilter(String, String...) - Constructor for class org.apache.lucene.search.FieldCacheTermsFilter
 
FieldComparator<T> - Class in org.apache.lucene.search
Expert: a FieldComparator compares hits so as to determine their sort order when collecting the top results with TopFieldCollector.
FieldComparator() - Constructor for class org.apache.lucene.search.FieldComparator
 
FieldComparator.ByteComparator - Class in org.apache.lucene.search
Deprecated.
FieldComparator.DocComparator - Class in org.apache.lucene.search
Sorts by ascending docID
FieldComparator.DoubleComparator - Class in org.apache.lucene.search
Parses field's values as double (using FieldCache.getDoubles(org.apache.lucene.index.AtomicReader, java.lang.String, boolean) and sorts by ascending value
FieldComparator.FloatComparator - Class in org.apache.lucene.search
Parses field's values as float (using FieldCache.getFloats(org.apache.lucene.index.AtomicReader, java.lang.String, boolean) and sorts by ascending value
FieldComparator.IntComparator - Class in org.apache.lucene.search
Parses field's values as int (using FieldCache.getInts(org.apache.lucene.index.AtomicReader, java.lang.String, boolean) and sorts by ascending value
FieldComparator.LongComparator - Class in org.apache.lucene.search
Parses field's values as long (using FieldCache.getLongs(org.apache.lucene.index.AtomicReader, java.lang.String, boolean) and sorts by ascending value
FieldComparator.NumericComparator<T extends Number> - Class in org.apache.lucene.search
Base FieldComparator class for numeric types
FieldComparator.NumericComparator(String, T) - Constructor for class org.apache.lucene.search.FieldComparator.NumericComparator
 
FieldComparator.RelevanceComparator - Class in org.apache.lucene.search
Sorts by descending relevance.
FieldComparator.ShortComparator - Class in org.apache.lucene.search
Deprecated.
FieldComparator.TermOrdValComparator - Class in org.apache.lucene.search
Sorts by field's natural Term sort order, using ordinals.
FieldComparator.TermOrdValComparator(int, String) - Constructor for class org.apache.lucene.search.FieldComparator.TermOrdValComparator
 
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 - Class in org.apache.lucene.index
Access to the Field Info file that describes document fields and whether or not they are indexed.
FieldInfo(String, boolean, int, boolean, boolean, boolean, FieldInfo.IndexOptions, FieldInfo.DocValuesType, FieldInfo.DocValuesType, Map<String, String>) - Constructor for class org.apache.lucene.index.FieldInfo
Sole Constructor.
fieldInfo(String) - Method in class org.apache.lucene.index.FieldInfos
Return the fieldinfo object referenced by the field name
fieldInfo(int) - Method in class org.apache.lucene.index.FieldInfos
Return the fieldinfo object referenced by the fieldNumber.
FieldInfo.DocValuesType - Enum in org.apache.lucene.index
DocValues types.
FieldInfo.IndexOptions - Enum in org.apache.lucene.index
Controls how much information is stored in the postings lists.
FieldInfos - Class in org.apache.lucene.index
Collection of FieldInfos (accessible by number or by name).
FieldInfos(FieldInfo[]) - Constructor for class org.apache.lucene.index.FieldInfos
Constructs a new FieldInfos from an array of FieldInfo objects
fieldInfos - Variable in class org.apache.lucene.index.MergeState
FieldInfos of the newly merged segment.
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.lucene3x.Lucene3xCodec
Deprecated.
 
fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene40.Lucene40Codec
Deprecated.
 
fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene41.Lucene41Codec
Deprecated.
 
fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
Deprecated.
 
fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
Deprecated.
 
fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
 
FieldInfosReader - Class in org.apache.lucene.codecs
Codec API for reading FieldInfos.
FieldInfosReader() - Constructor for class org.apache.lucene.codecs.FieldInfosReader
Sole constructor.
FieldInfosWriter - Class in org.apache.lucene.codecs
Codec API for writing FieldInfos.
FieldInfosWriter() - Constructor for class org.apache.lucene.codecs.FieldInfosWriter
Sole constructor.
FieldInvertState - Class in org.apache.lucene.index
This class tracks the number and position / offset parameters of terms being added to the index.
FieldInvertState(String) - Constructor for class org.apache.lucene.index.FieldInvertState
Creates {code FieldInvertState} for the specified field name.
FieldInvertState(String, int, int, int, int, float) - Constructor for class org.apache.lucene.index.FieldInvertState
Creates {code FieldInvertState} for the specified field name and values for all fields.
FieldMaskingSpanQuery - Class in org.apache.lucene.search.spans
Wrapper to allow SpanQuery objects participate in composite single-field SpanQueries by 'lying' about their search field.
FieldMaskingSpanQuery(SpanQuery, String) - Constructor for class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
fieldName - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
 
fieldNormStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of field norms (null if field norms could not be tested).
fields() - Method in class org.apache.lucene.index.AtomicReader
Returns Fields for this reader.
Fields - Class in org.apache.lucene.index
Flex API for access to fields and terms
Fields() - Constructor for class org.apache.lucene.index.Fields
Sole constructor.
fields() - Method in class org.apache.lucene.index.FilterAtomicReader
 
fields() - Method in class org.apache.lucene.index.ParallelAtomicReader
 
fields() - Method in class org.apache.lucene.index.SegmentReader
 
fields() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
fields - Variable in class org.apache.lucene.search.FieldDoc
Expert: The values which are used to sort the referenced document.
fields - Variable in class org.apache.lucene.search.FieldValueHitQueue
Stores the sort criteria being used.
fields - Variable in class org.apache.lucene.search.TopFieldDocs
The fields which were used to sort results by.
FIELDS_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
Extension of stored fields file
FIELDS_INDEX_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
Extension of stored fields index file
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.DocValuesFormat
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.lucene40.Lucene40DocValuesFormat
Deprecated.
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
Deprecated.
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene42.Lucene42DocValuesFormat
Deprecated.
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesFormat
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.PostingsFormat
Writes a new segment
fieldsData - Variable in class org.apache.lucene.document.Field
Field's value
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.DocValuesFormat
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.lucene40.Lucene40DocValuesFormat
Deprecated.
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene40.Lucene40PostingsFormat
Deprecated.
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene42.Lucene42DocValuesFormat
Deprecated.
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesFormat
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.PostingsFormat
Reads a segment.
fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
 
fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsFormat
 
fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
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.lucene40.Lucene40StoredFieldsFormat
 
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.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
A Filter that accepts all documents that have one or more values in a given field.
FieldValueFilter(String) - Constructor for class org.apache.lucene.search.FieldValueFilter
Creates a new FieldValueFilter
FieldValueFilter(String, boolean) - Constructor for class org.apache.lucene.search.FieldValueFilter
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.
FieldValueHitQueue.Entry(int, int, float) - Constructor for class org.apache.lucene.search.FieldValueHitQueue.Entry
 
file - Variable in class org.apache.lucene.store.FSDirectory.FSIndexInput
the underlying RandomAccessFile
fileExists(String) - Method in class org.apache.lucene.store.CompoundFileDirectory
Returns true iff a file with the given name exists.
fileExists(String) - Method in class org.apache.lucene.store.Directory
Returns true iff a file with the given name exists.
fileExists(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
fileExists(String) - Method in class org.apache.lucene.store.FilterDirectory
 
fileExists(String) - Method in class org.apache.lucene.store.FSDirectory
Returns true iff a file with the given name exists.
fileExists(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
fileExists(String) - Method in class org.apache.lucene.store.RAMDirectory
Returns true iff the named file exists in this directory.
fileLength(String) - Method in class org.apache.lucene.store.CompoundFileDirectory
Returns the length of a file in the directory.
fileLength(String) - Method in class org.apache.lucene.store.Directory
Returns the length of a file in the directory.
fileLength(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
fileLength(String) - Method in class org.apache.lucene.store.FilterDirectory
 
fileLength(String) - Method in class org.apache.lucene.store.FSDirectory
Returns the length in bytes of a file in the directory.
fileLength(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
fileLength(String) - Method in class org.apache.lucene.store.RAMDirectory
Returns the length in bytes of a file in the directory.
fileMap - Variable in class org.apache.lucene.store.RAMDirectory
 
fileModified(File, String) - Static method in class org.apache.lucene.store.FSDirectory
Returns the time the named file was last modified.
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.lucene40.Lucene40LiveDocsFormat
 
files() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns all files in use by this segment.
files() - Method in class org.apache.lucene.index.SegmentInfo
Return all files referenced by this SegmentInfo.
files(Directory, boolean) - Method in class org.apache.lucene.index.SegmentInfos
Returns all file names referenced by SegmentInfo instances matching the provided Directory (ie files associated with any "external" segments are skipped).
FileSwitchDirectory - Class in org.apache.lucene.store
Expert: A Directory instance that switches files between two other Directory instances.
FileSwitchDirectory(Set<String>, Directory, Directory, boolean) - Constructor for class org.apache.lucene.store.FileSwitchDirectory
 
fill(int, int, long) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
fill(int, int, long) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
Fill the mutable from fromIndex (inclusive) 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.
fillBytesRef() - Method in class org.apache.lucene.analysis.NumericTokenStream.NumericTermAttributeImpl
 
fillBytesRef() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
fillBytesRef() - Method in interface org.apache.lucene.analysis.tokenattributes.TermToBytesRefAttribute
Updates the bytes TermToBytesRefAttribute.getBytesRef() to contain this term's final encoding, and returns its hashcode.
fillSlice(BytesRef, long, int) - Method in class org.apache.lucene.util.PagedBytes.Reader
Gets a slice out of PagedBytes starting at start with a given length.
filter - Variable in class org.apache.lucene.search.ConstantScoreQuery
 
Filter - Class in org.apache.lucene.search
Abstract base class for restricting which documents may be returned during searching.
Filter() - Constructor for class org.apache.lucene.search.Filter
 
FilterAtomicReader - Class in org.apache.lucene.index
A FilterAtomicReader contains another AtomicReader, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterAtomicReader(AtomicReader) - Constructor for class org.apache.lucene.index.FilterAtomicReader
Construct a FilterAtomicReader based on the specified base reader.
FilterAtomicReader.FilterDocsAndPositionsEnum - Class in org.apache.lucene.index
Base class for filtering DocsAndPositionsEnum implementations.
FilterAtomicReader.FilterDocsAndPositionsEnum(DocsAndPositionsEnum) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
Create a new FilterDocsAndPositionsEnum
FilterAtomicReader.FilterDocsEnum - Class in org.apache.lucene.index
Base class for filtering DocsEnum implementations.
FilterAtomicReader.FilterDocsEnum(DocsEnum) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
Create a new FilterDocsEnum
FilterAtomicReader.FilterFields - Class in org.apache.lucene.index
Base class for filtering Fields implementations.
FilterAtomicReader.FilterFields(Fields) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterFields
Creates a new FilterFields.
FilterAtomicReader.FilterTerms - Class in org.apache.lucene.index
Base class for filtering Terms implementations.
FilterAtomicReader.FilterTerms(Terms) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterTerms
Creates a new FilterTerms
FilterAtomicReader.FilterTermsEnum - Class in org.apache.lucene.index
Base class for filtering TermsEnum implementations.
FilterAtomicReader.FilterTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
Creates a new FilterTermsEnum
FilterCodec - Class in org.apache.lucene.codecs
A codec that forwards all its method calls to another codec.
FilterCodec(String, Codec) - Constructor for class org.apache.lucene.codecs.FilterCodec
Sole constructor.
FilterDirectory - Class in org.apache.lucene.store
Directory implementation that delegates calls to another directory.
FilterDirectory(Directory) - Constructor for class org.apache.lucene.store.FilterDirectory
Sole constructor, typically called from sub-classes.
FilterDirectoryReader - Class in org.apache.lucene.index
A FilterDirectoryReader wraps another DirectoryReader, allowing implementations to transform or extend it.
FilterDirectoryReader(DirectoryReader) - Constructor for class org.apache.lucene.index.FilterDirectoryReader
Create a new FilterDirectoryReader that filters a passed in DirectoryReader.
FilterDirectoryReader(DirectoryReader, FilterDirectoryReader.SubReaderWrapper) - Constructor for class org.apache.lucene.index.FilterDirectoryReader
Create a new FilterDirectoryReader that filters a passed in DirectoryReader, using the supplied SubReaderWrapper to wrap its subreader.
FilterDirectoryReader.StandardReaderWrapper - Class in org.apache.lucene.index
A no-op SubReaderWrapper that simply returns the parent DirectoryReader's original subreaders.
FilterDirectoryReader.StandardReaderWrapper() - Constructor for class org.apache.lucene.index.FilterDirectoryReader.StandardReaderWrapper
Constructor
FilterDirectoryReader.SubReaderWrapper - Class in org.apache.lucene.index
Factory class passed to FilterDirectoryReader constructor that allows subclasses to wrap the filtered DirectoryReader's subreaders.
FilterDirectoryReader.SubReaderWrapper() - Constructor for class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
Constructor
FilteredDocIdSet - Class in org.apache.lucene.search
Abstract decorator class for a DocIdSet implementation that provides on-demand filtering/validation mechanism on a given DocIdSet.
FilteredDocIdSet(DocIdSet) - Constructor for class org.apache.lucene.search.FilteredDocIdSet
Constructor.
FilteredDocIdSetIterator - Class in org.apache.lucene.search
Abstract decorator class of a DocIdSetIterator implementation that provides on-demand filter/validation mechanism on an underlying DocIdSetIterator.
FilteredDocIdSetIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.FilteredDocIdSetIterator
Constructor.
FilteredQuery - Class in org.apache.lucene.search
A query that applies a filter to the results of another query.
FilteredQuery(Query, Filter) - Constructor for class org.apache.lucene.search.FilteredQuery
Constructs a new query which applies a filter to the results of the original query.
FilteredQuery(Query, Filter, FilteredQuery.FilterStrategy) - Constructor for class org.apache.lucene.search.FilteredQuery
Expert: Constructs a new query which applies a filter to the results of the original query.
FilteredQuery.FilterStrategy - Class in org.apache.lucene.search
Abstract class that defines how the filter (DocIdSet) applied during document collection.
FilteredQuery.FilterStrategy() - Constructor for class org.apache.lucene.search.FilteredQuery.FilterStrategy
 
FilteredQuery.RandomAccessFilterStrategy - Class in org.apache.lucene.search
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, int) returns true.
FilteredQuery.RandomAccessFilterStrategy() - Constructor for class org.apache.lucene.search.FilteredQuery.RandomAccessFilterStrategy
 
filteredScorer(AtomicReaderContext, boolean, boolean, Weight, DocIdSet) - Method in class org.apache.lucene.search.FilteredQuery.FilterStrategy
Returns a filtered Scorer based on this strategy.
filteredScorer(AtomicReaderContext, boolean, boolean, Weight, DocIdSet) - Method in class org.apache.lucene.search.FilteredQuery.RandomAccessFilterStrategy
 
FilteredTermsEnum - Class in org.apache.lucene.index
Abstract class for enumerating a subset of all terms.
FilteredTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
Creates a filtered TermsEnum on a terms enum.
FilteredTermsEnum(TermsEnum, boolean) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
Creates a filtered TermsEnum on a terms enum.
FilteredTermsEnum.AcceptStatus - Enum in org.apache.lucene.index
Return value, if term should be accepted or the iteration should END.
FilterIterator<T> - Class in org.apache.lucene.util
An Iterator implementation that filters elements with a boolean predicate.
FilterIterator(Iterator<T>) - Constructor for class org.apache.lucene.util.FilterIterator
 
filterPrefixCodedInts(TermsEnum) - Static method in class org.apache.lucene.util.NumericUtils
Filters the given TermsEnum by accepting only prefix coded 32 bit terms with a shift value of 0.
filterPrefixCodedLongs(TermsEnum) - Static method in class org.apache.lucene.util.NumericUtils
Filters the given TermsEnum by accepting only prefix coded 64 bit terms with a shift value of 0.
find(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Returns the id of the given BytesRef.
find(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefHash
Returns the id of the given BytesRef with a pre-calculated hash code.
find(int) - Method in class org.apache.lucene.util.SentinelIntSet
(internal) Returns the slot for this key, or -slot-1 if not found
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
Finds merges necessary to force-merge all deletes from the index.
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations is necessary in order to expunge all deletes from the index.
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.LogMergePolicy
Returns the merges necessary to merge the index down to a specified number of segments.
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations is necessary in order to merge to <= the specified segment count.
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
Checks if any merges are now necessary and returns a MergePolicy.MergeSpecification if so.
findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations are now necessary on the index.
findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
 
findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findMerges(MergePolicy.MergeTrigger, SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findTargetArc(int, FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
Finds an arc leaving the incoming arc, replacing the arc in place.
finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
 
finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40StoredFieldsWriter
 
finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
 
finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Called before StoredFieldsWriter.close(), passing in the number of documents that were written.
finish(long, long, int) - Method in class org.apache.lucene.codecs.TermsConsumer
Called when we are done adding terms to this field.
finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called before TermVectorsWriter.close(), passing in the number of documents that were written.
finish() - Method in class org.apache.lucene.util.fst.Builder
Returns final FST.
finish() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
Perform end-of-stream operations.
finishCommit() - Method in class org.apache.lucene.store.ChecksumIndexOutput
writes the checksum
finishDoc() - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
 
finishDoc() - Method in class org.apache.lucene.codecs.PostingsConsumer
Called when we are done adding positions & payloads for each doc.
finishDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
 
finishDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
finishDocument() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
 
finishDocument() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Called when a document and all its fields have been added.
finishDocument() - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called after a doc and all its fields have been added.
finishField() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
finishField() - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called after a field and all its terms have been added.
finishTerm() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
 
finishTerm(TermStats) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
Called when we are done adding docs to this term
finishTerm(TermStats) - Method in class org.apache.lucene.codecs.PostingsWriterBase
Finishes the current term.
finishTerm(BytesRef, TermStats) - Method in class org.apache.lucene.codecs.TermsConsumer
Finishes the current term; numDocs must be > 0.
finishTerm() - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called after a term and all its positions have been added.
finite - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Indicates if the automaton accepts a finite set of strings.
FIRST_LEVEL_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
The first level size for new slices
firstComparator - Variable in class org.apache.lucene.search.FieldValueHitQueue
 
FixedBitSet - Class in org.apache.lucene.util
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
 
FixedBitSet(long[], int) - Constructor for class org.apache.lucene.util.FixedBitSet
 
FixedBitSet(FixedBitSet, int) - Constructor for class org.apache.lucene.util.FixedBitSet
Makes a full copy of the bits, while allowing to expand/shrink the bitset.
fixIndex(CheckIndex.Status) - Method in class org.apache.lucene.index.CheckIndex
Repairs the index using previously returned result from CheckIndex.checkIndex().
FLAG_FREQS - Static variable in class org.apache.lucene.index.DocsEnum
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
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
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
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(long) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit, expanding the set size if necessary
flip(long, long) - Method in class org.apache.lucene.util.OpenBitSet
Flips a range of bits, expanding the set size if necessary
flipAndGet(int) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit and returns the resulting bit value.
flipAndGet(long) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit and returns the resulting bit value.
FloatDocValuesField - Class in org.apache.lucene.document
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.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 (4).
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, BytesRef) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
Finds largest term accepted by this Automaton, that's <= the provided input term.
floorBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
The number of floor blocks (meta-blocks larger than the allowed maxItemsPerBlock) in the terms file.
floorSubBlockCount - Variable in class org.apache.lucene.codecs.BlockTreeTermsReader.Stats
The number of sub-blocks within the floor blocks.
flush(boolean, boolean) - Method in class org.apache.lucene.index.IndexWriter
Flush all in-memory buffered updates (adds and deletes) to the Directory.
flush() - Method in class org.apache.lucene.store.BufferedIndexOutput
 
flush() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
flush() - Method in class org.apache.lucene.store.IndexOutput
Forces any buffered output to be written.
flush() - Method in class org.apache.lucene.store.RAMOutputStream
 
flush() - Method in class org.apache.lucene.util.packed.BlockPackedWriter
 
flush() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
 
flush() - Method in class org.apache.lucene.util.packed.PackedDataOutput
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.
flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexOutput
Expert: implements buffer write.
flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
 
FlushInfo - Class in org.apache.lucene.store
A FlushInfo provides information required for a FLUSH context.
FlushInfo(int, long) - Constructor for class org.apache.lucene.store.FlushInfo
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.
flushTermsBlock(int, int) - Method in class org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter
 
flushTermsBlock(int, int) - Method in class org.apache.lucene.codecs.PostingsWriterBase
Flush count terms starting at start "backwards", as a block.
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
 
FORMAT_3_1 - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
Each segment records the Lucene version that created it.
FORMAT_DIAGNOSTICS - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
This format adds optional per-segment String diagnostics storage, and switches userData to Map
FORMAT_HAS_VECTORS - Static variable in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
Each segment records whether it has term vectors
FORMAT_SEGMENTS_GEN_CURRENT - Static variable in class org.apache.lucene.index.SegmentInfos
Used for the segments.gen file only! Whenever you add a new format, make it 1 smaller (negative version logic)!
forName(String) - Static method in class org.apache.lucene.codecs.Codec
looks up a codec by name
forName(String) - Static method in class org.apache.lucene.codecs.DocValuesFormat
looks up a format by name
forName(String) - Static method in class org.apache.lucene.codecs.PostingsFormat
looks up a format by name
FREE_BSD - Static variable in class org.apache.lucene.util.Constants
True iff running on FreeBSD
freeBefore(int) - Method in class org.apache.lucene.util.RollingBuffer
 
freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
Removes the given number of byte blocks from the buffer if possible.
freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
Removes the given number of int blocks from the buffer if possible.
freeze() - Method in class org.apache.lucene.document.FieldType
Prevents future changes.
freeze(Builder.UnCompiledNode<T>[], int, IntsRef) - Method in class org.apache.lucene.util.fst.Builder.FreezeTail
 
freeze(boolean) - Method in class org.apache.lucene.util.PagedBytes
Commits final byte[], trimming it if necessary and if trim=true
freq() - Method in class org.apache.lucene.codecs.MappingMultiDocsAndPositionsEnum
 
freq() - Method in class org.apache.lucene.codecs.MappingMultiDocsEnum
 
freq() - Method in class org.apache.lucene.index.DocsEnum
Returns term frequency in the current document, or 1 if the field was indexed with FieldInfo.IndexOptions.DOCS_ONLY.
freq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsAndPositionsEnum
 
freq() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterDocsEnum
 
freq() - Method in class org.apache.lucene.index.MultiDocsAndPositionsEnum
 
freq() - Method in class org.apache.lucene.index.MultiDocsEnum
 
freq() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
freq() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
freq - Variable in class org.apache.lucene.search.spans.SpanScorer
 
freq() - Method in class org.apache.lucene.search.spans.SpanScorer
 
freq - Variable in class org.apache.lucene.search.spans.TermSpans
 
FSDirectory - Class in org.apache.lucene.store
Base class for Directory implementations that store index files in the file system.
FSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.FSDirectory
Create a new FSDirectory for the named location (ctor for subclasses).
FSDirectory.FSIndexInput - Class in org.apache.lucene.store
Base class for reading input from a RandomAccessFile
FSDirectory.FSIndexInput(String, File, IOContext) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexInput
Create a new FSIndexInput, reading the entire file from path
FSDirectory.FSIndexInput(String, RandomAccessFile, long, long, int) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexInput
Create a new FSIndexInput, representing a slice of an existing open file
FSDirectory.FSIndexOutput - Class in org.apache.lucene.store
FSDirectory.FSIndexOutput(FSDirectory, String) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexOutput
 
FSLockFactory - Class in org.apache.lucene.store
Base class for file system based locking implementation.
FSLockFactory() - Constructor for class org.apache.lucene.store.FSLockFactory
 
FST<T> - Class in org.apache.lucene.util.fst
Represents an finite state machine (FST), using a compact byte[] format.
FST(DataInput, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.FST
Load a previously saved FST.
FST(DataInput, Outputs<T>, int) - Constructor for class org.apache.lucene.util.fst.FST
Load a previously saved FST; maxBlockBits allows you to control the size of the byte[] pages used to hold the FST bytes.
FST.Arc<T> - Class in org.apache.lucene.util.fst
Represents a single arc.
FST.Arc() - Constructor for class org.apache.lucene.util.fst.FST.Arc
 
FST.BytesReader - Class in org.apache.lucene.util.fst
Reads bytes stored in an FST.
FST.BytesReader() - Constructor for class org.apache.lucene.util.fst.FST.BytesReader
 
FST.INPUT_TYPE - Enum in org.apache.lucene.util.fst
Specifies allowed range of each int input label for this FST.
fstSizeInBytes() - Method in class org.apache.lucene.util.fst.Builder
 
fsync(String) - Method in class org.apache.lucene.store.FSDirectory
 
function - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
 
function - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery
 
FuzzyQuery - Class in org.apache.lucene.search
Implements the fuzzy search query.
FuzzyQuery(Term, int, int, int, boolean) - Constructor for class org.apache.lucene.search.FuzzyQuery
Create a new FuzzyQuery that will match terms with an edit distance of at most 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)
FuzzyTermsEnum.LevenshteinAutomataAttributeImpl() - Constructor for class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
 

G

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).
GCD_COMPRESSED - Static variable in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesConsumer
Compressed by computing the GCD.
GEN_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of gen file
generationFromSegmentsFileName(String) - Static method in class org.apache.lucene.index.SegmentInfos
Parse the generation off the segments file name and return it.
get(int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
 
get(int) - Method in class org.apache.lucene.codecs.DocValuesProducer.SortedDocsWithField
 
get(int) - Method in class org.apache.lucene.codecs.DocValuesProducer.SortedSetDocsWithField
 
get(int) - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsReader
 
get(int) - Method in class org.apache.lucene.codecs.TermVectorsReader
Returns term vectors for this document, or null if term vectors were not indexed.
get(String) - Method in class org.apache.lucene.document.Document
Returns the string value of the field with the given name if any exist in this document, or null.
get(int, BytesRef) - Method in class org.apache.lucene.index.BinaryDocValues
Lookup the value for document.
get(int) - Method in class org.apache.lucene.index.MergeState.DocMap
Returns the mapped docID corresponding to the provided one.
get(int) - Method in class org.apache.lucene.index.NumericDocValues
Returns the numeric value for the specified document ID.
get(int, BytesRef) - Method in class org.apache.lucene.index.SortedDocValues
 
get(int) - Method in class org.apache.lucene.index.TermContext
Returns the TermState for an leaf ordinal or null if no TermState for the ordinal was registered.
get() - Static method in class org.apache.lucene.LucenePackage
Return Lucene's package, including version information.
get(int) - Method in class org.apache.lucene.search.FieldCache.Bytes
Return a single Byte representation of this field's value.
get(int) - Method in class org.apache.lucene.search.FieldCache.Doubles
Return an double representation of this field's value.
get(int) - Method in class org.apache.lucene.search.FieldCache.Floats
Return an float representation of this field's value.
get(int) - Method in class org.apache.lucene.search.FieldCache.Ints
Return an integer representation of this field's value.
get(int) - Method in class org.apache.lucene.search.FieldCache.Longs
Return an long representation of this field's value.
get(int) - Method in class org.apache.lucene.search.FieldCache.Shorts
Return a short representation of this field's value.
get(String) - Method in class org.apache.lucene.search.LiveFieldValues
Returns the current value for this id, or null if the id isn't in the index or was deleted.
get(String) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
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(int, BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Populates and returns a BytesRef with the bytes for the given bytesID.
get() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
get() - Method in class org.apache.lucene.util.Counter
Returns the counters current value
get(int) - Method in class org.apache.lucene.util.DocIdBitSet
 
get(K) - Method in class org.apache.lucene.util.DoubleBarrelLRUCache
 
get(int) - Method in class org.apache.lucene.util.FixedBitSet
 
get(FST<T>, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
Looks up the output for this input, or null if the input is not accepted.
get(FST<T>, BytesRef) - Static method in class org.apache.lucene.util.fst.Util
Looks up the output for this input, or null if the input is not accepted
get(long) - Method in class org.apache.lucene.util.LongValues
Get value at index.
get(int) - Method in class org.apache.lucene.util.LongValues
 
get(int) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index.
get(long) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index
get(long) - Method in class org.apache.lucene.util.packed.BlockPackedReader
 
get(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
get(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
get(int) - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
 
get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
 
get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.Reader
Bulk get: read at least one and at most len longs starting from index into arr[off:off+len] and return the actual number of values that have been read.
get() - Method in class org.apache.lucene.util.RefCount
 
get(int) - Method in class org.apache.lucene.util.RollingBuffer
Get T instance for this absolute position; this is allowed to be arbitrarily far "in the future" but cannot be before the last freeBefore.
get() - Method in class org.apache.lucene.util.SetOnce
Returns the object set by SetOnce.set(Object).
get(Class<S>) - Static method in class org.apache.lucene.util.SPIClassIterator
 
get(Class<S>, ClassLoader) - Static method in class org.apache.lucene.util.SPIClassIterator
 
get(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
Returns the value to which the specified key is mapped.
getAcceptStates() - Method in class org.apache.lucene.util.automaton.Automaton
Returns the set of reachable accept states.
getAddressInstance(IndexInput, FieldInfo, Lucene45DocValuesProducer.BinaryEntry) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
returns an address instance for variable-length binary values.
getAfterEffect() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
Returns the first normalization
getAnalyzer() - Method in class org.apache.lucene.index.IndexWriter
Returns the analyzer used by this index.
getAnalyzer() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getAnalyzer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the default analyzer to use for indexing documents.
getAnalyzer() - Method in class org.apache.lucene.util.QueryBuilder
Returns the analyzer.
getAndClear(int) - Method in class org.apache.lucene.util.FixedBitSet
 
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(int) - Method in class org.apache.lucene.util.OpenBitSet
Sets a bit and returns the previous value.
getAndSet(long) - Method in class org.apache.lucene.util.OpenBitSet
Sets a bit and returns the previous value.
getArcCount() - Method in class org.apache.lucene.util.fst.FST
 
getArcWithOutputCount() - Method in class org.apache.lucene.util.fst.FST
 
getArray() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getArray() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
Expert: if the bit-width of this reader matches one of java's native types, returns the underlying array (ie, byte[], short[], int[], long[]); else, returns null.
getAttribute(String) - Method in class org.apache.lucene.index.FieldInfo
Get a codec attribute value, or null if it does not exist
getAttribute(String) - Method in class org.apache.lucene.index.SegmentInfo
Deprecated.
no longer supported
getAttribute(Class<T>) - Method in class org.apache.lucene.util.AttributeSource
The caller must pass in a Class<? extends Attribute> value.
getAttributeClassesIterator() - Method in class org.apache.lucene.util.AttributeSource
Returns a new iterator that iterates the attribute classes in the same order they were added in.
getAttributeFactory() - Method in class org.apache.lucene.util.AttributeSource
returns the used AttributeFactory.
getAttributeImplsIterator() - Method in class org.apache.lucene.util.AttributeSource
Returns a new iterator that iterates all unique Attribute implementations.
getAttributeSource() - Method in class org.apache.lucene.index.FieldInvertState
Returns the AttributeSource from the TokenStream that provided the indexed tokens for this field.
getAutomaton(String) - Method in interface org.apache.lucene.util.automaton.AutomatonProvider
Returns automaton of the given name.
getAutomatonEnum(int, BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
return an automata-based enum for matching up to editDistance from lastTerm, if possible
getAvgFieldLength() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the average field length.
getB() - Method in class org.apache.lucene.search.similarities.BM25Similarity
Returns the 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(FieldInfo) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.AtomicReader
Returns BinaryDocValues for this field, or null if no BinaryDocValues were indexed for this field.
getBinaryDocValues(String) - Method in class org.apache.lucene.index.FilterAtomicReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.SegmentReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getBinaryValue(String) - Method in class org.apache.lucene.document.Document
Returns an array of bytes for the first (or only) field that has the name specified as the method parameter.
getBinaryValues(String) - Method in class org.apache.lucene.document.Document
Returns an array of byte arrays for of the fields that have the name specified as the method parameter.
getBinaryValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a BinaryDocValues for a reader's docvalues (potentially merging on-the-fly)
getBit(int) - Method in class org.apache.lucene.util.OpenBitSet
returns 1 if the bit is set, 0 if not.
getBits() - Method in class org.apache.lucene.util.FixedBitSet
Expert.
getBits() - Method in class org.apache.lucene.util.OpenBitSet
Expert: returns the long[] storing the bits
getBitSet() - Method in class org.apache.lucene.util.DocIdBitSet
Returns the underlying BitSet.
getBitsPerValue() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
 
getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
 
getBitsPerValue() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
Returns number of bits per value
getBoost() - Method in class org.apache.lucene.index.FieldInvertState
Get boost value.
getBoost() - Method in interface org.apache.lucene.search.BoostAttribute
Retrieves the boost, default is 1.0f.
getBoost() - Method in class org.apache.lucene.search.BoostAttributeImpl
 
getBoost() - Method in class org.apache.lucene.search.Query
Gets the boost for this clause.
getBuffer(int) - Method in class org.apache.lucene.store.RAMFile
 
getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexInput
Returns buffer size.
getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexOutput
Returns size of the used output buffer in bytes.
getByOutput(FST<Long>, long) - Static method in class org.apache.lucene.util.fst.Util
Reverse lookup (lookup by output instead of by input), in the special case when your FSTs outputs are strictly ascending.
getByOutput(FST<Long>, long, FST.BytesReader, FST.Arc<Long>, FST.Arc<Long>, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
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
 
getBytes(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
Deprecated.
(4.4) Index as a numeric field using IntField and then use FieldCache.getInts(AtomicReader, String, boolean) instead.
getBytes(AtomicReader, String, FieldCache.ByteParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Deprecated.
(4.4) Index as a numeric field using IntField and then use FieldCache.getInts(AtomicReader, String, boolean) instead.
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.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.
getCacheEntries() - Method in interface org.apache.lucene.search.FieldCache
EXPERT: Generates an array of CacheEntry objects representing all items currently in the FieldCache.
getCacheEntries() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
CacheEntry objects which suggest a problem
getCacheType() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getCalibrateSizeByDeletes() - Method in class org.apache.lucene.index.LogMergePolicy
Returns true if the segment size should be calibrated by the number of deletes when choosing segments for merge.
getCharIntervals() - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns array of codepoint class interval start points.
getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexInput
 
getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
getChildren() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
getChildren() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
getChildren() - Method in class org.apache.lucene.search.Scorer
Returns child sub-scorers
getClauses() - Method in class org.apache.lucene.search.BooleanQuery
Returns the set of clauses in this query.
getClauses() - Method in class org.apache.lucene.search.spans.SpanNearQuery
Return the clauses whose spans are matched.
getClauses() - Method in class org.apache.lucene.search.spans.SpanOrQuery
Return the clauses whose spans are matched.
getCodec() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getCodec() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the current Codec.
getCodec() - Method in class org.apache.lucene.index.SegmentInfo
Return Codec that wrote this segment.
getCollectionProbability() - Method in class org.apache.lucene.search.similarities.LMSimilarity.LMStats
Returns the probability that the current term is generated by the collection.
getCombinedCoreAndDeletesKey() - Method in class org.apache.lucene.index.IndexReader
Expert: Returns a key for this IndexReader that also includes deletions, so FieldCache/CachingWrapperFilter can find it again.
getCombinedCoreAndDeletesKey() - Method in class org.apache.lucene.index.SegmentReader
 
getCombinedCoreAndDeletesKey() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getCommitData() - Method in class org.apache.lucene.index.IndexWriter
Returns the commit user data map that was last committed, or the one that was set on IndexWriter.setCommitData(Map).
getCommonPrefix(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
Returns the longest string that is a prefix of all accepted strings and visits each state at most once.
getCommonPrefixBytesRef(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
 
getCommonSuffix(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
Returns the longest string that is a suffix of all accepted strings and visits each state at most once.
getCommonSuffixBytesRef(Automaton) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
 
getComparator() - Method in class org.apache.lucene.codecs.BlockTreeTermsReader.FieldReader
 
getComparator() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
 
getComparator() - Method in class org.apache.lucene.codecs.lucene40.Lucene40TermVectorsWriter
 
getComparator() - Method in class org.apache.lucene.codecs.TermsConsumer
Return the BytesRef Comparator used to sort terms before feeding to this API.
getComparator() - Method in class org.apache.lucene.codecs.TermVectorsWriter
Return the BytesRef Comparator used to sort terms before feeding to this API.
getComparator() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
 
getComparator() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTermsEnum
 
getComparator() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
getComparator() - Method in class org.apache.lucene.index.MultiTerms
 
getComparator() - Method in class org.apache.lucene.index.MultiTermsEnum
 
getComparator() - Method in class org.apache.lucene.index.Terms
Return the BytesRef Comparator used to sort terms provided by the iterator.
getComparator() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
getComparator(int, int) - Method in class org.apache.lucene.search.SortField
Returns the FieldComparator to use for sorting.
getComparator() - Method in interface org.apache.lucene.util.BytesRefIterator
Return the BytesRef Comparator used to sort terms provided by the iterator.
getComparators() - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getComparatorSource() - Method in class org.apache.lucene.search.SortField
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
 
getConfig() - Method in class org.apache.lucene.index.IndexWriter
Returns a LiveIndexWriterConfig, which can be used to query the IndexWriter current settings, as well as modify "live" ones.
getContext() - Method in class org.apache.lucene.index.AtomicReader
 
getContext() - Method in class org.apache.lucene.index.CompositeReader
 
getContext() - Method in class org.apache.lucene.index.IndexReader
Expert: Returns the root IndexReaderContext for this IndexReader's sub-reader tree.
getCoreCacheKey() - Method in class org.apache.lucene.index.IndexReader
Expert: Returns a key for this IndexReader, so FieldCache/CachingWrapperFilter can find it again.
getCoreCacheKey() - Method in class org.apache.lucene.index.SegmentReader
 
getCoreCacheKey() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getCreatedFiles() - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
getCrossCheckTermVectors() - Method in class org.apache.lucene.index.CheckIndex
getCurrentLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
getCurrentLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
getCurrentMerge() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
Return the current merge, or null if this MergeThread is done.
getCurrentOffset() - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
Returns the offset of the currently written slice.
getCustom() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getDataInput() - Method in class org.apache.lucene.util.PagedBytes
Returns a DataInput to read values from this PagedBytes instance.
getDataOutput() - Method in class org.apache.lucene.util.PagedBytes
Returns a DataOutput that you may use to write into this PagedBytes instance.
getDecodedLength(char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Returns the number of bytes required to decode the given char sequence.
getDecoder() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
Returns an EliasFanoDecoder to access the encoded values.
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(File, Charset) - Static method in class org.apache.lucene.util.IOUtils
Opens a Reader for the given File 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.util.InfoStream
The default InfoStream used by a newly instantiated classes.
getDefaultGenLookahedCount() - Static method in class org.apache.lucene.index.SegmentInfos
Returns the defaultGenLookaheadCount.
getDefaultSimilarity() - Static method in class org.apache.lucene.search.IndexSearcher
Expert: returns a default Similarity instance.
getDefaultWriteLockTimeout() - Static method in class org.apache.lucene.index.IndexWriterConfig
Returns the default write lock timeout for newly instantiated IndexWriterConfigs.
getDelCount() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the number of deleted docs in the segment.
getDelegate() - Method in class org.apache.lucene.store.FilterDirectory
Return the wrapped Directory.
getDelegate() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
getDelGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns generation number of the live docs file or -1 if there are no deletes yet.
getDescription() - Method in class org.apache.lucene.search.Explanation
A description of this explanation node.
getDest() - Method in class org.apache.lucene.util.automaton.Transition
Returns destination of this transition.
getDetails() - Method in class org.apache.lucene.search.Explanation
The sub-nodes of this explanation node.
getDiagnostics() - Method in class org.apache.lucene.index.SegmentInfo
Returns diagnostics saved into the segment when it was written.
getDirectory() - Method in class org.apache.lucene.index.IndexCommit
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.CompoundFileDirectory
 
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.
getDirectReaderNoHeader(IndexInput, PackedInts.Header) - Static method in class org.apache.lucene.util.packed.PackedInts
Expert: Construct a direct PackedInts.Reader from an IndexInput 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.BlockTreeTermsReader.FieldReader
 
getDocCount(String) - Method in class org.apache.lucene.index.AtomicReader
 
getDocCount(String) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getDocCount() - Method in class org.apache.lucene.index.FilterAtomicReader.FilterTerms
 
getDocCount(String) - Method in class org.apache.lucene.index.IndexReader
Returns the number of documents that have at least one term for this field, or -1 if this measure isn't stored by the codec.
getDocCount() - Method in class org.apache.lucene.index.MultiTerms
 
getDocCount() - Method in class org.apache.lucene.index.SegmentInfo
Returns number of documents in this segment (deletions are not taken into account).
getDocCount() - Method in class org.apache.lucene.index.Terms
Returns the number of documents that have at least one term for this field, or -1 if this measure isn't stored by the codec.
getDocFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the document frequency.
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.CachingWrapperFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
This method is implemented for each data type
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
This method is implemented for each data type
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.FieldCacheTermsFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.FieldValueFilter
 
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.Filter
Creates a DocIdSet enumerating the documents that should be permitted in search results.
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Returns a DocIdSet with documents that should be permitted in search results.
getDocIdSet(AtomicReaderContext, Bits) - Method in class org.apache.lucene.search.QueryWrapperFilter
 
getDocMap(MergeState) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Expert: If MergePolicy.OneMerge.getMergeReaders() reorders document IDs, this method must be overridden to return a mapping from the natural doc ID (the doc ID that would result from a natural merge) to the actual doc ID.
getDocStoreFiles(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xCodec
Deprecated.
Returns file names for shared doc stores, if any, else null.
getDocStoreIsCompoundFile(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
 
getDocStoreOffset(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
 
getDocStoreSegment(SegmentInfo) - Static method in class org.apache.lucene.codecs.lucene3x.Lucene3xSegmentInfoFormat
Deprecated.
 
getDocsWithField(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns a Bits at the size of reader.maxDoc(), with turned on bits for each docid that does have a value for this field.
getDocsWithField(FieldInfo) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
 
getDocsWithField(String) - Method in class org.apache.lucene.index.AtomicReader
Returns a Bits at the size of reader.maxDoc(), with turned on bits for each docid that does have a value for this field, or null if no DocValues were indexed for this field.
getDocsWithField(String) - Method in class org.apache.lucene.index.FilterAtomicReader
 
getDocsWithField(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a Bits for a reader's docsWithField (potentially merging on-the-fly)
getDocsWithField(String) - Method in class org.apache.lucene.index.ParallelAtomicReader
 
getDocsWithField(String) - Method in class org.apache.lucene.index.SegmentReader
 
getDocsWithField(String) - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getDocsWithField(AtomicReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field and returns a bit set at the size of reader.maxDoc(), with turned on bits for each docid that does have a value for this field.
getDocTermOrds(AtomicReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the term values in field and returns a DocTermOrds instance, providing a method to retrieve the terms (as ords) per document.
getDocument() - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
Retrieve the visited document.
getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene42.Lucene42Codec
Deprecated.
Returns the docvalues format that should be used for writing new segments of field.
getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene45.Lucene45Codec
Deprecated.
Returns the docvalues format that should be used for writing new segments of field.
getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene46.Lucene46Codec
Returns the docvalues format that should be used for writing new segments of field.
getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
Returns the doc values format that should be used for writing new segments of field.
getDocValuesGen() - Method in class org.apache.lucene.index.FieldInfo
Returns the docValues generation of this field, or -1 if no docValues updates exist for it.
getDocValuesType() - Method in class org.apache.lucene.index.FieldInfo
Returns FieldInfo.DocValuesType of the docValues.
getDoubles(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns a FieldCache.Doubles over the values found in documents in the given field.
getDoubles(AtomicReader, String, FieldCache.DoubleParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns a FieldCache.Doubles over the values found in documents in the given field.
getEliasFanoEncoder() - Method in class org.apache.lucene.util.packed.EliasFanoDecoder
 
getEmptyOutput() - Method in class org.apache.lucene.util.fst.FST
 
getEnablePositionIncrements() - Method in class org.apache.lucene.util.QueryBuilder
Returns true if position increments are enabled.
getEncodedLength(byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Returns the number of chars required to encode the given bytes.
getEncoder(PackedInts.Format, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
getEnd() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
getEstimatedSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
The most recently estimated size of the value, null unless estimateSize has been called.
getExclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
Return the SpanQuery whose matches must not overlap those returned.
getExtension(String) - Static method in class org.apache.lucene.store.FileSwitchDirectory
Utility method to return a file's extension.
getField(String) - Method in class org.apache.lucene.document.Document
Returns a field with the given name if any exist in this document, or null.
getField() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
Returns the field name for this filter
getField() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the field name for this filter
getField() - Method in class org.apache.lucene.search.MultiTermQuery
Returns the field name for this query
getField() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Returns the field name for this query
getField() - Method in class org.apache.lucene.search.SortField
Returns the name of the field.
getField() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
getField() - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanQuery
Returns the name of the field matched by this query.
getField() - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
getFieldCache() - Method in class org.apache.lucene.search.FieldCacheTermsFilter
 
getFieldInfos() - Method in class org.apache.lucene.index.AtomicReader
Get the FieldInfos describing all fields in this reader.
getFieldInfos() - Method in class org.apache.lucene.index.FilterAtomicReader
 
getFieldInfos() - Method in class org.apache.lucene.index.ParallelAtomicReader
Get the FieldInfos describing all fields in this reader.
getFieldInfos() - Method in class org.apache.lucene.index.SegmentReader
 
getFieldInfos() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getFieldInfosGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the generation number of the field infos file or -1 if there are no field updates yet.
getFieldInfosReader() - Method in class org.apache.lucene.codecs.FieldInfosFormat
Returns a FieldInfosReader to read field infos from the index
getFieldInfosReader() - Method in class org.apache.lucene.codecs.lucene40.Lucene40FieldInfosFormat
Deprecated.
 
getFieldInfosReader() - Method in class org.apache.lucene.codecs.lucene42.Lucene42FieldInfosFormat
Deprecated.
 
getFieldInfosReader() - Method in class org.apache.lucene.codecs.lucene46.Lucene46FieldInfosFormat
 
getFieldInfosWriter() - Method in class org.apache.lucene.codecs.FieldInfosFormat
Returns a FieldInfosWriter to write field infos to the index
getFieldInfosWriter() - Method in class org.apache.lucene.codecs.lucene40.Lucene40FieldInfosFormat
Deprecated.
 
getFieldInfosWriter() - Method in class org.apache.lucene.codecs.lucene42.Lucene42FieldInfosFormat
Deprecated.
 
getFieldInfosWriter() - Method in class org.apache.lucene.codecs.lucene46.Lucene46FieldInfosFormat
 
getFieldName() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getFields(String) - Method in class org.apache.lucene.document.Document
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.SegmentReader
Expert: retrieve thread-private StoredFieldsReader
getFileNames() - Method in class org.apache.lucene.index.IndexCommit
Returns all index files referenced by this commit point.
getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexOutput
 
getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
getFilePointer() - Method in class org.apache.lucene.store.IndexInput
Returns the current position in this file, where the next read will occur.
getFilePointer() - Method in class org.apache.lucene.store.IndexOutput
Returns the current position in this file, where the next write will occur.
getFilePointer() - Method in class org.apache.lucene.store.RAMInputStream
 
getFilePointer() - Method in class org.apache.lucene.store.RAMOutputStream
 
getFilter() - Method in class org.apache.lucene.search.CachingWrapperFilter
Gets the contained filter.
getFilter() - Method in class org.apache.lucene.search.ConstantScoreQuery
Returns the encapsulated filter, returns null if a query is wrapped.
getFilter() - Method in class org.apache.lucene.search.FilteredQuery
Returns this FilteredQuery's filter
getFilterStrategy() - Method in class org.apache.lucene.search.FilteredQuery
Returns this FilteredQuery's FilteredQuery.FilterStrategy
getFiniteStrings(Automaton, int) - Static method in class org.apache.lucene.util.automaton.SpecialOperations
Returns the set of accepted strings, assuming that at most limit strings are accepted.
getFirstArc(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST
Fills virtual 'start' arc, ie, an empty incoming arc to the FST's start node
getFirstSegmentNumber(long) - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
Given a global ordinal, returns the index of the first segment that contains this term.
getFirstSegmentOrd(long) - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
Given global ordinal, returns the ordinal of the first segment which contains this ordinal (the corresponding to the segment return MultiDocValues.OrdinalMap.getFirstSegmentNumber(long)).
getFirstState() - Method in class org.apache.lucene.util.automaton.StatePair
Returns first component of this pair.
getFlags() - Method in class org.apache.lucene.analysis.Token
Get the bitset for any bits that have been set.
getFlags() - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute
Get the bitset for any bits that have been set.
getFlags() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
getFloats(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns a FieldCache.Floats over the values found in documents in the given field.
getFloats(AtomicReader, String, FieldCache.FloatParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns a FieldCache.Floats over the values found in documents in the given field.
getFloorSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current floorSegmentMB.
getForceMergeDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current forceMergeDeletesPctAllowed setting.
getFormat() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
The format used to serialize values.
getFreqPointer() - Method in class org.apache.lucene.codecs.lucene40.Lucene40SkipListReader
Deprecated.
Returns the freq pointer of the doc to which the last call of MultiLevelSkipListReader.skipTo(int) has skipped.
getGeneration() - Method in class org.apache.lucene.index.IndexCommit
Returns the generation (the _N in segments_N) for this IndexCommit
getGeneration() - Method in class org.apache.lucene.index.SegmentInfos
Returns current generation.
getGeneration() - Method in class org.apache.lucene.index.TrackingIndexWriter
Return the current generation being indexed.
getGlobalCounter() - Static method in class org.apache.lucene.search.TimeLimitingCollector
Returns the global TimerThreads Counter
getGlobalOrd(int, long) - Method in class org.apache.lucene.index.MultiDocValues.OrdinalMap
Given a segment number and segment ordinal, returns the corresponding global ordinal.
getGlobalTimerThread() - Static method in class org.apache.lucene.search.TimeLimitingCollector
getHeapArray() - Method in class org.apache.lucene.util.PriorityQueue
This method returns the internal heap array as Object[].
getId() - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the ID of the format.
getIdentifiers() - Method in class org.apache.lucene.util.automaton.RegExp
Returns set of automaton identifiers that occur in this regular expression.
getImplementationDistance(Class<? extends C>) - Method in class org.apache.lucene.util.VirtualMethod
Returns the distance from the 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.
getIndexBits() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
Expert.
getIndexCommit() - Method in class org.apache.lucene.index.DirectoryReader
Expert: return the IndexCommit that this reader has opened.
getIndexCommit() - Method in class org.apache.lucene.index.FilterDirectoryReader
 
getIndexCommit() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getIndexCommit() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
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 null 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.
getInfo() - Method in class org.apache.lucene.util.automaton.Automaton
Returns extra information associated with this automaton.
getInfoStream() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getInfoStream() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns InfoStream used for debugging.
getInfoStream() - Static method in class org.apache.lucene.index.SegmentInfos
Returns infoStream.
getInfoStream() - Method in interface org.apache.lucene.search.FieldCache
getInitialState() - Method in class org.apache.lucene.util.automaton.Automaton
Gets initial state.
getInitialState() - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns initial state.
getInputType() - Method in class org.apache.lucene.util.fst.FST
 
getIntBlock() - Method in class org.apache.lucene.util.IntBlockPool.Allocator
 
getIntBlock() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
getIntervalInstance(IndexInput, FieldInfo, Lucene45DocValuesProducer.BinaryEntry) - Method in class org.apache.lucene.codecs.lucene45.Lucene45DocValuesProducer
returns an address instance for prefix-compressed binary values.
getInts(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns an FieldCache.Ints over the values found in documents in the given field.
getInts(AtomicReader, String, FieldCache.IntParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns an FieldCache.Ints over the values found in documents in the given field.
getK1() - Method in class org.apache.lucene.search.similarities.BM25Similarity
Returns the 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.
getLength() - Method in class org.apache.lucene.index.FieldInvertState
Get total number of terms in this field.
getLength() - Method in class org.apache.lucene.store.RAMFile
 
getLiveDocs() - Method in class org.apache.lucene.index.AtomicReader
Returns the Bits representing live (not deleted) docs.
getLiveDocs() - Method in class org.apache.lucene.index.FilterAtomicReader
 
getLiveDocs(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
Returns a single Bits instance for this reader, merging live Documents on the fly.
getLiveDocs() - Method in class org.apache.lucene.index.ParallelAtomicReader
 
getLiveDocs() - Method in class org.apache.lucene.index.SegmentReader
 
getLiveDocs() - Method in class org.apache.lucene.index.SlowCompositeReaderWrapper
 
getLockDir() - Method in class org.apache.lucene.store.FSLockFactory
Retrieve the lock directory.
getLockFactory() - Method in class org.apache.lucene.store.BaseDirectory
 
getLockFactory() - Method in class org.apache.lucene.store.Directory
Get the LockFactory that this Directory instance is using for its locking implementation.
getLockFactory() - Method in class org.apache.lucene.store.FilterDirectory
 
getLockFactory() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
getLockID() - Method in class org.apache.lucene.store.Directory
Return a string identifier that uniquely differentiates this Directory instance from other Directory instances.
getLockID() - Method in class org.apache.lucene.store.FSDirectory
 
getLockID() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
getLockPrefix() - Method in class org.apache.lucene.store.LockFactory
Get the prefix in use for all locks created in this LockFactory.
getLongs(AtomicReader, String, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns a FieldCache.Longs over the values found in documents in the given field.
getLongs(AtomicReader, String, FieldCache.LongParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Returns a FieldCache.Longs over the values found in documents in the given field.
getLowerBits() - Method in class org.apache.lucene.util.packed.EliasFanoEncoder
Expert.
getLowerTerm() - Method in class org.apache.lucene.search.TermRangeFilter
Returns the lower value of this range filter
getLowerTerm() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the lower value of this range query
getLowerVal() - Method in class org.apache.lucene.search.DocTermOrdsRangeFilter
Returns the lower value of this range filter
getLowerVal() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the lower value of this range filter
getMap() - Method in class org.apache.lucene.util.MapOfSets
 
getMappedStateCount() - Method in class org.apache.lucene.util.fst.Builder
 
getMaskedQuery() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
getMatch() - Method in class org.apache.lucene.search.ComplexExplanation
The match status of this explanation node.
getMatch() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
getMatchArray() - Method in class org.apache.lucene.index.MultiTermsEnum
Returns sub-reader slices positioned to the current term.
getMatchCount() - Method in class org.apache.lucene.index.MultiTermsEnum
Returns how many sub-reader slices contain the current term.
getMax() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns the upper value of this range filter
getMax() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns the upper value of this range query
getMax() - Method in class org.apache.lucene.util.automaton.Transition
Returns maximum of this transition interval.
getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the number of buffered deleted terms that will trigger a flush of all buffered deletes if enabled.
getMaxBufferedDocs() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMaxBufferedDocs() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the number of buffered added documents that will trigger a flush if enabled.
getMaxCFSSegmentSizeMB() - Method in class org.apache.lucene.index.MergePolicy
Returns the largest size allowed for a compound file segment
getMaxChunkSize() - Method in class org.apache.lucene.store.MMapDirectory
Returns the current mmap chunk size.
getMaxClauseCount() - Static method in class org.apache.lucene.search.BooleanQuery
Return the maximum number of clauses permitted, 1024 by default.
getMaxEdits() - Method in class org.apache.lucene.search.FuzzyQuery
 
getMaxMergeAtOnce() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current maxMergeAtOnce setting.
getMaxMergeAtOnceExplicit() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current maxMergeAtOnceExplicit setting.
getMaxMergeCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
getMaxMergeDocs() - Method in class org.apache.lucene.index.LogMergePolicy
Returns the largest segment (measured by document count) that may be merged with other segments.
getMaxMergedSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current maxMergedSegmentMB setting.
getMaxMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
Returns the largest segment (measured by total byte size of the segment's files, in MB) that may be merged with other segments.
getMaxMergeMBForForcedMerge() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
Returns the largest segment (measured by total byte size of the segment's files, in MB) that may be merged with other segments during forceMerge.
getMaxNonCompetitiveBoost() - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
This is the maximum boost that would not be competitive.
getMaxNonCompetitiveBoost() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
getMaxPos() - Method in class org.apache.lucene.util.RollingBuffer
Returns the maximum position looked up, or -1 if no position has been looked up sinc reset/init.
getMaxScore() - Method in class org.apache.lucene.search.TopDocs
Returns the maximum score value encountered.
getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
getMaxSize() - Method in class org.apache.lucene.search.TopTermsRewrite
return the maximum size of the priority queue (for boolean rewrites this is BooleanQuery#getMaxClauseCount).
getMaxTermFrequency() - Method in class org.apache.lucene.index.FieldInvertState
Get the maximum term-frequency encountered for any term in the field.
getMaxThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns maxThreadCount.
getMaxThreadStates() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMaxThreadStates() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the max number of simultaneous threads that may be indexing documents at once in IndexWriter.
getMaxWriteMBPerSec(IOContext.Context) - Method in class org.apache.lucene.store.RateLimitedDirectoryWrapper
getMbPerSec() - Method in class org.apache.lucene.store.RateLimiter
The current mb per second rate limit.
getMbPerSec() - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
The current mb per second rate limit.
getMergedFieldInfos(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
Call this to get the (merged) FieldInfos for a composite reader.
getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMergedSegmentWarmer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the current merged segment warmer.
getMergeFactor() - Method in class org.apache.lucene.index.LogMergePolicy
Returns the number of segments that are merged at once and also controls the total number of segments allowed to accumulate in the index.
getMergeInfo() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Return MergeInfo describing this merge.
getMergePolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMergePolicy() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the current MergePolicy in use by this writer.
getMergeReaders() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Expert: Get the list of readers to merge.
getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMergeScheduler() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Create and return a new MergeThread
getMergeThreadPriority() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Return the priority that merge threads run at.
getMergingSegments() - Method in class org.apache.lucene.index.IndexWriter
Expert: to be used by a MergePolicy to avoid selecting merges for segments already being merged.
getMilliseconds() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Get the timer value in milliseconds.
getMin() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns the lower value of this range filter
getMin() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns the lower value of this range query
getMin() - Method in class org.apache.lucene.util.automaton.Transition
Returns minimum of this transition interval.
getMinimumNumberShouldMatch() - Method in class org.apache.lucene.search.BooleanQuery
Gets the minimum number of the optional BooleanClauses which must be satisfied.
getMinMergeDocs() - Method in class org.apache.lucene.index.LogDocMergePolicy
Get the minimum size for a segment to remain un-merged.
getMinMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
Get the minimum size for a segment to remain un-merged.
getMinSimilarity() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
getMsg() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
Description of hte insane behavior
getMu() - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
Returns the μ parameter.
getMu() - Method in class org.apache.lucene.search.similarities.NormalizationH3
Returns the parameter μ
getMutable() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getMutable(int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
Create a packed integer array with the given amount of values initialized to 0.
getMutable(int, int, PackedInts.Format) - Static method in class org.apache.lucene.util.packed.PackedInts
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