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

A

ab - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
represent if edge ab belongs to original shape
abort() - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
Abort the merge this progress tracks at the next possible moment.
ABSOLUTE_MIN_SORT_BUFFER_SIZE - Static variable in class org.apache.lucene.util.OfflineSorter
Absolute minimum required buffer size for sorting.
AbstractAnalysisFactory - Class in org.apache.lucene.analysis
Abstract parent class for analysis factories TokenizerFactory, TokenFilterFactory and CharFilterFactory.
AbstractAnalysisFactory() - Constructor for class org.apache.lucene.analysis.AbstractAnalysisFactory
This default ctor is required to be implemented by all subclasses because of service loader (SPI) specification, but it is never called by Lucene.
AbstractAnalysisFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.AbstractAnalysisFactory
Initialize this factory via a set of key-value pairs.
AbstractIterator() - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap.AbstractIterator
 
AbstractKnnCollector - Class in org.apache.lucene.search
AbstractKnnCollector is the default implementation for a knn collector used for gathering kNN results and providing topDocs from the gathered neighbors
AbstractKnnCollector(int, long) - Constructor for class org.apache.lucene.search.AbstractKnnCollector
 
AbstractPagedMutable<T extends AbstractPagedMutable<T>> - Class in org.apache.lucene.util.packed
Base implementation for PagedMutable and PagedGrowableWriter.
AbstractRandomVectorScorer(RandomAccessVectorValues<T>) - Constructor for class org.apache.lucene.util.hnsw.RandomVectorScorer.AbstractRandomVectorScorer
Creates a new scorer for the given vector values.
accept() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
Override this method and return if the current input token should be returned by FilteringTokenFilter.incrementToken().
accept() - Method in class org.apache.lucene.analysis.StopFilter
Returns the next input Token whose term() is not a stop word.
accept(int) - Method in interface org.apache.lucene.search.CheckedIntConsumer
Process the given value.
accept(BytesRef) - Method in class org.apache.lucene.index.AutomatonTermsEnum
Returns true if the term matches the automaton.
accept(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
Return if term is accepted, not accepted or the iteration should ended (and possibly seek).
accept(BytesRef) - Method in class org.apache.lucene.index.SingleTermsEnum
 
accept(T) - Method in interface org.apache.lucene.util.IOConsumer
Performs this operation on the given argument.
accept(T) - Method in interface org.apache.lucene.util.IOUtils.IOConsumer
Deprecated.
Performs this operation on the given argument.
acceptField(String) - Method in class org.apache.lucene.search.QueryVisitor
Whether or not this field is of interest to the visitor
acceptPartialPath(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
Override this to prevent considering a path before it's complete
acceptResult(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
acceptResult(IntsRef, T) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
Accountable - Interface in org.apache.lucene.util
An object whose RAM usage can be computed.
Accountables - Class in org.apache.lucene.util
Helper methods for constructing nested resource descriptions and debugging RAM usage.
accumulateStatistics(int, long) - Method in class org.apache.lucene.index.TermStates
Expert: Accumulate term statistics.
acosh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic cosine of a double value.
acquire() - Method in class org.apache.lucene.search.ReferenceManager
Obtain the current reference.
acquire(long) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Retrieve a previously recorded IndexSearcher, if it has not yet been closed
actualTerm - Variable in class org.apache.lucene.index.FilteredTermsEnum
Which term the enum is currently positioned to.
add(byte[], int) - Method in class org.apache.lucene.util.bkd.BKDWriter
 
add(char[]) - Method in class org.apache.lucene.analysis.CharArraySet
Add this char[] directly to the set.
add(float[], float[]) - Static method in class org.apache.lucene.util.VectorUtil
Adds the second argument to the first
add(int) - Method in class org.apache.lucene.index.DocsWithFieldSet
Add a document to the set
add(int) - Method in class org.apache.lucene.util.DocIdSetBuilder.BulkAdder
 
add(int) - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
Add a new item to this ring buffer, potentially removing the oldest entry from this buffer if it is already full.
add(int) - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
Add a new doc-id to this builder.
add(int, float) - Method in class org.apache.lucene.util.hnsw.NeighborQueue
Adds a new graph arc, extending the storage as needed.
add(int, int, byte[], byte[], byte[]) - Static method in class org.apache.lucene.util.NumericUtils
Result = a + b, where a and b are unsigned.
add(int, long) - Method in class org.apache.lucene.codecs.CompetitiveImpactAccumulator
Accumulate a (freq,norm) pair, updating this structure if there is no equivalent or more competitive entry already.
add(long) - Method in class org.apache.lucene.util.packed.DirectMonotonicWriter
Write a new value.
add(long) - Method in class org.apache.lucene.util.packed.DirectWriter
Adds a value to this writer
add(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
 
add(long) - Method in class org.apache.lucene.util.packed.PackedInts.Writer
Add a value to the stream.
add(long) - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
Add a new element to this builder.
add(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
Add this CharSequence into the set
add(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
add(Object) - Method in class org.apache.lucene.analysis.CharArraySet
 
add(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
add(String) - Method in class org.apache.lucene.analysis.CharArraySet
Add this String into the set
add(String, BooleanQuery.Builder, List<QueryBuilder.TermAndBoost>, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
 
add(String, BytesRef) - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
add a term.
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(FieldInfo) - Method in interface org.apache.lucene.internal.tests.IndexPackageAccess.FieldInfosBuilder
 
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(Term) - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
add a term
add(Term) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Add a new Term to this builder, with a default boost of 1.
add(Term) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
Add a single term at the next position in the phrase.
add(Term) - Method in class org.apache.lucene.search.PhraseQuery.Builder
Adds a term to the end of the query phrase.
add(Term[]) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
Add multiple terms at the next position in the phrase.
add(Term[], int) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
Allows to specify the relative position of terms within the phrase.
add(Term, float) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Add a Term with the provided boost.
add(Term, float, TermStates) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Expert: Add a Term with the provided boost and context.
add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery.Builder
Adds a term to the end of the query phrase.
add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery.Builder
Add a new clause to this BooleanQuery.Builder.
add(DisiWrapper) - Method in class org.apache.lucene.search.DisiPriorityQueue
 
add(DocIdSetIterator) - Method in class org.apache.lucene.util.DocIdSetBuilder
Add the content of the provided DocIdSetIterator to this builder.
add(DocIdSetIterator) - Method in class org.apache.lucene.util.DocIdSetBuilder.BulkAdder
 
add(DocIdSetIterator) - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
Add the content of the provided DocIdSetIterator.
add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery.Builder
Add a new clause to this BooleanQuery.Builder.
add(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef
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(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
add(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
add(IntsRef, T) - Method in class org.apache.lucene.util.fst.FSTCompiler
Add the next input/output pair.
add(T) - Method in class org.apache.lucene.search.Multiset
 
add(T) - Method in class org.apache.lucene.util.PriorityQueue
Adds an Object to a PriorityQueue in log(size) time.
add(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg add("foo", "bar") -> "foobar"
ADD_INDEXES - org.apache.lucene.index.MergeTrigger
Merge was triggered by an IndexWriter.addIndexes(CodecReader...) operation
addAll(Iterable<SegmentCommitInfo>) - Method in class org.apache.lucene.index.SegmentInfos
Appends the provided SegmentCommitInfos.
addAll(Collection<T>) - Method in class org.apache.lucene.util.PriorityQueue
Adds all elements of the collection into the queue.
addAll(CompetitiveImpactAccumulator) - Method in class org.apache.lucene.codecs.CompetitiveImpactAccumulator
Merge acc into this.
addAll(DisiWrapper[], int, int) - Method in class org.apache.lucene.search.DisiPriorityQueue
 
addAllDocVectors(Fields, MergeState) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Safe (but, slowish) default method to write every vector field in the document.
addAndEnsureDiversity(int, float, int, RandomVectorScorerSupplier) - Method in class org.apache.lucene.util.hnsw.NeighborArray
In addition to NeighborArray.addOutOfOrder(int, float), this function will also remove the least-diverse node if the node array is full after insertion
addAndGet(long) - Method in class org.apache.lucene.util.Counter
Adds the given delta to the counters current value
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, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes binary docvalues for a field.
addByPoolOffset(int) - Method in class org.apache.lucene.util.BytesRefHash
Adds a "arbitrary" int offset instead of a BytesRef term.
addBytesRef(BytesRef) - Method in class org.apache.lucene.util.BytesRefBlockPool
Add a term returning the start position on the underlying ByteBlockPool.
addClause(BlendedTermQuery.Builder, Term, int, float, TermStates) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
 
addClause(BooleanQuery.Builder, Term, int, float, TermStates) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
addClause(BooleanQuery.Builder, Term, int, float, TermStates) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
addClosedListener(IndexReader.ClosedListener) - Method in class org.apache.lucene.index.FilterDirectoryReader.DelegatingCacheHelper
 
addClosedListener(IndexReader.ClosedListener) - Method in interface org.apache.lucene.index.IndexReader.CacheHelper
Add a IndexReader.ClosedListener which will be called when the resource guarded by IndexReader.CacheHelper.getKey() is closed.
addDiagnostics(Map<String, String>) - Method in class org.apache.lucene.index.SegmentInfo
Adds or modifies this segment's diagnostics.
addDocument(Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index.
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.
addEpsilon(int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Add a [virtual] epsilon transition between source and dest.
addEpsilon(int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Add a [virtual] epsilon transition between source and dest.
addField(FieldInfo) - Method in class org.apache.lucene.codecs.BufferingKnnVectorsWriter
 
addField(FieldInfo) - Method in class org.apache.lucene.codecs.KnnVectorsWriter
Add new field for indexing
addField(FieldInfo) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsWriter
 
addField(FieldInfo, KnnFieldVectorsWriter<?>) - Method in class org.apache.lucene.codecs.FlatVectorsWriter
Add a new field for indexing, allowing the user to provide a writer that the flat vectors writer can delegate to if additional indexing logic is required.
addField(FieldInfo, KnnFieldVectorsWriter<?>) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
addField(FieldInfo, KnnFieldVectorsWriter<?>) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
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.
addGraphNode(int) - Method in interface org.apache.lucene.util.hnsw.HnswBuilder
Inserts a doc with vector value to the graph
addGraphNode(int) - Method in class org.apache.lucene.util.hnsw.HnswConcurrentMergeBuilder
 
addGraphNode(int) - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
addGraphNode(int) - Method in class org.apache.lucene.util.hnsw.InitializedHnswGraphBuilder
 
addIfCompetitive(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
addIndexes(CodecReader...) - Method in class org.apache.lucene.index.IndexWriter
Merges the provided indexes into this index.
addIndexes(Directory...) - Method in class org.apache.lucene.index.IndexWriter
Adds all segments from an array of indexes into this index.
addIndexesReaderMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.IndexWriter
Runs a single merge operation for IndexWriter.addIndexes(CodecReader...).
addInOrder(int, float) - Method in class org.apache.lucene.util.hnsw.NeighborArray
Add a new node to the NeighborArray.
addIterator(DocIdSetIterator, List<DocIdSetIterator>, List<TwoPhaseIterator>) - Static method in class org.apache.lucene.search.ConjunctionUtils
Given a DocIdSetIterator, find any sub-iterators or two-phase iterators and add them to the provided DocIdSetIterator and TwoPhaseIterator lists
addListener(ReferenceManager.RefreshListener) - Method in class org.apache.lucene.search.ReferenceManager
Adds a listener, to be notified when a reference is refreshed/swapped.
addNode(int, int) - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
Add node on the given level.
addNormsField(FieldInfo, NormsProducer) - Method in class org.apache.lucene.codecs.NormsConsumer
Writes normalization values for a field.
addNumericField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes numeric docvalues for a field.
addOutOfOrder(int, float) - Method in class org.apache.lucene.util.hnsw.NeighborArray
Add node and newScore but do not insert as sorted
addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Adds a term position and offsets
addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Add a new position and payload, and start/end offset.
addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called by IndexWriter when writing new segments.
addReader(KnnVectorsReader, MergeState.DocMap, Bits) - Method in interface org.apache.lucene.util.hnsw.HnswGraphMerger
Adds a reader to the graph merger to record the state
addReader(KnnVectorsReader, MergeState.DocMap, Bits) - Method in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
Adds a reader to the graph merger if it meets the following criteria: 1.
addSortedField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted binary docvalues for a field.
addSortedNumericField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted numeric docvalues for a field
addSortedSetField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Writes pre-sorted set docvalues for a field
addStartPaths(FST.Arc<T>, T, boolean, IntsRefBuilder) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
addStartPaths(FST.Arc<T>, T, boolean, IntsRefBuilder, float, CharSequence, int) - 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.
addTerm(Term) - Method in class org.apache.lucene.search.SynonymQuery.Builder
Adds the provided term as a synonym.
addTerm(Term, float) - Method in class org.apache.lucene.search.SynonymQuery.Builder
Adds the provided term as a synonym, document frequencies of this term will be boosted by boost.
addTerm(BytesRef, float) - Method in class org.apache.lucene.search.SynonymQuery.Builder
Adds the provided term as a synonym, document frequencies of this term will be boosted by boost.
addTo(int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Adds incrementValue to any existing value for the given key or inserts incrementValue if key did not previously exist.
addTransition(int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Add a new transition with min = max = label.
addTransition(int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Add a new transition with min = max = label.
addTransition(int, int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Add a new transition with the specified source, dest, min, max.
addTransition(int, int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Add a new transition with the specified source, dest, min, max.
addTwoPhaseIterator(TwoPhaseIterator, List<DocIdSetIterator>, List<TwoPhaseIterator>) - Static method in class org.apache.lucene.search.ConjunctionUtils
Given a two-phase iterator, find any sub-iterators and add them to the provided DocIdSetIterator and TwoPhaseIterator lists
addValue(int, T) - Method in class org.apache.lucene.codecs.KnnFieldVectorsWriter
Add new docID with its vector value to the given field for indexing.
addVectors(int, int) - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder
add vectors in range [minOrd, maxOrd)
adjustForField(long, Field) - Static method in class org.apache.lucene.util.RamUsageEstimator
This method returns the maximum representation size of an object.
advance(int) - Method in class org.apache.lucene.codecs.lucene90.IndexedDISI
 
advance(int) - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues.DenseOffHeapVectorValues
 
advance(int) - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues.DenseOffHeapVectorValues
 
advance(int) - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues
 
advance(int) - Method in class org.apache.lucene.document.BinaryRangeDocValues
 
advance(int) - Method in class org.apache.lucene.index.FilterBinaryDocValues
 
advance(int) - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
advance(int) - Method in class org.apache.lucene.index.FilterNumericDocValues
 
advance(int) - Method in class org.apache.lucene.index.FilterSortedDocValues
 
advance(int) - Method in class org.apache.lucene.index.FilterSortedNumericDocValues
 
advance(int) - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
advance(int) - Method in class org.apache.lucene.index.FilterVectorValues
 
advance(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
advance(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
advance(int) - Method in class org.apache.lucene.index.MultiPostingsEnum
 
advance(int) - Method in class org.apache.lucene.index.SlowImpactsEnum
 
advance(int) - Method in class org.apache.lucene.search.comparators.MinDocIterator
 
advance(int) - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
advance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
Advances to the first beyond the current whose document number is greater than or equal to target, and returns the document number itself.
advance(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
advance(int) - Method in class org.apache.lucene.search.ImpactsDISI
 
advance(int) - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
advance(int) - Method in class org.apache.lucene.util.BitSetIterator
 
advance(int) - Method in class org.apache.lucene.util.DocBaseBitSetIterator
 
advanceExact(int) - Method in class org.apache.lucene.codecs.lucene90.IndexedDISI
 
advanceExact(int) - Method in class org.apache.lucene.document.BinaryRangeDocValues
 
advanceExact(int) - Method in class org.apache.lucene.index.FilterBinaryDocValues
 
advanceExact(int) - Method in class org.apache.lucene.index.FilterNumericDocValues
 
advanceExact(int) - Method in class org.apache.lucene.index.FilterSortedDocValues
 
advanceExact(int) - Method in class org.apache.lucene.index.FilterSortedNumericDocValues
 
advanceExact(int) - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
advanceExact(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
advanceExact(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
advanceExact(int) - Method in class org.apache.lucene.search.DoubleValues
Advance this instance to the given document id
advanceExact(int) - Method in class org.apache.lucene.search.LongValues
Advance this instance to the given document id
advanceSegmentInfosVersion(long) - Method in class org.apache.lucene.index.IndexWriter
If SegmentInfos.getVersion() is below newVersion then update it to this value.
advanceShallow(int) - Method in interface org.apache.lucene.index.ImpactsSource
Shallow-advance to target.
advanceShallow(int) - Method in class org.apache.lucene.index.SlowImpactsEnum
 
advanceShallow(int) - Method in class org.apache.lucene.search.MaxScoreCache
Implement the contract of Scorer.advanceShallow(int) based on the wrapped ImpactsSource.
advanceShallow(int) - Method in class org.apache.lucene.search.Scorer
Advance to the block of documents that contains target in order to get scoring information about this block.
advanceShallow(int) - Method in class org.apache.lucene.search.TermScorer
 
afterClose() - Method in class org.apache.lucene.search.ReferenceManager
Called after close(), so subclass can free any resources.
afterEffect - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
The first normalization of the information content.
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.
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.
alignFilePointer(int) - Method in class org.apache.lucene.store.IndexOutput
Aligns the current file pointer to multiples of alignmentBytes bytes to improve reads with mmap.
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.
alignOffset(long, int) - Static method in class org.apache.lucene.store.IndexOutput
Aligns the given offset to multiples of alignmentBytes bytes by rounding up.
all(int) - Static method in class org.apache.lucene.search.DocIdSet
A DocIdSet that matches all doc ids up to a specified doc (exclusive).
all(int) - Static method in class org.apache.lucene.search.DocIdSetIterator
A DocIdSetIterator that matches all documents up to maxDoc - 1.
ALL - org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Automaton that accepts all possible strings.
ALL - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) to get positions, payloads and offsets in the returned enum
ALL - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables all optional regexp syntax.
ALL_FILES - Static variable in class org.apache.lucene.store.MMapDirectory
Argument for MMapDirectory.setPreload(BiPredicate) that configures all files to be preloaded upon opening them.
allocate(int) - Method in class org.apache.lucene.store.ByteBuffersDataOutput.ByteBufferRecycler
 
ALLOCATE_BB_ON_HEAP - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
 
allocateBuffers(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Allocate new internal buffers.
allocateThenInsertThenRehash(int, int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
This method is invoked when there is a new key/ value pair to be inserted into the buffers but there is not enough empty slots to do so.
Allocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.Allocator
 
Allocator(int) - Constructor for class org.apache.lucene.util.IntBlockPool.Allocator
 
allowFixedLengthArcs(boolean) - Method in class org.apache.lucene.util.fst.FSTCompiler.Builder
Pass false to disable the fixed length arc optimization (binary search or direct addressing) while building the FST; this will make the resulting FST smaller but slower to traverse.
ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Alpha/numeric token type
AlreadyClosedException - Exception in org.apache.lucene.store
This exception is thrown when there is an attempt to access something that has already been closed.
AlreadyClosedException(String) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
 
AlreadyClosedException(String, Throwable) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
 
AlreadySetException() - Constructor for exception org.apache.lucene.util.SetOnce.AlreadySetException
 
AnalysisSPILoader<S extends AbstractAnalysisFactory> - Class in org.apache.lucene.analysis
Helper class for loading named SPIs from classpath (e.g.
AnalysisSPILoader(Class<S>) - Constructor for class org.apache.lucene.analysis.AnalysisSPILoader
 
AnalysisSPILoader(Class<S>, ClassLoader) - Constructor for class org.apache.lucene.analysis.AnalysisSPILoader
 
analyzeBoolean(String, TokenStream) - Method in class org.apache.lucene.util.QueryBuilder
Creates simple boolean query from the cached tokenstream contents
analyzeGraphBoolean(String, TokenStream, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
Creates a boolean query from a graph token stream.
analyzeGraphPhrase(TokenStream, String, int) - Method in class org.apache.lucene.util.QueryBuilder
Creates graph phrase query from the tokenstream contents
analyzeMultiBoolean(String, TokenStream, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
Creates complex boolean query from the cached tokenstream contents
analyzeMultiPhrase(String, TokenStream, int) - Method in class org.apache.lucene.util.QueryBuilder
Creates complex phrase query from the cached tokenstream contents
analyzePhrase(String, TokenStream, int) - Method in class org.apache.lucene.util.QueryBuilder
Creates simple phrase query from the cached tokenstream contents
analyzer - Variable in class org.apache.lucene.util.QueryBuilder
 
Analyzer - Class in org.apache.lucene.analysis
An Analyzer builds TokenStreams, which analyze text.
Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
Create a new Analyzer, reusing the same set of components per-thread across calls to Analyzer.tokenStream(String, Reader).
Analyzer(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.Analyzer
Expert: create a new Analyzer with a custom Analyzer.ReuseStrategy.
Analyzer.ReuseStrategy - Class in org.apache.lucene.analysis
Strategy defining how TokenStreamComponents are reused per call to Analyzer.tokenStream(String, java.io.Reader).
Analyzer.TokenStreamComponents - Class in org.apache.lucene.analysis
This class encapsulates the outer components of a token stream.
AnalyzerWrapper - Class in org.apache.lucene.analysis
Extension to Analyzer suitable for Analyzers which wrap other Analyzers.
AnalyzerWrapper(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.AnalyzerWrapper
Creates a new AnalyzerWrapper with the given reuse strategy.
analyzeTerm(String, TokenStream) - Method in class org.apache.lucene.util.QueryBuilder
Creates simple term query from the cached tokenstream contents
and(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND other
and(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
this = this AND other
andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
 
andNot(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND NOT other
andNot(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
this = this AND NOT other
andNotCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
Returns the popcount or cardinality of "a and not b" or "intersection(a, not(b))".
ANYSTRING - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables anystring (@).
append(byte) - Method in class org.apache.lucene.util.BytesRefBuilder
Append a single byte to this builder.
append(byte[]) - Method in class org.apache.lucene.util.ByteBlockPool
Append the provided byte array at the current position.
append(byte[], int) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
 
append(byte[], int) - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
append(byte[], int) - Method in interface org.apache.lucene.util.bkd.PointWriter
Add a new point from the packed value and docId
append(byte[], int, int) - Method in class org.apache.lucene.util.ByteBlockPool
Append some portion of the provided byte array at the current position.
append(byte[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Append the provided bytes to this builder.
append(char) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(char) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(char) - Method in class org.apache.lucene.util.CharsRefBuilder
 
append(char[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
Appends the given array to this CharsRef
append(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Append the provided int to this buffer.
append(CharSequence) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(CharSequence) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharSequence) - Method in class org.apache.lucene.util.CharsRefBuilder
 
append(CharSequence, int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharSequence, int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
 
append(String) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the specified String to this character sequence.
append(String) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(StringBuilder) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the specified StringBuilder to this character sequence.
append(StringBuilder) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharTermAttribute) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the contents of the other CharTermAttribute to this character sequence.
append(CharTermAttribute) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(PointValue) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
 
append(PointValue) - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
append(PointValue) - Method in interface org.apache.lucene.util.bkd.PointWriter
Add a new point from a PointValue
append(ByteBlockPool, long, int) - Method in class org.apache.lucene.util.ByteBlockPool
Append the bytes from a source ByteBlockPool at a given offset and length
append(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
Appends the bytes in the provided BytesRef at the current position.
append(BytesRef) - Method in class org.apache.lucene.util.BytesRefArray
Appends a copy of the given BytesRef to this BytesRefArray.
append(BytesRef) - Method in class org.apache.lucene.util.BytesRefBuilder
Append the provided bytes to this builder.
append(BytesRefBuilder) - Method in class org.apache.lucene.util.BytesRefBuilder
Append the provided bytes to this builder.
APPEND - org.apache.lucene.index.IndexWriterConfig.OpenMode
Opens an existing index.
appendAnyChar(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Automata
Accept any single character starting from the specified state, returning the new state
appendChar(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Automata
Appends the specified character to the specified state, returning a new state.
apply(int) - Method in interface org.apache.lucene.util.hnsw.IntToIntFunction
 
apply(T) - Method in interface org.apache.lucene.util.IOFunction
Applies this function to the given argument.
apply(T) - Method in interface org.apache.lucene.util.IOUtils.IOFunction
Deprecated.
Applies this function to the given argument.
applyToAll(Collection<T>, IOUtils.IOConsumer<T>) - Static method in class org.apache.lucene.util.IOUtils
Applies the consumer to all non-null elements in the collection even if an exception is thrown.
approximateCardinality() - Method in class org.apache.lucene.util.BitSet
Return an approximation of the cardinality of this set.
approximateCardinality() - Method in class org.apache.lucene.util.FixedBitSet
 
approximateCardinality() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
approximateSearch(LeafReaderContext, Bits, int) - Method in class org.apache.lucene.search.ByteVectorSimilarityQuery
 
approximateSearch(LeafReaderContext, Bits, int) - Method in class org.apache.lucene.search.FloatVectorSimilarityQuery
 
approximateSearch(LeafReaderContext, Bits, int, KnnCollectorManager) - Method in class org.apache.lucene.search.KnnByteVectorQuery
 
approximateSearch(LeafReaderContext, Bits, int, KnnCollectorManager) - Method in class org.apache.lucene.search.KnnFloatVectorQuery
 
approximation - Variable in class org.apache.lucene.search.DisiWrapper
 
approximation - Variable in class org.apache.lucene.search.TwoPhaseIterator
 
approximation() - Method in class org.apache.lucene.search.TwoPhaseIterator
Return an approximation.
arc - Variable in class org.apache.lucene.util.fst.Util.FSTPath
Holds the last arc appended to this path
Arc() - Constructor for class org.apache.lucene.util.fst.FST.Arc
 
arcIdx() - Method in class org.apache.lucene.util.fst.FST.Arc
Where we are in the array; only valid if bytesPerArc != 0.
ARCS_FOR_BINARY_SEARCH - Static variable in class org.apache.lucene.util.fst.FST
Value of the arc flags to declare a node with fixed length (sparse) arcs designed for binary search.
ArrayNodesIterator(int) - Constructor for class org.apache.lucene.util.hnsw.HnswGraph.ArrayNodesIterator
Constructor for iterator based on the size
ArrayNodesIterator(int[], int) - Constructor for class org.apache.lucene.util.hnsw.HnswGraph.ArrayNodesIterator
Constructor for iterator based on integer array representing nodes
ArrayUtil - Class in org.apache.lucene.util
Methods for manipulating arrays.
ArrayUtil.ByteArrayComparator - Interface in org.apache.lucene.util
Comparator for a fixed number of bytes.
articulationPoints() - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
Returns the articulation points (or cut vertices) of the graph: https://en.wikipedia.org/wiki/Biconnected_component
ASCII_CASE_INSENSITIVE - Static variable in class org.apache.lucene.util.automaton.RegExp
Allows case insensitive matching of ASCII characters.
asDocIdSetIterator(TwoPhaseIterator) - Static method in class org.apache.lucene.search.TwoPhaseIterator
Return a DocIdSetIterator view of the provided TwoPhaseIterator.
asin(double) - Static method in class org.apache.lucene.util.SloppyMath
Returns the arc sine of a value.
asinh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic sine of a double value.
asList() - Method in class org.apache.lucene.index.SegmentInfos
Returns all contained segments as an unmodifiable List view.
asReadOnlyBits() - Method in class org.apache.lucene.util.FixedBitSet
Convert this instance to read-only Bits.
assertDelCount(int, SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy
Asserts that the delCount for this SegmentCommitInfo is valid
assertsOn() - Static method in class org.apache.lucene.index.CheckIndex
Check whether asserts are enabled or not.
assigned - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
The number of stored keys (assigned key slots), excluding the special "empty" key, if any (use IntIntHashMap.size() instead).
atanh(double) - Static method in class org.apache.lucene.util.MathUtil
Calculates inverse hyperbolic tangent of a double value.
Attribute - Interface in org.apache.lucene.util
Base interface for attributes.
attributeFactory(String) - Method in class org.apache.lucene.analysis.Analyzer
Return the AttributeFactory to be used for analysis and normalization on the given FieldName.
attributeFactory(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
AttributeFactory - Class in org.apache.lucene.util
An AttributeFactory creates instances of AttributeImpls.
AttributeFactory() - Constructor for class org.apache.lucene.util.AttributeFactory
 
AttributeFactory.StaticImplementationAttributeFactory<A extends AttributeImpl> - Class in org.apache.lucene.util
Expert: AttributeFactory returning an instance of the given clazz for the attributes it implements.
AttributeImpl - Class in org.apache.lucene.util
Base class for Attributes that can be added to a AttributeSource.
AttributeImpl() - Constructor for class org.apache.lucene.util.AttributeImpl
 
AttributeReflector - Interface in org.apache.lucene.util
This interface is used to reflect contents of AttributeSource or AttributeImpl.
attributes() - Method in class org.apache.lucene.index.BaseTermsEnum
 
attributes() - Method in class org.apache.lucene.index.FieldInfo
Returns internal codec attributes map.
attributes() - Method in class org.apache.lucene.index.FilteredTermsEnum
Returns the related attributes, the returned AttributeSource is shared with the delegate TermsEnum.
attributes() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
attributes() - Method in class org.apache.lucene.index.TermsEnum
Returns the related attributes.
attributes() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
AttributeSource - Class in org.apache.lucene.util
An AttributeSource contains a list of different AttributeImpls, and methods to add and get them.
AttributeSource() - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the default attribute factory AttributeFactory.DEFAULT_ATTRIBUTE_FACTORY.
AttributeSource(AttributeFactory) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the supplied AttributeFactory for creating new Attribute instances.
AttributeSource(AttributeSource) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource that uses the same attributes as the supplied one.
AttributeSource.State - Class in org.apache.lucene.util
This class holds the state of an AttributeSource.
AUTO_DETECT_MERGES_AND_THREADS - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Dynamic default for maxThreadCount and maxMergeCount, based on CPU core count.
autoGenerateMultiTermSynonymsPhraseQuery - Variable in class org.apache.lucene.util.QueryBuilder
 
Automata - Class in org.apache.lucene.util.automaton
Construction of basic automata.
automatic() - Static method in class org.apache.lucene.util.OfflineSorter.BufferSize
Approximately half of the currently available free heap, but no less than OfflineSorter.ABSOLUTE_MIN_SORT_BUFFER_SIZE.
automaton - Variable in class org.apache.lucene.search.AutomatonQuery
the automaton to match index terms against
automaton - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Two dimensional array of transitions, indexed by state number for traversal.
Automaton - Class in org.apache.lucene.util.automaton
Represents an automaton and all its states and transitions.
Automaton() - Constructor for class org.apache.lucene.util.automaton.Automaton
Sole constructor; creates an automaton with no states.
Automaton(int, int) - Constructor for class org.apache.lucene.util.automaton.Automaton
Constructor which creates an automaton with enough space for the given number of states and transitions.
AUTOMATON - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables named automata (<identifier>).
Automaton.Builder - Class in org.apache.lucene.util.automaton
Records new states and transitions and then Automaton.Builder.finish() creates the Automaton.
automatonIsBinary - Variable in class org.apache.lucene.search.AutomatonQuery
 
AutomatonProvider - Interface in org.apache.lucene.util.automaton
Automaton provider for RegExp. RegExp.toAutomaton(AutomatonProvider,int)
AutomatonQuery - Class in org.apache.lucene.search
A Query that will match terms against a finite-state machine.
AutomatonQuery(Term, Automaton) - Constructor for class org.apache.lucene.search.AutomatonQuery
Create a new AutomatonQuery from an Automaton.
AutomatonQuery(Term, Automaton, int) - Constructor for class org.apache.lucene.search.AutomatonQuery
Create a new AutomatonQuery from an Automaton.
AutomatonQuery(Term, Automaton, int, boolean) - Constructor for class org.apache.lucene.search.AutomatonQuery
Create a new AutomatonQuery from an Automaton.
AutomatonQuery(Term, Automaton, int, boolean, MultiTermQuery.RewriteMethod) - Constructor for class org.apache.lucene.search.AutomatonQuery
Create a new AutomatonQuery from an Automaton.
AutomatonTermsEnum - Class in org.apache.lucene.index
A FilteredTermsEnum that enumerates terms based upon what is accepted by a DFA.
AutomatonTermsEnum(TermsEnum, CompiledAutomaton) - Constructor for class org.apache.lucene.index.AutomatonTermsEnum
Construct an enumerator based upon an automaton, enumerating the specified field, working on a supplied TermsEnum
AutomatonToTokenStream - Class in org.apache.lucene.analysis
Converts an Automaton into a TokenStream.
availableCharFilters() - Static method in class org.apache.lucene.analysis.CharFilterFactory
returns a list of all available charfilter names
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.analysis.AnalysisSPILoader
 
availableServices() - Method in class org.apache.lucene.util.NamedSPILoader
 
availableSortFieldProviders() - Static method in class org.apache.lucene.index.SortFieldProvider
Lists all available SortFieldProviders
availableTokenFilters() - Static method in class org.apache.lucene.analysis.TokenFilterFactory
returns a list of all available tokenfilter names from context classpath
availableTokenizers() - Static method in class org.apache.lucene.analysis.TokenizerFactory
returns a list of all available tokenizer names from context classpath
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 / docCount
awaitTermination(long, TimeUnit) - Method in class org.apache.lucene.util.SameThreadExecutorService
 
aX - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
x coordinate, vertex one
Axiomatic - Class in org.apache.lucene.search.similarities
Axiomatic approaches for IR.
Axiomatic() - Constructor for class org.apache.lucene.search.similarities.Axiomatic
Default constructor
Axiomatic(float) - Constructor for class org.apache.lucene.search.similarities.Axiomatic
Constructor setting only s, letting k and queryLen to default
Axiomatic(float, int) - Constructor for class org.apache.lucene.search.similarities.Axiomatic
Constructor setting s and queryLen, letting k to default
Axiomatic(float, int, float) - Constructor for class org.apache.lucene.search.similarities.Axiomatic
Constructor setting all Axiomatic hyperparameters
AxiomaticF1EXP - Class in org.apache.lucene.search.similarities
F1EXP is defined as Sum(tf(term_doc_freq)*ln(docLen)*IDF(term)) where IDF(t) = pow((N+1)/df(t), k) N=total num of docs, df=doc freq
AxiomaticF1EXP() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1EXP
Default constructor
AxiomaticF1EXP(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1EXP
Constructor setting s only, letting k and queryLen to default
AxiomaticF1EXP(float, float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1EXP
Constructor setting s and k, letting queryLen to default
AxiomaticF1LOG - Class in org.apache.lucene.search.similarities
F1LOG is defined as Sum(tf(term_doc_freq)*ln(docLen)*IDF(term)) where IDF(t) = ln((N+1)/df(t)) N=total num of docs, df=doc freq
AxiomaticF1LOG() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1LOG
Default constructor
AxiomaticF1LOG(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1LOG
Constructor setting s only, letting k and queryLen to default
AxiomaticF2EXP - Class in org.apache.lucene.search.similarities
F2EXP is defined as Sum(tfln(term_doc_freq, docLen)*IDF(term)) where IDF(t) = pow((N+1)/df(t), k) N=total num of docs, df=doc freq
AxiomaticF2EXP() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2EXP
Default constructor
AxiomaticF2EXP(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2EXP
Constructor setting s only, letting k and queryLen to default
AxiomaticF2EXP(float, float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2EXP
Constructor setting s and k, letting queryLen to default
AxiomaticF2LOG - Class in org.apache.lucene.search.similarities
F2EXP is defined as Sum(tfln(term_doc_freq, docLen)*IDF(term)) where IDF(t) = ln((N+1)/df(t)) N=total num of docs, df=doc freq
AxiomaticF2LOG() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2LOG
Default constructor
AxiomaticF2LOG(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2LOG
Constructor setting s only, letting k and queryLen to default
AxiomaticF3EXP - Class in org.apache.lucene.search.similarities
F3EXP is defined as Sum(tf(term_doc_freq)*IDF(term)-gamma(docLen, queryLen)) where IDF(t) = pow((N+1)/df(t), k) N=total num of docs, df=doc freq gamma(docLen, queryLen) = (docLen-queryLen)*queryLen*s/avdl NOTE: the gamma function of this similarity creates negative scores
AxiomaticF3EXP(float, int) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF3EXP
Constructor setting s and queryLen, letting k to default
AxiomaticF3EXP(float, int, float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF3EXP
Constructor setting all Axiomatic hyperparameters
AxiomaticF3LOG - Class in org.apache.lucene.search.similarities
F3EXP is defined as Sum(tf(term_doc_freq)*IDF(term)-gamma(docLen, queryLen)) where IDF(t) = ln((N+1)/df(t)) N=total num of docs, df=doc freq gamma(docLen, queryLen) = (docLen-queryLen)*queryLen*s/avdl NOTE: the gamma function of this similarity creates negative scores
AxiomaticF3LOG(float, int) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF3LOG
Constructor setting s and queryLen, letting k to default
axisLat(double, double) - Static method in class org.apache.lucene.geo.Rectangle
Calculate the latitude of a circle's intersections with its bbox meridians.
AXISLAT_ERROR - Static variable in class org.apache.lucene.geo.Rectangle
aY - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
y coordinate, vertex one

B

BASE_RAM_BYTES - Static variable in class org.apache.lucene.search.PointInSetQuery
 
BaseCompositeReader<R extends IndexReader> - Class in org.apache.lucene.index
Base class for implementing CompositeReaders based on an array of sub-readers.
BaseCompositeReader(R[], Comparator<R>) - Constructor for class org.apache.lucene.index.BaseCompositeReader
Constructs a BaseCompositeReader on the given subReaders.
BASED_ON_LOAD_IO_CONTEXT - Static variable in class org.apache.lucene.store.MMapDirectory
Argument for MMapDirectory.setPreload(BiPredicate) that configures files to be preloaded upon opening them if they use the IOContext.LOAD I/O context.
BaseDirectory - Class in org.apache.lucene.store
Base implementation for a concrete Directory that uses a LockFactory for locking.
BaseDirectory(LockFactory) - Constructor for class org.apache.lucene.store.BaseDirectory
Sole constructor.
baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
 
baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
 
baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedMutable
 
BaseTermsEnum - Class in org.apache.lucene.index
A base TermsEnum that adds default implementations for BaseTermsEnum.attributes() BaseTermsEnum.termState() BaseTermsEnum.seekExact(BytesRef) BaseTermsEnum.seekExact(BytesRef, TermState) In some cases, the default implementation may be slow and consume huge memory, so subclass SHOULD have its own implementation if possible.
BaseTermsEnum() - Constructor for class org.apache.lucene.index.BaseTermsEnum
Sole constructor.
basicModel - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
The basic model for information content.
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.
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
BasicStats - Class in org.apache.lucene.search.similarities
Stores all statistics commonly used ranking methods.
BasicStats(String, double) - Constructor for class org.apache.lucene.search.similarities.BasicStats
Constructor.
bc - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
represent if edge bc belongs to original shape
beamWidth - Variable in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
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.
beginMergeOnFullFlush(MergePolicy.MergeSpecification) - Method in interface org.apache.lucene.index.IndexWriterEventListener
Invoked at the start of merge on commit
BEST_COMPRESSION - org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat.Mode
Trade retrieval speed for compression ratio.
BEST_COMPRESSION - org.apache.lucene.codecs.lucene99.Lucene99Codec.Mode
Trade retrieval speed for compression ratio.
BEST_COMPRESSION_MODE - Static variable in class org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat
BEST_SPEED - org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat.Mode
Trade compression ratio for retrieval speed.
BEST_SPEED - org.apache.lucene.codecs.lucene99.Lucene99Codec.Mode
Trade compression ratio for retrieval speed.
BEST_SPEED_MODE - Static variable in class org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat
BIG_TERM - Static variable in class org.apache.lucene.util.UnicodeUtil
A binary term consisting of a number of 0xff bytes, likely to be bigger than other terms (e.g.
bigIntToSortableBytes(BigInteger, int, byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
Encodes a BigInteger value such that unsigned byte order comparison is consistent with BigInteger.compareTo(BigInteger).
BINARY - org.apache.lucene.document.InvertableType
The field should be treated as a single value whose binary content is returned by IndexableField.binaryValue().
BINARY - org.apache.lucene.document.StoredValue.Type
Type of binary values.
BINARY - org.apache.lucene.index.DocValuesType
A per-document byte[].
BinaryDocValues - Class in org.apache.lucene.index
A per-document numeric value.
BinaryDocValues() - Constructor for class org.apache.lucene.index.BinaryDocValues
Sole constructor.
BinaryDocValuesField - Class in org.apache.lucene.document
Field that stores a per-document BytesRef value.
BinaryDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.BinaryDocValuesField
Create a new binary DocValues field.
binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a binary field.
binaryField(FieldInfo, DataInput, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
binaryField(FieldInfo, DataInput, int) - Method in class org.apache.lucene.index.StoredFieldVisitor
Expert: Process a binary field directly from the DataInput.
BinaryPoint - Class in org.apache.lucene.document
An indexed binary field for fast range filters.
BinaryPoint(String, byte[]...) - Constructor for class org.apache.lucene.document.BinaryPoint
General purpose API: creates a new BinaryPoint, indexing the provided N-dimensional binary point.
BinaryPoint(String, byte[], IndexableFieldType) - Constructor for class org.apache.lucene.document.BinaryPoint
Expert API
BinaryRangeDocValues - Class in org.apache.lucene.document
A binary representation of a range that wraps a BinaryDocValues field
BinaryRangeDocValues(BinaryDocValues, int, int) - Constructor for class org.apache.lucene.document.BinaryRangeDocValues
Constructor for BinaryRangeDocValues
binarySearch(long, long, long) - Method in class org.apache.lucene.util.packed.DirectMonotonicReader
Return the index of a key if it exists, or its insertion point otherwise like Arrays.binarySearch(long[], int, int, long).
binaryValue - Variable in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
binaryValue - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
binaryValue() - Method in class org.apache.lucene.document.BinaryRangeDocValues
 
binaryValue() - Method in class org.apache.lucene.document.DoubleField
 
binaryValue() - Method in class org.apache.lucene.document.Field
 
binaryValue() - Method in class org.apache.lucene.document.FloatField
 
binaryValue() - Method in class org.apache.lucene.document.IntField
 
binaryValue() - Method in class org.apache.lucene.document.KeywordField
 
binaryValue() - Method in class org.apache.lucene.document.LongField
 
binaryValue() - Method in class org.apache.lucene.document.StringField
 
binaryValue() - Method in class org.apache.lucene.index.BinaryDocValues
Returns the binary value for the current document ID.
binaryValue() - Method in class org.apache.lucene.index.FilterBinaryDocValues
 
binaryValue() - Method in interface org.apache.lucene.index.IndexableField
Non-null if this field has a binary value
BIT_ARC_HAS_OUTPUT - Static variable in class org.apache.lucene.util.fst.FST
This flag is set if the arc has an output.
BitDocIdSet - Class in org.apache.lucene.util
Implementation of the DocIdSet interface on top of a BitSet.
BitDocIdSet(BitSet) - Constructor for class org.apache.lucene.util.BitDocIdSet
Same as BitDocIdSet(BitSet, long) but uses the set's approximate cardinality as a cost.
BitDocIdSet(BitSet, long) - Constructor for class org.apache.lucene.util.BitDocIdSet
Wrap the given BitSet as a DocIdSet.
BitMixer - Class in org.apache.lucene.util.hppc
Bit mixing utilities.
BitMixer() - Constructor for class org.apache.lucene.util.hppc.BitMixer
 
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.util.BitDocIdSet
 
bits() - Method in class org.apache.lucene.util.NotDocIdSet
 
Bits - Interface in org.apache.lucene.util
Interface for Bitset-like structures.
BITS - Static variable in class org.apache.lucene.geo.GeoEncodingUtils
number of bits used for quantizing latitude and longitude values
Bits.MatchAllBits - Class in org.apache.lucene.util
Bits impl of the specified length with all bits set.
Bits.MatchNoBits - Class in org.apache.lucene.util
Bits impl of the specified length with no bits set.
bits2words(int) - Static method in class org.apache.lucene.util.FixedBitSet
returns the number of 64 bit words it would take to hold numBits
bits2words(long) - Static method in class org.apache.lucene.util.LongBitSet
Returns the number of 64 bit words it would take to hold numBits
BitSet - Class in org.apache.lucene.util
Base implementation for a bit set.
BitSet() - Constructor for class org.apache.lucene.util.BitSet
 
BitSetIterator - Class in org.apache.lucene.util
A DocIdSetIterator which iterates over set bits in a bit set.
BitSetIterator(BitSet, long) - Constructor for class org.apache.lucene.util.BitSetIterator
Sole constructor.
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
 
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
bitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
The number of bits per value.
bitsRequired(long) - Static method in class org.apache.lucene.util.packed.DirectWriter
Returns how many bits are required to hold values up to and including maxValue
bitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
Returns how many bits are required to hold values up to and including maxValue NOTE: This method returns at least 1.
BitUtil - Class in org.apache.lucene.util
A variety of high efficiency bit twiddling routines and encoders for primitives.
BKDConfig - Class in org.apache.lucene.util.bkd
Basic parameters for indexing points on the BKD tree.
BKDConfig(int, int, int, int) - Constructor for class org.apache.lucene.util.bkd.BKDConfig
 
BKDRadixSelector - Class in org.apache.lucene.util.bkd
Offline Radix selector for BKD tree.
BKDRadixSelector(BKDConfig, int, Directory, String) - Constructor for class org.apache.lucene.util.bkd.BKDRadixSelector
Sole constructor.
BKDRadixSelector.PathSlice - Class in org.apache.lucene.util.bkd
Sliced reference to points in an PointWriter.
BKDReader - Class in org.apache.lucene.util.bkd
Handles reading a block KD-tree in byte[] space previously written with BKDWriter.
BKDReader(IndexInput, IndexInput, IndexInput) - Constructor for class org.apache.lucene.util.bkd.BKDReader
BKDWriter - Class in org.apache.lucene.util.bkd
Recursively builds a block KD-tree to assign all incoming points in N-dim space to smaller and smaller N-dim rectangles (cells) until the number of points in a given rectangle is <= config.maxPointsInLeafNode.
BKDWriter(int, Directory, String, BKDConfig, double, long) - Constructor for class org.apache.lucene.util.bkd.BKDWriter
 
BlendedTermQuery - Class in org.apache.lucene.search
A Query that blends index statistics across multiple terms.
BlendedTermQuery.Builder - Class in org.apache.lucene.search
A Builder for BlendedTermQuery.
BlendedTermQuery.DisjunctionMaxRewrite - Class in org.apache.lucene.search
A BlendedTermQuery.RewriteMethod that creates a DisjunctionMaxQuery out of the sub queries.
BlendedTermQuery.RewriteMethod - Class in org.apache.lucene.search
A BlendedTermQuery.RewriteMethod defines how queries for individual terms should be merged.
BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
Size of blocks.
blockCountByPrefixLen - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Number of blocks at each prefix depth.
blockFilePointer - Variable in class org.apache.lucene.codecs.BlockTermState
fp into the terms dict primary file (_X.tim) that holds this term
BlockingFloatHeap - Class in org.apache.lucene.util.hnsw
A blocking bounded min heap that stores floats.
BlockingFloatHeap(int) - Constructor for class org.apache.lucene.util.hnsw.BlockingFloatHeap
 
BlockPackedReaderIterator - Class in org.apache.lucene.util.packed
Reader for sequences of longs written with BlockPackedWriter.
BlockPackedReaderIterator(DataInput, int, int, long) - Constructor for class org.apache.lucene.util.packed.BlockPackedReaderIterator
Sole constructor.
BlockPackedWriter - Class in org.apache.lucene.util.packed
A writer for large sequences of longs.
BlockPackedWriter(DataOutput, int) - Constructor for class org.apache.lucene.util.packed.BlockPackedWriter
Sole constructor.
blockSize - Variable in class org.apache.lucene.util.ByteBlockPool.Allocator
 
blockSize - Variable in class org.apache.lucene.util.IntBlockPool.Allocator
 
BlockTermState - Class in org.apache.lucene.codecs
Holds all state required for PostingsReaderBase to produce a PostingsEnum without re-seeking the terms dict.
BlockTermState() - Constructor for class org.apache.lucene.codecs.BlockTermState
Sole constructor.
blockTreeStats - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Holds details of block allocations in the block tree terms dictionary (this is only set if the PostingsFormat for this segment uses block tree.
BM25Similarity - Class in org.apache.lucene.search.similarities
BM25 Similarity.
BM25Similarity() - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
BM25 with these default values: k1 = 1.2 b = 0.75 discountOverlaps = true
BM25Similarity(boolean) - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
BM25 with these default values: k1 = 1.2 b = 0.75 and the supplied parameter value:
BM25Similarity(float, float) - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
BM25 with the supplied parameter values.
BM25Similarity(float, float, boolean) - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
BM25 with the supplied parameter values.
BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.BlendedTermQuery
A BlendedTermQuery.RewriteMethod that adds all sub queries to a BooleanQuery.
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.Builder - Class in org.apache.lucene.search
A builder for boolean queries.
BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
BooleanSimilarity - Class in org.apache.lucene.search.similarities
Simple similarity that gives terms a score that is equal to their query boost.
BooleanSimilarity() - Constructor for class org.apache.lucene.search.similarities.BooleanSimilarity
Sole constructor
boost - Variable in class org.apache.lucene.search.similarities.BasicStats
A query boost.
boost - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
boost - Variable in class org.apache.lucene.util.QueryBuilder.TermAndBoost
the boost
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
 
BoostQuery - Class in org.apache.lucene.search
A Query wrapper that allows to give a boost to the wrapped query.
BoostQuery(Query, float) - Constructor for class org.apache.lucene.search.BoostQuery
Sole constructor: wrap query in such a way that the produced scores will be boosted by boost.
bottom - Variable in class org.apache.lucene.search.comparators.DoubleComparator
 
bottom - Variable in class org.apache.lucene.search.comparators.FloatComparator
 
bottom - Variable in class org.apache.lucene.search.comparators.IntComparator
 
bottom - Variable in class org.apache.lucene.search.comparators.LongComparator
 
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() - 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_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
Default buffer size set to 1024.
BufferAllocationException(String) - Constructor for exception org.apache.lucene.util.hppc.IntIntHashMap.BufferAllocationException
 
BufferAllocationException(String, Object...) - Constructor for exception org.apache.lucene.util.hppc.IntIntHashMap.BufferAllocationException
 
BufferAllocationException(String, Throwable, Object...) - Constructor for exception org.apache.lucene.util.hppc.IntIntHashMap.BufferAllocationException
 
BufferedChecksum - Class in org.apache.lucene.store
Wraps another Checksum with an internal buffer to speed up checksum calculations.
BufferedChecksum(Checksum) - Constructor for class org.apache.lucene.store.BufferedChecksum
Create a new BufferedChecksum with BufferedChecksum.DEFAULT_BUFFERSIZE
BufferedChecksum(Checksum, int) - Constructor for class org.apache.lucene.store.BufferedChecksum
Create a new BufferedChecksum with the specified bufferSize
BufferedChecksumIndexInput - Class in org.apache.lucene.store
Simple implementation of ChecksumIndexInput that wraps another input and delegates calls.
BufferedChecksumIndexInput(IndexInput) - Constructor for class org.apache.lucene.store.BufferedChecksumIndexInput
Creates a new BufferedChecksumIndexInput
BufferedIndexInput - Class in org.apache.lucene.store
Base implementation class for buffered IndexInput.
BufferedIndexInput(String) - Constructor for class org.apache.lucene.store.BufferedIndexInput
 
BufferedIndexInput(String, int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
Inits BufferedIndexInput with a specific bufferSize
BufferedIndexInput(String, IOContext) - Constructor for class org.apache.lucene.store.BufferedIndexInput
 
BufferingKnnVectorsWriter - Class in org.apache.lucene.codecs
Buffers up pending vector value(s) per doc, then flushes when segment flushes.
BufferingKnnVectorsWriter() - Constructor for class org.apache.lucene.codecs.BufferingKnnVectorsWriter
Sole constructor
buffers - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 
buffers - Variable in class org.apache.lucene.util.IntBlockPool
array of buffers currently used in the pool.
bufferSize - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
read buffer size (in bytes)
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.
bufferSkip(int, CompetitiveImpactAccumulator, int, long, long, int, int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipWriter
Sets the values for the current skip data.
bugfix - Variable in class org.apache.lucene.util.Version
Bugfix number, incremented on release branches
build() - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
Build the BlendedTermQuery.
build() - Method in class org.apache.lucene.search.BooleanQuery.Builder
Create a new BooleanQuery based on the parameters that have been set on this builder.
build() - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
build() - Method in class org.apache.lucene.search.PhraseQuery.Builder
Build a phrase query based on the terms that have been added.
build() - Method in class org.apache.lucene.search.SynonymQuery.Builder
Builds the SynonymQuery.
build() - Method in class org.apache.lucene.util.DocIdSetBuilder
Build a DocIdSet from the accumulated doc IDs.
build() - Method in class org.apache.lucene.util.fst.FSTCompiler.Builder
Creates a new FSTCompiler.
build() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
Build a PackedLongValues instance that contains values that have been added to this builder.
build() - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
Build an instance.
build(int) - Method in interface org.apache.lucene.util.hnsw.HnswBuilder
Adds all nodes to the graph up to the provided maxOrd.
build(int) - Method in class org.apache.lucene.util.hnsw.HnswConcurrentMergeBuilder
 
build(int) - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
build(Iterable<BytesRef>) - Static method in class org.apache.lucene.util.automaton.DaciukMihovAutomatonBuilder
Deprecated.
build(IndexReader.CacheKey, SortedDocValues[], float) - Static method in class org.apache.lucene.index.OrdinalMap
Create an ordinal map that uses the number of unique values of each SortedDocValues instance as a weight.
build(IndexReader.CacheKey, SortedSetDocValues[], float) - Static method in class org.apache.lucene.index.OrdinalMap
Create an ordinal map that uses the number of unique values of each SortedSetDocValues instance as a weight.
build(IndexReader.CacheKey, TermsEnum[], long[], float) - Static method in class org.apache.lucene.index.OrdinalMap
Creates an ordinal map that allows mapping ords to/from a merged space from subs.
build(BlendedTermQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
 
build(BooleanQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
build(BooleanQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
build(IndexSearcher, Term, boolean) - Static method in class org.apache.lucene.index.TermStates
Creates a TermStates from a top-level IndexReaderContext and the given Term.
builder - Variable in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
May be used by subclasses to convert to different charsets / encodings for implementing CharTermAttributeImpl.getBytesRef().
Builder() - Constructor for class org.apache.lucene.index.PrefixCodedTerms.Builder
Sole constructor.
Builder() - Constructor for class org.apache.lucene.search.BlendedTermQuery.Builder
Sole constructor.
Builder() - Constructor for class org.apache.lucene.search.BooleanQuery.Builder
Sole constructor.
Builder() - Constructor for class org.apache.lucene.search.MultiPhraseQuery.Builder
Default constructor.
Builder() - Constructor for class org.apache.lucene.search.PhraseQuery.Builder
Sole constructor.
Builder() - Constructor for class org.apache.lucene.util.automaton.Automaton.Builder
Default constructor, pre-allocating for 16 states and transitions.
Builder(int) - Constructor for class org.apache.lucene.util.RoaringDocIdSet.Builder
Sole constructor.
Builder(int, int) - Constructor for class org.apache.lucene.util.automaton.Automaton.Builder
Constructor which creates a builder with enough space for the given number of states and transitions.
Builder(String) - Constructor for class org.apache.lucene.search.SynonymQuery.Builder
Sole constructor
Builder(MultiPhraseQuery) - Constructor for class org.apache.lucene.search.MultiPhraseQuery.Builder
Copy constructor: this will create a builder that has the same configuration as the provided builder.
Builder(FST.INPUT_TYPE, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.FSTCompiler.Builder
 
buildHistogram(int, int, int, int, int, int[]) - Method in class org.apache.lucene.util.MSBRadixSorter
Build an histogram of the k-th characters of values occurring between offsets from and to, using MSBRadixSorter.getBucket(int, int).
buildSlice(String, long, long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
Builds the actual sliced IndexInput (may apply extra offset in subclasses).
BulkAdder() - Constructor for class org.apache.lucene.util.DocIdSetBuilder.BulkAdder
 
bulkScorer(LeafReaderContext) - Method in class org.apache.lucene.search.IndriAndWeight
 
bulkScorer(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
Optional method, to return a BulkScorer to score the query and send hits to a Collector.
BulkScorer - Class in org.apache.lucene.search
This class is used to score a range of documents at once, and is returned by Weight.bulkScorer(org.apache.lucene.index.LeafReaderContext).
BulkScorer() - Constructor for class org.apache.lucene.search.BulkScorer
 
bX - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
x coordinate, vertex two
bY - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
y coordinate, vertex two
byId(int) - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
Get a format according to its ID.
BYTE - org.apache.lucene.index.VectorEncoding
Encodes vector using 8 bits of precision per sample.
BYTE_BLOCK_MASK - Static variable in class org.apache.lucene.util.ByteBlockPool
Use this to find the position of a global offset in a particular buffer.
BYTE_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.ByteBlockPool
Use this to find the index of the buffer containing a byte, given an offset to that byte.
BYTE_BLOCK_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
The size of each buffer in the pool.
BYTE1 - org.apache.lucene.util.fst.FST.INPUT_TYPE
 
BYTE2 - org.apache.lucene.util.fst.FST.INPUT_TYPE
 
byte315ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
byteToFloat(b, mantissaBits=3, zeroExponent=15)
BYTE4 - org.apache.lucene.util.fst.FST.INPUT_TYPE
 
byte4ToInt(byte) - Static method in class org.apache.lucene.util.SmallFloat
Decode values that have been encoded with SmallFloat.intToByte4(int).
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() - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataOutput - Class in org.apache.lucene.store
DataOutput backed by a byte array.
ByteArrayDataOutput() - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
byteAt(int) - Method in class org.apache.lucene.util.BytesRefBuilder
Return the byte at the given offset.
byteAt(int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
Return the k-th byte of the entry at index i, or -1 if its length is less than or equal to k.
byteAt(int, int) - Method in class org.apache.lucene.util.RadixSelector
Return the k-th byte of the entry at index i, or -1 if its length is less than or equal to k.
byteAt(int, int) - Method in class org.apache.lucene.util.StringSorter.MSBStringRadixSorter
 
byteAt(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefComparator
Return the unsigned byte to use for comparison at index i, or -1 if all bytes that are useful for comparisons are exhausted.
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
This class enables the allocation of fixed-size buffers and their management as part of a buffer array.
ByteBlockPool(ByteBlockPool.Allocator) - Constructor for class org.apache.lucene.util.ByteBlockPool
 
ByteBlockPool.Allocator - Class in org.apache.lucene.util
Abstract class for allocating and freeing byte blocks.
ByteBlockPool.DirectAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles.
ByteBlockPool.DirectTrackingAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles, but tracks how much total RAM is in use.
byteBuffer - Variable in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
byteBuffer - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
ByteBufferIndexInput - Class in org.apache.lucene.store
Base IndexInput implementation that uses an array of ByteBuffers to represent a file.
ByteBufferRecycler(IntFunction<ByteBuffer>) - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput.ByteBufferRecycler
 
ByteBuffersDataInput - Class in org.apache.lucene.store
A DataInput implementing RandomAccessInput and reading data from a list of ByteBuffers.
ByteBuffersDataInput(List<ByteBuffer>) - Constructor for class org.apache.lucene.store.ByteBuffersDataInput
Read data from a set of contiguous buffers.
ByteBuffersDataOutput - Class in org.apache.lucene.store
A DataOutput storing data in a list of ByteBuffers.
ByteBuffersDataOutput() - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput
Creates a new output with all defaults.
ByteBuffersDataOutput(int, int, IntFunction<ByteBuffer>, Consumer<ByteBuffer>) - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput
Expert: Creates a new output with custom parameters.
ByteBuffersDataOutput(long) - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput
Create a new output, suitable for writing a file of around expectedSize bytes.
ByteBuffersDataOutput.ByteBufferRecycler - Class in org.apache.lucene.store
An implementation of a ByteBuffer allocation and recycling policy.
ByteBuffersDirectory - Class in org.apache.lucene.store
A ByteBuffer-based Directory implementation that can be used to store index files on the heap.
ByteBuffersDirectory() - Constructor for class org.apache.lucene.store.ByteBuffersDirectory
 
ByteBuffersDirectory(LockFactory) - Constructor for class org.apache.lucene.store.ByteBuffersDirectory
 
ByteBuffersDirectory(LockFactory, Supplier<ByteBuffersDataOutput>, BiFunction<String, ByteBuffersDataOutput, IndexInput>) - Constructor for class org.apache.lucene.store.ByteBuffersDirectory
 
ByteBuffersIndexInput - Class in org.apache.lucene.store
An IndexInput implementing RandomAccessInput and backed by a ByteBuffersDataInput.
ByteBuffersIndexInput(ByteBuffersDataInput, String) - Constructor for class org.apache.lucene.store.ByteBuffersIndexInput
 
ByteBuffersIndexOutput - Class in org.apache.lucene.store
ByteBuffersIndexOutput(ByteBuffersDataOutput, String, String) - Constructor for class org.apache.lucene.store.ByteBuffersIndexOutput
 
ByteBuffersIndexOutput(ByteBuffersDataOutput, String, String, Checksum, Consumer<ByteBuffersDataOutput>) - Constructor for class org.apache.lucene.store.ByteBuffersIndexOutput
 
byteCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Computes how many byte blocks are needed to store values values of size bitsPerValue.
byteOffset - Variable in class org.apache.lucene.util.ByteBlockPool
Offset from the start of the first buffer to the start of the current buffer, which is bufferUpto * BYTE_BLOCK_SIZE.
ByteRunAutomaton - Class in org.apache.lucene.util.automaton
Automaton representation for matching UTF-8 byte[].
ByteRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
Converts incoming automaton to byte-based (UTF32ToUTF8) first
ByteRunAutomaton(Automaton, boolean, int) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
expert: if isBinary is true, the input is already byte-based
bytes - Variable in class org.apache.lucene.util.BytesRef
The contents of the BytesRef.
bytes() - Method in class org.apache.lucene.index.Term
Returns the bytes of this term, these should not be modified.
bytes() - Method in class org.apache.lucene.util.BytesRefBuilder
Return a reference to the bytes of this builder.
BYTES - Static variable in class org.apache.lucene.document.DoubleRange
stores double values so number of bytes is 8
BYTES - Static variable in class org.apache.lucene.document.FloatRange
stores float values so number of bytes is 4
BYTES - Static variable in class org.apache.lucene.document.InetAddressPoint
The number of bytes per dimension: 128 bits
BYTES - Static variable in class org.apache.lucene.document.InetAddressRange
The number of bytes per dimension : sync w/ InetAddressPoint
BYTES - Static variable in class org.apache.lucene.document.IntRange
stores integer values so number of bytes is 4
BYTES - Static variable in class org.apache.lucene.document.LatLonPoint
LatLonPoint is encoded as integer values so number of bytes is 4
BYTES - Static variable in class org.apache.lucene.document.LongRange
stores long values so number of bytes is 8
BYTES - Static variable in class org.apache.lucene.document.XYPointField
XYPoint is encoded as integer values so number of bytes is 4
bytesDifference(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Compares two BytesRef, element by element, and returns the number of elements common to both arrays (from the start of each).
bytesEquals(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Expert: compares the bytes against another BytesRef, returning true if the bytes are equal.
ByteSequenceOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a sequence of bytes.
ByteSequencesReader(ChecksumIndexInput, String) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
Constructs a ByteSequencesReader from the provided IndexInput
ByteSequencesWriter(IndexOutput) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Constructs a ByteSequencesWriter to the provided DataOutput
byteSize - Variable in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
byteSize - Variable in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
byteSize - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
byteSize - Variable in enum org.apache.lucene.index.VectorEncoding
The number of bytes required to encode a scalar in this format.
bytesPerArc() - Method in class org.apache.lucene.util.fst.FST.Arc
Non-zero if this arc is part of a node with fixed length arcs, which means all arcs for the node are encoded with a fixed number of bytes so that we binary search or direct address.
bytesPerDim - Variable in class org.apache.lucene.util.bkd.BKDConfig
How many bytes each value in each dimension takes.
bytesPerDoc - Variable in class org.apache.lucene.util.bkd.BKDConfig
packedBytesLength plus docID size
BytesReader() - Constructor for class org.apache.lucene.util.fst.FST.BytesReader
 
BytesRef - Class in org.apache.lucene.util
Represents byte[], as a slice (offset + length) into an existing byte[].
BytesRef() - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef with BytesRef.EMPTY_BYTES
BytesRef(byte[]) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(byte[], int, int) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(int) - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef pointing to a new array of size capacity.
BytesRef(CharSequence) - Constructor for class org.apache.lucene.util.BytesRef
Initialize the byte[] from the UTF8 bytes for the provided String.
BytesRefArray - Class in org.apache.lucene.util
A simple append only random-access BytesRef array that stores full copies of the appended bytes in a ByteBlockPool.
BytesRefArray(Counter) - Constructor for class org.apache.lucene.util.BytesRefArray
Creates a new BytesRefArray with a counter to track allocated bytes
BytesRefArray.IndexedBytesRefIterator - Interface in org.apache.lucene.util
An extension of BytesRefIterator that allows retrieving the index of the current element
BytesRefArray.SortState - Class in org.apache.lucene.util
Used to iterate the elements of an array in a given order.
BytesRefBlockPool - Class in org.apache.lucene.util
Represents a logical list of ByteRef backed by a ByteBlockPool.
BytesRefBlockPool() - Constructor for class org.apache.lucene.util.BytesRefBlockPool
 
BytesRefBlockPool(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefBlockPool
 
BytesRefBuilder - Class in org.apache.lucene.util
A builder for BytesRef instances.
BytesRefBuilder() - Constructor for class org.apache.lucene.util.BytesRefBuilder
Sole constructor.
BytesRefComparator - Class in org.apache.lucene.util
Specialized BytesRef comparator that StringSorter has optimizations for.
BytesRefComparator(int) - Constructor for class org.apache.lucene.util.BytesRefComparator
Sole constructor.
BytesRefFSTEnum<T> - Class in org.apache.lucene.util.fst
Enumerates all input (BytesRef) + output pairs in an FST.
BytesRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum
doFloor controls the behavior of advance: if it's true doFloor is true, advance positions to the biggest term before target.
BytesRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
Holds a single input (BytesRef) + output pair.
BytesRefHash - Class in org.apache.lucene.util
BytesRefHash is a special purpose hash-map like data-structure optimized for BytesRef instances.
BytesRefHash() - Constructor for class org.apache.lucene.util.BytesRefHash
BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash.BytesStartArray - Class in org.apache.lucene.util
Manages allocation of the per-term addresses.
BytesRefHash.DirectBytesStartArray - Class in org.apache.lucene.util
A simple BytesRefHash.BytesStartArray that tracks memory allocation using a private Counter instance.
BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
Thrown if a BytesRef exceeds the BytesRefHash limit of ByteBlockPool.BYTE_BLOCK_SIZE-2.
BytesRefIterator - Interface in org.apache.lucene.util
A simple iterator interface for BytesRef iteration.
BytesStartArray() - Constructor for class org.apache.lucene.util.BytesRefHash.BytesStartArray
 
byteStart(int) - Method in class org.apache.lucene.util.BytesRefHash
Returns the bytesStart offset into the internally used ByteBlockPool for the given bytesID
BytesTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
This attribute can be used if you have the raw term bytes to be indexed.
BytesTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Implementation class for BytesTermAttribute.
BytesTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
Initialize this attribute with no bytes.
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
A Counter reference holding the number of bytes used by this BytesRefHash.BytesStartArray.
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
bytesUsed() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
bytesUsed() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
byteToFloat(byte, int, int) - Static method in class org.apache.lucene.util.SmallFloat
Converts an 8 bit float to a 32 bit float.
byteUpto - Variable in class org.apache.lucene.util.ByteBlockPool
Where we are in the 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.
ByteVectorSimilarityQuery - Class in org.apache.lucene.search
Search for all (approximate) byte vectors above a similarity threshold.
ByteVectorSimilarityQuery(String, byte[], float) - Constructor for class org.apache.lucene.search.ByteVectorSimilarityQuery
Search for all (approximate) byte vectors above a similarity threshold using VectorSimilarityCollector.
ByteVectorSimilarityQuery(String, byte[], float, float) - Constructor for class org.apache.lucene.search.ByteVectorSimilarityQuery
Search for all (approximate) byte vectors above a similarity threshold using VectorSimilarityCollector.
ByteVectorSimilarityQuery(String, byte[], float, float, Query) - Constructor for class org.apache.lucene.search.ByteVectorSimilarityQuery
Search for all (approximate) byte vectors above a similarity threshold using VectorSimilarityCollector.
ByteVectorSimilarityQuery(String, byte[], float, Query) - Constructor for class org.apache.lucene.search.ByteVectorSimilarityQuery
Search for all (approximate) byte vectors above a similarity threshold using VectorSimilarityCollector.
ByteVectorValues - Class in org.apache.lucene.index
This class provides access to per-document floating point vector values indexed as KnnByteVectorField.
ByteVectorValues() - Constructor for class org.apache.lucene.index.ByteVectorValues
Sole constructor

C

c - Variable in class org.apache.lucene.util.automaton.RegExp
Character expression
ca - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
represent if edge ca belongs to original shape
CacheAndCount(DocIdSet, int) - Constructor for class org.apache.lucene.search.LRUQueryCache.CacheAndCount
 
cacheImpl(BulkScorer, int) - Method in class org.apache.lucene.search.LRUQueryCache
Default cache implementation: uses RoaringDocIdSet for sets that have a density < 1% and a BitDocIdSet over a FixedBitSet otherwise.
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.
calculateDefaultConfidenceInterval(int) - Static method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsFormat
 
calcUTF16toUTF8Length(CharSequence, int, int) - Static method in class org.apache.lucene.util.UnicodeUtil
Calculates the number of UTF8 bytes necessary to write a UTF16 string.
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.
CANDIDATE - org.apache.lucene.geo.Component2D.WithinRelation
If the shape is a candidate for within.
canReuse(MultiTermsEnum) - Method in class org.apache.lucene.index.MultiPostingsEnum
Returns true if this instance can be reused by the provided MultiTermsEnum.
captureState() - Method in class org.apache.lucene.util.AttributeSource
Captures the state of all Attributes.
cardinality() - Method in class org.apache.lucene.index.DocsWithFieldSet
Return the number of documents of this set.
cardinality() - Method in class org.apache.lucene.util.BitSet
Return the number of bits that are set.
cardinality() - Method in class org.apache.lucene.util.FixedBitSet
Returns number of set bits.
cardinality() - Method in class org.apache.lucene.util.LongBitSet
Returns number of set bits.
cardinality() - Method in class org.apache.lucene.util.RoaringDocIdSet
Return the exact number of documents that are contained in this set.
cardinality() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
CCW - org.apache.lucene.geo.GeoUtils.WindingOrder
 
CELL_CROSSES_QUERY - org.apache.lucene.index.PointValues.Relation
Return this if the cell partially overlaps the query
CELL_INSIDE_QUERY - org.apache.lucene.index.PointValues.Relation
Return this if the cell is fully contained by the query
CELL_OUTSIDE_QUERY - org.apache.lucene.index.PointValues.Relation
Return this if the cell and query do not overlap
changed() - Method in class org.apache.lucene.index.SegmentInfos
Call this before committing if changes have been made to the segments.
changeToken(BytesRef) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
Subclass and implement this if you need to change the token (such as escaping certain bytes) before it's turned into a graph.
CharacterRunAutomaton - Class in org.apache.lucene.util.automaton
Automaton representation for matching char[].
CharacterRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CharacterRunAutomaton
Construct with a default number of determinizeWorkLimit.
CharacterRunAutomaton(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.CharacterRunAutomaton
Constructor specifying determinizeWorkLimit.
CharacterUtils - Class in org.apache.lucene.analysis
Utility class to write tokenizers or token filters.
CharacterUtils.CharacterBuffer - Class in org.apache.lucene.analysis
A simple IO buffer to use with CharacterUtils.fill(CharacterBuffer, Reader).
CharArrayMap<V> - Class in org.apache.lucene.analysis
A simple class that stores key Strings as char[]'s in a hash table.
CharArrayMap(int, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
Create map with enough capacity to hold startSize terms
CharArrayMap(Map<?, ? extends V>, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
Creates a map from the mappings in another map.
CharArrayMap.EntryIterator - Class in org.apache.lucene.analysis
public iterator class so efficient methods are exposed to users
CharArrayMap.EntrySet - Class in org.apache.lucene.analysis
public EntrySet class so efficient methods are exposed to users
CharArraySet - Class in org.apache.lucene.analysis
A simple class that stores Strings as char[]'s in a hash table.
CharArraySet(int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
Create set with enough capacity to hold startSize terms
CharArraySet(Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
Creates a set from a Collection of objects.
charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
charAt(int) - Method in class org.apache.lucene.util.CharsRef
 
charAt(int) - Method in class org.apache.lucene.util.CharsRefBuilder
Return the char at the given offset.
CharFilter - Class in org.apache.lucene.analysis
Subclasses of CharFilter can be chained to filter a Reader They can be used as Reader with additional offset correction.
CharFilter(Reader) - Constructor for class org.apache.lucene.analysis.CharFilter
Create a new CharFilter wrapping the provided reader.
CharFilterFactory - Class in org.apache.lucene.analysis
Abstract parent class for analysis factories that create CharFilter instances.
CharFilterFactory() - Constructor for class org.apache.lucene.analysis.CharFilterFactory
Default ctor for compatibility with SPI
CharFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.CharFilterFactory
Initialize this factory via a set of key-value pairs.
chars - Variable in class org.apache.lucene.util.CharsRef
The contents of the CharsRef.
chars() - Method in class org.apache.lucene.util.CharsRefBuilder
Return a reference to the chars of this builder.
charsEquals(CharsRef) - Method in class org.apache.lucene.util.CharsRef
 
CharSequenceOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a sequence of characters.
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(char[], int, int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given array, offset and length
CharsRef(int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with an array of the given capacity
CharsRef(String) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given Strings character array
CharsRefBuilder - Class in org.apache.lucene.util
A builder for CharsRef instances.
CharsRefBuilder() - Constructor for class org.apache.lucene.util.CharsRefBuilder
Sole constructor.
CharTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The term text of a Token.
CharTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of CharTermAttribute.
CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
Initialize this attribute with empty term text
checkAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Checks if merge has been aborted and throws a merge exception if so.
checkArgs(String, Object, Object) - Static method in class org.apache.lucene.search.PointRangeQuery
Check preconditions for all factory methods
checkConsistency() - Method in class org.apache.lucene.index.FieldInfo
Check correctness of the FieldInfo options
CheckedIntConsumer<T extends Exception> - Interface in org.apache.lucene.search
Like IntConsumer, but may throw checked exceptions.
checkFinite(float[]) - Static method in class org.apache.lucene.util.VectorUtil
Checks if a float vector only has finite components.
checkFooter(ChecksumIndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Validates the codec footer previously written by CodecUtil.writeFooter(org.apache.lucene.store.IndexOutput).
checkFooter(ChecksumIndexInput, Throwable) - Static method in class org.apache.lucene.codecs.CodecUtil
Validates the codec footer previously written by CodecUtil.writeFooter(org.apache.lucene.store.IndexOutput), optionally passing an unexpected exception that has already occurred.
checkHeader(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
Reads and validates a header previously written with CodecUtil.writeHeader(DataOutput, String, int).
checkHeaderNoMagic(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
Like CodecUtil.checkHeader(DataInput,String,int,int) except this version assumes the first int has already been read and validated from the input.
checkIfFrozen() - Method in class org.apache.lucene.document.FieldType
Throws an exception if this FieldType is frozen.
checkImpacts(Impacts, int) - Method in interface org.apache.lucene.internal.tests.IndexPackageAccess
 
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(List<String>, ExecutorService) - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
CheckIndex - Class in org.apache.lucene.index
Basic tool and API to check the health of an index and write a new segments file that removes reference to problematic segments.
CheckIndex(Directory) - Constructor for class org.apache.lucene.index.CheckIndex
Create a new CheckIndex on the directory.
CheckIndex(Directory, Lock) - Constructor for class org.apache.lucene.index.CheckIndex
Expert: create a directory with the specified lock.
CheckIndex.CheckIndexException - Exception in org.apache.lucene.index
The marker RuntimeException used by CheckIndex APIs when index integrity failure is detected.
CheckIndex.Options - Class in org.apache.lucene.index
Run-time configuration options for CheckIndex commands.
CheckIndex.Status - Class in org.apache.lucene.index
Returned from CheckIndex.checkIndex() detailing the health and status of the index.
CheckIndex.Status.DocValuesStatus - Class in org.apache.lucene.index
Status from testing DocValues
CheckIndex.Status.FieldInfoStatus - Class in org.apache.lucene.index
Status from testing field infos.
CheckIndex.Status.FieldNormStatus - Class in org.apache.lucene.index
Status from testing field norms.
CheckIndex.Status.IndexSortStatus - Class in org.apache.lucene.index
Status from testing index sort
CheckIndex.Status.LiveDocStatus - Class in org.apache.lucene.index
Status from testing livedocs
CheckIndex.Status.PointsStatus - Class in org.apache.lucene.index
Status from testing PointValues
CheckIndex.Status.SegmentInfoStatus - Class in org.apache.lucene.index
Holds the status of each segment in the index.
CheckIndex.Status.SoftDeletsStatus - Class in org.apache.lucene.index
Status from testing soft deletes
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.
CheckIndex.Status.VectorValuesStatus - Class in org.apache.lucene.index
Status from testing vector values
CheckIndex.VerifyPointsVisitor - Class in org.apache.lucene.index
Walks the entire N-dimensional points space, verifying that all points fall within the last cell's boundaries.
CheckIndexException(String) - Constructor for exception org.apache.lucene.index.CheckIndex.CheckIndexException
Constructs a new CheckIndexException with the error message
CheckIndexException(String, Throwable) - Constructor for exception org.apache.lucene.index.CheckIndex.CheckIndexException
Constructs a new CheckIndexException with the error message, and the root cause
checkIndexHeader(DataInput, String, int, int, byte[], String) - Static method in class org.apache.lucene.codecs.CodecUtil
Reads and validates a header previously written with CodecUtil.writeIndexHeader(DataOutput, String, int, byte[], String).
checkIndexHeaderID(DataInput, byte[]) - Static method in class org.apache.lucene.codecs.CodecUtil
Expert: just reads and verifies the object ID of an index header
checkIndexHeaderSuffix(DataInput, String) - Static method in class org.apache.lucene.codecs.CodecUtil
Expert: just reads and verifies the suffix of an index header
checkIntegrity() - Method in class org.apache.lucene.codecs.CompoundDirectory
Checks consistency of this directory.
checkIntegrity() - Method in class org.apache.lucene.codecs.DocValuesProducer
Checks consistency of this producer
checkIntegrity() - Method in class org.apache.lucene.codecs.FieldsProducer
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.FlatVectorsReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.KnnVectorsReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.NormsProducer
Checks consistency of this producer
checkIntegrity() - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
 
checkIntegrity() - Method in class org.apache.lucene.codecs.PointsReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.PostingsReaderBase
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.StoredFieldsReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.codecs.TermVectorsReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.index.CodecReader
 
checkIntegrity() - Method in class org.apache.lucene.index.EmptyDocValuesProducer
 
checkIntegrity() - Method in class org.apache.lucene.index.FilterCodecReader
 
checkIntegrity() - Method in class org.apache.lucene.index.FilterLeafReader
 
checkIntegrity() - Method in class org.apache.lucene.index.LeafReader
Checks consistency of this reader.
checkIntegrity() - Method in class org.apache.lucene.index.ParallelLeafReader
 
checkIntegrity() - Method in class org.apache.lucene.index.SegmentReader
 
checkLatitude(double) - Static method in class org.apache.lucene.geo.GeoUtils
validates latitude value is within standard +/-90 coordinate bounds
checkLongitude(double) - Static method in class org.apache.lucene.geo.GeoUtils
validates longitude value is within standard +/-180 coordinate bounds
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.
checkPendingFlushOnUpdate - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
if an indexing thread should check for pending flushes on update in order to help out on a full flush
checkServiceName(String) - Static method in class org.apache.lucene.util.NamedSPILoader
Validates that a service name meets the requirements of NamedSPILoader.NamedSPI
checksumEntireFile(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Clones the provided input, reads all bytes from the file, and calls CodecUtil.checkFooter(org.apache.lucene.store.ChecksumIndexInput)
ChecksumIndexInput - Class in org.apache.lucene.store
Extension of IndexInput, computing checksum as it goes.
ChecksumIndexInput(String) - Constructor for class org.apache.lucene.store.ChecksumIndexInput
resourceDescription should be a non-null, opaque string describing this resource; it's returned from IndexInput.toString().
checkUnpositioned(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
Assert that the current doc is -1.
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.Scorable.ChildScorable
Child Scorer.
children() - Method in class org.apache.lucene.index.CompositeReaderContext
 
children() - Method in class org.apache.lucene.index.IndexReaderContext
Returns the context's children iff this context is a composite context otherwise null .
children() - Method in class org.apache.lucene.index.LeafReaderContext
 
ChildScorable(Scorable, String) - Constructor for class org.apache.lucene.search.Scorable.ChildScorable
Creates a new ChildScorer node with the specified relationship.
chunkSizeMask - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 
chunkSizePower - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 
Circle - Class in org.apache.lucene.geo
Represents a circle on the earth's surface.
Circle(double, double, double) - Constructor for class org.apache.lucene.geo.Circle
Creates a new circle from the supplied latitude/longitude center and a radius in meters..
classHash() - Method in class org.apache.lucene.search.Query
Provides a constant integer for a given class, derived from the name of the class.
ClassicSimilarity - Class in org.apache.lucene.search.similarities
Expert: Historical scoring implementation.
ClassicSimilarity() - Constructor for class org.apache.lucene.search.similarities.ClassicSimilarity
Sole constructor: parameter-free
ClassLoaderUtils - Interface in org.apache.lucene.util
Helper class used by ServiceLoader to investigate parent/child relationships of ClassLoaders.
ClasspathResourceLoader - Class in org.apache.lucene.util
Simple ResourceLoader that uses ClassLoader.getResourceAsStream(String) and Class.forName(String,boolean,ClassLoader) to open resources and classes, respectively.
ClasspathResourceLoader(Class<?>) - Constructor for class org.apache.lucene.util.ClasspathResourceLoader
Creates an instance using the context classloader to load Resources and classes Resources are resolved relative to the given class, if path is not absolute.
ClasspathResourceLoader(ClassLoader) - Constructor for class org.apache.lucene.util.ClasspathResourceLoader
Creates an instance using the given classloader to load Resources and classes.
clauses() - Method in class org.apache.lucene.search.BooleanQuery
Return a list of the clauses of this BooleanQuery.
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.CharArrayMap
Clears all entries in this map.
clear() - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
clear() - Method in class org.apache.lucene.analysis.CharArraySet
Clears all entries in this set.
clear() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Resets the attributes
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
clear() - Method in class org.apache.lucene.codecs.CompetitiveImpactAccumulator
Reset to the same state it was in after creation.
clear() - Method in class org.apache.lucene.document.Document
Removes all the fields from document.
clear() - Method in class org.apache.lucene.index.SegmentInfos
Clear all SegmentCommitInfos.
clear() - Method in class org.apache.lucene.index.TermStates
Clears the TermStates internal state and removes all registered TermStates
clear() - Method in class org.apache.lucene.search.BoostAttributeImpl
 
clear() - Method in class org.apache.lucene.search.DisiPriorityQueue
Clear the heap.
clear() - Method in class org.apache.lucene.search.LRUQueryCache
Clear the content of this cache.
clear() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
clear() - Method in class org.apache.lucene.search.Multiset
 
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.BitSet
Clear all the bits of the set.
clear() - Method in class org.apache.lucene.util.BytesRefArray
Clears this BytesRefArray
clear() - Method in class org.apache.lucene.util.BytesRefBuilder
Reset this builder to the empty state.
clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
clears the BytesRefHash.BytesStartArray and returns the cleared instance.
clear() - Method in class org.apache.lucene.util.BytesRefHash
 
clear() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
clear() - Method in class org.apache.lucene.util.CharsRefBuilder
Reset this builder to the empty state.
clear() - Method in class org.apache.lucene.util.FixedBitSet
 
clear() - Method in class org.apache.lucene.util.hnsw.FloatHeap
 
clear() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
clear() - Method in class org.apache.lucene.util.hnsw.NeighborArray
 
clear() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
clear() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
clear() - Method in class org.apache.lucene.util.IntsRefBuilder
Empty this builder.
clear() - Method in class org.apache.lucene.util.LongHeap
Removes all entries from the PriorityQueue.
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.SparseFixedBitSet
 
clear() - Method in class org.apache.lucene.util.WeakIdentityMap
Removes all of the mappings from this map.
clear(boolean) - Method in class org.apache.lucene.util.BytesRefHash
Clears the BytesRef which maps to the given BytesRef
clear(int) - Method in class org.apache.lucene.util.BitSet
Clear the bit at i.
clear(int) - Method in class org.apache.lucene.util.FixedBitSet
 
clear(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
Clear the bit at index i.
clear(int, int) - Method in class org.apache.lucene.util.BitSet
Clears a range of bits.
clear(int, int) - Method in class org.apache.lucene.util.FixedBitSet
 
clear(int, int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
clear(long) - Method in class org.apache.lucene.util.LongBitSet
 
clear(long, long) - Method in class org.apache.lucene.util.LongBitSet
Clears a range of bits.
clearAttributes() - Method in class org.apache.lucene.util.AttributeSource
Resets all Attributes in this AttributeSource by calling AttributeImpl.clear() on each Attribute implementation.
clearCoreCacheKey(Object) - Method in class org.apache.lucene.search.LRUQueryCache
Remove all cache entries for the given core cache key.
clearCreatedFiles() - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
clearQuery(Query) - Method in class org.apache.lucene.search.LRUQueryCache
Remove all cache entries for the given query.
clone() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clone() - Method in class org.apache.lucene.codecs.compressing.Decompressor
 
clone() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsReader
 
clone() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsReader
 
clone() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
 
clone() - Method in class org.apache.lucene.codecs.MutablePointTree
 
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.NoMergeScheduler
 
clone() - Method in interface org.apache.lucene.index.PointValues.PointTree
Clone, the current node becomes the root of the new tree.
clone() - Method in class org.apache.lucene.index.SegmentCommitInfo
 
clone() - Method in class org.apache.lucene.index.SegmentInfos
Returns a copy of this instance, also copying each SegmentInfo.
clone() - Method in class org.apache.lucene.index.TermState
 
clone() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
clone() - Method in class org.apache.lucene.store.BufferedIndexInput
 
clone() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
clone() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
clone() - Method in class org.apache.lucene.store.DataInput
Returns a clone of this stream.
clone() - Method in class org.apache.lucene.store.IndexInput
Returns a clone of this stream.
clone() - Method in class org.apache.lucene.util.AttributeImpl
In most cases the clone is, and should be, deep in order to be able to properly capture the state of all attributes.
clone() - Method in class org.apache.lucene.util.AttributeSource.State
 
clone() - Method in class org.apache.lucene.util.BytesRef
Returns a shallow clone of this instance (the underlying bytes are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.CharsRef
Returns a shallow clone of this instance (the underlying characters are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.FixedBitSet
 
clone() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
clone() - Method in class org.apache.lucene.util.IntsRef
Returns a shallow clone of this instance (the underlying ints are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.LongBitSet
 
clone() - Method in class org.apache.lucene.util.LongsRef
Returns a shallow clone of this instance (the underlying longs are not copied and will be shared by both the returned object and this object.
clone() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
cloneAttributes() - Method in class org.apache.lucene.util.AttributeSource
Performs a clone of all AttributeImpl instances returned in a new AttributeSource instance.
close() - Method in class org.apache.lucene.analysis.Analyzer
Frees persistent resources used by this Analyzer
close() - Method in class org.apache.lucene.analysis.CharFilter
Closes the underlying input stream.
close() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
 
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.FieldsConsumer
 
close() - Method in class org.apache.lucene.codecs.FieldsProducer
 
close() - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
 
close() - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene90.compressing.FieldsIndexWriter
 
close() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsReader
Close the underlying IndexInputs.
close() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsReader
 
close() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsReader
 
close() - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
close() - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
close() - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
 
close() - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
 
close() - Method in class org.apache.lucene.codecs.PostingsReaderBase
 
close() - Method in class org.apache.lucene.codecs.PostingsWriterBase
 
close() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
 
close() - Method in class org.apache.lucene.codecs.TermVectorsWriter
 
close() - Method in class org.apache.lucene.index.CheckIndex
 
close() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
close() - Method in class org.apache.lucene.index.EmptyDocValuesProducer
Closes this doc values producer.
close() - Method in class org.apache.lucene.index.IndexReader
Closes files associated with this index.
close() - Method in class org.apache.lucene.index.IndexWriter
Closes all open resources and releases the write lock.
close() - Method in class org.apache.lucene.index.MergeScheduler
Close this MergeScheduler.
close() - Method in class org.apache.lucene.index.NoMergeScheduler
 
close() - Method in class org.apache.lucene.index.SerialMergeScheduler
 
close() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
 
close() - Method in class org.apache.lucene.search.LiveFieldValues
 
close() - Method in class org.apache.lucene.search.ReferenceManager
Closes this ReferenceManager to prevent future acquiring.
close() - Method in class org.apache.lucene.search.SearcherLifetimeManager
Close this to future searching; any searches still in process in other threads won't be affected, and they should still call SearcherLifetimeManager.release(org.apache.lucene.search.IndexSearcher) after they are done.
close() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
close() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
close() - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
close() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
close() - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
close() - Method in class org.apache.lucene.store.Directory
Closes the directory.
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.FilterIndexInput
 
close() - Method in class org.apache.lucene.store.FilterIndexOutput
 
close() - Method in class org.apache.lucene.store.FSDirectory
 
close() - Method in class org.apache.lucene.store.IndexInput
Closes the stream to further operations.
close() - Method in class org.apache.lucene.store.IndexOutput
Closes this stream to further operations.
close() - Method in class org.apache.lucene.store.InputStreamDataInput
 
close() - Method in class org.apache.lucene.store.Lock
Releases exclusive access.
close() - Method in class org.apache.lucene.store.NRTCachingDirectory
Close this directory, which flushes any cached files to the delegate and then closes the delegate.
close() - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
close() - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
close() - Method in class org.apache.lucene.util.bkd.BKDWriter
 
close() - Method in class org.apache.lucene.util.bkd.HeapPointReader
 
close() - Method in class org.apache.lucene.util.bkd.HeapPointWriter
 
close() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
 
close() - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
close() - Method in class org.apache.lucene.util.BytesRefHash
Closes the BytesRefHash and releases all internally used memory
close() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
close() - Method in class org.apache.lucene.util.JavaLoggingInfoStream
 
close() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
Closes the provided IndexInput.
close() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Closes the provided IndexOutput.
close() - Method in class org.apache.lucene.util.PrintStreamInfoStream
 
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.
CloseableRandomVectorScorerSupplier - Interface in org.apache.lucene.util.hnsw
A supplier that creates RandomVectorScorer from an ordinal.
CloseableThreadLocal<T> - Class in org.apache.lucene.util
Java's builtin ThreadLocal has a serious flaw: it can take an arbitrarily long amount of time to dereference the things you had stored in it, even once the ThreadLocal instance itself is no longer referenced.
CloseableThreadLocal() - Constructor for class org.apache.lucene.util.CloseableThreadLocal
 
closeWhileHandlingException(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown non VirtualMachineError exceptions.
CLOSING - org.apache.lucene.index.MergeTrigger
Merge was triggered by a closing IndexWriter.
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 - 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_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.bkd.BKDWriter
 
CODEC_NAME - Static variable in class org.apache.lucene.util.packed.PackedInts
 
CodecReader - Class in org.apache.lucene.index
LeafReader implemented by codec APIs.
CodecReader() - Constructor for class org.apache.lucene.index.CodecReader
Sole constructor.
CodecUtil - Class in org.apache.lucene.codecs
Utility class for reading and writing versioned headers.
codePoint - Variable in class org.apache.lucene.util.UnicodeUtil.UTF8CodePoint
 
codePointAt(byte[], int, UnicodeUtil.UTF8CodePoint) - Static method in class org.apache.lucene.util.UnicodeUtil
Computes the codepoint and codepoint length (in bytes) of the specified offset in the provided utf8 byte array, assuming UTF8 encoding.
codePointCount(BytesRef) - Static method in class org.apache.lucene.util.UnicodeUtil
Returns the number of code points in this UTF8 sequence.
COLINEAR - org.apache.lucene.geo.GeoUtils.WindingOrder
 
collect(int) - Method in class org.apache.lucene.search.FilterLeafCollector
 
collect(int) - Method in interface org.apache.lucene.search.LeafCollector
Called once for every document matching a query, with the unbased document number.
collect(int) - Method in class org.apache.lucene.search.SimpleCollector
 
collect(int, float) - Method in class org.apache.lucene.search.AbstractKnnCollector
 
collect(int, float) - Method in class org.apache.lucene.search.knn.MultiLeafTopKnnCollector
 
collect(int, float) - Method in interface org.apache.lucene.search.KnnCollector
Collect the provided docId and include in the result set.
collect(int, float) - Method in class org.apache.lucene.search.TopKnnCollector
 
collect(int, float) - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
collect(int, float) - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
collect(DocIdStream) - Method in interface org.apache.lucene.search.LeafCollector
Bulk-collect doc IDs.
collectionModel - Variable in class org.apache.lucene.search.similarities.LMSimilarity
The collection model.
CollectionNodesIterator(Collection<Integer>) - Constructor for class org.apache.lucene.util.hnsw.HnswGraph.CollectionNodesIterator
Constructor for iterator based on collection representing nodes
collectionStatistics(String) - Method in class org.apache.lucene.search.IndexSearcher
Returns CollectionStatistics for a field, or null if the field does not exist (has no indexed terms)
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
Creates statistics instance for a collection (field).
CollectionTerminatedException - Exception in org.apache.lucene.search
Throw this exception in LeafCollector.collect(int) to prematurely terminate collection of the current leaf.
CollectionTerminatedException() - Constructor for exception org.apache.lucene.search.CollectionTerminatedException
Sole constructor.
CollectionUtil - Class in org.apache.lucene.util
Methods for manipulating (sorting) and creating collections.
Collector - Interface in org.apache.lucene.search
Expert: Collectors are primarily meant to be used to gather raw results from a search, and implement sorting or custom result filtering, collation, etc.
CollectorManager<C extends Collector,​T> - Interface in org.apache.lucene.search
A manager of collectors.
combine(float, boolean, float) - Method in class org.apache.lucene.search.QueryRescorer
Implement this in a subclass to combine the first pass and second pass scores.
COMMA - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
 
CommandLineUtil - Class in org.apache.lucene.util
Class containing some useful methods used by command line tools
commit - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
IndexCommit that IndexWriter is opened on.
commit() - Method in class org.apache.lucene.index.IndexWriter
Commits all pending changes (added and deleted documents, segment merges, added indexes, etc.) to the index, and syncs all referenced index files, such that a reader will see the changes and the index updates will survive an OS or machine crash or power loss.
commit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
The second phase of a 2-phase commit.
commit(Directory) - Method in class org.apache.lucene.index.SegmentInfos
Writes and syncs to the Directory dir, taking care to remove the segments file on exception
COMMIT - org.apache.lucene.index.MergeTrigger
Merge was triggered on commit.
CommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.CommitFailException
Sole constructor.
commitOnClose - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
True if calls to IndexWriter.close() should first do a commit.
common(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
common(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
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(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
common(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
common(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg common("foobar", "food") -> "foo"
commonSuffixRef - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Shared common suffix accepted by the automaton.
compact() - Method in class org.apache.lucene.util.BytesRefHash
Returns the ids array in arbitrary order.
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(byte[], byte[]) - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
 
compare(byte[], byte[]) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
Called for non-leaf cells to test how the cell relates to the query, to determine how to further recurse down the tree.
compare(byte[], byte[]) - Method in enum org.apache.lucene.index.VectorSimilarityFunction
Calculates a similarity score between the two vectors with a specified function.
compare(byte[], int, byte[], int) - Method in interface org.apache.lucene.util.ArrayUtil.ByteArrayComparator
Compare bytes starting from the given offsets.
compare(float[], float[]) - Method in enum org.apache.lucene.index.VectorSimilarityFunction
Calculates a similarity score between the two vectors with a specified function.
compare(int, int) - Method in interface org.apache.lucene.index.IndexSorter.DocComparator
Compare docID1 against docID2.
compare(int, int) - Method in class org.apache.lucene.search.comparators.DocComparator
 
compare(int, int) - Method in class org.apache.lucene.search.comparators.DoubleComparator
 
compare(int, int) - Method in class org.apache.lucene.search.comparators.FloatComparator
 
compare(int, int) - Method in class org.apache.lucene.search.comparators.IntComparator
 
compare(int, int) - Method in class org.apache.lucene.search.comparators.LongComparator
 
compare(int, int) - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
 
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.RelevanceComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compare(int, int) - Method in class org.apache.lucene.util.IntroSelector
Compare entries found in slots i and j.
compare(int, int) - Method in class org.apache.lucene.util.IntroSorter
 
compare(int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
 
compare(int, int) - Method in class org.apache.lucene.util.Sorter
Compare entries found in slots i and j.
compare(int, int) - Method in class org.apache.lucene.util.StringSorter
 
compare(BytesRef, BytesRef) - Method in class org.apache.lucene.util.BytesRefComparator
 
compare(BytesRef, BytesRef, int) - Method in class org.apache.lucene.util.BytesRefComparator
Compare two bytes refs that first k bytes are already guaranteed to be equal.
compareBottom(int) - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compareBottom(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
Compare the bottom of the queue with this doc.
compareImplementationDistance(Class<? extends C>, VirtualMethod<C>, VirtualMethod<C>) - Static method in class org.apache.lucene.util.VirtualMethod
Utility method that compares the implementation/override distance of two methods.
compareMissingValueWithBottomValue() - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
compareMissingValueWithBottomValue() - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
compareMissingValueWithBottomValue() - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
compareMissingValueWithBottomValue() - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
compareMissingValueWithBottomValue() - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
compareMissingValueWithTopValue() - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
compareMissingValueWithTopValue() - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
compareMissingValueWithTopValue() - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
compareMissingValueWithTopValue() - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
compareMissingValueWithTopValue() - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
in ascending sort, missing value is competitive when it is less or equal(maybe there are two or more comparators) than bottom value.
comparePivot(int) - Method in class org.apache.lucene.util.IntroSelector
Compare the pivot with the slot at j, similarly to compare(i, j).
comparePivot(int) - Method in class org.apache.lucene.util.IntroSorter
 
comparePivot(int) - Method in class org.apache.lucene.util.Sorter
Compare the pivot with the slot at j, similarly to compare(i, j).
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
compareSaved(int, int) - Method in class org.apache.lucene.util.TimSorter
Compare element i from the temporary storage with element j from the slice to sort, similarly to Sorter.compare(int, int).
compareTo(ConcurrentMergeScheduler.MergeThread) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
 
compareTo(IndexCommit) - Method in class org.apache.lucene.index.IndexCommit
 
compareTo(Term) - Method in class org.apache.lucene.index.Term
Compares two terms, returning a negative integer if this term belongs before the argument, zero if this term is equal to the argument, and a positive integer if this term belongs after the argument.
compareTo(PhraseQuery.PostingsAndFreq) - Method in class org.apache.lucene.search.PhraseQuery.PostingsAndFreq
 
compareTo(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Unsigned byte order comparison
compareTo(CharsRef) - Method in class org.apache.lucene.util.CharsRef
Signed int order comparison
compareTo(IntsRef) - Method in class org.apache.lucene.util.IntsRef
Signed int order comparison
compareTo(LongsRef) - Method in class org.apache.lucene.util.LongsRef
Signed int order comparison
compareTo(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValue
 
compareTop(int) - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
compareTop(int) - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
compareTop(int) - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
compareTop(int) - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compareTop(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
Compare the top value with this doc.
compareUnsigned4(byte[], int, byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Compare exactly 4 unsigned bytes from the provided arrays.
compareUnsigned8(byte[], int, byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Compare exactly 8 unsigned bytes from the provided arrays.
compareValues(Float, Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareValues(BytesRef, BytesRef) - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
 
compareValues(BytesRef, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
compareValues(T, T) - Method in class org.apache.lucene.search.FieldComparator
Returns a negative integer if first is less than second, 0 if they are equal and a positive integer otherwise.
CompetitiveImpactAccumulator - Class in org.apache.lucene.codecs
This class accumulates the (freq, norm) pairs that may produce competitive scores.
CompetitiveImpactAccumulator() - Constructor for class org.apache.lucene.codecs.CompetitiveImpactAccumulator
Sole constructor.
competitiveIterator() - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
competitiveIterator() - Method in interface org.apache.lucene.search.LeafCollector
Optionally returns an iterator over competitive documents.
competitiveIterator() - Method in interface org.apache.lucene.search.LeafFieldComparator
Returns a competitive iterator
compile() - Method in class org.apache.lucene.util.fst.FSTCompiler
Returns the metadata of the final FST.
compiled - Variable in class org.apache.lucene.search.AutomatonQuery
 
CompiledAutomaton - Class in org.apache.lucene.util.automaton
Immutable class holding compiled details for a given Automaton.
CompiledAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
Create this, passing simplify=true and finite=null, so that we try to simplify the automaton and determine if it is finite.
CompiledAutomaton(Automaton, Boolean, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
Create this.
CompiledAutomaton(Automaton, Boolean, boolean, int, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
Create this.
CompiledAutomaton.AUTOMATON_TYPE - Enum in org.apache.lucene.util.automaton
Automata are compiled into different internal forms for the most efficient execution depending upon the language they accept.
complement(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns a (deterministic) automaton that accepts the complement of the language of the given automaton.
COMPLEMENT - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables complement (~).
COMPLETE - org.apache.lucene.search.ScoreMode
Produced scorers will allow visiting all matches and get their score.
COMPLETE_NO_SCORES - org.apache.lucene.search.ScoreMode
Produced scorers will allow visiting all matches but scores won't be available.
COMPLETED - Static variable in interface org.apache.lucene.geo.Tessellator.Monitor
 
Component2D - Interface in org.apache.lucene.geo
2D Geometry object that supports spatial relationships with bounding boxes, triangles and points.
Component2D.WithinRelation - Enum in org.apache.lucene.geo
Used by withinTriangle to check the within relationship between a triangle and the query shape (e.g.
CompositeReader - Class in org.apache.lucene.index
Instances of this reader type can only be used to get stored fields from the underlying LeafReaders, but it is not possible to directly retrieve postings.
CompositeReader() - Constructor for class org.apache.lucene.index.CompositeReader
Sole constructor.
CompositeReaderContext - Class in org.apache.lucene.index
compound - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if segment is compound file format.
CompoundDirectory - Class in org.apache.lucene.codecs
A read-only Directory that consists of a view over a compound file.
CompoundDirectory() - Constructor for class org.apache.lucene.codecs.CompoundDirectory
Sole constructor.
compoundFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes compound files
compoundFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
compoundFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
CompoundFormat - Class in org.apache.lucene.codecs
Encodes/decodes compound files
CompoundFormat() - Constructor for class org.apache.lucene.codecs.CompoundFormat
Sole constructor.
compress(byte[], int, byte[], DataOutput) - Static method in class org.apache.lucene.util.compress.LowercaseAsciiCompression
Compress in[0:len] into out.
compress(byte[], int, int, DataOutput, LZ4.HashTable) - Static method in class org.apache.lucene.util.compress.LZ4
Compress bytes[off:off+len] into out using at most 16kB of memory.
compress(ByteBuffersDataInput, DataOutput) - Method in class org.apache.lucene.codecs.compressing.Compressor
Compress bytes into out.
COMPRESSED_REFS_ENABLED - Static variable in class org.apache.lucene.util.RamUsageEstimator
True, iff compressed references (oops) are enabled by this JVM
compressionAlgorithms - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Number of times each compression method has been used.
CompressionMode - Class in org.apache.lucene.codecs.compressing
A compression mode.
CompressionMode() - Constructor for class org.apache.lucene.codecs.compressing.CompressionMode
Sole constructor.
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.
compressWithDictionary(byte[], int, int, int, DataOutput, LZ4.HashTable) - Static method in class org.apache.lucene.util.compress.LZ4
Compress bytes[dictOff+dictLen:dictOff+dictLen+len] into out using at most 16kB of memory.
computeBoundingBox() - Method in class org.apache.lucene.document.LatLonShapeDocValues
 
computeBoundingBox() - Method in class org.apache.lucene.document.XYShapeDocValues
 
computeCardinality(int, int, int[]) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
Computes the cardinality of the points between from tp to
computeCentroid() - Method in class org.apache.lucene.document.LatLonShapeDocValues
 
computeCentroid() - Method in class org.apache.lucene.document.XYShapeDocValues
 
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.BM25Similarity
 
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.BooleanSimilarity
 
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 BM25Similarity.
computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
 
computeProbability(BasicStats) - Method in class org.apache.lucene.search.similarities.IndriDirichletSimilarity.IndriCollectionModel
 
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
 
concatenate(List<Automaton>) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the concatenation of the languages of the given automata.
concatenate(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the concatenation of the languages of the given automata.
ConcurrentHnswMerger - Class in org.apache.lucene.util.hnsw
This merger merges graph in a concurrent manner, by using HnswConcurrentMergeBuilder
ConcurrentHnswMerger(FieldInfo, RandomVectorScorerSupplier, int, int, TaskExecutor, int) - Constructor for class org.apache.lucene.util.hnsw.ConcurrentHnswMerger
 
ConcurrentMergeScheduler - Class in org.apache.lucene.index
A MergeScheduler that runs each merge using a separate thread.
ConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler
Sole constructor, with all settings set to default values.
ConcurrentMergeScheduler.MergeThread - Class in org.apache.lucene.index
Runs a merge thread to execute a single merge, then exits.
ConcurrentMergeSchedulerAccess - Interface in org.apache.lucene.internal.tests
Access to ConcurrentMergeScheduler internals exposed to the test framework.
config - Variable in class org.apache.lucene.util.bkd.BKDWriter
BKD tree configuration
ConjunctionUtils - Class in org.apache.lucene.search
Helper methods for building conjunction iterators
ConjunctionUtils() - Constructor for class org.apache.lucene.search.ConjunctionUtils
 
constant(double) - Static method in class org.apache.lucene.search.DoubleValuesSource
Creates a DoubleValuesSource that always returns a constant value
constant(long) - Static method in class org.apache.lucene.search.LongValuesSource
Creates a LongValuesSource that always returns a constant value
CONSTANT_SCORE_BLENDED_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
A rewrite method where documents are assigned a constant score equal to the query's boost.
CONSTANT_SCORE_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
Like MultiTermQuery.SCORING_BOOLEAN_REWRITE except scores are not computed.
CONSTANT_SCORE_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
Like ScoringRewrite.SCORING_BOOLEAN_REWRITE except scores are not computed.
CONSTANT_SCORE_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
A rewrite method that first creates a private Filter, by visiting each term in sequence and marking all docs for that term.
ConstantBulkScorer(BulkScorer, Weight, float) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
 
Constants - Class in org.apache.lucene.util
Some useful constants.
ConstantScoreQuery - Class in org.apache.lucene.search
A query that wraps another query and simply returns a constant score equal to 1 for every document that matches the query.
ConstantScoreQuery(Query) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Strips off scores from the passed in Query.
ConstantScoreQuery.ConstantBulkScorer - Class in org.apache.lucene.search
We return this as our BulkScorer so that if the CSQ wraps a query with its own optimized top-level scorer (e.g.
ConstantScoreScorer - Class in org.apache.lucene.search
A constant-scoring Scorer.
ConstantScoreScorer(Weight, float, ScoreMode, DocIdSetIterator) - Constructor for class org.apache.lucene.search.ConstantScoreScorer
Constructor based on a DocIdSetIterator which will be used to drive iteration.
ConstantScoreScorer(Weight, float, ScoreMode, TwoPhaseIterator) - Constructor for class org.apache.lucene.search.ConstantScoreScorer
Constructor based on a TwoPhaseIterator.
ConstantScoreWeight - Class in org.apache.lucene.search
A Weight that has a constant score equal to the boost of the wrapped query.
ConstantScoreWeight(Query, float) - Constructor for class org.apache.lucene.search.ConstantScoreWeight
 
consume(int[]) - Method in class org.apache.lucene.util.hnsw.HnswGraph.ArrayNodesIterator
 
consume(int[]) - Method in class org.apache.lucene.util.hnsw.HnswGraph.CollectionNodesIterator
 
consume(int[]) - Method in class org.apache.lucene.util.hnsw.HnswGraph.NodesIterator
Consume integers from the iterator and place them into the `dest` array.
consumeTerms(Query, Term...) - Method in class org.apache.lucene.search.QueryVisitor
Called by leaf queries that match on specific terms
consumeTermsMatching(Query, String, Supplier<ByteRunAutomaton>) - Method in class org.apache.lucene.search.QueryVisitor
Called by leaf queries that match on a class of terms
contains(char[], int, int) - Method in class org.apache.lucene.analysis.CharArraySet
true if the len chars of text starting at off are in the set
contains(double, double) - Method in interface org.apache.lucene.geo.Component2D
relates this component2D with a point *
contains(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
true if the CharSequence is in the set
contains(Object) - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
contains(Object) - Method in class org.apache.lucene.analysis.CharArraySet
 
contains(Object) - Method in class org.apache.lucene.search.Multiset
 
CONTAINS - org.apache.lucene.document.RangeFieldQuery.QueryType
Use this for contains
CONTAINS - org.apache.lucene.document.ShapeField.QueryRelation
used for CONTAINS Queries
containsKey(char[], int, int) - Method in class org.apache.lucene.analysis.CharArrayMap
true if the len chars of text starting at off are in the CharArrayMap.keySet()
containsKey(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
containsKey(CharSequence) - Method in class org.apache.lucene.analysis.CharArrayMap
true if the CharSequence is in the CharArrayMap.keySet()
containsKey(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
 
containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
Returns true if this map contains a mapping for the specified key.
containsLine(double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D contains the provided line *
containsLine(double, double, double, double, double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D contains the provided line *
containsPoint(double, double) - Method in class org.apache.lucene.geo.Tessellator.Triangle
utility method to compute whether the point is in the triangle
containsPoint(double, double, double, double, double, double) - Static method in interface org.apache.lucene.geo.Component2D
returns true if rectangle (defined by minX, maxX, minY, maxY) contains the X Y point
containsPoint(double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.Rectangle
returns true if rectangle (defined by minLat, maxLat, minLon, maxLon) contains the lat lon point
containsTriangle(double, double, double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D contains the provided triangle *
containsTriangle(double, double, double, double, double, double, double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D contains the provided triangle *
context - Variable in class org.apache.lucene.index.SegmentReadState
context - Variable in class org.apache.lucene.index.SegmentWriteState
IOContext for all writes; you should pass this to Directory.createOutput(String,IOContext).
context - Variable in class org.apache.lucene.store.IOContext
An object of a enumerator Context type
context - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
ControlledRealTimeReopenThread<T> - Class in org.apache.lucene.search
Utility class that runs a thread to manage periodicc reopens of a ReferenceManager, with methods to wait for a specific index changes to become visible.
ControlledRealTimeReopenThread(IndexWriter, ReferenceManager<T>, double, double) - Constructor for class org.apache.lucene.search.ControlledRealTimeReopenThread
Create ControlledRealTimeReopenThread, to periodically reopen the ReferenceManager.
convert(Automaton) - Method in class org.apache.lucene.util.automaton.UTF32ToUTF8
Converts an incoming utf32 automaton to an equivalent utf8 one.
copy() - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues.DenseOffHeapVectorValues
 
copy() - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues.DenseOffHeapVectorValues
 
copy() - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues
 
copy() - Method in interface org.apache.lucene.util.hnsw.RandomAccessVectorValues
Creates a new copy of this RandomAccessVectorValues.
copy() - Method in class org.apache.lucene.util.hnsw.RandomVectorScorerSupplier.ByteScoringSupplier
 
copy() - Method in interface org.apache.lucene.util.hnsw.RandomVectorScorerSupplier
Make a copy of the supplier, which will copy the underlying vectorValues so the copy is safe to be used in other threads.
copy() - Method in class org.apache.lucene.util.hnsw.RandomVectorScorerSupplier.FloatScoringSupplier
 
copy() - Method in interface org.apache.lucene.util.quantization.RandomAccessQuantizedByteVectorValues
 
copy() - Method in class org.apache.lucene.util.quantization.ScalarQuantizedRandomVectorScorerSupplier
 
copy(int, int) - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
copy(int, int) - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
copy(int, int) - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
copy(int, int) - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
copy(int, int) - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
copy(int, int) - Method in interface org.apache.lucene.search.LeafFieldComparator
This method is called when a new hit is competitive.
copy(int, int) - Method in class org.apache.lucene.util.TimSorter
Copy data from slot src to slot dest.
copy(Map<?, ? extends V>) - Static method in class org.apache.lucene.analysis.CharArrayMap
Returns a copy of the given map as a CharArrayMap.
copy(Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
Returns a copy of the given set as a CharArraySet.
copy(CompetitiveImpactAccumulator) - Method in class org.apache.lucene.codecs.CompetitiveImpactAccumulator
Replace the content of this acc with the provided acc.
copy(IndexInput, long) - Method in class org.apache.lucene.util.PagedBytes
Read this many bytes from in
copy(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Copies over all states/transitions from other.
copy(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
Copies over all states/transitions from other.
copy(BytesRef, BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy BytesRef in, setting BytesRef out to the result.
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.
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(byte[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this builder with the provided bytes.
copyBytes(DataInput, long) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
copyBytes(DataInput, long) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
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.BytesRefBuilder
Replace the content of this builder with the provided bytes.
copyBytes(BytesRefBuilder) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this builder with the provided bytes.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this buffer with UTF-8 encoded bytes that would represent the provided text.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
Copies the given array into this instance.
copyChars(CharSequence) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this buffer with UTF-8 encoded bytes that would represent the provided text.
copyChars(CharSequence, int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
Replace the content of this buffer with UTF-8 encoded bytes that would represent the provided text.
copyChars(CharsRef) - Method in class org.apache.lucene.util.CharsRefBuilder
Copies the given CharsRef referenced content into this instance.
copyFrom(TermState) - Method in class org.apache.lucene.codecs.BlockTermState
 
copyFrom(TermState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
 
copyFrom(TermState) - Method in class org.apache.lucene.index.OrdTermState
 
copyFrom(TermState) - Method in class org.apache.lucene.index.TermState
Copies the content of the given TermState to this instance
copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.Directory
Copies an existing src file from directory from to a non-existent file dest in this directory.
copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
copyFrom(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST.Arc
Returns this
copyInts(int[], int, int) - Method in class org.apache.lucene.util.IntsRefBuilder
Copies the given array into this instance.
copyInts(IntsRef) - Method in class org.apache.lucene.util.IntsRefBuilder
Copies the given array into this instance.
copyOf(Bits) - Static method in class org.apache.lucene.util.FixedBitSet
Make a copy of the given bits.
copyOfSubArray(byte[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyOfSubArray(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyOfSubArray(double[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyOfSubArray(float[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyOfSubArray(int[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyOfSubArray(long[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyOfSubArray(short[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyOfSubArray(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Copies the specified range of the given array into a new sub array.
copyStates(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Copies over all states from other.
copyTo(DataOutput) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
Copy the current content of this object into another DataOutput.
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
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.MaxNonCompetitiveBoostAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.util.AttributeImpl
Copies the values from this Attribute into the passed-in target attribute.
copyTo(AttributeSource) - Method in class org.apache.lucene.util.AttributeSource
Copies the contents of this AttributeSource to the given target AttributeSource.
copyUsingLengthPrefix(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy bytes in, writing the length as a 1 or 2 byte vInt prefix.
copyUTF8Bytes(byte[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
Copy the provided bytes, interpreted as UTF-8 bytes.
copyUTF8Bytes(BytesRef) - Method in class org.apache.lucene.util.CharsRefBuilder
Copy the provided bytes, interpreted as UTF-8 bytes.
copyUTF8Bytes(BytesRef) - Method in class org.apache.lucene.util.IntsRefBuilder
Copy the given UTF-8 bytes into this builder.
copyValue(T) - Method in class org.apache.lucene.codecs.KnnFieldVectorsWriter
Used to copy values being indexed to internal storage.
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, String) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with a message only
CorruptIndexException(String, String, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with message and root cause.
CorruptIndexException(String, DataInput) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with a message only
CorruptIndexException(String, DataInput, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with message and root cause.
CorruptIndexException(String, DataOutput) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with a message only
CorruptIndexException(String, DataOutput, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
Create exception with message and root cause.
cos(double) - Static method in class org.apache.lucene.util.SloppyMath
Returns the trigonometric cosine of an angle.
cosine(byte[], byte[]) - Method in interface org.apache.lucene.internal.vectorization.VectorUtilSupport
Returns the cosine similarity between the two byte vectors.
cosine(byte[], byte[]) - Static method in class org.apache.lucene.util.VectorUtil
Returns the cosine similarity between the two vectors.
cosine(float[], float[]) - Method in interface org.apache.lucene.internal.vectorization.VectorUtilSupport
Returns the cosine similarity between the two vectors.
cosine(float[], float[]) - Static method in class org.apache.lucene.util.VectorUtil
Returns the cosine similarity between the two vectors.
COSINE - org.apache.lucene.index.VectorSimilarityFunction
Cosine similarity.
cost - Variable in class org.apache.lucene.search.DisiWrapper
 
cost() - Method in class org.apache.lucene.codecs.lucene90.IndexedDISI
 
cost() - Method in class org.apache.lucene.document.BinaryRangeDocValues
 
cost() - Method in class org.apache.lucene.index.ByteVectorValues
 
cost() - Method in class org.apache.lucene.index.FilterBinaryDocValues
 
cost() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
cost() - Method in class org.apache.lucene.index.FilterNumericDocValues
 
cost() - Method in class org.apache.lucene.index.FilterSortedDocValues
 
cost() - Method in class org.apache.lucene.index.FilterSortedNumericDocValues
 
cost() - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
cost() - Method in class org.apache.lucene.index.FloatVectorValues
 
cost() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
cost() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
cost() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
cost() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
cost() - Method in class org.apache.lucene.search.BulkScorer
Same as DocIdSetIterator.cost() for bulk scorers.
cost() - Method in class org.apache.lucene.search.comparators.MinDocIterator
 
cost() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
 
cost() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
cost() - Method in class org.apache.lucene.search.DocIdSetIterator
Returns the estimated cost of this DocIdSetIterator.
cost() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
cost() - Method in class org.apache.lucene.search.ImpactsDISI
 
cost() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
cost() - Method in class org.apache.lucene.search.ScorerSupplier
Get an estimate of the Scorer that would be returned by ScorerSupplier.get(long).
cost() - Method in class org.apache.lucene.search.Weight.DefaultBulkScorer
 
cost() - Method in class org.apache.lucene.util.BitSetIterator
 
cost() - Method in class org.apache.lucene.util.DocBaseBitSetIterator
 
count - Variable in class org.apache.lucene.util.bkd.BKDRadixSelector.PathSlice
 
count - Variable in class org.apache.lucene.util.SentinelIntSet
 
count() - Method in class org.apache.lucene.search.DocIdStream
Count the number of entries in this stream.
count() - Method in class org.apache.lucene.search.LRUQueryCache.CacheAndCount
 
count() - Method in class org.apache.lucene.util.bkd.HeapPointWriter
 
count() - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
count() - Method in interface org.apache.lucene.util.bkd.PointWriter
Return the number of points in this writer
count(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
Counts the number of live documents that match a given Weight.parentQuery in a leaf.
count(Query) - Method in class org.apache.lucene.search.IndexSearcher
Count how many documents match the given query.
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() - Method in class org.apache.lucene.analysis.TokenizerFactory
Creates a TokenStream of the specified input using the default attribute factory.
create(boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
Creates a CachingCollector which does not wrap another collector.
create(int, int) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Deprecated.
This method is deprecated in favor of the constructor of TopScoreDocCollectorManager due to its support for concurrency in IndexSearcher
create(int, ScoreDoc, int) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Deprecated.
This method is deprecated in favor of the constructor of TopScoreDocCollectorManager due to its support for concurrency in IndexSearcher
create(Reader) - Method in class org.apache.lucene.analysis.CharFilterFactory
Wraps the given Reader with a CharFilter.
create(TokenStream) - Method in class org.apache.lucene.analysis.TokenFilterFactory
Transform the specified input TokenStream
create(LatLonGeometry...) - Static method in class org.apache.lucene.geo.LatLonGeometry
Creates a Component2D from the provided LatLonGeometry array
create(XYGeometry...) - Static method in class org.apache.lucene.geo.XYGeometry
Creates a Component2D from the provided XYGeometries array
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, int) - Static method in class org.apache.lucene.search.TopFieldCollector
Deprecated.
This method is deprecated in favor of the constructor of TopFieldCollectorManager due to its support for concurrency in IndexSearcher
create(Sort, int, FieldDoc, int) - Static method in class org.apache.lucene.search.TopFieldCollector
Deprecated.
This method is deprecated in favor of the constructor of TopFieldCollectorManager due to its support for concurrency in IndexSearcher
create(AttributeFactory) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerFactory
 
create(AttributeFactory) - Method in class org.apache.lucene.analysis.TokenizerFactory
Creates a TokenStream of the specified input using the given AttributeFactory
create(RandomVectorScorerSupplier, int, int, long) - Static method in class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
create(RandomVectorScorerSupplier, int, int, long, int) - Static method in class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
CREATE - org.apache.lucene.index.IndexWriterConfig.OpenMode
Creates a new index or overwrites an existing one.
CREATE_OR_APPEND - org.apache.lucene.index.IndexWriterConfig.OpenMode
Creates a new index if one does not exist, otherwise it opens the index and documents will be appended.
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeFactory
Returns an AttributeImpl for the supplied Attribute interface class.
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
 
createBlockSlice(IndexInput, String, long, long, int) - Static method in class org.apache.lucene.codecs.lucene90.IndexedDISI
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.
createBuilder(DocIdSetIterator, int) - Method in class org.apache.lucene.util.hnsw.ConcurrentHnswMerger
 
createBuilder(DocIdSetIterator, int) - Method in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
Builds a new HnswGraphBuilder using the biggest graph from the merge state as a starting point.
createBytes(RandomAccessVectorValues<byte[]>, VectorSimilarityFunction) - Static method in interface org.apache.lucene.util.hnsw.RandomVectorScorerSupplier
Creates a RandomVectorScorerSupplier to compare byte vectors.
createBytes(RandomAccessVectorValues<byte[]>, VectorSimilarityFunction, byte[]) - Static method in interface org.apache.lucene.util.hnsw.RandomVectorScorer
Creates a default scorer for byte vectors.
createComponentPredicate(Component2D) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Create a predicate that checks whether points are within a geometry.
createComponents(String) - Method in class org.apache.lucene.analysis.Analyzer
Creates a new Analyzer.TokenStreamComponents instance for this analyzer.
createComponents(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
createComponents(String) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
 
createConjunction(List<DocIdSetIterator>, List<TwoPhaseIterator>) - Static method in class org.apache.lucene.search.ConjunctionUtils
Create a conjunction over the provided set of DocIdSetIterators and TwoPhaseIterators, using two-phase iterator where possible.
createDistancePredicate(double, double, double) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Create a predicate that checks whether points are within a distance of a given point.
createDocValueField(String, double, double) - Static method in class org.apache.lucene.document.LatLonShape
create doc value field for lat lon line geometry without creating indexable fields.
createDocValueField(String, float, float) - Static method in class org.apache.lucene.document.XYShape
create a XYShapeDocValuesField for cartesian points without creating indexable fields.
createDocValueField(String, List<ShapeField.DecodedTriangle>) - Static method in class org.apache.lucene.document.LatLonShape
create a LatLonShapeDocValuesField from an existing tessellation
createDocValueField(String, List<ShapeField.DecodedTriangle>) - Static method in class org.apache.lucene.document.XYShape
create a XYShapeDocValuesField from a precomputed tessellation
createDocValueField(String, Field[]) - Static method in class org.apache.lucene.document.LatLonShape
create a shape docvalue field from indexable fields
createDocValueField(String, Line) - Static method in class org.apache.lucene.document.LatLonShape
create doc value field for lat lon line geometry without creating indexable fields.
createDocValueField(String, Polygon) - Static method in class org.apache.lucene.document.LatLonShape
create doc value field for lat lon polygon geometry without creating indexable fields
createDocValueField(String, Polygon, boolean) - Static method in class org.apache.lucene.document.LatLonShape
create doc value field for lat lon polygon geometry without creating indexable fields.
createDocValueField(String, XYLine) - Static method in class org.apache.lucene.document.XYShape
create doc value field for x, y line geometry without creating indexable fields.
createDocValueField(String, XYPolygon) - Static method in class org.apache.lucene.document.XYShape
create doc value field for X,Y polygon geometry without creating indexable fields
createDocValueField(String, XYPolygon, boolean) - Static method in class org.apache.lucene.document.XYShape
create doc value field for lat lon polygon geometry without creating indexable fields.
createDocValueField(String, BytesRef) - Static method in class org.apache.lucene.document.LatLonShape
create a LatLonShapeDocValuesField from an existing encoded representation
createDocValueField(String, BytesRef) - Static method in class org.apache.lucene.document.XYShape
create a XYShapeDocValuesField from an existing encoded representation
createdVersionMajor - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Compatibility version to use for this index.
createFieldQuery(Analyzer, BooleanClause.Occur, String, String, boolean, int) - Method in class org.apache.lucene.util.QueryBuilder
Creates a query from the analysis chain.
createFieldQuery(TokenStream, BooleanClause.Occur, String, boolean, int) - Method in class org.apache.lucene.util.QueryBuilder
Creates a query from a token stream.
createFieldType(int, VectorSimilarityFunction) - Static method in class org.apache.lucene.document.KnnByteVectorField
A convenience method for creating a vector field type.
createFieldType(int, VectorSimilarityFunction) - Static method in class org.apache.lucene.document.KnnFloatVectorField
A convenience method for creating a vector field type.
createFloats(RandomAccessVectorValues<float[]>, VectorSimilarityFunction) - Static method in interface org.apache.lucene.util.hnsw.RandomVectorScorerSupplier
Creates a RandomVectorScorerSupplier to compare float vectors.
createFloats(RandomAccessVectorValues<float[]>, VectorSimilarityFunction, float[]) - Static method in interface org.apache.lucene.util.hnsw.RandomVectorScorer
Creates a default scorer for float vectors.
createIndexableFields(String, double, double) - Static method in class org.apache.lucene.document.LatLonShape
create indexable fields for point geometry
createIndexableFields(String, float, float) - Static method in class org.apache.lucene.document.XYShape
create indexable fields for cartesian point geometry
createIndexableFields(String, Line) - Static method in class org.apache.lucene.document.LatLonShape
create indexable fields for line geometry
createIndexableFields(String, Polygon) - Static method in class org.apache.lucene.document.LatLonShape
create indexable fields for polygon geometry.
createIndexableFields(String, Polygon, boolean) - Static method in class org.apache.lucene.document.LatLonShape
create indexable fields for polygon geometry.
createIndexableFields(String, XYLine) - Static method in class org.apache.lucene.document.XYShape
create indexable fields for cartesian line geometry
createIndexableFields(String, XYPolygon) - Static method in class org.apache.lucene.document.XYShape
create indexable fields for cartesian polygon geometry
createIndexableFields(String, XYPolygon, boolean) - Static method in class org.apache.lucene.document.XYShape
create indexable fields for cartesian polygon geometry.
createInstance() - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
Creates an instance of A.
createJumpTable(IndexInput, long, long, int) - Static method in class org.apache.lucene.codecs.lucene90.IndexedDISI
createLatLonShapeDocValues(BytesRef) - Static method in class org.apache.lucene.document.LatLonShape
Factory method for creating the LatLonShapeDocValues
createMinShouldMatchQuery(String, String, float) - Method in class org.apache.lucene.util.QueryBuilder
Creates a minimum-should-match query from the query text.
createOutput(String, IOContext) - Method in class org.apache.lucene.codecs.CompoundDirectory
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.Directory
Creates a new, empty file in the directory and returns an IndexOutput instance for appending data to this file.
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
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
createOutput(String, IOContext) - Method in class org.apache.lucene.store.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.
createSharedManager(int, ScoreDoc, int) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Deprecated.
This method is deprecated in favor of the constructor of TopScoreDocCollectorManager due to its support for concurrency in IndexSearcher
createSharedManager(Sort, int, FieldDoc, int) - Static method in class org.apache.lucene.search.TopFieldCollector
Deprecated.
This method is deprecated in favor of the constructor of TopFieldCollectorManager due to its support for concurrency in IndexSearcher
createState() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Create a new state.
createState() - Method in class org.apache.lucene.util.automaton.Automaton
Create a new state.
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.codecs.CompoundDirectory
 
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.Directory
Creates a new, empty, temporary file in the directory and returns an IndexOutput instance for appending data to this file.
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
 
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.FSDirectory
 
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.document.RangeFieldQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.document.XYDocValuesPointInGeometryQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.BooleanQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.BoostQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create the Weight used to score us
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.FieldExistsQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.IndriAndQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.IndriQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.MatchNoDocsQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.PhraseQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.PointInSetQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.PointRangeQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.Query
Expert: Constructs an appropriate Weight implementation for this query.
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.SynonymQuery
 
createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.search.TermQuery
 
createWeight(Query, ScoreMode, float) - Method in class org.apache.lucene.search.IndexSearcher
Creates a Weight for the given query, potentially adding caching if possible and configured.
createXYShapeDocValues(BytesRef) - Static method in class org.apache.lucene.document.XYShape
Factory method for creating the XYShapeDocValues
CROSSES - org.apache.lucene.document.RangeFieldQuery.QueryType
Use this for crosses queries
crossesDateline() - Method in class org.apache.lucene.geo.Rectangle
Returns true if this bounding box crosses the dateline
curBuf - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 
curBufIndex - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 
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
 
currentState(String, List<Point>, List<Tessellator.Triangle>) - Method in interface org.apache.lucene.geo.Tessellator.Monitor
Each loop of the main earclip algorithm will call this with the current state
currentValue() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
returns the value associated with the last key returned
CUSTOM - org.apache.lucene.search.SortField.Type
Sort using a custom Comparator.
CW - org.apache.lucene.geo.GeoUtils.WindingOrder
 
cX - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
x coordinate, vertex three
cY - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
y coordinate, vertex three

D

DaciukMihovAutomatonBuilder - Class in org.apache.lucene.util.automaton
Deprecated.
Visibility of this class will be reduced in a future release. Users can access this functionality directly through Automata.makeStringUnion(Iterable)
DATA_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene90.Lucene90PointsFormat
Filename extension for the leaf blocks
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
 
dataOut - Variable in class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
Outputs used to write the BKD tree data files.
dataOutput(DataOutput) - Method in class org.apache.lucene.util.fst.FSTCompiler.Builder
Set the DataOutput which is used for low-level writing of FST.
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.
DAY - org.apache.lucene.document.DateTools.Resolution
Limit a date's resolution to day granularity.
decode(byte[]) - Static method in class org.apache.lucene.document.InetAddressPoint
Decodes InetAddress value from binary encoding
decode(byte[], int) - Static method in class org.apache.lucene.geo.XYEncodingUtils
Turns quantized value from byte array back into a double.
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.
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(int) - Static method in class org.apache.lucene.geo.XYEncodingUtils
Turns quantized value from XYEncodingUtils.encode(float) back into a double.
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(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.
decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.DoublePoint
Decode single double dimension
decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.FloatPoint
Decode single float dimension
decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.IntPoint
Decode single integer dimension
decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.LongPoint
Decode single long dimension
DecodedTriangle() - Constructor for class org.apache.lucene.document.ShapeField.DecodedTriangle
default xtor
decodeLatitude(byte[], int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Turns quantized value from byte array back into a double.
decodeLatitude(int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Turns quantized value from GeoEncodingUtils.encodeLatitude(double) back into a double.
decodeLongitude(byte[], int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Turns quantized value from byte array back into a double.
decodeLongitude(int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Turns quantized value from GeoEncodingUtils.encodeLongitude(double) back into a double.
decodeTerm(DataInput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
decodeTerm(DataInput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.PostingsReaderBase
Actually decode metadata for next term
decodeTriangle(byte[], ShapeField.DecodedTriangle) - Static method in class org.apache.lucene.document.ShapeField
decodeX(int) - Method in class org.apache.lucene.document.LatLonShapeDocValuesField
 
decodeX(int) - Method in class org.apache.lucene.document.ShapeDocValuesField
decodes x coordinates from encoded space
decodeX(int) - Method in class org.apache.lucene.document.XYShapeDocValuesField
 
decodeY(int) - Method in class org.apache.lucene.document.LatLonShapeDocValuesField
 
decodeY(int) - Method in class org.apache.lucene.document.ShapeDocValuesField
decodes y coordinates from encoded space
decodeY(int) - Method in class org.apache.lucene.document.XYShapeDocValuesField
 
decompress(DataInput, byte[], int) - Static method in class org.apache.lucene.util.compress.LowercaseAsciiCompression
Decompress data that has been compressed with LowercaseAsciiCompression.compress(byte[], int, byte[], DataOutput).
decompress(DataInput, int, byte[], int) - Static method in class org.apache.lucene.util.compress.LZ4
Decompress at least decompressedLen bytes into dest[dOff:].
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 .
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.
decRef() - Method in class org.apache.lucene.index.IndexReader
Expert: decreases the refCount of this IndexReader instance.
decRef() - Method in class org.apache.lucene.util.FileDeleter.RefCount
 
decRef() - Method in class org.apache.lucene.util.RefCount
Decrements the reference counting of this object.
decRef(G) - Method in class org.apache.lucene.search.ReferenceManager
Decrement reference counting on the given reference.
decRef(Collection<String>) - Method in class org.apache.lucene.util.FileDeleter
Decrease ref counts for all provided files, delete them if ref counts down to 0, even on exception.
decRef(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
 
decRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
 
decRefDeleter(SegmentInfos) - Method in class org.apache.lucene.index.IndexWriter
Record that the files referenced by this SegmentInfos are no longer in use.
deepCopyOf(BytesRef) - Static method in class org.apache.lucene.util.BytesRef
Creates a new BytesRef that points to a copy of the bytes from other
deepCopyOf(CharsRef) - Static method in class org.apache.lucene.util.CharsRef
Creates a new CharsRef that points to a copy of the chars from other
deepCopyOf(IntsRef) - Static method in class org.apache.lucene.util.IntsRef
Creates a new IntsRef that points to a copy of the ints from other
deepCopyOf(LongsRef) - Static method in class org.apache.lucene.util.LongsRef
Creates a new LongsRef that points to a copy of the longs from other
DEFAULT - org.apache.lucene.store.IOContext.Context
 
DEFAULT - Static variable in class org.apache.lucene.store.IOContext
 
DEFAULT - Static variable in class org.apache.lucene.util.packed.PackedInts
At most 25% memory overhead.
DEFAULT_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.util.AttributeFactory
This is the default factory that creates AttributeImpls using the class name of the supplied Attribute interface class by appending Impl to it.
DEFAULT_BEAM_WIDTH - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
Default number of the size of the queue maintained while searching during a graph construction.
DEFAULT_BEAM_WIDTH - Static variable in class org.apache.lucene.util.hnsw.HnswGraphBuilder
Default number of the size of the queue maintained while searching during a graph construction.
DEFAULT_BOOST - Static variable in interface org.apache.lucene.search.BoostAttribute
 
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.lucene.util.packed.PackedInts
Default amount of memory to use for bulk operations.
DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
DEFAULT_BUFFERSIZE - Static variable in class org.apache.lucene.store.BufferedChecksum
Default buffer size: 1024
DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
 
DEFAULT_COMMIT_ON_CLOSE - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value for whether calls to IndexWriter.close() include a commit.
DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.util.OfflineSorter
Default comparator: sorts in binary (codepoint) order
DEFAULT_CPU_CORE_COUNT_PROPERTY - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Used for testing.
DEFAULT_DENSE_RANK_POWER - Static variable in class org.apache.lucene.codecs.lucene90.IndexedDISI
 
DEFAULT_DETERMINIZE_WORK_LIMIT - Static variable in class org.apache.lucene.util.automaton.Operations
Default maximum effort that Operations.determinize(org.apache.lucene.util.automaton.Automaton, int) should spend before giving up and throwing TooComplexToDeterminizeException.
DEFAULT_EXPECTED_ELEMENTS - Static variable in class org.apache.lucene.util.hppc.IntIntHashMap
 
DEFAULT_LOAD_FACTOR - Static variable in class org.apache.lucene.util.hppc.IntIntHashMap
 
DEFAULT_MAX_BITS_PER_BLOCK - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
Default maxBitsPerBlock
DEFAULT_MAX_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsWriter
Suggested default value for the maxItemsInBlock parameter to Lucene90BlockTreeTermsWriter(SegmentWriteState,PostingsWriterBase,int,int).
DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_CFS_SEGMENT_SIZE - Static variable in class org.apache.lucene.index.MergePolicy
Default max segment size in order to use compound file system.
DEFAULT_MAX_CHUNK_SIZE - Static variable in class org.apache.lucene.store.MMapDirectory
Default max chunk size: 16 GiBytes for 64 bit Java 19 / 20 / 21 JVMs 1 GiBytes for other 64 bit JVMs 256 MiBytes for 32 bit JVMs
DEFAULT_MAX_CONN - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
Default number of maximum connections per node
DEFAULT_MAX_CONN - Static variable in class org.apache.lucene.util.hnsw.HnswGraphBuilder
Default number of maximum connections per node
DEFAULT_MAX_DIMENSIONS - Static variable in class org.apache.lucene.codecs.KnnVectorsFormat
The maximum number of vector dimensions
DEFAULT_MAX_FULL_FLUSH_MERGE_WAIT_MILLIS - Static variable in class org.apache.lucene.index.IndexWriterConfig
DEFAULT_MAX_MB_SORT_IN_HEAP - Static variable in class org.apache.lucene.util.bkd.BKDWriter
Default maximum heap to use, before spilling to (slower) disk
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_POINTS_IN_LEAF_NODE - Static variable in class org.apache.lucene.util.bkd.BKDConfig
Default maximum number of point in each leaf block
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.standard.StandardAnalyzer
Default maximum allowed token length
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_BITS_PER_BLOCK - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
Default minBitsPerBlock
DEFAULT_MIN_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsWriter
Suggested default value for the minItemsInBlock parameter to Lucene90BlockTreeTermsWriter(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_NUM_MERGE_WORKER - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
Default to use single thread merge
DEFAULT_POLL_INTERVAL - Static variable in class org.apache.lucene.store.SleepingLockWrapper
How long SleepingLockWrapper.obtainLock(java.lang.String) waits, in milliseconds, in between attempts to acquire the lock.
DEFAULT_PROVIDER - Static variable in class org.apache.lucene.search.RegexpQuery
A provider that provides no named automata
DEFAULT_RAM_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 16 MB (which means flush when buffered docs consume approximately 16 MB RAM).
DEFAULT_RAM_PER_THREAD_HARD_LIMIT_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 1945.
DEFAULT_READER_POOLING - Static variable in class org.apache.lucene.index.IndexWriterConfig
DEFAULT_RESOLUTION - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
DEFAULT_TOKEN_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.analysis.TokenStream
Default AttributeFactory instance that should be used for TokenStreams.
DEFAULT_TYPE - Static variable in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
the default type
DEFAULT_USE_COMPOUND_FILE_SYSTEM - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value for compound file system for newly written segments (set to true).
DefaultBulkScorer(Scorer) - Constructor for class org.apache.lucene.search.Weight.DefaultBulkScorer
Sole constructor.
DefaultCollectionModel() - Constructor for class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
Sole constructor: parameter-free
defaultCtorException() - Static method in class org.apache.lucene.analysis.AbstractAnalysisFactory
Helper method to be called from mandatory default constructor of all subclasses to make ServiceLoader happy.
defaultMaxEdits - Static variable in class org.apache.lucene.search.FuzzyQuery
 
defaultMaxExpansions - Static variable in class org.apache.lucene.search.FuzzyQuery
 
defaultPrefixLength - Static variable in class org.apache.lucene.search.FuzzyQuery
 
defaultRewriteMethod(int) - Static method in class org.apache.lucene.search.FuzzyQuery
Creates a default top-terms blended frequency scoring rewrite with the given max expansions
defaultTranspositions - Static variable in class org.apache.lucene.search.FuzzyQuery
 
DeflateWithPresetDictCompressionMode - Class in org.apache.lucene.codecs.lucene90
A compression mode that trades speed for compression ratio.
DeflateWithPresetDictCompressionMode() - Constructor for class org.apache.lucene.codecs.lucene90.DeflateWithPresetDictCompressionMode
Sole constructor.
deinterleave(long) - Static method in class org.apache.lucene.util.BitUtil
Extract just the even-bits value as a long from the bit-interleaved value
delCountOnFlush - Variable in class org.apache.lucene.index.SegmentWriteState
Number of deleted documents set while flushing the segment.
delegate - Variable in class org.apache.lucene.codecs.FilterCodec
The codec to filter.
DelegatingAnalyzerWrapper - Class in org.apache.lucene.analysis
An analyzer wrapper, that doesn't allow to wrap components or readers.
DelegatingAnalyzerWrapper(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
Constructor.
DelegatingCacheHelper(IndexReader.CacheHelper) - Constructor for class org.apache.lucene.index.FilterDirectoryReader.DelegatingCacheHelper
Create a new DelegatingCacheHelper that delegates the cache onClose listener to another CacheHelper, but with its own unique CacheKey.
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.
deleteDocuments(Term...) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) containing any of the terms.
deleteDocuments(Query...) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) matching any of the provided queries.
deleteFile(String) - Method in class org.apache.lucene.codecs.CompoundDirectory
Not implemented
deleteFile(String) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
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
 
deleteFile(String) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
deleteFile(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
deleteFile(String) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
deleteFileIfNoRef(String) - Method in class org.apache.lucene.util.FileDeleter
 
deleteFiles(Directory, Collection<String>) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given file names.
deleteFilesIfExist(Path...) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given Paths, if they exist.
deleteFilesIfExist(Collection<? extends Path>) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given Paths, if they exist.
deleteFilesIfNoRef(Collection<String>) - Method in class org.apache.lucene.util.FileDeleter
delete only files that are unref'ed
deleteFilesIgnoringExceptions(Path...) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteFilesIgnoringExceptions(Collection<? extends Path>) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deleteFilesIgnoringExceptions(Directory, String...) - Static method in class org.apache.lucene.util.IOUtils
 
deleteFilesIgnoringExceptions(Directory, Collection<String>) - Static method in class org.apache.lucene.util.IOUtils
Deletes all given files, suppressing all thrown IOExceptions.
deletePendingFiles() - Method in class org.apache.lucene.store.FSDirectory
Try to delete any pending files that we had previously tried to delete but failed because we are on Windows and the files were still held open.
deleteUnusedFiles() - Method in class org.apache.lucene.index.IndexWriter
Expert: remove any index files that are no longer used.
deletionsGen - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Current deletions generation.
delGen() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
Del gen of the current term.
delPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
IndexDeletionPolicy controlling when commit points are deleted.
deltaPackedBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
 
deltaPackedBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
Return a new PackedLongValues.Builder that will compress efficiently integers that are close to each other.
delTermCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Number of terms with zero live docs docs.
DenseOffHeapVectorValues(int, int, IndexInput) - Constructor for class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues
 
DenseOffHeapVectorValues(int, int, IndexInput, int) - Constructor for class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues.DenseOffHeapVectorValues
 
DenseOffHeapVectorValues(int, int, IndexInput, int) - Constructor for class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues.DenseOffHeapVectorValues
 
deQuantize(byte[], float[]) - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
Dequantize a byte vector into a float vector
dest - Variable in class org.apache.lucene.util.automaton.Transition
Destination state.
destroy() - Method in class org.apache.lucene.util.bkd.HeapPointWriter
 
destroy() - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
destroy() - Method in interface org.apache.lucene.util.bkd.PointWriter
Removes any temp files behind this writer
determinize(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
Determinizes the given automaton.
DFISimilarity - Class in org.apache.lucene.search.similarities
Implements the Divergence from Independence (DFI) model based on Chi-square statistics (i.e., standardized Chi-squared distance from independence in term frequency tf).
DFISimilarity(Independence) - Constructor for class org.apache.lucene.search.similarities.DFISimilarity
Create DFI with the specified divergence from independence measure
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
digits - Variable in class org.apache.lucene.util.automaton.RegExp
Limits for repeatable type expressions
dimension - Variable in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
dimension - Variable in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
dimension - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
dimension() - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
dimension() - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
dimension() - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
dimension() - Method in class org.apache.lucene.index.ByteVectorValues
Return the dimension of the vectors
dimension() - Method in class org.apache.lucene.index.FilterVectorValues
 
dimension() - Method in class org.apache.lucene.index.FloatVectorValues
Return the dimension of the vectors
dimension() - Method in interface org.apache.lucene.util.hnsw.RandomAccessVectorValues
Return the dimension of the returned vector values
dir - Variable in class org.apache.lucene.index.CheckIndex.Status
Directory index is in.
dir - Variable in class org.apache.lucene.index.SegmentInfo
Where this segment resides.
directAddressingMaxOversizingFactor(float) - Method in class org.apache.lucene.util.fst.FSTCompiler.Builder
Overrides the default the maximum oversizing of fixed array allowed to enable direct addressing of arcs instead of binary search.
DirectAllocator() - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
DirectAllocator() - Constructor for class org.apache.lucene.util.IntBlockPool.DirectAllocator
Creates a new IntBlockPool.DirectAllocator with a default block size
DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
DirectBytesStartArray(int, Counter) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
DirectMonotonicReader - Class in org.apache.lucene.util.packed
Retrieves an instance previously written by DirectMonotonicWriter.
DirectMonotonicReader.Meta - Class in org.apache.lucene.util.packed
In-memory metadata that needs to be kept around for DirectMonotonicReader to read data from disk.
DirectMonotonicWriter - Class in org.apache.lucene.util.packed
Write monotonically-increasing sequences of integers.
directory - Variable in class org.apache.lucene.index.DirectoryReader
The index directory.
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 - Variable in class org.apache.lucene.store.FSDirectory
 
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 - Class in org.apache.lucene.store
A Directory provides an abstraction layer for storing a list of files.
Directory() - Constructor for class org.apache.lucene.store.Directory
 
DirectoryReader - Class in org.apache.lucene.index
DirectoryReader is an implementation of CompositeReader that can read indexes in a Directory.
DirectoryReader(Directory, LeafReader[], Comparator<LeafReader>) - Constructor for class org.apache.lucene.index.DirectoryReader
Expert: Constructs a DirectoryReader on the given subReaders.
DirectReader - Class in org.apache.lucene.util.packed
Retrieves an instance previously written by DirectWriter
DirectReader() - Constructor for class org.apache.lucene.util.packed.DirectReader
 
DirectTrackingAllocator(Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
DirectWriter - Class in org.apache.lucene.util.packed
Class for writing packed integers to be directly read from Directory.
DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriterConfig
Denotes a flush trigger is disabled.
disableAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Turn off auto IO throttling.
disableSkipping() - Method in class org.apache.lucene.search.comparators.NumericComparator
 
disableSkipping() - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
 
disableSkipping() - Method in class org.apache.lucene.search.FieldComparator
Informs the comparator that the skipping of documents should be disabled.
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.
discountOverlaps - Variable in class org.apache.lucene.search.similarities.TFIDFSimilarity
True if overlap tokens (tokens with a position of increment of zero) are discounted from the document's length.
DisiPriorityQueue - Class in org.apache.lucene.search
A priority queue of DocIdSetIterators that orders by current doc ID.
DisiPriorityQueue(int) - Constructor for class org.apache.lucene.search.DisiPriorityQueue
 
DisiWrapper - Class in org.apache.lucene.search
Wrapper used in DisiPriorityQueue.
DisiWrapper(Scorer) - Constructor for class org.apache.lucene.search.DisiWrapper
 
disjoint(double, double, double, double, double, double, double, double) - Static method in interface org.apache.lucene.geo.Component2D
Compute whether the bounding boxes are disjoint *
DISJOINT - org.apache.lucene.document.ShapeField.QueryRelation
used for DISJOINT Queries
DISJOINT - org.apache.lucene.geo.Component2D.WithinRelation
The query shape is disjoint with the triangle.
disjunction(List<MatchesIterator>) - Static method in class org.apache.lucene.search.MatchesUtils
Create a MatchesIterator that iterates in order over all matches in a set of subiterators
disjunction(LeafReaderContext, int, Query, String, BytesRefIterator) - Static method in class org.apache.lucene.search.MatchesUtils
Create a MatchesIterator that is a disjunction over a list of terms extracted from a BytesRefIterator.
DISJUNCTION_MAX_REWRITE - Static variable in class org.apache.lucene.search.BlendedTermQuery
BlendedTermQuery.DisjunctionMaxRewrite instance with a tie-breaker of 0.01.
DisjunctionDISIApproximation - Class in org.apache.lucene.search
A DocIdSetIterator which is a disjunction of the approximations of the provided iterators.
DisjunctionDISIApproximation(DisiPriorityQueue) - Constructor for class org.apache.lucene.search.DisjunctionDISIApproximation
 
DisjunctionMaxQuery - Class in org.apache.lucene.search
A query that generates the union of documents produced by its subqueries, and that scores each document with the maximum score for that document as produced by any subquery, plus a tie breaking increment for any additional matching subqueries.
DisjunctionMaxQuery(Collection<Query>, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
Creates a new DisjunctionMaxQuery
DisjunctionMaxQuery.DisjunctionMaxWeight - Class in org.apache.lucene.search
Expert: the Weight for DisjunctionMaxQuery, used to normalize, score and explain these queries.
DisjunctionMaxRewrite(float) - Constructor for class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
This BlendedTermQuery.RewriteMethod will create DisjunctionMaxQuery instances that have the provided tie breaker.
DisjunctionMaxWeight(IndexSearcher, ScoreMode, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Construct the Weight for this Query searched by searcher.
distanceQuerySortKey(double) - Static method in class org.apache.lucene.geo.GeoUtils
binary search to find the exact sortKey needed to match the specified radius any sort key lte this is a query match.
distribution - Variable in class org.apache.lucene.search.similarities.IBSimilarity
The probabilistic distribution used to model term occurrence.
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.
DistributionLL - Class in org.apache.lucene.search.similarities
Log-logistic distribution.
DistributionLL() - Constructor for class org.apache.lucene.search.similarities.DistributionLL
Sole constructor: parameter-free
DistributionSPL - Class in org.apache.lucene.search.similarities
The smoothed power-law (SPL) distribution for the information-based framework that is described in the original paper.
DistributionSPL() - Constructor for class org.apache.lucene.search.similarities.DistributionSPL
Sole constructor: parameter-free
doAfterFlush() - Method in class org.apache.lucene.index.IndexWriter
A hook for extending classes to execute operations after pending added and deleted documents have been flushed to the Directory but before the change is committed (new segments_N file written).
doBeforeFlush() - Method in class org.apache.lucene.index.IndexWriter
A hook for extending classes to execute operations before pending added and deleted documents are flushed to the Directory.
doBody(String) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
Subclass must implement this.
doc - Variable in class org.apache.lucene.search.DisiWrapper
 
doc - Variable in class org.apache.lucene.search.ScoreDoc
A hit document's number.
doc(int) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
Use IndexSearcher.storedFields() to access fields for one or more documents
doc(int, Set<String>) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
Use IndexSearcher.storedFields() to access fields for one or more documents
doc(int, StoredFieldVisitor) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
Use IndexSearcher.storedFields() to access fields for one or more documents
DOC - org.apache.lucene.search.SortField.Type
Sort by document number (index order).
DOC_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
Filename extension for document number, frequencies, and skip data.
DOC_VALUES_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
A rewrite method that uses DocValuesType.SORTED / DocValuesType.SORTED_SET doc values to find matching docs through a post-filtering type approach.
doCache(Weight, QueryCachingPolicy) - Method in class org.apache.lucene.search.LRUQueryCache
 
doCache(Weight, QueryCachingPolicy) - Method in interface org.apache.lucene.search.QueryCache
Return a wrapper around the provided weight that will cache matching docs per-segment accordingly to the given policy.
doCacheWrite(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
Subclass can override this to customize logic; return true if this file should be written to the RAM-based cache first.
docBase - Variable in class org.apache.lucene.index.LeafReaderContext
The reader's absolute doc base
DocBaseBitSetIterator - Class in org.apache.lucene.util
A DocIdSetIterator like BitSetIterator but has a doc base in onder to avoid storing previous 0s.
DocBaseBitSetIterator(FixedBitSet, long, int) - Constructor for class org.apache.lucene.util.DocBaseBitSetIterator
 
docBaseInParent - Variable in class org.apache.lucene.index.IndexReaderContext
the doc base for this reader in the parent, 0 if parent is null
DocComparator - Class in org.apache.lucene.search.comparators
Comparator that sorts by asc _doc
DocComparator(int, boolean, Pruning) - Constructor for class org.apache.lucene.search.comparators.DocComparator
Creates a new comparator based on document ids for numHits
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
Number of documents tested.
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
Number of documents tested.
docCount() - Method in class org.apache.lucene.search.CollectionStatistics
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 - Variable in class org.apache.lucene.search.similarities.BasicStats
The document frequency.
docFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
docFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
docFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
 
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.index.TermStates
Returns the accumulated document frequency of all TermState instances passed to TermStates.register(TermState, int, int, long).
docFreq() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
docFreq() - Method in class org.apache.lucene.search.TermStatistics
The number of documents this term occurs in.
docFreq(Term) - Method in class org.apache.lucene.index.BaseCompositeReader
 
docFreq(Term) - Method in class org.apache.lucene.index.IndexReader
Returns the number of documents containing the term.
docFreq(Term) - Method in class org.apache.lucene.index.LeafReader
 
doCheck(CheckIndex.Options) - Method in class org.apache.lucene.index.CheckIndex
Actually perform the index check
docID() - Method in class org.apache.lucene.codecs.lucene90.IndexedDISI
 
docID() - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues.DenseOffHeapVectorValues
 
docID() - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues.DenseOffHeapVectorValues
 
docID() - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues
 
docID() - Method in class org.apache.lucene.document.BinaryRangeDocValues
 
docID() - Method in class org.apache.lucene.index.FilterBinaryDocValues
 
docID() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
docID() - Method in class org.apache.lucene.index.FilterNumericDocValues
 
docID() - Method in class org.apache.lucene.index.FilterSortedDocValues
 
docID() - Method in class org.apache.lucene.index.FilterSortedNumericDocValues
 
docID() - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
docID() - Method in class org.apache.lucene.index.FilterVectorValues
 
docID() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
docID() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
docID() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
docID() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
docID() - Method in class org.apache.lucene.search.comparators.MinDocIterator
 
docID() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
docID() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
docID() - Method in class org.apache.lucene.search.DocIdSetIterator
Returns the following: -1 if DocIdSetIterator.nextDoc() or DocIdSetIterator.advance(int) were not called yet.
docID() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
docID() - Method in class org.apache.lucene.search.FilterScorable
 
docID() - Method in class org.apache.lucene.search.FilterScorer
 
docID() - Method in class org.apache.lucene.search.ImpactsDISI
 
docID() - Method in class org.apache.lucene.search.IndriDisjunctionScorer
 
docID() - Method in class org.apache.lucene.search.IndriScorer
 
docID() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
docID() - Method in class org.apache.lucene.search.Scorable
Returns the doc ID that is currently being scored.
docID() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
docID() - Method in class org.apache.lucene.search.TermScorer
 
docID() - Method in class org.apache.lucene.util.BitSetIterator
 
docID() - Method in interface org.apache.lucene.util.bkd.PointValue
Returns the docID
docID() - Method in class org.apache.lucene.util.DocBaseBitSetIterator
 
DocIDMerger<T extends DocIDMerger.Sub> - Class in org.apache.lucene.index
Utility class to help merging documents from sub-readers according to either simple concatenated (unsorted) order, or by a specified index-time sort, skipping deleted documents and remapping non-deleted documents.
DocIDMerger.Sub - Class in org.apache.lucene.index
Represents one sub-reader being merged
DocIdSet - Class in org.apache.lucene.search
A DocIdSet contains a set of doc ids.
DocIdSet() - Constructor for class org.apache.lucene.search.DocIdSet
 
DocIdSetBuilder - Class in org.apache.lucene.util
A builder of DocIdSets.
DocIdSetBuilder(int) - Constructor for class org.apache.lucene.util.DocIdSetBuilder
Create a builder that can contain doc IDs between 0 and maxDoc.
DocIdSetBuilder(int, PointValues, String) - Constructor for class org.apache.lucene.util.DocIdSetBuilder
Create a DocIdSetBuilder instance that is optimized for accumulating docs that match the given PointValues.
DocIdSetBuilder(int, Terms) - Constructor for class org.apache.lucene.util.DocIdSetBuilder
Create a DocIdSetBuilder instance that is optimized for accumulating docs that match the given Terms.
DocIdSetBuilder.BulkAdder - Class in org.apache.lucene.util
Utility class to efficiently add many docs in one go.
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
 
DocIdStream - Class in org.apache.lucene.search
A stream of doc IDs.
DocIdStream() - Constructor for class org.apache.lucene.search.DocIdStream
Sole constructor, for invocation by sub classes.
doClose() - Method in class org.apache.lucene.index.CodecReader
 
doClose() - Method in class org.apache.lucene.index.FilterCodecReader
 
doClose() - Method in class org.apache.lucene.index.FilterDirectoryReader
 
doClose() - Method in class org.apache.lucene.index.FilterLeafReader
 
doClose() - Method in class org.apache.lucene.index.IndexReader
Implements close.
doClose() - Method in class org.apache.lucene.index.MultiReader
 
doClose() - Method in class org.apache.lucene.index.ParallelCompositeReader
 
doClose() - Method in class org.apache.lucene.index.ParallelLeafReader
 
doClose() - Method in class org.apache.lucene.index.SegmentReader
 
doClose() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
docMap - Variable in class org.apache.lucene.index.DocIDMerger.Sub
Map from old to new doc IDs
DocMap() - Constructor for class org.apache.lucene.index.Sorter.DocMap
Sole constructor.
docMaps - Variable in class org.apache.lucene.index.MergeState
Maps document IDs from old segments to document IDs in the new segment
DOCS - org.apache.lucene.index.IndexOptions
Only documents are indexed: term frequencies and positions are omitted.
DOCS_AND_FREQS - org.apache.lucene.index.IndexOptions
Only documents and term frequencies are indexed: positions are omitted.
DOCS_AND_FREQS_AND_POSITIONS - org.apache.lucene.index.IndexOptions
Indexes documents, frequencies and positions.
DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS - org.apache.lucene.index.IndexOptions
Indexes documents, frequencies, positions and offsets.
docsSeen - Variable in class org.apache.lucene.util.bkd.BKDWriter
 
docStartFP - Variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
file pointer to the start of the doc ids enumeration, in Lucene99PostingsFormat.DOC_EXTENSION file
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
DocsWithFieldSet - Class in org.apache.lucene.index
Accumulator for documents that have a value for a field.
DocsWithFieldSet() - Constructor for class org.apache.lucene.index.DocsWithFieldSet
Creates an empty DocsWithFieldSet.
document(int) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
use IndexReader.storedFields() to retrieve one or more documents
document(int) - Method in class org.apache.lucene.index.StoredFields
Returns the stored fields of the nth Document in this index.
document(int, Set<String>) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
use IndexReader.storedFields() to retrieve one or more documents
document(int, Set<String>) - Method in class org.apache.lucene.index.StoredFields
Like StoredFields.document(int) but only loads the specified fields.
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.BaseCompositeReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.CodecReader
Deprecated.
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.FilterCodecReader
Deprecated.
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.FilterLeafReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
use IndexReader.storedFields() to retrieve one or more documents
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.ParallelLeafReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.SegmentReader
 
document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.StoredFields
Expert: visits the fields of a stored document, for custom processing/loading of each field.
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.
DocumentStoredFieldVisitor - Class in org.apache.lucene.document
A StoredFieldVisitor that creates a Document from stored fields.
DocumentStoredFieldVisitor() - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
Load all stored fields.
DocumentStoredFieldVisitor(String...) - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
Load only fields named in the provided fields.
DocumentStoredFieldVisitor(Set<String>) - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
Load only fields named in the provided Set<String>.
docValueCount() - Method in class org.apache.lucene.index.FilterSortedNumericDocValues
 
docValueCount() - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
docValueCount() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
docValueCount() - Method in class org.apache.lucene.index.SortedNumericDocValues
Retrieves the number of values for the current document.
docValueCount() - Method in class org.apache.lucene.index.SortedSetDocValues
Retrieves the number of unique ords for the current document.
docValues - Variable in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
DocValues - Class in org.apache.lucene.index
This class contains utility methods and constants for DocValues
DocValuesConsumer - Class in org.apache.lucene.codecs
Abstract API that consumes numeric, binary and sorted docvalues.
DocValuesConsumer() - Constructor for class org.apache.lucene.codecs.DocValuesConsumer
Sole constructor.
DocValuesFieldExistsQuery - Class in org.apache.lucene.search
Deprecated.
Use FieldExistsQuery instead.
DocValuesFieldExistsQuery(String) - Constructor for class org.apache.lucene.search.DocValuesFieldExistsQuery
Deprecated.
Create a query that will match documents which have a value for the given field.
docValuesFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes docvalues
docValuesFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
docValuesFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
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.
DocValuesProducer - Class in org.apache.lucene.codecs
Abstract API that produces numeric, binary, sorted, sortedset, and sortednumeric docvalues.
DocValuesProducer() - Constructor for class org.apache.lucene.codecs.DocValuesProducer
Sole constructor.
docValuesProducers - Variable in class org.apache.lucene.index.MergeState
DocValues producers being merged
DocValuesRewriteMethod - Class in org.apache.lucene.search
Rewrites MultiTermQueries into a filter, using DocValues for term enumeration.
DocValuesRewriteMethod() - Constructor for class org.apache.lucene.search.DocValuesRewriteMethod
 
docValuesStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of DocValues (null if DocValues could not be tested).
docValuesType() - Method in class org.apache.lucene.document.FieldType
DocValues DocValuesType: how the field's value will be indexed into docValues.
docValuesType() - Method in interface org.apache.lucene.index.IndexableFieldType
DocValues DocValuesType: how the field's value will be indexed into docValues.
DocValuesType - Enum in org.apache.lucene.index
DocValues types.
doMerge(MergeScheduler.MergeSource, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
done() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.AbstractIterator
Call when done.
doOpenIfChanged() - Method in class org.apache.lucene.index.DirectoryReader
Implement this method to support DirectoryReader.openIfChanged(DirectoryReader).
doOpenIfChanged() - Method in class org.apache.lucene.index.FilterDirectoryReader
 
doOpenIfChanged() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.DirectoryReader
doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.FilterDirectoryReader
 
doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.StandardDirectoryReader
 
doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.DirectoryReader
doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.FilterDirectoryReader
 
doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.StandardDirectoryReader
 
doPrune(double, IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager.PruneByAge
 
doPrune(double, IndexSearcher) - Method in interface org.apache.lucene.search.SearcherLifetimeManager.Pruner
Return true if this searcher should be removed.
doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleCollector
This method is called before collecting context.
doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleFieldComparator
This method is called before collecting context.
doSlowChecks() - Method in class org.apache.lucene.index.CheckIndex
doStall() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
DOT_PRODUCT - org.apache.lucene.index.VectorSimilarityFunction
Dot product.
dotProduct(byte[], byte[]) - Method in interface org.apache.lucene.internal.vectorization.VectorUtilSupport
Returns the dot product computed over signed bytes.
dotProduct(byte[], byte[]) - Static method in class org.apache.lucene.util.VectorUtil
Dot product computed over signed bytes.
dotProduct(float[], float[]) - Method in interface org.apache.lucene.internal.vectorization.VectorUtilSupport
Calculates the dot product of the given float arrays.
dotProduct(float[], float[]) - Static method in class org.apache.lucene.util.VectorUtil
Returns the vector dot product of the two vectors.
DotProduct(float) - Constructor for class org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity.DotProduct
 
dotProductScore(byte[], byte[]) - Static method in class org.apache.lucene.util.VectorUtil
Dot product score computed over signed bytes, scaled to be in [0, 1].
DOUBLE - org.apache.lucene.document.StoredValue.Type
Type of double values.
DOUBLE - org.apache.lucene.search.SortField.Type
Sort using term values as encoded Doubles.
DoubleComparator - Class in org.apache.lucene.search.comparators
Comparator based on Double.compare(double, double) for numHits.
DoubleComparator(int, String, Double, boolean, Pruning) - Constructor for class org.apache.lucene.search.comparators.DoubleComparator
 
DoubleComparator.DoubleLeafComparator - Class in org.apache.lucene.search.comparators
Leaf comparator for DoubleComparator that provides skipping functionality
DoubleDocValuesField - Class in org.apache.lucene.document
Syntactic sugar for encoding doubles as NumericDocValues via Double.doubleToRawLongBits(double).
DoubleDocValuesField(String, double) - Constructor for class org.apache.lucene.document.DoubleDocValuesField
Creates a new DocValues field with the specified 64-bit double value
doubleField(FieldInfo, double) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
doubleField(FieldInfo, double) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
doubleField(FieldInfo, double) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a double numeric field.
DoubleField - Class in org.apache.lucene.document
Field that stores a per-document double value for scoring, sorting or value retrieval and index the field for fast range filters.
DoubleField(String, double) - Constructor for class org.apache.lucene.document.DoubleField
DoubleField(String, double, Field.Store) - Constructor for class org.apache.lucene.document.DoubleField
Creates a new DoubleField, indexing the provided point, storing it as a DocValue, and optionally storing it as a stored field.
DoubleLeafComparator(LeafReaderContext) - Constructor for class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
DoublePoint - Class in org.apache.lucene.document
An indexed double field for fast range filters.
DoublePoint(String, double...) - Constructor for class org.apache.lucene.document.DoublePoint
Creates a new DoublePoint, indexing the provided N-dimensional double point.
DoubleRange - Class in org.apache.lucene.document
An indexed Double Range field.
DoubleRange(String, double[], double[]) - Constructor for class org.apache.lucene.document.DoubleRange
Create a new DoubleRange type, from min/max parallel arrays
DoubleRangeDocValuesField - Class in org.apache.lucene.document
DocValues field for DoubleRange.
DoubleRangeDocValuesField(String, double[], double[]) - Constructor for class org.apache.lucene.document.DoubleRangeDocValuesField
Sole constructor.
DoubleSorter(String, Double, boolean, IndexSorter.NumericDocValuesProvider) - Constructor for class org.apache.lucene.index.IndexSorter.DoubleSorter
Creates a new DoubleSorter
doubleToSortableLong(double) - Static method in class org.apache.lucene.util.NumericUtils
Converts a double value to a sortable signed long.
doubleValue() - Method in class org.apache.lucene.search.DoubleValues
Get the double value for the current document
DoubleValues - Class in org.apache.lucene.search
Per-segment, per-document double values, which can be calculated at search-time
DoubleValues() - Constructor for class org.apache.lucene.search.DoubleValues
 
DoubleValuesSource - Class in org.apache.lucene.search
Base class for producing DoubleValues
DoubleValuesSource() - Constructor for class org.apache.lucene.search.DoubleValuesSource
 
doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.ExitableDirectoryReader
 
doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.FilterDirectoryReader
Called by the doOpenIfChanged() methods to return a new wrapped DirectoryReader.
doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.SoftDeletesDirectoryReaderWrapper
 
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

earlyTerminated() - Method in class org.apache.lucene.search.AbstractKnnCollector
 
earlyTerminated() - Method in interface org.apache.lucene.search.KnnCollector
If search visits too many documents, the results collector will terminate early.
earlyTerminated() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
earlyTerminated() - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
EARTH_MEAN_RADIUS_METERS - Static variable in class org.apache.lucene.geo.GeoUtils
mean earth axis in meters
EMOJI - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Emoji token type.
EMOJI_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Emoji token type
empty() - Static method in class org.apache.lucene.search.DocIdSetIterator
An empty DocIdSetIterator instance
EMPTY - Static variable in class org.apache.lucene.codecs.KnnVectorsFormat
EMPTY throws an exception when written.
EMPTY - Static variable in class org.apache.lucene.codecs.PointsFormat
A PointsFormat that has nothing indexed
EMPTY - Static variable in class org.apache.lucene.codecs.PostingsFormat
Zero-length PostingsFormat array.
EMPTY - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
 
EMPTY - Static variable in class org.apache.lucene.index.FieldInfos
An instance without any fields.
EMPTY - Static variable in class org.apache.lucene.index.TermsEnum
An empty TermsEnum for quickly returning an empty instance e.g.
EMPTY - Static variable in class org.apache.lucene.index.TermVectors
Instance that never returns term vectors
EMPTY - Static variable in class org.apache.lucene.search.DocIdSet
An empty DocIdSet instance
EMPTY - Static variable in class org.apache.lucene.search.DoubleValues
An empty DoubleValues instance that always returns false from DoubleValues.advanceExact(int)
EMPTY - Static variable in class org.apache.lucene.search.LRUQueryCache.CacheAndCount
 
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 - Static variable in class org.apache.lucene.util.hnsw.HnswGraph
Empty graph value
EMPTY_ARRAY - Static variable in class org.apache.lucene.index.Fields
Zero-length Fields array.
EMPTY_ARRAY - Static variable in class org.apache.lucene.index.ReaderSlice
Zero-length ReaderSlice array.
EMPTY_ARRAY - Static variable in class org.apache.lucene.index.Terms
Zero-length array of Terms.
EMPTY_ARRAY - Static variable in interface org.apache.lucene.util.Bits
 
EMPTY_BYTES - Static variable in class org.apache.lucene.util.BytesRef
An empty byte array for convenience
EMPTY_CHARS - Static variable in class org.apache.lucene.util.CharsRef
An empty character array for convenience
EMPTY_INTS - Static variable in class org.apache.lucene.util.IntsRef
An empty integer array for convenience
EMPTY_LONGS - Static variable in class org.apache.lucene.util.LongsRef
An empty long array for convenience
EMPTY_SET - Static variable in class org.apache.lucene.analysis.CharArraySet
An empty CharArraySet.
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.
EMPTY_VISITOR - Static variable in class org.apache.lucene.search.QueryVisitor
A QueryVisitor implementation that does nothing
emptyBinary() - Static method in class org.apache.lucene.index.DocValues
An empty BinaryDocValues which returns no documents
EmptyDocValuesProducer - Class in org.apache.lucene.index
Abstract base class implementing a DocValuesProducer that has no doc values.
EmptyDocValuesProducer() - Constructor for class org.apache.lucene.index.EmptyDocValuesProducer
Sole constructor
emptyMap() - Static method in class org.apache.lucene.analysis.CharArrayMap
Returns an empty, unmodifiable map.
emptyNumeric() - Static method in class org.apache.lucene.index.DocValues
An empty NumericDocValues which returns no documents
emptySorted() - Static method in class org.apache.lucene.index.DocValues
An empty SortedDocValues which returns BytesRef.EMPTY_BYTES for every document
emptySortedNumeric() - Static method in class org.apache.lucene.index.DocValues
An empty SortedNumericDocValues which returns zero values for every document
emptySortedSet() - Static method in class org.apache.lucene.index.DocValues
An empty SortedDocValues which returns BytesRef.EMPTY_BYTES for every document
emptyVal - Variable in class org.apache.lucene.util.SentinelIntSet
 
ENABLE_MEMORY_SEGMENTS_SYSPROP - Static variable in class org.apache.lucene.store.MMapDirectory
This sysprop allows to control if MemorySegment API should be used on supported Java versions.
ENABLE_UNMAP_HACK_SYSPROP - Static variable in class org.apache.lucene.store.MMapDirectory
This sysprop allows to control the workaround/hack for unmapping the buffers from address space after closing IndexInput.
enableAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Turn on dynamic IO throttling, to adaptively rate limit writes bytes/sec to the minimal rate necessary so merges do not fall behind.
enableGraphQueries - Variable in class org.apache.lucene.util.QueryBuilder
 
enablePositionIncrements - Variable in class org.apache.lucene.util.QueryBuilder
 
encode(float) - Static method in class org.apache.lucene.geo.XYEncodingUtils
Quantizes double (64 bit) values into 32 bits
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.
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(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(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(InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
Encode InetAddress value into binary encoding
encodeBottom(byte[]) - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
encodeBottom(byte[]) - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
encodeBottom(byte[]) - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
encodeBottom(byte[]) - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
encodeBottom(byte[]) - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
encodeDimension(double, byte[], int) - Static method in class org.apache.lucene.document.DoublePoint
Encode single double dimension
encodeDimension(float, byte[], int) - Static method in class org.apache.lucene.document.FloatPoint
Encode single float dimension
encodeDimension(int, byte[], int) - Static method in class org.apache.lucene.document.IntPoint
Encode single integer dimension
encodeDimension(long, byte[], int) - Static method in class org.apache.lucene.document.LongPoint
Encode single long dimension
encodeLatitude(double) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Quantizes double (64 bit) latitude into 32 bits (rounding down: in the direction of -90)
encodeLatitudeCeil(double) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Quantizes double (64 bit) latitude into 32 bits (rounding up: in the direction of +90)
encodeLongitude(double) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Quantizes double (64 bit) longitude into 32 bits (rounding down: in the direction of -180)
encodeLongitudeCeil(double) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
Quantizes double (64 bit) longitude into 32 bits (rounding up: in the direction of +180)
encodeTerm(DataOutput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
encodeTerm(DataOutput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.PostingsWriterBase
Encode metadata as long[] and byte[].
encodeTop(byte[]) - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
encodeTop(byte[]) - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
encodeTop(byte[]) - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
encodeTop(byte[]) - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
encodeTop(byte[]) - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
encodeTriangle(byte[], int, int, boolean, int, int, boolean, int, int, boolean) - Static method in class org.apache.lucene.document.ShapeField
A triangle is encoded using 6 points and an extra point with encoded information in three bits of how to reconstruct it.
end - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
 
end() - Method in class org.apache.lucene.analysis.CachingTokenFilter
 
end() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
 
end() - Method in class org.apache.lucene.analysis.GraphTokenFilter
 
end() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
 
end() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Resets the attributes at end
end() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
end() - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
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.util.AttributeImpl
Clears the values in this AttributeImpl and resets it to its value at the end of the field.
END - org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Reject the term and stop enumerating.
END - org.apache.lucene.index.TermsEnum.SeekStatus
The term was not found, and the end of iteration was hit.
END_LABEL - Static variable in class org.apache.lucene.util.fst.FST
If arc has this label then that arc is final/accepted
endAttributes() - Method in class org.apache.lucene.util.AttributeSource
Resets all Attributes in this AttributeSource by calling AttributeImpl.end() on each Attribute implementation.
endMergeOnFullFlush(MergePolicy.MergeSpecification) - Method in interface org.apache.lucene.index.IndexWriterEventListener
Invoked at the end of merge on commit, due to either merge completed, or merge timed out according to IndexWriterConfig.setMaxFullFlushMergeWaitMillis(long)
endOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
endOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
endOffset() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
endOffset() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
endOffset() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
endOffset() - Method in class org.apache.lucene.index.PostingsEnum
Returns end offset for the current position, or -1 if offsets were not indexed.
endOffset() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
endOffset() - Method in class org.apache.lucene.search.ExactPhraseMatcher
 
endOffset() - Method in class org.apache.lucene.search.FilterMatchesIterator
 
endOffset() - Method in interface org.apache.lucene.search.MatchesIterator
The ending offset of the current match, or -1 if offsets are not available
endOffset() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionFullPostingsEnum
 
endOffset() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
endOffset() - Method in class org.apache.lucene.search.SloppyPhraseMatcher
 
endPosition() - Method in class org.apache.lucene.search.ExactPhraseMatcher
 
endPosition() - Method in class org.apache.lucene.search.FilterMatchesIterator
 
endPosition() - Method in interface org.apache.lucene.search.MatchesIterator
The end position of the current match
endPosition() - Method in class org.apache.lucene.search.SloppyPhraseMatcher
 
endSplit(String) - Method in interface org.apache.lucene.geo.Tessellator.Monitor
When a polygon split is completed, this is called.
endsWith(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns true iff the ref ends with the given suffix.
ensureCanRead(String) - Method in class org.apache.lucene.store.FSDirectory
 
ensureCapacity(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Ensure this container can hold at least the given number of keys (entries) without resizing its buffers.
ensureCapacity(FixedBitSet, int) - Static method in class org.apache.lucene.util.FixedBitSet
If the given FixedBitSet is large enough to hold numBits+1, returns the given bits, otherwise returns a new FixedBitSet which can hold the requested number of bits.
ensureCapacity(LongBitSet, long) - Static method in class org.apache.lucene.util.LongBitSet
If the given LongBitSet is large enough to hold numBits+1, returns the given bits, otherwise returns a new LongBitSet which can hold the requested number of bits.
ensureOpen() - Method in class org.apache.lucene.index.IndexReader
Throws AlreadyClosedException if this IndexReader or any of its child readers is closed, otherwise returns.
ensureOpen() - 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
Ensures this directory is still open.
ensureOpen() - Method in class org.apache.lucene.store.FilterDirectory
 
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.
ensureValid() - Method in class org.apache.lucene.store.Lock
Best effort check that this lock is still valid.
Entry(int, int) - Constructor for class org.apache.lucene.search.FieldValueHitQueue.Entry
 
entryNode() - Method in class org.apache.lucene.util.hnsw.HnswGraph
Returns graph's entry point on the top level *
entryNode() - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
Returns the graph's current entry node on the top level shown as ordinals of the nodes on 0th level
entrySet() - Method in class org.apache.lucene.analysis.CharArrayMap
 
ENVELOPE - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
eof() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
EQUAL_TO - org.apache.lucene.search.TotalHits.Relation
The total hit count is equal to TotalHits.value.
equalElements(IntIntHashMap) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Return true if all keys of some other container exist in this container.
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.document.FieldType
 
equals(Object) - Method in class org.apache.lucene.document.RangeFieldQuery
 
equals(Object) - Method in class org.apache.lucene.document.ShapeField.DecodedTriangle
 
equals(Object) - Method in class org.apache.lucene.document.XYDocValuesPointInGeometryQuery
 
equals(Object) - Method in class org.apache.lucene.geo.Circle
 
equals(Object) - Method in class org.apache.lucene.geo.Line
 
equals(Object) - Method in class org.apache.lucene.geo.Point
 
equals(Object) - Method in class org.apache.lucene.geo.Polygon
 
equals(Object) - Method in class org.apache.lucene.geo.Rectangle
 
equals(Object) - Method in class org.apache.lucene.geo.XYCircle
 
equals(Object) - Method in class org.apache.lucene.geo.XYLine
 
equals(Object) - Method in class org.apache.lucene.geo.XYPoint
 
equals(Object) - Method in class org.apache.lucene.geo.XYPolygon
 
equals(Object) - Method in class org.apache.lucene.geo.XYRectangle
 
equals(Object) - Method in class org.apache.lucene.index.Impact
 
equals(Object) - Method in class org.apache.lucene.index.IndexCommit
Two IndexCommits are equal if both their Directory and versions are equal.
equals(Object) - Method in class org.apache.lucene.index.IndexReader
equals(Object) - Method in class org.apache.lucene.index.PrefixCodedTerms
 
equals(Object) - Method in class org.apache.lucene.index.SegmentInfo
We consider another SegmentInfo instance equal if it has the same dir and same name.
equals(Object) - Method in class org.apache.lucene.index.Term
 
equals(Object) - Method in class org.apache.lucene.search.AutomatonQuery
 
equals(Object) - Method in class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
 
equals(Object) - Method in class org.apache.lucene.search.BlendedTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.BooleanClause
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.BooleanQuery
Compares the specified object with this boolean query for equality.
equals(Object) - Method in class org.apache.lucene.search.BoostQuery
 
equals(Object) - Method in class org.apache.lucene.search.ByteVectorSimilarityQuery
 
equals(Object) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
equals(Object) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Return true if we represent the same query as other
equals(Object) - Method in class org.apache.lucene.search.DocValuesRewriteMethod
 
equals(Object) - Method in class org.apache.lucene.search.DoubleValuesSource
 
equals(Object) - Method in class org.apache.lucene.search.Explanation
 
equals(Object) - Method in class org.apache.lucene.search.FieldExistsQuery
 
equals(Object) - Method in class org.apache.lucene.search.FloatVectorSimilarityQuery
 
equals(Object) - Method in class org.apache.lucene.search.FuzzyQuery
 
equals(Object) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
 
equals(Object) - Method in class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
 
equals(Object) - Method in class org.apache.lucene.search.IndriQuery
 
equals(Object) - Method in class org.apache.lucene.search.KnnByteVectorQuery
 
equals(Object) - Method in class org.apache.lucene.search.KnnFloatVectorQuery
 
equals(Object) - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
 
equals(Object) - Method in class org.apache.lucene.search.LongValuesSource
 
equals(Object) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
equals(Object) - Method in class org.apache.lucene.search.MatchNoDocsQuery
 
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.Multiset
 
equals(Object) - Method in class org.apache.lucene.search.MultiTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.NGramPhraseQuery
 
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.PhraseQuery.PostingsAndFreq
 
equals(Object) - Method in class org.apache.lucene.search.PointInSetQuery
 
equals(Object) - Method in class org.apache.lucene.search.PointRangeQuery
 
equals(Object) - Method in class org.apache.lucene.search.PrefixQuery
 
equals(Object) - Method in class org.apache.lucene.search.Query
Override and implement query instance equivalence properly in a subclass.
equals(Object) - Method in class org.apache.lucene.search.Sort
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.SortedNumericSortField
 
equals(Object) - Method in class org.apache.lucene.search.SortedSetSortField
 
equals(Object) - Method in class org.apache.lucene.search.SortField
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.SynonymQuery
 
equals(Object) - Method in class org.apache.lucene.search.TermInSetQuery
 
equals(Object) - Method in class org.apache.lucene.search.TermQuery
Returns true iff other 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.search.TotalHits
 
equals(Object) - Method in class org.apache.lucene.store.FlushInfo
 
equals(Object) - Method in class org.apache.lucene.store.IOContext
 
equals(Object) - Method in class org.apache.lucene.store.MergeInfo
 
equals(Object) - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
 
equals(Object) - Method in class org.apache.lucene.util.AttributeSource
 
equals(Object) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
 
equals(Object) - Method in class org.apache.lucene.util.automaton.RunAutomaton
 
equals(Object) - Method in class org.apache.lucene.util.automaton.StatePair
Checks for equality.
equals(Object) - Method in class org.apache.lucene.util.BytesRef
 
equals(Object) - Method in class org.apache.lucene.util.BytesRefBuilder
 
equals(Object) - Method in class org.apache.lucene.util.CharsRef
 
equals(Object) - Method in class org.apache.lucene.util.CharsRefBuilder
 
equals(Object) - Method in class org.apache.lucene.util.FixedBitSet
 
equals(Object) - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
 
equals(Object) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
equals(Object) - Method in class org.apache.lucene.util.IntsRef
 
equals(Object) - Method in class org.apache.lucene.util.IntsRefBuilder
 
equals(Object) - Method in class org.apache.lucene.util.LongBitSet
returns true if both sets have the same bits set
equals(Object) - Method in class org.apache.lucene.util.LongsRef
 
equals(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
 
equals(Object) - Method in class org.apache.lucene.util.Version
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
equalsSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
equalsTo(RangeFieldQuery) - Method in class org.apache.lucene.document.RangeFieldQuery
Check equality of two RangeFieldQuery objects
error - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Exception thrown during doc values test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldInfoStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.IndexSortStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.LiveDocStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.PointsStatus
Exception thrown during point values test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Exception thrown during segment test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.SoftDeletsStatus
Exception thrown during soft deletes 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)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.VectorValuesStatus
Exception thrown during vector values 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
 
estimateDocCount(PointValues.IntersectVisitor) - Method in class org.apache.lucene.index.PointValues
Estimate the number of documents that would be matched by PointValues.intersect(org.apache.lucene.index.PointValues.IntersectVisitor) with the given PointValues.IntersectVisitor.
estimatedSegmentSize - Variable in class org.apache.lucene.store.FlushInfo
 
estimatePointCount(PointValues.IntersectVisitor) - Method in class org.apache.lucene.index.PointValues
Estimate the number of points that would be visited by PointValues.intersect(org.apache.lucene.index.PointValues.IntersectVisitor) with the given PointValues.IntersectVisitor.
Euclidean(float) - Constructor for class org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity.Euclidean
 
EUCLIDEAN - org.apache.lucene.index.VectorSimilarityFunction
Euclidean distance
eventListener - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
The IndexWriter event listener to record key events *
ExactPhraseMatcher - Class in org.apache.lucene.search
Expert: Find exact phrases
ExactPhraseMatcher(PhraseQuery.PostingsAndFreq[], ScoreMode, Similarity.SimScorer, float) - Constructor for class org.apache.lucene.search.ExactPhraseMatcher
Expert: Creates ExactPhraseMatcher instance
execute(Runnable) - Method in class org.apache.lucene.util.SameThreadExecutorService
 
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?
exists(String) - Method in class org.apache.lucene.util.FileDeleter
return true only if file is touched and also has larger than 0 ref count
ExitableDirectoryReader - Class in org.apache.lucene.index
The ExitableDirectoryReader wraps a real index DirectoryReader and allows for a QueryTimeout implementation object to be checked periodically to see if the thread should exit or not.
ExitableDirectoryReader(DirectoryReader, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader
Constructor
ExitableDirectoryReader.ExitableFilterAtomicReader - Class in org.apache.lucene.index
Wrapper class for another FilterAtomicReader.
ExitableDirectoryReader.ExitableSubReaderWrapper - Class in org.apache.lucene.index
Wrapper class for a SubReaderWrapper that is used by the ExitableDirectoryReader.
ExitableDirectoryReader.ExitableTerms - Class in org.apache.lucene.index
Wrapper class for another Terms implementation that is used by ExitableFields.
ExitableDirectoryReader.ExitableTermsEnum - Class in org.apache.lucene.index
Wrapper class for TermsEnum that is used by ExitableTerms for implementing an exitable enumeration of terms.
ExitableDirectoryReader.ExitingReaderException - Exception in org.apache.lucene.index
Exception that is thrown to prematurely terminate a term enumeration.
ExitableFilterAtomicReader(LeafReader, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
Constructor *
ExitableSubReaderWrapper(QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableSubReaderWrapper
Constructor *
ExitableTerms(Terms, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
Constructor *
ExitableTermsEnum(TermsEnum, QueryTimeout) - Constructor for class org.apache.lucene.index.ExitableDirectoryReader.ExitableTermsEnum
Constructor *
ExitingReaderException(String) - Constructor for exception org.apache.lucene.index.ExitableDirectoryReader.ExitingReaderException
Constructor *
exorciseIndex(CheckIndex.Status) - Method in class org.apache.lucene.index.CheckIndex
Repairs the index using previously returned result from CheckIndex.checkIndex().
exp1 - Variable in class org.apache.lucene.util.automaton.RegExp
Child expressions held by a container type expression
exp2 - Variable in class org.apache.lucene.util.automaton.RegExp
Child expressions held by a container type expression
explain(int, Explanation) - Method in class org.apache.lucene.search.LeafSimScorer
Explain the score for the provided document assuming the given term document frequency.
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
 
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.DFRSimilarity
 
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.IBSimilarity
 
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.IndriDirichletSimilarity
 
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
 
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
 
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.LMSimilarity
 
explain(List<Explanation>, BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.SimilarityBase
Subclasses should implement this method to explain the score.
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.ConstantScoreWeight
 
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Explain the score we computed for doc
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.FilterWeight
 
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.IndriAndWeight
 
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.PhraseWeight
 
explain(LeafReaderContext, int) - Method in class org.apache.lucene.search.Weight
An explanation of the score computation for the named document.
explain(LeafReaderContext, int, Explanation) - Method in class org.apache.lucene.search.DoubleValuesSource
An explanation of the value for the named document.
explain(Explanation, long) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
Explain the score for a single document
explain(IndexSearcher, Explanation, int) - Method in class org.apache.lucene.search.QueryRescorer
 
explain(IndexSearcher, Explanation, int) - Method in class org.apache.lucene.search.Rescorer
Explains how the score for the specified document was computed.
explain(IndexSearcher, Explanation, int) - Method in class org.apache.lucene.search.SortRescorer
 
explain(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
Returns an Explanation that describes how doc scored against query.
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(BasicStats, double) - Method in class org.apache.lucene.search.similarities.AfterEffect
Returns an explanation for the score.
explain(BasicStats, double) - Method in class org.apache.lucene.search.similarities.AfterEffectB
 
explain(BasicStats, double) - Method in class org.apache.lucene.search.similarities.AfterEffectL
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModel
Returns an explanation for the score.
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelG
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelIF
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelIn
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelIne
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Distribution
Explains the score.
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Normalization
Returns an explanation for the normalized term frequency.
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationH1
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationH2
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationH3
 
explain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationZ
 
explain(BasicStats, Explanation, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
 
explain(BasicStats, Explanation, double) - Method in class org.apache.lucene.search.similarities.DFISimilarity
 
explain(BasicStats, Explanation, double) - Method in class org.apache.lucene.search.similarities.DFRSimilarity
 
explain(BasicStats, Explanation, double) - Method in class org.apache.lucene.search.similarities.IBSimilarity
 
explain(BasicStats, Explanation, double) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
 
explain(BasicStats, Explanation, double) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
 
explain(BasicStats, Explanation, double) - Method in class org.apache.lucene.search.similarities.SimilarityBase
Explains the score.
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.
Explanation - Class in org.apache.lucene.search
Expert: Describes the score computation for document and query.
EXPLICIT - org.apache.lucene.index.MergeTrigger
Merge has been triggered explicitly by the user.

F

FAILED - Static variable in interface org.apache.lucene.geo.Tessellator.Monitor
 
fallbackSorter(Comparator<BytesRef>) - Method in class org.apache.lucene.util.StringSorter
 
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.
FastCompressionHashTable() - Constructor for class org.apache.lucene.util.compress.LZ4.FastCompressionHashTable
Sole constructor
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.
FeatureField - Class in org.apache.lucene.document
Field that can be used to store static scoring factors into documents.
FeatureField(String, String, float) - Constructor for class org.apache.lucene.document.FeatureField
Create a feature.
featureRequested(int, short) - Static method in class org.apache.lucene.index.PostingsEnum
Returns true if the given feature is requested in the flags, false otherwise.
fetch() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.AbstractIterator
Fetch next element.
field - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Field name.
field - Variable in class org.apache.lucene.search.comparators.NumericComparator
 
field - Variable in class org.apache.lucene.search.MultiTermQuery
 
field() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
Returns current field.
field() - Method in class org.apache.lucene.index.Term
Returns the field of this term.
field() - Method in class org.apache.lucene.search.CollectionStatistics
The field's name.
Field - Class in org.apache.lucene.document
Expert: directly create a field for a document.
Field(String, byte[], int, int, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
Create field with binary value.
Field(String, byte[], IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
Create field with binary value.
Field(String, Reader, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
Create field with Reader value.
Field(String, CharSequence, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
Create field with String value.
Field(String, TokenStream, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
Create field with TokenStream value.
Field(String, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
Expert: creates a field with no initial value.
Field(String, BytesRef, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
Create field with binary value.
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).
FIELD_TYPE - Static variable in class org.apache.lucene.document.ShapeDocValuesField
FieldType for ShapeDocValues field
Field.Store - Enum in org.apache.lucene.document
Specifies whether and how a field should be stored.
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.RelevanceComparator - Class in org.apache.lucene.search
Sorts by descending relevance.
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.
FieldExistsQuery - Class in org.apache.lucene.search
A Query that matches documents that contain either a KnnFloatVectorField, KnnByteVectorField or a field that indexes norms or doc values.
FieldExistsQuery(String) - Constructor for class org.apache.lucene.search.FieldExistsQuery
Create a query that will match that have a value for the given field.
fieldInfo - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
FieldInfo of current field being written.
fieldInfo - Variable in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
fieldInfo(int) - Method in class org.apache.lucene.index.FieldInfos
Return the fieldinfo object referenced by the fieldNumber.
fieldInfo(String) - Method in class org.apache.lucene.index.FieldInfos
Return the fieldinfo object referenced by the field name
FieldInfo - Class in org.apache.lucene.index
Access to the Field Info file that describes document fields and whether or not they are indexed.
FieldInfo(String, int, boolean, boolean, boolean, IndexOptions, DocValuesType, long, Map<String, String>, int, int, int, int, VectorEncoding, VectorSimilarityFunction, boolean, boolean) - Constructor for class org.apache.lucene.index.FieldInfo
Sole constructor.
fieldInfos - Variable in class org.apache.lucene.index.MergeState
FieldInfos being merged
fieldInfos - Variable in class org.apache.lucene.index.SegmentReadState
FieldInfos describing all fields in this segment.
fieldInfos - Variable in class org.apache.lucene.index.SegmentWriteState
FieldInfos describing all fields in this segment.
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
fieldInfosFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes field infos file
fieldInfosFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
FieldInfosFormat - Class in org.apache.lucene.codecs
Encodes/decodes FieldInfos
FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.FieldInfosFormat
Sole constructor.
fieldInfoStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of field infos
FieldInvertState - Class in org.apache.lucene.index
This class tracks the number and position / offset parameters of terms being added to the index.
FieldInvertState(int, String, IndexOptions) - Constructor for class org.apache.lucene.index.FieldInvertState
Creates {code FieldInvertState} for the specified field name.
FieldInvertState(int, String, IndexOptions, int, int, int, int, int, int) - Constructor for class org.apache.lucene.index.FieldInvertState
Creates {code FieldInvertState} for the specified field name and values for all fields.
fieldNormStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of field norms (null if field norms could not be tested).
FieldReader - Class in org.apache.lucene.codecs.lucene90.blocktree
BlockTree's implementation of Terms.
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 - Class in org.apache.lucene.index
Provides a Terms index for fields that have it, and lists which fields do.
Fields() - Constructor for class org.apache.lucene.index.Fields
Sole constructor.
FIELDS_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
Extension of stored fields file
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.DocValuesFormat
Returns a DocValuesConsumer to write docvalues to the index.
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene90.Lucene90DocValuesFormat
 
fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
 
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
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.
fieldsData - Variable in class org.apache.lucene.document.Field
Field's value
FieldsIndexWriter - Class in org.apache.lucene.codecs.lucene90.compressing
Efficient index format for block-based Codecs.
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.DocValuesFormat
Returns a DocValuesProducer to read docvalues from the index.
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene90.Lucene90DocValuesFormat
 
fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
 
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.
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.
fieldsProducers - Variable in class org.apache.lucene.index.MergeState
Postings to merge
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.FlatVectorsFormat
Returns a KnnVectorsReader to read the vectors from the index.
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.KnnVectorsFormat
Returns a KnnVectorsReader to read the vectors from the index.
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsFormat
 
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsFormat
 
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswScalarQuantizedVectorsFormat
 
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
 
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsFormat
 
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
 
fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.PointsFormat
Reads a segment.
fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsFormat
 
fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat
 
fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
Returns a StoredFieldsReader to load stored fields.
FieldsReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
Create a FieldsReader over a segment, opening VectorReaders for each KnnVectorsFormat specified by the indexed numeric vector fields.
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.FlatVectorsFormat
Returns a FlatVectorsWriter to write the vectors to the index.
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.KnnVectorsFormat
Returns a KnnVectorsWriter to write the vectors to the index.
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsFormat
 
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsFormat
 
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswScalarQuantizedVectorsFormat
 
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
 
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsFormat
 
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
 
fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.PointsFormat
Writes a new segment
fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsFormat
 
fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat
 
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() - Method in class org.apache.lucene.document.ShapeDocValuesField
Gets the IndexableFieldType for this ShapeDocValue field
fieldType() - Method in interface org.apache.lucene.index.IndexableField
IndexableFieldType describing the properties of this field.
FieldType - Class in org.apache.lucene.document
Describes the properties of a field.
FieldType() - Constructor for class org.apache.lucene.document.FieldType
Create a new FieldType with default properties.
FieldType(IndexableFieldType) - Constructor for class org.apache.lucene.document.FieldType
Create a new mutable FieldType with all of the properties from ref
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.
FILE - org.apache.lucene.util.FileDeleter.MsgType
 
FileDeleter - Class in org.apache.lucene.util
This class provides ability to track the reference counts of a set of index files and delete them when their counts decreased to 0.
FileDeleter(Directory, BiConsumer<FileDeleter.MsgType, String>) - Constructor for class org.apache.lucene.util.FileDeleter
Create a new FileDeleter with a messenger consumes various verbose messages
FileDeleter.MsgType - Enum in org.apache.lucene.util
Types of messages this file deleter will broadcast REF: messages about reference FILE: messages about file
FileDeleter.RefCount - Class in org.apache.lucene.util
Tracks the reference count for a single index file:
fileExists(String) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
fileLength(String) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
fileLength(String) - Method in class org.apache.lucene.store.Directory
Returns the byte 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
 
fileLength(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
fileNameFromGeneration(String, String, long) - Static method in class org.apache.lucene.index.IndexFileNames
Computes the full file name from base, extension and generation.
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(boolean) - Method in class org.apache.lucene.index.SegmentInfos
Returns all file names referenced by SegmentInfo.
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.lucene90.Lucene90LiveDocsFormat
 
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(CharacterUtils.CharacterBuffer, Reader) - Static method in class org.apache.lucene.analysis.CharacterUtils
Convenience method which calls fill(buffer, reader, buffer.buffer.length).
fill(CharacterUtils.CharacterBuffer, Reader, int) - Static method in class org.apache.lucene.analysis.CharacterUtils
Fills the CharacterUtils.CharacterBuffer with characters read from the given reader Reader.
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(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefBlockPool
Populates the given BytesRef with the term starting at start.
fillInStackTrace() - Method in exception org.apache.lucene.search.CollectionTerminatedException
 
fillPages() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
 
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 - org.apache.lucene.search.BooleanClause.Occur
Like BooleanClause.Occur.MUST except that these clauses do not participate in scoring.
FilterBinaryDocValues - Class in org.apache.lucene.index
Delegates all methods to a wrapped BinaryDocValues.
FilterBinaryDocValues(BinaryDocValues) - Constructor for class org.apache.lucene.index.FilterBinaryDocValues
Sole constructor
FilterCodec - Class in org.apache.lucene.codecs
A codec that forwards all its method calls to another codec.
FilterCodec(String, Codec) - Constructor for class org.apache.lucene.codecs.FilterCodec
Sole constructor.
FilterCodecReader - Class in org.apache.lucene.index
A FilterCodecReader contains another CodecReader, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterCodecReader(CodecReader) - Constructor for class org.apache.lucene.index.FilterCodecReader
Creates a new FilterCodecReader.
FilterCollector - Class in org.apache.lucene.search
Collector delegator.
FilterCollector(Collector) - Constructor for class org.apache.lucene.search.FilterCollector
Sole constructor.
FilterDirectory - Class in org.apache.lucene.store
Directory implementation that delegates calls to another directory.
FilterDirectory(Directory) - Constructor for class org.apache.lucene.store.FilterDirectory
Sole constructor, typically called from sub-classes.
FilterDirectoryReader - Class in org.apache.lucene.index
A FilterDirectoryReader wraps another DirectoryReader, allowing implementations to transform or extend it.
FilterDirectoryReader(DirectoryReader, FilterDirectoryReader.SubReaderWrapper) - Constructor for class org.apache.lucene.index.FilterDirectoryReader
Create a new FilterDirectoryReader that filters a passed in DirectoryReader, using the supplied SubReaderWrapper to wrap its subreader.
FilterDirectoryReader.DelegatingCacheHelper - Class in org.apache.lucene.index
A DelegatingCacheHelper is a CacheHelper specialization for implementing long-lived caching behaviour for FilterDirectoryReader subclasses.
FilterDirectoryReader.SubReaderWrapper - Class in org.apache.lucene.index
Factory class passed to FilterDirectoryReader constructor that allows subclasses to wrap the filtered DirectoryReader's subreaders.
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.
FilteredTermsEnum - Class in org.apache.lucene.index
Abstract class for enumerating a subset of all terms.
FilteredTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
Creates a filtered TermsEnum on a terms enum.
FilteredTermsEnum(TermsEnum, boolean) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
Creates a filtered TermsEnum on a terms enum.
FilteredTermsEnum.AcceptStatus - Enum in org.apache.lucene.index
Return value, if term should be accepted or the iteration should END.
FilterFields(Fields) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterFields
Creates a new FilterFields.
FilterIndexInput - Class in org.apache.lucene.store
IndexInput implementation that delegates calls to another directory.
FilterIndexInput(String, IndexInput) - Constructor for class org.apache.lucene.store.FilterIndexInput
Creates a FilterIndexInput with a resource description and wrapped delegate IndexInput
FilterIndexOutput - Class in org.apache.lucene.store
IndexOutput implementation that delegates calls to another directory.
FilterIndexOutput(String, String, IndexOutput) - Constructor for class org.apache.lucene.store.FilterIndexOutput
Creates a FilterIndexOutput with a resource description, name, and wrapped delegate IndexOutput
FilteringTokenFilter - Class in org.apache.lucene.analysis
Abstract base class for TokenFilters that may remove tokens.
FilteringTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.FilteringTokenFilter
Create a new FilteringTokenFilter.
FilterIterator<T,​InnerT extends T> - Class in org.apache.lucene.util
An Iterator implementation that filters elements with a boolean predicate.
FilterIterator(Iterator<InnerT>) - Constructor for class org.apache.lucene.util.FilterIterator
 
FilterLeafCollector - Class in org.apache.lucene.search
LeafCollector delegator.
FilterLeafCollector(LeafCollector) - Constructor for class org.apache.lucene.search.FilterLeafCollector
Sole constructor.
FilterLeafReader - Class in org.apache.lucene.index
A FilterLeafReader contains another LeafReader, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterLeafReader(LeafReader) - Constructor for class org.apache.lucene.index.FilterLeafReader
Construct a FilterLeafReader based on the specified base reader.
FilterLeafReader.FilterFields - Class in org.apache.lucene.index
Base class for filtering Fields implementations.
FilterLeafReader.FilterPostingsEnum - Class in org.apache.lucene.index
Base class for filtering PostingsEnum implementations.
FilterLeafReader.FilterTerms - Class in org.apache.lucene.index
Base class for filtering Terms implementations.
FilterLeafReader.FilterTermsEnum - Class in org.apache.lucene.index
Base class for filtering TermsEnum implementations.
FilterMatchesIterator - Class in org.apache.lucene.search
A MatchesIterator that delegates all calls to another MatchesIterator
FilterMatchesIterator(MatchesIterator) - Constructor for class org.apache.lucene.search.FilterMatchesIterator
Create a new FilterMatchesIterator
FilterMergePolicy - Class in org.apache.lucene.index
A wrapper for MergePolicy instances.
FilterMergePolicy(MergePolicy) - Constructor for class org.apache.lucene.index.FilterMergePolicy
Creates a new filter merge policy instance wrapping another.
FilterNumericDocValues - Class in org.apache.lucene.index
Delegates all methods to a wrapped NumericDocValues.
FilterNumericDocValues(NumericDocValues) - Constructor for class org.apache.lucene.index.FilterNumericDocValues
Sole constructor
FilterPostingsEnum(PostingsEnum) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
Create a new FilterPostingsEnum
FilterScorable - Class in org.apache.lucene.search
Filter a Scorable, intercepting methods and optionally changing their return values
FilterScorable(Scorable) - Constructor for class org.apache.lucene.search.FilterScorable
Filter a scorer
FilterScorer - Class in org.apache.lucene.search
A FilterScorer contains another Scorer, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterScorer(Scorer) - Constructor for class org.apache.lucene.search.FilterScorer
Create a new FilterScorer
FilterScorer(Scorer, Weight) - Constructor for class org.apache.lucene.search.FilterScorer
Create a new FilterScorer with a specific weight
FilterSortedDocValues - Class in org.apache.lucene.index
Delegates all methods to a wrapped SortedDocValues.
FilterSortedDocValues(SortedDocValues) - Constructor for class org.apache.lucene.index.FilterSortedDocValues
Sole constructor
FilterSortedNumericDocValues - Class in org.apache.lucene.index
Delegates all methods to a wrapped SortedNumericDocValues.
FilterSortedNumericDocValues(SortedNumericDocValues) - Constructor for class org.apache.lucene.index.FilterSortedNumericDocValues
Sole constructor
FilterSortedSetDocValues - Class in org.apache.lucene.index
Delegates all methods to a wrapped SortedSetDocValues.
FilterSortedSetDocValues(SortedSetDocValues) - Constructor for class org.apache.lucene.index.FilterSortedSetDocValues
Initializes delegate
FilterTerms(Terms) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterTerms
Creates a new FilterTerms
FilterTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
Creates a new FilterTermsEnum
FilterVectorValues - Class in org.apache.lucene.index
Delegates all methods to a wrapped FloatVectorValues.
FilterVectorValues(FloatVectorValues) - Constructor for class org.apache.lucene.index.FilterVectorValues
Sole constructor
FilterWeight - Class in org.apache.lucene.search
A FilterWeight contains another Weight and implements all abstract methods by calling the contained weight's method.
FilterWeight(Query, Weight) - Constructor for class org.apache.lucene.search.FilterWeight
Alternative constructor.
FilterWeight(Weight) - Constructor for class org.apache.lucene.search.FilterWeight
Default constructor.
find(int) - Method in class org.apache.lucene.util.SentinelIntSet
(internal) Returns the slot for this key, or -slot-1 if not found
find(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Returns the id of the given BytesRef.
findClass(String, Class<T>) - Method in class org.apache.lucene.util.ClasspathResourceLoader
 
findClass(String, Class<T>) - Method in class org.apache.lucene.util.ModuleResourceLoader
 
findClass(String, Class<T>) - Method in interface org.apache.lucene.util.ResourceLoader
Finds class of the name and expected type
findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
 
findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
Finds merges necessary to force-merge all deletes from the index.
findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - 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, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.OneMergeWrappingMergePolicy
 
findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - 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>, MergePolicy.MergeContext) - 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>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.OneMergeWrappingMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findFullFlushMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
 
findFullFlushMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
Identifies merges that we want to execute (synchronously) on commit.
findFullFlushMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
 
findFullFlushMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.OneMergeWrappingMergePolicy
 
findMerges(CodecReader...) - Method in class org.apache.lucene.index.FilterMergePolicy
 
findMerges(CodecReader...) - Method in class org.apache.lucene.index.MergePolicy
Define the set of merge operations to perform on provided codec readers in IndexWriter.addIndexes(CodecReader...).
findMerges(CodecReader...) - Method in class org.apache.lucene.index.NoMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
Checks if any merges are now necessary and returns a MergePolicy.MergeSpecification if so.
findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations are now necessary on the index.
findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.OneMergeWrappingMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findNamedMatches(Matches) - Static method in class org.apache.lucene.search.NamedMatches
Finds all NamedMatches in a Matches tree
FindSegmentsFile(Directory) - Constructor for class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
Sole constructor.
findSPIName(Class<? extends CharFilterFactory>) - Static method in class org.apache.lucene.analysis.CharFilterFactory
looks up a SPI name for the specified char filter factory
findSPIName(Class<? extends TokenFilterFactory>) - Static method in class org.apache.lucene.analysis.TokenFilterFactory
looks up a SPI name for the specified token filter factory
findSPIName(Class<? extends TokenizerFactory>) - Static method in class org.apache.lucene.analysis.TokenizerFactory
looks up a SPI name for the specified tokenizer factory
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() - Method in class org.apache.lucene.codecs.FlatVectorsWriter
Called once at the end before close
finish() - Method in class org.apache.lucene.codecs.KnnVectorsWriter
Called once at the end before close
finish() - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
 
finish() - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
finish() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsWriter
 
finish() - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
finish() - Method in class org.apache.lucene.codecs.PointsWriter
Called once at the end before close
finish() - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
return finalized form
finish() - Method in interface org.apache.lucene.internal.tests.IndexPackageAccess.FieldInfosBuilder
 
finish() - Method in class org.apache.lucene.search.FilterLeafCollector
 
finish() - Method in interface org.apache.lucene.search.LeafCollector
Hook that gets called once the leaf that is associated with this collector has finished collecting successfully, including when a CollectionTerminatedException is thrown.
finish() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Compiles all added states and transitions into a new Automaton and returns it.
finish() - Method in class org.apache.lucene.util.packed.DirectMonotonicWriter
This must be called exactly once after all values have been added.
finish() - Method in class org.apache.lucene.util.packed.DirectWriter
finishes writing
finish() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
Perform end-of-stream operations.
finish(int) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
finish(int) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
finish(int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Called before StoredFieldsWriter.close(), passing in the number of documents that were written.
finish(int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called before TermVectorsWriter.close(), passing in the number of documents that were written.
finish(IndexOutput, IndexOutput, IndexOutput) - Method in class org.apache.lucene.util.bkd.BKDWriter
Writes the BKD tree to the provided IndexOutputs and returns a Runnable that writes the index of the tree if at least one point has been added, or null otherwise.
finishDoc() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
finishDoc() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Called when we are done adding positions and payloads for each doc.
finishDocument() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
finishDocument() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
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.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
finishField() - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called after a field and all its terms have been added.
finishState() - Method in class org.apache.lucene.util.automaton.Automaton
Finishes the current state; call this once you are done adding transitions for a state.
finishTerm() - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called after a term and all its positions have been added.
finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
Called when we are done adding docs to this term
finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Finishes the current term.
finite - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Indicates if the automaton accepts a finite set of strings.
FiniteStringsIterator - Class in org.apache.lucene.util.automaton
Iterates all accepted strings.
FiniteStringsIterator(Automaton) - Constructor for class org.apache.lucene.util.automaton.FiniteStringsIterator
Constructor.
FiniteStringsIterator(Automaton, int, int) - Constructor for class org.apache.lucene.util.automaton.FiniteStringsIterator
Constructor.
FixedBitSet - Class in org.apache.lucene.util
BitSet of fixed length (numBits), backed by accessible (FixedBitSet.getBits()) long[], accessed with an int index, implementing Bits and DocIdSet.
FixedBitSet(int) - Constructor for class org.apache.lucene.util.FixedBitSet
Creates a new LongBitSet.
FixedBitSet(long[], int) - Constructor for class org.apache.lucene.util.FixedBitSet
Creates a new LongBitSet using the provided long[] array as backing store.
flags() - Method in class org.apache.lucene.util.fst.FST.Arc
 
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
FlatFieldVectorsWriter<T> - Class in org.apache.lucene.codecs
Vectors' writer for a field
FlatFieldVectorsWriter(KnnFieldVectorsWriter<T>) - Constructor for class org.apache.lucene.codecs.FlatFieldVectorsWriter
Sole constructor that expects some indexingDelegate.
FlatVectorsFormat - Class in org.apache.lucene.codecs
Encodes/decodes per-document vectors
FlatVectorsFormat() - Constructor for class org.apache.lucene.codecs.FlatVectorsFormat
Sole constructor
FlatVectorsReader - Class in org.apache.lucene.codecs
Reads vectors from an index.
FlatVectorsReader() - Constructor for class org.apache.lucene.codecs.FlatVectorsReader
Sole constructor
FlatVectorsWriter - Class in org.apache.lucene.codecs
Vectors' writer for a field that allows additional indexing logic to be implemented by the caller
FlatVectorsWriter() - Constructor for class org.apache.lucene.codecs.FlatVectorsWriter
Sole constructor
flip(int) - Method in class org.apache.lucene.util.FixedBitSet
Flip the bit at the provided index.
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.LongBitSet
Flip the bit at the provided index.
flip(long, long) - Method in class org.apache.lucene.util.LongBitSet
Flips a range of bits
flipFlop(long) - Static method in class org.apache.lucene.util.BitUtil
flip flops odd with even bits
FLOAT - org.apache.lucene.document.StoredValue.Type
Type of float values.
FLOAT - org.apache.lucene.search.SortField.Type
Sort using term values as encoded Floats.
FLOAT32 - org.apache.lucene.index.VectorEncoding
Encodes vector using 32 bits of precision per sample in IEEE floating point format.
floatArrayToDoubleArray(float[]) - Static method in class org.apache.lucene.geo.XYEncodingUtils
Convert an array of float numbers to double numbers.
FloatComparator - Class in org.apache.lucene.search.comparators
Comparator based on Float.compare(float, float) for numHits.
FloatComparator(int, String, Float, boolean, Pruning) - Constructor for class org.apache.lucene.search.comparators.FloatComparator
 
FloatComparator.FloatLeafComparator - Class in org.apache.lucene.search.comparators
Leaf comparator for FloatComparator that provides skipping functionality
FloatDocValuesField - Class in org.apache.lucene.document
Syntactic sugar for encoding floats as NumericDocValues via Float.floatToRawIntBits(float).
FloatDocValuesField(String, float) - Constructor for class org.apache.lucene.document.FloatDocValuesField
Creates a new DocValues field with the specified 32-bit float value
floatField(FieldInfo, float) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
floatField(FieldInfo, float) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
floatField(FieldInfo, float) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a float numeric field.
FloatField - Class in org.apache.lucene.document
Field that stores a per-document float value for scoring, sorting or value retrieval and index the field for fast range filters.
FloatField(String, float) - Constructor for class org.apache.lucene.document.FloatField
FloatField(String, float, Field.Store) - Constructor for class org.apache.lucene.document.FloatField
Creates a new FloatField, indexing the provided point, storing it as a DocValue, and optionally storing it as a stored field.
FloatHeap - Class in org.apache.lucene.util.hnsw
A bounded min heap that stores floats.
FloatHeap(int) - Constructor for class org.apache.lucene.util.hnsw.FloatHeap
 
FloatLeafComparator(LeafReaderContext) - Constructor for class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
FloatPoint - Class in org.apache.lucene.document
An indexed float field for fast range filters.
FloatPoint(String, float...) - Constructor for class org.apache.lucene.document.FloatPoint
Creates a new FloatPoint, indexing the provided N-dimensional float point.
FloatRange - Class in org.apache.lucene.document
An indexed Float Range field.
FloatRange(String, float[], float[]) - Constructor for class org.apache.lucene.document.FloatRange
Create a new FloatRange type, from min/max parallel arrays
FloatRangeDocValuesField - Class in org.apache.lucene.document
DocValues field for FloatRange.
FloatRangeDocValuesField(String, float[], float[]) - Constructor for class org.apache.lucene.document.FloatRangeDocValuesField
Sole constructor.
FloatSorter(String, Float, boolean, IndexSorter.NumericDocValuesProvider) - Constructor for class org.apache.lucene.index.IndexSorter.FloatSorter
Creates a new FloatSorter
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
floatToEdits(float, int) - Static method in class org.apache.lucene.search.FuzzyQuery
Helper function to convert from "minimumSimilarity" fractions to raw edit distances.
floatToSortableInt(float) - Static method in class org.apache.lucene.util.NumericUtils
Converts a float value to a sortable signed int.
FloatVectorSimilarityQuery - Class in org.apache.lucene.search
Search for all (approximate) float vectors above a similarity threshold.
FloatVectorSimilarityQuery(String, float[], float) - Constructor for class org.apache.lucene.search.FloatVectorSimilarityQuery
Search for all (approximate) float vectors above a similarity threshold using VectorSimilarityCollector.
FloatVectorSimilarityQuery(String, float[], float, float) - Constructor for class org.apache.lucene.search.FloatVectorSimilarityQuery
Search for all (approximate) float vectors above a similarity threshold using VectorSimilarityCollector.
FloatVectorSimilarityQuery(String, float[], float, float, Query) - Constructor for class org.apache.lucene.search.FloatVectorSimilarityQuery
Search for all (approximate) float vectors above a similarity threshold using VectorSimilarityCollector.
FloatVectorSimilarityQuery(String, float[], float, Query) - Constructor for class org.apache.lucene.search.FloatVectorSimilarityQuery
Search for all (approximate) float vectors above a similarity threshold using VectorSimilarityCollector.
FloatVectorValues - Class in org.apache.lucene.index
This class provides access to per-document floating point vector values indexed as KnnFloatVectorField.
FloatVectorValues() - Constructor for class org.apache.lucene.index.FloatVectorValues
Sole constructor
floor(BytesRef, BytesRefBuilder) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
Finds largest term accepted by this Automaton, that's <= the provided input term.
floorBlockCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
The number of floor blocks (meta-blocks larger than the allowed maxItemsPerBlock) in the terms file.
floorSubBlockCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
The number of sub-blocks within the floor blocks.
flush() - Method in class org.apache.lucene.index.IndexWriter
Moves all in-memory segments to the Directory, but does not commit (fsync) them (call IndexWriter.commit() for that).
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.
flush(int, Sorter.DocMap) - Method in class org.apache.lucene.codecs.BufferingKnnVectorsWriter
 
flush(int, Sorter.DocMap) - Method in class org.apache.lucene.codecs.FlatVectorsWriter
Flush all buffered data on disk *
flush(int, Sorter.DocMap) - Method in class org.apache.lucene.codecs.KnnVectorsWriter
Flush all buffered data on disk *
flush(int, Sorter.DocMap) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
flush(int, Sorter.DocMap) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsWriter
 
flush(int, Sorter.DocMap) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
FLUSH - org.apache.lucene.store.IOContext.Context
 
flushInfo - Variable in class org.apache.lucene.store.IOContext
 
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.
flushNextBuffer() - Method in class org.apache.lucene.index.IndexWriter
Expert: Flushes the next pending writer per thread buffer if available or the largest active non-pending writer per thread buffer in the calling thread.
flushPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
FlushPolicy to control when segments are flushed.
FOOTER_MAGIC - Static variable in class org.apache.lucene.codecs.CodecUtil
Constant to identify the start of a codec footer.
footerLength() - Static method in class org.apache.lucene.codecs.CodecUtil
Computes the length of a codec footer.
forceDelete(String) - Method in class org.apache.lucene.util.FileDeleter
 
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() - Method in class org.apache.lucene.index.IndexWriter
Forces merging of all segments that have deleted documents.
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.
ForDeltaUtil - Class in org.apache.lucene.codecs.lucene99
Utility class to encode/decode increasing sequences of 128 integers.
forEach(CheckedIntConsumer<IOException>) - Method in class org.apache.lucene.search.DocIdStream
Iterate over doc IDs contained in this stream in order, calling the given CheckedIntConsumer on them.
forField(String, IOSupplier<MatchesIterator>) - Static method in class org.apache.lucene.search.MatchesUtils
Create a Matches for a single field
format - Variable in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
 
FormatAndBits(PackedInts.Format, int) - Constructor for class org.apache.lucene.util.packed.PackedInts.FormatAndBits
 
forName(String) - Static method in class org.apache.lucene.codecs.Codec
looks up a codec by name
forName(String) - Static method in class org.apache.lucene.codecs.DocValuesFormat
looks up a format by name
forName(String) - Static method in class org.apache.lucene.codecs.KnnVectorsFormat
looks up a format by name
forName(String) - Static method in class org.apache.lucene.codecs.PostingsFormat
looks up a format by name
forName(String) - Static method in enum org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
forName(String) - Static method in class org.apache.lucene.index.SortFieldProvider
Looks up a SortFieldProvider by name
forName(String, Map<String, String>) - Static method in class org.apache.lucene.analysis.CharFilterFactory
looks up a charfilter by name from context classpath
forName(String, Map<String, String>) - Static method in class org.apache.lucene.analysis.TokenFilterFactory
looks up a tokenfilter by name from context classpath
forName(String, Map<String, String>) - Static method in class org.apache.lucene.analysis.TokenizerFactory
looks up a tokenizer by name from context classpath
FOUND - org.apache.lucene.index.TermsEnum.SeekStatus
The precise term was found.
FREE_BSD - Static variable in class org.apache.lucene.util.Constants
True iff running on FreeBSD
freeBefore(int) - Method in class org.apache.lucene.util.RollingBuffer
 
freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
Removes the given number of byte blocks from the buffer if possible.
freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
Removes the given number of int blocks from the buffer if possible.
freeze() - Method in class org.apache.lucene.document.FieldType
Prevents future changes.
freeze(boolean) - Method in class org.apache.lucene.util.PagedBytes
Commits final byte[], trimming it if necessary and if trim=true
freq - Variable in class org.apache.lucene.index.Impact
Term frequency of the term in the document.
freq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
freq() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
freq() - Method in class org.apache.lucene.index.PostingsEnum
Returns term frequency in the current document, or 1 if the field was indexed with IndexOptions.DOCS.
freq() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
freq() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionFullPostingsEnum
 
freq() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
freq() - Method in class org.apache.lucene.search.TermScorer
Returns term frequency in the current document.
FREQS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require term frequencies in the returned enum.
frequency(int) - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
Returns the frequency of the provided key in the ring buffer.
FrequencyTrackingRingBuffer - Class in org.apache.lucene.util
A ring buffer that tracks the frequency of the integers that it contains.
FrequencyTrackingRingBuffer(int, int) - Constructor for class org.apache.lucene.util.FrequencyTrackingRingBuffer
Create a new ring buffer that will contain at most maxSize items.
from - Variable in class org.apache.lucene.util.automaton.RegExp
Extents for range type expressions
from(int[], int[]) - Static method in class org.apache.lucene.util.hppc.IntIntHashMap
Creates a hash map from two index-aligned arrays of key-value pairs.
fromBits(int, int, int) - Static method in class org.apache.lucene.util.Version
Returns a new version based on raw numbers
fromDoubleField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
Creates a DoubleValuesSource that wraps a double-valued field
fromField(String, LongToDoubleFunction) - Static method in class org.apache.lucene.search.DoubleValuesSource
Creates a DoubleValuesSource that wraps a generic NumericDocValues field
fromFloatField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
Creates a DoubleValuesSource that wraps a float-valued field
fromFSTReader(FST.FSTMetadata<T>, FSTReader) - Static method in class org.apache.lucene.util.fst.FST
Create a FST from a FSTReader.
fromGeoJSON(String) - Static method in class org.apache.lucene.geo.Polygon
Parses a standard GeoJSON polygon string.
fromGraph(RandomVectorScorerSupplier, int, int, long, HnswGraph, int[], BitSet, int) - Static method in class org.apache.lucene.util.hnsw.InitializedHnswGraphBuilder
Create a new HnswGraphBuilder that is initialized with the provided HnswGraph.
fromIntField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
Creates a DoubleValuesSource that wraps an int-valued field
fromIntField(String) - Static method in class org.apache.lucene.search.LongValuesSource
Creates a LongValuesSource that wraps an int-valued field
fromLongField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
Creates a DoubleValuesSource that wraps a long-valued field
fromLongField(String) - Static method in class org.apache.lucene.search.LongValuesSource
Creates a LongValuesSource that wraps a long-valued field
fromPointDistance(double, double, double) - Static method in class org.apache.lucene.geo.Rectangle
Compute Bounding Box for a circle using WGS-84 parameters
fromPointDistance(float, float, float) - Static method in class org.apache.lucene.geo.XYRectangle
Compute Bounding Box for a circle in cartesian geometry
fromPolygon(Polygon[]) - Static method in class org.apache.lucene.geo.Rectangle
Returns the bounding box over an array of polygons
fromQuery(Query) - Static method in class org.apache.lucene.search.DoubleValuesSource
Create a DoubleValuesSource that returns the score of a particular query
fromScorer(Scorable) - Static method in class org.apache.lucene.search.DoubleValuesSource
Returns a DoubleValues instance that wraps scores returned by a Scorer.
fromSign(int) - Static method in enum org.apache.lucene.geo.GeoUtils.WindingOrder
 
fromStoredMeta(IndexInput, int) - Static method in class org.apache.lucene.codecs.lucene95.OrdToDocDISIReaderConfiguration
Reads in the necessary fields stored in the outputMeta to configure DirectMonotonicReader and IndexedDISI.
fromSubMatches(List<Matches>) - Static method in class org.apache.lucene.search.MatchesUtils
Amalgamate a collection of Matches into a single object
fromVectors(FloatVectorValues, float, int) - Static method in class org.apache.lucene.util.quantization.ScalarQuantizer
This will read the float vector values and calculate the quantiles.
fromVectorSimilarity(VectorSimilarityFunction, float) - Static method in interface org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity
Creates a ScalarQuantizedVectorSimilarity from a VectorSimilarityFunction and the constant multiplier used for quantization.
FSDirectory - Class in org.apache.lucene.store
Base class for Directory implementations that store index files in the file system.
FSDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.FSDirectory
Create a new FSDirectory for the named location (ctor for subclasses).
FSLockFactory - Class in org.apache.lucene.store
Base class for file system based locking implementation.
FSLockFactory() - Constructor for class org.apache.lucene.store.FSLockFactory
 
FST<T> - Class in org.apache.lucene.util.fst
Represents an finite state machine (FST), using a compact byte[] format.
FST(FST.FSTMetadata<T>, DataInput) - Constructor for class org.apache.lucene.util.fst.FST
Load a previously saved FST with a DataInput for metdata using an OnHeapFSTStore with maxBlockBits set to FST.DEFAULT_MAX_BLOCK_BITS
FST(FST.FSTMetadata<T>, DataInput, FSTStore) - Constructor for class org.apache.lucene.util.fst.FST
Load a previously saved FST with a metdata object and a FSTStore.
FST.Arc<T> - Class in org.apache.lucene.util.fst
Represents a single arc.
FST.BytesReader - Class in org.apache.lucene.util.fst
Reads bytes stored in an FST.
FST.FSTMetadata<T> - Class in org.apache.lucene.util.fst
Represents the FST metadata.
FST.INPUT_TYPE - Enum in org.apache.lucene.util.fst
Specifies allowed range of each int input label for this FST.
FSTCompiler<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.
FSTCompiler.Builder<T> - Class in org.apache.lucene.util.fst
Fluent-style constructor for FST FSTCompiler.
FSTMetadata(FST.INPUT_TYPE, Outputs<T>, T, long, int, long) - Constructor for class org.apache.lucene.util.fst.FST.FSTMetadata
 
fstRamBytesUsed() - Method in class org.apache.lucene.util.fst.FSTCompiler
 
FSTReader - Interface in org.apache.lucene.util.fst
Abstraction for reading bytes necessary for FST.
fstSizeInBytes() - Method in class org.apache.lucene.util.fst.FSTCompiler
 
FSTStore - Interface in org.apache.lucene.util.fst
A type of FSTReader which needs data to be initialized before use
fsync(String) - Method in class org.apache.lucene.store.FSDirectory
 
fsync(Path, boolean) - Static method in class org.apache.lucene.util.IOUtils
Ensure that any writes to the given file is written to the storage device that contains it.
FULL_FLUSH - org.apache.lucene.index.MergeTrigger
Merge was triggered by a full flush.
FuzzyQuery - Class in org.apache.lucene.search
Implements the fuzzy search query.
FuzzyQuery(Term) - Constructor for class org.apache.lucene.search.FuzzyQuery
FuzzyQuery(Term, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
FuzzyQuery(Term, int, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
FuzzyQuery(Term, int, int, int, boolean) - Constructor for class org.apache.lucene.search.FuzzyQuery
Calls FuzzyQuery(Term, int, int, int, boolean, org.apache.lucene.search.MultiTermQuery.RewriteMethod) FuzzyQuery(term, maxEdits, prefixLength, maxExpansions, defaultRewriteMethod(maxExpansions))
FuzzyQuery(Term, int, int, int, boolean, MultiTermQuery.RewriteMethod) - 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.
FuzzyTermsEnum - Class in org.apache.lucene.search
Subclass of TermsEnum for enumerating all terms that are similar to the specified filter term.
FuzzyTermsEnum(Terms, Term, int, 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 at most maxEdits edits.
FuzzyTermsEnum.FuzzyTermsException - Exception in org.apache.lucene.search
Thrown to indicate that there was an issue creating a fuzzy query for a given term.

G

gamma(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
compute the gamma component (only for F3EXp and F3LOG)
gamma(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
compute the gamma component
gamma(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
compute the gamma component
gamma(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
compute the gamma component
gamma(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
compute the gamma component
gamma(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
compute the gamma component
gamma(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
compute the gamma component
GB - Static variable in class org.apache.lucene.util.OfflineSorter
Convenience constant for gigabytes
gcd(long, long) - Static method in class org.apache.lucene.util.MathUtil
Return the greatest common divisor of a and b, consistently with BigInteger.gcd(BigInteger).
generationFromSegmentsFileName(String) - Static method in class org.apache.lucene.index.SegmentInfos
Parse the generation off the segments file name and return it.
GeoEncodingUtils - Class in org.apache.lucene.geo
reusable geopoint encoding methods
GeoEncodingUtils.Component2DPredicate - Class in org.apache.lucene.geo
A predicate that checks whether a given point is within a component2D geometry.
GeoEncodingUtils.DistancePredicate - Class in org.apache.lucene.geo
A predicate that checks whether a given point is within a distance of another point.
Geometry - Class in org.apache.lucene.geo
Base class for LatLonGeometry and XYGeometry
Geometry() - Constructor for class org.apache.lucene.geo.Geometry
 
GEOMETRYCOLLECTION - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
GeoUtils - Class in org.apache.lucene.geo
Basic reusable geo-spatial utility methods
GeoUtils.WindingOrder - Enum in org.apache.lucene.geo
used to define the orientation of 3 points -1 = Clockwise 0 = Colinear 1 = Counter-clockwise
get() - Method in class org.apache.lucene.util.BytesRefBuilder
Return a BytesRef that points to the internal content of this builder.
get() - Method in class org.apache.lucene.util.CharsRefBuilder
Return a CharsRef that points to the internal content of this builder.
get() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
get() - Method in class org.apache.lucene.util.Counter
Returns the counters current value
get() - Method in class org.apache.lucene.util.IntsRefBuilder
Return a IntsRef that points to the internal content of this builder.
get() - Method in interface org.apache.lucene.util.IOSupplier
Gets the result.
get() - Method in class org.apache.lucene.util.RefCount
 
get() - Method in class org.apache.lucene.util.SetOnce
Returns the object set by SetOnce.set(Object).
get(char[], int, int) - Method in class org.apache.lucene.analysis.CharArrayMap
returns the value of the mapping of len chars of text starting at off
get(int) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsReader
 
get(int) - Method in interface org.apache.lucene.index.MergeState.DocMap
Return the mapped docID or -1 if the given doc is not mapped.
get(int) - Method in class org.apache.lucene.index.MultiBits
 
get(int) - Method in class org.apache.lucene.index.TermVectors
Returns term vectors for this document, or null if term vectors were not indexed.
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) - Method in class org.apache.lucene.util.FixedBitSet
 
get(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
get(int) - Method in class org.apache.lucene.util.LongHeap
Return the element at the ith location in the heap array.
get(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
get(int) - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
 
get(int) - Method in class org.apache.lucene.util.packed.PackedInts.Reader
Get the long at the given index.
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(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
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(int, String) - Method in class org.apache.lucene.index.TermVectors
Retrieve term vector for this document and field, or null if term vectors were not indexed.
get(int, BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Populates and returns a BytesRef with the bytes for the given bytesID.
get(long) - Method in class org.apache.lucene.search.ScorerSupplier
Get the Scorer.
get(long) - Method in class org.apache.lucene.util.LongBitSet
 
get(long) - Method in class org.apache.lucene.util.LongValues
Get value at index.
get(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
 
get(long) - Method in class org.apache.lucene.util.packed.DirectMonotonicReader
 
get(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
get(long) - Method in class org.apache.lucene.util.packed.PackedLongValues
 
get(CharSequence) - Method in class org.apache.lucene.analysis.CharArrayMap
returns the value of the mapping of the chars inside this CharSequence
get(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
 
get(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
Returns the value to which the specified key is mapped.
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(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(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
get(Map<String, String>, String, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
get(Map<String, String>, String, Collection<String>) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
get(Map<String, String>, String, Collection<String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
get(Map<String, String>, String, Collection<String>, String, boolean) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
get(LeafReader) - Method in interface org.apache.lucene.index.IndexSorter.NumericDocValuesProvider
Returns the NumericDocValues instance for this LeafReader
get(LeafReader) - Method in interface org.apache.lucene.index.IndexSorter.SortedDocValuesProvider
Returns the SortedDocValues instance for this LeafReader
get(LeafReaderContext) - Method in class org.apache.lucene.index.TermStates
Returns the TermState for a leaf reader context or null if no TermState for the context was registered.
get(BytesRefBuilder, int) - Method in class org.apache.lucene.util.BytesRefArray
Returns the n'th element of this BytesRefArray
get(BytesRefBuilder, BytesRef, int) - Method in class org.apache.lucene.util.StringSorter
 
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(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_READER - org.apache.lucene.index.MergeTrigger
Merge was triggered on opening NRT readers.
getAcceptOrds(Bits) - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues.DenseOffHeapVectorValues
 
getAcceptOrds(Bits) - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues.DenseOffHeapVectorValues
 
getAcceptOrds(Bits) - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues
 
getAcceptOrds(Bits) - Method in interface org.apache.lucene.util.hnsw.RandomAccessVectorValues
Returns the Bits representing live documents.
getAcceptOrds(Bits) - Method in class org.apache.lucene.util.hnsw.RandomVectorScorer.AbstractRandomVectorScorer
 
getAcceptOrds(Bits) - Method in interface org.apache.lucene.util.hnsw.RandomVectorScorer
Returns the Bits representing live documents.
getAfterEffect() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
Returns the first normalization
getAllFiles() - Method in class org.apache.lucene.util.FileDeleter
get all files, some of them may have ref count 0
getAnalyzer() - Method in class org.apache.lucene.index.IndexWriter
Returns the analyzer used by this index.
getAnalyzer() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getAnalyzer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the default analyzer to use for indexing documents.
getAnalyzer() - Method in class org.apache.lucene.util.QueryBuilder
Returns the analyzer.
getAndClear(int) - Method in class org.apache.lucene.util.FixedBitSet
 
getAndClear(long) - Method in class org.apache.lucene.util.LongBitSet
 
getAndSet(int) - Method in class org.apache.lucene.util.BitSet
Set the bit at i, returning true if it was previously set.
getAndSet(int) - Method in class org.apache.lucene.util.FixedBitSet
 
getAndSet(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
getAndSet(long) - Method in class org.apache.lucene.util.LongBitSet
 
getArcCount() - Method in class org.apache.lucene.util.fst.FSTCompiler
 
getAsComparableLong(int) - Method in interface org.apache.lucene.index.IndexSorter.ComparableProvider
Returns a long so that the natural ordering of long values matches the ordering of doc IDs for the given comparator
getAttribute(Class<T>) - Method in class org.apache.lucene.util.AttributeSource
Returns the instance of the passed in Attribute contained in this AttributeSource
getAttribute(String) - Method in class org.apache.lucene.index.FieldInfo
Get a codec attribute value, or null if it does not exist
getAttribute(String) - Method in class org.apache.lucene.index.SegmentInfo
Get a codec attribute value, or null if it does not exist
getAttributeClassesIterator() - Method in class org.apache.lucene.util.AttributeSource
Returns a new iterator that iterates the attribute classes in the same order they were added in.
getAttributeFactory() - Method in class org.apache.lucene.util.AttributeSource
returns the used AttributeFactory.
getAttributeImplsIterator() - Method in class org.apache.lucene.util.AttributeSource
Returns a new iterator that iterates all unique Attribute implementations.
getAttributes() - Method in class org.apache.lucene.document.FieldType
 
getAttributes() - Method in interface org.apache.lucene.index.IndexableFieldType
Attributes for the field type.
getAttributes() - Method in class org.apache.lucene.index.SegmentInfo
Returns the internal codec attributes map.
getAttributeSource() - Method in class org.apache.lucene.index.FieldInvertState
Returns the AttributeSource from the TokenStream that provided the indexed tokens for this field.
getAutoGenerateMultiTermSynonymsPhraseQuery() - Method in class org.apache.lucene.util.QueryBuilder
Returns true if phrase query should be automatically generated for multi terms synonyms.
getAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns true if auto IO throttling is currently enabled.
getAutomata() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the compiled automata used to match terms
getAutomaton() - Method in class org.apache.lucene.search.AutomatonQuery
Returns the automaton used to create this query
getAutomaton() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Returns the automaton that caused this exception, if any.
getAutomaton(String) - Method in interface org.apache.lucene.util.automaton.AutomatonProvider
Returns automaton of the given name.
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.index.EmptyDocValuesProducer
 
getBinary(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns BinaryDocValues for the field, or DocValues.emptyBinary() if it has none.
getBinaryDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getBinaryDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns BinaryDocValues for this field, or null if no binary doc values were indexed for this field.
getBinaryDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getBinaryDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
Retrieves the BinaryDocValues for the field in this segment
getBinaryValue() - Method in class org.apache.lucene.document.StoredValue
Retrieve a binary value.
getBinaryValue(String) - Method in class org.apache.lucene.document.Document
Returns an array of bytes for the first (or only) field that has the name specified as the method parameter.
getBinaryValues(String) - Method in class org.apache.lucene.document.Document
Returns an array of byte arrays for of the fields that have the name specified as the method parameter.
getBinaryValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a BinaryDocValues for a reader's docvalues (potentially merging on-the-fly)
getBits() - Method in class org.apache.lucene.util.FixedBitSet
Expert.
getBits() - Method in class org.apache.lucene.util.LongBitSet
Expert.
getBitSet() - Method in class org.apache.lucene.util.BitSetIterator
Return the wrapped BitSet.
getBitSet() - Method in class org.apache.lucene.util.DocBaseBitSetIterator
Get the FixedBitSet.
getBitsPerValue() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
 
getBitsPerValue() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
Returns number of bits per value
getBoolean(Map<String, String>, String, boolean) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
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.BoostQuery
Return the applied boost.
getBoost() - Method in class org.apache.lucene.search.FuzzyTermsEnum
Gets the boost of the current term
getBoost() - Method in class org.apache.lucene.search.IndriScorer
 
getBoost() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the total boost.
getBoundingBox() - Method in class org.apache.lucene.document.LatLonShapeDocValues
 
getBoundingBox() - Method in class org.apache.lucene.document.LatLonShapeDocValuesField
retrieves the bounding box for the geometry
getBoundingBox() - Method in class org.apache.lucene.document.ShapeDocValuesField
retrieves the bounding box for the geometry
getBoundingBox() - Method in class org.apache.lucene.document.XYShapeDocValues
 
getBoundingBox() - Method in class org.apache.lucene.document.XYShapeDocValuesField
 
getBucket(int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
Return a number for the k-th character between 0 and MSBRadixSorter.HISTOGRAM_SIZE.
getBuffer() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
Returns the internal buffer
getBuffer(int) - Method in class org.apache.lucene.util.ByteBlockPool
Retrieve the buffer at the specified index from the buffer pool.
getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexInput
Returns buffer size
getBufferSize() - Method in class org.apache.lucene.util.RollingBuffer
Returns how many active positions are in the buffer.
getByte(long) - Method in class org.apache.lucene.util.PagedBytes.Reader
Get the byte at the given offset.
getByteAt(int, int) - Method in class org.apache.lucene.codecs.MutablePointTree
Get the k-th byte of the i-th value.
getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
 
getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
getByteBlock() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
getBytesComparator() - Method in class org.apache.lucene.search.SortField
 
getBytesPerDim() - Method in class org.apache.lucene.search.PointInSetQuery
 
getBytesPerDim() - Method in class org.apache.lucene.search.PointRangeQuery
 
getBytesPerDimension() - Method in class org.apache.lucene.index.PointValues
Returns the number of bytes per dimension
getBytesPerDimension() - Method in class org.apache.lucene.util.bkd.BKDReader
 
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.tokenattributes.BytesTermAttributeImpl
 
getBytesRef() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
getBytesRef() - Method in interface org.apache.lucene.analysis.tokenattributes.TermToBytesRefAttribute
Retrieve this attribute's BytesRef.
getByteVectorValues(String) - Method in class org.apache.lucene.codecs.FlatVectorsReader
Returns the ByteVectorValues for the given field.
getByteVectorValues(String) - Method in class org.apache.lucene.codecs.KnnVectorsReader
Returns the ByteVectorValues for the given field.
getByteVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
getByteVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
getByteVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
getByteVectorValues(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
 
getByteVectorValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getByteVectorValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getByteVectorValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getByteVectorValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns ByteVectorValues for this field, or null if no ByteVectorValues were indexed.
getByteVectorValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getC() - Method in class org.apache.lucene.search.similarities.NormalizationH1
Returns the c parameter.
getC() - Method in class org.apache.lucene.search.similarities.NormalizationH2
Returns the c parameter.
getCacheCount() - Method in class org.apache.lucene.search.LRUQueryCache
Return the total number of cache entries that have been generated and put in the cache.
getCacheSize() - Method in class org.apache.lucene.search.LRUQueryCache
Return the total number of DocIdSets which are currently stored in the cache.
getCalibrateSizeByDeletes() - Method in class org.apache.lucene.index.LogMergePolicy
Returns true if the segment size should be calibrated by the number of deletes when choosing segments for merge.
getCentroid() - Method in class org.apache.lucene.document.LatLonShapeDocValues
 
getCentroid() - Method in class org.apache.lucene.document.LatLonShapeDocValuesField
retrieves the centroid location for the geometry
getCentroid() - Method in class org.apache.lucene.document.ShapeDocValuesField
retrieves the centroid location for the geometry
getCentroid() - Method in class org.apache.lucene.document.XYShapeDocValues
 
getCentroid() - Method in class org.apache.lucene.document.XYShapeDocValuesField
retrieves the centroid location for the geometry
getChar(Map<String, String>, String, char) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
getCharIntervals() - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns array of codepoint class interval start points.
getCharSequenceValue() - Method in class org.apache.lucene.document.Field
 
getCharSequenceValue() - Method in interface org.apache.lucene.index.IndexableField
Non-null if this field has a string value
getChecksum() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
getChecksum() - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexInput
Returns the current checksum value
getChecksum() - Method in class org.apache.lucene.store.FilterIndexOutput
 
getChecksum() - Method in class org.apache.lucene.store.IndexOutput
Returns the current checksum of bytes written so far
getChecksum() - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
getChecksumsOnly() - Method in class org.apache.lucene.index.CheckIndex
getChildren() - Method in class org.apache.lucene.search.FilterScorable
 
getChildren() - Method in class org.apache.lucene.search.Scorable
Returns child sub-scorers positioned on the current document
getChildren() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
getChildResources() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
getChildResources() - Method in class org.apache.lucene.index.OrdinalMap
 
getChildResources() - Method in class org.apache.lucene.search.LRUQueryCache
 
getChildResources() - Method in class org.apache.lucene.search.TermInSetQuery
 
getChildResources() - Method in interface org.apache.lucene.util.Accountable
Returns nested resources of this class.
getClassArg() - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
getClauses() - Method in class org.apache.lucene.search.IndriQuery
 
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.
getCollectors() - Method in class org.apache.lucene.search.MultiCollector
Provides access to the wrapped Collectors for advanced use-cases
getCollectors() - Method in class org.apache.lucene.search.TopFieldCollectorManager
 
getCommitLuceneVersion() - Method in class org.apache.lucene.index.SegmentInfos
Returns which Lucene Version wrote this commit, or null if the version this index was written with did not directly record the version.
getCommitOnClose() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns true if IndexWriter.close() should first commit before closing.
getCommonPrefix(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns the longest string that is a prefix of all accepted strings and visits each state at most once.
getCommonPrefixBytesRef(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns the longest BytesRef that is a prefix of all accepted strings and visits each state at most once.
getCommonSuffixBytesRef(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns the longest BytesRef that is a suffix of all accepted strings.
getComparableProviders(List<? extends LeafReader>) - Method in class org.apache.lucene.index.IndexSorter.DoubleSorter
 
getComparableProviders(List<? extends LeafReader>) - Method in class org.apache.lucene.index.IndexSorter.FloatSorter
 
getComparableProviders(List<? extends LeafReader>) - Method in interface org.apache.lucene.index.IndexSorter
Get an array of IndexSorter.ComparableProvider, one per segment, for merge sorting documents in different segments
getComparableProviders(List<? extends LeafReader>) - Method in class org.apache.lucene.index.IndexSorter.IntSorter
 
getComparableProviders(List<? extends LeafReader>) - Method in class org.apache.lucene.index.IndexSorter.LongSorter
 
getComparableProviders(List<? extends LeafReader>) - Method in class org.apache.lucene.index.IndexSorter.StringSorter
 
getComparator() - Method in class org.apache.lucene.util.OfflineSorter
Returns the comparator in use to sort entries
getComparator(int, Pruning) - Method in class org.apache.lucene.search.SortedNumericSortField
 
getComparator(int, Pruning) - Method in class org.apache.lucene.search.SortedSetSortField
 
getComparator(int, Pruning) - Method in class org.apache.lucene.search.SortField
Returns the FieldComparator to use for sorting.
getComparators() - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getComparators(LeafReaderContext) - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getComparatorSource() - Method in class org.apache.lucene.search.SortField
Returns the FieldComparatorSource used for custom sorting
getCompetitiveFreqNormPairs() - Method in class org.apache.lucene.codecs.CompetitiveImpactAccumulator
Get the set of competitive freq and norm pairs, ordered by increasing freq and norm.
getCompetitiveTerm() - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
This is the term or null of the term that triggered the boost change.
getCompetitiveTerm() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
getCompoundReader(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.CompoundFormat
Returns a Directory view (read-only) for the compound files in this segment
getCompoundReader(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene90.Lucene90CompoundFormat
 
getConcurrentMergeSchedulerAccess() - Static method in class org.apache.lucene.internal.tests.TestSecrets
Return the accessor to internal secrets for an ConcurrentMergeScheduler.
getConfidenceInterval() - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
 
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.
getConstantMultiplier() - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
 
getContext() - Method in class org.apache.lucene.index.CompositeReader
 
getContext() - Method in class org.apache.lucene.index.IndexReader
Expert: Returns the root IndexReaderContext for this IndexReader's sub-reader tree.
getContext() - Method in class org.apache.lucene.index.LeafReader
 
getCore(SegmentReader) - Method in interface org.apache.lucene.internal.tests.SegmentReaderAccess
 
getCoreCacheHelper() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getCoreCacheHelper() - Method in class org.apache.lucene.index.LeafReader
Optional method: Return a IndexReader.CacheHelper that can be used to cache based on the content of this leaf regardless of deletions.
getCoreCacheHelper() - Method in class org.apache.lucene.index.ParallelLeafReader
 
getCoreCacheHelper() - Method in class org.apache.lucene.index.SegmentReader
 
getCoreCacheHelper() - Method in class org.apache.lucene.index.SortingCodecReader
 
getCreatedFiles() - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
NOTE: returns a copy of the created files.
getCreatedVersionMajor() - Method in class org.apache.lucene.index.LeafMetaData
Get the Lucene version that created this index.
getCurrentLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
getCurrentLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
getDataInput() - Method in class org.apache.lucene.util.PagedBytes
Returns a DataInput to read values from this PagedBytes instance.
getDataOutput() - Method in class org.apache.lucene.util.PagedBytes
Returns a DataOutput that you may use to write into this PagedBytes instance.
getDecoder(PackedInts.Format, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
getDecodingReader(InputStream, Charset) - Static method in class org.apache.lucene.util.IOUtils
Wrapping the given InputStream in a reader using a CharsetDecoder.
getDecodingReader(Class<?>, String, Charset) - Static method in class org.apache.lucene.util.IOUtils
Deprecated, for removal: This API element is subject to removal in a future version.
Class.getResourceAsStream(String) is caller sensitive and cannot load resources across Java Modules. Please call the getResourceAsStream() directly and use IOUtils.requireResourceNonNull(Object,String) to signal missing resources null
getDefault() - Static method in class org.apache.lucene.codecs.Codec
expert: returns the default codec used for newly created IndexWriterConfigs.
getDefault() - Static method in class org.apache.lucene.store.FSLockFactory
Returns the default locking implementation for this platform.
getDefault() - Static method in class org.apache.lucene.util.InfoStream
The default InfoStream used by a newly instantiated classes.
getDefaultQueryCache() - Static method in class org.apache.lucene.search.IndexSearcher
Expert: Get the default QueryCache or null if the cache is disabled.
getDefaultQueryCachingPolicy() - Static method in class org.apache.lucene.search.IndexSearcher
Expert: Get the default QueryCachingPolicy.
getDefaultSimilarity() - Static method in class org.apache.lucene.search.IndexSearcher
Expert: returns a default Similarity instance.
getDelCount() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the number of deleted docs in the segment.
getDelegate() - Method in class org.apache.lucene.index.FilterCodecReader
Returns the wrapped CodecReader.
getDelegate() - Method in class org.apache.lucene.index.FilterDirectoryReader
Returns the wrapped DirectoryReader.
getDelegate() - Method in class org.apache.lucene.index.FilterLeafReader
Returns the wrapped LeafReader.
getDelegate() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
Return the wrapped DocIdSetIterator.
getDelegate() - Method in class org.apache.lucene.store.FilterDirectory
Return the wrapped Directory.
getDelegate() - Method in class org.apache.lucene.store.FilterIndexInput
Gets the delegate that was passed in on creation
getDelegate() - Method in class org.apache.lucene.store.FilterIndexOutput
Gets the delegate that was passed in on creation
getDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current deletesPctAllowed setting.
getDelGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns generation number of the live docs file or -1 if there are no deletes yet.
getDescription() - Method in class org.apache.lucene.search.Explanation
A description of this explanation node.
getDetails() - Method in class org.apache.lucene.search.Explanation
The sub-nodes of this explanation node.
getDeterminizeWorkLimit() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Get the maximum allowed determinize effort.
getDiagnostics() - Method in class org.apache.lucene.index.SegmentInfo
Returns diagnostics saved into the segment when it was written.
getDirectAddressingMaxOversizingFactor() - Method in class org.apache.lucene.util.fst.FSTCompiler
 
getDirectMonotonicReader(IndexInput) - Method in class org.apache.lucene.codecs.lucene95.OrdToDocDISIReaderConfiguration
 
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 class org.apache.lucene.store.FSDirectory
 
getDirectory() - Method in class org.apache.lucene.util.OfflineSorter
Returns the Directory we use to create temp files.
getDirImpl() - Method in class org.apache.lucene.index.CheckIndex.Options
Get the name of the FSDirectory implementation class to use.
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.SimilarityBase
Returns true if overlap tokens are discounted from the document's length.
getDiscountOverlaps() - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
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.
getDocBase() - Method in class org.apache.lucene.util.DocBaseBitSetIterator
Get the docBase.
getDocComparator(LeafReader, int) - Method in class org.apache.lucene.index.IndexSorter.DoubleSorter
 
getDocComparator(LeafReader, int) - Method in class org.apache.lucene.index.IndexSorter.FloatSorter
 
getDocComparator(LeafReader, int) - Method in interface org.apache.lucene.index.IndexSorter
Get a comparator that determines the sort order of docs within a single Reader.
getDocComparator(LeafReader, int) - Method in class org.apache.lucene.index.IndexSorter.IntSorter
 
getDocComparator(LeafReader, int) - Method in class org.apache.lucene.index.IndexSorter.LongSorter
 
getDocComparator(LeafReader, int) - Method in class org.apache.lucene.index.IndexSorter.StringSorter
 
getDocCount() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
getDocCount() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
getDocCount() - Method in class org.apache.lucene.index.MultiTerms
 
getDocCount() - Method in class org.apache.lucene.index.PointValues
Returns the total number of documents that have indexed at least one point.
getDocCount() - Method in class org.apache.lucene.index.Terms
Returns the number of documents that have at least one term for this field.
getDocCount() - Method in class org.apache.lucene.util.bkd.BKDReader
 
getDocCount(String) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getDocCount(String) - Method in class org.apache.lucene.index.IndexReader
Returns the number of documents that have at least one term for this field.
getDocCount(String) - Method in class org.apache.lucene.index.LeafReader
 
getDocCount(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
Return the cumulated number of docs that have points across all leaves of the given IndexReader.
getDocCountSeen() - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
Returns total number of unique docIDs in this BKD tree
getDocFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the document frequency.
getDocID(int) - Method in class org.apache.lucene.codecs.MutablePointTree
Return the doc ID of the i-th value.
getDocIdUpTo(int) - Method in class org.apache.lucene.index.Impacts
Return the maximum inclusive doc ID until which the list of impacts returned by Impacts.getImpacts(int) is valid.
getDocPointer() - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
Returns the doc pointer of the doc to which the last call of MultiLevelSkipListReader.skipTo(int) has skipped.
getDocStats() - Method in class org.apache.lucene.index.IndexWriter
Returns accurate IndexWriter.DocStats for this writer.
getDocument() - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
Retrieve the visited document.
getDocValuesDocIdSetIterator(String, LeafReader) - Static method in class org.apache.lucene.search.FieldExistsQuery
Returns a DocIdSetIterator from the given field or null if the field doesn't exist in the reader or if the reader has no doc values for the field.
getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
Returns the docvalues format that should be used for writing new segments of field .
getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
Returns the doc values format that should be used for writing new segments of field .
getDocValuesGen() - Method in class org.apache.lucene.index.FieldInfo
Returns the docValues generation of this field, or -1 if no docValues updates exist for it.
getDocValuesGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the generation number of the DocValues file or -1 if there are no doc-values updates yet.
getDocValuesReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying DocValuesProducer
getDocValuesReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getDocValuesReader() - Method in class org.apache.lucene.index.SegmentReader
 
getDocValuesReader() - Method in class org.apache.lucene.index.SortingCodecReader
 
getDocValuesType() - Method in class org.apache.lucene.index.FieldInfo
Returns DocValuesType of the docValues; this is DocValuesType.NONE if the field has no docvalues.
getDocValuesUpdatesFiles() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the per-field DocValues updates files.
getDocWriterThreadPoolSize(IndexWriter) - Method in interface org.apache.lucene.internal.tests.IndexWriterAccess
 
getDoubleValue() - Method in class org.apache.lucene.document.StoredValue
Retrieve a double value.
getEmptyOutput() - Method in class org.apache.lucene.util.fst.FST
 
getEnableGraphQueries() - Method in class org.apache.lucene.util.QueryBuilder
Returns true if graph TokenStream processing is enabled (default).
getEnablePositionIncrements() - Method in class org.apache.lucene.util.QueryBuilder
Returns true if position increments are enabled.
getEncodedX(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
get quantized x value for the given vertex
getEncodedY(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
get quantized y value for the given vertex
getEncoder() - Method in class org.apache.lucene.document.LatLonShapeDocValues
 
getEncoder() - Method in class org.apache.lucene.document.XYShapeDocValues
 
getEncoder(PackedInts.Format, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
getEvictionCount() - Method in class org.apache.lucene.search.LRUQueryCache
Return the number of cache entries that have been removed from the cache either in order to stay under the maximum configured size/ram usage, or because a segment has been closed.
getExecutor() - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
use IndexSearcher.getTaskExecutor() executor instead to execute concurrent tasks
getExtension(String) - Static method in class org.apache.lucene.index.IndexFileNames
Return the extension (anything after the first '.'), or null if there is no '.' in the file name.
getExtension(String) - Static method in class org.apache.lucene.store.FileSwitchDirectory
Utility method to return a file's extension.
getFailFast() - Method in class org.apache.lucene.index.CheckIndex
getFallbackQuery() - Method in class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
 
getFallbackSelector(int) - Method in class org.apache.lucene.util.RadixSelector
Get a fall-back selector which may assume that the first d bytes of all compared strings are equal.
getFallbackSorter(int) - Method in class org.apache.lucene.util.MSBRadixSorter
Get a fall-back sorter which may assume that the first k bytes of all compared strings are equal.
getFallbackSorter(int) - Method in class org.apache.lucene.util.StableMSBRadixSorter
 
getFallbackSorter(int) - Method in class org.apache.lucene.util.StringSorter.MSBStringRadixSorter
 
getField() - Method in class org.apache.lucene.search.FieldExistsQuery
 
getField() - Method in class org.apache.lucene.search.MultiTermQuery
Returns the field name for this query
getField() - Method in class org.apache.lucene.search.PhraseQuery
Returns the field this query applies to
getField() - Method in class org.apache.lucene.search.PointInSetQuery
 
getField() - Method in class org.apache.lucene.search.PointRangeQuery
 
getField() - Method in class org.apache.lucene.search.SortField
Returns the name of the field.
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.
getFieldInfos() - Method in class org.apache.lucene.index.FilterCodecReader
 
getFieldInfos() - Method in class org.apache.lucene.index.FilterLeafReader
 
getFieldInfos() - Method in class org.apache.lucene.index.LeafReader
Get the FieldInfos describing all fields in this reader.
getFieldInfos() - Method in class org.apache.lucene.index.ParallelLeafReader
Get the FieldInfos describing all fields in this reader.
getFieldInfos() - Method in class org.apache.lucene.index.SegmentReader
 
getFieldInfosFiles() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the FieldInfos file names.
getFieldInfosGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the generation number of the field infos file or -1 if there are no field updates yet.
getFieldNames() - Method in class org.apache.lucene.index.IndexWriter
Return an unmodifiable set of all field names as visible from this IndexWriter, across all segments of the index.
getFieldNumber() - Method in class org.apache.lucene.index.FieldInfo
Returns the field number
getFieldReader(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
Return the underlying VectorReader for the given field
getFields() - Method in class org.apache.lucene.document.Document
Returns a List of all the fields in a document.
getFields(String) - Method in class org.apache.lucene.document.Document
Returns an array of IndexableFields with the given name.
getFieldsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying StoredFieldsReader
getFieldsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getFieldsReader() - Method in class org.apache.lucene.index.SegmentReader
 
getFieldsReader() - Method in class org.apache.lucene.index.SortingCodecReader
 
getFileNames() - Method in class org.apache.lucene.index.IndexCommit
Returns all index files referenced by this commit point.
getFilePointer() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
getFilePointer() - Method in class org.apache.lucene.store.FilterIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.FilterIndexOutput
 
getFilePointer() - Method in class org.apache.lucene.store.IndexInput
Returns the current position in this file, where the next read will occur.
getFilePointer() - Method in class org.apache.lucene.store.IndexOutput
Returns the current position in this file, where the next write will occur.
getFilePointer() - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
getFiniteStrings() - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
Get all finite strings from the automaton.
getFiniteStrings(int, int) - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
Get all finite strings that start at startState and end at endState.
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.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.OrdinalMap
Given global ordinal, returns the ordinal of the first segment which contains this ordinal (the corresponding to the segment return OrdinalMap.getFirstSegmentNumber(long)).
getFixedBitSetOrNull(DocIdSetIterator) - Static method in class org.apache.lucene.util.BitSetIterator
If the provided iterator wraps a FixedBitSet, returns it, otherwise returns null.
getFlags() - Method in 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
 
getFloat(Map<String, String>, String, float) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
getFloatValue() - Method in class org.apache.lucene.document.StoredValue
Retrieve a float value.
getFloatVectorValues(String) - Method in class org.apache.lucene.codecs.FlatVectorsReader
Returns the FloatVectorValues for the given field.
getFloatVectorValues(String) - Method in class org.apache.lucene.codecs.KnnVectorsReader
Returns the FloatVectorValues for the given field.
getFloatVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
getFloatVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
getFloatVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
getFloatVectorValues(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
 
getFloatVectorValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getFloatVectorValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getFloatVectorValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getFloatVectorValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns FloatVectorValues for this field, or null if no FloatVectorValues were indexed.
getFloatVectorValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getFloorSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current floorSegmentMB.
getFlushingBytes() - Method in class org.apache.lucene.index.IndexWriter
Returns the number of bytes currently being flushed
getForceMergeDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current forceMergeDeletesPctAllowed setting.
getForceMergeMBPerSec() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Get the per-merge IO throttle rate for forced merges.
getFormat() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
The format used to serialize values.
getFSTReader() - Method in class org.apache.lucene.util.fst.FSTCompiler
Get the respective FSTReader of the DataOutput.
getFullSliceDescription(String) - Method in class org.apache.lucene.store.IndexInput
Subclasses call this to get the String for resourceDescription of a slice of this IndexInput.
getFuzzyAutomaton(String, int, int, boolean) - Static method in class org.apache.lucene.search.FuzzyQuery
Returns the CompiledAutomaton internally used by FuzzyQuery to match terms.
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.
getGlobalCounter() - Static method in class org.apache.lucene.search.TimeLimitingCollector
Returns the global TimerThreads Counter
getGlobalOrds(int) - Method in class org.apache.lucene.index.OrdinalMap
Given a segment number, return a LongValues instance that maps segment ordinals to global ordinals.
getGlobalTimerThread() - Static method in class org.apache.lucene.search.TimeLimitingCollector
getGraph() - Method in interface org.apache.lucene.util.hnsw.HnswBuilder
 
getGraph() - Method in class org.apache.lucene.util.hnsw.HnswConcurrentMergeBuilder
 
getGraph() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
getGraph(String) - Method in interface org.apache.lucene.codecs.HnswGraphProvider
Return the stored HnswGraph for the given field.
getGraph(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
getHardLiveDocs() - Method in class org.apache.lucene.index.SegmentReader
Returns the live docs that are not hard-deleted.
getHasBlocks() - Method in class org.apache.lucene.index.SegmentInfo
Returns true if this segment contains documents written as blocks.
getHeap() - Method in class org.apache.lucene.util.hnsw.FloatHeap
 
getHeapArray() - Method in class org.apache.lucene.util.PriorityQueue
This method returns the internal heap array as Object[].
getHighestDimensionType() - Method in class org.apache.lucene.document.ShapeDocValuesField
Retrieves the highest dimensional type (POINT, LINE, TRIANGLE) for computing the geometry(s) centroid
getHitCount() - Method in class org.apache.lucene.search.LRUQueryCache
Over the total number of times that a query has been looked up, return how many times a cached DocIdSet has been found and returned.
getHoles() - Method in class org.apache.lucene.geo.Polygon
Returns a copy of the internal holes array
getHoles() - Method in class org.apache.lucene.geo.XYPolygon
Returns a copy of the internal holes array
getId() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns and Id that uniquely identifies this segment commit or null if there is no ID assigned.
getId() - Method in class org.apache.lucene.index.SegmentInfo
Return the id that uniquely identifies this segment.
getId() - Method in class org.apache.lucene.index.SegmentInfos
Since Lucene 5.0, every commit (segments_N) writes a unique id.
getId() - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the ID of the format.
getID() - Method in class org.apache.lucene.index.Sorter
Returns the identifier of this Sorter.
getIdentifiers() - Method in class org.apache.lucene.util.automaton.RegExp
Returns set of automaton identifiers that occur in this regular expression.
getImpacts() - Method in interface org.apache.lucene.index.ImpactsSource
Get information about upcoming impacts for doc ids that are greater than or equal to the maximum of DocIdSetIterator.docID() and the last target that was passed to ImpactsSource.advanceShallow(int).
getImpacts() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
getImpacts(int) - Method in class org.apache.lucene.index.Impacts
Return impacts on the given level.
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.
getIndependence() - Method in class org.apache.lucene.search.similarities.DFISimilarity
Returns the measure of independence
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() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
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
getIndexCreatedVersionMajor() - Method in class org.apache.lucene.index.FieldInvertState
Return the version that was used to create the index, or 6 if it was created before 7.0.
getIndexCreatedVersionMajor() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Return the compatibility version to use for this index.
getIndexCreatedVersionMajor() - Method in class org.apache.lucene.index.SegmentInfos
Return the version major that was used to initially create the index.
getIndexDeletionPolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getIndexDeletionPolicy() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
getIndexedDISI(IndexInput) - Method in class org.apache.lucene.codecs.lucene95.OrdToDocDISIReaderConfiguration
 
getIndexedFields(IndexReader) - Static method in class org.apache.lucene.index.FieldInfos
Returns a set of names of fields that have a terms index.
getIndexOptions() - Method in class org.apache.lucene.index.FieldInfo
Returns IndexOptions for the field, or IndexOptions.NONE if the field is not indexed
getIndexOptions() - Method in class org.apache.lucene.index.FieldInvertState
Get the index options for this field
getIndexPackageAccess() - Static method in class org.apache.lucene.internal.tests.TestSecrets
Return the accessor to internal secrets for an IndexReader.
getIndexPath() - Method in class org.apache.lucene.index.CheckIndex.Options
Get the directory containing the index.
getIndexQuery() - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
Return the wrapped query that may be costly to initialize but has a good iterator.
getIndexReader() - Method in class org.apache.lucene.search.IndexSearcher
Return the IndexReader this searches.
getIndexSort() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Get the index-time Sort order, applied to all (flushed and merged) segments.
getIndexSort() - Method in class org.apache.lucene.index.SegmentInfo
Return the sort order of this segment, or null if the index has no sort.
getIndexSorter() - Method in class org.apache.lucene.search.SortedNumericSortField
 
getIndexSorter() - Method in class org.apache.lucene.search.SortedSetSortField
 
getIndexSorter() - Method in class org.apache.lucene.search.SortField
Returns an IndexSorter used for sorting index segments by this SortField.
getIndexSortFields() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the field names involved in the index sort
getIndexWriterAccess() - Static method in class org.apache.lucene.internal.tests.TestSecrets
Return the accessor to internal secrets for an IndexWriter.
getIndexWriterEventListener() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the IndexWriterEventListener callback that tracks the key IndexWriter operations.
getInfoStream() - Method in class org.apache.lucene.index.IndexWriter
 
getInfoStream() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getInfoStream() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns InfoStream used for debugging.
getInfoStream() - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
Returns the info stream that can be used to log messages
getInfoStream() - Static method in class org.apache.lucene.index.SegmentInfos
Returns infoStream.
getInstance() - Static method in class org.apache.lucene.internal.vectorization.VectorizationProvider
Returns the default instance of the provider matching vectorization possibilities of actual runtime.
getInstance(DataOutput, long, int) - Static method in class org.apache.lucene.util.packed.DirectWriter
Returns an instance suitable for encoding numValues using bitsPerValue
getInstance(IndexOutput, IndexOutput, long, int) - Static method in class org.apache.lucene.util.packed.DirectMonotonicWriter
Returns an instance suitable for encoding numValues into monotonic blocks of 2blockShift values.
getInstance(RandomAccessInput, int) - Static method in class org.apache.lucene.util.packed.DirectReader
Retrieves an instance from the specified slice written decoding bitsPerValue for each value
getInstance(RandomAccessInput, int, long) - Static method in class org.apache.lucene.util.packed.DirectReader
Retrieves an instance from the specified offset of the given slice decoding bitsPerValue for each value
getInstance(DirectMonotonicReader.Meta, RandomAccessInput) - Static method in class org.apache.lucene.util.packed.DirectMonotonicReader
Retrieves a non-merging instance from the specified slice.
getInstance(DirectMonotonicReader.Meta, RandomAccessInput, boolean) - Static method in class org.apache.lucene.util.packed.DirectMonotonicReader
Retrieves an instance from the specified slice.
getInt(Map<String, String>, String, int) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
getIntBlock() - Method in class org.apache.lucene.util.IntBlockPool.Allocator
 
getIntBlock() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
getIntValue() - Method in class org.apache.lucene.document.StoredValue
Retrieve an integer value.
getIORateLimitMBPerSec() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns the currently set per-merge IO writes rate limit, if ConcurrentMergeScheduler.enableAutoIOThrottle() was called, else Double.POSITIVE_INFINITY.
getK1() - Method in class org.apache.lucene.search.similarities.BM25Similarity
Returns the k1 parameter
getKey() - Method in class org.apache.lucene.index.FilterDirectoryReader.DelegatingCacheHelper
 
getKey() - Method in interface org.apache.lucene.index.IndexReader.CacheHelper
Get a key that the resource can be cached on.
getKnnVectorsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
Returns the vectors format that should be used for writing new segments of field
getKnnVectorsFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
Returns the numeric vector format that should be used for writing new segments of field .
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.
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.
getLat() - Method in class org.apache.lucene.geo.Circle
Returns the center's latitude
getLat() - Method in class org.apache.lucene.geo.Point
Returns latitude value at given index
getLat(int) - Method in class org.apache.lucene.geo.Line
Returns latitude value at given index
getLats() - Method in class org.apache.lucene.geo.Line
Returns a copy of the internal latitude array
getLeafCollector(LeafReaderContext) - Method in interface org.apache.lucene.search.Collector
Create a new collector to collect the given context.
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.FilterCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.MultiCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.TimeLimitingCollector
 
getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.TotalHitCountCollector
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.comparators.DocComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.comparators.DoubleComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.comparators.FloatComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.comparators.IntComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.comparators.LongComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator
Get a per-segment LeafFieldComparator to collect the given LeafReaderContext.
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleFieldComparator
 
getLeafContexts() - Method in class org.apache.lucene.search.IndexSearcher
Expert: returns leaf contexts associated with this searcher.
getLeafSorter() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns a comparator for sorting leaf readers.
getLength() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
Return the length of the data in the internal buffer starting at CharacterUtils.CharacterBuffer.getOffset()
getLength() - Method in class org.apache.lucene.index.FieldInvertState
Get total number of terms in this field.
getLines(InputStream, Charset) - Static method in class org.apache.lucene.analysis.WordlistLoader
Accesses a resource by name and returns the (non comment) lines containing data using the given character encoding.
getLines(ResourceLoader, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
Returns the resource's lines (with content treated as UTF-8)
getLiveCommitData() - Method in class org.apache.lucene.index.IndexWriter
Returns the commit user data iterable previously set with IndexWriter.setLiveCommitData(Iterable), or null if nothing has been set yet.
getLiveDocs() - Method in class org.apache.lucene.index.FilterCodecReader
 
getLiveDocs() - Method in class org.apache.lucene.index.FilterLeafReader
 
getLiveDocs() - Method in class org.apache.lucene.index.LeafReader
Returns the Bits representing live (not deleted) docs.
getLiveDocs() - Method in class org.apache.lucene.index.ParallelLeafReader
 
getLiveDocs() - Method in class org.apache.lucene.index.SegmentReader
 
getLiveDocs() - Method in class org.apache.lucene.index.SortingCodecReader
 
getLiveDocs(IndexReader) - Static method in class org.apache.lucene.index.MultiBits
Returns a single Bits instance for this reader, merging live Documents on the fly.
getLon() - Method in class org.apache.lucene.geo.Circle
Returns the center's longitude
getLon() - Method in class org.apache.lucene.geo.Point
Returns longitude value at given index
getLon(int) - Method in class org.apache.lucene.geo.Line
Returns longitude value at given index
getLongValue() - Method in class org.apache.lucene.document.StoredValue
Retrieve a long value.
getLons() - Method in class org.apache.lucene.geo.Line
Returns a copy of the internal longitude array
getLowerPoint() - Method in class org.apache.lucene.search.PointRangeQuery
 
getLowerQuantile() - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
 
getLowerTerm() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the lower value of this range query
getLuceneMatchVersion() - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
getMap() - Method in class org.apache.lucene.util.MapOfSets
 
getMatchArray() - Method in class org.apache.lucene.index.MultiTermsEnum
Returns sub-reader slices positioned to the current term.
getMatchCost() - Method in class org.apache.lucene.search.PhraseMatcher
An estimate of the average cost of finding all matches on a document
getMatchCount() - Method in class org.apache.lucene.index.MultiTermsEnum
Returns how many sub-reader slices contain the current term.
getMatches(String) - Method in interface org.apache.lucene.search.Matches
Returns a MatchesIterator over the matches for a single field, or null if there are no matches in that field.
getMatches(String) - Method in class org.apache.lucene.search.NamedMatches
 
getMax() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
getMax() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
 
getMax() - Method in class org.apache.lucene.index.MultiTerms
 
getMax() - Method in class org.apache.lucene.index.Terms
Returns the largest term (in lexicographic order) in the field.
getMax(int) - Method in class org.apache.lucene.document.DoubleRange
Get the max value for the given dimension
getMax(int) - Method in class org.apache.lucene.document.DoubleRangeDocValuesField
Get the maximum value for the given dimension.
getMax(int) - Method in class org.apache.lucene.document.FloatRange
Get the max value for the given dimension
getMax(int) - Method in class org.apache.lucene.document.FloatRangeDocValuesField
Get the maximum value for the given dimension.
getMax(int) - Method in class org.apache.lucene.document.IntRange
Get the max value for the given dimension
getMax(int) - Method in class org.apache.lucene.document.IntRangeDocValuesField
Get the maximum value for the given dimension.
getMax(int) - Method in class org.apache.lucene.document.LongRange
Get the max value for the given dimension
getMax(int) - Method in class org.apache.lucene.document.LongRangeDocValuesField
Get the maximum value for the given dimension.
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.FilterMergePolicy
 
getMaxCFSSegmentSizeMB() - Method in class org.apache.lucene.index.MergePolicy
Returns the largest size allowed for a compound file segment
getMaxCFSSegmentSizeMB() - Method in class org.apache.lucene.index.NoMergePolicy
 
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
getMaxClauseCount() - Static method in class org.apache.lucene.search.IndexSearcher
Return the maximum number of clauses permitted, 1024 by default.
getMaxClauseCount() - Method in exception org.apache.lucene.search.IndexSearcher.TooManyClauses
The value of IndexSearcher.getMaxClauseCount() when this Exception was created
getMaxCompletedSequenceNumber() - Method in class org.apache.lucene.index.IndexWriter
Returns the highest sequence number across all completed operations, or 0 if no operations have finished yet.
getMaxDimensions(String) - Method in class org.apache.lucene.codecs.KnnVectorsFormat
Returns the maximum number of vector dimensions supported by this codec for the given field name
getMaxDimensions(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswScalarQuantizedVectorsFormat
 
getMaxDimensions(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
 
getMaxDimensions(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
 
getMaxEdits() - Method in class org.apache.lucene.search.FuzzyQuery
 
getMaxFullFlushMergeWaitMillis() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Expert: return the amount of time to wait for merges returned by by MergePolicy.findFullFlushMerges(...).
getMaxMergeAtOnce() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current maxMergeAtOnce 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
 
getMaxPackedValue() - Method in class org.apache.lucene.codecs.MutablePointTree
 
getMaxPackedValue() - Method in class org.apache.lucene.index.PointValues
Returns maximum value for each dimension, packed, or null if PointValues.size(org.apache.lucene.index.IndexReader, java.lang.String) is 0
getMaxPackedValue() - Method in interface org.apache.lucene.index.PointValues.PointTree
Return the maximum packed value of the current node.
getMaxPackedValue() - Method in class org.apache.lucene.util.bkd.BKDReader
 
getMaxPackedValue(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
Return the maximum packed values across all leaves of the given IndexReader.
getMaxPos() - Method in class org.apache.lucene.util.RollingBuffer
Returns the maximum position looked up, or -1 if no position has been looked up since reset/init.
getMaxScore(int) - Method in class org.apache.lucene.search.ConstantScoreScorer
 
getMaxScore(int) - Method in class org.apache.lucene.search.IndriDisjunctionScorer
 
getMaxScore(int) - Method in class org.apache.lucene.search.IndriScorer
 
getMaxScore(int) - Method in class org.apache.lucene.search.MaxScoreCache
Return the maximum score up to upTo included.
getMaxScore(int) - Method in class org.apache.lucene.search.Scorer
Return the maximum score that documents between the last target that this iterator was shallow-advanced to included and upTo included.
getMaxScore(int) - Method in class org.apache.lucene.search.TermScorer
 
getMaxScoreCache() - Method in class org.apache.lucene.search.ImpactsDISI
Get the MaxScoreCache.
getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
 
getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
getMaxSize() - Method in class org.apache.lucene.search.TopTermsRewrite
return the maximum size of the priority queue (for boolean rewrites this is BooleanQuery#getMaxClauseCount).
getMaxTermFrequency() - Method in class org.apache.lucene.index.FieldInvertState
Get the maximum term-frequency encountered for any term in the field.
getMaxThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns maxThreadCount.
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
Returns the current maximum token length
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
Returns the current maximum token length
getMaxVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
Returns the maximum version accepted
getMaxVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns the maximum version accepted.
getMaxX() - Method in interface org.apache.lucene.geo.Component2D
max X value for the component *
getMaxY() - Method in interface org.apache.lucene.geo.Component2D
max Y value for the component *
getMBPerSec() - Method in class org.apache.lucene.index.MergeRateLimiter
 
getMBPerSec() - Method in class org.apache.lucene.store.RateLimiter
The current MB per second rate limit.
getMBPerSec() - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
The current mb per second rate limit.
getMergedFieldInfos(IndexReader) - Static method in class org.apache.lucene.index.FieldInfos
Call this to get the (merged) FieldInfos for a composite reader.
getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMergedSegmentWarmer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the current merged segment warmer.
getMergeFactor() - Method in class org.apache.lucene.index.LogMergePolicy
Returns the number of segments that are merged at once and also controls the total number of segments allowed to accumulate in the index.
getMergeInfo() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Returns the SegmentCommitInfo for the merged segment, or null if it hasn't been set yet.
getMergeInstance() - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.FieldsProducer
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.KnnVectorsReader
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsReader
 
getMergeInstance() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsReader
 
getMergeInstance() - Method in class org.apache.lucene.codecs.NormsProducer
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.PointsReader
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.StoredFieldsReader
Returns an instance optimized for merging.
getMergeInstance() - Method in class org.apache.lucene.codecs.TermVectorsReader
Returns an instance optimized for merging.
getMergeInstance(RandomAccessInput, int, long) - Static method in class org.apache.lucene.util.packed.DirectReader
Retrieves an instance that is specialized for merges and is typically faster at sequential access but slower at random access.
getMergeInstance(RandomAccessInput, int, long, long) - Static method in class org.apache.lucene.util.packed.DirectReader
Retrieves an instance that is specialized for merges and is typically faster at sequential access.
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.
getMergeProgress() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Returns a MergePolicy.OneMergeProgress instance for this merge, which provides statistics of the merge threads (run time vs.
getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getMergeScheduler() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
getMergeThread(MergeScheduler.MergeSource, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Create and return a new MergeThread
getMergingSegments() - Method in class org.apache.lucene.index.IndexWriter
Expert: to be used by a MergePolicy to avoid selecting merges for segments already being merged.
getMergingSegments() - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
Returns an unmodifiable set of segments that are currently merging.
getMetadata() - Method in class org.apache.lucene.util.fst.FST
 
getMetaData() - Method in class org.apache.lucene.index.FilterCodecReader
 
getMetaData() - Method in class org.apache.lucene.index.FilterLeafReader
 
getMetaData() - Method in class org.apache.lucene.index.LeafReader
Return metadata about this leaf.
getMetaData() - Method in class org.apache.lucene.index.ParallelLeafReader
 
getMetaData() - Method in class org.apache.lucene.index.SegmentReader
 
getMetaData() - Method in class org.apache.lucene.index.SortingCodecReader
 
getMilliseconds() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Get the timer value in milliseconds.
getMin() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
getMin() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
 
getMin() - Method in class org.apache.lucene.index.MultiTerms
 
getMin() - Method in class org.apache.lucene.index.Terms
Returns the smallest term (in lexicographic order) in the field.
getMin(int) - Method in class org.apache.lucene.document.DoubleRange
Get the min value for the given dimension
getMin(int) - Method in class org.apache.lucene.document.DoubleRangeDocValuesField
Get the minimum value for the given dimension.
getMin(int) - Method in class org.apache.lucene.document.FloatRange
Get the min value for the given dimension
getMin(int) - Method in class org.apache.lucene.document.FloatRangeDocValuesField
Get the minimum value for the given dimension.
getMin(int) - Method in class org.apache.lucene.document.IntRange
Get the min value for the given dimension
getMin(int) - Method in class org.apache.lucene.document.IntRangeDocValuesField
Get the minimum value for the given dimension.
getMin(int) - Method in class org.apache.lucene.document.LongRange
Get the min value for the given dimension
getMin(int) - Method in class org.apache.lucene.document.LongRangeDocValuesField
Get the minimum value for the given dimension.
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.
getMinPackedValue() - Method in class org.apache.lucene.codecs.MutablePointTree
 
getMinPackedValue() - Method in class org.apache.lucene.index.PointValues
Returns minimum value for each dimension, packed, or null if PointValues.size(org.apache.lucene.index.IndexReader, java.lang.String) is 0
getMinPackedValue() - Method in interface org.apache.lucene.index.PointValues.PointTree
Return the minimum packed value of the current node.
getMinPackedValue() - Method in class org.apache.lucene.util.bkd.BKDReader
 
getMinPackedValue(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
Return the minimum packed values across all leaves of the given IndexReader.
getMinPauseCheckBytes() - Method in class org.apache.lucene.index.MergeRateLimiter
 
getMinPauseCheckBytes() - Method in class org.apache.lucene.store.RateLimiter
How many bytes caller should add up itself before invoking RateLimiter.pause(long).
getMinPauseCheckBytes() - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
 
getMinSegmentLuceneVersion() - Method in class org.apache.lucene.index.SegmentInfos
Returns the version of the oldest segment, or null if there are no segments.
getMinVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
Returns the minimum version accepted
getMinVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns the minimum version accepted This method will return null if an alternative IndexFormatTooOldException.getReason() is provided.
getMinVersion() - Method in class org.apache.lucene.index.LeafMetaData
Return the minimum Lucene version that contributed documents to this index, or null if this information is not available.
getMinVersion() - Method in class org.apache.lucene.index.SegmentInfo
Return the minimum Lucene version that contributed documents to this segment, or null if it is unknown.
getMinX() - Method in interface org.apache.lucene.geo.Component2D
min X value for the component *
getMinY() - Method in interface org.apache.lucene.geo.Component2D
min Y value for the component *
getMissCount() - Method in class org.apache.lucene.search.LRUQueryCache
Over the total number of times that a query has been looked up, return how many times this query was not contained in the cache.
getMissingValue() - Method in class org.apache.lucene.search.SortField
Return the value to use for documents that don't have a value.
getMu() - Method in class org.apache.lucene.search.similarities.IndriDirichletSimilarity
Returns the μ parameter.
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.
getN() - Method in class org.apache.lucene.search.NGramPhraseQuery
Return the n in n-gram
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.KnnVectorsFormat
 
getName() - Method in class org.apache.lucene.codecs.PostingsFormat
Returns this posting format's name
getName() - Method in class org.apache.lucene.index.FieldInfo
Returns name of this field
getName() - Method in class org.apache.lucene.index.FieldInvertState
Return the field's name
getName() - Method in class org.apache.lucene.index.SortFieldProvider
 
getName() - Method in class org.apache.lucene.search.NamedMatches
Returns the name of this Matches
getName() - Method in class org.apache.lucene.search.similarities.IndriDirichletSimilarity
 
getName() - Method in class org.apache.lucene.search.similarities.IndriDirichletSimilarity.IndriCollectionModel
 
getName() - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
 
getName() - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
 
getName() - Method in interface org.apache.lucene.search.similarities.LMSimilarity.CollectionModel
The name of the collection model strategy.
getName() - Method in class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
 
getName() - Method in class org.apache.lucene.search.similarities.LMSimilarity
Returns the name of the LM method.
getName() - Method in class org.apache.lucene.store.IndexOutput
Returns the name used to create this IndexOutput.
getName() - Method in interface org.apache.lucene.util.NamedSPILoader.NamedSPI
 
getNeighbors(int, int) - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
Returns the NeighborQueue connected to the given node.
getNewOrdMapping(DocIdSetIterator, BitSet) - Method in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
Creates a new mapping from old ordinals to new ordinals and returns the total number of vectors in the newly merged segment.
getNextDelGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the next available generation number of the live docs file.
getNextDocValuesGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the next available generation number of the DocValues files.
getNextFieldInfosGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the next available generation number of the FieldInfos files.
getNextMerge() - Method in interface org.apache.lucene.index.MergeScheduler.MergeSource
The MergeScheduler calls this method to retrieve the next merge requested by the MergePolicy
getNextSkipDoc() - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
getNextToken() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
getNextTransition(Transition) - Method in class org.apache.lucene.util.automaton.Automaton
Iterate to the next transition after the provided one
getNoCFSRatio() - Method in class org.apache.lucene.index.FilterMergePolicy
 
getNoCFSRatio() - Method in class org.apache.lucene.index.MergePolicy
Returns current noCFSRatio.
getNoCFSRatio() - Method in class org.apache.lucene.index.NoMergePolicy
 
getNodeCount() - Method in class org.apache.lucene.util.fst.FSTCompiler
 
getNodesOnLevel(int) - Method in class org.apache.lucene.util.hnsw.HnswGraph
Get all nodes on a given level as node 0th ordinals
getNodesOnLevel(int) - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
WARN: calling this method will essentially iterate through all nodes at level 0 (even if you're not getting node at level 0), we have built some caching mechanism such that if graph is not changed only the first non-zero level call will pay the cost.
getNoOutput() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
getNoOutput() - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
getNoOutput() - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
getNoOutput() - Method in class org.apache.lucene.util.fst.NoOutputs
 
getNoOutput() - Method in class org.apache.lucene.util.fst.Outputs
NOTE: this output is compared with == so you must ensure that all methods return the single object if it's really no output
getNoOutput() - Method in class org.apache.lucene.util.fst.PairOutputs
 
getNoOutput() - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
getNormalization() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
Returns the second normalization
getNormalization() - Method in class org.apache.lucene.search.similarities.IBSimilarity
Returns the term frequency normalization
getNorms(FieldInfo) - Method in class org.apache.lucene.codecs.NormsProducer
Returns NumericDocValues for this field.
getNormsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying NormsProducer
getNormsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getNormsReader() - Method in class org.apache.lucene.index.SegmentReader
 
getNormsReader() - Method in class org.apache.lucene.index.SortingCodecReader
 
getNormValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getNormValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getNormValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns NumericDocValues representing norms for this field, or null if no NumericDocValues were indexed.
getNormValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getNormValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a NumericDocValues for a reader's norms (potentially merging on-the-fly).
getNumberOfDocuments() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the number of documents.
getNumberOfFieldTokens() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the total number of tokens in the field.
getNumDimensions() - Method in class org.apache.lucene.index.PointValues
Returns how many dimensions are represented in the values
getNumDimensions() - Method in class org.apache.lucene.util.bkd.BKDReader
 
getNumDims() - Method in class org.apache.lucene.search.PointInSetQuery
 
getNumDims() - Method in class org.apache.lucene.search.PointRangeQuery
 
getNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns NumericDocValues for this field.
getNumeric(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
 
getNumeric(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns NumericDocValues for the field, or DocValues.emptyNumeric() if it has none.
getNumericDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getNumericDocValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getNumericDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getNumericDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns NumericDocValues for this field, or null if no numeric doc values were indexed for this field.
getNumericDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getNumericDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
Retrieves the NumericDocValues for the field in this segment
getNumericType() - Method in class org.apache.lucene.search.SortedNumericSortField
Returns the numeric type in use for this sort
getNumericValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a NumericDocValues for a reader's docvalues (potentially merging on-the-fly)
getNumIndexDimensions() - Method in class org.apache.lucene.index.PointValues
Returns how many dimensions are used for the index
getNumIndexDimensions() - Method in class org.apache.lucene.util.bkd.BKDReader
 
getNumOverlap() - Method in class org.apache.lucene.index.FieldInvertState
Get the number of terms with positionIncrement == 0.
getNumStates() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
How many states this automaton has.
getNumStates() - Method in class org.apache.lucene.util.automaton.Automaton
How many states this automaton has.
getNumSubs() - Method in class org.apache.lucene.index.MultiPostingsEnum
How many sub-readers we are merging.
getNumTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
How many transitions this automaton has.
getNumTransitions(int) - Method in class org.apache.lucene.util.automaton.Automaton
How many transitions this state has.
getOccur() - Method in class org.apache.lucene.search.BooleanClause
 
getOffset() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
Returns the data offset in the internal buffer.
getOffset() - Method in class org.apache.lucene.index.FieldInvertState
Get end offset of the last processed term.
getOffsetGap(String) - Method in class org.apache.lucene.analysis.Analyzer
Just like Analyzer.getPositionIncrementGap(java.lang.String), except for Token offsets instead.
getOffsetGap(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
getOnHeapReaderWriter(int) - Static method in class org.apache.lucene.util.fst.FSTCompiler
Get an on-heap DataOutput that allows the FST to be read immediately after writing, and also optionally saved to an external DataOutput.
getOpenMode() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getOpenMode() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
getOptimizeSortWithIndexedData() - Method in class org.apache.lucene.search.SortField
Deprecated.
getOptimizeSortWithPoints() - Method in class org.apache.lucene.search.SortField
Deprecated.
This is a duplicate method for SortField#getOptimizeSortWithIndexedData.
getOrDefault(int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
getOriginalArgs() - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
getOriginalMessage() - Method in exception org.apache.lucene.index.CorruptIndexException
Returns the original exception message without the corrupted file description.
getOriginalString() - Method in class org.apache.lucene.util.automaton.RegExp
The string that was used to construct the regex.
getPackageImplementationVersion() - Static method in class org.apache.lucene.util.Version
Return Lucene's full implementation version.
getPackedPoints() - Method in class org.apache.lucene.search.PointInSetQuery
 
getPackedValue() - Method in class org.apache.lucene.document.BinaryRangeDocValues
Gets the packed value that represents this range
getPackedValueSlice(int) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
Returns a reference, in result, to the byte[] slice holding this value
getParallelReaders() - Method in class org.apache.lucene.index.ParallelLeafReader
Returns the LeafReaders that were passed on init.
getParentField() - Method in class org.apache.lucene.index.FieldInfos
Returns the parent document field name if exists; otherwise returns null
getParentField() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the parent document field name if configured.
getPattern(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
Compiles a pattern for the value of the specified argument key name
getPauseTimes() - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
Returns pause reasons and associated times in nanoseconds.
getPayload() - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
Returns this Token's payload.
getPayload() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
getPayload() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
getPayload() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
getPayload() - Method in class org.apache.lucene.index.PostingsEnum
Returns the payload at this position, or null if no payload was indexed.
getPayload() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
getPayload() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionFullPostingsEnum
 
getPayload() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
getPayloadByteUpto() - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
getPayPointer() - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
getPendingDeletions() - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
getPendingDeletions() - Method in class org.apache.lucene.store.Directory
Returns a set of files currently pending deletion in this directory.
getPendingDeletions() - Method in class org.apache.lucene.store.FileSwitchDirectory
 
getPendingDeletions() - Method in class org.apache.lucene.store.FilterDirectory
 
getPendingDeletions() - Method in class org.apache.lucene.store.FSDirectory
 
getPendingNumDocs() - Method in class org.apache.lucene.index.IndexWriter
Returns the number of documents in the index including documents are being added (i.e., reserved).
getPhraseMatcher(LeafReaderContext, Similarity.SimScorer, boolean) - Method in class org.apache.lucene.search.PhraseWeight
 
getPointCountSeen() - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
Returns total number of points in this BKD tree
getPointDimensionCount() - Method in class org.apache.lucene.index.FieldInfo
Return point data dimension count
getPointer() - Method in class org.apache.lucene.util.PagedBytes
 
getPointIndexDimensionCount() - Method in class org.apache.lucene.index.FieldInfo
Return point data dimension count
getPointNumBytes() - Method in class org.apache.lucene.index.FieldInfo
Return number of bytes per dimension
getPointsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying PointsReader
getPointsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getPointsReader() - Method in class org.apache.lucene.index.SegmentReader
 
getPointsReader() - Method in class org.apache.lucene.index.SortingCodecReader
 
getPointTree() - Method in class org.apache.lucene.index.PointValues
Create a new PointValues.PointTree to navigate the index
getPointTree() - Method in class org.apache.lucene.util.bkd.BKDReader
 
getPointValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getPointValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getPointValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getPointValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns the PointValues used for numeric or spatial searches for the given field, or null if there are no point fields.
getPointValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getPolyLat(int) - Method in class org.apache.lucene.geo.Polygon
Returns latitude value at given index
getPolyLats() - Method in class org.apache.lucene.geo.Polygon
Returns a copy of the internal latitude array
getPolyLon(int) - Method in class org.apache.lucene.geo.Polygon
Returns longitude value at given index
getPolyLons() - Method in class org.apache.lucene.geo.Polygon
Returns a copy of the internal longitude array
getPolyX() - Method in class org.apache.lucene.geo.XYPolygon
Returns a copy of the internal x array
getPolyX(int) - Method in class org.apache.lucene.geo.XYPolygon
Returns x value at given index
getPolyY() - Method in class org.apache.lucene.geo.XYPolygon
Returns a copy of the internal y array
getPolyY(int) - Method in class org.apache.lucene.geo.XYPolygon
Returns y value at given index
getPosBufferUpto() - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
getPosition() - Method in class org.apache.lucene.index.FieldInvertState
Get the last processed term position.
getPosition() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
getPosition() - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
getPosition() - Method in class org.apache.lucene.util.ByteBlockPool
the current position (in absolute value) of this byte pool
getPosition() - Method in class org.apache.lucene.util.fst.FST.BytesReader
Get current read position.
getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
Returns the current byte position.
getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
Return the current byte position.
getPositionIncrement() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Returns the position increment of this Token.
getPositionIncrement() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
Returns the position increment of this Token.
getPositionIncrement() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.Analyzer
Invoked before indexing a IndexableField instance if terms have already been added to that field.
getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
getPositionLength() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Returns the position length of this Token.
getPositionLength() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
Returns the position length of this Token.
getPositionLength() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
getPositions() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns the relative positions of terms in this phrase.
getPositions() - Method in class org.apache.lucene.search.NGramPhraseQuery
Return the list of relative positions that each term should appear at.
getPositions() - Method in class org.apache.lucene.search.PhraseQuery
Returns the relative positions of terms in this phrase.
getPosPointer() - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
Returns the postings format that should be used for writing new segments of field.
getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
Returns the postings format that should be used for writing new segments of field.
getPostingsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying FieldsProducer
getPostingsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getPostingsReader() - Method in class org.apache.lucene.index.SegmentReader
 
getPostingsReader() - Method in class org.apache.lucene.index.SortingCodecReader
 
getPrefix() - Method in class org.apache.lucene.search.PrefixQuery
Returns the prefix of this query.
getPrefixLength() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the non-fuzzy prefix length.
getPreload() - Method in class org.apache.lucene.store.MMapDirectory
Deprecated.
This information is no longer reliable now that preloading is more granularly configured via a predicate.
getPrimaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
Return the primary directory
getProviderName() - Method in class org.apache.lucene.index.IndexSorter.DoubleSorter
 
getProviderName() - Method in class org.apache.lucene.index.IndexSorter.FloatSorter
 
getProviderName() - Method in interface org.apache.lucene.index.IndexSorter
The SPI-registered name of a SortFieldProvider that will deserialize the parent SortField
getProviderName() - Method in class org.apache.lucene.index.IndexSorter.IntSorter
 
getProviderName() - Method in class org.apache.lucene.index.IndexSorter.LongSorter
 
getProviderName() - Method in class org.apache.lucene.index.IndexSorter.StringSorter
 
getQuantizationState(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
getQuantizationState(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
getQuantizationState(String) - Method in interface org.apache.lucene.util.quantization.QuantizedVectorsReader
 
getQuantizedVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
getQuantizedVectorValues(String) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
getQuantizedVectorValues(String) - Method in interface org.apache.lucene.util.quantization.QuantizedVectorsReader
 
getQuery() - Method in class org.apache.lucene.search.BooleanClause
 
getQuery() - Method in class org.apache.lucene.search.BoostQuery
Return the wrapped Query.
getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery
Returns the encapsulated query.
getQuery() - Method in class org.apache.lucene.search.FilterMatchesIterator
 
getQuery() - Method in interface org.apache.lucene.search.MatchesIterator
Returns the Query causing the current match
getQuery() - Method in class org.apache.lucene.search.Weight
The query that this concerns.
getQueryCache() - Method in class org.apache.lucene.search.IndexSearcher
Return the query cache of this IndexSearcher.
getQueryCachingPolicy() - Method in class org.apache.lucene.search.IndexSearcher
Return the query cache of this IndexSearcher.
getRadius() - Method in class org.apache.lucene.geo.Circle
Returns the radius in meters
getRadius() - Method in class org.apache.lucene.geo.XYCircle
Returns the radius
getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getRAMBufferSizeMB() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the value set by LiveIndexWriterConfig.setRAMBufferSizeMB(double) if enabled.
getRAMPerThreadHardLimitMB() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getRAMPerThreadHardLimitMB() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the max amount of memory each DocumentsWriterPerThread can consume until forcefully flushed.
getRandomAccessQuery() - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
Return the wrapped query that may be slow at identifying all matching documents, but which is cheap to initialize and can efficiently verify that some documents match.
getRandomVectorScorer(String, byte[]) - Method in class org.apache.lucene.codecs.FlatVectorsReader
Returns a RandomVectorScorer for the given field and target vector.
getRandomVectorScorer(String, byte[]) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
getRandomVectorScorer(String, byte[]) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
getRandomVectorScorer(String, float[]) - Method in class org.apache.lucene.codecs.FlatVectorsReader
Returns a RandomVectorScorer for the given field and target vector.
getRandomVectorScorer(String, float[]) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
getRandomVectorScorer(String, float[]) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
getReader(long, long) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
 
getReader(long, long) - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
getReader(long, long) - Method in interface org.apache.lucene.util.bkd.PointWriter
Returns a PointReader iterator to step through all previously added points
getReader(long, long, byte[]) - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
getReader(IndexWriter, boolean, boolean) - Method in interface org.apache.lucene.internal.tests.IndexWriterAccess
 
getReader(ChecksumIndexInput, String) - Method in class org.apache.lucene.util.OfflineSorter
Subclasses can override to change how byte sequences are read from disk.
getReaderCacheHelper() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.ExitableDirectoryReader
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.IndexReader
Optional method: Return a IndexReader.CacheHelper that can be used to cache based on the content of this reader.
getReaderCacheHelper() - Method in class org.apache.lucene.index.MultiReader
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.ParallelCompositeReader
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.ParallelLeafReader
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.SegmentReader
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.SoftDeletesDirectoryReaderWrapper
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.SortingCodecReader
 
getReaderCacheHelper() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
getReaderIteratorNoHeader(DataInput, PackedInts.Format, int, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Expert: Restore a PackedInts.ReaderIterator from a stream without reading metadata at the beginning of the stream.
getReaderPooling() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getReaderPooling() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns true if IndexWriter should pool readers even if DirectoryReader.open(IndexWriter) has not been called.
getReason() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns an optional reason for this exception if the version information was not available.
getRefCount() - Method in class org.apache.lucene.index.IndexReader
Expert: returns the current refCount for this reader
getRefCount() - Method in class org.apache.lucene.util.RefCount
Returns the current reference count.
getRefCount(G) - Method in class org.apache.lucene.search.ReferenceManager
Returns the current reference count of the given reference.
getRefCount(String) - Method in class org.apache.lucene.util.FileDeleter
get ref count for a provided file, if the file is not yet recorded, this method will return 0
getRefCount(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
 
getRefCount(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
 
getRegexp() - Method in class org.apache.lucene.search.RegexpQuery
Returns the regexp of this query wrapped in a Term.
getRegExp() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Return the RegExp that caused this exception if any.
getResolution() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Return the timer resolution.
getResourceDescription() - Method in exception org.apache.lucene.index.CorruptIndexException
Returns a description of the file that was corrupted
getResourceDescription() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
Returns a description of the file that was too new
getResourceDescription() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns a description of the file that was too old
getReusableComponents(Analyzer, String) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Gets the reusable TokenStreamComponents for the field with the given name.
getReuseStrategy() - Method in class org.apache.lucene.analysis.Analyzer
Returns the used Analyzer.ReuseStrategy.
getReverse() - Method in class org.apache.lucene.search.SortField
Returns whether the sort should be reversed.
getReverseBytesReader() - Method in interface org.apache.lucene.util.fst.FSTReader
Get the reverse BytesReader for this FST
getReverseBytesReader() - Method in class org.apache.lucene.util.fst.OffHeapFSTStore
 
getReverseBytesReader() - Method in class org.apache.lucene.util.fst.OnHeapFSTStore
 
getReverseMul() - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getRewriteMethod() - Method in class org.apache.lucene.search.MultiTermQuery
 
getScoreCorrectionConstant() - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
getScoreCorrectionConstant() - Method in class org.apache.lucene.util.quantization.QuantizedByteVectorValues
 
getScoreCorrectionConstant() - Method in interface org.apache.lucene.util.quantization.RandomAccessQuantizedByteVectorValues
 
getSearcher(SearcherFactory, IndexReader, IndexReader) - Static method in class org.apache.lucene.search.SearcherManager
Expert: creates a searcher from the provided IndexReader using the provided SearcherFactory.
getSearchingGen() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
Returns which generation the current searcher is guaranteed to include.
getSecondaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
Return the secondary directory
getSegmentCount() - Method in class org.apache.lucene.index.IndexCommit
Returns number of segments referenced by this commit.
getSegmentCount(IndexWriter) - Method in interface org.apache.lucene.internal.tests.IndexWriterAccess
 
getSegmentInfo() - Method in class org.apache.lucene.index.SegmentReader
Return the SegmentInfoPerCommit of the segment this reader is reading.
getSegmentInfos() - Method in class org.apache.lucene.index.StandardDirectoryReader
Return the SegmentInfos for this reader.
getSegmentName() - Method in class org.apache.lucene.index.SegmentReader
Return the name of the segment this reader is reading.
getSegmentReaderAccess() - Static method in class org.apache.lucene.internal.tests.TestSecrets
Return the accessor to internal secrets for an SegmentReader.
getSegmentsFileName() - Method in class org.apache.lucene.index.IndexCommit
Get the segments file (segments_N) associated with this commit point.
getSegmentsFileName() - Method in class org.apache.lucene.index.SegmentInfos
Get the segments_N filename in use by this segment infos.
getSegmentsPerTier() - Method in class org.apache.lucene.index.TieredMergePolicy
Returns the current segmentsPerTier setting.
getSelector() - Method in class org.apache.lucene.search.SortedNumericSortField
Returns the selector in use for this sort
getSelector() - Method in class org.apache.lucene.search.SortedSetSortField
Returns the selector in use for this sort
getSentenceIndex() - Method in interface org.apache.lucene.analysis.tokenattributes.SentenceAttribute
Get the sentence index for the current token
getSentenceIndex() - Method in class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
 
getSequentialSubReaders() - Method in class org.apache.lucene.index.BaseCompositeReader
 
getSequentialSubReaders() - Method in class org.apache.lucene.index.CompositeReader
Expert: returns the sequential sub readers that this reader is logically composed of.
getSet(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
Returns whitespace- and/or comma-separated set of values, or null if none are found
getSimilarity() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getSimilarity() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Expert: returns the Similarity implementation used by this IndexWriter.
getSimilarity() - Method in class org.apache.lucene.search.IndexSearcher
Expert: Get the Similarity to use to compute scores.
getSimScorer() - Method in class org.apache.lucene.search.LeafSimScorer
Return the wrapped Similarity.SimScorer.
getSingleton() - Static method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
getSingleton() - Static method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
getSingleton() - Static method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
getSingleton() - Static method in class org.apache.lucene.util.fst.NoOutputs
 
getSingleton() - Static method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
getSingleton(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
If this automaton accepts a single input, return it.
getSize() - Method in class org.apache.lucene.search.TopTermsRewrite
return the maximum priority queue size
getSize() - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns number of states in automaton.
getSlices() - Method in class org.apache.lucene.search.IndexSearcher
Returns the leaf slices used for concurrent searching.
getSlop() - Method in class org.apache.lucene.search.MultiPhraseQuery
Sets the phrase slop for this query.
getSlop() - Method in class org.apache.lucene.search.PhraseQuery
Return the slop for this PhraseQuery.
getSlot(int) - Method in class org.apache.lucene.util.SentinelIntSet
(internal) Returns the slot for this key
getSnapshotCount() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Returns the total number of snapshots currently held.
getSnapshots() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Returns all IndexCommits held by at least one snapshot.
getSnowballWordSet(InputStream) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.
getSnowballWordSet(InputStream, Charset) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.
getSnowballWordSet(Reader) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.
getSnowballWordSet(Reader, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.
getSnowballWordSet(ResourceLoader, String, boolean) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
same as AbstractAnalysisFactory.getWordSet(ResourceLoader, String, boolean), except the input is in snowball format.
getSoftDelCount() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns the number of only soft-deleted docs.
getSoftDeletesField() - Method in class org.apache.lucene.index.FieldInfos
Returns the soft-deletes field name if exists; otherwise returns null
getSoftDeletesField() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns the soft deletes field or null if soft-deletes are disabled.
getSort() - Method in class org.apache.lucene.index.LeafMetaData
Return the order in which documents from this index are sorted, or null if documents are in no particular order.
getSort() - Method in class org.apache.lucene.search.Sort
Representation of the sort criteria.
getSorted(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns SortedDocValues for this field.
getSorted(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
 
getSorted(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns SortedDocValues for the field, or DocValues.emptySorted() if it has none.
getSortedDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getSortedDocValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getSortedDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getSortedDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns SortedDocValues for this field, or null if no SortedDocValues were indexed for this field.
getSortedDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getSortedDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
Retrieves the SortedDocValues for the field in this segment
getSortedNodes(HnswGraph.NodesIterator) - Static method in class org.apache.lucene.util.hnsw.HnswGraph.NodesIterator
 
getSortedNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns SortedNumericDocValues for this field.
getSortedNumeric(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
 
getSortedNumeric(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns SortedNumericDocValues for the field, or DocValues.emptySortedNumeric() if it has none.
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns SortedNumericDocValues for this field, or null if no SortedNumericDocValues were indexed for this field.
getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getSortedNumericValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a SortedNumericDocValues for a reader's docvalues (potentially merging on-the-fly)
getSortedSet(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
Returns SortedSetDocValues for this field.
getSortedSet(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
 
getSortedSet(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
Returns SortedSetDocValues for the field, or DocValues.emptySortedSet() if it has none.
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.CodecReader
 
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.LeafReader
Returns SortedSetDocValues for this field, or null if no SortedSetDocValues were indexed for this field.
getSortedSetDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getSortedSetValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a SortedSetDocValues for a reader's docvalues (potentially doing extremely slow things).
getSortedTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
Sugar to get all transitions for all states.
getSortedValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
Returns a SortedDocValues for a reader's docvalues (potentially doing extremely slow things).
getSortField(boolean) - Method in class org.apache.lucene.search.DoubleValuesSource
Create a sort field based on the value of this producer
getSortField(boolean) - Method in class org.apache.lucene.search.LongValuesSource
Create a sort field based on the value of this producer
getSource() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Returns the component's source
getSparseFixedBitSetOrNull(DocIdSetIterator) - Static method in class org.apache.lucene.util.BitSetIterator
If the provided iterator wraps a SparseFixedBitSet, returns it, otherwise returns null.
getStartPoints() - Method in class org.apache.lucene.util.automaton.Automaton
Returns sorted array of all interval start points.
getStaticImplementation(AttributeFactory, Class<A>) - Static method in class org.apache.lucene.util.AttributeFactory
Returns an AttributeFactory returning an instance of the given clazz for the attributes it implements.
getStats() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
For debugging -- used by CheckIndex too
getStats() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
getStats() - Method in class org.apache.lucene.index.Terms
Expert: returns additional information about this Terms instance for debugging purposes.
getStats(IndexSearcher) - Method in class org.apache.lucene.search.PhraseWeight
 
getStemDict(Reader, CharArrayMap<String>) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads a stem dictionary.
getStopwordSet() - Method in class org.apache.lucene.analysis.StopwordAnalyzerBase
Returns the analyzer's stopword set or an empty set if the analyzer has no stopwords
getStoredValue(Analyzer) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Returns the currently stored value.
getStoreMergeInfo() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Return MergeInfo describing this merge.
getStringValue() - Method in class org.apache.lucene.document.StoredValue
Retrieve a string value.
getSubMatches() - Method in class org.apache.lucene.search.FilterMatchesIterator
 
getSubMatches() - Method in class org.apache.lucene.search.IndriDisjunctionScorer
 
getSubMatches() - Method in interface org.apache.lucene.search.Matches
Returns a collection of Matches that make up this instance; if it is not a composite, then this returns an empty list
getSubMatches() - Method in interface org.apache.lucene.search.MatchesIterator
Returns a MatchesIterator that iterates over the positions and offsets of individual terms within the current match
getSubMatches() - Method in class org.apache.lucene.search.NamedMatches
 
getSubs() - Method in class org.apache.lucene.index.MultiPostingsEnum
Returns sub-readers we are merging.
getSubSlices() - Method in class org.apache.lucene.index.MultiTerms
Expert: returns pointers to the sub-readers corresponding to the Terms being merged.
getSubTerms() - Method in class org.apache.lucene.index.MultiTerms
Expert: returns the Terms being merged.
getSubVisitor(BooleanClause.Occur, Query) - Method in class org.apache.lucene.search.QueryVisitor
Pulls a visitor instance for visiting child clauses of a query
getSumDocFreq() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
getSumDocFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
getSumDocFreq() - Method in class org.apache.lucene.index.MultiTerms
 
getSumDocFreq() - Method in class org.apache.lucene.index.Terms
Returns the sum of TermsEnum.docFreq() for all terms in this field.
getSumDocFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getSumDocFreq(String) - Method in class org.apache.lucene.index.IndexReader
Returns the sum of TermsEnum.docFreq() for all terms in this field.
getSumDocFreq(String) - Method in class org.apache.lucene.index.LeafReader
 
getSumTotalTermFreq() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
getSumTotalTermFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
getSumTotalTermFreq() - Method in class org.apache.lucene.index.MultiTerms
 
getSumTotalTermFreq() - Method in class org.apache.lucene.index.Terms
Returns the sum of TermsEnum.totalTermFreq() for all terms in this field.
getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.IndexReader
Returns the sum of TermsEnum.totalTermFreq() for all terms in this field.
getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.LeafReader
 
getTargetCopy() - Method in class org.apache.lucene.search.KnnByteVectorQuery
 
getTargetCopy() - Method in class org.apache.lucene.search.KnnFloatVectorQuery
 
getTargetLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
getTargetLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
getTaskExecutor() - Method in class org.apache.lucene.search.IndexSearcher
Returns the TaskExecutor that this searcher relies on to execute concurrent operations
getTempFileName(String, String, long) - Static method in class org.apache.lucene.store.Directory
Creates a file name for a temporary file.
getTempFileNamePrefix() - Method in class org.apache.lucene.util.OfflineSorter
Returns the temp file name prefix passed to Directory.createTempOutput(java.lang.String, java.lang.String, org.apache.lucene.store.IOContext) to generate temporary files.
getTerm() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the pattern term.
getTerm() - Method in class org.apache.lucene.search.TermQuery
Returns the term of this query.
getTerm() - Method in class org.apache.lucene.search.WildcardQuery
Returns the pattern term.
getTerm() - Method in class org.apache.lucene.util.TermAndVector
 
getTermArrays() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns the arrays of arrays of terms in the multi-phrase.
getTermData() - Method in class org.apache.lucene.search.TermInSetQuery
Deprecated.
the encoded terms will no longer be exposed in a future major version; this is an implementation detail that could change at some point and shouldn't be relied on directly
getTermFrequency() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
getTermFrequency() - Method in interface org.apache.lucene.analysis.tokenattributes.TermFrequencyAttribute
Returns the custom term frequency.
getTermFrequency() - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
getTermPostingsEnum(IndexReader, String, BytesRef) - Static method in class org.apache.lucene.index.MultiTerms
Returns PostingsEnum for the specified field and term.
getTermPostingsEnum(IndexReader, String, BytesRef, int) - Static method in class org.apache.lucene.index.MultiTerms
Returns PostingsEnum for the specified field and term, with control over whether freqs, positions, offsets or payloads are required.
getTerms() - Method in class org.apache.lucene.search.NGramPhraseQuery
Return the list of terms.
getTerms() - Method in class org.apache.lucene.search.PhraseQuery
Returns the list of terms in this phrase.
getTerms() - Method in class org.apache.lucene.search.SynonymQuery
 
getTerms(int) - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
Returns the list of tokens that start at the provided state
getTerms(String, int) - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
Returns the list of terms that start at the provided state
getTerms(IndexReader, String) - Static method in class org.apache.lucene.index.MultiTerms
This method may return null if the field does not exist or if it has no terms.
getTerms(LeafReader, String) - Static method in class org.apache.lucene.index.Terms
Returns the Terms index for this field, or Terms.EMPTY if it has none.
getTermsCount() - Method in class org.apache.lucene.search.MultiTermQuery
Return the number of unique terms contained in this query, if known up-front.
getTermsCount() - Method in class org.apache.lucene.search.TermInSetQuery
 
getTermsEnum(Terms) - Method in class org.apache.lucene.search.MultiTermQuery
Constructs an enumeration that expands the pattern term.
getTermsEnum(Terms) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
Return a TermsEnum intersecting the provided Terms with the terms accepted by this automaton.
getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.AutomatonQuery
 
getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.FuzzyQuery
 
getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.MultiTermQuery
Construct the enumeration to be used, expanding the pattern term.
getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.TermInSetQuery
 
getTermsEnum(MultiTermQuery, Terms, AttributeSource) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
getTermStates() - Method in class org.apache.lucene.search.TermQuery
Returns the TermStates passed to the constructor, or null if it was not passed.
getTermVector(int, String) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
use IndexReader.termVectors() to retrieve one or more documents
getTermVectors(int) - Method in class org.apache.lucene.index.BaseCompositeReader
 
getTermVectors(int) - Method in class org.apache.lucene.index.CodecReader
Deprecated.
getTermVectors(int) - Method in class org.apache.lucene.index.FilterCodecReader
Deprecated.
getTermVectors(int) - Method in class org.apache.lucene.index.FilterLeafReader
 
getTermVectors(int) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
use IndexReader.termVectors() to retrieve one or more documents
getTermVectors(int) - Method in class org.apache.lucene.index.ParallelLeafReader
 
getTermVectors(int) - Method in class org.apache.lucene.index.SegmentReader
 
getTermVectorsReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying TermVectorsReader
getTermVectorsReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getTermVectorsReader() - Method in class org.apache.lucene.index.SegmentReader
 
getTermVectorsReader() - Method in class org.apache.lucene.index.SortingCodecReader
 
getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Fills CharTermAttribute with the current token text.
getTieBreakerMultiplier() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
 
getTimeAllowed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
Returns allowed time (milliseconds).
getTimeElapsed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
Returns elapsed time (milliseconds).
getTimeoutAt() - Method in class org.apache.lucene.index.QueryTimeoutImpl
Returns time at which to time out, in nanoseconds relative to the (JVM-specific) epoch for System.nanoTime(), to compare with the value returned by nanoTime().
getTimestamp() - Method in class org.apache.lucene.util.PrintStreamInfoStream
Returns the current time as string for insertion into log messages.
getTokenStream() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Returns the sink TokenStream
getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
 
getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
getTopLevelContext(IndexReaderContext) - Static method in class org.apache.lucene.index.ReaderUtil
Walks up the reader tree and return the given context's top level reader context, or in other words the reader tree's root context.
getTopReaderContext() - Method in class org.apache.lucene.search.IndexSearcher
Returns this searcher's top-level IndexReaderContext.
getTotalBytesWritten() - Method in class org.apache.lucene.index.MergeRateLimiter
Returns total bytes written by this merge.
getTotalCount() - Method in class org.apache.lucene.search.LRUQueryCache
Return the total number of times that a Query has been looked up in this QueryCache.
getTotalHits() - Method in class org.apache.lucene.search.TopDocsCollector
The total number of documents that matched this query.
getTotalHits() - Method in class org.apache.lucene.search.TotalHitCountCollector
Returns how many hits matched the search.
getTotalPausedNS() - Method in class org.apache.lucene.index.MergeRateLimiter
Total NS merge was paused to rate limit IO.
getTotalStoppedNS() - Method in class org.apache.lucene.index.MergeRateLimiter
Total NS merge was stopped.
getTotalTermFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
Returns the total number of occurrences of this term across all documents.
getTragicException() - Method in class org.apache.lucene.index.IndexWriter
If this IndexWriter was closed as a side-effect of a tragic exception, e.g.
getTrailingPositions() - Method in class org.apache.lucene.analysis.GraphTokenFilter
Return the number of trailing positions at the end of the graph
getTransition(int, int, Transition) - Method in class org.apache.lucene.util.automaton.Automaton
Fill the provided Transition with the index'th transition leaving the specified state.
getTranspositions() - Method in class org.apache.lucene.search.FuzzyQuery
Returns true if transpositions should be treated as a primitive edit operation.
getType() - Method in class org.apache.lucene.document.StoredValue
Retrieve the type of the stored value.
getType() - Method in class org.apache.lucene.search.SortField
Returns the type of contents in the field.
getUniqueTermCount() - Method in class org.apache.lucene.index.FieldInvertState
Return the number of unique terms encountered in this field.
getUnrefedFiles() - Method in class org.apache.lucene.util.FileDeleter
get files that are touched but not incref'ed
getUnsignedComparator(int) - Static method in class org.apache.lucene.util.ArrayUtil
Return a comparator for exactly the specified number of bytes.
getUpperPoint() - Method in class org.apache.lucene.search.PointRangeQuery
 
getUpperQuantile() - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
 
getUpperTerm() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the upper value of this range query
getUseCompoundFile() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Returns true iff the IndexWriter packs newly written segments in a compound file.
getUseCompoundFile() - Method in class org.apache.lucene.index.SegmentInfo
Returns true if this segment is stored as a compound file; else, false.
getUserData() - Method in class org.apache.lucene.index.IndexCommit
Returns userData, previously passed to IndexWriter.setLiveCommitData(Iterable) for this commit.
getUserData() - Method in class org.apache.lucene.index.SegmentInfos
Return userData saved with this commit.
getUseUnmap() - Method in class org.apache.lucene.store.MMapDirectory
getUTF16SortedAsUTF8Comparator() - Static method in class org.apache.lucene.util.CharsRef
Deprecated.
This comparator is only a transition mechanism
getValue() - Method in class org.apache.lucene.search.Explanation
The value assigned to this explanation node.
getValue() - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
Get the constant value.
getValue() - Method in class org.apache.lucene.store.BufferedChecksum
 
getValue(int, BytesRef) - Method in class org.apache.lucene.codecs.MutablePointTree
Set packedValue with a reference to the packed bytes of the i-th value.
getValueCount() - Method in class org.apache.lucene.index.FilterSortedDocValues
 
getValueCount() - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
getValueCount() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
getValueCount() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
getValueCount() - Method in class org.apache.lucene.index.OrdinalMap
Returns the total number of unique terms in global ord space.
getValueCount() - Method in class org.apache.lucene.index.SortedDocValues
Returns the number of unique values.
getValueCount() - Method in class org.apache.lucene.index.SortedSetDocValues
Returns the number of unique values.
getValues(String) - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsReader
Returns the underlying BKDReader.
getValues(String) - Method in class org.apache.lucene.codecs.PointsReader
Return PointValues for the given field.
getValues(String) - Method in class org.apache.lucene.document.Document
Returns an array of values of the field specified as the method parameter.
getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.search.DoubleValuesSource
Returns a DoubleValues instance for the passed-in LeafReaderContext and scores
getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
 
getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.search.LongValuesSource
Returns a LongValues instance for the passed-in LeafReaderContext and scores
getVector() - Method in class org.apache.lucene.util.TermAndVector
 
getVectorDimension() - Method in class org.apache.lucene.index.FieldInfo
Returns the number of dimensions of the vector value
getVectorEncoding() - Method in class org.apache.lucene.index.FieldInfo
Returns the number of dimensions of the vector value
getVectorReader() - Method in class org.apache.lucene.index.CodecReader
Expert: retrieve underlying VectorReader
getVectorReader() - Method in class org.apache.lucene.index.FilterCodecReader
 
getVectorReader() - Method in class org.apache.lucene.index.SegmentReader
 
getVectorReader() - Method in class org.apache.lucene.index.SortingCodecReader
 
getVectorSimilarityFunction() - Method in class org.apache.lucene.index.FieldInfo
Returns VectorSimilarityFunction for the field
getVectorUtilSupport() - Method in class org.apache.lucene.internal.vectorization.VectorizationProvider
Returns a singleton (stateless) VectorUtilSupport to support SIMD usage in VectorUtil.
getVersion() - Method in class org.apache.lucene.index.DirectoryReader
Version number when this IndexReader was opened.
getVersion() - Method in class org.apache.lucene.index.FilterDirectoryReader
 
getVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
Returns the version of the file that was too new
getVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
Returns the version of the file that was too old.
getVersion() - Method in class org.apache.lucene.index.SegmentInfo
Returns the version of the code which wrote the segment.
getVersion() - Method in class org.apache.lucene.index.SegmentInfos
version number when this SegmentInfos was generated.
getVersion() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
getVersion() - Method in class org.apache.lucene.util.fst.FST.FSTMetadata
Returns the version constant of the binary format this FST was written in.
getWeight() - Method in class org.apache.lucene.search.Scorer
returns parent Weight
getWindingOrder() - Method in class org.apache.lucene.geo.Polygon
Returns the winding order (CW, COLINEAR, CCW) for the polygon shell
getWindingOrder() - Method in class org.apache.lucene.geo.XYPolygon
Returns the winding order (CW, COLINEAR, CCW) for the polygon shell
getWordSet(InputStream) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from an InputStream with UTF-8 charset and adds every line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(InputStream, String) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from an InputStream with UTF-8 charset and adds every non-comment line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(InputStream, Charset) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from an InputStream with the given charset and adds every line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(InputStream, Charset, String) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from an InputStream with the given charset and adds every non-comment line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(Reader) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from a Reader and adds every line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(Reader, String) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from a Reader and adds every non-comment line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(Reader, String, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from a Reader and adds every non-blank non-comment line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(Reader, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads lines from a Reader and adds every non-blank line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWordSet(ResourceLoader, String, boolean) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
Returns as CharArraySet from wordFiles, which can be a comma-separated list of filenames
getWrappedAnalyzer(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
Retrieves the wrapped Analyzer appropriate for analyzing the field with the given name
getWriter(IndexOutput, long) - Method in class org.apache.lucene.util.OfflineSorter
Subclasses can override to change how byte sequences are written to disk.
getWriterNoHeader(DataOutput, PackedInts.Format, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Expert: Create a packed integer array writer for the given output, format, value count, and number of bits per value.
getX() - Method in class org.apache.lucene.geo.Tessellator.Node
get the x value
getX() - Method in class org.apache.lucene.geo.XYCircle
Returns the center's x
getX() - Method in class org.apache.lucene.geo.XYLine
Returns a copy of the internal x array
getX() - Method in class org.apache.lucene.geo.XYPoint
Returns latitude value at given index
getX(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
get x value for the given vertex
getX(int) - Method in class org.apache.lucene.geo.XYLine
Returns x value at given index
getY() - Method in class org.apache.lucene.geo.Tessellator.Node
get the y value
getY() - Method in class org.apache.lucene.geo.XYCircle
Returns the center's y
getY() - Method in class org.apache.lucene.geo.XYLine
Returns a copy of the internal y array
getY() - Method in class org.apache.lucene.geo.XYPoint
Returns longitude value at given index
getY(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
get y value for the given vertex
getY(int) - Method in class org.apache.lucene.geo.XYLine
Returns y value at given index
getZ() - Method in class org.apache.lucene.search.similarities.NormalizationZ
Returns the parameter z
GLOBAL_REUSE_STRATEGY - Static variable in class org.apache.lucene.analysis.Analyzer
A predefined Analyzer.ReuseStrategy that reuses the same components for every field.
GOOD_FAST_HASH_SEED - Static variable in class org.apache.lucene.util.StringHelper
GraphBuilderKnnCollector(int) - Constructor for class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
GraphTokenFilter - Class in org.apache.lucene.analysis
An abstract TokenFilter that exposes its input stream as a graph
GraphTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.GraphTokenFilter
Create a new GraphTokenFilter
GraphTokenStreamFiniteStrings - Class in org.apache.lucene.util.graph
Consumes a TokenStream and creates an Automaton where the transition labels are terms from the TermToBytesRefAttribute.
GraphTokenStreamFiniteStrings(TokenStream) - Constructor for class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
 
GREATER_THAN - org.apache.lucene.search.Pruning
Allowed to skip documents that compare strictly better than the top value, or strictly worse than the bottom value.
GREATER_THAN_OR_EQUAL_TO - org.apache.lucene.search.Pruning
Allowed to skip documents that compare better than the top value, or worse than or equal to the bottom value.
GREATER_THAN_OR_EQUAL_TO - org.apache.lucene.search.TotalHits.Relation
The total hit count is greater than or equal to TotalHits.value.
GroupVIntUtil - Class in org.apache.lucene.util
This class contains utility methods and constants for group varint
GroupVIntUtil() - Constructor for class org.apache.lucene.util.GroupVIntUtil
 
GroupVIntUtil.IntReader - Interface in org.apache.lucene.util
Provides an abstraction for read int values, so that decoding logic can be reused in different DataInput.
grow() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
grow() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
grow() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
grow() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
grow() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
grow(byte[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
grow(char[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
grow(double[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(double[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
grow(float[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(float[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
grow(int) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
Notifies the caller that this many documents are about to be visited
grow(int) - Method in class org.apache.lucene.util.BytesRefBuilder
Ensure that this builder can hold at least capacity bytes without resizing.
grow(int) - Method in class org.apache.lucene.util.CharsRefBuilder
Used to grow the reference array.
grow(int) - Method in class org.apache.lucene.util.DocIdSetBuilder
Reserve space and return a DocIdSetBuilder.BulkAdder object that can be used to add up to numDocs documents.
grow(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Used to grow the reference array.
grow(int[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
grow(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
grow(long[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
grow(short[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
grow(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a larger array, generally over-allocating exponentially
grow(T[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially
GrowableWriter - Class in org.apache.lucene.util.packed
Implements PackedInts.Mutable, but grows the bit count of the underlying packed ints on-demand.
GrowableWriter(int, int, float) - Constructor for class org.apache.lucene.util.packed.GrowableWriter
 
growExact(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growExact(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growExact(double[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growExact(float[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growExact(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growExact(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growExact(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growExact(T[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns a new array whose size is exact the specified newLength without over-allocating
growInRange(int[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minLength, generally over-allocating exponentially, but never allocating more than maxLength elements.
growNoCopy(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially, and it will not copy the origin data to the new array
growNoCopy(int) - Method in class org.apache.lucene.util.BytesRefBuilder
Used to grow the builder without copying bytes.
growNoCopy(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Grow the reference array without copying the origin data to the new array.
growNoCopy(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially, and it will not copy the origin data to the new array
growNoCopy(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array whose size is at least minSize, generally over-allocating exponentially, and it will not copy the origin data to the new array
guard - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 

H

handleMergeException(Throwable) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Called when an exception is hit in a background merge thread
HANGUL - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Hangul token type
HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Hangul token type
HAS_FAST_SCALAR_FMA - Static variable in class org.apache.lucene.util.Constants
true iff we know FMA has faster throughput than separate mul/add.
HAS_FAST_VECTOR_FMA - Static variable in class org.apache.lucene.util.Constants
true iff we know VFMA has faster throughput than separate vmul/vadd.
hasAttribute(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource
The caller must pass in a Class<? extends Attribute> value.
hasAttributes() - Method in class org.apache.lucene.util.AttributeSource
Returns true, iff this AttributeSource has any attributes
hasBlocks() - Method in class org.apache.lucene.index.LeafMetaData
Returns true iff this index contains blocks created with IndexWriter.addDocument(Iterable) or it's corresponding update methods with at least 2 or more documents per call.
hasDeadStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if this automaton has any states that cannot be reached from the initial state or cannot reach an accept state.
hasDeadStatesFromInitial(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if there are dead states reachable from an initial state.
hasDeadStatesToAccept(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if there are dead states that reach an accept state.
hasDeletions - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if this segment has pending deletions.
hasDeletions() - Method in class org.apache.lucene.index.IndexReader
Returns true if any documents have been deleted.
hasDeletions() - Method in class org.apache.lucene.index.IndexWriter
Returns true if this index has deletions (including buffered deletions).
hasDeletions() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns true if there are any deletions for the segment at this commit.
hasDocValues() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have DocValues
hasEmptyKey - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
Special treatment for the "empty slot" key marker.
hasFieldUpdates() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns true if there are any field updates for the segment in this commit.
hasFreq() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have freqs
hasFreqs() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
hasFreqs() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasFreqs() - Method in class org.apache.lucene.index.MultiTerms
 
hasFreqs() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store per-document term frequency (PostingsEnum.freq()).
hash(int) - Method in class org.apache.lucene.util.SentinelIntSet
(internal) Return the hash for the key.
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
hashCode() - Method in class org.apache.lucene.document.FieldType
 
hashCode() - Method in class org.apache.lucene.document.RangeFieldQuery
 
hashCode() - Method in class org.apache.lucene.document.ShapeField.DecodedTriangle
 
hashCode() - Method in class org.apache.lucene.document.XYDocValuesPointInGeometryQuery
 
hashCode() - Method in class org.apache.lucene.geo.Circle
 
hashCode() - Method in class org.apache.lucene.geo.Line
 
hashCode() - Method in class org.apache.lucene.geo.Point
 
hashCode() - Method in class org.apache.lucene.geo.Polygon
 
hashCode() - Method in class org.apache.lucene.geo.Rectangle
 
hashCode() - Method in class org.apache.lucene.geo.XYCircle
 
hashCode() - Method in class org.apache.lucene.geo.XYLine
 
hashCode() - Method in class org.apache.lucene.geo.XYPoint
 
hashCode() - Method in class org.apache.lucene.geo.XYPolygon
 
hashCode() - Method in class org.apache.lucene.geo.XYRectangle
 
hashCode() - Method in class org.apache.lucene.index.Impact
 
hashCode() - Method in class org.apache.lucene.index.IndexCommit
 
hashCode() - Method in class org.apache.lucene.index.IndexReader
hashCode() - Method in class org.apache.lucene.index.PrefixCodedTerms
 
hashCode() - Method in class org.apache.lucene.index.SegmentInfo
 
hashCode() - Method in class org.apache.lucene.index.Term
 
hashCode() - Method in class org.apache.lucene.search.AutomatonQuery
 
hashCode() - Method in class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
 
hashCode() - Method in class org.apache.lucene.search.BlendedTermQuery
 
hashCode() - Method in class org.apache.lucene.search.BooleanClause
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.BooleanQuery
 
hashCode() - Method in class org.apache.lucene.search.BoostQuery
 
hashCode() - Method in class org.apache.lucene.search.ByteVectorSimilarityQuery
 
hashCode() - Method in class org.apache.lucene.search.ConstantScoreQuery
 
hashCode() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Compute a hash code for hashing us
hashCode() - Method in class org.apache.lucene.search.DocValuesRewriteMethod
 
hashCode() - Method in class org.apache.lucene.search.DoubleValuesSource
 
hashCode() - Method in class org.apache.lucene.search.Explanation
 
hashCode() - Method in class org.apache.lucene.search.FieldExistsQuery
 
hashCode() - Method in class org.apache.lucene.search.FloatVectorSimilarityQuery
 
hashCode() - Method in class org.apache.lucene.search.FuzzyQuery
 
hashCode() - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
 
hashCode() - Method in class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.IndriQuery
 
hashCode() - Method in class org.apache.lucene.search.KnnByteVectorQuery
 
hashCode() - Method in class org.apache.lucene.search.KnnFloatVectorQuery
 
hashCode() - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
 
hashCode() - Method in class org.apache.lucene.search.LongValuesSource
 
hashCode() - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
hashCode() - Method in class org.apache.lucene.search.MatchNoDocsQuery
 
hashCode() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.Multiset
 
hashCode() - Method in class org.apache.lucene.search.MultiTermQuery
 
hashCode() - Method in class org.apache.lucene.search.NGramPhraseQuery
 
hashCode() - Method in class org.apache.lucene.search.PhraseQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.PhraseQuery.PostingsAndFreq
 
hashCode() - Method in class org.apache.lucene.search.PointInSetQuery
 
hashCode() - Method in class org.apache.lucene.search.PointRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.PrefixQuery
 
hashCode() - Method in class org.apache.lucene.search.Query
Override and implement query hash code properly in a subclass.
hashCode() - Method in class org.apache.lucene.search.Sort
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.SortedNumericSortField
 
hashCode() - Method in class org.apache.lucene.search.SortedSetSortField
 
hashCode() - Method in class org.apache.lucene.search.SortField
Returns a hash code for this SortField instance.
hashCode() - Method in class org.apache.lucene.search.SynonymQuery
 
hashCode() - Method in class org.apache.lucene.search.TermInSetQuery
 
hashCode() - Method in class org.apache.lucene.search.TermQuery
 
hashCode() - Method in class org.apache.lucene.search.TermRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.TopTermsRewrite
 
hashCode() - Method in class org.apache.lucene.search.TotalHits
 
hashCode() - Method in class org.apache.lucene.store.FlushInfo
 
hashCode() - Method in class org.apache.lucene.store.IOContext
 
hashCode() - Method in class org.apache.lucene.store.MergeInfo
 
hashCode() - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
 
hashCode() - Method in class org.apache.lucene.util.AttributeSource
 
hashCode() - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
 
hashCode() - Method in class org.apache.lucene.util.automaton.RunAutomaton
 
hashCode() - Method in class org.apache.lucene.util.automaton.StatePair
Returns hash code.
hashCode() - Method in class org.apache.lucene.util.BytesRef
Calculates the hash code as required by TermsHash during indexing.
hashCode() - Method in class org.apache.lucene.util.BytesRefBuilder
 
hashCode() - Method in class org.apache.lucene.util.CharsRef
 
hashCode() - Method in class org.apache.lucene.util.CharsRefBuilder
 
hashCode() - Method in class org.apache.lucene.util.FixedBitSet
 
hashCode() - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
 
hashCode() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
hashCode() - Method in class org.apache.lucene.util.IntsRef
 
hashCode() - Method in class org.apache.lucene.util.IntsRefBuilder
 
hashCode() - Method in class org.apache.lucene.util.LongBitSet
 
hashCode() - Method in class org.apache.lucene.util.LongsRef
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValue
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
hashCode() - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
hashCode() - Method in class org.apache.lucene.util.Version
 
hashCode(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns hash of chars in range start (inclusive) to end (inclusive)
hashKey(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Returns a hash code for the given key.
HASHTABLE_RAM_BYTES_PER_ENTRY - Static variable in class org.apache.lucene.util.RamUsageEstimator
Approximate memory usage that we assign to a Hashtable / HashMap entry.
hasNext() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
 
hasNext() - Method in class org.apache.lucene.util.FilterIterator
 
hasNext() - Method in class org.apache.lucene.util.hnsw.HnswGraph.ArrayNodesIterator
 
hasNext() - Method in class org.apache.lucene.util.hnsw.HnswGraph.CollectionNodesIterator
 
hasNext() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.AbstractIterator
 
hasNext() - Method in class org.apache.lucene.util.MergedIterator
 
hasNext() - Method in class org.apache.lucene.util.packed.PackedLongValues.Iterator
Whether or not there are remaining values.
hasNorms() - Method in class org.apache.lucene.index.FieldInfo
Returns true if this field actually has any norms.
hasNorms() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have norms
hasOffsets() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
hasOffsets() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have offsets
hasOffsets() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasOffsets() - Method in class org.apache.lucene.index.MultiTerms
 
hasOffsets() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store offsets.
hasPayloads() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
hasPayloads() - Method in class org.apache.lucene.index.FieldInfo
Returns true if any payloads exist for this field.
hasPayloads() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have payloads
hasPayloads() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasPayloads() - Method in class org.apache.lucene.index.MultiTerms
 
hasPayloads() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store payloads.
hasPendingMerges() - Method in class org.apache.lucene.index.IndexWriter
Expert: returns true if there are merges waiting to be scheduled.
hasPendingMerges() - Method in interface org.apache.lucene.index.MergeScheduler.MergeSource
Expert: returns true if there are merges waiting to be scheduled.
hasPointValues() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have PointValues
hasPositions() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
hasPositions() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
hasPositions() - Method in class org.apache.lucene.index.MultiTerms
 
hasPositions() - Method in class org.apache.lucene.index.Terms
Returns true if documents in this field store positions.
hasPostings() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have postings
hasProx() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have positions
hasSidePath(int) - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
Returns whether the provided state is the start of multiple side paths of different length (eg: new york, ny)
hasUncommittedChanges() - Method in class org.apache.lucene.index.IndexWriter
Returns true if there may be changes that have not been committed.
hasVectors() - Method in class org.apache.lucene.index.FieldInfo
Returns true if any term vectors exist for this field.
hasVectors() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have vectors
hasVectorValues() - Method in class org.apache.lucene.index.FieldInfo
Returns whether any (numeric) vector values exist for this field
hasVectorValues() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields have vector values
haversinMeters(double) - Static method in class org.apache.lucene.util.SloppyMath
Returns the Haversine distance in meters between two points given the previous result from SloppyMath.haversinSortKey(double, double, double, double)
haversinMeters(double, double, double, double) - Static method in class org.apache.lucene.util.SloppyMath
Returns the Haversine distance in meters between two points specified in decimal degrees (latitude/longitude).
haversinSortKey(double, double, double, double) - Static method in class org.apache.lucene.util.SloppyMath
Returns a sort key for distance.
headerLength(String) - Static method in class org.apache.lucene.codecs.CodecUtil
Computes the length of a codec header.
HeapPointReader - Class in org.apache.lucene.util.bkd
Utility class to read buffered points from in-heap arrays.
HeapPointWriter - Class in org.apache.lucene.util.bkd
Utility class to write new points into in-heap arrays.
HeapPointWriter(BKDConfig, int) - Constructor for class org.apache.lucene.util.bkd.HeapPointWriter
 
heapRadixSort(HeapPointWriter, int, int, int, int) - Method in class org.apache.lucene.util.bkd.BKDRadixSelector
Sort the heap writer by the specified dim.
HIGH_COMPRESSION - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
A compression mode that trades speed for compression ratio.
HighCompressionHashTable() - Constructor for class org.apache.lucene.util.compress.LZ4.HighCompressionHashTable
Sole constructor
HIRAGANA - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Hiragana token type
HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Hiragana token type
HISTOGRAM_SIZE - Static variable in class org.apache.lucene.util.MSBRadixSorter
 
HitQueue - Class in org.apache.lucene.search
Expert: Priority queue containing hit docs
HitQueue(int, boolean) - Constructor for class org.apache.lucene.search.HitQueue
Creates a new instance with size elements.
hitsThresholdReached - Variable in class org.apache.lucene.search.comparators.NumericComparator
 
hnsw - Variable in class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
HNSW_COMPONENT - Static variable in class org.apache.lucene.util.hnsw.HnswGraphBuilder
A name for the HNSW component for the info-stream *
HnswBuilder - Interface in org.apache.lucene.util.hnsw
Interface for builder building the OnHeapHnswGraph
HnswConcurrentMergeBuilder - Class in org.apache.lucene.util.hnsw
A graph builder that manages multiple workers, it only supports adding the whole graph all at once.
HnswConcurrentMergeBuilder(TaskExecutor, int, RandomVectorScorerSupplier, int, int, OnHeapHnswGraph, BitSet) - Constructor for class org.apache.lucene.util.hnsw.HnswConcurrentMergeBuilder
 
HnswGraph - Class in org.apache.lucene.util.hnsw
Hierarchical Navigable Small World graph.
HnswGraph() - Constructor for class org.apache.lucene.util.hnsw.HnswGraph
Sole constructor
HnswGraph.ArrayNodesIterator - Class in org.apache.lucene.util.hnsw
NodesIterator that accepts nodes as an integer array.
HnswGraph.CollectionNodesIterator - Class in org.apache.lucene.util.hnsw
Nodes iterator based on set representation of nodes.
HnswGraph.NodesIterator - Class in org.apache.lucene.util.hnsw
Iterator over the graph nodes on a certain level, Iterator also provides the size – the total number of nodes to be iterated over.
HnswGraphBuilder - Class in org.apache.lucene.util.hnsw
Builder for HNSW graph.
HnswGraphBuilder(RandomVectorScorerSupplier, int, int, long, int) - Constructor for class org.apache.lucene.util.hnsw.HnswGraphBuilder
Reads all the vectors from vector values, builds a graph connecting them by their dense ordinals, using the given hyperparameter settings, and returns the resulting graph.
HnswGraphBuilder(RandomVectorScorerSupplier, int, int, long, OnHeapHnswGraph) - Constructor for class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
HnswGraphBuilder(RandomVectorScorerSupplier, int, int, long, OnHeapHnswGraph, HnswGraphSearcher) - Constructor for class org.apache.lucene.util.hnsw.HnswGraphBuilder
Reads all the vectors from vector values, builds a graph connecting them by their dense ordinals, using the given hyperparameter settings, and returns the resulting graph.
HnswGraphBuilder.GraphBuilderKnnCollector - Class in org.apache.lucene.util.hnsw
A restricted, specialized knnCollector that can be used when building a graph.
HnswGraphMerger - Interface in org.apache.lucene.util.hnsw
Abstraction of merging multiple graphs into one on-heap graph
HnswGraphProvider - Interface in org.apache.lucene.codecs
An interface that provides an HNSW graph.
HnswGraphSearcher - Class in org.apache.lucene.util.hnsw
Searches an HNSW graph to find nearest neighbors to a query vector.
HnswGraphSearcher(NeighborQueue, BitSet) - Constructor for class org.apache.lucene.util.hnsw.HnswGraphSearcher
Creates a new graph searcher.
HOLE - Static variable in class org.apache.lucene.analysis.TokenStreamToAutomaton
We add this arc to represent a hole.
HOUR - org.apache.lucene.document.DateTools.Resolution
Limit a date's resolution to hour granularity.
humanReadableUnits(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns size in human-readable units (GB, MB, KB or bytes).
humanReadableUnits(long, DecimalFormat) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns size in human-readable units (GB, MB, KB or bytes).

I

IBSimilarity - Class in org.apache.lucene.search.similarities
Provides a framework for the family of information-based models, as described in Stéphane Clinchant and Eric Gaussier.
IBSimilarity(Distribution, Lambda, Normalization) - Constructor for class org.apache.lucene.search.similarities.IBSimilarity
Creates IBSimilarity from the three components.
id - Variable in enum org.apache.lucene.util.packed.PackedInts.Format
 
id() - Method in class org.apache.lucene.index.IndexReaderContext
Expert: Return an Object that uniquely identifies this context.
ID_LENGTH - Static variable in class org.apache.lucene.util.StringHelper
length in bytes of an ID
IDENTITY - Static variable in class org.apache.lucene.util.LongValues
An instance that returns the provided value.
IDEOGRAPHIC - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Ideographic token type
IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Ideographic token type
idf(long, long) - Method in class org.apache.lucene.search.similarities.BM25Similarity
Implemented as log(1 + (docCount - docFreq + 0.5)/(docFreq + 0.5)).
idf(long, long) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
Implemented as log((docCount+1)/(docFreq+1)) + 1.
idf(long, long) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Computes a score factor based on a term's document frequency (the number of documents which contain the term).
idf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
compute the inverted document frequency component
idf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
compute the inverted document frequency component
idf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
compute the inverted document frequency component
idf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
compute the inverted document frequency component
idf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
compute the inverted document frequency component
idf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
compute the inverted document frequency component
idf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
compute the inverted document frequency component
idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.BM25Similarity
Computes a score factor for a simple term and returns an explanation for that score factor.
idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
 
idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Computes a score factor for a simple term and returns an explanation for that score factor.
idfExplain(CollectionStatistics, TermStatistics[]) - Method in class org.apache.lucene.search.similarities.BM25Similarity
Computes a score factor for a phrase.
idfExplain(CollectionStatistics, TermStatistics[]) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Computes a score factor for a phrase.
idfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
Explain the score of the inverted document frequency component for a single document
idfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
 
idfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
 
idfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
 
idfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
 
idfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
 
idfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
 
idToString(byte[]) - Static method in class org.apache.lucene.util.StringHelper
Helper method to render an ID as a string, for debugging
IgnoreRandomChains - Annotation Type in org.apache.lucene.util
Annotation to not test a class or constructor with TestRandomChains integration test.
Impact - Class in org.apache.lucene.index
Per-document scoring factors.
Impact(int, long) - Constructor for class org.apache.lucene.index.Impact
Constructor.
impacts(int) - Method in class org.apache.lucene.index.FilteredTermsEnum
 
impacts(int) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
impacts(int) - Method in class org.apache.lucene.index.MultiTermsEnum
 
impacts(int) - Method in class org.apache.lucene.index.TermsEnum
Return a ImpactsEnum.
impacts(int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
impacts(FieldInfo, BlockTermState, int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
impacts(FieldInfo, BlockTermState, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
Return a ImpactsEnum that computes impacts with scorer.
Impacts - Class in org.apache.lucene.index
Information about upcoming impacts, ie.
Impacts() - Constructor for class org.apache.lucene.index.Impacts
Sole constructor.
ImpactsDISI - Class in org.apache.lucene.search
DocIdSetIterator that skips non-competitive docs thanks to the indexed impacts.
ImpactsDISI(DocIdSetIterator, MaxScoreCache) - Constructor for class org.apache.lucene.search.ImpactsDISI
Sole constructor.
ImpactsEnum - Class in org.apache.lucene.index
Extension of PostingsEnum which also provides information about upcoming impacts.
ImpactsEnum() - Constructor for class org.apache.lucene.index.ImpactsEnum
Sole constructor.
ImpactsSource - Interface in org.apache.lucene.index
Source of Impacts.
in - Variable in class org.apache.lucene.index.FilterBinaryDocValues
Wrapped values
in - Variable in class org.apache.lucene.index.FilterCodecReader
The underlying CodecReader instance.
in - Variable in class org.apache.lucene.index.FilterDirectoryReader
The filtered DirectoryReader
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterFields
The underlying Fields instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
The underlying PostingsEnum instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterTerms
The underlying Terms instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
The underlying TermsEnum instance.
in - Variable in class org.apache.lucene.index.FilterLeafReader
The underlying LeafReader.
in - Variable in class org.apache.lucene.index.FilterMergePolicy
The wrapped MergePolicy.
in - Variable in class org.apache.lucene.index.FilterNumericDocValues
Wrapped values
in - Variable in class org.apache.lucene.index.FilterSortedDocValues
Wrapped values
in - Variable in class org.apache.lucene.index.FilterSortedNumericDocValues
Wrapped values
in - Variable in class org.apache.lucene.index.FilterSortedSetDocValues
Wrapped values
in - Variable in class org.apache.lucene.index.FilterVectorValues
Wrapped values
in - Variable in class org.apache.lucene.search.FilterCollector
 
in - Variable in class org.apache.lucene.search.FilterLeafCollector
 
in - Variable in class org.apache.lucene.search.FilterMatchesIterator
The delegate
in - Variable in class org.apache.lucene.search.FilterScorable
 
in - Variable in class org.apache.lucene.search.FilterScorer
 
in - Variable in class org.apache.lucene.search.FilterWeight
 
in - Variable in class org.apache.lucene.store.FilterDirectory
 
in - Variable in class org.apache.lucene.store.FilterIndexInput
 
in - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
 
includesLower() - Method in class org.apache.lucene.search.TermRangeQuery
Returns true if the lower endpoint is inclusive
includesUpper() - Method in class org.apache.lucene.search.TermRangeQuery
Returns true if the upper endpoint is inclusive
incomplete() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
incRef() - Method in class org.apache.lucene.index.IndexReader
Expert: increments the refCount of this IndexReader instance.
incRef() - Method in class org.apache.lucene.util.FileDeleter.RefCount
 
incRef() - Method in class org.apache.lucene.util.RefCount
Increments the reference count.
incRef(String) - Method in class org.apache.lucene.util.FileDeleter
 
incRef(Collection<String>) - Method in class org.apache.lucene.util.FileDeleter
 
incRef(IndexCommit) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Increments the refCount for this IndexCommit.
incRefDeleter(SegmentInfos) - Method in class org.apache.lucene.index.IndexWriter
Record that the files referenced by this SegmentInfos are still in use.
IncrementalHnswGraphMerger - Class in org.apache.lucene.util.hnsw
This selects the biggest Hnsw graph from the provided merge state and initializes a new HnswGraphBuilder with that graph as a starting point.
IncrementalHnswGraphMerger(FieldInfo, RandomVectorScorerSupplier, int, int) - Constructor for class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
incrementBaseToken() - Method in class org.apache.lucene.analysis.GraphTokenFilter
Move the root of the graph to the next token in the wrapped TokenStream
incrementGraph() - Method in class org.apache.lucene.analysis.GraphTokenFilter
Reset to the root token again, and move down the next route through the graph
incrementGraphToken() - Method in class org.apache.lucene.analysis.GraphTokenFilter
Move to the next token in the current route through the graph
incrementToken() - Method in class org.apache.lucene.analysis.CachingTokenFilter
The first time called, it'll read and cache all tokens from the input.
incrementToken() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.LowerCaseFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
 
incrementToken() - Method in class org.apache.lucene.analysis.TokenStream
Consumers (i.e., IndexWriter) use this method to advance the stream to the next token.
incVisitedCount(int) - Method in class org.apache.lucene.search.AbstractKnnCollector
 
incVisitedCount(int) - Method in interface org.apache.lucene.search.KnnCollector
 
incVisitedCount(int) - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
incVisitedCount(int) - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
Independence - Class in org.apache.lucene.search.similarities
Computes the measure of divergence from independence for DFI scoring functions.
Independence() - Constructor for class org.apache.lucene.search.similarities.Independence
Sole constructor.
IndependenceChiSquared - Class in org.apache.lucene.search.similarities
Normalized chi-squared measure of distance from independence
IndependenceChiSquared() - Constructor for class org.apache.lucene.search.similarities.IndependenceChiSquared
Sole constructor.
IndependenceSaturated - Class in org.apache.lucene.search.similarities
Saturated measure of distance from independence
IndependenceSaturated() - Constructor for class org.apache.lucene.search.similarities.IndependenceSaturated
Sole constructor.
IndependenceStandardized - Class in org.apache.lucene.search.similarities
Standardized measure of distance from independence
IndependenceStandardized() - Constructor for class org.apache.lucene.search.similarities.IndependenceStandardized
Sole constructor.
index - Variable in class org.apache.lucene.util.hppc.IntIntHashMap.IntCursor
The current value's index in the container this cursor belongs to.
index - Variable in class org.apache.lucene.util.hppc.IntIntHashMap.IntIntCursor
The current key and value's index in the container this cursor belongs to.
index() - Method in class org.apache.lucene.codecs.lucene90.IndexedDISI
 
INDEX_CODEC_NAME - Static variable in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
Codec name for the index.
INDEX_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
Extension of stored fields index
INDEX_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene90.Lucene90PointsFormat
Filename extension for the index per field
IndexableField - Interface in org.apache.lucene.index
Represents a single field for indexing.
IndexableFieldType - Interface in org.apache.lucene.index
Describes the properties of a field.
IndexCommit - Class in org.apache.lucene.index
Expert: represents a single commit into an index as seen by the IndexDeletionPolicy or IndexReader.
IndexCommit() - Constructor for class org.apache.lucene.index.IndexCommit
Sole constructor.
indexCommits - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
Used to map gen to IndexCommit.
IndexDeletionPolicy - Class in org.apache.lucene.index
Expert: policy for deletion of stale index commits.
IndexDeletionPolicy() - Constructor for class org.apache.lucene.index.IndexDeletionPolicy
Sole constructor, typically called by sub-classes constructors.
IndexedDISI - Class in org.apache.lucene.codecs.lucene90
Disk-based implementation of a DocIdSetIterator which can return the index of the current document, i.e.
IndexedDISI(IndexInput, long, long, int, byte, long) - Constructor for class org.apache.lucene.codecs.lucene90.IndexedDISI
This constructor always creates a new blockSlice and a new jumpTable from in, to ensure that operations are independent from the caller.
indexExists(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
indexExists(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
Returns true if an index likely exists at the specified directory.
IndexFileNames - Class in org.apache.lucene.index
This class contains useful constants representing filenames and extensions used by lucene, as well as convenience methods for querying whether a file name matches an extension (matchesExtension), as well as generating file names from a segment name, generation and extension ( fileNameFromGeneration, segmentFileName).
IndexFormatTooNewException - Exception in org.apache.lucene.index
This exception is thrown when Lucene detects an index that is newer than this Lucene version.
IndexFormatTooNewException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
Creates an IndexFormatTooNewException
IndexFormatTooNewException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
Creates an IndexFormatTooNewException
IndexFormatTooOldException - Exception in org.apache.lucene.index
This exception is thrown when Lucene detects an index that is too old for this Lucene version
IndexFormatTooOldException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
Creates an IndexFormatTooOldException.
IndexFormatTooOldException(String, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
Creates an IndexFormatTooOldException.
IndexFormatTooOldException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
Creates an IndexFormatTooOldException.
IndexFormatTooOldException(DataInput, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
Creates an IndexFormatTooOldException.
indexGet(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
indexHeaderLength(String, String) - Static method in class org.apache.lucene.codecs.CodecUtil
Computes the length of an index header.
indexingDelegate - Variable in class org.apache.lucene.codecs.FlatFieldVectorsWriter
The delegate to write to, can be null When non-null, all vectors seen should be written to the delegate along with being written to the flat vectors.
IndexInput - Class in org.apache.lucene.store
Abstract base class for input from a file in a Directory.
IndexInput(String) - Constructor for class org.apache.lucene.store.IndexInput
resourceDescription should be a non-null, opaque string describing this resource; it's returned from IndexInput.toString().
indexInsert(int, int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
IndexNotFoundException - Exception in org.apache.lucene.index
Signals that no index was found in the Directory.
IndexNotFoundException(String) - Constructor for exception org.apache.lucene.index.IndexNotFoundException
Creates IndexFileNotFoundException with the description message.
indexNumBytes - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Byte size of the index.
indexOf(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
indexOptions - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
IndexOptions of current field being written
indexOptions() - Method in class org.apache.lucene.document.FieldType
IndexOptions, describing what should be recorded into the inverted index
indexOptions() - Method in interface org.apache.lucene.index.IndexableFieldType
IndexOptions, describing what should be recorded into the inverted index
IndexOptions - Enum in org.apache.lucene.index
Controls how much information is stored in the postings lists.
INDEXORDER - Static variable in class org.apache.lucene.search.Sort
Represents sorting by index order.
IndexOrDocValuesQuery - Class in org.apache.lucene.search
A query that uses either an index structure (points or terms) or doc values in order to run a query, depending which one is more efficient.
IndexOrDocValuesQuery(Query, Query) - Constructor for class org.apache.lucene.search.IndexOrDocValuesQuery
indexOut - Variable in class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
Outputs used to write the BKD tree data files.
IndexOutput - Class in org.apache.lucene.store
A DataOutput for appending data to a file in a Directory.
IndexOutput(String, String) - Constructor for class org.apache.lucene.store.IndexOutput
Sole constructor.
IndexPackageAccess - Interface in org.apache.lucene.internal.tests
Access to org.apache.lucene.index package internals exposed to the test framework.
IndexPackageAccess.FieldInfosBuilder - Interface in org.apache.lucene.internal.tests
Public type exposing FieldInfo internal builders.
IndexReader - Class in org.apache.lucene.index
IndexReader is an abstract class, providing an interface for accessing a point-in-time view of an index.
IndexReader.CacheHelper - Interface in org.apache.lucene.index
A utility class that gives hooks in order to help build a cache based on the data that is contained in this index.
IndexReader.CacheKey - Class in org.apache.lucene.index
A cache key identifying a resource that is being cached on.
IndexReader.ClosedListener - Interface in org.apache.lucene.index
A listener that is called when a resource gets closed.
IndexReaderContext - Class in org.apache.lucene.index
A struct like class that represents a hierarchical relationship between IndexReader instances.
indexRemove(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
indexReplace(int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
IndexSearcher - Class in org.apache.lucene.search
Implements search over a single IndexReader.
IndexSearcher(IndexReader) - Constructor for class org.apache.lucene.search.IndexSearcher
Creates a searcher searching the provided index.
IndexSearcher(IndexReaderContext) - Constructor for class org.apache.lucene.search.IndexSearcher
Creates a searcher searching the provided top-level IndexReaderContext.
IndexSearcher(IndexReaderContext, Executor) - Constructor for class org.apache.lucene.search.IndexSearcher
Creates a searcher searching the provided top-level IndexReaderContext.
IndexSearcher(IndexReader, Executor) - Constructor for class org.apache.lucene.search.IndexSearcher
Runs searches for each segment separately, using the provided Executor.
IndexSearcher.LeafSlice - Class in org.apache.lucene.search
A class holding a subset of the IndexSearchers leaf contexts to be executed within a single thread.
IndexSearcher.TooManyClauses - Exception in org.apache.lucene.search
Thrown when an attempt is made to add more than IndexSearcher.TooManyClauses.getMaxClauseCount() clauses.
IndexSearcher.TooManyNestedClauses - Exception in org.apache.lucene.search
Thrown when a client attempts to execute a Query that has more than IndexSearcher.TooManyClauses.getMaxClauseCount() total clauses cumulatively in all of its children.
indexSort - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
The sort order to use to write merged segments.
IndexSorter - Interface in org.apache.lucene.index
Handles how documents should be sorted in an index, both within a segment and between segments.
IndexSorter.ComparableProvider - Interface in org.apache.lucene.index
Used for sorting documents across segments
IndexSorter.DocComparator - Interface in org.apache.lucene.index
A comparator of doc IDs, used for sorting documents within a segment
IndexSorter.DoubleSorter - Class in org.apache.lucene.index
Sorts documents based on double values from a NumericDocValues instance
IndexSorter.FloatSorter - Class in org.apache.lucene.index
Sorts documents based on float values from a NumericDocValues instance
IndexSorter.IntSorter - Class in org.apache.lucene.index
Sorts documents based on integer values from a NumericDocValues instance
IndexSorter.LongSorter - Class in org.apache.lucene.index
Sorts documents based on long values from a NumericDocValues instance
IndexSorter.NumericDocValuesProvider - Interface in org.apache.lucene.index
Provide a NumericDocValues instance for a LeafReader
IndexSorter.SortedDocValuesProvider - Interface in org.apache.lucene.index
Provide a SortedDocValues instance for a LeafReader
IndexSorter.StringSorter - Class in org.apache.lucene.index
Sorts documents based on terms from a SortedDocValues instance
indexSortFields - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
The field names involved in the index sort
IndexSortSortedNumericDocValuesRangeQuery - Class in org.apache.lucene.search
A range query that can take advantage of the fact that the index is sorted to speed up execution.
IndexSortSortedNumericDocValuesRangeQuery(String, long, long, Query) - Constructor for class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
indexSortStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status of index sort
IndexUpgrader - Class in org.apache.lucene.index
This is an easy-to-use tool that upgrades all segments of an index from previous Lucene versions to the current segment file format.
IndexUpgrader(Directory) - Constructor for class org.apache.lucene.index.IndexUpgrader
Creates index upgrader on the given directory, using an IndexWriter using the given matchVersion.
IndexUpgrader(Directory, IndexWriterConfig, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
Creates index upgrader on the given directory, using an IndexWriter using the given config.
IndexUpgrader(Directory, InfoStream, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
Creates index upgrader on the given directory, using an IndexWriter using the given matchVersion.
IndexWriter - Class in org.apache.lucene.index
An IndexWriter creates and maintains an index.
IndexWriter(Directory, IndexWriterConfig) - Constructor for class org.apache.lucene.index.IndexWriter
Constructs a new IndexWriter per the settings given in conf.
IndexWriter.DocStats - Class in org.apache.lucene.index
DocStats for this index
IndexWriter.IndexReaderWarmer - Interface in org.apache.lucene.index
If DirectoryReader.open(IndexWriter) has been called (ie, this writer is in near real-time mode), then after a merge completes, this class can be invoked to warm the reader on the newly merged segment, before the merge commits.
IndexWriterAccess - Interface in org.apache.lucene.internal.tests
Access to IndexWriter internals exposed to the test framework.
IndexWriterConfig - Class in org.apache.lucene.index
Holds all the configuration that is used to create an IndexWriter.
IndexWriterConfig() - Constructor for class org.apache.lucene.index.IndexWriterConfig
Creates a new config, using StandardAnalyzer as the analyzer.
IndexWriterConfig(Analyzer) - Constructor for class org.apache.lucene.index.IndexWriterConfig
Creates a new config that with the provided Analyzer.
IndexWriterConfig.OpenMode - Enum in org.apache.lucene.index
Specifies the open mode for IndexWriter.
IndexWriterEventListener - Interface in org.apache.lucene.index
A callback event listener for recording key events happened inside IndexWriter
IndriAndQuery - Class in org.apache.lucene.search
A Query that matches documents matching combinations of subqueries.
IndriAndQuery(List<BooleanClause>) - Constructor for class org.apache.lucene.search.IndriAndQuery
 
IndriAndScorer - Class in org.apache.lucene.search
Combines scores of subscorers.
IndriAndScorer(Weight, List<Scorer>, ScoreMode, float) - Constructor for class org.apache.lucene.search.IndriAndScorer
 
IndriAndWeight - Class in org.apache.lucene.search
The Weight for IndriAndQuery, used to normalize, score and explain these queries.
IndriAndWeight(IndriAndQuery, IndexSearcher, ScoreMode, float) - Constructor for class org.apache.lucene.search.IndriAndWeight
 
IndriCollectionModel() - Constructor for class org.apache.lucene.search.similarities.IndriDirichletSimilarity.IndriCollectionModel
Sole constructor: parameter-free
IndriDirichletSimilarity - Class in org.apache.lucene.search.similarities
Bayesian smoothing using Dirichlet priors as implemented in the Indri Search engine (http://www.lemurproject.org/indri.php).
IndriDirichletSimilarity() - Constructor for class org.apache.lucene.search.similarities.IndriDirichletSimilarity
Instantiates the similarity with the default μ value of 2000.
IndriDirichletSimilarity(float) - Constructor for class org.apache.lucene.search.similarities.IndriDirichletSimilarity
Instantiates the similarity with the provided μ parameter.
IndriDirichletSimilarity(LMSimilarity.CollectionModel) - Constructor for class org.apache.lucene.search.similarities.IndriDirichletSimilarity
Instantiates the similarity with the default μ value of 2000.
IndriDirichletSimilarity(LMSimilarity.CollectionModel, float) - Constructor for class org.apache.lucene.search.similarities.IndriDirichletSimilarity
Instantiates the similarity with the provided μ parameter.
IndriDirichletSimilarity.IndriCollectionModel - Class in org.apache.lucene.search.similarities
Models p(w|C) as the number of occurrences of the term in the collection, divided by the total number of tokens + 1.
IndriDisjunctionScorer - Class in org.apache.lucene.search
The Indri implemenation of a disjunction scorer which stores the subscorers for the child queries.
IndriDisjunctionScorer(Weight, List<Scorer>, ScoreMode, float) - Constructor for class org.apache.lucene.search.IndriDisjunctionScorer
 
IndriQuery - Class in org.apache.lucene.search
A Basic abstract query that all IndriQueries can extend to implement toString, equals, getClauses, and iterator.
IndriQuery(List<BooleanClause>) - Constructor for class org.apache.lucene.search.IndriQuery
 
IndriScorer - Class in org.apache.lucene.search
The Indri parent scorer that stores the boost so that IndriScorers can use the boost outside of the term.
IndriScorer(Weight, float) - Constructor for class org.apache.lucene.search.IndriScorer
 
InetAddressPoint - Class in org.apache.lucene.document
An indexed 128-bit InetAddress field.
InetAddressPoint(String, InetAddress) - Constructor for class org.apache.lucene.document.InetAddressPoint
Creates a new InetAddressPoint, indexing the provided address.
InetAddressRange - Class in org.apache.lucene.document
An indexed InetAddress Range Field
InetAddressRange(String, InetAddress, InetAddress) - Constructor for class org.apache.lucene.document.InetAddressRange
Create a new InetAddressRange from min/max value
info - Variable in class org.apache.lucene.index.SegmentCommitInfo
The SegmentInfo that we wrap.
info(int) - Method in class org.apache.lucene.index.SegmentInfos
Returns SegmentCommitInfo at the provided index.
inform(ResourceLoader) - Method in interface org.apache.lucene.util.ResourceLoaderAware
Initializes this component with the provided ResourceLoader (used for loading classes, files, etc).
infoStream - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
InfoStream for debugging messages.
infoStream - Variable in class org.apache.lucene.index.MergeScheduler
For messages about merge scheduling
infoStream - Variable in class org.apache.lucene.index.MergeState
InfoStream for debugging messages.
infoStream - Variable in class org.apache.lucene.index.SegmentWriteState
InfoStream used for debugging messages.
InfoStream - Class in org.apache.lucene.util
Debugging API for Lucene classes such as IndexWriter and SegmentInfos.
InfoStream() - Constructor for class org.apache.lucene.util.InfoStream
 
init() - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Allocates internal skip buffers.
init() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
Initializes the BytesStartArray.
init() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
init(long, int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
Initializes the reader, for reuse on a new term.
init(long, long, long, long, int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
init(DataInput, long) - Method in interface org.apache.lucene.util.fst.FSTStore
Initialize the FSTStore
init(DataInput, long) - Method in class org.apache.lucene.util.fst.OffHeapFSTStore
 
init(DataInput, long) - Method in class org.apache.lucene.util.fst.OnHeapFSTStore
 
init(IndexInput, SegmentReadState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
init(IndexInput, SegmentReadState) - Method in class org.apache.lucene.codecs.PostingsReaderBase
Performs any initialization, such as reading and verifying the header from the provided terms dictionary IndexInput.
init(IndexOutput, SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
init(IndexOutput, SegmentWriteState) - Method in class org.apache.lucene.codecs.PostingsWriterBase
Called once after startup, before any terms have been added.
initDocMap - Variable in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
initGraph(int, HnswGraph, int[], int) - Static method in class org.apache.lucene.util.hnsw.InitializedHnswGraphBuilder
 
initGraphSize - Variable in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
InitializedHnswGraphBuilder - Class in org.apache.lucene.util.hnsw
This creates a graph builder that is initialized with the provided HnswGraph.
InitializedHnswGraphBuilder(RandomVectorScorerSupplier, int, int, long, OnHeapHnswGraph, BitSet) - Constructor for class org.apache.lucene.util.hnsw.InitializedHnswGraphBuilder
 
initialValue() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
initReader - Variable in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
initReader(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
Override this if you want to add a CharFilter chain.
initReader(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
initReaderForNormalization(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
Wrap the given Reader with CharFilters that make sense for normalization.
initReaderForNormalization(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
initRefCount(String) - Method in class org.apache.lucene.util.FileDeleter
if the file is not yet recorded, this method will create a new RefCount object with count 0
initSize - Variable in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
initTransition(int, Transition) - Method in class org.apache.lucene.util.automaton.Automaton
Initialize the provided Transition to iterate through all transitions leaving the specified state.
InPlaceMergeSorter - Class in org.apache.lucene.util
Sorter implementation based on the merge-sort algorithm that merges in place (no extra memory will be allocated).
InPlaceMergeSorter() - Constructor for class org.apache.lucene.util.InPlaceMergeSorter
Create a new InPlaceMergeSorter
input - Variable in class org.apache.lucene.analysis.CharFilter
The underlying character-input stream.
input - Variable in class org.apache.lucene.analysis.TokenFilter
The source of tokens for this filter.
input - Variable in class org.apache.lucene.analysis.Tokenizer
The text source for this Tokenizer.
input - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
input - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
 
input - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
input - Variable in class org.apache.lucene.util.fst.Util.Result
 
InputOutput() - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
InputOutput() - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
 
InputStreamDataInput - Class in org.apache.lucene.store
A DataInput wrapping a plain InputStream.
InputStreamDataInput(InputStream) - Constructor for class org.apache.lucene.store.InputStreamDataInput
 
insertWithOverflow(int, float) - Method in class org.apache.lucene.util.hnsw.NeighborQueue
If the heap is not full (size is less than the initialSize provided to the constructor), adds a new node-and-score element.
insertWithOverflow(long) - Method in class org.apache.lucene.util.LongHeap
Adds a value to an LongHeap in log(size) time.
insertWithOverflow(T) - Method in class org.apache.lucene.util.PriorityQueue
Adds an Object to a PriorityQueue in log(size) time.
INSTANCE - Static variable in class org.apache.lucene.index.NoDeletionPolicy
The single instance of this class.
INSTANCE - Static variable in class org.apache.lucene.index.NoMergePolicy
Singleton instance.
INSTANCE - Static variable in class org.apache.lucene.index.NoMergeScheduler
The single instance of NoMergeScheduler
INSTANCE - Static variable in class org.apache.lucene.store.NativeFSLockFactory
Singleton instance
INSTANCE - Static variable in class org.apache.lucene.store.NoLockFactory
The singleton
INSTANCE - Static variable in class org.apache.lucene.store.SimpleFSLockFactory
Singleton instance
INT - org.apache.lucene.search.SortField.Type
Sort using term values as encoded Integers.
INT_BLOCK_MASK - Static variable in class org.apache.lucene.util.IntBlockPool
 
INT_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.IntBlockPool
 
INT_BLOCK_SIZE - Static variable in class org.apache.lucene.util.IntBlockPool
 
int4ToLong(int) - Static method in class org.apache.lucene.util.SmallFloat
Decode values encoded with SmallFloat.longToInt4(long).
intAt(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Return the int at the given offset.
IntBlockPool - Class in org.apache.lucene.util
A pool for int blocks similar to ByteBlockPool
IntBlockPool() - Constructor for class org.apache.lucene.util.IntBlockPool
Creates a new IntBlockPool with a default IntBlockPool.Allocator.
IntBlockPool(IntBlockPool.Allocator) - Constructor for class org.apache.lucene.util.IntBlockPool
Creates a new IntBlockPool with the given IntBlockPool.Allocator.
IntBlockPool.Allocator - Class in org.apache.lucene.util
Abstract class for allocating and freeing int blocks.
IntBlockPool.DirectAllocator - Class in org.apache.lucene.util
A simple IntBlockPool.Allocator that never recycles.
IntBlockTermState() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
Sole constructor.
IntComparator - Class in org.apache.lucene.search.comparators
Comparator based on Integer.compare(int, int) for numHits.
IntComparator(int, String, Integer, boolean, Pruning) - Constructor for class org.apache.lucene.search.comparators.IntComparator
 
IntComparator.IntLeafComparator - Class in org.apache.lucene.search.comparators
Leaf comparator for IntComparator that provides skipping functionality
IntContainer() - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap.IntContainer
 
IntCursor() - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap.IntCursor
 
INTEGER - org.apache.lucene.document.StoredValue.Type
Type of integer values.
interleave(int, int) - Static method in class org.apache.lucene.util.BitUtil
Interleaves the first 32 bits of each long value
intersect(PointValues.IntersectVisitor) - Method in class org.apache.lucene.index.PointValues
Finds all documents and points matching the provided visitor.
intersect(CompiledAutomaton) - Method in class org.apache.lucene.index.FilterSortedDocValues
 
intersect(CompiledAutomaton) - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
intersect(CompiledAutomaton) - Method in class org.apache.lucene.index.SortedDocValues
Returns a TermsEnum over the values, filtered by a CompiledAutomaton The enum supports TermsEnum.ord().
intersect(CompiledAutomaton) - Method in class org.apache.lucene.index.SortedSetDocValues
Returns a TermsEnum over the values, filtered by a CompiledAutomaton The enum supports TermsEnum.ord().
intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
 
intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.MultiTerms
 
intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.Terms
Returns a TermsEnum that iterates over all terms and documents that are accepted by the provided CompiledAutomaton.
intersection(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the intersection of the languages of the given automata.
INTERSECTION - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables intersection (&).
intersectionCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
Returns the popcount or cardinality of the intersection of the two sets.
intersectIterators(List<? extends DocIdSetIterator>) - Static method in class org.apache.lucene.search.ConjunctionUtils
Create a conjunction over the provided DocIdSetIterators.
intersects(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
returns true if the sets have any elements in common
intersects(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
returns true if the sets have any elements in common
INTERSECTS - org.apache.lucene.document.RangeFieldQuery.QueryType
Use this for intersects queries.
INTERSECTS - org.apache.lucene.document.ShapeField.QueryRelation
used for INTERSECT Queries
intersectScorers(Collection<Scorer>) - Static method in class org.apache.lucene.search.ConjunctionUtils
Create a conjunction over the provided Scorers.
intersectsLine(double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D intersects the provided line *
intersectsLine(double, double, double, double, double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D intersects the provided line *
intersectsTriangle(double, double, double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D intersects the provided triangle *
intersectsTriangle(double, double, double, double, double, double, double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
return true if this component2D intersects the provided triangle *
INTERVAL - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables numerical intervals ( <n-m>).
intField(FieldInfo, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
intField(FieldInfo, int) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
intField(FieldInfo, int) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a int numeric field.
IntField - Class in org.apache.lucene.document
Field that stores a per-document int value for scoring, sorting or value retrieval and index the field for fast range filters.
IntField(String, int) - Constructor for class org.apache.lucene.document.IntField
Deprecated.
IntField(String, int, Field.Store) - Constructor for class org.apache.lucene.document.IntField
Creates a new IntField, indexing the provided point, storing it as a DocValue, and optionally storing it as a stored field.
IntIntCursor() - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap.IntIntCursor
 
IntIntHashMap - Class in org.apache.lucene.util.hppc
A hash map of int to int, implemented using open addressing with linear probing for collision resolution.
IntIntHashMap() - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap
New instance with sane defaults.
IntIntHashMap(int) - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap
New instance with sane defaults.
IntIntHashMap(int, double) - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap
New instance with the provided defaults.
IntIntHashMap(Iterable<? extends IntIntHashMap.IntIntCursor>) - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap
Create a hash map from all key-value pairs of another container.
IntIntHashMap.AbstractIterator<E> - Class in org.apache.lucene.util.hppc
Simplifies the implementation of iterators a bit.
IntIntHashMap.BufferAllocationException - Exception in org.apache.lucene.util.hppc
BufferAllocationException forked from HPPC
IntIntHashMap.IntContainer - Class in org.apache.lucene.util.hppc
IntCursor iterable with size and toArray function implemented
IntIntHashMap.IntCursor - Class in org.apache.lucene.util.hppc
Forked from HPPC, holding int index and int value
IntIntHashMap.IntIntCursor - Class in org.apache.lucene.util.hppc
Forked from HPPC, holding int index,key and value
IntIntHashMap.KeysContainer - Class in org.apache.lucene.util.hppc
A view of the keys inside this hash map.
IntLeafComparator(LeafReaderContext) - Constructor for class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
intOffset - Variable in class org.apache.lucene.util.IntBlockPool
Current head offset
IntPoint - Class in org.apache.lucene.document
An indexed int field for fast range filters.
IntPoint(String, int...) - Constructor for class org.apache.lucene.document.IntPoint
Creates a new IntPoint, indexing the provided N-dimensional int point.
IntRange - Class in org.apache.lucene.document
An indexed Integer Range field.
IntRange(String, int[], int[]) - Constructor for class org.apache.lucene.document.IntRange
Create a new IntRange type, from min/max parallel arrays
IntRangeDocValuesField - Class in org.apache.lucene.document
DocValues field for IntRange.
IntRangeDocValuesField(String, int[], int[]) - Constructor for class org.apache.lucene.document.IntRangeDocValuesField
Sole constructor.
IntroSelector - Class in org.apache.lucene.util
Adaptive selection algorithm based on the introspective quick select algorithm.
IntroSelector() - Constructor for class org.apache.lucene.util.IntroSelector
 
introSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
Sorts the given random access List in natural order.
introSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
Sorts the given random access List using the Comparator.
introSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array in natural order.
introSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array slice in natural order.
introSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array slice using the Comparator.
introSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array using the Comparator.
IntroSorter - Class in org.apache.lucene.util
Sorter implementation based on a variant of the quicksort algorithm called introsort: when the recursion level exceeds the log of the length of the array to sort, it falls back to heapsort.
IntroSorter() - Constructor for class org.apache.lucene.util.IntroSorter
Create a new IntroSorter.
ints - Variable in class org.apache.lucene.util.IntsRef
The contents of the IntsRef.
ints() - Method in class org.apache.lucene.util.IntsRefBuilder
Return a reference to the ints of this builder.
intsEquals(IntsRef) - Method in class org.apache.lucene.util.IntsRef
 
IntSequenceOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a sequence of ints.
IntSorter(String, Integer, boolean, IndexSorter.NumericDocValuesProvider) - Constructor for class org.apache.lucene.index.IndexSorter.IntSorter
Creates a new IntSorter
IntsRef - Class in org.apache.lucene.util
Represents int[], as a slice (offset + length) into an existing int[].
IntsRef() - Constructor for class org.apache.lucene.util.IntsRef
Create a IntsRef with IntsRef.EMPTY_INTS
IntsRef(int) - Constructor for class org.apache.lucene.util.IntsRef
Create a IntsRef pointing to a new array of size capacity.
IntsRef(int[], int, int) - Constructor for class org.apache.lucene.util.IntsRef
This instance will directly reference ints w/o making a copy.
IntsRefBuilder - Class in org.apache.lucene.util
A builder for IntsRef instances.
IntsRefBuilder() - Constructor for class org.apache.lucene.util.IntsRefBuilder
Sole constructor.
IntsRefFSTEnum<T> - Class in org.apache.lucene.util.fst
Enumerates all input (IntsRef) + output pairs in an FST.
IntsRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum
doFloor controls the behavior of advance: if it's true doFloor is true, advance positions to the biggest term before target.
IntsRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
Holds a single input (IntsRef) + output pair.
intsRefToBytesRef(IntsRef) - Static method in class org.apache.lucene.util.StringHelper
Just converts each int in the incoming IntsRef to each byte in the returned BytesRef, throwing IllegalArgumentException if any int value is out of bounds for a byte.
intToByte4(int) - Static method in class org.apache.lucene.util.SmallFloat
Encode an integer to a byte.
IntToIntFunction - Interface in org.apache.lucene.util.hnsw
Native int to int function
intToSortableBytes(int, byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
Encodes an integer value such that unsigned byte order comparison is consistent with Integer.compare(int, int)
intUpto - Variable in class org.apache.lucene.util.IntBlockPool
Pointer to the current position in head buffer
invertableType() - Method in class org.apache.lucene.document.Field
 
invertableType() - Method in class org.apache.lucene.document.KeywordField
 
invertableType() - Method in class org.apache.lucene.document.StringField
 
invertableType() - Method in interface org.apache.lucene.index.IndexableField
Describes how this field should be inverted.
InvertableType - Enum in org.apache.lucene.document
Describes how an IndexableField should be inverted for indexing terms and postings.
invokeAll(Collection<Callable<T>>) - Method in class org.apache.lucene.search.TaskExecutor
Execute all the callables provided as an argument, wait for them to complete and return the obtained results.
IOConsumer<T> - Interface in org.apache.lucene.util
An IO operation with a single input that may throw an IOException.
IOContext - Class in org.apache.lucene.store
IOContext holds additional details on the merge/search context.
IOContext() - Constructor for class org.apache.lucene.store.IOContext
 
IOContext(FlushInfo) - Constructor for class org.apache.lucene.store.IOContext
 
IOContext(IOContext.Context) - Constructor for class org.apache.lucene.store.IOContext
 
IOContext(IOContext, boolean) - Constructor for class org.apache.lucene.store.IOContext
This constructor is used to initialize a IOContext instance with a new value for the readOnce variable.
IOContext(MergeInfo) - Constructor for class org.apache.lucene.store.IOContext
 
IOContext.Context - Enum in org.apache.lucene.store
Context is a enumerator which specifies the context in which the Directory is being used for.
IOFunction<T,​R> - Interface in org.apache.lucene.util
A Function that may throw an IOException
IOSupplier<T> - Interface in org.apache.lucene.util
This is a result supplier that is allowed to throw an IOException.
IOUtils - Class in org.apache.lucene.util
Utilities for dealing with Closeables.
IOUtils.IOConsumer<T> - Interface in org.apache.lucene.util
Deprecated, for removal: This API element is subject to removal in a future version.
was replaced by IOConsumer.
IOUtils.IOFunction<T,​R> - Interface in org.apache.lucene.util
Deprecated, for removal: This API element is subject to removal in a future version.
was replaced by IOFunction.
IS_CLIENT_VM - Static variable in class org.apache.lucene.util.Constants
True iff the Java runtime is a client runtime and C2 compiler is not enabled.
IS_HOTSPOT_VM - Static variable in class org.apache.lucene.util.Constants
True iff the Java VM is based on Hotspot and has the Hotspot MX bean readable by Lucene.
IS_JVMCI_VM - Static variable in class org.apache.lucene.util.Constants
True if jvmci is enabled (e.g.
isAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Returns true if this merge was or should be aborted.
isAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
Return the aborted state of this merge.
isAccept(int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Returns true if this state is an accept state.
isAccept(int) - Method in class org.apache.lucene.util.automaton.Automaton
Returns true if this state is an accept state.
isAccept(int) - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns acceptance status for given state.
isAutomatonBinary() - Method in class org.apache.lucene.search.AutomatonQuery
Is this a binary (byte) oriented automaton.
isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
 
isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.FilterWeight
 
isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.IndriAndWeight
 
isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
 
isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.PhraseWeight
 
isCacheable(LeafReaderContext) - Method in interface org.apache.lucene.search.SegmentCacheable
 
isCacheable(LeafReaderContext, String...) - Static method in class org.apache.lucene.index.DocValues
Returns true if the specified docvalues fields have not been updated
isCached() - Method in class org.apache.lucene.analysis.CachingTokenFilter
If the underlying token stream was consumed and cached.
isCached() - Method in class org.apache.lucene.search.CachingCollector
Return true is this collector is able to replay collection.
isCheckPendingFlushOnUpdate() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Expert: Returns if indexing threads check for pending flushes on update in order to help our flushing indexing buffers to disk
isClone - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 
isClosed(IndexWriter) - Method in interface org.apache.lucene.internal.tests.IndexWriterAccess
 
isComplete - Variable in class org.apache.lucene.util.fst.Util.TopResults
true iff this is a complete result ie.
isCurrent() - Method in class org.apache.lucene.index.DirectoryReader
Check whether any new changes have occurred to the index since this reader was opened.
isCurrent() - Method in class org.apache.lucene.index.FilterDirectoryReader
 
isCurrent() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
isDeleted() - Method in class org.apache.lucene.index.IndexCommit
Returns true if this commit should be deleted; this is only used by IndexWriter after invoking the IndexDeletionPolicy.
isDeleterClosed(IndexWriter) - Method in interface org.apache.lucene.internal.tests.IndexWriterAccess
 
isDense() - Method in class org.apache.lucene.codecs.lucene95.OrdToDocDISIReaderConfiguration
 
isDeterministic() - Method in class org.apache.lucene.util.automaton.Automaton
Returns true if this automaton is deterministic (for ever state there is only one transition for each label).
isEarlyTerminated() - Method in class org.apache.lucene.search.TopFieldCollector
Return whether collection terminated early.
isEdgefromPolygon(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
get if edge is shared with the polygon for the given edge
isEmpty() - Method in class org.apache.lucene.codecs.lucene95.OrdToDocDISIReaderConfiguration
 
isEmpty() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
isEmpty() - Method in class org.apache.lucene.util.WeakIdentityMap
Returns true if this map contains no key-value mappings.
isEmpty(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given automaton accepts no strings.
isEnabled(String) - Method in class org.apache.lucene.util.InfoStream
returns true if messages are enabled and should be posted to InfoStream.message(java.lang.String, java.lang.String).
isEnabled(String) - Method in class org.apache.lucene.util.JavaLoggingInfoStream
 
isEnabled(String) - Method in class org.apache.lucene.util.PrintStreamInfoStream
 
isEnableTestPoints() - Method in class org.apache.lucene.index.IndexWriter
Tests should override this to enable test points.
isExhaustive() - Method in enum org.apache.lucene.search.ScoreMode
Returns true if for this ScoreMode it is necessary to process all documents, or false if is enough to go through top documents only.
isExplicitLuceneMatchVersion() - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
isExternal - Variable in class org.apache.lucene.store.MergeInfo
 
isFinal() - Method in class org.apache.lucene.util.fst.FST.Arc
 
isFinite(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the language of this automaton is finite.
isGreedy() - Method in class org.apache.lucene.search.TimeLimitingCollector
Checks if this time limited collector is greedy in collecting the last hit.
isKeyword() - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
Returns true if the current token is a keyword, otherwise false
isKeyword() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
isLast() - Method in class org.apache.lucene.util.fst.FST.Arc
 
isMatch() - Method in class org.apache.lucene.search.Explanation
Indicates whether or not this Explanation models a match.
isMerged(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
Returns true if the number of segments eligible for merging is less than or equal to the specified maxNumSegments.
isMerged(SegmentInfos, SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
Returns true if this single info is already fully merged (has no pending deletes, is in the same dir as the writer, and matches the current compound file setting
isOpen - Variable in class org.apache.lucene.store.BaseDirectory
 
isOpen() - Method in class org.apache.lucene.index.IndexWriter
Returns true if this IndexWriter is still open.
isOverriddenAsOf(Class<? extends C>) - Method in class org.apache.lucene.util.VirtualMethod
Returns, if this method is overridden/implemented in the inheritance path between baseClass and the given subclass subclazz.
isParentClassLoader(ClassLoader, ClassLoader) - Static method in interface org.apache.lucene.util.ClassLoaderUtils
Utility method to check if some class loader is a (grand-)parent of or the same as another one.
isParentField() - Method in class org.apache.lucene.index.FieldInfo
Returns true if this field is configured and used as the parent document field field.
isProhibited() - Method in class org.apache.lucene.search.BooleanClause
 
isRequired() - Method in class org.apache.lucene.search.BooleanClause
 
isScoring() - Method in class org.apache.lucene.search.BooleanClause
 
isSearcherCurrent() - Method in class org.apache.lucene.search.SearcherManager
Returns true if no changes have occurred since this searcher ie.
isShutdown() - Method in class org.apache.lucene.util.SameThreadExecutorService
 
isSingleValued(Iterable<Number>) - Static method in class org.apache.lucene.codecs.DocValuesConsumer
Helper: returns true if the given docToValue count contains only at most one value
isSoftDeletesField() - Method in class org.apache.lucene.index.FieldInfo
Returns true if this field is configured and used as the soft-deletes field.
isSupported(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Tests whether the provided number of bits per value is supported by the format.
isSystemStream() - Method in class org.apache.lucene.util.PrintStreamInfoStream
 
isTerminated() - Method in class org.apache.lucene.util.SameThreadExecutorService
 
isTopLevel - Variable in class org.apache.lucene.index.IndexReaderContext
true if this context struct represents the top level reader within the hierarchical context
isTotal(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given automaton accepts all strings.
isTotal(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given automaton accepts all strings for the specified min/max range of the alphabet.
isValid() - Method in class org.apache.lucene.util.BytesRef
Performs internal consistency checks.
isValid() - Method in class org.apache.lucene.util.CharsRef
Performs internal consistency checks.
isValid() - Method in class org.apache.lucene.util.IntsRef
Performs internal consistency checks.
isValid() - Method in class org.apache.lucene.util.LongsRef
Performs internal consistency checks.
iterationSeed - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
Seed used to ensure the hash iteration order is different from an iteration to another.
iterator - Variable in class org.apache.lucene.search.DisiWrapper
 
iterator() - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
iterator() - Method in class org.apache.lucene.analysis.CharArraySet
Returns an Iterator for char[] instances in this set.
iterator() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
iterator() - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
 
iterator() - Method in class org.apache.lucene.document.Document
 
iterator() - Method in class org.apache.lucene.index.DocsWithFieldSet
 
iterator() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
 
iterator() - Method in class org.apache.lucene.index.FieldInfos
Returns an iterator over all the fieldinfo objects present, ordered by ascending field number
iterator() - Method in class org.apache.lucene.index.Fields
Returns an iterator that will step through all fields names.
iterator() - Method in class org.apache.lucene.index.FilterLeafReader.FilterFields
 
iterator() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
iterator() - Method in class org.apache.lucene.index.MultiFields
 
iterator() - Method in class org.apache.lucene.index.MultiTerms
 
iterator() - Method in class org.apache.lucene.index.PrefixCodedTerms
Return an iterator over the terms stored in this PrefixCodedTerms.
iterator() - Method in class org.apache.lucene.index.SegmentInfos
Returns an unmodifiable Iterator of contained segments in order.
iterator() - Method in class org.apache.lucene.index.Terms
Returns an iterator that will step through all terms.
iterator() - Method in class org.apache.lucene.search.BooleanQuery
Returns an iterator on the clauses in this query.
iterator() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
iterator() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
iterator() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
 
iterator() - Method in class org.apache.lucene.search.DocIdSet
Provides a DocIdSetIterator to access the set.
iterator() - Method in class org.apache.lucene.search.FilterScorer
 
iterator() - Method in class org.apache.lucene.search.IndriDisjunctionScorer
 
iterator() - Method in class org.apache.lucene.search.IndriQuery
 
iterator() - Method in class org.apache.lucene.search.IndriScorer
 
iterator() - Method in class org.apache.lucene.search.LRUQueryCache.CacheAndCount
 
iterator() - Method in class org.apache.lucene.search.Multiset
 
iterator() - Method in class org.apache.lucene.search.NamedMatches
 
iterator() - Method in class org.apache.lucene.search.Scorer
Return a DocIdSetIterator over matching documents.
iterator() - Method in class org.apache.lucene.search.TermScorer
 
iterator() - Method in class org.apache.lucene.util.BitDocIdSet
 
iterator() - Method in class org.apache.lucene.util.BytesRefArray
sugar for BytesRefArray.iterator(Comparator) with a null comparator
iterator() - Method in class org.apache.lucene.util.fst.Util.TopResults
 
iterator() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
iterator() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.KeysContainer
 
iterator() - Method in class org.apache.lucene.util.NamedSPILoader
 
iterator() - Method in class org.apache.lucene.util.NotDocIdSet
 
iterator() - Method in class org.apache.lucene.util.packed.PackedLongValues
Return an iterator over the values of this array.
iterator() - Method in class org.apache.lucene.util.PriorityQueue
 
iterator() - Method in class org.apache.lucene.util.RoaringDocIdSet
 
iterator(Comparator<BytesRef>) - Method in class org.apache.lucene.util.BytesRefArray
Returns a BytesRefIterator with point in time semantics.
iterator(BytesRefArray.SortState) - Method in class org.apache.lucene.util.BytesRefArray
Returns an BytesRefArray.IndexedBytesRefIterator with point in time semantics.

J

JAVA_VENDOR - Static variable in class org.apache.lucene.util.Constants
The value of System.getProperty("java.vendor").
JAVA_VERSION - Static variable in class org.apache.lucene.util.Constants
Deprecated.
To detect Java versions use Runtime.version()
JavaLoggingInfoStream - Class in org.apache.lucene.util
InfoStream implementation that logs every message using Java Utils Logging (JUL) with the supplied log level.
JavaLoggingInfoStream(String, Level) - Constructor for class org.apache.lucene.util.JavaLoggingInfoStream
Gets an implementation that logs using the given log level and adds a prefix to the component name.
JavaLoggingInfoStream(Function<String, String>, Level) - Constructor for class org.apache.lucene.util.JavaLoggingInfoStream
Gets an implementation that logs using the given log level with a logger name derived from the component name.
JavaLoggingInfoStream(Level) - Constructor for class org.apache.lucene.util.JavaLoggingInfoStream
Gets an implementation using the given log level with a default prefix "org.apache.lucene.".
JRE_IS_64BIT - Static variable in class org.apache.lucene.util.Constants
True iff running on a 64bit JVM
JRE_IS_MINIMUM_JAVA11 - Static variable in class org.apache.lucene.util.Constants
Deprecated.
This constant is useless and always true. To detect Java versions use Runtime.version()
JRE_IS_MINIMUM_JAVA8 - Static variable in class org.apache.lucene.util.Constants
Deprecated.
This constant is useless and always true. To detect Java versions use Runtime.version()
JRE_IS_MINIMUM_JAVA9 - Static variable in class org.apache.lucene.util.Constants
Deprecated.
This constant is useless and always true. To detect Java versions use Runtime.version()
JVM_NAME - Static variable in class org.apache.lucene.util.Constants
JVM vendor name.
JVM_SPEC_VERSION - Static variable in class org.apache.lucene.util.Constants
Deprecated.
To detect Java versions use Runtime.version()
JVM_VENDOR - Static variable in class org.apache.lucene.util.Constants
JVM vendor info.
JVM_VERSION - Static variable in class org.apache.lucene.util.Constants
Deprecated.
To detect Java versions use Runtime.version()

K

k - Variable in class org.apache.lucene.search.similarities.Axiomatic
hyperparam for the primitive weighthing function
k() - Method in class org.apache.lucene.search.AbstractKnnCollector
 
k() - Method in interface org.apache.lucene.search.KnnCollector
 
k() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
k() - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
KATAKANA - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Katakana token type
KATAKANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Katakana token type
keepFullyDeletedSegment(IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.FilterMergePolicy
 
keepFullyDeletedSegment(IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.MergePolicy
Returns true if the segment represented by the given CodecReader should be keep even if it's fully deleted.
keepFullyDeletedSegment(IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.NoMergePolicy
 
keepFullyDeletedSegment(IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.SoftDeletesRetentionMergePolicy
 
KeepOnlyLastCommitDeletionPolicy - Class in org.apache.lucene.index
This IndexDeletionPolicy implementation that keeps only the most recent commit and immediately removes all prior commits after a new commit is done.
KeepOnlyLastCommitDeletionPolicy() - Constructor for class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
Sole constructor.
key - Variable in class org.apache.lucene.util.hppc.IntIntHashMap.IntIntCursor
The current key.
keyIterator() - Method in class org.apache.lucene.util.WeakIdentityMap
Returns an iterator over all weak keys of this map.
keys - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
The array holding keys.
keys - Variable in class org.apache.lucene.util.SentinelIntSet
A power-of-2 over-sized array holding the integers in the set along with empty values.
keys() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Returns a specialized view of the keys of this associated container.
KeysContainer() - Constructor for class org.apache.lucene.util.hppc.IntIntHashMap.KeysContainer
 
keySet() - Method in class org.apache.lucene.analysis.CharArrayMap
Returns an CharArraySet view on the map's keys.
KeywordAttribute - Interface in org.apache.lucene.analysis.tokenattributes
This attribute can be used to mark a token as a keyword.
KeywordAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of KeywordAttribute.
KeywordAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
Initialize this attribute with the keyword value as false.
KeywordField - Class in org.apache.lucene.document
Field that indexes a per-document String or BytesRef into an inverted index for fast filtering, stores values in a columnar fashion using DocValuesType.SORTED_SET doc values for sorting and faceting, and optionally stores values as stored fields for top-hits retrieval.
KeywordField(String, String, Field.Store) - Constructor for class org.apache.lucene.document.KeywordField
Creates a new KeywordField from a String value, by indexing its UTF-8 representation.
KeywordField(String, BytesRef, Field.Store) - Constructor for class org.apache.lucene.document.KeywordField
Creates a new KeywordField.
kind - Variable in class org.apache.lucene.util.automaton.RegExp
The type of expression
KnnByteVectorField - Class in org.apache.lucene.document
A field that contains a single byte numeric vector (or none) for each document.
KnnByteVectorField(String, byte[]) - Constructor for class org.apache.lucene.document.KnnByteVectorField
Creates a numeric vector field with the default EUCLIDEAN_HNSW (L2) similarity.
KnnByteVectorField(String, byte[], FieldType) - Constructor for class org.apache.lucene.document.KnnByteVectorField
Creates a numeric vector field.
KnnByteVectorField(String, byte[], VectorSimilarityFunction) - Constructor for class org.apache.lucene.document.KnnByteVectorField
Creates a numeric vector field.
KnnByteVectorQuery - Class in org.apache.lucene.search
Uses KnnVectorsReader.search(String, byte[], KnnCollector, Bits) to perform nearest neighbour search.
KnnByteVectorQuery(String, byte[], int) - Constructor for class org.apache.lucene.search.KnnByteVectorQuery
Find the k nearest documents to the target vector according to the vectors in the given field.
KnnByteVectorQuery(String, byte[], int, Query) - Constructor for class org.apache.lucene.search.KnnByteVectorQuery
Find the k nearest documents to the target vector according to the vectors in the given field.
KnnCollector - Interface in org.apache.lucene.search
KnnCollector is a knn collector used for gathering kNN results and providing topDocs from the gathered neighbors
KnnCollectorManager - Interface in org.apache.lucene.search.knn
KnnCollectorManager responsible for creating KnnCollector instances.
KnnFieldVectorsWriter<T> - Class in org.apache.lucene.codecs
Vectors' writer for a field
KnnFieldVectorsWriter() - Constructor for class org.apache.lucene.codecs.KnnFieldVectorsWriter
Sole constructor
KnnFloatVectorField - Class in org.apache.lucene.document
A field that contains a single floating-point numeric vector (or none) for each document.
KnnFloatVectorField(String, float[]) - Constructor for class org.apache.lucene.document.KnnFloatVectorField
Creates a numeric vector field with the default EUCLIDEAN_HNSW (L2) similarity.
KnnFloatVectorField(String, float[], FieldType) - Constructor for class org.apache.lucene.document.KnnFloatVectorField
Creates a numeric vector field.
KnnFloatVectorField(String, float[], VectorSimilarityFunction) - Constructor for class org.apache.lucene.document.KnnFloatVectorField
Creates a numeric vector field.
KnnFloatVectorQuery - Class in org.apache.lucene.search
Uses KnnVectorsReader.search(String, float[], KnnCollector, Bits) to perform nearest neighbour search.
KnnFloatVectorQuery(String, float[], int) - Constructor for class org.apache.lucene.search.KnnFloatVectorQuery
Find the k nearest documents to the target vector according to the vectors in the given field.
KnnFloatVectorQuery(String, float[], int, Query) - Constructor for class org.apache.lucene.search.KnnFloatVectorQuery
Find the k nearest documents to the target vector according to the vectors in the given field.
KnnVectorField - Class in org.apache.lucene.document
Deprecated.
KnnVectorField(String, float[]) - Constructor for class org.apache.lucene.document.KnnVectorField
Deprecated.
Creates a numeric vector field with the default EUCLIDEAN_HNSW (L2) similarity.
KnnVectorField(String, float[], FieldType) - Constructor for class org.apache.lucene.document.KnnVectorField
Deprecated.
Creates a numeric vector field.
KnnVectorField(String, float[], VectorSimilarityFunction) - Constructor for class org.apache.lucene.document.KnnVectorField
Deprecated.
Creates a numeric vector field.
KnnVectorFieldExistsQuery - Class in org.apache.lucene.search
Deprecated.
Use FieldExistsQuery instead.
KnnVectorFieldExistsQuery(String) - Constructor for class org.apache.lucene.search.KnnVectorFieldExistsQuery
Deprecated.
Create a query that will match documents which have a value for the given field.
KnnVectorQuery - Class in org.apache.lucene.search
Deprecated.
KnnVectorQuery(String, float[], int) - Constructor for class org.apache.lucene.search.KnnVectorQuery
Deprecated.
 
KnnVectorQuery(String, float[], int, Query) - Constructor for class org.apache.lucene.search.KnnVectorQuery
Deprecated.
 
knnVectorsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes numeric vector fields
knnVectorsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
knnVectorsFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
KnnVectorsFormat - Class in org.apache.lucene.codecs
Encodes/decodes per-document vector and any associated indexing structures required to support nearest-neighbor search
KnnVectorsFormat(String) - Constructor for class org.apache.lucene.codecs.KnnVectorsFormat
Sole constructor
KnnVectorsReader - Class in org.apache.lucene.codecs
Reads vectors from an index.
KnnVectorsReader() - Constructor for class org.apache.lucene.codecs.KnnVectorsReader
Sole constructor
knnVectorsReaders - Variable in class org.apache.lucene.index.MergeState
Vector readers to merge
KnnVectorsWriter - Class in org.apache.lucene.codecs
Writes vectors to an index.
KnnVectorsWriter() - Constructor for class org.apache.lucene.codecs.KnnVectorsWriter
Sole constructor
KnnVectorsWriter.MergedVectorValues - Class in org.apache.lucene.codecs
View over multiple vector values supporting iterator-style access via DocIdMerger.

L

l2normalize(float[]) - Static method in class org.apache.lucene.util.VectorUtil
Modifies the argument to be unit length, dividing by its l2-norm.
l2normalize(float[], boolean) - Static method in class org.apache.lucene.util.VectorUtil
Modifies the argument to be unit length, dividing by its l2-norm.
label() - Method in class org.apache.lucene.util.fst.FST.Arc
 
lambda - Variable in class org.apache.lucene.search.similarities.IBSimilarity
The lambda (λw) parameter.
lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.Lambda
Computes the lambda parameter.
lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaDF
 
lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaTTF
 
Lambda - Class in org.apache.lucene.search.similarities
The lambda (λw) parameter in information-based models.
Lambda() - Constructor for class org.apache.lucene.search.similarities.Lambda
Sole constructor.
LambdaDF - Class in org.apache.lucene.search.similarities
Computes lambda as docFreq+1 / numberOfDocuments+1.
LambdaDF() - Constructor for class org.apache.lucene.search.similarities.LambdaDF
Sole constructor: parameter-free
LambdaTTF - Class in org.apache.lucene.search.similarities
Computes lambda as totalTermFreq+1 / numberOfDocuments+1.
LambdaTTF() - Constructor for class org.apache.lucene.search.similarities.LambdaTTF
Sole constructor: parameter-free
lastCommit - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
Most recently committed IndexCommit.
lastOrd - Variable in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
lastOrd - Variable in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
lastOrd - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
lastPosBlockOffset - Variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
file offset for the last position in the last block, if there are more than ForUtil.BLOCK_SIZE positions; otherwise -1
LATEST - Static variable in class org.apache.lucene.util.Version
WARNING: if you use this setting, and then upgrade to a newer release of Lucene, sizable changes may happen.
LatLonDocValuesField - Class in org.apache.lucene.document
An per-document location field.
LatLonDocValuesField(String, double, double) - Constructor for class org.apache.lucene.document.LatLonDocValuesField
Creates a new LatLonDocValuesField with the specified latitude and longitude
LatLonGeometry - Class in org.apache.lucene.geo
Lat/Lon Geometry object.
LatLonGeometry() - Constructor for class org.apache.lucene.geo.LatLonGeometry
 
LatLonPoint - Class in org.apache.lucene.document
An indexed location field.
LatLonPoint(String, double, double) - Constructor for class org.apache.lucene.document.LatLonPoint
Creates a new LatLonPoint with the specified latitude and longitude
LatLonShape - Class in org.apache.lucene.document
An geo shape utility class for indexing and searching gis geometries whose vertices are latitude, longitude values (in decimal degrees).
LatLonShapeDocValues - Class in org.apache.lucene.document
A concrete implementation of ShapeDocValues for storing binary doc value representation of LatLonShape geometries in a LatLonShapeDocValuesField
LatLonShapeDocValues(List<ShapeField.DecodedTriangle>) - Constructor for class org.apache.lucene.document.LatLonShapeDocValues
protected ctor for instantiating a lat lon doc value based on a tessellation
LatLonShapeDocValues(BytesRef) - Constructor for class org.apache.lucene.document.LatLonShapeDocValues
protected ctor for instantiating a lat lon doc value based on an already retrieved binary format
LatLonShapeDocValuesField - Class in org.apache.lucene.document
Concrete implementation of a ShapeDocValuesField for geographic geometries.
LatLonShapeDocValuesField(String, List<ShapeField.DecodedTriangle>) - Constructor for class org.apache.lucene.document.LatLonShapeDocValuesField
constructs a LatLonShapeDocValueField from a pre-tessellated geometry
LatLonShapeDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.LatLonShapeDocValuesField
Creates a LatLonShapeDocValueField from a given serialized value
LeafCollector - Interface in org.apache.lucene.search
Collector decouples the score from the collected doc: the score computation is skipped entirely if it's not needed.
leafContexts - Variable in class org.apache.lucene.search.IndexSearcher
 
LeafFieldComparator - Interface in org.apache.lucene.search
Expert: comparator that gets instantiated on each leaf from a top-level FieldComparator instance.
LeafMetaData - Class in org.apache.lucene.index
Provides read-only metadata about a leaf.
LeafMetaData(int, Version, Sort, boolean) - Constructor for class org.apache.lucene.index.LeafMetaData
Expert: Sole constructor.
LeafReader - Class in org.apache.lucene.index
LeafReader is an abstract class, providing an interface for accessing an index.
LeafReader() - Constructor for class org.apache.lucene.index.LeafReader
Sole constructor.
LeafReaderContext - Class in org.apache.lucene.index
LeafSimScorer - Class in org.apache.lucene.search
LeafSimScorer(Similarity.SimScorer, LeafReader, String, boolean) - Constructor for class org.apache.lucene.search.LeafSimScorer
Sole constructor: Score documents of reader with scorer.
LeafSlice(List<LeafReaderContext>) - Constructor for class org.apache.lucene.search.IndexSearcher.LeafSlice
 
leafSorter - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
The comparator for sorting leaf readers.
leaves - Variable in class org.apache.lucene.search.IndexSearcher.LeafSlice
The leaves that make up this slice.
leaves() - Method in class org.apache.lucene.index.CompositeReaderContext
 
leaves() - Method in class org.apache.lucene.index.IndexReader
Returns the reader's leaves, or itself if this reader is atomic.
leaves() - Method in class org.apache.lucene.index.IndexReaderContext
Returns the context's leaves if this context is a top-level context.
leaves() - Method in class org.apache.lucene.index.LeafReaderContext
 
length - Variable in class org.apache.lucene.index.ReaderSlice
Number of documents in this slice.
length - Variable in class org.apache.lucene.store.ByteBufferIndexInput
 
length - Variable in class org.apache.lucene.util.BytesRef
Length of used bytes.
length - Variable in class org.apache.lucene.util.CharsRef
Length of used characters.
length - Variable in class org.apache.lucene.util.IntsRef
Length of used ints.
length - Variable in class org.apache.lucene.util.LongsRef
Length of used longs.
length() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
length() - Method in class org.apache.lucene.index.MultiBits
 
length() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
length() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
length() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
length() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
length() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
length() - Method in class org.apache.lucene.store.FilterIndexInput
 
length() - Method in class org.apache.lucene.store.IndexInput
The number of bytes in the file.
length() - Method in interface org.apache.lucene.store.RandomAccessInput
The number of bytes in the file.
length() - Method in interface org.apache.lucene.util.Bits
Returns the number of bits in this set
length() - Method in class org.apache.lucene.util.Bits.MatchAllBits
 
length() - Method in class org.apache.lucene.util.Bits.MatchNoBits
 
length() - Method in class org.apache.lucene.util.BytesRefBuilder
Return the number of bytes in this buffer.
length() - Method in class org.apache.lucene.util.CharsRef
 
length() - Method in class org.apache.lucene.util.CharsRefBuilder
Return the number of chars in this buffer.
length() - Method in class org.apache.lucene.util.FixedBitSet
 
length() - Method in class org.apache.lucene.util.IntsRefBuilder
Return the number of ints in this buffer.
length() - Method in class org.apache.lucene.util.LongBitSet
Returns the number of bits stored in this bitset.
length() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
LENGTH_THRESHOLD - Static variable in class org.apache.lucene.util.MSBRadixSorter
 
lengthNorm(int) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
Implemented as 1/sqrt(length).
lengthNorm(int) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Compute an index-time normalization value for this field instance.
lessThan(FieldValueHitQueue.Entry, FieldValueHitQueue.Entry) - Method in class org.apache.lucene.search.FieldValueHitQueue
 
lessThan(ScoreDoc, ScoreDoc) - Method in class org.apache.lucene.search.HitQueue
 
lessThan(T, T) - Method in class org.apache.lucene.util.PriorityQueue
Determines the ordering of objects in this priority queue.
LEVEL_LOG_SPAN - Static variable in class org.apache.lucene.index.LogMergePolicy
Defines the allowed range of log(size) for each level.
LEVEL_THRESHOLD - Static variable in class org.apache.lucene.util.MSBRadixSorter
 
LevenshteinAutomata - Class in org.apache.lucene.util.automaton
Class to construct DFAs that match a word within some edit distance.
LevenshteinAutomata(int[], int, boolean) - Constructor for class org.apache.lucene.util.automaton.LevenshteinAutomata
Expert: specify a custom maximum possible symbol (alphaMax); default is Character.MAX_CODE_POINT.
LevenshteinAutomata(String, boolean) - Constructor for class org.apache.lucene.util.automaton.LevenshteinAutomata
Create a new LevenshteinAutomata for some input String.
LIMIT_MAX_BITS_PER_BLOCK - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
Largest maxBitsPerBlock allowed
LIMIT_MIN_BITS_PER_BLOCK - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
Smallest minBitsPerBlock allowed
LimitedFiniteStringsIterator - Class in org.apache.lucene.util.automaton
FiniteStringsIterator which limits the number of iterated accepted strings.
LimitedFiniteStringsIterator(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
Constructor.
Line - Class in org.apache.lucene.geo
Represents a line on the earth's surface.
Line(double[], double[]) - Constructor for class org.apache.lucene.geo.Line
Creates a new Line from the supplied latitude/longitude array.
LINE - org.apache.lucene.document.ShapeField.DecodedTriangle.TYPE
first and third coordinates are equal
lineCount - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
number of lines of data read
lineCrossesLine(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
uses orient method to compute whether two line segments cross
lineCrossesLineWithBoundary(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
uses orient method to compute whether two line segments cross; boundaries included - returning true for lines that terminate on each other.
lineOverlapLine(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
uses orient method to compute whether two line overlap each other
linesIntersect(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.Tessellator
Determines whether two line segments intersect.
LINESTRING - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
LINKED_HASHTABLE_RAM_BYTES_PER_ENTRY - Static variable in class org.apache.lucene.util.RamUsageEstimator
Approximate memory usage that we assign to a LinkedHashMap entry.
LINUX - Static variable in class org.apache.lucene.util.Constants
True iff running on Linux.
listAll() - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
listAll() - Method in class org.apache.lucene.store.Directory
Returns names of all files stored in this directory.
listAll() - Method in class org.apache.lucene.store.FileSwitchDirectory
 
listAll() - Method in class org.apache.lucene.store.FilterDirectory
 
listAll() - Method in class org.apache.lucene.store.FSDirectory
 
listAll() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
listAll(Path) - Static method in class org.apache.lucene.store.FSDirectory
Lists all files (including subdirectories) in the directory.
listCachedFiles() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
listCommits(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
Returns all commit points that exist in the Directory.
liveDocs - Variable in class org.apache.lucene.index.MergeState
Live docs for each reader
liveDocs - Variable in class org.apache.lucene.index.SegmentWriteState
FixedBitSet recording live documents; this is only set if there is one or more deleted documents.
liveDocsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes live docs
liveDocsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
LiveDocsFormat - Class in org.apache.lucene.codecs
Format for live/deleted documents
LiveDocsFormat() - Constructor for class org.apache.lucene.codecs.LiveDocsFormat
Sole constructor.
liveDocStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of livedocs
LiveFieldValues<S,​T> - Class in org.apache.lucene.search
Tracks live field values across NRT reader reopens.
LiveFieldValues(ReferenceManager<S>, T) - Constructor for class org.apache.lucene.search.LiveFieldValues
The missingValue must be non-null.
LiveIndexWriterConfig - Class in org.apache.lucene.index
Holds all the configuration used by IndexWriter with few setters for settings that can be changed on an IndexWriter instance "live".
LMDirichletSimilarity - Class in org.apache.lucene.search.similarities
Bayesian smoothing using Dirichlet priors.
LMDirichletSimilarity() - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
Instantiates the similarity with the default μ value of 2000.
LMDirichletSimilarity(float) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
Instantiates the similarity with the provided μ parameter.
LMDirichletSimilarity(LMSimilarity.CollectionModel) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
Instantiates the similarity with the default μ value of 2000.
LMDirichletSimilarity(LMSimilarity.CollectionModel, float) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
Instantiates the similarity with the provided μ parameter.
LMJelinekMercerSimilarity - Class in org.apache.lucene.search.similarities
Language model based on the Jelinek-Mercer smoothing method.
LMJelinekMercerSimilarity(float) - Constructor for class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
Instantiates with the specified λ parameter.
LMJelinekMercerSimilarity(LMSimilarity.CollectionModel, float) - Constructor for class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
Instantiates with the specified collectionModel and λ parameter.
LMSimilarity - Class in org.apache.lucene.search.similarities
Abstract superclass for language modeling Similarities.
LMSimilarity() - Constructor for class org.apache.lucene.search.similarities.LMSimilarity
Creates a new instance with the default collection language model.
LMSimilarity(LMSimilarity.CollectionModel) - Constructor for class org.apache.lucene.search.similarities.LMSimilarity
Creates a new instance with the specified collection language model.
LMSimilarity.CollectionModel - Interface in org.apache.lucene.search.similarities
A strategy for computing the collection language model.
LMSimilarity.DefaultCollectionModel - Class in org.apache.lucene.search.similarities
Models p(w|C) as the number of occurrences of the term in the collection, divided by the total number of tokens + 1.
LMSimilarity.LMStats - Class in org.apache.lucene.search.similarities
Stores the collection distribution of the current term.
LMStats(String, double) - Constructor for class org.apache.lucene.search.similarities.LMSimilarity.LMStats
Creates LMStats for the provided field and query-time boost
ln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
compute the document length component
ln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
compute the document length component
ln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
compute the document length component
ln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
compute the document length component
ln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
compute the document length component
ln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
compute the document length component
ln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
compute the document length component
lnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
Explain the score of the document length component for a single document
lnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
 
lnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
 
lnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
 
lnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
 
lnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
 
lnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
 
load - Variable in class org.apache.lucene.store.IOContext
This flag is used for files that are a small fraction of the total index size and are expected to be heavily accessed in random-access fashion.
load(OrdToDocDISIReaderConfiguration, int, int, long, long, IndexInput) - Static method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
load(OrdToDocDISIReaderConfiguration, VectorEncoding, int, long, long, IndexInput) - Static method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
load(OrdToDocDISIReaderConfiguration, VectorEncoding, int, long, long, IndexInput) - Static method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
LOAD - Static variable in class org.apache.lucene.store.IOContext
 
loadDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
Loads a specific Directory implementation
loadFactor - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
The load factor for IntIntHashMap.keys.
loadFSDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
Loads a specific FSDirectory implementation
loadMeta(IndexInput, long, int) - Static method in class org.apache.lucene.util.packed.DirectMonotonicReader
Load metadata from the given IndexInput.
loadStopwordSet(boolean, Class<? extends Analyzer>, String, String) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
Deprecated, for removal: This API element is subject to removal in a future version.
Class.getResourceAsStream(String) is caller sensitive and cannot load resources across Java Modules. Please call the getResourceAsStream() and WordlistLoader.getWordSet(Reader, String, CharArraySet) or other methods directly.
loadStopwordSet(Reader) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
Creates a CharArraySet from a file.
loadStopwordSet(Path) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
Creates a CharArraySet from a path.
Lock - Class in org.apache.lucene.store
An interprocess mutex lock.
Lock() - Constructor for class org.apache.lucene.store.Lock
 
LOCK_OBTAIN_WAIT_FOREVER - Static variable in class org.apache.lucene.store.SleepingLockWrapper
Pass this lockWaitTimeout to try forever to obtain the lock.
lockFactory - Variable in class org.apache.lucene.store.BaseDirectory
Holds the LockFactory instance (implements locking for this Directory instance).
LockFactory - Class in org.apache.lucene.store
Base class for Locking implementation.
LockFactory() - Constructor for class org.apache.lucene.store.LockFactory
 
LockObtainFailedException - Exception in org.apache.lucene.store
This exception is thrown when the write.lock could not be acquired.
LockObtainFailedException(String) - Constructor for exception org.apache.lucene.store.LockObtainFailedException
 
LockObtainFailedException(String, Throwable) - Constructor for exception org.apache.lucene.store.LockObtainFailedException
 
LockReleaseFailedException - Exception in org.apache.lucene.store
This exception is thrown when the write.lock could not be released.
LockReleaseFailedException(String) - Constructor for exception org.apache.lucene.store.LockReleaseFailedException
 
LockReleaseFailedException(String, Throwable) - Constructor for exception org.apache.lucene.store.LockReleaseFailedException
 
LockStressTest - Class in org.apache.lucene.store
Simple standalone tool that forever acquires and releases a lock using a specific LockFactory.
LockStressTest() - Constructor for class org.apache.lucene.store.LockStressTest
 
LockValidatingDirectoryWrapper - Class in org.apache.lucene.store
This class makes a best-effort check that a provided Lock is valid before any destructive filesystem operation.
LockValidatingDirectoryWrapper(Directory, Lock) - Constructor for class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
LockVerifyServer - Class in org.apache.lucene.store
Simple standalone server that must be running when you use VerifyingLockFactory.
LockVerifyServer() - Constructor for class org.apache.lucene.store.LockVerifyServer
 
log(double, double) - Static method in class org.apache.lucene.util.MathUtil
Calculates logarithm in a given base with doubles.
log(long, int) - Static method in class org.apache.lucene.util.MathUtil
Returns x <= 0 ? 0 : Math.floor(Math.log(x) / Math.log(base))
log2(double) - Static method in class org.apache.lucene.search.similarities.SimilarityBase
Returns the base two logarithm of x.
LogByteSizeMergePolicy - Class in org.apache.lucene.index
This is a LogMergePolicy that measures size of a segment as the total byte size of the segment's files.
LogByteSizeMergePolicy() - Constructor for class org.apache.lucene.index.LogByteSizeMergePolicy
Sole constructor, setting all settings to their defaults.
LogDocMergePolicy - Class in org.apache.lucene.index
This is a LogMergePolicy that measures size of a segment as the number of documents (not taking deletions into account).
LogDocMergePolicy() - Constructor for class org.apache.lucene.index.LogDocMergePolicy
Sole constructor, setting all settings to their defaults.
LogMergePolicy - Class in org.apache.lucene.index
This class implements a MergePolicy that tries to merge segments into levels of exponentially increasing size, where each level has fewer segments than the value of the merge factor.
LogMergePolicy() - Constructor for class org.apache.lucene.index.LogMergePolicy
Sole constructor.
LONG - org.apache.lucene.document.StoredValue.Type
Type of long values.
LONG - org.apache.lucene.search.SortField.Type
Sort using term values as encoded Longs.
LongBitSet - Class in org.apache.lucene.util
BitSet of fixed length (numBits), backed by accessible (LongBitSet.getBits()) long[], accessed with a long index.
LongBitSet(long) - Constructor for class org.apache.lucene.util.LongBitSet
Creates a new LongBitSet.
LongBitSet(long[], long) - Constructor for class org.apache.lucene.util.LongBitSet
Creates a new LongBitSet using the provided long[] array as backing store.
longBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
The minimum number of long blocks to encode in a single iteration, when using long encoding.
longBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
The minimum number of long blocks to encode in a single iteration, when using long encoding.
LongComparator - Class in org.apache.lucene.search.comparators
Comparator based on Long.compare(long, long) for numHits.
LongComparator(int, String, Long, boolean, Pruning) - Constructor for class org.apache.lucene.search.comparators.LongComparator
 
LongComparator.LongLeafComparator - Class in org.apache.lucene.search.comparators
Leaf comparator for LongComparator that provides skipping functionality
longCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Computes how many long blocks are needed to store values values of size bitsPerValue.
longField(FieldInfo, long) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
longField(FieldInfo, long) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
longField(FieldInfo, long) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a long numeric field.
LongField - Class in org.apache.lucene.document
Field that stores a per-document long value for scoring, sorting or value retrieval and index the field for fast range filters.
LongField(String, long) - Constructor for class org.apache.lucene.document.LongField
LongField(String, long, Field.Store) - Constructor for class org.apache.lucene.document.LongField
Creates a new LongField, indexing the provided point, storing it as a DocValue, and optionally storing it as a stored field.
LongHeap - Class in org.apache.lucene.util
A min heap that stores longs; a primitive priority queue that like all priority queues maintains a partial ordering of its elements such that the least element can always be found in constant time.
LongHeap(int) - Constructor for class org.apache.lucene.util.LongHeap
Create an empty priority queue of the configured initial size.
longHex(long) - Static method in class org.apache.lucene.util.ToStringUtils
 
LongLeafComparator(LeafReaderContext) - Constructor for class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
LongPoint - Class in org.apache.lucene.document
An indexed long field for fast range filters.
LongPoint(String, long...) - Constructor for class org.apache.lucene.document.LongPoint
Creates a new LongPoint, indexing the provided N-dimensional long point.
LongRange - Class in org.apache.lucene.document
An indexed Long Range field.
LongRange(String, long[], long[]) - Constructor for class org.apache.lucene.document.LongRange
Create a new LongRange type, from min/max parallel arrays
LongRangeDocValuesField - Class in org.apache.lucene.document
DocValues field for LongRange.
LongRangeDocValuesField(String, long[], long[]) - Constructor for class org.apache.lucene.document.LongRangeDocValuesField
Sole constructor.
longs - Variable in class org.apache.lucene.util.LongsRef
The contents of the LongsRef.
longsEquals(LongsRef) - Method in class org.apache.lucene.util.LongsRef
 
LongSorter(String, Long, boolean, IndexSorter.NumericDocValuesProvider) - Constructor for class org.apache.lucene.index.IndexSorter.LongSorter
Creates a new LongSorter
LongsRef - Class in org.apache.lucene.util
Represents long[], as a slice (offset + length) into an existing long[].
LongsRef() - Constructor for class org.apache.lucene.util.LongsRef
Create a LongsRef with LongsRef.EMPTY_LONGS
LongsRef(int) - Constructor for class org.apache.lucene.util.LongsRef
Create a LongsRef pointing to a new array of size capacity.
LongsRef(long[], int, int) - Constructor for class org.apache.lucene.util.LongsRef
This instance will directly reference longs w/o making a copy.
longToInt4(long) - Static method in class org.apache.lucene.util.SmallFloat
Float-like encoding for positive longs that preserves ordering and 4 significant bits.
longToSortableBytes(long, byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
Encodes an long value such that unsigned byte order comparison is consistent with Long.compare(long, long)
longValue() - Method in class org.apache.lucene.index.FilterNumericDocValues
 
longValue() - Method in class org.apache.lucene.index.NumericDocValues
Returns the numeric value for the current document ID.
longValue() - Method in class org.apache.lucene.search.LongValues
Get the long value for the current document
longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
The number of values that can be stored in PackedInts.Decoder.longBlockCount() long blocks.
longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
The number of values that can be stored in PackedInts.Encoder.longBlockCount() long blocks.
LongValues - Class in org.apache.lucene.search
Per-segment, per-document long values, which can be calculated at search-time
LongValues - Class in org.apache.lucene.util
Abstraction over an array of longs.
LongValues() - Constructor for class org.apache.lucene.search.LongValues
 
LongValues() - Constructor for class org.apache.lucene.util.LongValues
 
LongValuesSource - Class in org.apache.lucene.search
Base class for producing LongValues
LongValuesSource() - Constructor for class org.apache.lucene.search.LongValuesSource
 
LongValuesSource.ConstantLongValuesSource - Class in org.apache.lucene.search
A ConstantLongValuesSource that always returns a constant value
lookup(String) - Method in class org.apache.lucene.util.NamedSPILoader
 
lookupClass(String) - Method in class org.apache.lucene.analysis.AnalysisSPILoader
 
lookupClass(String) - Static method in class org.apache.lucene.analysis.CharFilterFactory
looks up a charfilter class by name from context classpath
lookupClass(String) - Static method in class org.apache.lucene.analysis.TokenFilterFactory
looks up a tokenfilter class by name from context classpath
lookupClass(String) - Static method in class org.apache.lucene.analysis.TokenizerFactory
looks up a tokenizer class by name from context classpath
lookupFromSearcher(S, String) - Method in class org.apache.lucene.search.LiveFieldValues
This is called when the id/value was already flushed and opened in an NRT IndexSearcher.
lookupOrd(int) - Method in class org.apache.lucene.index.FilterSortedDocValues
 
lookupOrd(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
lookupOrd(int) - Method in class org.apache.lucene.index.SortedDocValues
Retrieves the value for the specified ordinal.
lookupOrd(long) - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
lookupOrd(long) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
lookupOrd(long) - Method in class org.apache.lucene.index.SortedSetDocValues
Retrieves the value for the specified ordinal.
lookupSPIName(Class<? extends AbstractAnalysisFactory>) - Static method in class org.apache.lucene.analysis.AnalysisSPILoader
Looks up SPI name (static "NAME" field) with appropriate modifiers.
lookupTerm(BytesRef) - Method in class org.apache.lucene.index.FilterSortedDocValues
 
lookupTerm(BytesRef) - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedDocValues
If key exists, returns its ordinal, else returns -insertionPoint-1, like Arrays.binarySearch.
lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedSetDocValues
If key exists, returns its ordinal, else returns -insertionPoint-1, like Arrays.binarySearch.
LowercaseAsciiCompression - Class in org.apache.lucene.util.compress
Utility class that can efficiently compress arrays that mostly contain characters in the [0x1F,0x3F) or [0x5F,0x7F) ranges, which notably include all digits, lowercase characters, '.', '-' and '_'.
LowerCaseFilter - Class in org.apache.lucene.analysis
Normalizes token text to lower case.
LowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.LowerCaseFilter
Create a new LowerCaseFilter, that normalizes token text to lower case.
LPAREN - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
 
LRUQueryCache - Class in org.apache.lucene.search
A QueryCache that evicts queries using a LRU (least-recently-used) eviction policy in order to remain under a given maximum size and number of bytes used.
LRUQueryCache(int, long) - Constructor for class org.apache.lucene.search.LRUQueryCache
Create a new instance that will cache at most maxSize queries with at most maxRamBytesUsed bytes of memory.
LRUQueryCache(int, long, Predicate<LeafReaderContext>, float) - Constructor for class org.apache.lucene.search.LRUQueryCache
Expert: Create a new instance that will cache at most maxSize queries with at most maxRamBytesUsed bytes of memory, only on leaves that satisfy leavesToCache.
LRUQueryCache.CacheAndCount - Class in org.apache.lucene.search
Cache of doc ids with a count.
LSBRadixSorter - Class in org.apache.lucene.util
A LSB Radix sorter for unsigned int values.
LSBRadixSorter() - Constructor for class org.apache.lucene.util.LSBRadixSorter
 
LUCENE_8_0_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.0.0) Use latest
LUCENE_8_1_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_1_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_10_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_10_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_11_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(8.11.1) Use latest
LUCENE_8_11_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_11_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_11_3 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_12_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_2_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_3_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_3_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_4_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_4_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_5_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_5_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_5_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_6_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_6_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_6_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_6_3 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_7_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_8_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_8_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_8_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_8_9_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_9_0_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.1.0) Use latest
LUCENE_9_1_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.2.0) Use latest
LUCENE_9_10_0 - Static variable in class org.apache.lucene.util.Version
Match settings and bugs in Lucene's 9.10.0 release.
LUCENE_9_2_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.3.0) Use latest
LUCENE_9_3_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.4.0) Use latest
LUCENE_9_4_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.5.0) Use latest
LUCENE_9_4_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_9_4_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
Use latest
LUCENE_9_5_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.6.0) Use latest
LUCENE_9_6_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.7.0) Use latest
LUCENE_9_7_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.8.0) Use latest
LUCENE_9_8_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.9.0) Use latest
LUCENE_9_9_0 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.9.1) Use latest
LUCENE_9_9_1 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.9.2) Use latest
LUCENE_9_9_2 - Static variable in class org.apache.lucene.util.Version
Deprecated.
(9.10.0) Use latest
LUCENE_CURRENT - Static variable in class org.apache.lucene.util.Version
Deprecated.
LUCENE_MATCH_VERSION_PARAM - Static variable in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
Lucene90BlockTreeTermsReader - Class in org.apache.lucene.codecs.lucene90.blocktree
A block-based terms index and dictionary that assigns terms to variable length blocks according to how they share prefixes.
Lucene90BlockTreeTermsReader(PostingsReaderBase, SegmentReadState) - Constructor for class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
Sole constructor.
Lucene90BlockTreeTermsWriter - Class in org.apache.lucene.codecs.lucene90.blocktree
Block-based terms index and dictionary writer.
Lucene90BlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int) - Constructor for class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsWriter
Create a new writer.
Lucene90BlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int, int) - Constructor for class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsWriter
Expert constructor that allows configuring the version, used for bw tests.
Lucene90CompoundFormat - Class in org.apache.lucene.codecs.lucene90
Lucene 9.0 compound file format
Lucene90CompoundFormat() - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90CompoundFormat
Sole constructor.
Lucene90CompressingStoredFieldsFormat - Class in org.apache.lucene.codecs.lucene90.compressing
A StoredFieldsFormat that compresses documents in chunks in order to improve the compression ratio.
Lucene90CompressingStoredFieldsFormat(String, String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsFormat
Lucene90CompressingStoredFieldsFormat(String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsFormat
Create a new Lucene90CompressingStoredFieldsFormat with an empty segment suffix.
Lucene90CompressingStoredFieldsReader - Class in org.apache.lucene.codecs.lucene90.compressing
Lucene90CompressingStoredFieldsReader(Directory, SegmentInfo, String, FieldInfos, IOContext, String, CompressionMode) - Constructor for class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsReader
Sole constructor.
Lucene90CompressingStoredFieldsWriter - Class in org.apache.lucene.codecs.lucene90.compressing
Lucene90CompressingTermVectorsFormat - Class in org.apache.lucene.codecs.lucene90.compressing
A TermVectorsFormat that compresses chunks of documents together in order to improve the compression ratio.
Lucene90CompressingTermVectorsFormat(String, String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsFormat
Lucene90CompressingTermVectorsReader - Class in org.apache.lucene.codecs.lucene90.compressing
Lucene90CompressingTermVectorsReader(Directory, SegmentInfo, String, FieldInfos, IOContext, String, CompressionMode) - Constructor for class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsReader
Sole constructor.
Lucene90CompressingTermVectorsWriter - Class in org.apache.lucene.codecs.lucene90.compressing
Lucene90DocValuesFormat - Class in org.apache.lucene.codecs.lucene90
Lucene 9.0 DocValues format.
Lucene90DocValuesFormat() - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90DocValuesFormat
Default constructor.
Lucene90LiveDocsFormat - Class in org.apache.lucene.codecs.lucene90
Lucene 9.0 live docs format
Lucene90LiveDocsFormat() - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90LiveDocsFormat
Sole constructor.
Lucene90NormsFormat - Class in org.apache.lucene.codecs.lucene90
Lucene 9.0 Score normalization format.
Lucene90NormsFormat() - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90NormsFormat
Sole Constructor
Lucene90PointsFormat - Class in org.apache.lucene.codecs.lucene90
Lucene 9.0 point format, which encodes dimensional values in a block KD-tree structure for fast 1D range and N dimensional shape intersection filtering.
Lucene90PointsFormat() - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90PointsFormat
Sole constructor
Lucene90PointsReader - Class in org.apache.lucene.codecs.lucene90
Reads point values previously written with Lucene90PointsWriter
Lucene90PointsReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90PointsReader
Sole constructor
Lucene90PointsWriter - Class in org.apache.lucene.codecs.lucene90
Writes dimensional values
Lucene90PointsWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
Uses the defaults values for maxPointsInLeafNode (512) and maxMBSortInHeap (16.0)
Lucene90PointsWriter(SegmentWriteState, int, double) - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
Full constructor
Lucene90StoredFieldsFormat - Class in org.apache.lucene.codecs.lucene90
Lucene 9.0 stored fields format.
Lucene90StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat
Stored fields format with default options
Lucene90StoredFieldsFormat(Lucene90StoredFieldsFormat.Mode) - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat
Stored fields format with specified mode
Lucene90StoredFieldsFormat.Mode - Enum in org.apache.lucene.codecs.lucene90
Configuration option for stored fields.
Lucene90TermVectorsFormat - Class in org.apache.lucene.codecs.lucene90
Lucene90TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene90.Lucene90TermVectorsFormat
Sole constructor.
Lucene94FieldInfosFormat - Class in org.apache.lucene.codecs.lucene94
Lucene 9.0 Field Infos format.
Lucene94FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.lucene94.Lucene94FieldInfosFormat
Sole constructor.
Lucene99Codec - Class in org.apache.lucene.codecs.lucene99
Implements the Lucene 9.9 index format
Lucene99Codec() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99Codec
Instantiates a new codec.
Lucene99Codec(Lucene99Codec.Mode) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99Codec
Instantiates a new codec, specifying the stored fields compression mode to use.
Lucene99Codec.Mode - Enum in org.apache.lucene.codecs.lucene99
Configuration option for the codec.
Lucene99FlatVectorsFormat - Class in org.apache.lucene.codecs.lucene99
Lucene 9.9 flat vector format, which encodes numeric vector values
Lucene99FlatVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsFormat
Constructs a format
Lucene99FlatVectorsReader - Class in org.apache.lucene.codecs.lucene99
Reads vectors from the index segments.
Lucene99FlatVectorsReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
Lucene99FlatVectorsWriter - Class in org.apache.lucene.codecs.lucene99
Writes vector values to index segments.
Lucene99FlatVectorsWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
Lucene99HnswScalarQuantizedVectorsFormat - Class in org.apache.lucene.codecs.lucene99
Lucene 9.9 vector format, which encodes numeric vector values into an associated graph connecting the documents having values.
Lucene99HnswScalarQuantizedVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswScalarQuantizedVectorsFormat
Constructs a format using default graph construction parameters
Lucene99HnswScalarQuantizedVectorsFormat(int, int) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswScalarQuantizedVectorsFormat
Constructs a format using the given graph construction parameters.
Lucene99HnswScalarQuantizedVectorsFormat(int, int, int, Float, ExecutorService) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswScalarQuantizedVectorsFormat
Constructs a format using the given graph construction parameters and scalar quantization.
Lucene99HnswVectorsFormat - Class in org.apache.lucene.codecs.lucene99
Lucene 9.9 vector format, which encodes numeric vector values into an associated graph connecting the documents having values.
Lucene99HnswVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
Constructs a format using default graph construction parameters
Lucene99HnswVectorsFormat(int, int) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
Constructs a format using the given graph construction parameters.
Lucene99HnswVectorsFormat(int, int, int, ExecutorService) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
Constructs a format using the given graph construction parameters and scalar quantization.
Lucene99HnswVectorsReader - Class in org.apache.lucene.codecs.lucene99
Reads vectors from the index segments along with index data structures supporting KNN search.
Lucene99HnswVectorsReader(SegmentReadState, FlatVectorsReader) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
Lucene99HnswVectorsWriter - Class in org.apache.lucene.codecs.lucene99
Writes vector values and knn graphs to index segments.
Lucene99HnswVectorsWriter(SegmentWriteState, int, int, FlatVectorsWriter, int, TaskExecutor) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsWriter
 
Lucene99PostingsFormat - Class in org.apache.lucene.codecs.lucene99
Lucene 9.9 postings format, which encodes postings in packed integer blocks for fast decode.
Lucene99PostingsFormat() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
Creates Lucene99PostingsFormat with default settings.
Lucene99PostingsFormat(int, int) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
Creates Lucene99PostingsFormat with custom values for minBlockSize and maxBlockSize passed to block terms dictionary.
Lucene99PostingsFormat.IntBlockTermState - Class in org.apache.lucene.codecs.lucene99
Holds all state required for Lucene99PostingsReader to produce a PostingsEnum without re-seeking the terms dict.
Lucene99PostingsReader - Class in org.apache.lucene.codecs.lucene99
Concrete class that reads docId(maybe frq,pos,offset,payloads) list with postings format.
Lucene99PostingsReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
Sole constructor.
Lucene99PostingsWriter - Class in org.apache.lucene.codecs.lucene99
Concrete class that writes docId(maybe frq,pos,offset,payloads) list with postings format.
Lucene99PostingsWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
Creates a postings writer
Lucene99ScalarQuantizedVectorsFormat - Class in org.apache.lucene.codecs.lucene99
Format supporting vector quantization, storage, and retrieval
Lucene99ScalarQuantizedVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsFormat
Constructs a format using default graph construction parameters
Lucene99ScalarQuantizedVectorsFormat(Float) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsFormat
Constructs a format using the given graph construction parameters.
Lucene99ScalarQuantizedVectorsReader - Class in org.apache.lucene.codecs.lucene99
Reads Scalar Quantized vectors from the index segments along with index data structures.
Lucene99ScalarQuantizedVectorsReader(SegmentReadState, FlatVectorsReader) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
Lucene99ScalarQuantizedVectorsWriter - Class in org.apache.lucene.codecs.lucene99
Writes quantized vector values and metadata to index segments.
Lucene99ScalarQuantizedVectorsWriter(SegmentWriteState, Float, FlatVectorsWriter) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
Lucene99SegmentInfoFormat - Class in org.apache.lucene.codecs.lucene99
Lucene 9.9 Segment info format.
Lucene99SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99SegmentInfoFormat
Sole constructor.
Lucene99SkipReader - Class in org.apache.lucene.codecs.lucene99
Implements the skip list reader for block postings format that stores positions and payloads.
Lucene99SkipReader(IndexInput, int, boolean, boolean, boolean) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
Lucene99SkipWriter - Class in org.apache.lucene.codecs.lucene99
Write skip lists with multiple levels, and support skip within block ints.
Lucene99SkipWriter(int, int, int, IndexOutput, IndexOutput, IndexOutput) - Constructor for class org.apache.lucene.codecs.lucene99.Lucene99SkipWriter
 
luceneMatchVersion - Variable in class org.apache.lucene.analysis.AbstractAnalysisFactory
the luceneVersion arg
LZ4 - Class in org.apache.lucene.util.compress
LZ4 compression and decompression routines.
LZ4.FastCompressionHashTable - Class in org.apache.lucene.util.compress
Simple lossy LZ4.HashTable that only stores the last ocurrence for each hash on 2^14 bytes of memory.
LZ4.HighCompressionHashTable - Class in org.apache.lucene.util.compress
A higher-precision LZ4.HashTable.
LZ4WithPresetDictCompressionMode - Class in org.apache.lucene.codecs.lucene90
A compression mode that compromises on the compression ratio to provide fast compression and decompression.
LZ4WithPresetDictCompressionMode() - Constructor for class org.apache.lucene.codecs.lucene90.LZ4WithPresetDictCompressionMode
Sole constructor.

M

M - Variable in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
MAC_OS_X - Static variable in class org.apache.lucene.util.Constants
True iff running on Mac OS X
main(String[]) - Static method in class org.apache.lucene.index.CheckIndex
Command-line interface to check and exorcise corrupt segments from an index.
main(String[]) - Static method in class org.apache.lucene.index.IndexUpgrader
Main method to run {code IndexUpgrader} from the command-line.
main(String[]) - Static method in class org.apache.lucene.store.LockStressTest
 
main(String[]) - Static method in class org.apache.lucene.store.LockVerifyServer
 
major - Variable in class org.apache.lucene.util.Version
Major version, the difference between stable and trunk
makeAnyBinary() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts all binary terms.
makeAnyChar() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts any single codepoint.
makeAnyString() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts all strings.
makeBinary(BytesRef) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts the single given binary term.
makeBinaryInterval(BytesRef, boolean, BytesRef, boolean) - Static method in class org.apache.lucene.util.automaton.Automata
Creates a new deterministic, minimal automaton accepting all binary terms in the specified interval.
makeBinaryStringUnion(Iterable<BytesRef>) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic and minimal) automaton that accepts the union of the given collection of BytesRefs representing UTF-8 encoded strings.
makeBinaryStringUnion(BytesRefIterator) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic and minimal) automaton that accepts the union of the given iterator of BytesRefs representing UTF-8 encoded strings.
makeChar(int) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts a single codepoint of the given value.
makeCharRange(int, int) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts a single codepoint whose value is in the given interval (including both end points).
makeDecimalInterval(int, int, int) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new automaton that accepts strings representing decimal (base 10) non-negative integers in the given interval.
makeEmpty() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton with the empty language.
makeEmptyString() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts only the empty string.
makeNonEmptyBinary() - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts all binary terms except the empty string.
makeStopSet(String...) - Static method in class org.apache.lucene.analysis.StopFilter
Builds a Set from an array of stop words, appropriate for passing into the StopFilter constructor.
makeStopSet(String[], boolean) - Static method in class org.apache.lucene.analysis.StopFilter
Creates a stopword set from the given stopword array.
makeStopSet(List<?>) - Static method in class org.apache.lucene.analysis.StopFilter
Builds a Set from an array of stop words, appropriate for passing into the StopFilter constructor.
makeStopSet(List<?>, boolean) - Static method in class org.apache.lucene.analysis.StopFilter
Creates a stopword set from the given stopword list.
makeString(int[], int, int) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts the single given string from the specified unicode code points.
makeString(String) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic) automaton that accepts the single given string.
makeStringUnion(Iterable<BytesRef>) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic and minimal) automaton that accepts the union of the given collection of BytesRefs representing UTF-8 encoded strings.
makeStringUnion(BytesRefIterator) - Static method in class org.apache.lucene.util.automaton.Automata
Returns a new (deterministic and minimal) automaton that accepts the union of the given iterator of BytesRefs representing UTF-8 encoded strings.
MapOfSets<K,​V> - Class in org.apache.lucene.util
Helper class for keeping Lists of Objects associated with keys.
MapOfSets(Map<K, Set<V>>) - Constructor for class org.apache.lucene.util.MapOfSets
 
mappedDocID - Variable in class org.apache.lucene.index.DocIDMerger.Sub
Mapped doc ID
MappedMultiFields - Class in org.apache.lucene.index
A Fields implementation that merges multiple Fields into one, and maps around deleted documents.
MappedMultiFields(MergeState, MultiFields) - Constructor for class org.apache.lucene.index.MappedMultiFields
Create a new MappedMultiFields for merging, based on the supplied mergestate and merged view of terms.
mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
ordinal map mapping ords from values to global ord space
mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
ordinal map mapping ords from values to global ord space
markIncomplete() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
mask - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
Mask for slot scans in IntIntHashMap.keys.
match(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
Validation method to determine whether a docid should be in the result set.
match(Number, String, Collection<Explanation>) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a match.
match(Number, String, Explanation...) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a match.
MATCH_WITH_NO_TERMS - Static variable in class org.apache.lucene.search.MatchesUtils
Indicates a match with no term positions, for example on a Point or DocValues field, or a field indexed as docs and freqs only
MatchAllBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchAllBits
 
MatchAllDocsQuery - Class in org.apache.lucene.search
A query that matches all documents.
MatchAllDocsQuery() - Constructor for class org.apache.lucene.search.MatchAllDocsQuery
 
matchCost - Variable in class org.apache.lucene.search.DisiWrapper
 
matchCost() - Method in class org.apache.lucene.search.TwoPhaseIterator
An estimate of the expected cost to determine that a single document TwoPhaseIterator.matches().
matches() - Method in class org.apache.lucene.search.TwoPhaseIterator
Return whether the current doc ID that TwoPhaseIterator.approximation() is on matches.
matches(byte[], byte[], int, int, ArrayUtil.ByteArrayComparator) - Method in enum org.apache.lucene.document.RangeFieldQuery.QueryType
Compares every dim for 2 encoded ranges and returns true if all dims match.
matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
 
matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.FilterWeight
 
matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.PhraseWeight
 
matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.Weight
Returns Matches for a specific document, or null if the document does not match the parent query
Matches - Interface in org.apache.lucene.search
Reports the positions and optionally offsets of all matching terms in a query for a single document
matchesExtension(String, String) - Static method in class org.apache.lucene.index.IndexFileNames
Returns true if the given filename ends with the given extension.
MatchesIterator - Interface in org.apache.lucene.search
An iterator over match positions (and optionally offsets) for a single document and field
MatchesUtils - Class in org.apache.lucene.search
Contains static functions that aid the implementation of Matches and MatchesIterator interfaces.
matchingReaders - Variable in class org.apache.lucene.codecs.compressing.MatchingReaders
SegmentReaders that have identical field name/number mapping, so their stored fields and term vectors may be bulk merged.
MatchingReaders - Class in org.apache.lucene.codecs.compressing
Computes which segments have identical field name to number mappings, which allows stored fields and term vectors in this codec to be bulk-merged.
MatchingReaders(MergeState) - Constructor for class org.apache.lucene.codecs.compressing.MatchingReaders
 
MatchNoBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchNoBits
 
MatchNoDocsQuery - Class in org.apache.lucene.search
A query that matches no documents.
MatchNoDocsQuery() - Constructor for class org.apache.lucene.search.MatchNoDocsQuery
Default constructor
MatchNoDocsQuery(String) - Constructor for class org.apache.lucene.search.MatchNoDocsQuery
Provides a reason explaining why this query was used
MathUtil - Class in org.apache.lucene.util
Math static utility methods.
max - Variable in class org.apache.lucene.util.automaton.RegExp
Limits for repeatable type expressions
max - Variable in class org.apache.lucene.util.automaton.Transition
Maximum accepted label (inclusive).
MAX - org.apache.lucene.search.SortedNumericSelector.Type
Selects the maximum value in the set
MAX - org.apache.lucene.search.SortedSetSelector.Type
Selects the maximum value in the set
MAX_ARRAY_LENGTH - Static variable in class org.apache.lucene.util.ArrayUtil
Maximum length for an array (Integer.MAX_VALUE - RamUsageEstimator.NUM_BYTES_ARRAY_HEADER).
MAX_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.packed.DirectMonotonicWriter
 
MAX_DEPTH - Static variable in class org.apache.lucene.util.RamUsageEstimator
Recurse only into immediate descendants.
MAX_DIMENSIONS - Static variable in class org.apache.lucene.index.PointValues
Maximum number of dimensions
MAX_DIMS - Static variable in class org.apache.lucene.util.bkd.BKDConfig
Maximum number of index dimensions (2 * max index dimensions)
MAX_DISTANCE - Static variable in class org.apache.lucene.util.compress.LZ4
Window size: this is the maximum supported distance between two strings so that LZ4 can replace the second one by a reference to the first one.
MAX_DOCS - Static variable in class org.apache.lucene.index.IndexWriter
Hard limit on maximum number of documents that may be added to the index.
MAX_GRAPH_STACK_SIZE - Static variable in class org.apache.lucene.analysis.GraphTokenFilter
The maximum permitted number of routes through a graph
MAX_HASH_ARRAY_LENGTH - Static variable in class org.apache.lucene.util.hppc.IntIntHashMap
Maximum array size for hash containers (power-of-two and still allocable in Java, not a negative int).
MAX_INDEX_DIMENSIONS - Static variable in class org.apache.lucene.index.PointValues
Maximum number of index dimensions
MAX_INDEX_DIMS - Static variable in class org.apache.lucene.util.bkd.BKDConfig
Maximum number of index dimensions
MAX_LAT_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
Maximum latitude value.
MAX_LAT_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
max latitude value in radians
MAX_LENGTH_PER_GROUP - Static variable in class org.apache.lucene.util.GroupVIntUtil
 
MAX_LOAD_FACTOR - Static variable in class org.apache.lucene.util.hppc.IntIntHashMap
Maximum sane load factor (1 empty slot per 100).
MAX_LON_ENCODED - Static variable in class org.apache.lucene.geo.GeoEncodingUtils
 
MAX_LON_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
Maximum longitude value.
MAX_LON_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
max longitude value in radians
MAX_NUM_BITS - Static variable in class org.apache.lucene.util.LongBitSet
The maximum numBits supported.
MAX_NUM_BYTES - Static variable in class org.apache.lucene.index.PointValues
Maximum number of bytes for each dimension
MAX_POSITION - Static variable in class org.apache.lucene.index.IndexWriter
Maximum value of the token position in an indexed field.
MAX_RECURSION_LEVEL - Static variable in class org.apache.lucene.util.automaton.Operations
Maximum level of recursion allowed in recursive operations.
MAX_STORED_STRING_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
Maximum length string for a stored field.
MAX_STRING_UNION_TERM_LENGTH - Static variable in class org.apache.lucene.util.automaton.Automata
Automata.makeStringUnion(Iterable) limits terms of this max length to ensure the stack doesn't overflow while building, since our algorithm currently relies on recursion.
MAX_TEMPFILES - Static variable in class org.apache.lucene.util.OfflineSorter
Maximum number of temporary files before doing an intermediate merge.
MAX_TERM_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
Absolute hard maximum length for a term, in bytes once encoded as UTF8.
MAX_TERM_LENGTH - Static variable in class org.apache.lucene.util.automaton.DaciukMihovAutomatonBuilder
MAX_TOKEN_CACHE_SIZE - Static variable in class org.apache.lucene.analysis.GraphTokenFilter
The maximum permitted read-ahead in the token stream
MAX_TOKEN_LENGTH_LIMIT - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Absolute maximum sized token
MAX_UTF8_BYTES_PER_CHAR - Static variable in class org.apache.lucene.util.UnicodeUtil
Maximum number of UTF8 bytes per UTF16 character.
MAX_VAL_INCL - Static variable in class org.apache.lucene.geo.XYEncodingUtils
 
MAX_VALUE - Static variable in class org.apache.lucene.document.InetAddressPoint
The maximum value that an ip address can hold.
maxBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
maxBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
maxCFSSegmentSize - Variable in class org.apache.lucene.index.MergePolicy
If the size of the merged segment exceeds this value then it will not use compound file format.
maxDoc - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Document count (does not take deletions into account).
maxDoc - Variable in class org.apache.lucene.index.IndexWriter.DocStats
The total number of docs in this index, counting docs not yet flushed (still in the RAM buffer), and also counting deleted docs.
maxDoc() - Method in class org.apache.lucene.index.BaseCompositeReader
 
maxDoc() - Method in class org.apache.lucene.index.FilterCodecReader
 
maxDoc() - Method in class org.apache.lucene.index.FilterLeafReader
 
maxDoc() - Method in class org.apache.lucene.index.IndexReader
Returns one greater than the largest possible document number.
maxDoc() - Method in class org.apache.lucene.index.ParallelLeafReader
 
maxDoc() - Method in class org.apache.lucene.index.SegmentInfo
Returns number of documents in this segment (deletions are not taken into account).
maxDoc() - Method in class org.apache.lucene.index.SegmentReader
 
maxDoc() - Method in class org.apache.lucene.search.CollectionStatistics
The total number of documents, regardless of whether they all contain values for this field.
maxDocs - Variable in class org.apache.lucene.index.MergeState
Max docs per reader
maxFullFlushMergeSize() - Method in class org.apache.lucene.index.FilterMergePolicy
 
maxFullFlushMergeSize() - Method in class org.apache.lucene.index.LogMergePolicy
 
maxFullFlushMergeSize() - Method in class org.apache.lucene.index.MergePolicy
Return the maximum size of segments to be included in full-flush merges by the default implementation of MergePolicy.findFullFlushMerges(org.apache.lucene.index.MergeTrigger, org.apache.lucene.index.SegmentInfos, org.apache.lucene.index.MergePolicy.MergeContext).
maxFullFlushMergeSize() - Method in class org.apache.lucene.index.TieredMergePolicy
 
maxFullFlushMergeWaitMillis - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Amount of time to wait for merges returned by MergePolicy.findFullFlushMerges(...)
MAXIMUM_INNER_PRODUCT - org.apache.lucene.index.VectorSimilarityFunction
Maximum inner product.
MAXIMUM_SUPPORTED_DISTANCE - Static variable in class org.apache.lucene.util.automaton.LevenshteinAutomata
Maximum edit distance this class can generate an automaton for.
MaximumInnerProduct(float) - Constructor for class org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity.MaximumInnerProduct
 
maxLat - Variable in class org.apache.lucene.geo.Line
maximum latitude of this line's bounding box
maxLat - Variable in class org.apache.lucene.geo.Polygon
maximum latitude of this polygon's bounding box area
maxLat - Variable in class org.apache.lucene.geo.Rectangle
maximum latitude value (in degrees)
maxLength - Variable in class org.apache.lucene.util.MSBRadixSorter
 
maxLon - Variable in class org.apache.lucene.geo.Line
maximum longitude of this line's bounding box
maxLon - Variable in class org.apache.lucene.geo.Polygon
maximum longitude of this polygon's bounding box area
maxLon - Variable in class org.apache.lucene.geo.Rectangle
minimum latitude value (in degrees)
maxMergeDocs - Variable in class org.apache.lucene.index.LogMergePolicy
If a segment has more than this many documents then it will never be merged.
maxMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
If the size of a segment exceeds this value then it will never be merged.
maxMergeSizeForForcedMerge - Variable in class org.apache.lucene.index.LogMergePolicy
If the size of a segment exceeds this value then it will never be merged during IndexWriter.forceMerge(int).
maxNodeId() - Method in class org.apache.lucene.util.hnsw.HnswGraph
Returns max node id, inclusive, normally this value will be size - 1
maxNodeId() - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
When we initialize from another graph, the max node id is different from OnHeapHnswGraph.size(), because we will add nodes out of order, such that we need two method for each
MaxNonCompetitiveBoostAttribute - Interface in org.apache.lucene.search
MaxNonCompetitiveBoostAttributeImpl - Class in org.apache.lucene.search
Implementation class for MaxNonCompetitiveBoostAttribute.
MaxNonCompetitiveBoostAttributeImpl() - Constructor for class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
maxNumberOfSkipLevels - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
the maximum number of skip levels possible for this index
maxOrd() - Method in class org.apache.lucene.util.hnsw.RandomVectorScorer.AbstractRandomVectorScorer
 
maxOrd() - Method in interface org.apache.lucene.util.hnsw.RandomVectorScorer
 
maxPackedValue - Variable in class org.apache.lucene.util.bkd.BKDWriter
Maximum per-dim values, packed
maxPointsInLeafNode - Variable in class org.apache.lucene.util.bkd.BKDConfig
max points allowed on a Leaf block
MaxScoreCache - Class in org.apache.lucene.search
Compute maximum scores based on Impacts and keep them in a cache in order not to run expensive similarity score computations multiple times on the same data.
MaxScoreCache(ImpactsSource, Similarity.SimScorer) - Constructor for class org.apache.lucene.search.MaxScoreCache
Sole constructor.
maxSegmentName - Variable in class org.apache.lucene.index.CheckIndex.Status
The greatest segment name.
maxUTF8Length(int) - Static method in class org.apache.lucene.util.UnicodeUtil
Returns the maximum number of utf8 bytes required to encode a utf16 (e.g., java char[], String)
maxValue(int) - Static method in class org.apache.lucene.util.packed.PackedInts
Calculates the maximum unsigned long that can be expressed with the given number of bits.
maxX - Variable in class org.apache.lucene.geo.XYLine
maximum y of this line's bounding box
maxX - Variable in class org.apache.lucene.geo.XYPolygon
maximum x of this polygon's bounding box area
maxX - Variable in class org.apache.lucene.geo.XYRectangle
minimum y value
maxY - Variable in class org.apache.lucene.geo.XYLine
maximum y of this line's bounding box
maxY - Variable in class org.apache.lucene.geo.XYPolygon
maximum y of this polygon's bounding box area
maxY - Variable in class org.apache.lucene.geo.XYRectangle
maximum y value
maybeMerge() - Method in class org.apache.lucene.index.IndexWriter
Expert: asks the mergePolicy whether any merges are necessary now and if so, runs the requested merges and then iterate (test again if merges are needed) until no more merges are returned by the mergePolicy.
maybeRefresh() - Method in class org.apache.lucene.search.ReferenceManager
You must call this (or ReferenceManager.maybeRefreshBlocking()), periodically, if you want that ReferenceManager.acquire() will return refreshed instances.
maybeRefreshBlocking() - Method in class org.apache.lucene.search.ReferenceManager
You must call this (or ReferenceManager.maybeRefresh()), periodically, if you want that ReferenceManager.acquire() will return refreshed instances.
maybeStall(MergeScheduler.MergeSource) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
This is invoked by ConcurrentMergeScheduler.merge(org.apache.lucene.index.MergeScheduler.MergeSource, org.apache.lucene.index.MergeTrigger) to possibly stall the incoming thread when there are too many merges running or pending.
MB - Static variable in class org.apache.lucene.util.OfflineSorter
Convenience constant for megabytes
megabytes(long) - Static method in class org.apache.lucene.util.OfflineSorter.BufferSize
Creates a OfflineSorter.BufferSize in MB.
merge(int, int, TopDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Same as TopDocs.merge(int, TopDocs[]) but also ignores the top start top docs.
merge(int, int, TopDocs[], Comparator<ScoreDoc>) - Static method in class org.apache.lucene.search.TopDocs
Same as above, but accepts the passed in tie breaker
merge(int, TopDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Returns a new TopDocs, containing topN results across the provided TopDocs, sorting by score.
merge(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
merge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.IndexWriter
Merges the indicated segments, replacing them in the stack with a single segment.
merge(MergePolicy.OneMerge) - Method in interface org.apache.lucene.index.MergeScheduler.MergeSource
Merges the indicated segments, replacing them in the stack with a single segment.
merge(MergeScheduler.MergeSource, MergeTrigger) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
merge(MergeScheduler.MergeSource, MergeTrigger) - Method in class org.apache.lucene.index.MergeScheduler
Run the merges provided by MergeScheduler.MergeSource.getNextMerge().
merge(MergeScheduler.MergeSource, MergeTrigger) - Method in class org.apache.lucene.index.NoMergeScheduler
 
merge(MergeScheduler.MergeSource, MergeTrigger) - Method in class org.apache.lucene.index.SerialMergeScheduler
Just do the merges in sequence.
merge(MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges in the fields from the readers in mergeState.
merge(MergeState) - Method in class org.apache.lucene.codecs.KnnVectorsWriter
Merges the segment vectors for all fields.
merge(MergeState) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
merge(MergeState) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
merge(MergeState) - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
 
merge(MergeState) - Method in class org.apache.lucene.codecs.NormsConsumer
Merges in the fields from the readers in mergeState.
merge(MergeState) - Method in class org.apache.lucene.codecs.PointsWriter
Default merge implementation to merge incoming points readers by visiting all their points and adding to this writer
merge(MergeState) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Merges in the stored fields from the readers in mergeState.
merge(MergeState) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Merges in the term vectors from the readers in mergeState.
merge(MergeState, NormsProducer) - Method in class org.apache.lucene.codecs.FieldsConsumer
Merges in the fields from the readers in mergeState.
merge(DocIdSetIterator, InfoStream, int) - Method in interface org.apache.lucene.util.hnsw.HnswGraphMerger
Merge and produce the on heap graph
merge(DocIdSetIterator, InfoStream, int) - Method in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
merge(Sort, int, int, TopFieldDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Same as TopDocs.merge(Sort, int, TopFieldDocs[]) but also ignores the top start top docs.
merge(Sort, int, int, TopFieldDocs[], Comparator<ScoreDoc>) - Static method in class org.apache.lucene.search.TopDocs
Pass in a custom tie breaker for ordering results
merge(Sort, int, TopFieldDocs[]) - Static method in class org.apache.lucene.search.TopDocs
Returns a new TopFieldDocs, containing topN results across the provided TopFieldDocs, sorting by the specified Sort.
merge(IndexOutput, IndexOutput, IndexOutput, List<MergeState.DocMap>, List<PointValues>) - Method in class org.apache.lucene.util.bkd.BKDWriter
More efficient bulk-add for incoming PointValuess.
merge(T, T) - Method in class org.apache.lucene.util.fst.Outputs
 
MERGE - org.apache.lucene.store.IOContext.Context
 
MERGE_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
A buffer size for merges set to 4096.
MERGE_FINISHED - org.apache.lucene.index.MergeTrigger
Merge was triggered by a successfully finished merge.
MergeAbortedException() - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
MergeAbortedException(String) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
Create a MergePolicy.MergeAbortedException with a specified message.
mergeAndRecalculateQuantiles(MergeState, FieldInfo, float) - Static method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
Merges the quantiles of the segments and recalculates the quantiles if necessary.
mergeBinaryField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges the binary docvalues from MergeState.
mergeByteVectorValues(FieldInfo, MergeState) - Static method in class org.apache.lucene.codecs.KnnVectorsWriter.MergedVectorValues
Returns a merged view over all the segment's ByteVectorValues.
MergedIterator<T extends Comparable<T>> - Class in org.apache.lucene.util
Provides a merged sorted view from several sorted iterators.
MergedIterator(boolean, Iterator<T>...) - Constructor for class org.apache.lucene.util.MergedIterator
 
MergedIterator(Iterator<T>...) - Constructor for class org.apache.lucene.util.MergedIterator
 
MergeException(String) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
Create a MergeException.
MergeException(Throwable) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
Create a MergeException.
mergeFactor - Variable in class org.apache.lucene.index.LogMergePolicy
How many segments to merge at a time.
mergeFieldInfos - Variable in class org.apache.lucene.index.MergeState
FieldInfos of the newly merged segment.
mergeFinished(boolean, boolean) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Called by IndexWriter after the merge is done and all readers have been closed.
mergeFloatVectorValues(FieldInfo, MergeState) - Static method in class org.apache.lucene.codecs.KnnVectorsWriter.MergedVectorValues
Returns a merged view over all the segment's FloatVectorValues.
mergeInfo - Variable in class org.apache.lucene.store.IOContext
 
MergeInfo - Class in org.apache.lucene.store
A MergeInfo provides information required for a MERGE context.
MergeInfo(int, long, boolean, int) - Constructor for class org.apache.lucene.store.MergeInfo
Creates a new MergeInfo instance from the values required for a MERGE IOContext context.
mergeInit() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Called by IndexWriter after the merge started and from the thread that will be executing the merge.
mergeMaxNumSegments - Variable in class org.apache.lucene.store.MergeInfo
 
mergeNormsField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.NormsConsumer
Merges the norms from toMerge.
mergeNumericField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges the numeric docvalues from MergeState.
mergeOneField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.BufferingKnnVectorsWriter
 
mergeOneField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.FlatVectorsWriter
Write field for merging
mergeOneField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.KnnVectorsWriter
Write field for merging
mergeOneField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
mergeOneField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsWriter
 
mergeOneField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
mergeOneField(MergeState, FieldInfo) - Method in class org.apache.lucene.codecs.PointsWriter
Default naive merge implementation for one field: it just re-indexes all the values from the incoming segment.
mergeOneFieldToIndex(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.FlatVectorsWriter
Write the field for merging, providing a scorer over the newly merged flat vectors.
mergeOneFieldToIndex(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
mergeOneFieldToIndex(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
mergePolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
MergePolicy for selecting merges.
MergePolicy - Class in org.apache.lucene.index
Expert: a MergePolicy determines the sequence of primitive merge operations.
MergePolicy() - Constructor for class org.apache.lucene.index.MergePolicy
Creates a new merge policy instance.
MergePolicy(double, long) - Constructor for class org.apache.lucene.index.MergePolicy
Creates a new merge policy instance with default settings for noCFSRatio and maxCFSSegmentSize.
MergePolicy.MergeAbortedException - Exception in org.apache.lucene.index
Thrown when a merge was explicitly aborted because IndexWriter.abortMerges() was called.
MergePolicy.MergeContext - Interface in org.apache.lucene.index
This interface represents the current context of the merge selection process.
MergePolicy.MergeException - Exception in org.apache.lucene.index
Exception thrown if there are any problems while executing a merge.
MergePolicy.MergeSpecification - Class in org.apache.lucene.index
A MergeSpecification instance provides the information necessary to perform multiple merges.
MergePolicy.OneMerge - Class in org.apache.lucene.index
OneMerge provides the information necessary to perform an individual primitive merge operation, resulting in a single new segment.
MergePolicy.OneMergeProgress - Class in org.apache.lucene.index
Progress and state for an executing merge.
MergePolicy.OneMergeProgress.PauseReason - Enum in org.apache.lucene.index
Reason for pausing the merge thread.
MergeRateLimiter - Class in org.apache.lucene.index
This is the RateLimiter that IndexWriter assigns to each running merge, to give MergeSchedulers ionice like control.
MergeRateLimiter(MergePolicy.OneMergeProgress) - Constructor for class org.apache.lucene.index.MergeRateLimiter
Sole constructor.
mergeRounds - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
number of partition merges
merges - Variable in class org.apache.lucene.index.MergePolicy.MergeSpecification
The subset of segments to be included in the primitive merge.
mergeScheduler - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
MergeScheduler to use for running merges.
MergeScheduler - Class in org.apache.lucene.index
Expert: IndexWriter uses an instance implementing this interface to execute the merges selected by a MergePolicy.
MergeScheduler() - Constructor for class org.apache.lucene.index.MergeScheduler
Sole constructor.
MergeScheduler.MergeSource - Interface in org.apache.lucene.index
Provides access to new merges and executes the actual merge
MergeScore() - Constructor for class org.apache.lucene.index.TieredMergePolicy.MergeScore
Sole constructor.
mergeSortedField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges the sorted docvalues from toMerge.
mergeSortedNumericField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges the sorted docvalues from toMerge.
mergeSortedSetField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
Merges the sortedset docvalues from toMerge.
MergeSorter() - Constructor for class org.apache.lucene.util.StableMSBRadixSorter.MergeSorter
 
MergeSpecification() - Constructor for class org.apache.lucene.index.MergePolicy.MergeSpecification
Sole constructor.
MergeState - Class in org.apache.lucene.index
Holds common state used during segment merging.
MergeState.DocMap - Interface in org.apache.lucene.index
A map of doc IDs.
mergeSuccess(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.IndexWriter
Hook that's called when the specified merge is complete.
MergeThread(MergeScheduler.MergeSource, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
Sole constructor.
mergeThreadCount - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
How many ConcurrentMergeScheduler.MergeThreads have kicked off (this is use to name them).
mergeThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Returns the number of merge threads that are alive, ignoring the calling thread if it is a merge thread.
mergeThreads - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
List of currently active ConcurrentMergeScheduler.MergeThreads.
mergeTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
time spent merging sorted partitions (in milliseconds)
MergeTrigger - Enum in org.apache.lucene.index
MergeTrigger is passed to MergePolicy.findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) to indicate the event that triggered the merge.
MergeVisitor(MergeState, int) - Constructor for class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
Create new merge visitor.
message(String) - Method in class org.apache.lucene.index.MergeScheduler
Outputs the given message - this method assumes MergeScheduler.verbose() was called and returned true.
message(String, String) - Method in class org.apache.lucene.util.InfoStream
prints a message
message(String, String) - Method in class org.apache.lucene.util.JavaLoggingInfoStream
 
message(String, String) - Method in class org.apache.lucene.util.PrintStreamInfoStream
 
message(String, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
Print a debug message to MergePolicy.MergeContext's infoStream.
messageID - Variable in class org.apache.lucene.util.PrintStreamInfoStream
 
META_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
Extension of stored fields meta
META_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene90.Lucene90PointsFormat
Filename extension for the meta per field
metaOut - Variable in class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
Outputs used to write the BKD tree data files.
MIDDLE_MAX - org.apache.lucene.search.SortedSetSelector.Type
Selects the middle value in the set.
MIDDLE_MIN - org.apache.lucene.search.SortedSetSelector.Type
Selects the middle value in the set.
MILLISECOND - org.apache.lucene.document.DateTools.Resolution
Limit a date's resolution to millisecond granularity.
min - Variable in class org.apache.lucene.util.automaton.RegExp
Limits for repeatable type expressions
min - Variable in class org.apache.lucene.util.automaton.Transition
Minimum accepted label (inclusive).
MIN - org.apache.lucene.search.SortedNumericSelector.Type
Selects the minimum value in the set
MIN - org.apache.lucene.search.SortedSetSelector.Type
Selects the minimum value in the set
MIN_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.packed.DirectMonotonicWriter
 
MIN_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
Minimum buffer size allowed
MIN_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.util.OfflineSorter
Minimum recommended buffer size for sorting.
MIN_HASH_ARRAY_LENGTH - Static variable in class org.apache.lucene.util.hppc.IntIntHashMap
Minimum hash buffer size.
MIN_LAT_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
Minimum latitude value.
MIN_LAT_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
min latitude value in radians
MIN_LOAD_FACTOR - Static variable in class org.apache.lucene.util.hppc.IntIntHashMap
Minimal sane load factor (99 empty slots per 100).
MIN_LON_ENCODED - Static variable in class org.apache.lucene.geo.GeoEncodingUtils
 
MIN_LON_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
Minimum longitude value.
MIN_LON_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
min longitude value in radians
MIN_SUPPORTED_MAJOR - Static variable in class org.apache.lucene.util.Version
Constant for the minimal supported major version of an index.
MIN_VAL_INCL - Static variable in class org.apache.lucene.geo.XYEncodingUtils
 
MIN_VALUE - Static variable in class org.apache.lucene.document.InetAddressPoint
The minimum value that an ip address can hold.
minCompetitiveSimilarity() - Method in class org.apache.lucene.search.AbstractKnnCollector
 
minCompetitiveSimilarity() - Method in class org.apache.lucene.search.knn.MultiLeafTopKnnCollector
 
minCompetitiveSimilarity() - Method in interface org.apache.lucene.search.KnnCollector
This method is utilized during search to ensure only competitive results are explored.
minCompetitiveSimilarity() - Method in class org.apache.lucene.search.TopKnnCollector
 
minCompetitiveSimilarity() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
minCompetitiveSimilarity() - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
MinDocIterator - Class in org.apache.lucene.search.comparators
Docs iterator that starts iterating from a configurable minimum document
minFrequencyToCache(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
For a given filter, return how many times it should appear in the history before being cached.
MinimizationOperations - Class in org.apache.lucene.util.automaton
Operations for minimizing automata.
minimize(Automaton, int) - Static method in class org.apache.lucene.util.automaton.MinimizationOperations
Minimizes (and determinizes if not already deterministic) the given automaton using Hopcroft's algorithm.
minLat - Variable in class org.apache.lucene.geo.Line
minimum latitude of this line's bounding box
minLat - Variable in class org.apache.lucene.geo.Polygon
minimum latitude of this polygon's bounding box area
minLat - Variable in class org.apache.lucene.geo.Rectangle
maximum longitude value (in degrees)
minLon - Variable in class org.apache.lucene.geo.Line
minimum longitude of this line's bounding box
minLon - Variable in class org.apache.lucene.geo.Polygon
minimum longitude of this polygon's bounding box area
minLon - Variable in class org.apache.lucene.geo.Rectangle
minimum longitude value (in degrees)
minMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
Any segments whose size is smaller than this value will be candidates for full-flush merges and merged more aggressively.
minor - Variable in class org.apache.lucene.util.Version
Minor version, incremented within the stable branch
minPackedValue - Variable in class org.apache.lucene.util.bkd.BKDWriter
Minimum per-dim values, packed
minus(Automaton, Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns a (deterministic) automaton that accepts the intersection of the language of a1 and the complement of the language of a2.
MINUTE - org.apache.lucene.document.DateTools.Resolution
Limit a date's resolution to minute granularity.
minX - Variable in class org.apache.lucene.geo.XYLine
minimum x of this line's bounding box
minX - Variable in class org.apache.lucene.geo.XYPolygon
minimum x of this polygon's bounding box area
minX - Variable in class org.apache.lucene.geo.XYRectangle
minimum x value
minY - Variable in class org.apache.lucene.geo.XYLine
minimum y of this line's bounding box
minY - Variable in class org.apache.lucene.geo.XYPolygon
minimum y of this polygon's bounding box area
minY - Variable in class org.apache.lucene.geo.XYRectangle
maximum x value
missingSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
True if we were unable to locate and load the segments_N file.
missingValue - Variable in class org.apache.lucene.search.comparators.NumericComparator
 
missingValue - Variable in class org.apache.lucene.search.SortField
 
mix(byte) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix(char) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix(double) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix(float) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix(int) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix(long) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix(short) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix(Object) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mix32(int) - Static method in class org.apache.lucene.util.hppc.BitMixer
MH3's plain finalization step.
mix64(long) - Static method in class org.apache.lucene.util.hppc.BitMixer
Computes David Stafford variant 9 of 64bit mix function (MH3 finalization step, with different shifts and constants).
mixedBlockCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
The number of "internal" blocks (that have both terms and sub-blocks).
mixPhi(byte) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mixPhi(char) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mixPhi(double) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mixPhi(float) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mixPhi(int) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mixPhi(long) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mixPhi(short) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
mixPhi(Object) - Static method in class org.apache.lucene.util.hppc.BitMixer
 
MMapDirectory - Class in org.apache.lucene.store
File-based Directory implementation that uses mmap for reading, and FSDirectory.FSIndexOutput for writing.
MMapDirectory(Path) - Constructor for class org.apache.lucene.store.MMapDirectory
Create a new MMapDirectory for the named location and FSLockFactory.getDefault().
MMapDirectory(Path, int) - Constructor for class org.apache.lucene.store.MMapDirectory
Deprecated.
MMapDirectory(Path, long) - Constructor for class org.apache.lucene.store.MMapDirectory
Create a new MMapDirectory for the named location and FSLockFactory.getDefault().
MMapDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.MMapDirectory
Create a new MMapDirectory for the named location.
MMapDirectory(Path, LockFactory, int) - Constructor for class org.apache.lucene.store.MMapDirectory
Deprecated.
MMapDirectory(Path, LockFactory, long) - Constructor for class org.apache.lucene.store.MMapDirectory
Create a new MMapDirectory for the named location, specifying the maximum chunk size used for memory mapping.
MODE_KEY - Static variable in class org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat
Attribute key for compression mode.
ModuleResourceLoader - Class in org.apache.lucene.util
Simple ResourceLoader that uses Module.getResourceAsStream(String) and Class.forName(Module,String) to open resources and classes, respectively.
ModuleResourceLoader(Module) - Constructor for class org.apache.lucene.util.ModuleResourceLoader
Creates an instance using the given Java Module to load resources and classes.
MonotonicBlockPackedReader - Class in org.apache.lucene.util.packed
Provides random access to a stream written with MonotonicBlockPackedWriter.
MonotonicBlockPackedWriter - Class in org.apache.lucene.util.packed
A writer for large monotonically increasing sequences of positive longs.
MonotonicBlockPackedWriter(DataOutput, int) - Constructor for class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
Sole constructor.
monotonicBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
 
monotonicBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
Return a new PackedLongValues.Builder that will compress efficiently integers that would be a monotonic function of their index.
MONTH - org.apache.lucene.document.DateTools.Resolution
Limit a date's resolution to month granularity.
moveToChild() - Method in class org.apache.lucene.codecs.MutablePointTree
 
moveToChild() - Method in interface org.apache.lucene.index.PointValues.PointTree
Move to the first child node and return true upon success.
moveToParent() - Method in class org.apache.lucene.codecs.MutablePointTree
 
moveToParent() - Method in interface org.apache.lucene.index.PointValues.PointTree
Move to the parent node and return true upon success.
moveToSibling() - Method in class org.apache.lucene.codecs.MutablePointTree
 
moveToSibling() - Method in interface org.apache.lucene.index.PointValues.PointTree
Move to the next sibling node and return true upon success.
MSBRadixSorter - Class in org.apache.lucene.util
Radix sorter for variable-length strings.
MSBRadixSorter(int) - Constructor for class org.apache.lucene.util.MSBRadixSorter
Sole constructor.
MSBStringRadixSorter(BytesRefComparator) - Constructor for class org.apache.lucene.util.StringSorter.MSBStringRadixSorter
 
MSG_LOCK_ACQUIRED - Static variable in class org.apache.lucene.store.VerifyingLockFactory
 
MSG_LOCK_RELEASED - Static variable in class org.apache.lucene.store.VerifyingLockFactory
 
MultiBits - Class in org.apache.lucene.index
Concatenates multiple Bits together, on every lookup.
MultiCollector - Class in org.apache.lucene.search
A Collector which allows running a search with several Collectors.
MultiCollectorManager - Class in org.apache.lucene.search
A CollectorManager implements which wrap a set of CollectorManager as MultiCollector acts for Collector.
MultiCollectorManager(CollectorManager<? extends Collector, ?>...) - Constructor for class org.apache.lucene.search.MultiCollectorManager
 
MultiDocValues - Class in org.apache.lucene.index
A wrapper for CompositeIndexReader providing access to DocValues.
MultiDocValues.MultiSortedDocValues - Class in org.apache.lucene.index
Implements SortedDocValues over n subs, using an OrdinalMap
MultiDocValues.MultiSortedSetDocValues - Class in org.apache.lucene.index
Implements MultiSortedSetDocValues over n subs, using an OrdinalMap
MultiFields - Class in org.apache.lucene.index
Provides a single Fields term index view over an IndexReader.
MultiFields(Fields[], ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiFields
Sole constructor.
MultiLeafReader - Class in org.apache.lucene.index
Utility methods for working with a IndexReader as if it were a LeafReader.
MultiLeafTopKnnCollector - Class in org.apache.lucene.search.knn
MultiLeafTopKnnCollector is a specific KnnCollector that can exchange the top collected results across segments through a shared global queue.
MultiLeafTopKnnCollector(int, int, BlockingFloatHeap) - Constructor for class org.apache.lucene.search.knn.MultiLeafTopKnnCollector
 
MultiLevelSkipListReader - Class in org.apache.lucene.codecs
This abstract class reads skip lists with multiple levels.
MultiLevelSkipListReader(IndexInput, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListReader
Creates a MultiLevelSkipListReader, where skipInterval and skipMultiplier are the same.
MultiLevelSkipListReader(IndexInput, int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListReader
Creates a MultiLevelSkipListReader.
MultiLevelSkipListWriter - Class in org.apache.lucene.codecs
This abstract class writes skip lists with multiple levels.
MultiLevelSkipListWriter(int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListWriter
Creates a MultiLevelSkipListWriter, where skipInterval and skipMultiplier are the same.
MultiLevelSkipListWriter(int, int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListWriter
Creates a MultiLevelSkipListWriter.
MULTILINESTRING - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
MultiPhraseQuery - Class in org.apache.lucene.search
A generalized version of PhraseQuery, with the possibility of adding more than one term at the same position that are treated as a disjunction (OR).
MultiPhraseQuery.Builder - Class in org.apache.lucene.search
A builder for multi-phrase queries
MultiPhraseQuery.UnionFullPostingsEnum - Class in org.apache.lucene.search
Slower version of UnionPostingsEnum that delegates offsets and positions, for use by MatchesIterator
MultiPhraseQuery.UnionPostingsEnum - Class in org.apache.lucene.search
Takes the logical union of multiple PostingsEnum iterators.
MULTIPOINT - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
MULTIPOLYGON - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
MultiPostingsEnum - Class in org.apache.lucene.index
Exposes PostingsEnum, merged from PostingsEnum API of sub-segments.
MultiPostingsEnum(MultiTermsEnum, int) - Constructor for class org.apache.lucene.index.MultiPostingsEnum
Sole constructor.
MultiPostingsEnum.EnumWithSlice - Class in org.apache.lucene.index
Holds a PostingsEnum along with the corresponding ReaderSlice.
MultiReader - Class in org.apache.lucene.index
A CompositeReader which reads multiple indexes, appending their content.
MultiReader(IndexReader...) - Constructor for class org.apache.lucene.index.MultiReader
Construct a MultiReader aggregating the named set of (sub)readers.
MultiReader(IndexReader[], boolean) - Constructor for class org.apache.lucene.index.MultiReader
Construct a MultiReader aggregating the named set of (sub)readers.
MultiReader(IndexReader[], Comparator<IndexReader>, boolean) - Constructor for class org.apache.lucene.index.MultiReader
Construct a MultiReader aggregating the named set of (sub)readers.
Multiset<T> - Class in org.apache.lucene.search
A Multiset is a set that allows for duplicate elements.
Multiset() - Constructor for class org.apache.lucene.search.Multiset
Create an empty Multiset.
MultiSimilarity - Class in org.apache.lucene.search.similarities
Implements the CombSUM method for combining evidence from multiple similarity values described in: Joseph A.
MultiSimilarity(Similarity[]) - Constructor for class org.apache.lucene.search.similarities.MultiSimilarity
Creates a MultiSimilarity which will sum the scores of the provided sims.
MultiSortedDocValues(SortedDocValues[], int[], OrdinalMap, long) - Constructor for class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
Creates a new MultiSortedDocValues over values
MultiSortedSetDocValues(SortedSetDocValues[], int[], OrdinalMap, long) - Constructor for class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
Creates a new MultiSortedSetDocValues over values
MultiTermQuery - Class in org.apache.lucene.search
An abstract Query that matches documents containing a subset of terms provided by a FilteredTermsEnum enumeration.
MultiTermQuery(String, MultiTermQuery.RewriteMethod) - Constructor for class org.apache.lucene.search.MultiTermQuery
Constructs a query matching terms that cannot be represented with a single Term.
MultiTermQuery.RewriteMethod - Class in org.apache.lucene.search
Abstract class that defines how the query is rewritten.
MultiTermQuery.TopTermsBlendedFreqScoringRewrite - Class in org.apache.lucene.search
A rewrite method that first translates each term into BooleanClause.Occur.SHOULD clause in a BooleanQuery, but adjusts the frequencies used for scoring to be blended across the terms, otherwise the rarest term typically ranks highest (often not useful eg in the set of expanded terms in a FuzzyQuery).
MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite - Class in org.apache.lucene.search
A rewrite method that first translates each term into BooleanClause.Occur.SHOULD clause in a BooleanQuery, but the scores are only computed as the boost.
MultiTermQuery.TopTermsScoringBooleanQueryRewrite - Class in org.apache.lucene.search
A rewrite method that first translates each term into BooleanClause.Occur.SHOULD clause in a BooleanQuery, and keeps the scores as computed by the query.
MultiTerms - Class in org.apache.lucene.index
Exposes flex API, merged from flex API of sub-segments.
MultiTerms(Terms[], ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiTerms
Sole constructor.
MultiTermsEnum - Class in org.apache.lucene.index
Exposes TermsEnum API, merged from TermsEnum API of sub-segments.
MultiTermsEnum(ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiTermsEnum
Sole constructor.
murmurhash3_x86_32(byte[], int, int, int) - Static method in class org.apache.lucene.util.StringHelper
Returns the MurmurHash3_x86_32 hash.
murmurhash3_x86_32(BytesRef, int) - Static method in class org.apache.lucene.util.StringHelper
 
MUST - org.apache.lucene.search.BooleanClause.Occur
Use this operator for clauses that must appear in the matching documents.
MUST_NOT - org.apache.lucene.search.BooleanClause.Occur
Use this operator for clauses that must not appear in the matching documents.
Mutable() - Constructor for class org.apache.lucene.util.packed.PackedInts.Mutable
 
MutablePointTree - Class in org.apache.lucene.codecs
One leaf PointValues.PointTree whose order of points can be changed.
MutablePointTree() - Constructor for class org.apache.lucene.codecs.MutablePointTree
Sole constructor.
MutablePointTreeReaderUtils - Class in org.apache.lucene.util.bkd
Utility APIs for sorting and partitioning buffered points.
MutableValue - Class in org.apache.lucene.util.mutable
Base class for all mutable values.
MutableValue() - Constructor for class org.apache.lucene.util.mutable.MutableValue
 
MutableValueBool - Class in org.apache.lucene.util.mutable
MutableValue implementation of type boolean.
MutableValueBool() - Constructor for class org.apache.lucene.util.mutable.MutableValueBool
 
MutableValueDate - Class in org.apache.lucene.util.mutable
MutableValue implementation of type Date.
MutableValueDate() - Constructor for class org.apache.lucene.util.mutable.MutableValueDate
 
MutableValueDouble - Class in org.apache.lucene.util.mutable
MutableValue implementation of type double.
MutableValueDouble() - Constructor for class org.apache.lucene.util.mutable.MutableValueDouble
 
MutableValueFloat - Class in org.apache.lucene.util.mutable
MutableValue implementation of type float.
MutableValueFloat() - Constructor for class org.apache.lucene.util.mutable.MutableValueFloat
 
MutableValueInt - Class in org.apache.lucene.util.mutable
MutableValue implementation of type int.
MutableValueInt() - Constructor for class org.apache.lucene.util.mutable.MutableValueInt
 
MutableValueLong - Class in org.apache.lucene.util.mutable
MutableValue implementation of type long.
MutableValueLong() - Constructor for class org.apache.lucene.util.mutable.MutableValueLong
 
MutableValueStr - Class in org.apache.lucene.util.mutable
MutableValue implementation of type String.
MutableValueStr() - Constructor for class org.apache.lucene.util.mutable.MutableValueStr
 

N

name - Variable in class org.apache.lucene.document.Field
Field's name
name - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Name of the segment.
name - Variable in class org.apache.lucene.index.FieldInfo
Field's name
name - Variable in class org.apache.lucene.index.SegmentInfo
Unique segment name in the directory.
name - Variable in class org.apache.lucene.index.SortFieldProvider
The name this SortFieldProvider is registered under
name - Variable in class org.apache.lucene.util.bkd.OfflinePointWriter
 
name - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
 
name() - Method in class org.apache.lucene.document.Field
 
name() - Method in class org.apache.lucene.document.ShapeDocValuesField
The name of the field
name() - Method in interface org.apache.lucene.index.IndexableField
Field name
NAME - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerFactory
SPI name
NAME - Static variable in class org.apache.lucene.search.SortedNumericSortField.Provider
The name this provider is registered under
NAME - Static variable in class org.apache.lucene.search.SortedSetSortField.Provider
The name this provider is registered under
NAME - Static variable in class org.apache.lucene.search.SortField.Provider
The name this Provider is registered under
namedAccountable(String, long) - Static method in class org.apache.lucene.util.Accountables
Returns an accountable with the provided description and bytes.
namedAccountable(String, Collection<Accountable>, long) - Static method in class org.apache.lucene.util.Accountables
Returns an accountable with the provided description, children and bytes.
namedAccountable(String, Accountable) - Static method in class org.apache.lucene.util.Accountables
Augments an existing accountable with the provided description.
namedAccountables(String, Map<?, ? extends Accountable>) - Static method in class org.apache.lucene.util.Accountables
Converts a map of resources to a collection.
NamedMatches - Class in org.apache.lucene.search
Utility class to help extract the set of sub queries that have matched from a larger query.
NamedMatches(String, Matches) - Constructor for class org.apache.lucene.search.NamedMatches
Wraps a Matches object and associates a name with it
NamedSPILoader<S extends NamedSPILoader.NamedSPI> - Class in org.apache.lucene.util
Helper class for loading named SPIs from classpath (e.g.
NamedSPILoader(Class<S>) - Constructor for class org.apache.lucene.util.NamedSPILoader
 
NamedSPILoader(Class<S>, ClassLoader) - Constructor for class org.apache.lucene.util.NamedSPILoader
 
NamedSPILoader.NamedSPI - Interface in org.apache.lucene.util
Interface to support NamedSPILoader.lookup(String) by name.
NamedThreadFactory - Class in org.apache.lucene.util
A default ThreadFactory implementation that accepts the name prefix of the created threads as a constructor argument.
NamedThreadFactory(String) - Constructor for class org.apache.lucene.util.NamedThreadFactory
Creates a new NamedThreadFactory instance
NAN - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
 
NATIVE_BYTE_ORDER - Static variable in class org.apache.lucene.util.BitUtil
Native byte order.
NativeFSLockFactory - Class in org.apache.lucene.store
Implements LockFactory using native OS file locks.
NATURAL - Static variable in class org.apache.lucene.util.BytesRefComparator
Comparing ByteRefs in natual order.
needsField(FieldInfo) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
needsField(FieldInfo) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
needsField(FieldInfo) - Method in class org.apache.lucene.index.StoredFieldVisitor
Hook before processing a field.
needsIndexSort - Variable in class org.apache.lucene.index.MergeState
Indicates if the index needs to be sorted *
needsScores() - Method in class org.apache.lucene.search.DoubleValuesSource
Return true if document scores are needed to calculate values
needsScores() - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
 
needsScores() - Method in class org.apache.lucene.search.LongValuesSource
Return true if document scores are needed to calculate values
needsScores() - Method in enum org.apache.lucene.search.ScoreMode
Whether this ScoreMode needs to compute scores.
needsScores() - Method in class org.apache.lucene.search.Sort
Returns true if the relevance score is needed to sort documents.
needsScores() - Method in class org.apache.lucene.search.SortField
Whether the relevance score is needed to sort documents.
NeighborArray - Class in org.apache.lucene.util.hnsw
NeighborArray encodes the neighbors of a node and their mutual scores in the HNSW graph as a pair of growable arrays.
NeighborArray(int, boolean) - Constructor for class org.apache.lucene.util.hnsw.NeighborArray
 
NeighborQueue - Class in org.apache.lucene.util.hnsw
NeighborQueue uses a LongHeap to store lists of arcs in an HNSW graph, represented as a neighbor node id with an associated score packed together as a sortable long, which is sorted primarily by score.
NeighborQueue(int, boolean) - Constructor for class org.apache.lucene.util.hnsw.NeighborQueue
 
newBooleanQuery() - Method in class org.apache.lucene.util.QueryBuilder
Builds a new BooleanQuery instance.
newBoxQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonPoint
Create a query for matching a bounding box.
newBoxQuery(String, float, float, float, float) - Static method in class org.apache.lucene.document.XYPointField
Create a query for matching a bounding box.
newBoxQuery(String, ShapeField.QueryRelation, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonShape
create a query to find all indexed geo shapes that intersect a defined bounding box *
newBoxQuery(String, ShapeField.QueryRelation, float, float, float, float) - Static method in class org.apache.lucene.document.XYShape
create a query to find all cartesian shapes that intersect a defined bounding box *
newCacheKey() - Method in interface org.apache.lucene.internal.tests.IndexPackageAccess
 
newCharacterBuffer(int) - Static method in class org.apache.lucene.analysis.CharacterUtils
Creates a new CharacterUtils.CharacterBuffer and allocates a char[] of the given bufferSize.
newCloneInstance(String, ByteBuffer[], int, long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
Factory method that creates a suitable implementation of this class for the given ByteBuffers.
newCollector() - Method in interface org.apache.lucene.search.CollectorManager
Return a new Collector.
newCollector() - Method in class org.apache.lucene.search.MultiCollectorManager
 
newCollector() - Method in class org.apache.lucene.search.TopFieldCollectorManager
 
newCollector() - Method in class org.apache.lucene.search.TopScoreDocCollectorManager
 
newCollector() - Method in class org.apache.lucene.search.TotalHitCountCollectorManager
 
newCollector(int, LeafReaderContext) - Method in interface org.apache.lucene.search.knn.KnnCollectorManager
Return a new KnnCollector instance.
newCollector(int, LeafReaderContext) - Method in class org.apache.lucene.search.knn.TopKnnCollectorManager
Return a new TopKnnCollector instance.
newComparator(String, int, Pruning, boolean) - Method in class org.apache.lucene.search.FieldComparatorSource
Creates a comparator for the field in the given index.
newCompressor() - Method in class org.apache.lucene.codecs.compressing.CompressionMode
Create a new Compressor instance.
newCompressor() - Method in class org.apache.lucene.codecs.lucene90.DeflateWithPresetDictCompressionMode
 
newCompressor() - Method in class org.apache.lucene.codecs.lucene90.LZ4WithPresetDictCompressionMode
 
newConcurrentHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
Creates a new WeakIdentityMap based on a ConcurrentHashMap.
newConcurrentHashMap(boolean) - Static method in class org.apache.lucene.util.WeakIdentityMap
Creates a new WeakIdentityMap based on a ConcurrentHashMap.
newContainsQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
Create a query for matching indexed ranges that contain the defined range.
newContainsQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
Create a query for matching indexed float ranges that contain the defined range.
newContainsQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
Create a query for matching indexed ranges that contain the defined range.
newContainsQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
Create a query for matching indexed ranges that contain the defined range.
newContainsQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
Create a query for matching indexed ip ranges that CONTAINS the defined range.
newCounter() - Static method in class org.apache.lucene.util.Counter
Returns a new counter.
newCounter(boolean) - Static method in class org.apache.lucene.util.Counter
Returns a new counter.
newCrossesQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
Create a query for matching indexed ranges that cross the defined range.
newCrossesQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
Create a query for matching indexed ranges that cross the defined range.
newCrossesQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
Create a query for matching indexed ranges that cross the defined range.
newCrossesQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
Create a query for matching indexed ranges that cross the defined range.
newCrossesQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
Create a query for matching indexed ip ranges that CROSS the defined range.
newDecompressor() - Method in class org.apache.lucene.codecs.compressing.CompressionMode
Create a new Decompressor instance.
newDecompressor() - Method in class org.apache.lucene.codecs.lucene90.DeflateWithPresetDictCompressionMode
 
newDecompressor() - Method in class org.apache.lucene.codecs.lucene90.LZ4WithPresetDictCompressionMode
 
newDistanceFeatureQuery(String, float, double, double, double) - Static method in class org.apache.lucene.document.LatLonPoint
Given a field that indexes point values into a LatLonPoint and doc values into LatLonDocValuesField, this returns a query that scores documents based on their haversine distance in meters to (originLat, originLon): score = weight * pivotDistanceMeters / (pivotDistanceMeters + distance), ie.
newDistanceFeatureQuery(String, float, long, long) - Static method in class org.apache.lucene.document.LongField
Returns a query that scores documents based on their distance to origin: score = weight * pivotDistance / (pivotDistance + distance), ie.
newDistanceFeatureQuery(String, float, long, long) - Static method in class org.apache.lucene.document.LongPoint
Deprecated.
newDistanceQuery(String, double, double, double) - Static method in class org.apache.lucene.document.LatLonPoint
Create a query for matching points within the specified distance of the supplied location.
newDistanceQuery(String, float, float, float) - Static method in class org.apache.lucene.document.XYPointField
Create a query for matching points within the specified distance of the supplied location.
newDistanceQuery(String, ShapeField.QueryRelation, Circle...) - Static method in class org.apache.lucene.document.LatLonShape
create a query to find all polygons that intersect a provided circle.
newDistanceQuery(String, ShapeField.QueryRelation, XYCircle...) - Static method in class org.apache.lucene.document.XYShape
create a query to find all cartesian shapes that intersect a provided circle (or arrays of circles) *
newDistanceSort(String, double, double) - Static method in class org.apache.lucene.document.LatLonDocValuesField
Creates a SortField for sorting by distance from a location.
newDistanceSort(String, float, float) - Static method in class org.apache.lucene.document.XYDocValuesField
Creates a SortField for sorting by distance from a location.
newDoubleValues(String, String) - Static method in class org.apache.lucene.document.FeatureField
Creates a DoubleValuesSource instance which can be used to read the values of a feature from the a FeatureField for documents.
newestSegment(IndexWriter) - Method in interface org.apache.lucene.internal.tests.IndexWriterAccess
 
newExactQuery(String, byte[]) - Static method in class org.apache.lucene.document.BinaryPoint
Create a query for matching an exact binary value.
newExactQuery(String, double) - Static method in class org.apache.lucene.document.DoubleField
Create a query for matching an exact double value.
newExactQuery(String, double) - Static method in class org.apache.lucene.document.DoublePoint
Create a query for matching an exact double value.
newExactQuery(String, float) - Static method in class org.apache.lucene.document.FloatField
Create a query for matching an exact float value.
newExactQuery(String, float) - Static method in class org.apache.lucene.document.FloatPoint
Create a query for matching an exact float value.
newExactQuery(String, int) - Static method in class org.apache.lucene.document.IntField
Create a query for matching an exact integer value.
newExactQuery(String, int) - Static method in class org.apache.lucene.document.IntPoint
Create a query for matching an exact integer value.
newExactQuery(String, long) - Static method in class org.apache.lucene.document.LongField
Create a query for matching an exact long value.
newExactQuery(String, long) - Static method in class org.apache.lucene.document.LongPoint
Create a query for matching an exact long value.
newExactQuery(String, String) - Static method in class org.apache.lucene.document.KeywordField
Create a query for matching an exact String value.
newExactQuery(String, InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
Create a query for matching a network address.
newExactQuery(String, BytesRef) - Static method in class org.apache.lucene.document.KeywordField
Create a query for matching an exact BytesRef value.
newFactoryClassInstance(Class<T>, Map<String, String>) - Static method in class org.apache.lucene.analysis.AnalysisSPILoader
Creates a new instance of the given AbstractAnalysisFactory by invoking the constructor, passing the given argument map.
newFeatureSort(String, String) - Static method in class org.apache.lucene.document.FeatureField
Creates a SortField for sorting by the value of a feature.
newFieldInfosBuilder(String, String) - Method in interface org.apache.lucene.internal.tests.IndexPackageAccess
 
newFSDirectory(Class<? extends FSDirectory>, Path) - Static method in class org.apache.lucene.util.CommandLineUtil
Creates a new specific FSDirectory instance
newFSDirectory(Class<? extends FSDirectory>, Path, LockFactory) - Static method in class org.apache.lucene.util.CommandLineUtil
Creates a new specific FSDirectory instance
newFSDirectory(String, Path) - Static method in class org.apache.lucene.util.CommandLineUtil
Creates a specific FSDirectory instance starting from its class name, using the default lock factory
newFSDirectory(String, Path, LockFactory) - Static method in class org.apache.lucene.util.CommandLineUtil
Creates a specific FSDirectory instance starting from its class name
newGeometryQuery(String, ShapeField.QueryRelation, Object...) - Static method in class org.apache.lucene.document.ShapeDocValuesField
Creates a geometry query for shape docvalues
newGeometryQuery(String, ShapeField.QueryRelation, LatLonGeometry...) - Static method in class org.apache.lucene.document.LatLonPoint
Create a query for matching one or more geometries against the provided ShapeField.QueryRelation.
newGeometryQuery(String, ShapeField.QueryRelation, LatLonGeometry...) - Static method in class org.apache.lucene.document.LatLonShape
create a query to find all indexed geo shapes that intersect a provided geometry (or array of geometries).
newGeometryQuery(String, ShapeField.QueryRelation, XYGeometry...) - Static method in class org.apache.lucene.document.XYShape
create a query to find all indexed geo shapes that intersect a provided geometry collection note: Components do not support dateline crossing
newGeometryQuery(String, XYGeometry...) - Static method in class org.apache.lucene.document.XYPointField
create a query to find all indexed shapes that intersect a provided geometry collection.
newGraphSynonymQuery(Iterator<Query>) - Method in class org.apache.lucene.util.QueryBuilder
Builds a new GraphQuery for multi-terms synonyms.
newHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
Creates a new WeakIdentityMap based on a non-synchronized HashMap.
newHashMap(boolean) - Static method in class org.apache.lucene.util.WeakIdentityMap
Creates a new WeakIdentityMap based on a non-synchronized HashMap.
newHashMap(int) - Static method in class org.apache.lucene.util.CollectionUtil
Returns a new HashMap sized to contain size items without resizing the internal array.
newHashSet(int) - Static method in class org.apache.lucene.util.CollectionUtil
Returns a new HashSet sized to contain size items without resizing the internal array.
newInstance() - Method in class org.apache.lucene.util.RollingBuffer
 
newInstance(String, Class<T>) - Method in interface org.apache.lucene.util.ResourceLoader
Creates an instance of the name and expected type
newInstance(String, ByteBuffer[], long, int, ByteBufferGuard) - Static method in class org.apache.lucene.store.ByteBufferIndexInput
 
newInstance(String, Map<String, String>) - Method in class org.apache.lucene.analysis.AnalysisSPILoader
 
newIntersectsQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
Create a query for matching indexed ranges that intersect the defined range.
newIntersectsQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
Create a query for matching indexed ranges that intersect the defined range.
newIntersectsQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
Create a query for matching indexed ranges that intersect the defined range.
newIntersectsQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
Create a query for matching indexed ranges that intersect the defined range.
newIntersectsQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
Create a query for matching indexed ip ranges that INTERSECT the defined range.
newLinearQuery(String, String, float) - Static method in class org.apache.lucene.document.FeatureField
Return a new Query that will score documents as weight * S where S is the value of the static feature.
newLineQuery(String, ShapeField.QueryRelation, Line...) - Static method in class org.apache.lucene.document.LatLonShape
create a query to find all indexed geo shapes that intersect a provided linestring (or array of linestrings) note: does not support dateline crossing
newLineQuery(String, ShapeField.QueryRelation, XYLine...) - Static method in class org.apache.lucene.document.XYShape
create a query to find all cartesian shapes that intersect a provided linestring (or array of linestrings) *
newLogQuery(String, String, float, float) - Static method in class org.apache.lucene.document.FeatureField
Return a new Query that will score documents as weight * Math.log(scalingFactor + S) where S is the value of the static feature.
newMultiPhraseQueryBuilder() - Method in class org.apache.lucene.util.QueryBuilder
Builds a new MultiPhraseQuery instance.
newMutable(int, int) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
 
newMutable(int, int) - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
 
newMutable(int, int) - Method in class org.apache.lucene.util.packed.PagedMutable
 
newPair(A, B) - Method in class org.apache.lucene.util.fst.PairOutputs
Create a new Pair
newPointQuery(String, ShapeField.QueryRelation, double[]...) - Static method in class org.apache.lucene.document.LatLonShape
create a query to find all indexed shapes that comply the ShapeField.QueryRelation with the provided points
newPointQuery(String, ShapeField.QueryRelation, float[]...) - Static method in class org.apache.lucene.document.XYShape
create a query to find all indexed shapes that comply the ShapeField.QueryRelation with the provided point
newPolygonQuery(String, ShapeField.QueryRelation, Polygon...) - Static method in class org.apache.lucene.document.LatLonShape
create a query to find all indexed geo shapes that intersect a provided polygon (or array of polygons) note: does not support dateline crossing
newPolygonQuery(String, ShapeField.QueryRelation, XYPolygon...) - Static method in class org.apache.lucene.document.XYShape
create a query to find all cartesian shapes that intersect a provided polygon (or array of polygons) *
newPolygonQuery(String, Polygon...) - Static method in class org.apache.lucene.document.LatLonPoint
Create a query for matching one or more polygons.
newPolygonQuery(String, XYPolygon...) - Static method in class org.apache.lucene.document.XYPointField
Create a query for matching one or more polygons.
newPrefixQuery(String, InetAddress, int) - Static method in class org.apache.lucene.document.InetAddressPoint
Create a prefix query for matching a CIDR network range.
newRangeQuery(String, byte[][], byte[][]) - Static method in class org.apache.lucene.document.BinaryPoint
Create a range query for n-dimensional binary values.
newRangeQuery(String, byte[], byte[]) - Static method in class org.apache.lucene.document.BinaryPoint
Create a range query for binary values.
newRangeQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoublePoint
Create a range query for n-dimensional double values.
newRangeQuery(String, double, double) - Static method in class org.apache.lucene.document.DoubleField
Create a range query for double values.
newRangeQuery(String, double, double) - Static method in class org.apache.lucene.document.DoublePoint
Create a range query for double values.
newRangeQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatPoint
Create a range query for n-dimensional float values.
newRangeQuery(String, float, float) - Static method in class org.apache.lucene.document.FloatField
Create a range query for float values.
newRangeQuery(String, float, float) - Static method in class org.apache.lucene.document.FloatPoint
Create a range query for float values.
newRangeQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntPoint
Create a range query for n-dimensional integer values.
newRangeQuery(String, int, int) - Static method in class org.apache.lucene.document.IntField
Create a range query for integer values.
newRangeQuery(String, int, int) - Static method in class org.apache.lucene.document.IntPoint
Create a range query for integer values.
newRangeQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongPoint
Create a range query for n-dimensional long values.
newRangeQuery(String, long, long) - Static method in class org.apache.lucene.document.LongField
Create a range query for long values.
newRangeQuery(String, long, long) - Static method in class org.apache.lucene.document.LongPoint
Create a range query for long values.
newRangeQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
Create a range query for network addresses.
newResettableInstance() - Static method in class org.apache.lucene.store.ByteBuffersDataOutput
 
newSaturationQuery(String, String) - Static method in class org.apache.lucene.document.FeatureField
Same as FeatureField.newSaturationQuery(String, String, float, float) but 1f is used as a weight and a reasonably good default pivot value is computed based on index statistics and is approximately equal to the geometric mean of all values that exist in the index.
newSaturationQuery(String, String, float, float) - Static method in class org.apache.lucene.document.FeatureField
Return a new Query that will score documents as weight * S / (S + pivot) where S is the value of the static feature.
newSearcher(IndexReader, IndexReader) - Method in class org.apache.lucene.search.SearcherFactory
Returns a new IndexSearcher over the given reader.
newSetQuery(String, byte[]...) - Static method in class org.apache.lucene.document.BinaryPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, double...) - Static method in class org.apache.lucene.document.DoubleField
Create a query matching values in a supplied set
newSetQuery(String, double...) - Static method in class org.apache.lucene.document.DoublePoint
Create a query matching any of the specified 1D values.
newSetQuery(String, float...) - Static method in class org.apache.lucene.document.FloatField
Create a query matching values in a supplied set
newSetQuery(String, float...) - Static method in class org.apache.lucene.document.FloatPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, int...) - Static method in class org.apache.lucene.document.IntField
Create a query matching values in a supplied set
newSetQuery(String, int...) - Static method in class org.apache.lucene.document.IntPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, long...) - Static method in class org.apache.lucene.document.LongField
Create a query matching values in a supplied set
newSetQuery(String, long...) - Static method in class org.apache.lucene.document.LongPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, InetAddress...) - Static method in class org.apache.lucene.document.InetAddressPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, Collection<Double>) - Static method in class org.apache.lucene.document.DoublePoint
Create a query matching any of the specified 1D values.
newSetQuery(String, Collection<Float>) - Static method in class org.apache.lucene.document.FloatPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, Collection<Integer>) - Static method in class org.apache.lucene.document.IntPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, Collection<Long>) - Static method in class org.apache.lucene.document.LongPoint
Create a query matching any of the specified 1D values.
newSetQuery(String, Collection<BytesRef>) - Static method in class org.apache.lucene.document.KeywordField
Create a query for matching any of a set of provided BytesRef values.
newSetQuery(String, BytesRef...) - Static method in class org.apache.lucene.document.KeywordField
Deprecated, for removal: This API element is subject to removal in a future version.
newSigmoidQuery(String, String, float, float, float) - Static method in class org.apache.lucene.document.FeatureField
Return a new Query that will score documents as weight * S^a / (S^a + pivot^a) where S is the value of the static feature.
newSlowBoxQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonDocValuesField
Create a query for matching a bounding box using doc values.
newSlowBoxQuery(String, float, float, float, float) - Static method in class org.apache.lucene.document.XYDocValuesField
Create a query for matching a bounding box using doc values.
newSlowDistanceQuery(String, double, double, double) - Static method in class org.apache.lucene.document.LatLonDocValuesField
Create a query for matching points within the specified distance of the supplied location.
newSlowDistanceQuery(String, float, float, float) - Static method in class org.apache.lucene.document.XYDocValuesField
Create a query for matching points within the specified distance of the supplied location.
newSlowDocValuesBoxQuery(String, ShapeField.QueryRelation, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonShape
create a docvalue query to find all geo shapes that intersect a defined bounding box *
newSlowDocValuesBoxQuery(String, ShapeField.QueryRelation, float, float, float, float) - Static method in class org.apache.lucene.document.XYShape
create a docvalue query to find all cartesian shapes that intersect a defined bounding box *
newSlowExactQuery(String, long) - Static method in class org.apache.lucene.document.NumericDocValuesField
Create a query for matching an exact long value.
newSlowExactQuery(String, long) - Static method in class org.apache.lucene.document.SortedNumericDocValuesField
Create a query for matching an exact long value.
newSlowExactQuery(String, BytesRef) - Static method in class org.apache.lucene.document.SortedDocValuesField
Create a query for matching an exact BytesRef value.
newSlowExactQuery(String, BytesRef) - Static method in class org.apache.lucene.document.SortedSetDocValuesField
Create a query for matching an exact BytesRef value.
newSlowGeometryQuery(String, ShapeField.QueryRelation, LatLonGeometry...) - Static method in class org.apache.lucene.document.LatLonDocValuesField
Create a query for matching one or more geometries against the provided ShapeField.QueryRelation.
newSlowGeometryQuery(String, XYGeometry...) - Static method in class org.apache.lucene.document.XYDocValuesField
Create a query for matching points within the supplied geometries.
newSlowIntersectsQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRangeDocValuesField
Create a new range query that finds all ranges that intersect using doc values.
newSlowIntersectsQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRangeDocValuesField
Create a new range query that finds all ranges that intersect using doc values.
newSlowIntersectsQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRangeDocValuesField
Create a new range query that finds all ranges that intersect using doc values.
newSlowIntersectsQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRangeDocValuesField
Create a new range query that finds all ranges that intersect using doc values.
newSlowPolygonQuery(String, Polygon...) - Static method in class org.apache.lucene.document.LatLonDocValuesField
Create a query for matching points within the supplied polygons.
newSlowPolygonQuery(String, XYPolygon...) - Static method in class org.apache.lucene.document.XYDocValuesField
Create a query for matching points within the supplied polygons.
newSlowRangeQuery(String, long, long) - Static method in class org.apache.lucene.document.NumericDocValuesField
Create a range query that matches all documents whose value is between lowerValue and upperValue included.
newSlowRangeQuery(String, long, long) - Static method in class org.apache.lucene.document.SortedNumericDocValuesField
Create a range query that matches all documents whose value is between lowerValue and upperValue included.
newSlowRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.document.SortedDocValuesField
Create a range query that matches all documents whose value is between lowerValue and upperValue included.
newSlowRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.document.SortedSetDocValuesField
Create a range query that matches all documents whose value is between lowerValue and upperValue.
newSlowSetQuery(String, long...) - Static method in class org.apache.lucene.document.NumericDocValuesField
Create a query matching any of the specified values.
newSlowSetQuery(String, long...) - Static method in class org.apache.lucene.document.SortedNumericDocValuesField
Create a query matching any of the specified values.
newSlowSetQuery(String, Collection<BytesRef>) - Static method in class org.apache.lucene.document.SortedDocValuesField
Create a query matching any of the specified values.
newSlowSetQuery(String, Collection<BytesRef>) - Static method in class org.apache.lucene.document.SortedSetDocValuesField
Create a query matching any of the specified values.
newSlowSetQuery(String, BytesRef...) - Static method in class org.apache.lucene.document.SortedDocValuesField
Deprecated, for removal: This API element is subject to removal in a future version.
newSlowSetQuery(String, BytesRef...) - Static method in class org.apache.lucene.document.SortedSetDocValuesField
Deprecated, for removal: This API element is subject to removal in a future version.
newSortField(String, boolean, SortedNumericSelector.Type) - Static method in class org.apache.lucene.document.DoubleField
Create a new SortField for double values.
newSortField(String, boolean, SortedNumericSelector.Type) - Static method in class org.apache.lucene.document.FloatField
Create a new SortField for float values.
newSortField(String, boolean, SortedNumericSelector.Type) - Static method in class org.apache.lucene.document.IntField
Create a new SortField for int values.
newSortField(String, boolean, SortedNumericSelector.Type) - Static method in class org.apache.lucene.document.LongField
Create a new SortField for long values.
newSortField(String, boolean, SortedSetSelector.Type) - Static method in class org.apache.lucene.document.KeywordField
Create a new SortField for BytesRef values.
newStats(String, double) - Method in class org.apache.lucene.search.similarities.LMSimilarity
 
newStats(String, double) - Method in class org.apache.lucene.search.similarities.SimilarityBase
Factory method to return a custom stats object
newString(int[], int, int) - Static method in class org.apache.lucene.util.UnicodeUtil
Cover JDK 1.5 API.
newStringRange(String, String, String, boolean, boolean) - Static method in class org.apache.lucene.search.TermRangeQuery
Factory that creates a new TermRangeQuery using Strings for term text.
newStringRange(String, String, String, boolean, boolean, MultiTermQuery.RewriteMethod) - Static method in class org.apache.lucene.search.TermRangeQuery
Factory that creates a new TermRangeQuery using Strings for term text.
newSynonymQuery(String, QueryBuilder.TermAndBoost[]) - Method in class org.apache.lucene.util.QueryBuilder
Builds a new SynonymQuery instance.
newTermQuery(Term, float) - Method in class org.apache.lucene.util.QueryBuilder
Builds a new TermQuery instance.
newTermState() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
newTermState() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
newTermState() - Method in class org.apache.lucene.codecs.PostingsReaderBase
Return a newly created empty TermState
newTermState() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Return a newly created empty TermState
newThread(Runnable) - Method in class org.apache.lucene.util.NamedThreadFactory
Creates a new Thread
newToOld(int) - Method in class org.apache.lucene.index.Sorter.DocMap
Given the ordinal of a doc ID, return its doc ID in the original index.
newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopDocsCollector
Returns a TopDocs instance containing the given results.
newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopFieldCollector
 
newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopScoreDocCollector
 
newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
 
newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
 
newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.PagedMutable
 
newVectorQuery(String, byte[], int) - Static method in class org.apache.lucene.document.KnnByteVectorField
Create a new vector query for the provided field targeting the byte vector
newVectorQuery(String, float[], int) - Static method in class org.apache.lucene.document.KnnFloatVectorField
Create a new vector query for the provided field targeting the float vector
newWithinQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
Create a query for matching indexed ranges that are within the defined range.
newWithinQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
Create a query for matching indexed ranges that are within the defined range.
newWithinQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
Create a query for matching indexed ranges that are within the defined range.
newWithinQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
Create a query for matching indexed ranges that are within the defined range.
newWithinQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
Create a query for matching indexed ip ranges that are WITHIN the defined range.
next - Variable in class org.apache.lucene.search.DisiWrapper
 
next() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
use nextCharArray() + currentValue() for better efficiency.
next() - Method in class org.apache.lucene.index.DocIDMerger
Returns null when done.
next() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTermsEnum
 
next() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
next() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
next() - Method in class org.apache.lucene.index.MultiTermsEnum
 
next() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
 
next() - Method in class org.apache.lucene.search.FilterMatchesIterator
 
next() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
next() - Method in interface org.apache.lucene.search.MatchesIterator
Advance the iterator to the next match position
next() - Method in class org.apache.lucene.search.PointInSetQuery.Stream
 
next() - Method in class org.apache.lucene.util.automaton.FiniteStringsIterator
Generate next finite string.
next() - Method in class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
 
next() - Method in class org.apache.lucene.util.bkd.HeapPointReader
 
next() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
 
next() - Method in interface org.apache.lucene.util.bkd.PointReader
Returns false once iteration is done, else true.
next() - Method in interface org.apache.lucene.util.BytesRefIterator
Increments the iteration to the next BytesRef in the iterator.
next() - Method in class org.apache.lucene.util.FilterIterator
 
next() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
next() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
next() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.AbstractIterator
 
next() - Method in class org.apache.lucene.util.MergedIterator
 
next() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
Reads the next entry into the provided BytesRef.
next() - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
Read the next value.
next() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
Returns next value
next() - Method in class org.apache.lucene.util.packed.PackedLongValues.Iterator
Return the next long in the buffer.
next(int) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
Read between 1 and count values.
next(int) - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
Returns at least 1 and at most count next values, the returned ref MUST NOT be modified
next(Transition, int) - Method in class org.apache.lucene.util.automaton.Automaton
Looks for the next transition that matches the provided label, assuming determinism.
nextBuffer() - Method in class org.apache.lucene.util.ByteBlockPool
Allocates a new buffer and advances the pool to it.
nextBuffer() - Method in class org.apache.lucene.util.IntBlockPool
Advances the pool to its next buffer.
nextDoc() - Method in class org.apache.lucene.codecs.lucene90.IndexedDISI
 
nextDoc() - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues.DenseOffHeapVectorValues
 
nextDoc() - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues.DenseOffHeapVectorValues
 
nextDoc() - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues
 
nextDoc() - Method in class org.apache.lucene.document.BinaryRangeDocValues
 
nextDoc() - Method in class org.apache.lucene.index.DocIDMerger.Sub
Returns the next document ID from this sub reader, and DocIdSetIterator.NO_MORE_DOCS when done
nextDoc() - Method in class org.apache.lucene.index.FilterBinaryDocValues
 
nextDoc() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
nextDoc() - Method in class org.apache.lucene.index.FilterNumericDocValues
 
nextDoc() - Method in class org.apache.lucene.index.FilterSortedDocValues
 
nextDoc() - Method in class org.apache.lucene.index.FilterSortedNumericDocValues
 
nextDoc() - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
nextDoc() - Method in class org.apache.lucene.index.FilterVectorValues
 
nextDoc() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
nextDoc() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
nextDoc() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
nextDoc() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
nextDoc() - Method in class org.apache.lucene.search.comparators.MinDocIterator
 
nextDoc() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
 
nextDoc() - Method in class org.apache.lucene.search.DocIdSetIterator
Advances to the next document in the set and returns the doc it is currently on, or DocIdSetIterator.NO_MORE_DOCS if there are no more docs in the set.
NOTE: after the iterator has exhausted you should not call this method, as it may result in unpredicted behavior.
nextDoc() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
nextDoc() - Method in class org.apache.lucene.search.ImpactsDISI
 
nextDoc() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
nextDoc() - Method in class org.apache.lucene.util.BitSetIterator
 
nextDoc() - Method in class org.apache.lucene.util.DocBaseBitSetIterator
 
nextDown(byte[]) - Static method in class org.apache.lucene.util.NumericUtils
Modify in-place the given bytes to the previous value of the same length that compares less than the current value.
nextDown(double) - Static method in class org.apache.lucene.document.DoublePoint
Return the greatest double that compares less than d consistently with Double.compare(double, double).
nextDown(float) - Static method in class org.apache.lucene.document.FloatPoint
Return the greatest float that compares less than f consistently with Float.compare(float, float).
nextDown(InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
Return the InetAddress that compares immediately less than address.
nextFinalOutput() - Method in class org.apache.lucene.util.fst.FST.Arc
 
nextHighestPowerOfTwo(int) - Static method in class org.apache.lucene.util.BitUtil
returns the next highest power of two, or the current value if it's already a power of two or zero
nextHighestPowerOfTwo(long) - Static method in class org.apache.lucene.util.BitUtil
returns the next highest power of two, or the current value if it's already a power of two or zero
nextInt() - Method in class org.apache.lucene.util.hnsw.HnswGraph.ArrayNodesIterator
 
nextInt() - Method in class org.apache.lucene.util.hnsw.HnswGraph.CollectionNodesIterator
 
nextIterationSeed() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Provides the next iteration seed used to build the iteration starting slot and offset increment.
nextKey() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
gets the next key...
nextKeyString() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
gets the next key as a newly created String object
nextMappedDoc() - Method in class org.apache.lucene.index.DocIDMerger.Sub
Like DocIDMerger.Sub.nextDoc() but skips over unmapped docs and returns the next mapped doc ID, or DocIdSetIterator.NO_MORE_DOCS when exhausted.
nextMatch() - Method in class org.apache.lucene.search.ExactPhraseMatcher
 
nextMatch() - Method in class org.apache.lucene.search.PhraseMatcher
Find the next match on the current document, returning false if there are none.
nextMatch() - Method in class org.apache.lucene.search.SloppyPhraseMatcher
 
nextNeighbor() - Method in class org.apache.lucene.util.hnsw.HnswGraph
Iterates over the neighbor list.
nextNeighbor() - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
 
nextOrd() - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
nextOrd() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
 
nextOrd() - Method in class org.apache.lucene.index.SortedSetDocValues
Returns the next ordinal for the current document.
nextPosition() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
nextPosition() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
nextPosition() - Method in class org.apache.lucene.index.PostingsEnum
Returns the next position, or -1 if positions were not indexed.
nextPosition() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
nextPosition() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionFullPostingsEnum
 
nextPosition() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
nextSeekTerm(BytesRef) - Method in class org.apache.lucene.index.AutomatonTermsEnum
 
nextSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
On the first call to FilteredTermsEnum.next() or if FilteredTermsEnum.accept(org.apache.lucene.util.BytesRef) returns FilteredTermsEnum.AcceptStatus.YES_AND_SEEK or FilteredTermsEnum.AcceptStatus.NO_AND_SEEK, this method will be called to eventually seek the underlying TermsEnum to a new position.
nextSetBit(int) - Method in class org.apache.lucene.util.BitSet
Returns the index of the first set bit starting at the index specified.
nextSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
 
nextSetBit(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
nextSetBit(long) - Method in class org.apache.lucene.util.LongBitSet
Returns the index of the first set bit starting at the index specified.
nextUp(byte[]) - Static method in class org.apache.lucene.util.NumericUtils
Modify in-place the given bytes to the next value of the same length that compares greater than the current value.
nextUp(double) - Static method in class org.apache.lucene.document.DoublePoint
Return the least double that compares greater than d consistently with Double.compare(double, double).
nextUp(float) - Static method in class org.apache.lucene.document.FloatPoint
Return the least float that compares greater than f consistently with Float.compare(float, float).
nextUp(InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
Return the InetAddress that compares immediately greater than address.
nextValue() - Method in class org.apache.lucene.index.FilterSortedNumericDocValues
 
nextValue() - Method in class org.apache.lucene.index.SortedNumericDocValues
Iterates to the next value in the current document.
NGramPhraseQuery - Class in org.apache.lucene.search
This is a PhraseQuery which is optimized for n-gram phrase query.
NGramPhraseQuery(int, PhraseQuery) - Constructor for class org.apache.lucene.search.NGramPhraseQuery
Constructor that takes gram size.
NIOFSDirectory - Class in org.apache.lucene.store
An FSDirectory implementation that uses java.nio's FileChannel's positional read, which allows multiple threads to read from the same file without synchronizing.
NIOFSDirectory(Path) - Constructor for class org.apache.lucene.store.NIOFSDirectory
Create a new NIOFSDirectory for the named location and FSLockFactory.getDefault().
NIOFSDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.NIOFSDirectory
Create a new NIOFSDirectory for the named location.
NO - org.apache.lucene.document.Field.Store
Do not store the field value in the index.
NO - org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Reject the term and position the enum at the next term.
NO - org.apache.lucene.index.StoredFieldVisitor.Status
NO: don't visit this field, but continue processing fields for this document.
NO - Static variable in class org.apache.lucene.index.SegmentInfo
Used by some member fields to mean not present (e.g., norms, deletions).
NO_AND_SEEK - org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Reject the term and advance (FilteredTermsEnum.nextSeekTerm(BytesRef)) to the next term.
NO_FILES - Static variable in class org.apache.lucene.store.MMapDirectory
Argument for MMapDirectory.setPreload(BiPredicate) that configures no files to be preloaded upon opening them.
NO_MORE_DOCS - Static variable in class org.apache.lucene.search.DocIdSetIterator
When returned by DocIdSetIterator.nextDoc(), DocIdSetIterator.advance(int) and DocIdSetIterator.docID() it means there are no more docs in the iterator.
NO_MORE_ORDS - Static variable in class org.apache.lucene.index.SortedSetDocValues
Deprecated.
Will be removed in a future version. Please use SortedSetDocValues.docValueCount() to know the number of doc values for the current document up-front.
NO_OP_LISTENER - Static variable in interface org.apache.lucene.index.IndexWriterEventListener
A no-op listener that helps to save null checks
NO_OUTPUT - Static variable in class org.apache.lucene.util.InfoStream
Instance of InfoStream that does no logging at all.
NO_REUSE - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
A singleton instance of "no-reuse" buffer strategy.
noCFSRatio - Variable in class org.apache.lucene.index.MergePolicy
If the size of the merge segment exceeds this ratio of the total index size then it will remain in non-compound format
Node(double[], double[], int, int, boolean) - Constructor for class org.apache.lucene.geo.Tessellator.Node
 
Node(Tessellator.Node) - Constructor for class org.apache.lucene.geo.Tessellator.Node
simple deep copy constructor
nodeFlags() - Method in class org.apache.lucene.util.fst.FST.Arc
Node header flags.
NoDeletionPolicy - Class in org.apache.lucene.index
An IndexDeletionPolicy which keeps all index commits around, never deleting them.
nodes() - Method in class org.apache.lucene.util.hnsw.NeighborArray
Direct access to the internal list of node ids; provided for efficient writing of the graph
nodes() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
NodesIterator(int) - Constructor for class org.apache.lucene.util.hnsw.HnswGraph.NodesIterator
Constructor for iterator based on the size
NoLockFactory - Class in org.apache.lucene.store
Use this LockFactory to disable locking entirely.
noMatch(String, Collection<Explanation>) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a document which does not match.
noMatch(String, Explanation...) - Static method in class org.apache.lucene.search.Explanation
Create a new explanation for a document which does not match.
NoMergePolicy - Class in org.apache.lucene.index
A MergePolicy which never returns merges to execute.
NoMergeScheduler - Class in org.apache.lucene.index
A MergeScheduler which never executes any merges.
NONE - org.apache.lucene.index.DocValuesType
No doc values for this field.
NONE - org.apache.lucene.index.IndexOptions
Not indexed
NONE - org.apache.lucene.search.Pruning
Not allowed to skip documents.
NONE - org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Automaton that accepts no strings.
NONE - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you don't require per-document postings in the returned enum.
NONE - Static variable in class org.apache.lucene.util.automaton.RegExp
Syntax flag, enables no optional regexp syntax.
nonFloorBlockCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
The number of normal (non-floor) blocks in the terms file.
NoNormalization() - Constructor for class org.apache.lucene.search.similarities.Normalization.NoNormalization
Sole constructor: parameter-free
NoOutputs - Class in org.apache.lucene.util.fst
A null FST Outputs implementation; use this if you just want to build an FSA.
norm - Variable in class org.apache.lucene.index.Impact
Norm factor of the document.
NORMAL - org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Catch-all for any other automata.
normalization - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
The term frequency normalization.
normalization - Variable in class org.apache.lucene.search.similarities.IBSimilarity
The term frequency normalization.
Normalization - Class in org.apache.lucene.search.similarities
This class acts as the base class for the implementations of the term frequency normalization methods in the DFR framework.
Normalization() - Constructor for class org.apache.lucene.search.similarities.Normalization
Sole constructor.
Normalization.NoNormalization - Class in org.apache.lucene.search.similarities
Implementation used when there is no normalization.
NormalizationH1 - Class in org.apache.lucene.search.similarities
Normalization model that assumes a uniform distribution of the term frequency.
NormalizationH1() - Constructor for class org.apache.lucene.search.similarities.NormalizationH1
NormalizationH1(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH1
Creates NormalizationH1 with the supplied parameter c.
NormalizationH2 - Class in org.apache.lucene.search.similarities
Normalization model in which the term frequency is inversely related to the length.
NormalizationH2() - Constructor for class org.apache.lucene.search.similarities.NormalizationH2
NormalizationH2(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH2
Creates NormalizationH2 with the supplied parameter c.
NormalizationH3 - Class in org.apache.lucene.search.similarities
Dirichlet Priors normalization
NormalizationH3() - Constructor for class org.apache.lucene.search.similarities.NormalizationH3
NormalizationH3(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH3
Creates NormalizationH3 with the supplied parameter μ.
NormalizationZ - Class in org.apache.lucene.search.similarities
Pareto-Zipf Normalization
NormalizationZ() - Constructor for class org.apache.lucene.search.similarities.NormalizationZ
NormalizationZ(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationZ
Creates NormalizationZ with the supplied parameter z.
normalize(Reader) - Method in class org.apache.lucene.analysis.CharFilterFactory
Normalize the specified input Reader While the default implementation returns input unchanged, char filters that should be applied at normalization time can delegate to create method.
normalize(String, String) - Method in class org.apache.lucene.analysis.Analyzer
Normalize a string down to the representation that it would have in the index.
normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.Analyzer
Wrap the given TokenStream in order to apply normalization filters.
normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
 
normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
 
normalize(TokenStream) - Method in class org.apache.lucene.analysis.TokenFilterFactory
Normalize the specified input TokenStream While the default implementation returns input unchanged, filters that should be applied at normalization time can delegate to create method.
normalizeVector() - Method in class org.apache.lucene.util.TermAndVector
 
normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene90.Lucene90NormsFormat
 
normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.NormsFormat
Returns a NormsConsumer to write norms to the index.
NormsConsumer - Class in org.apache.lucene.codecs
Abstract API that consumes normalization values.
NormsConsumer() - Constructor for class org.apache.lucene.codecs.NormsConsumer
Sole constructor.
NormsFieldExistsQuery - Class in org.apache.lucene.search
Deprecated.
Use FieldExistsQuery instead.
NormsFieldExistsQuery(String) - Constructor for class org.apache.lucene.search.NormsFieldExistsQuery
Deprecated.
Create a query that will match that have a value for the given field.
normsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes document normalization values
normsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
normsFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
NormsFormat - Class in org.apache.lucene.codecs
Encodes/decodes per-document score normalization values.
NormsFormat() - Constructor for class org.apache.lucene.codecs.NormsFormat
Sole constructor.
normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene90.Lucene90NormsFormat
 
normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.NormsFormat
Returns a NormsProducer to read norms from the index.
NormsProducer - Class in org.apache.lucene.codecs
Abstract API that produces field normalization values
NormsProducer() - Constructor for class org.apache.lucene.codecs.NormsProducer
Sole constructor.
normsProducers - Variable in class org.apache.lucene.index.MergeState
Norms producers being merged
NOT_FOUND - org.apache.lucene.index.TermsEnum.SeekStatus
A different term was found after the requested term
NotDocIdSet - Class in org.apache.lucene.util
This DocIdSet encodes the negation of another DocIdSet.
NotDocIdSet(int, DocIdSet) - Constructor for class org.apache.lucene.util.NotDocIdSet
Sole constructor.
notifyReaderClosedListeners() - Method in class org.apache.lucene.index.IndexReader
For test framework use only.
notifyReaderClosedListeners() - Method in class org.apache.lucene.index.SegmentReader
 
notifyReaderClosedListeners() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
NOTWITHIN - org.apache.lucene.geo.Component2D.WithinRelation
The query shape intersects an edge that does belong to the original shape or any point of the triangle is inside the shape.
NRTCachingDirectory - Class in org.apache.lucene.store
Wraps a RAM-resident directory around any provided delegate directory, to be used during NRT search.
NRTCachingDirectory(Directory, double, double) - Constructor for class org.apache.lucene.store.NRTCachingDirectory
We will cache a newly created output if 1) it's a flush or a merge and the estimated size of the merged segment is <= maxMergeSizeMB, and 2) the total cached bytes is <= maxCachedMB
NULL_ACCOUNTABLE - Static variable in interface org.apache.lucene.util.Accountable
An accountable that always returns 0
NullReader(int) - Constructor for class org.apache.lucene.util.packed.PackedInts.NullReader
Sole constructor.
NUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Numeric token type
NUM_BYTES_ARRAY_HEADER - Static variable in class org.apache.lucene.util.RamUsageEstimator
Number of bytes to represent an array header (no content, but with alignments).
NUM_BYTES_OBJECT_ALIGNMENT - Static variable in class org.apache.lucene.util.RamUsageEstimator
A constant specifying the object alignment boundary inside the JVM.
NUM_BYTES_OBJECT_HEADER - Static variable in class org.apache.lucene.util.RamUsageEstimator
Number of bytes to represent an object header (no fields, no alignments).
NUM_BYTES_OBJECT_REF - Static variable in class org.apache.lucene.util.RamUsageEstimator
Number of bytes this JVM uses to represent an object reference.
numArcs() - Method in class org.apache.lucene.util.fst.FST.Arc
How many arcs; only valid if bytesPerArc != 0 (fixed length arcs).
numBadSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
How many bad segments were found.
number - Variable in class org.apache.lucene.index.FieldInfo
Internal field number
numberOfDocuments - Variable in class org.apache.lucene.search.similarities.BasicStats
The number of documents.
numberOfFieldTokens - Variable in class org.apache.lucene.search.similarities.BasicStats
The total number of tokens in the field.
numberOfSkipLevels - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
number of levels in this skip list
numberOfSkipLevels - Variable in class org.apache.lucene.codecs.MultiLevelSkipListWriter
number of levels in this skip list
numberOfTerms() - Method in class org.apache.lucene.document.ShapeDocValuesField
Returns the number of terms (tessellated triangles) for this shape
numBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
numBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
numBytes - Variable in class org.apache.lucene.util.UnicodeUtil.UTF8CodePoint
 
numBytes() - Method in class org.apache.lucene.util.fst.FST
 
numDeleted - Variable in class org.apache.lucene.index.CheckIndex.Status.LiveDocStatus
Number of deleted documents.
numDeletedDocs() - Method in class org.apache.lucene.index.IndexReader
Returns the number of deleted documents.
numDeletedDocs(SegmentCommitInfo) - Method in class org.apache.lucene.index.IndexWriter
Obtain the number of deleted docs for a pooled reader.
numDeletedDocs(SegmentCommitInfo) - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
Returns the number of deleted documents in the given segments.
numDeletesToMerge(SegmentCommitInfo) - Method in class org.apache.lucene.index.IndexWriter
Returns the number of deletes a merge would claim back if the given segment is merged.
numDeletesToMerge(SegmentCommitInfo) - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
Returns the number of deletes a merge would claim back if the given segment is merged.
numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.FilterMergePolicy
 
numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.MergePolicy
Returns the number of deletes that a merge would claim on the given segment.
numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.NoMergePolicy
 
numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.SoftDeletesRetentionMergePolicy
 
numDims - Variable in class org.apache.lucene.util.bkd.BKDConfig
How many dimensions we are storing at the leaf (data) nodes
numDocs - Variable in class org.apache.lucene.index.IndexWriter.DocStats
The total number of docs in this index, counting docs not yet flushed (still in the RAM buffer), but not counting deleted docs.
numDocs - Variable in class org.apache.lucene.store.FlushInfo
 
numDocs() - Method in class org.apache.lucene.index.BaseCompositeReader
 
numDocs() - Method in class org.apache.lucene.index.FilterCodecReader
 
numDocs() - Method in class org.apache.lucene.index.FilterLeafReader
 
numDocs() - Method in class org.apache.lucene.index.IndexReader
Returns the number of documents in this index.
numDocs() - Method in class org.apache.lucene.index.ParallelLeafReader
 
numDocs() - Method in class org.apache.lucene.index.SegmentReader
 
NUMERIC - org.apache.lucene.index.DocValuesType
A per-document Number
NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Numbers
NumericComparator<T extends Number> - Class in org.apache.lucene.search.comparators
Abstract numeric comparator for comparing numeric values.
NumericComparator(String, T, boolean, Pruning, int) - Constructor for class org.apache.lucene.search.comparators.NumericComparator
 
NumericComparator.NumericLeafComparator - Class in org.apache.lucene.search.comparators
Leaf comparator for NumericComparator that provides skipping functionality
NumericDocValues - Class in org.apache.lucene.index
A per-document numeric value.
NumericDocValues() - Constructor for class org.apache.lucene.index.NumericDocValues
Sole constructor.
NumericDocValuesField - Class in org.apache.lucene.document
Field that stores a per-document long value for scoring, sorting or value retrieval.
NumericDocValuesField(String, long) - Constructor for class org.apache.lucene.document.NumericDocValuesField
Creates a new DocValues field with the specified 64-bit long value
NumericDocValuesField(String, Long) - Constructor for class org.apache.lucene.document.NumericDocValuesField
Creates a new DocValues field with the specified 64-bit long value
NumericLeafComparator(LeafReaderContext) - Constructor for class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
NumericUtils - Class in org.apache.lucene.util
Helper APIs to encode numeric values as sortable bytes and vice-versa.
numericValue() - Method in class org.apache.lucene.document.DoublePoint
 
numericValue() - Method in class org.apache.lucene.document.Field
 
numericValue() - Method in class org.apache.lucene.document.FloatPoint
 
numericValue() - Method in class org.apache.lucene.document.IntPoint
 
numericValue() - Method in class org.apache.lucene.document.LongPoint
 
numericValue() - Method in interface org.apache.lucene.index.IndexableField
Non-null if this field has a numeric value
numFiles - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Number of files referenced by this segment.
numHoles() - Method in class org.apache.lucene.geo.Polygon
returns the number of holes for the polygon
numHoles() - Method in class org.apache.lucene.geo.XYPolygon
returns the number of holes for the polygon
numIndexDims - Variable in class org.apache.lucene.util.bkd.BKDConfig
How many dimensions we are indexing in the internal nodes
numLevels() - Method in class org.apache.lucene.index.Impacts
Return the number of levels on which we have impacts.
numLevels() - Method in class org.apache.lucene.util.hnsw.HnswGraph
Returns the number of levels of the graph
numLevels() - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
Returns the current number of levels in the graph
numPoints() - Method in class org.apache.lucene.geo.Line
returns the number of vertex points
numPoints() - Method in class org.apache.lucene.geo.Polygon
returns the number of vertex points
numPoints() - Method in class org.apache.lucene.geo.XYLine
returns the number of vertex points
numPoints() - Method in class org.apache.lucene.geo.XYPolygon
returns the number of vertex points
numRamDocs() - Method in class org.apache.lucene.index.IndexWriter
Expert: Return the number of documents currently buffered in RAM.
numSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
Number of segments in the index.

O

object - Variable in class org.apache.lucene.util.RefCount
 
obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.FSLockFactory
Implement this method to obtain a lock for a FSDirectory instance.
obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.NativeFSLockFactory
 
obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
 
obtainLock(String) - Method in class org.apache.lucene.codecs.CompoundDirectory
 
obtainLock(String) - Method in class org.apache.lucene.store.BaseDirectory
 
obtainLock(String) - Method in class org.apache.lucene.store.Directory
Acquires and returns a Lock for a file with the given name.
obtainLock(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
obtainLock(String) - Method in class org.apache.lucene.store.FilterDirectory
 
obtainLock(String) - Method in class org.apache.lucene.store.SleepingLockWrapper
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.FSLockFactory
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.LockFactory
Return a new obtained Lock instance identified by lockName.
obtainLock(Directory, String) - Method in class org.apache.lucene.store.NoLockFactory
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
 
obtainLock(Directory, String) - Method in class org.apache.lucene.store.VerifyingLockFactory
 
of(List<T>, boolean) - Static method in class org.apache.lucene.index.DocIDMerger
Construct this from the provided subs
of(List<T>, int, boolean) - Static method in class org.apache.lucene.index.DocIDMerger
Construct this from the provided subs, specifying the maximum sub count
of(DocIdSetIterator, int) - Static method in class org.apache.lucene.util.BitSet
Build a BitSet from the content of the provided DocIdSetIterator.
of(IndexInput, int, int, long) - Static method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
Sole constructor.
offer(float) - Method in class org.apache.lucene.util.hnsw.BlockingFloatHeap
Inserts a value into this heap.
offer(float) - Method in class org.apache.lucene.util.hnsw.FloatHeap
Inserts a value into this heap.
offer(float[]) - Method in class org.apache.lucene.util.hnsw.BlockingFloatHeap
Inserts array of values into this heap.
OffHeapByteVectorValues - Class in org.apache.lucene.codecs.lucene95
Read the vector values from the index input.
OffHeapByteVectorValues.DenseOffHeapVectorValues - Class in org.apache.lucene.codecs.lucene95
Dense vector values that are stored off-heap.
OffHeapFloatVectorValues - Class in org.apache.lucene.codecs.lucene95
Read the vector values from the index input.
OffHeapFloatVectorValues.DenseOffHeapVectorValues - Class in org.apache.lucene.codecs.lucene95
Dense vector values that are stored off-heap.
OffHeapFSTStore - Class in org.apache.lucene.util.fst
Provides off heap storage of finite state machine (FST), using underlying index input instead of byte store on heap
OffHeapFSTStore() - Constructor for class org.apache.lucene.util.fst.OffHeapFSTStore
 
OffHeapQuantizedByteVectorValues - Class in org.apache.lucene.codecs.lucene99
Read the quantized vector values and their score correction values from the index input.
OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues - Class in org.apache.lucene.codecs.lucene99
Dense vector values that are stored off-heap.
OfflinePointReader - Class in org.apache.lucene.util.bkd
Reads points from disk in a fixed-with format, previously written with OfflinePointWriter.
OfflinePointReader(BKDConfig, Directory, String, long, long, byte[]) - Constructor for class org.apache.lucene.util.bkd.OfflinePointReader
 
OfflinePointWriter - Class in org.apache.lucene.util.bkd
Writes points to disk in a fixed-with format.
OfflinePointWriter(BKDConfig, Directory, String, String, long) - Constructor for class org.apache.lucene.util.bkd.OfflinePointWriter
Create a new writer with an unknown number of incoming points
OfflineSorter - Class in org.apache.lucene.util
On-disk sorting of byte arrays.
OfflineSorter(Directory, String) - Constructor for class org.apache.lucene.util.OfflineSorter
Defaults constructor.
OfflineSorter(Directory, String, Comparator<BytesRef>) - Constructor for class org.apache.lucene.util.OfflineSorter
Defaults constructor with a custom comparator.
OfflineSorter(Directory, String, Comparator<BytesRef>, OfflineSorter.BufferSize, int, int, ExecutorService, int) - Constructor for class org.apache.lucene.util.OfflineSorter
All-details constructor.
OfflineSorter.BufferSize - Class in org.apache.lucene.util
A bit more descriptive unit for constructors.
OfflineSorter.ByteSequencesReader - Class in org.apache.lucene.util
Utility class to read length-prefixed byte[] entries from an input.
OfflineSorter.ByteSequencesWriter - Class in org.apache.lucene.util
Utility class to emit length-prefixed byte[] entries to an output stream for sorting.
OfflineSorter.SortInfo - Class in org.apache.lucene.util
Sort info (debugging mostly).
offset - Variable in class org.apache.lucene.util.BytesRef
Offset of first valid byte.
offset - Variable in class org.apache.lucene.util.CharsRef
Offset of first valid character.
offset - Variable in class org.apache.lucene.util.IntsRef
Offset of first valid integer.
offset - Variable in class org.apache.lucene.util.LongsRef
Offset of first valid long.
OffsetAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The start and end character offset of a Token.
OffsetAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of OffsetAttribute.
OffsetAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
Initialize this attribute with startOffset and endOffset of 0.
OFFSETS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require offsets in the returned enum.
oldToNew(int) - Method in class org.apache.lucene.index.Sorter.DocMap
Given a doc ID from the original index, return its ordinal in the sorted index.
omitNorms() - Method in class org.apache.lucene.document.FieldType
True if normalization values should be omitted for the field.
omitNorms() - Method in interface org.apache.lucene.index.IndexableFieldType
True if normalization values should be omitted for the field.
omitsNorms() - Method in class org.apache.lucene.index.FieldInfo
Returns true if norms are explicitly omitted for this field
onClear() - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when the cache is completely cleared.
onClose(IndexReader.CacheKey) - Method in interface org.apache.lucene.index.IndexReader.ClosedListener
Invoked when the resource (segment core, or index reader) that is being cached on is closed.
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.IndexDeletionPolicy
This is called each time the writer completed a commit.
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
Deletes all commits except the most recent one.
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.NoDeletionPolicy
 
onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
 
onDocIdSetCache(Object, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when a DocIdSet is added to this cache.
onDocIdSetEviction(Object, int, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when one or more DocIdSets are removed from this cache.
ONE_GB - Static variable in class org.apache.lucene.util.RamUsageEstimator
One gigabyte bytes.
ONE_KB - Static variable in class org.apache.lucene.util.RamUsageEstimator
One kilobyte bytes.
ONE_MB - Static variable in class org.apache.lucene.util.RamUsageEstimator
One megabyte bytes.
OneMerge(List<SegmentCommitInfo>) - Constructor for class org.apache.lucene.index.MergePolicy.OneMerge
Sole constructor.
OneMerge(CodecReader...) - Constructor for class org.apache.lucene.index.MergePolicy.OneMerge
Create a OneMerge directly from CodecReaders.
OneMerge(MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.MergePolicy.OneMerge
Constructor for wrapping.
OneMergeProgress() - Constructor for class org.apache.lucene.index.MergePolicy.OneMergeProgress
Creates a new merge progress info.
OneMergeWrappingMergePolicy - Class in org.apache.lucene.index
A wrapping merge policy that wraps the MergePolicy.OneMerge objects returned by the wrapped merge policy.
OneMergeWrappingMergePolicy(MergePolicy, UnaryOperator<MergePolicy.OneMerge>) - Constructor for class org.apache.lucene.index.OneMergeWrappingMergePolicy
Constructor
OnHeapFSTStore - Class in org.apache.lucene.util.fst
Provides storage of finite state machine (FST), using byte array or byte store allocated on heap.
OnHeapFSTStore(int) - Constructor for class org.apache.lucene.util.fst.OnHeapFSTStore
 
OnHeapHnswGraph - Class in org.apache.lucene.util.hnsw
An HnswGraph where all nodes and connections are held in memory.
onHit(Object, Query) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when there is a cache hit on a given query.
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.IndexDeletionPolicy
This is called once when a writer is first instantiated to give the policy a chance to remove old commit points.
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
Deletes all commits except the most recent one.
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.NoDeletionPolicy
 
onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
 
onMergeFinished(MergePolicy.OneMerge) - Method in interface org.apache.lucene.index.MergeScheduler.MergeSource
Does finishing for a merge.
onMiss(Object, Query) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when there is a cache miss on a given query.
onOrAfter(Version) - Method in class org.apache.lucene.util.Version
Returns true if this version is the same or after the version from the argument.
onQueryCache(Query, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when a query is added to this cache.
onQueryEviction(Query, long) - Method in class org.apache.lucene.search.LRUQueryCache
Expert: callback when a query is evicted from this cache.
onTragicEvent(Throwable, String) - Method in class org.apache.lucene.index.IndexWriter
This method should be called on a tragic event ie.
onUse(Query) - Method in interface org.apache.lucene.search.QueryCachingPolicy
Callback that is called every time that a cached filter is used.
onUse(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
 
open(Path) - Static method in class org.apache.lucene.store.FSDirectory
Creates an FSDirectory instance, trying to pick the best implementation given the current environment.
open(Path, LockFactory) - Static method in class org.apache.lucene.store.FSDirectory
Just like FSDirectory.open(Path), but allows you to also specify a custom LockFactory.
open(IndexCommit) - Static method in class org.apache.lucene.index.DirectoryReader
Expert: returns an IndexReader reading the index in the given IndexCommit.
open(IndexCommit, int, Comparator<LeafReader>) - Static method in class org.apache.lucene.index.DirectoryReader
Expert: returns an IndexReader reading the index on the given IndexCommit.
open(IndexWriter) - Static method in class org.apache.lucene.index.DirectoryReader
Open a near real time IndexReader from the IndexWriter.
open(IndexWriter, boolean, boolean) - Static method in class org.apache.lucene.index.DirectoryReader
Expert: open a near real time IndexReader from the IndexWriter, controlling whether past deletions should be applied.
open(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
Returns a IndexReader reading the index in the given Directory
open(Directory, Comparator<LeafReader>) - Static method in class org.apache.lucene.index.DirectoryReader
Returns a IndexReader for the the index in the given Directory
open(Directory, SegmentInfos, List<? extends LeafReader>, Comparator<LeafReader>) - Static method in class org.apache.lucene.index.StandardDirectoryReader
This constructor is only used for StandardDirectoryReader.doOpenIfChanged(SegmentInfos), as well as NRT replication.
openChecksumInput(String, IOContext) - Method in class org.apache.lucene.store.Directory
Opens a checksum-computing stream for reading an existing file.
openIfChanged(DirectoryReader) - Static method in class org.apache.lucene.index.DirectoryReader
If the index has changed since the provided reader was opened, open and return a new reader; else, return null.
openIfChanged(DirectoryReader, IndexCommit) - Static method in class org.apache.lucene.index.DirectoryReader
If the IndexCommit differs from what the provided reader is searching, open and return a new reader; else, return null.
openIfChanged(DirectoryReader, IndexWriter) - Static method in class org.apache.lucene.index.DirectoryReader
Expert: If there changes (committed or not) in the IndexWriter versus what the provided reader is searching, then open and return a new IndexReader searching both committed and uncommitted changes from the writer; else, return null (though, the current implementation never returns null).
openIfChanged(DirectoryReader, IndexWriter, boolean) - Static method in class org.apache.lucene.index.DirectoryReader
Expert: Opens a new reader, if there are any changes, controlling whether past deletions should be applied.
openInput(String, IOContext) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
openInput(String, IOContext) - Method in class org.apache.lucene.store.Directory
Opens a stream for reading an existing file.
openInput(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
openInput(String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
 
openInput(String, IOContext) - Method in class org.apache.lucene.store.MMapDirectory
Creates an IndexInput for the file with the given name.
openInput(String, IOContext) - Method in class org.apache.lucene.store.NIOFSDirectory
 
openInput(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
openMode - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
openReaderPassed - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if we were able to open a CodecReader on this segment.
openResource(String) - Method in class org.apache.lucene.util.ClasspathResourceLoader
 
openResource(String) - Method in class org.apache.lucene.util.ModuleResourceLoader
 
openResource(String) - Method in interface org.apache.lucene.util.ResourceLoader
Opens a named resource
Operations - Class in org.apache.lucene.util.automaton
Automata operations.
optional(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the union of the empty string and the language of the given automaton.
Options() - Constructor for class org.apache.lucene.index.CheckIndex.Options
Sole constructor.
or(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
Does in-place OR of the bits provided by the iterator.
or(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
 
or(DocIdSetIterator) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
or(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this OR other
or(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
this = this OR other
ord - Variable in class org.apache.lucene.index.LeafReaderContext
The reader's ord in the top-level's leaves array
ord - Variable in class org.apache.lucene.index.OrdTermState
Term ordinal, i.e.
ord() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
ord() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
ord() - Method in class org.apache.lucene.index.MultiTermsEnum
 
ord() - Method in class org.apache.lucene.index.TermsEnum
Returns ordinal position for current term.
ord() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
ord() - Method in interface org.apache.lucene.util.BytesRefArray.IndexedBytesRefIterator
Returns the ordinal position of the element that was returned in the latest call of BytesRefIterator.next().
ord() - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
Return the offset of the next value to read.
ord() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
Returns the current position
ord() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
Returns the current ord in the stream (number of values that have been written so far minus one).
OrdinalMap - Class in org.apache.lucene.index
Maps per-segment ordinals to/from global ordinal space, using a compact packed-ints representation.
OrdinalTranslatedKnnCollector - Class in org.apache.lucene.util.hnsw
Wraps a provided KnnCollector object, translating the provided vectorId ordinal to a documentId
OrdinalTranslatedKnnCollector(KnnCollector, IntToIntFunction) - Constructor for class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
ordInParent - Variable in class org.apache.lucene.index.IndexReaderContext
the ord for this reader in the parent, 0 if parent is null
OrdTermState - Class in org.apache.lucene.index
An ordinal based TermState
OrdTermState() - Constructor for class org.apache.lucene.index.OrdTermState
Sole constructor.
ordToDoc(int) - Method in interface org.apache.lucene.util.hnsw.RandomAccessVectorValues
Translates vector ordinal to the correct document ID.
ordToDoc(int) - Method in class org.apache.lucene.util.hnsw.RandomVectorScorer.AbstractRandomVectorScorer
 
ordToDoc(int) - Method in interface org.apache.lucene.util.hnsw.RandomVectorScorer
Translates vector ordinal to the correct document ID.
OrdToDocDISIReaderConfiguration - Class in org.apache.lucene.codecs.lucene95
Configuration for DirectMonotonicReader and IndexedDISI for reading sparse vectors.
ordValue() - Method in class org.apache.lucene.index.FilterSortedDocValues
 
ordValue() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
 
ordValue() - Method in class org.apache.lucene.index.SortedDocValues
Returns the ordinal for the current docID.
org.apache.lucene.analysis - package org.apache.lucene.analysis
Text analysis.
org.apache.lucene.analysis.standard - package org.apache.lucene.analysis.standard
Fast, general-purpose grammar-based tokenizer StandardTokenizer implements the Word Break rules from the Unicode Text Segmentation algorithm, as specified in Unicode Standard Annex #29.
org.apache.lucene.analysis.tokenattributes - package org.apache.lucene.analysis.tokenattributes
General-purpose attributes for text analysis.
org.apache.lucene.codecs - package org.apache.lucene.codecs
Codecs API: API for customization of the encoding and structure of the index.
org.apache.lucene.codecs.compressing - package org.apache.lucene.codecs.compressing
Compressing helper classes.
org.apache.lucene.codecs.lucene90 - package org.apache.lucene.codecs.lucene90
Lucene 9.0 file format.
org.apache.lucene.codecs.lucene90.blocktree - package org.apache.lucene.codecs.lucene90.blocktree
BlockTree terms dictionary.
org.apache.lucene.codecs.lucene90.compressing - package org.apache.lucene.codecs.lucene90.compressing
Lucene 9.0 compressing format.
org.apache.lucene.codecs.lucene94 - package org.apache.lucene.codecs.lucene94
Lucene 9.4 file format.
org.apache.lucene.codecs.lucene95 - package org.apache.lucene.codecs.lucene95
Lucene 9.5 file format.
org.apache.lucene.codecs.lucene99 - package org.apache.lucene.codecs.lucene99
Lucene 9.9 file format.
org.apache.lucene.codecs.perfield - package org.apache.lucene.codecs.perfield
Postings format that can delegate to different formats per-field.
org.apache.lucene.document - package org.apache.lucene.document
The logical representation of a Document for indexing and searching.
org.apache.lucene.geo - package org.apache.lucene.geo
Geospatial Utility Implementations for Lucene Core
org.apache.lucene.index - package org.apache.lucene.index
Code to maintain and access indices.
org.apache.lucene.internal.tests - package org.apache.lucene.internal.tests
Internal bridges to package-private internals, for use by the lucene test framework only.
org.apache.lucene.internal.vectorization - package org.apache.lucene.internal.vectorization
Internal implementations to support SIMD vectorization.
org.apache.lucene.search - package org.apache.lucene.search
Code to search indices.
org.apache.lucene.search.comparators - package org.apache.lucene.search.comparators
Comparators, used to compare hits so as to determine their sort order when collecting the top results with TopFieldCollector.
org.apache.lucene.search.knn - package org.apache.lucene.search.knn
Classes related to vector search: knn and vector fields.
org.apache.lucene.search.similarities - package org.apache.lucene.search.similarities
This package contains the various ranking models that can be used in Lucene.
org.apache.lucene.store - package org.apache.lucene.store
Binary i/o API, used for all index data.
org.apache.lucene.util - package org.apache.lucene.util
Some utility classes.
org.apache.lucene.util.automaton - package org.apache.lucene.util.automaton
Finite-state automaton for regular expressions.
org.apache.lucene.util.bkd - package org.apache.lucene.util.bkd
Block KD-tree, implementing the generic spatial data structure described in this paper.
org.apache.lucene.util.compress - package org.apache.lucene.util.compress
Compression utilities.
org.apache.lucene.util.fst - package org.apache.lucene.util.fst
Finite state transducers
org.apache.lucene.util.graph - package org.apache.lucene.util.graph
Utility classes for working with token streams as graphs.
org.apache.lucene.util.hnsw - package org.apache.lucene.util.hnsw
Navigable Small-World graph, nominally Hierarchical but currently only has a single layer.
org.apache.lucene.util.hppc - package org.apache.lucene.util.hppc
package holding hppc related classes.
org.apache.lucene.util.mutable - package org.apache.lucene.util.mutable
Comparable object wrappers
org.apache.lucene.util.packed - package org.apache.lucene.util.packed
Packed integer arrays and streams.
org.apache.lucene.util.quantization - package org.apache.lucene.util.quantization
Provides quantization methods for scaling vector values to smaller data types and possibly fewer dimensions
orient(double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
Returns a positive value if points a, b, and c are arranged in counter-clockwise order, negative value if clockwise, zero if collinear.
OS_ARCH - Static variable in class org.apache.lucene.util.Constants
The value of System.getProperty("os.arch").
OS_NAME - Static variable in class org.apache.lucene.util.Constants
The value of System.getProperty("os.name").
OS_VERSION - Static variable in class org.apache.lucene.util.Constants
The value of System.getProperty("os.version").
OTHER - org.apache.lucene.index.MergePolicy.OneMergeProgress.PauseReason
Other reason.
out - Variable in class org.apache.lucene.store.FilterIndexOutput
 
out - Variable in class org.apache.lucene.util.bkd.OfflinePointWriter
 
out - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
 
out - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
output - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
output - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
 
output - Variable in class org.apache.lucene.util.fst.Util.FSTPath
Holds cost plus any usage-specific output:
output - Variable in class org.apache.lucene.util.fst.Util.Result
 
output() - Method in class org.apache.lucene.util.fst.FST.Arc
 
OUTPUT_AS_BYTE_ARRAY - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
 
OUTPUT_AS_MANY_BUFFERS - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
 
OUTPUT_AS_MANY_BUFFERS_LUCENE - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
 
OUTPUT_AS_ONE_BUFFER - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
 
output1 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
 
output2 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
 
outputs - Variable in class org.apache.lucene.util.fst.FST
 
Outputs<T> - Class in org.apache.lucene.util.fst
Represents the outputs for an FST, providing the basic algebra required for building and traversing the FST.
Outputs() - Constructor for class org.apache.lucene.util.fst.Outputs
 
OutputStreamDataOutput - Class in org.apache.lucene.store
A DataOutput wrapping a plain OutputStream.
OutputStreamDataOutput(OutputStream) - Constructor for class org.apache.lucene.store.OutputStreamDataOutput
 
OutputStreamIndexOutput - Class in org.apache.lucene.store
Implementation class for buffered IndexOutput that writes to an OutputStream.
OutputStreamIndexOutput(String, String, OutputStream, int) - Constructor for class org.apache.lucene.store.OutputStreamIndexOutput
Creates a new OutputStreamIndexOutput with the given buffer size.
outputToString(Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
outputToString(Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
outputToString(BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
outputToString(CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
outputToString(PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
outputToString(IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
outputToString(T) - Method in class org.apache.lucene.util.fst.Outputs
 
overheadPerValue(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the overhead per value, in bits.
overheadRatio(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the overhead ratio (overhead per value / bits per value).
oversize(int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns an array size >= minTargetSize, generally over-allocating exponentially to achieve amortized linear-time cost as the array grows.
owner - Variable in class org.apache.lucene.index.OrdinalMap
Cache key of whoever asked for this awful thing

P

pack(double...) - Static method in class org.apache.lucene.document.DoublePoint
Pack a double point into a BytesRef
pack(float...) - Static method in class org.apache.lucene.document.FloatPoint
Pack a float point into a BytesRef
pack(int...) - Static method in class org.apache.lucene.document.IntPoint
Pack an integer point into a BytesRef
pack(long...) - Static method in class org.apache.lucene.document.LongPoint
Pack a long point into a BytesRef
PACKED - org.apache.lucene.util.packed.PackedInts.Format
Compact format, all bits are written contiguously.
PACKED_SINGLE_BLOCK - org.apache.lucene.util.packed.PackedInts.Format
Deprecated.
packedBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
 
packedBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
Return a new PackedLongValues.Builder that will compress efficiently positive integers.
packedBytesLength - Variable in class org.apache.lucene.util.bkd.BKDConfig
numDataDims * bytesPerDim
PackedDataInput - Class in org.apache.lucene.util.packed
A DataInput wrapper to read unaligned, variable-length packed integers.
PackedDataInput(DataInput) - Constructor for class org.apache.lucene.util.packed.PackedDataInput
Create a new instance that wraps in.
PackedDataOutput - Class in org.apache.lucene.util.packed
A DataOutput wrapper to write unaligned, variable-length packed integers.
PackedDataOutput(DataOutput) - Constructor for class org.apache.lucene.util.packed.PackedDataOutput
Create a new instance that wraps out.
packedIndexBytesLength - Variable in class org.apache.lucene.util.bkd.BKDConfig
numIndexDims * bytesPerDim
PackedInts - Class in org.apache.lucene.util.packed
Simplistic compression for array of unsigned long values.
PackedInts() - Constructor for class org.apache.lucene.util.packed.PackedInts
 
PackedInts.Decoder - Interface in org.apache.lucene.util.packed
A decoder for packed integers.
PackedInts.Encoder - Interface in org.apache.lucene.util.packed
An encoder for packed integers.
PackedInts.Format - Enum in org.apache.lucene.util.packed
A format to write packed ints.
PackedInts.FormatAndBits - Class in org.apache.lucene.util.packed
Simple class that holds a format and a number of bits per value.
PackedInts.Mutable - Class in org.apache.lucene.util.packed
A packed integer array that can be modified.
PackedInts.NullReader - Class in org.apache.lucene.util.packed
A PackedInts.Reader which has all its values equal to 0 (bitsPerValue = 0).
PackedInts.Reader - Class in org.apache.lucene.util.packed
A read-only random access array of positive integers.
PackedInts.ReaderIterator - Interface in org.apache.lucene.util.packed
Run-once iterator interface, to decode previously saved PackedInts.
PackedInts.Writer - Class in org.apache.lucene.util.packed
A write-once Writer.
PackedLongValues - Class in org.apache.lucene.util.packed
Utility class to compress integers into a LongValues instance.
PackedLongValues.Builder - Class in org.apache.lucene.util.packed
A Builder for a PackedLongValues instance.
PackedLongValues.Iterator - Class in org.apache.lucene.util.packed
An iterator over long values.
PackedTokenAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
PackedTokenAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Constructs the attribute implementation.
packedValue() - Method in interface org.apache.lucene.util.bkd.PointValue
Returns the packed values for the dimensions
packedValueDocIDBytes() - Method in interface org.apache.lucene.util.bkd.PointValue
Returns the byte representation of the packed value together with the docID
PagedBytes - Class in org.apache.lucene.util
Represents a logical byte[] as a series of pages.
PagedBytes(int) - Constructor for class org.apache.lucene.util.PagedBytes
1<<blockBits must be bigger than biggest single BytesRef slice that will be pulled
PagedBytes.PagedBytesDataInput - Class in org.apache.lucene.util
Input that transparently iterates over pages
PagedBytes.PagedBytesDataOutput - Class in org.apache.lucene.util
Output that transparently spills to new pages as necessary
PagedBytes.Reader - Class in org.apache.lucene.util
Provides methods to read BytesRefs from a frozen PagedBytes.
PagedBytesDataOutput() - Constructor for class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
 
PagedGrowableWriter - Class in org.apache.lucene.util.packed
PagedGrowableWriter(long, int, int, float) - Constructor for class org.apache.lucene.util.packed.PagedGrowableWriter
Create a new PagedGrowableWriter instance.
PagedMutable - Class in org.apache.lucene.util.packed
PagedMutable(long, int, int, float) - Constructor for class org.apache.lucene.util.packed.PagedMutable
Create a new PagedMutable instance.
PairOutputs<A,​B> - Class in org.apache.lucene.util.fst
An FST Outputs implementation, holding two other outputs.
PairOutputs(Outputs<A>, Outputs<B>) - Constructor for class org.apache.lucene.util.fst.PairOutputs
 
PairOutputs.Pair<A,​B> - Class in org.apache.lucene.util.fst
Holds a single pair of two outputs.
ParallelCompositeReader - Class in org.apache.lucene.index
An CompositeReader which reads multiple, parallel indexes.
ParallelCompositeReader(boolean, CompositeReader...) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
Create a ParallelCompositeReader based on the provided readers.
ParallelCompositeReader(boolean, CompositeReader[], CompositeReader[]) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
Expert: create a ParallelCompositeReader based on the provided readers and storedFieldReaders; when a document is loaded, only storedFieldsReaders will be used.
ParallelCompositeReader(CompositeReader...) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
Create a ParallelCompositeReader based on the provided readers; auto-closes the given readers on IndexReader.close().
ParallelLeafReader - Class in org.apache.lucene.index
An LeafReader which reads multiple, parallel indexes.
ParallelLeafReader(boolean, LeafReader...) - Constructor for class org.apache.lucene.index.ParallelLeafReader
Create a ParallelLeafReader based on the provided readers.
ParallelLeafReader(boolean, LeafReader[], LeafReader[]) - Constructor for class org.apache.lucene.index.ParallelLeafReader
Expert: create a ParallelLeafReader based on the provided readers and storedFieldReaders; when a document is loaded, only storedFieldsReaders will be used.
ParallelLeafReader(LeafReader...) - Constructor for class org.apache.lucene.index.ParallelLeafReader
Create a ParallelLeafReader based on the provided readers; auto-closes the given readers on IndexReader.close().
parent - Variable in class org.apache.lucene.index.IndexReaderContext
The reader context for this reader's immediate parent, or null if none
parentField - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
parent document field
parentQuery - Variable in class org.apache.lucene.search.Weight
 
parse(String) - Static method in class org.apache.lucene.geo.SimpleWKTShapeParser
 
parse(String) - Static method in class org.apache.lucene.util.Version
Parse a version number of the form "major.minor.bugfix.prerelease".
parseExpectedType(String, SimpleWKTShapeParser.ShapeType) - Static method in class org.apache.lucene.geo.SimpleWKTShapeParser
 
parseGeneration(String) - Static method in class org.apache.lucene.index.IndexFileNames
Returns the generation from this file name, or 0 if there is no generation.
parseInt(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Parses a char array into an int.
parseInt(char[], int, int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Parses the string argument as if it was an int value and returns the result.
parseLeniently(String) - Static method in class org.apache.lucene.util.Version
Parse the given version number as a constant or dot based version.
parseOptions(String[]) - Static method in class org.apache.lucene.index.CheckIndex
Parse command line args into fields
parseSegmentName(String) - Static method in class org.apache.lucene.index.IndexFileNames
Parses the segment name out of the given file name.
partial - Variable in class org.apache.lucene.index.CheckIndex.Status
True if we checked only specific segments (CheckIndex.checkIndex(List)) was called with non-null argument).
partition(BKDConfig, int, int, int, MutablePointTree, int, int, int, BytesRef, BytesRef) - Static method in class org.apache.lucene.util.bkd.MutablePointTreeReaderUtils
Partition points around mid.
PathSlice(PointWriter, long, long) - Constructor for class org.apache.lucene.util.bkd.BKDRadixSelector.PathSlice
 
pause(long) - Method in class org.apache.lucene.index.MergeRateLimiter
 
pause(long) - Method in class org.apache.lucene.store.RateLimiter
Pauses, if necessary, to keep the instantaneous IO rate at or below the target.
pause(long) - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
Pauses, if necessary, to keep the instantaneous IO rate at or below the target.
PAUSED - org.apache.lucene.index.MergePolicy.OneMergeProgress.PauseReason
Temporarily paused because of exceeded throughput rate.
pauseNanos(long, MergePolicy.OneMergeProgress.PauseReason, BooleanSupplier) - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
Pauses the calling thread for at least pauseNanos nanoseconds unless the merge is aborted or the external condition returns false, in which case control returns immediately.
PAY_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
Filename extension for payloads and offsets.
payload - Variable in class org.apache.lucene.util.fst.Util.FSTPath
 
PayloadAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The payload of a Token.
PayloadAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of PayloadAttribute.
PayloadAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Initialize this attribute with no payload.
PayloadAttributeImpl(BytesRef) - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Initialize this attribute with the given payload.
PAYLOADS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require payloads in the returned enum.
payStartFP - Variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
file pointer to the start of the payloads enumeration, in Lucene99PostingsFormat.PAY_EXTENSION file
peek() - Method in class org.apache.lucene.util.hnsw.BlockingFloatHeap
Retrieves, but does not remove, the head of this heap.
peek() - Method in class org.apache.lucene.util.hnsw.FloatHeap
Retrieves, but does not remove, the head of this heap.
PENDING_SEGMENTS - Static variable in class org.apache.lucene.index.IndexFileNames
Name of pending index segment file
PER_FIELD_FORMAT_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
FieldInfo attribute name used to store the format name for each field.
PER_FIELD_FORMAT_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
FieldInfo attribute name used to store the format name for each field.
PER_FIELD_FORMAT_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
FieldInfo attribute name used to store the format name for each field.
PER_FIELD_NAME - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
Name of this DocValuesFormat.
PER_FIELD_NAME - Static variable in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
Name of this KnnVectorsFormat.
PER_FIELD_NAME - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
Name of this PostingsFormat.
PER_FIELD_REUSE_STRATEGY - Static variable in class org.apache.lucene.analysis.Analyzer
A predefined Analyzer.ReuseStrategy that reuses components per-field by maintaining a Map of TokenStreamComponent per field name.
PER_FIELD_SUFFIX_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
FieldInfo attribute name used to store the segment suffix name for each field.
PER_FIELD_SUFFIX_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
FieldInfo attribute name used to store the segment suffix name for each field.
PER_FIELD_SUFFIX_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
FieldInfo attribute name used to store the segment suffix name for each field.
PerFieldDocValuesFormat - Class in org.apache.lucene.codecs.perfield
Enables per field docvalues support.
PerFieldDocValuesFormat() - Constructor for class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
Sole constructor.
PerFieldKnnVectorsFormat - Class in org.apache.lucene.codecs.perfield
Enables per field numeric vector support.
PerFieldKnnVectorsFormat() - Constructor for class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat
Sole constructor.
PerFieldKnnVectorsFormat.FieldsReader - Class in org.apache.lucene.codecs.perfield
VectorReader that can wrap multiple delegate readers, selected by field.
PerFieldPostingsFormat - Class in org.apache.lucene.codecs.perfield
Enables per field postings support.
PerFieldPostingsFormat() - Constructor for class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
Sole constructor.
PerFieldSimilarityWrapper - Class in org.apache.lucene.search.similarities
Provides the ability to use a different Similarity for different fields.
PerFieldSimilarityWrapper() - Constructor for class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
Sole constructor.
PersistentSnapshotDeletionPolicy - Class in org.apache.lucene.index
A SnapshotDeletionPolicy which adds a persistence layer so that snapshots can be maintained across the life of an application.
PersistentSnapshotDeletionPolicy(IndexDeletionPolicy, Directory) - Constructor for class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
PersistentSnapshotDeletionPolicy wraps another IndexDeletionPolicy to enable flexible snapshotting, passing IndexWriterConfig.OpenMode.CREATE_OR_APPEND by default.
PersistentSnapshotDeletionPolicy(IndexDeletionPolicy, Directory, IndexWriterConfig.OpenMode) - Constructor for class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
PersistentSnapshotDeletionPolicy wraps another IndexDeletionPolicy to enable flexible snapshotting.
perThreadHardLimitMB - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Sets the hard upper bound on RAM usage for a single segment, after which the segment is forced to flush.
PhraseMatcher - Class in org.apache.lucene.search
Base class for exact and sloppy phrase matching
PhraseQuery - Class in org.apache.lucene.search
A Query that matches documents containing a particular sequence of terms.
PhraseQuery(int, String, String...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field, and at a maximum edit distance of slop.
PhraseQuery(int, String, BytesRef...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field, and at a maximum edit distance of slop.
PhraseQuery(String, String...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field.
PhraseQuery(String, BytesRef...) - Constructor for class org.apache.lucene.search.PhraseQuery
Create a phrase query which will match documents that contain the given list of terms at consecutive positions in field.
PhraseQuery.Builder - Class in org.apache.lucene.search
A builder for phrase queries.
PhraseQuery.PostingsAndFreq - Class in org.apache.lucene.search
Term postings and position information for phrase matching
PhraseWeight - Class in org.apache.lucene.search
Expert: Weight class for phrase matching
PhraseWeight(Query, String, IndexSearcher, ScoreMode) - Constructor for class org.apache.lucene.search.PhraseWeight
Expert: Creates PhraseWeight instance
pivot - Variable in class org.apache.lucene.util.StringSorter
 
pivotBuilder - Variable in class org.apache.lucene.util.StringSorter
 
Point - Class in org.apache.lucene.geo
Represents a point on the earth's surface.
Point(double, double) - Constructor for class org.apache.lucene.geo.Point
Creates a new Point from the supplied latitude/longitude.
POINT - org.apache.lucene.document.ShapeField.DecodedTriangle.TYPE
all coordinates are equal
POINT - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
pointCount - Variable in class org.apache.lucene.util.bkd.BKDWriter
 
pointDimensionCount() - Method in class org.apache.lucene.document.FieldType
 
pointDimensionCount() - Method in interface org.apache.lucene.index.IndexableFieldType
If this is positive (representing the number of point dimensions), the field is indexed as a point.
pointIndexDimensionCount() - Method in class org.apache.lucene.document.FieldType
 
pointIndexDimensionCount() - Method in interface org.apache.lucene.index.IndexableFieldType
The number of dimensions used for the index key
pointInPolygon(List<Tessellator.Triangle>, double, double) - Static method in class org.apache.lucene.geo.Tessellator
Brute force compute if a point is in the polygon by traversing entire triangulation todo: speed this up using either binary tree or prefix coding (filtering by bounding box of triangle)
PointInSetQuery - Class in org.apache.lucene.search
Abstract query class to find all documents whose single or multi-dimensional point values, previously indexed with e.g.
PointInSetQuery(String, int, int, PointInSetQuery.Stream) - Constructor for class org.apache.lucene.search.PointInSetQuery
The packedPoints iterator must be in sorted order.
PointInSetQuery.Stream - Class in org.apache.lucene.search
Iterator of encoded point values.
pointInTriangle(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.Tessellator
compute whether the given x, y point is in a triangle; uses the winding order method
pointInTriangle(double, double, double, double, double, double, double, double, double, double, double, double) - Static method in interface org.apache.lucene.geo.Component2D
Compute whether the given x, y point is in a triangle; uses the winding order method
pointNumBytes() - Method in class org.apache.lucene.document.FieldType
 
pointNumBytes() - Method in interface org.apache.lucene.index.IndexableFieldType
The number of bytes in each dimension's values.
PointRangeQuery - Class in org.apache.lucene.search
Abstract class for range queries against single or multidimensional points such as IntPoint.
PointRangeQuery(String, byte[], byte[], int) - Constructor for class org.apache.lucene.search.PointRangeQuery
Expert: create a multidimensional range query for point values.
PointReader - Interface in org.apache.lucene.util.bkd
One pass iterator through all points previously written with a PointWriter, abstracting away whether points are read from (offline) disk or simple arrays in heap.
pointsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes points index
pointsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
pointsFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
PointsFormat - Class in org.apache.lucene.codecs
Encodes/decodes indexed points.
PointsFormat() - Constructor for class org.apache.lucene.codecs.PointsFormat
Creates a new point format.
PointsReader - Class in org.apache.lucene.codecs
Abstract API to visit point values.
PointsReader() - Constructor for class org.apache.lucene.codecs.PointsReader
Sole constructor.
pointsReaders - Variable in class org.apache.lucene.index.MergeState
Point readers to merge
pointsStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of PointValues (null if PointValues could not be tested).
PointsWriter - Class in org.apache.lucene.codecs
Abstract API to write points
PointsWriter() - Constructor for class org.apache.lucene.codecs.PointsWriter
Sole constructor.
pointValue() - Method in class org.apache.lucene.util.bkd.HeapPointReader
 
pointValue() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
 
pointValue() - Method in interface org.apache.lucene.util.bkd.PointReader
Sets the packed value in the provided ByteRef
PointValue - Interface in org.apache.lucene.util.bkd
Represents a dimensional point value written in the BKD tree.
PointValues - Class in org.apache.lucene.index
Access to indexed numeric values.
PointValues() - Constructor for class org.apache.lucene.index.PointValues
Default constructor
PointValues.IntersectVisitor - Interface in org.apache.lucene.index
We recurse the PointValues.PointTree, using a provided instance of this to guide the recursion.
PointValues.PointTree - Interface in org.apache.lucene.index
Basic operations to read the KD-tree.
PointValues.Relation - Enum in org.apache.lucene.index
Used by PointValues.intersect(org.apache.lucene.index.PointValues.IntersectVisitor) to check how each recursive cell corresponds to the query.
PointWriter - Interface in org.apache.lucene.util.bkd
Appends many points, and then at the end provides a PointReader to iterate those points.
poll() - Method in class org.apache.lucene.util.hnsw.BlockingFloatHeap
Removes and returns the head of the heap
poll() - Method in class org.apache.lucene.util.hnsw.FloatHeap
Removes and returns the head of the heap
Polygon - Class in org.apache.lucene.geo
Represents a closed polygon on the earth's surface.
Polygon(double[], double[], Polygon...) - Constructor for class org.apache.lucene.geo.Polygon
Creates a new Polygon from the supplied latitude/longitude array, and optionally any holes.
POLYGON - org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 
pop() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
pop() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
Removes the top element and returns its node id.
pop() - Method in class org.apache.lucene.util.LongHeap
Removes and returns the least element of the PriorityQueue in log(size) time.
pop() - Method in class org.apache.lucene.util.PriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.
popNode() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
populateResults(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopDocsCollector
Populates the results array with the ScoreDoc instances.
populateResults(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopFieldCollector
 
populateScores(ScoreDoc[], IndexSearcher, Query) - Static method in class org.apache.lucene.search.TopFieldCollector
Populate scores of the given topDocs.
popUntilNearestKNodes() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
POS_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
Filename extension for positions.
POS_SEP - Static variable in class org.apache.lucene.analysis.TokenStreamToAutomaton
We create transition between two adjacent tokens.
posArcsStart() - Method in class org.apache.lucene.util.fst.FST.Arc
Where the first arc in the array starts; only valid if bytesPerArc != 0
position() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
PositionIncrementAttribute - Interface in org.apache.lucene.analysis.tokenattributes
Determines the position of this token relative to the previous Token in a TokenStream, used in phrase searching.
PositionIncrementAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of PositionIncrementAttribute.
PositionIncrementAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
Initialize this attribute with position increment of 1
PositionLengthAttribute - Interface in org.apache.lucene.analysis.tokenattributes
Determines how many positions this token spans.
PositionLengthAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of PositionLengthAttribute.
PositionLengthAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
Initializes this attribute with position length of 1.
POSITIONS - Static variable in class org.apache.lucene.index.PostingsEnum
Flag to pass to TermsEnum.postings(PostingsEnum, int) if you require term positions in the returned enum.
PositiveIntOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a non-negative long value.
PositiveScoresOnlyCollector - Class in org.apache.lucene.search
A Collector implementation which wraps another Collector and makes sure only documents with scores > 0 are collected.
PositiveScoresOnlyCollector(Collector) - Constructor for class org.apache.lucene.search.PositiveScoresOnlyCollector
 
posStartFP - Variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
file pointer to the start of the positions enumeration, in Lucene99PostingsFormat.POS_EXTENSION file
postings(FieldInfo, BlockTermState, PostingsEnum, int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
postings(FieldInfo, BlockTermState, PostingsEnum, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
Must fully consume state, since after this call that TermState may be reused.
postings(PostingsEnum) - Method in class org.apache.lucene.index.TermsEnum
Get PostingsEnum for the current term.
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.FilteredTermsEnum
 
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.MultiTermsEnum
 
postings(PostingsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
Get PostingsEnum for the current term, with control over whether freqs, positions, offsets or payloads are required.
postings(PostingsEnum, int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
postings(Term) - Method in class org.apache.lucene.index.LeafReader
Returns PostingsEnum for the specified term with PostingsEnum.FREQS.
postings(Term, int) - Method in class org.apache.lucene.index.LeafReader
Returns PostingsEnum for the specified term.
PostingsAndFreq(PostingsEnum, ImpactsEnum, int, List<Term>) - Constructor for class org.apache.lucene.search.PhraseQuery.PostingsAndFreq
 
PostingsAndFreq(PostingsEnum, ImpactsEnum, int, Term...) - Constructor for class org.apache.lucene.search.PhraseQuery.PostingsAndFreq
Creates PostingsAndFreq instance
postingsEnum - Variable in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
PostingsEnum for this sub-reader.
PostingsEnum - Class in org.apache.lucene.index
Iterates through the postings.
PostingsEnum() - Constructor for class org.apache.lucene.index.PostingsEnum
Sole constructor.
postingsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes postings
postingsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
postingsFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
PostingsFormat - Class in org.apache.lucene.codecs
Encodes/decodes terms, postings, and proximity data.
PostingsFormat(String) - Constructor for class org.apache.lucene.codecs.PostingsFormat
Creates a new postings format.
PostingsReaderBase - Class in org.apache.lucene.codecs
The core terms dictionaries (BlockTermsReader, BlockTreeTermsReader) interact with a single instance of this class to manage creation of PostingsEnum and PostingsEnum instances.
PostingsReaderBase() - Constructor for class org.apache.lucene.codecs.PostingsReaderBase
Sole constructor.
PostingsWriterBase - Class in org.apache.lucene.codecs
Class that plugs into term dictionaries, such as Lucene90BlockTreeTermsWriter, and handles writing postings.
PostingsWriterBase() - Constructor for class org.apache.lucene.codecs.PostingsWriterBase
Sole constructor.
pq - Variable in class org.apache.lucene.search.TopDocsCollector
The priority queue which holds the top documents.
predicateFunction(InnerT) - Method in class org.apache.lucene.util.FilterIterator
returns true, if this element should be returned by FilterIterator.next().
PrefixCodedTerms - Class in org.apache.lucene.index
Prefix codes term instances (prefixes are shared).
PrefixCodedTerms.Builder - Class in org.apache.lucene.index
Builds a PrefixCodedTerms: call add repeatedly, then finish.
PrefixCodedTerms.TermIterator - Class in org.apache.lucene.index
An iterator over the list of terms stored in a PrefixCodedTerms.
PrefixQuery - Class in org.apache.lucene.search
A Query that matches documents containing terms with a specified prefix.
PrefixQuery(Term) - Constructor for class org.apache.lucene.search.PrefixQuery
Constructs a query for terms starting with prefix.
PrefixQuery(Term, MultiTermQuery.RewriteMethod) - Constructor for class org.apache.lucene.search.PrefixQuery
Constructs a query for terms starting with prefix using a defined RewriteMethod
prepareCommit() - Method in class org.apache.lucene.index.IndexWriter
Expert: prepare for commit.
prepareCommit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
The first stage of a 2-phase commit.
PrepareCommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.PrepareCommitFailException
Sole constructor.
prerelease - Variable in class org.apache.lucene.util.Version
Prerelease version, currently 0 (alpha), 1 (beta), or 2 (final)
previous(int) - Method in class org.apache.lucene.util.compress.LZ4.FastCompressionHashTable
 
prevSetBit(int) - Method in class org.apache.lucene.util.BitSet
Returns the index of the last set bit before or on the index specified.
prevSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
 
prevSetBit(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
 
prevSetBit(long) - Method in class org.apache.lucene.util.LongBitSet
Returns the index of the last set bit before or on the index specified.
primitiveSizes - Static variable in class org.apache.lucene.util.RamUsageEstimator
Sizes of primitive classes.
PrintStreamInfoStream - Class in org.apache.lucene.util
InfoStream implementation over a PrintStream such as System.out.
PrintStreamInfoStream(PrintStream) - Constructor for class org.apache.lucene.util.PrintStreamInfoStream
 
PrintStreamInfoStream(PrintStream, int) - Constructor for class org.apache.lucene.util.PrintStreamInfoStream
 
PriorityQueue<T> - Class in org.apache.lucene.util
A priority queue maintains a partial ordering of its elements such that the least element can always be found in constant time.
PriorityQueue(int) - Constructor for class org.apache.lucene.util.PriorityQueue
Create an empty priority queue of the configured size.
PriorityQueue(int, Supplier<T>) - Constructor for class org.apache.lucene.util.PriorityQueue
Create a priority queue that is pre-filled with sentinel objects, so that the code which uses that queue can always assume it's full and only change the top without attempting to insert any new object.
Provider() - Constructor for class org.apache.lucene.search.SortedNumericSortField.Provider
Creates a new Provider
Provider() - Constructor for class org.apache.lucene.search.SortedSetSortField.Provider
Creates a new Provider
Provider() - Constructor for class org.apache.lucene.search.SortField.Provider
Creates a new Provider
prune(SearcherLifetimeManager.Pruner) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Calls provided SearcherLifetimeManager.Pruner to prune entries.
PruneByAge(double) - Constructor for class org.apache.lucene.search.SearcherLifetimeManager.PruneByAge
 
pruning - Variable in class org.apache.lucene.search.comparators.NumericComparator
 
Pruning - Enum in org.apache.lucene.search
Controls LeafFieldComparator how to skip documents
push(long) - Method in class org.apache.lucene.util.LongHeap
Adds a value in log(size) time.
pushAll(LongHeap) - Method in class org.apache.lucene.util.LongHeap
 
PushPostingsWriterBase - Class in org.apache.lucene.codecs
Extension of PostingsWriterBase, adding a push API for writing each element of the postings.
PushPostingsWriterBase() - Constructor for class org.apache.lucene.codecs.PushPostingsWriterBase
Sole constructor.
put(char[], V) - Method in class org.apache.lucene.analysis.CharArrayMap
Add the given mapping.
put(int) - Method in class org.apache.lucene.util.SentinelIntSet
Puts this integer (key) in the set, and returns the slot index it was added to.
put(int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
put(CharSequence, V) - Method in class org.apache.lucene.analysis.CharArrayMap
Add the given mapping.
put(Object, V) - Method in class org.apache.lucene.analysis.CharArrayMap
 
put(String, V) - Method in class org.apache.lucene.analysis.CharArrayMap
Add the given mapping.
put(K, V) - Method in class org.apache.lucene.util.MapOfSets
Adds val to the Set associated with key in the Map.
put(K, V) - Method in class org.apache.lucene.util.WeakIdentityMap
Associates the specified value with the specified key in this map.
putAll(Iterable<? extends IntIntHashMap.IntIntCursor>) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
putAll(K, Collection<? extends V>) - Method in class org.apache.lucene.util.MapOfSets
Adds multiple vals to the Set associated with key in the Map.
putAttribute(String, String) - Method in class org.apache.lucene.document.FieldType
Puts an attribute value.
putAttribute(String, String) - Method in class org.apache.lucene.index.FieldInfo
Puts a codec attribute value.
putAttribute(String, String) - Method in class org.apache.lucene.index.SegmentInfo
Puts a codec attribute value.
putIfAbsent(int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Trove-inspired API method.
putOrAdd(int, int, int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
If key exists, putValue is inserted into the map, otherwise any existing value is incremented by additionValue.

Q

quantize(float[], byte[], VectorSimilarityFunction) - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
Quantize a float vector into a byte vector
QUANTIZED_VECTOR_COMPONENT - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsFormat
 
QuantizedByteVectorValues - Class in org.apache.lucene.util.quantization
A version of ByteVectorValues, but additionally retrieving score correction offset for Scalar quantization scores.
QuantizedByteVectorValues() - Constructor for class org.apache.lucene.util.quantization.QuantizedByteVectorValues
 
QuantizedVectorsReader - Interface in org.apache.lucene.util.quantization
Quantized vector reader
quantizeQuery(float[], byte[], VectorSimilarityFunction, ScalarQuantizer) - Static method in class org.apache.lucene.util.quantization.ScalarQuantizedRandomVectorScorer
 
Query - Class in org.apache.lucene.search
The abstract base class for queries.
Query() - Constructor for class org.apache.lucene.search.Query
 
QUERY_DEFAULT_RAM_BYTES_USED - Static variable in class org.apache.lucene.util.RamUsageEstimator
Approximate memory usage that we assign to all unknown queries - this maps roughly to a BooleanQuery with a couple term clauses.
QueryBuilder - Class in org.apache.lucene.util
Creates queries from the Analyzer chain.
QueryBuilder(Analyzer) - Constructor for class org.apache.lucene.util.QueryBuilder
Creates a new QueryBuilder using the given analyzer.
QueryBuilder.TermAndBoost - Class in org.apache.lucene.util
Wraps a term and boost
QueryCache - Interface in org.apache.lucene.search
A cache for queries.
QueryCachingPolicy - Interface in org.apache.lucene.search
A policy defining which filters should be cached.
queryLen - Variable in class org.apache.lucene.search.similarities.Axiomatic
the query length
QueryRescorer - Class in org.apache.lucene.search
A Rescorer that uses a provided Query to assign scores to the first-pass hits.
QueryRescorer(Query) - Constructor for class org.apache.lucene.search.QueryRescorer
Sole constructor, passing the 2nd pass query to assign scores to the 1st pass hits.
QueryTimeout - Interface in org.apache.lucene.index
Query timeout abstraction that controls whether a query should continue or be stopped.
QueryTimeoutImpl - Class in org.apache.lucene.index
An implementation of QueryTimeout that can be used by the ExitableDirectoryReader class to time out and exit out when a query takes a long time to rewrite.
QueryTimeoutImpl(long) - Constructor for class org.apache.lucene.index.QueryTimeoutImpl
Sets the time at which to time out by adding the given timeAllowed to the current time.
QueryVisitor - Class in org.apache.lucene.search
Allows recursion through a query tree
QueryVisitor() - Constructor for class org.apache.lucene.search.QueryVisitor
 
queue - Variable in class org.apache.lucene.search.TopKnnCollector
 
queueFull - Variable in class org.apache.lucene.search.comparators.NumericComparator
 

R

RadixSelector - Class in org.apache.lucene.util
Radix selector.
RadixSelector(int) - Constructor for class org.apache.lucene.util.RadixSelector
Sole constructor.
radixSorter(BytesRefComparator) - Method in class org.apache.lucene.util.StringSorter
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.BufferingKnnVectorsWriter
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene95.OrdToDocDISIReaderConfiguration
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsReader
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsWriter
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsWriter
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsReader
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
 
ramBytesUsed() - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
 
ramBytesUsed() - Method in class org.apache.lucene.index.DocsWithFieldSet
 
ramBytesUsed() - Method in class org.apache.lucene.index.IndexWriter
 
ramBytesUsed() - Method in class org.apache.lucene.index.OrdinalMap
 
ramBytesUsed() - Method in class org.apache.lucene.index.PrefixCodedTerms
 
ramBytesUsed() - Method in class org.apache.lucene.index.Term
 
ramBytesUsed() - Method in class org.apache.lucene.search.AutomatonQuery
 
ramBytesUsed() - Method in class org.apache.lucene.search.LRUQueryCache.CacheAndCount
 
ramBytesUsed() - Method in class org.apache.lucene.search.LRUQueryCache
 
ramBytesUsed() - Method in class org.apache.lucene.search.PointInSetQuery
 
ramBytesUsed() - Method in class org.apache.lucene.search.TermInSetQuery
 
ramBytesUsed() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
ramBytesUsed() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
ramBytesUsed() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
ramBytesUsed() - Method in interface org.apache.lucene.util.Accountable
Return the memory usage of this object in bytes.
ramBytesUsed() - Method in class org.apache.lucene.util.automaton.Automaton
 
ramBytesUsed() - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
 
ramBytesUsed() - Method in class org.apache.lucene.util.automaton.RunAutomaton
 
ramBytesUsed() - Method in class org.apache.lucene.util.BitDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.ByteBlockPool
 
ramBytesUsed() - Method in class org.apache.lucene.util.BytesRefArray.SortState
 
ramBytesUsed() - Method in class org.apache.lucene.util.BytesRefBlockPool
 
ramBytesUsed() - Method in class org.apache.lucene.util.BytesRefHash
 
ramBytesUsed() - Method in class org.apache.lucene.util.FixedBitSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
 
ramBytesUsed() - Method in class org.apache.lucene.util.fst.FST
 
ramBytesUsed() - Method in class org.apache.lucene.util.fst.OffHeapFSTStore
 
ramBytesUsed() - Method in class org.apache.lucene.util.fst.OnHeapFSTStore
 
ramBytesUsed() - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
 
ramBytesUsed() - Method in class org.apache.lucene.util.LongBitSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.NotDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.DirectMonotonicReader.Meta
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.DirectMonotonicReader
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
 
ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedLongValues
 
ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes
 
ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes.Reader
 
ramBytesUsed() - Method in class org.apache.lucene.util.RoaringDocIdSet
 
ramBytesUsed() - Method in class org.apache.lucene.util.SentinelIntSet
Return the memory footprint of this class in bytes.
ramBytesUsed() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
ramBytesUsed(Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
ramBytesUsed(Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
ramBytesUsed(BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
ramBytesUsed(CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
ramBytesUsed(PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
ramBytesUsed(IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
ramBytesUsed(T) - Method in class org.apache.lucene.util.fst.Outputs
Return memory usage for the provided output.
RamUsageEstimator - Class in org.apache.lucene.util
Estimates the size (memory representation) of Java objects.
RandomAccessInput - Interface in org.apache.lucene.store
Random Access Index API.
RandomAccessQuantizedByteVectorValues - Interface in org.apache.lucene.util.quantization
Random access values for byte[], but also includes accessing the score correction constant for the current vector in the buffer.
randomAccessSlice(long, long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
randomAccessSlice(long, long) - Method in class org.apache.lucene.store.IndexInput
Creates a random-access slice of this index input, with the given offset and length.
RandomAccessVectorValues<T> - Interface in org.apache.lucene.util.hnsw
Provides random access to vectors by dense ordinal.
randomId() - Static method in class org.apache.lucene.util.StringHelper
Generates a non-cryptographic globally unique id.
RandomVectorScorer - Interface in org.apache.lucene.util.hnsw
A RandomVectorScorer for scoring random nodes in batches against an abstract query.
RandomVectorScorer.AbstractRandomVectorScorer<T> - Class in org.apache.lucene.util.hnsw
Creates a default scorer for random access vectors.
RandomVectorScorerSupplier - Interface in org.apache.lucene.util.hnsw
A supplier that creates RandomVectorScorer from an ordinal.
RandomVectorScorerSupplier.ByteScoringSupplier - Class in org.apache.lucene.util.hnsw
RandomVectorScorerSupplier for bytes vector
RandomVectorScorerSupplier.FloatScoringSupplier - Class in org.apache.lucene.util.hnsw
RandomVectorScorerSupplier for Float vector
randSeed - Static variable in class org.apache.lucene.util.hnsw.HnswGraphBuilder
Random seed for level generation; public to expose for testing *
range(int, int) - Static method in class org.apache.lucene.search.DocIdSetIterator
A DocIdSetIterator that matches a range documents from minDocID (inclusive) to maxDocID (exclusive).
RangeFieldQuery - Class in org.apache.lucene.document
Query class for searching RangeField types by a defined PointValues.Relation.
RangeFieldQuery(String, byte[], int, RangeFieldQuery.QueryType) - Constructor for class org.apache.lucene.document.RangeFieldQuery
Create a query for searching indexed ranges that match the provided relation.
RangeFieldQuery.QueryType - Enum in org.apache.lucene.document
Used by RangeFieldQuery to check how each internal or leaf node relates to the query.
RateLimitedIndexOutput - Class in org.apache.lucene.store
RateLimitedIndexOutput(RateLimiter, IndexOutput) - Constructor for class org.apache.lucene.store.RateLimitedIndexOutput
 
RateLimiter - Class in org.apache.lucene.store
Abstract base class to rate limit IO.
RateLimiter() - Constructor for class org.apache.lucene.store.RateLimiter
 
RateLimiter.SimpleRateLimiter - Class in org.apache.lucene.store
Simple class to rate limit IO.
read(long) - Method in interface org.apache.lucene.util.GroupVIntUtil.IntReader
 
read(Path, Outputs<T>) - Static method in class org.apache.lucene.util.fst.FST
Reads an automaton from a file.
read(DataInput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
read(DataInput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
read(DataInput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
read(DataInput) - Method in class org.apache.lucene.util.fst.NoOutputs
 
read(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
Decode an output value previously written with Outputs.write(Object, DataOutput).
read(DataInput) - Method in class org.apache.lucene.util.fst.PairOutputs
 
read(DataInput) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SegmentInfoFormat
 
read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.SegmentInfoFormat
Read SegmentInfo data from a directory.
read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.FieldInfosFormat
read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.lucene94.Lucene94FieldInfosFormat
 
READ - org.apache.lucene.store.IOContext.Context
 
READ - Static variable in class org.apache.lucene.store.IOContext
 
readArcByContinuous(FST.Arc<T>, FST.BytesReader, int) - Method in class org.apache.lucene.util.fst.FST
Reads a Continuous node arc, with the provided index in the label range.
readArcByDirectAddressing(FST.Arc<T>, FST.BytesReader, int) - Method in class org.apache.lucene.util.fst.FST
Reads a present direct addressing node arc, with the provided index in the label range.
readArcByIndex(FST.Arc<T>, FST.BytesReader, int) - Method in class org.apache.lucene.util.fst.FST
 
readBEInt(DataInput) - Static method in class org.apache.lucene.codecs.CodecUtil
read int value from header / footer with big endian order
readBELong(DataInput) - Static method in class org.apache.lucene.codecs.CodecUtil
read long value from header / footer with big endian order
readByte() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
readByte() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readByte() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
readByte() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readByte() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readByte() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readByte() - Method in class org.apache.lucene.store.DataInput
Reads and returns a single byte.
readByte() - Method in class org.apache.lucene.store.FilterIndexInput
 
readByte() - Method in class org.apache.lucene.store.InputStreamDataInput
 
readByte() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
readByte(long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readByte(long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readByte(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readByte(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readByte(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads a byte at the given position in the file
readByte(long) - Method in class org.apache.lucene.util.ByteBlockPool
Read a single byte at the given offset
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.DataInput
Reads a specified number of bytes into an array at the specified offset.
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.FilterIndexInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.store.InputStreamDataInput
 
readBytes(byte[], int, int) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.DataInput
Reads a specified number of bytes into an array at the specified offset with control over whether the read should be buffered (callers who have their own buffer should pass in "false" for useBuffer).
readBytes(long, byte[], int, int) - Method in class org.apache.lucene.util.ByteBlockPool
Reads bytes out of the pool starting at the given offset with the given length into the given byte array at offset off.
readBytes(ByteBuffer, int) - Method in class org.apache.lucene.store.ByteBuffersDataInput
Reads exactly len bytes into the given buffer.
readCeilArc(int, FST<T>, FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Static method in class org.apache.lucene.util.fst.Util
Reads the first arc greater or equal than the given label into the provided arc in place and returns it iff found, otherwise return null.
readChildPointer(IndexInput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
readCommit(Directory, String) - Static method in class org.apache.lucene.index.SegmentInfos
Read a particular segmentFileName.
readCommit(Directory, ChecksumIndexInput, long) - Static method in class org.apache.lucene.index.SegmentInfos
Read the commit from the provided ChecksumIndexInput.
reader() - Method in class org.apache.lucene.index.CompositeReaderContext
 
reader() - Method in class org.apache.lucene.index.IndexReaderContext
Returns the IndexReader, this context represents.
reader() - Method in class org.apache.lucene.index.LeafReaderContext
 
Reader() - Constructor for class org.apache.lucene.util.packed.PackedInts.Reader
 
readerBase(int) - Method in class org.apache.lucene.index.BaseCompositeReader
Helper method for subclasses to get the docBase of the given sub-reader index.
readerContext - Variable in class org.apache.lucene.search.IndexSearcher
 
readerIndex - Variable in class org.apache.lucene.index.ReaderSlice
Sub-reader index for this slice.
readerIndex(int) - Method in class org.apache.lucene.index.BaseCompositeReader
Helper method for subclasses to get the corresponding reader for a doc ID
ReaderManager - Class in org.apache.lucene.index
Utility class to safely share DirectoryReader instances across multiple threads, while periodically reopening.
ReaderManager(DirectoryReader) - Constructor for class org.apache.lucene.index.ReaderManager
Creates and returns a new ReaderManager from the given already-opened DirectoryReader, stealing the incoming reference.
ReaderManager(IndexWriter) - Constructor for class org.apache.lucene.index.ReaderManager
Creates and returns a new ReaderManager from the given IndexWriter.
ReaderManager(IndexWriter, boolean, boolean) - Constructor for class org.apache.lucene.index.ReaderManager
Expert: creates and returns a new ReaderManager from the given IndexWriter, controlling whether past deletions should be applied.
ReaderManager(Directory) - Constructor for class org.apache.lucene.index.ReaderManager
Creates and returns a new ReaderManager from the given Directory.
readerPooling - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
True if readers should be pooled.
ReaderSlice - Class in org.apache.lucene.index
Subreader slice from a parent composite reader.
ReaderSlice(int, int, int) - Constructor for class org.apache.lucene.index.ReaderSlice
Sole constructor.
ReaderUtil - Class in org.apache.lucene.index
Common util methods for dealing with IndexReaders and IndexReaderContexts.
readerValue() - Method in class org.apache.lucene.document.Field
The value of the field as a Reader, or null.
readerValue() - Method in interface org.apache.lucene.index.IndexableField
Non-null if this field has a Reader value
readFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
Decode an output value previously written with Outputs.writeFinalOutput(Object, DataOutput).
readFirstRealTargetArc(long, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
 
readFirstTargetArc(FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
Follow the follow arc and read the first arc of its target; this changes the provided arc (2nd arg) in-place and returns it.
readFloats(float[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readFloats(float[], int, int) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readFloats(float[], int, int) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readFloats(float[], int, int) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readFloats(float[], int, int) - Method in class org.apache.lucene.store.DataInput
Reads a specified number of floats into an array at the specified offset.
readFooter(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Retrieves the full footer from the provided IndexInput.
readGroupVInt(long[], int) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readGroupVInt(long[], int) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readGroupVInt(long[], int) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readGroupVInt(long[], int) - Method in class org.apache.lucene.store.DataInput
Override if you have a efficient implementation.
readGroupVInt(DataInput, long[], int) - Static method in class org.apache.lucene.util.GroupVIntUtil
Default implementation of read single group, for optimal performance, you should use DataInput.readGroupVInts(long[], int) instead.
readGroupVInt(DataInput, long, GroupVIntUtil.IntReader, long, long[], int) - Static method in class org.apache.lucene.util.GroupVIntUtil
Faster implementation of read single group, It read values from the buffer that would not cross boundaries.
readGroupVInts(long[], int) - Method in class org.apache.lucene.store.DataInput
Read all the group varints, including the tail vints.
readImpacts(int, IndexInput) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
readIndexHeader(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Retrieves the full index header from the provided IndexInput.
readInt() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readInt() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
readInt() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readInt() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readInt() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readInt() - Method in class org.apache.lucene.store.DataInput
Reads four bytes and returns an int (LE byte order).
readInt(long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readInt(long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readInt(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readInt(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readInt(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads an integer (LE byte order) at the given position in the file
readInternal(ByteBuffer) - Method in class org.apache.lucene.store.BufferedIndexInput
Expert: implements buffer refill.
readInts(int[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readInts(int[], int, int) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readInts(int[], int, int) - Method in class org.apache.lucene.store.DataInput
Reads a specified number of ints into an array at the specified offset.
readLabel(DataInput) - Method in class org.apache.lucene.util.fst.FST
Reads one BYTE1/2/4 label from the provided DataInput.
readLastArcByContinuous(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
Reads the last arc of a continuous node.
readLastArcByDirectAddressing(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
Reads the last arc of a direct addressing node.
readLatestCommit(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
Find the latest commit (segments_N file) and load all SegmentCommitInfos.
readLatestCommit(Directory, int) - Static method in class org.apache.lucene.index.SegmentInfos
Find the latest commit (segments_N file) and load all SegmentCommitInfos, as long as the commit's SegmentInfos.getIndexCreatedVersionMajor() is strictly greater than the provided minimum supported major version.
readLevelLength(IndexInput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
read the length of the current level written via MultiLevelSkipListWriter.writeLevelLength(long, IndexOutput).
readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.LiveDocsFormat
Read live docs bits.
readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene90.Lucene90LiveDocsFormat
 
readLong() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readLong() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
readLong() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readLong() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readLong() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readLong() - Method in class org.apache.lucene.store.DataInput
Reads eight bytes and returns a long (LE byte order).
readLong(int) - Method in class org.apache.lucene.util.packed.PackedDataInput
Read the next long using exactly bitsPerValue bits.
readLong(long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readLong(long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readLong(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readLong(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readLong(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads a long (LE byte order) at the given position in the file
readLongs(long[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readLongs(long[], int, int) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readLongs(long[], int, int) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readLongs(long[], int, int) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readLongs(long[], int, int) - Method in class org.apache.lucene.store.DataInput
Read a specified number of longs.
readMapOfStrings() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readMapOfStrings() - Method in class org.apache.lucene.store.DataInput
Reads a Map<String,String> previously written with DataOutput.writeMapOfStrings(Map).
readMetadata(DataInput, Outputs<T>) - Static method in class org.apache.lucene.util.fst.FST
Read the FST metadata from DataInput
readNextArc(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
In-place read; returns the arc.
readNextRealArc(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
Never returns null, but you should never call this if arc.isLast() is true.
readOnce - Variable in class org.apache.lucene.store.IOContext
This flag indicates that the file will be opened, then fully read sequentially then closed.
READONCE - Static variable in class org.apache.lucene.store.IOContext
 
readSetOfStrings() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readSetOfStrings() - Method in class org.apache.lucene.store.DataInput
Reads a Set<String> previously written with DataOutput.writeSetOfStrings(Set).
readShort() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readShort() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
readShort() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readShort() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readShort() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readShort() - Method in class org.apache.lucene.store.DataInput
Reads two bytes and returns a short (LE byte order).
readShort(long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
readShort(long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readShort(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
readShort(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readShort(long) - Method in interface org.apache.lucene.store.RandomAccessInput
Reads a short (LE byte order) at the given position in the file
readSimilarityFunction(DataInput) - Static method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
readSkipData(int, IndexInput) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
readSkipData(int, IndexInput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
Subclasses must implement the actual skip data encoding in this method.
readSortField(DataInput) - Method in class org.apache.lucene.index.SortFieldProvider
Reads a SortField from serialized bytes
readSortField(DataInput) - Method in class org.apache.lucene.search.SortedNumericSortField.Provider
 
readSortField(DataInput) - Method in class org.apache.lucene.search.SortedSetSortField.Provider
 
readSortField(DataInput) - Method in class org.apache.lucene.search.SortField.Provider
 
readString() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readString() - Method in class org.apache.lucene.store.DataInput
Reads a string.
readTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
time spent in i/o read (in milliseconds)
readType(DataInput) - Static method in class org.apache.lucene.search.SortField
 
readVectorEncoding(DataInput) - Static method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
readVInt() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readVInt() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
readVInt() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readVInt() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readVInt() - Method in class org.apache.lucene.store.DataInput
Reads an int stored in variable-length format.
readVLong() - Method in class org.apache.lucene.store.BufferedIndexInput
 
readVLong() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
readVLong() - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
readVLong() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readVLong() - Method in class org.apache.lucene.store.DataInput
Reads a long stored in variable-length format.
readZInt() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readZInt() - Method in class org.apache.lucene.store.DataInput
Read a zig-zag-encoded variable-length integer.
readZLong() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
readZLong() - Method in class org.apache.lucene.store.DataInput
Read a zig-zag-encoded variable-length integer.
reap() - Method in class org.apache.lucene.util.WeakIdentityMap
This method manually cleans up the reference queue to remove all garbage collected key/value pairs from the map.
reason() - Method in annotation type org.apache.lucene.util.IgnoreRandomChains
A reason for ignoring should always be given.
reason() - Method in annotation type org.apache.lucene.util.SuppressForbidden
A reason for suppressing should always be given.
recalculateCorrectiveOffset(byte[], ScalarQuantizer, VectorSimilarityFunction) - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
Recalculate the old score corrective value given new current quantiles
record(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Records that you are now using this IndexSearcher.
Rectangle - Class in org.apache.lucene.geo
Represents a lat/lon rectangle.
Rectangle(double, double, double, double) - Constructor for class org.apache.lucene.geo.Rectangle
Constructs a bounding box by first validating the provided latitude and longitude coordinates
recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
 
recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.IntBlockPool.Allocator
 
recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.IntBlockPool.DirectAllocator
 
recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
 
RecyclingByteBlockAllocator - Class in org.apache.lucene.util
A ByteBlockPool.Allocator implementation that recycles unused byte blocks in a buffer and reuses them in subsequent calls to RecyclingByteBlockAllocator.getByteBlock().
RecyclingByteBlockAllocator() - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
RecyclingByteBlockAllocator(int) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
RecyclingByteBlockAllocator(int, Counter) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
RecyclingIntBlockAllocator - Class in org.apache.lucene.util
A IntBlockPool.Allocator implementation that recycles unused int blocks in a buffer and reuses them in subsequent calls to RecyclingIntBlockAllocator.getIntBlock().
RecyclingIntBlockAllocator() - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
Creates a new RecyclingIntBlockAllocator with a block size of IntBlockPool.INT_BLOCK_SIZE, upper buffered docs limit of RecyclingIntBlockAllocator.DEFAULT_BUFFERED_BLOCKS (64).
RecyclingIntBlockAllocator(int, int) - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
RecyclingIntBlockAllocator(int, int, Counter) - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
reduce(Collection<C>) - Method in interface org.apache.lucene.search.CollectorManager
Reduce the results of individual collectors into a meaningful result.
reduce(Collection<Collector>) - Method in class org.apache.lucene.search.MultiCollectorManager
 
reduce(Collection<TopFieldCollector>) - Method in class org.apache.lucene.search.TopFieldCollectorManager
 
reduce(Collection<TopScoreDocCollector>) - Method in class org.apache.lucene.search.TopScoreDocCollectorManager
 
reduce(Collection<TotalHitCountCollector>) - Method in class org.apache.lucene.search.TotalHitCountCollectorManager
 
ref - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
 
REF - org.apache.lucene.util.FileDeleter.MsgType
 
RefCount<T> - Class in org.apache.lucene.util
Manages reference counting for a given object.
RefCount(T) - Constructor for class org.apache.lucene.util.RefCount
 
refCounts - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
Records how many snapshots are held against each commit generation
ReferenceManager<G> - Class in org.apache.lucene.search
Utility class to safely share instances of a certain type across multiple threads, while periodically refreshing them.
ReferenceManager() - Constructor for class org.apache.lucene.search.ReferenceManager
 
ReferenceManager.RefreshListener - Interface in org.apache.lucene.search
Use to receive notification when a refresh has finished.
reflect(Class<? extends Attribute>, String, Object) - Method in interface org.apache.lucene.util.AttributeReflector
This method gets called for every property in an AttributeImpl/AttributeSource passing the class name of the Attribute, a key and the actual value.
reflectAsString(boolean) - Method in class org.apache.lucene.util.AttributeImpl
This method returns the current attribute values as a string in the following format by calling the AttributeImpl.reflectWith(AttributeReflector) method: iff prependAttClass=true: "AttributeClass#key=value,AttributeClass#key=value" iff prependAttClass=false: "key=value,key=value"
reflectAsString(boolean) - Method in class org.apache.lucene.util.AttributeSource
This method returns the current attribute values as a string in the following format by calling the AttributeSource.reflectWith(AttributeReflector) method: iff prependAttClass=true: "AttributeClass#key=value,AttributeClass#key=value" iff prependAttClass=false: "key=value,key=value"
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.BoostAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
reflectWith(AttributeReflector) - Method in class org.apache.lucene.util.AttributeImpl
This method is for introspection of attributes, it should simply add the key/values this attribute holds to the given AttributeReflector.
reflectWith(AttributeReflector) - Method in class org.apache.lucene.util.AttributeSource
This method is for introspection of attributes, it should simply add the key/values this AttributeSource holds to the given AttributeReflector.
refreshIfNeeded(G) - Method in class org.apache.lucene.search.ReferenceManager
Refresh the given reference if needed.
refreshIfNeeded(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
 
refreshIfNeeded(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
 
RegExp - Class in org.apache.lucene.util.automaton
Regular Expression extension to Automaton.
RegExp(String) - Constructor for class org.apache.lucene.util.automaton.RegExp
Constructs new RegExp from a string.
RegExp(String, int) - Constructor for class org.apache.lucene.util.automaton.RegExp
Constructs new RegExp from a string.
RegExp(String, int, int) - Constructor for class org.apache.lucene.util.automaton.RegExp
Constructs new RegExp from a string.
REGEXP_ANYCHAR - org.apache.lucene.util.automaton.RegExp.Kind
Any Character allowed
REGEXP_ANYSTRING - org.apache.lucene.util.automaton.RegExp.Kind
Any string allowed
REGEXP_AUTOMATON - org.apache.lucene.util.automaton.RegExp.Kind
An Automaton expression
REGEXP_CHAR - org.apache.lucene.util.automaton.RegExp.Kind
A Character
REGEXP_CHAR_RANGE - org.apache.lucene.util.automaton.RegExp.Kind
A Character range
REGEXP_COMPLEMENT - org.apache.lucene.util.automaton.RegExp.Kind
The complement of an expression
REGEXP_CONCATENATION - org.apache.lucene.util.automaton.RegExp.Kind
A sequence of two expressions
REGEXP_EMPTY - org.apache.lucene.util.automaton.RegExp.Kind
An empty expression
REGEXP_INTERSECTION - org.apache.lucene.util.automaton.RegExp.Kind
The intersection of two expressions
REGEXP_INTERVAL - org.apache.lucene.util.automaton.RegExp.Kind
An Interval expression
REGEXP_OPTIONAL - org.apache.lucene.util.automaton.RegExp.Kind
An optional expression
REGEXP_PRE_CLASS - org.apache.lucene.util.automaton.RegExp.Kind
An expression for a pre-defined class e.g.
REGEXP_REPEAT - org.apache.lucene.util.automaton.RegExp.Kind
An expression that repeats
REGEXP_REPEAT_MIN - org.apache.lucene.util.automaton.RegExp.Kind
An expression that repeats a minimum number of times
REGEXP_REPEAT_MINMAX - org.apache.lucene.util.automaton.RegExp.Kind
An expression that repeats a minimum and maximum number of times
REGEXP_STRING - org.apache.lucene.util.automaton.RegExp.Kind
A string expression
REGEXP_UNION - org.apache.lucene.util.automaton.RegExp.Kind
The union of two expressions
RegExp.Kind - Enum in org.apache.lucene.util.automaton
The type of expression represented by a RegExp node.
RegexpQuery - Class in org.apache.lucene.search
A fast regular expression query based on the org.apache.lucene.util.automaton package.
RegexpQuery(Term) - Constructor for class org.apache.lucene.search.RegexpQuery
Constructs a query for terms matching term.
RegexpQuery(Term, int) - Constructor for class org.apache.lucene.search.RegexpQuery
Constructs a query for terms matching term.
RegexpQuery(Term, int, int) - Constructor for class org.apache.lucene.search.RegexpQuery
Constructs a query for terms matching term.
RegexpQuery(Term, int, int, int) - Constructor for class org.apache.lucene.search.RegexpQuery
Constructs a query for terms matching term.
RegexpQuery(Term, int, int, AutomatonProvider, int, MultiTermQuery.RewriteMethod) - Constructor for class org.apache.lucene.search.RegexpQuery
Constructs a query for terms matching term.
RegexpQuery(Term, int, AutomatonProvider, int) - Constructor for class org.apache.lucene.search.RegexpQuery
Constructs a query for terms matching term.
register(TermState, int) - Method in class org.apache.lucene.index.TermStates
Expert: Registers and associates a TermState with an leaf ordinal.
register(TermState, int, int, long) - Method in class org.apache.lucene.index.TermStates
Registers and associates a TermState with an leaf ordinal.
registerParentReader(IndexReader) - Method in class org.apache.lucene.index.IndexReader
Expert: This method is called by IndexReaders which wrap other readers (e.g.
rehash() - Method in class org.apache.lucene.util.SentinelIntSet
(internal) Rehashes by doubling int[] key and filling with the old values.
rehash(int[], int[]) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Rehash from old buffers to new buffers.
rehashCount - Variable in class org.apache.lucene.util.SentinelIntSet
the count at which a rehash should be done
reinit() - Method in class org.apache.lucene.util.BytesRefHash
reinitializes the BytesRefHash after a previous BytesRefHash.clear() call.
relate(double, double, double, double) - Method in interface org.apache.lucene.geo.Component2D
relates this component2D with a bounding box *
relate(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
Compute the relation between the provided box and distance query.
relation - Variable in class org.apache.lucene.search.TotalHits
Whether TotalHits.value is the exact hit count, in which case TotalHits.relation is equal to TotalHits.Relation.EQUAL_TO, or a lower bound of the total hit count, in which case TotalHits.relation is equal to TotalHits.Relation.GREATER_THAN_OR_EQUAL_TO.
relationship - Variable in class org.apache.lucene.search.Scorable.ChildScorable
An arbitrary string relating this scorer to the parent.
release() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
release() - Method in class org.apache.lucene.util.RefCount
Called when reference counting hits 0.
release(long) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
Deletes a snapshotted commit by generation.
release(G) - Method in class org.apache.lucene.search.ReferenceManager
Release the reference previously obtained via ReferenceManager.acquire().
release(IndexCommit) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
Deletes a snapshotted commit.
release(IndexCommit) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Release a snapshotted commit.
release(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Release a searcher previously obtained from SearcherLifetimeManager.acquire(long).
releaseGen(long) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Release a snapshot by generation.
RELEVANCE - Static variable in class org.apache.lucene.search.Sort
Represents sorting by computed relevance.
RelevanceComparator(int) - Constructor for class org.apache.lucene.search.FieldComparator.RelevanceComparator
Creates a new comparator based on relevance for numHits.
reload(ClassLoader) - Method in class org.apache.lucene.analysis.AnalysisSPILoader
Reloads the internal SPI list from the given ClassLoader.
reload(ClassLoader) - Method in class org.apache.lucene.util.NamedSPILoader
Reloads the internal SPI list from the given ClassLoader.
reloadCharFilters(ClassLoader) - Static method in class org.apache.lucene.analysis.CharFilterFactory
Reloads the factory list from the given ClassLoader.
reloadCodecs(ClassLoader) - Static method in class org.apache.lucene.codecs.Codec
Reloads the codec list from the given ClassLoader.
reloadDocValuesFormats(ClassLoader) - Static method in class org.apache.lucene.codecs.DocValuesFormat
Reloads the DocValues format list from the given ClassLoader.
reloadPostingsFormats(ClassLoader) - Static method in class org.apache.lucene.codecs.PostingsFormat
Reloads the postings format list from the given ClassLoader.
reloadSortFieldProviders(ClassLoader) - Static method in class org.apache.lucene.index.SortFieldProvider
Reloads the SortFieldProvider list from the given ClassLoader.
reloadTokenFilters(ClassLoader) - Static method in class org.apache.lucene.analysis.TokenFilterFactory
Reloads the factory list from the given ClassLoader.
reloadTokenizers(ClassLoader) - Static method in class org.apache.lucene.analysis.TokenizerFactory
Reloads the factory list from the given ClassLoader.
remove() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
 
remove() - Method in class org.apache.lucene.util.FilterIterator
 
remove() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.AbstractIterator
Default implementation throws UnsupportedOperationException.
remove() - Method in class org.apache.lucene.util.MergedIterator
 
remove(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
remove(Object) - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
remove(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
 
remove(Object) - Method in class org.apache.lucene.search.Multiset
 
remove(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
Removes the mapping for a key from this weak hash map if it is present.
remove(SegmentCommitInfo) - Method in class org.apache.lucene.index.SegmentInfos
Remove the provided SegmentCommitInfo.
remove(T) - Method in class org.apache.lucene.util.PriorityQueue
Removes an existing element currently stored in the PriorityQueue.
removeAllAttributes() - Method in class org.apache.lucene.util.AttributeSource
Removes all attributes and their implementations from this AttributeSource.
removeDeadStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Removes transitions to dead states (a state is "dead" if it is not reachable from the initial state or no accept state is reachable from it.)
removeField(String) - Method in class org.apache.lucene.document.Document
Removes field with the specified name from the document.
removeFields(String) - Method in class org.apache.lucene.document.Document
Removes all fields with the given name from the document.
removeListener(ReferenceManager.RefreshListener) - Method in class org.apache.lucene.search.ReferenceManager
Remove a listener added with ReferenceManager.addListener(RefreshListener).
rename(String, String) - Method in class org.apache.lucene.codecs.CompoundDirectory
Not implemented
rename(String, String) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
rename(String, String) - Method in class org.apache.lucene.store.Directory
Renames source file to dest file where dest must not already exist in the directory.
rename(String, String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
rename(String, String) - Method in class org.apache.lucene.store.FilterDirectory
 
rename(String, String) - Method in class org.apache.lucene.store.FSDirectory
 
rename(String, String) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
rename(String, String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
rename(String, String) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
 
reorder(int, int, int[], int[], int) - Method in class org.apache.lucene.util.MSBRadixSorter
Reorder based on start/end offsets for each bucket.
reorder(int, int, int[], int[], int) - Method in class org.apache.lucene.util.StableMSBRadixSorter
Reorder elements in stable way, since Dutch sort does not guarantee ordering for same values.
reorder(CodecReader, Directory) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Extend this method if you wish to renumber doc IDs.
repeat(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the Kleene star (zero or more concatenated repetitions) of the language of the given automaton.
repeat(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts min or more concatenated repetitions of the language of the given automaton.
repeat(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts between min and max (including both) concatenated repetitions of the language of the given automaton.
replay(Collector) - Method in class org.apache.lucene.search.CachingCollector
Replays the cached doc IDs (and scores) to the given Collector.
require(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
require(Map<String, String>, String, Collection<String>) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
require(Map<String, String>, String, Collection<String>, boolean) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
requireBoolean(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
requireChar(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
requireFloat(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
requireInt(Map<String, String>, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
requireResourceNonNull(T, String) - Static method in class org.apache.lucene.util.IOUtils
Wrap all calls to Class.getResource(String) or Class.getResourceAsStream(String) using this method to enforce existence of the resource.
rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.QueryRescorer
 
rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.Rescorer
Rescore an initial first-pass TopDocs.
rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.SortRescorer
 
rescore(IndexSearcher, TopDocs, Query, double, int) - Static method in class org.apache.lucene.search.QueryRescorer
Sugar API, calling {#rescore} using a simple linear combination of firstPassScore + weight * secondPassScore
Rescorer - Class in org.apache.lucene.search
Re-scores the topN results (TopDocs) from an original query.
Rescorer() - Constructor for class org.apache.lucene.search.Rescorer
 
reset() - Method in class org.apache.lucene.analysis.CachingTokenFilter
Propagates reset if incrementToken has not yet been called.
reset() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
Resets the CharacterBuffer.
reset() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
 
reset() - Method in class org.apache.lucene.analysis.GraphTokenFilter
 
reset() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
 
reset() - Method in class org.apache.lucene.analysis.TokenFilter
This method is called by a consumer before it begins consumption using TokenStream.incrementToken().
reset() - Method in class org.apache.lucene.analysis.Tokenizer
 
reset() - Method in class org.apache.lucene.analysis.TokenStream
This method is called by a consumer before it begins consumption using TokenStream.incrementToken().
reset() - Method in class org.apache.lucene.index.DocIDMerger
Reuse API, currently only used by postings during merge
reset() - Method in class org.apache.lucene.index.QueryTimeoutImpl
Reset the timeout value.
reset() - Method in class org.apache.lucene.search.ExactPhraseMatcher
 
reset() - Method in class org.apache.lucene.search.PhraseMatcher
Called after PhraseMatcher.approximation() has been advanced
reset() - Method in class org.apache.lucene.search.SloppyPhraseMatcher
 
reset() - Method in class org.apache.lucene.store.BufferedChecksum
 
reset() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
This method resets this object to a clean (zero-size) state and publishes any currently allocated buffers for reuse to the reuse strategy provided in the constructor.
reset() - Method in class org.apache.lucene.util.RollingBuffer
 
reset() - Method in interface org.apache.lucene.util.RollingBuffer.Resettable
 
reset(boolean, boolean) - Method in class org.apache.lucene.util.ByteBlockPool
Expert: Resets the pool to its initial state, while optionally reusing the first buffer.
reset(boolean, boolean) - Method in class org.apache.lucene.util.IntBlockPool
Expert: Resets the pool to its initial state, while optionally reusing the first buffer.
reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataInput
 
reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
 
reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
reset(MultiPostingsEnum.EnumWithSlice[], int) - Method in class org.apache.lucene.index.MultiPostingsEnum
Re-use and reset this instance on the provided slices.
reset(TermsEnumIndex[]) - Method in class org.apache.lucene.index.MultiTermsEnum
The terms array must be newly created TermsEnum, ie BytesRefIterator.next() has not yet been called.
reset(DataInput, long) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
Reset the current reader to wrap a stream of valueCount values contained in in.
resetSkip() - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipWriter
 
resetSkip() - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Creates new buffers or empties the existing ones
resize(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
resize(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
Create a new copy of size newSize based on the content of this buffer.
resizeAt - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
Expand (rehash) IntIntHashMap.keys when IntIntHashMap.assigned hits this value.
resizeBuffer(int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Grows the termBuffer to at least size newSize, preserving the existing content.
resizeBuffer(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
ResourceLoader - Interface in org.apache.lucene.util
Abstraction for loading resources (streams, files, and classes).
ResourceLoaderAware - Interface in org.apache.lucene.util
Interface for a component that needs to be initialized by an implementation of ResourceLoader.
restore(int, int) - Method in class org.apache.lucene.codecs.MutablePointTree
Restore values between i-th and j-th(excluding) in temporary storage into original storage.
restore(int, int) - Method in class org.apache.lucene.util.StableMSBRadixSorter.MergeSorter
Restore values between i-th and j-th(excluding) in temporary storage into original storage.
restore(int, int) - Method in class org.apache.lucene.util.StableMSBRadixSorter
Restore values between i-th and j-th(excluding) in temporary storage into original storage.
restore(int, int) - Method in class org.apache.lucene.util.TimSorter
Restore element j from the temporary storage into slot i.
restoreState(AttributeSource.State) - Method in class org.apache.lucene.util.AttributeSource
Restores this state by copying the values of all attribute implementations that this state contains into the attributes implementations of the targetStream.
Result(IntsRef, T) - Constructor for class org.apache.lucene.util.fst.Util.Result
 
rethrowAlways(Throwable) - Static method in class org.apache.lucene.util.IOUtils
This utility method takes a previously caught (non-null) Throwable and rethrows either the original argument if it was a subclass of the IOException or an RuntimeException with the cause set to the argument.
retrieveChecksum(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
Returns (but does not validate) the checksum previously written by CodecUtil.checkFooter(org.apache.lucene.store.ChecksumIndexInput).
retrieveChecksum(IndexInput, long) - Static method in class org.apache.lucene.codecs.CodecUtil
Returns (but does not validate) the checksum previously written by CodecUtil.checkFooter(org.apache.lucene.store.ChecksumIndexInput).
reuse(ByteBuffer) - Method in class org.apache.lucene.store.ByteBuffersDataOutput.ByteBufferRecycler
 
ReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Sole constructor.
reverse - Variable in class org.apache.lucene.search.comparators.NumericComparator
 
reverse(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton accepting the reverse language.
reverse(Automaton, Set<Integer>) - Static method in class org.apache.lucene.util.automaton.Operations
Reverses the automaton, returning the new initial states.
reverseMul - Variable in class org.apache.lucene.search.FieldValueHitQueue
 
rewind() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
rewrite(IndexReader) - Method in class org.apache.lucene.search.Query
rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.DocValuesRewriteMethod
 
rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
 
rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.ScoringRewrite
 
rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.TopTermsRewrite
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.BlendedTermQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.BooleanQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.BoostQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Optimize our representation and our subqueries representations
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.DoubleValuesSource
Return a DoubleValuesSource specialised for the given IndexSearcher
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.FieldExistsQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.LongValuesSource
Return a LongValuesSource specialised for the given IndexSearcher
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.MultiTermQuery
To rewrite to a simpler form, instead return a simpler enum from MultiTermQuery.getTermsEnum(Terms, AttributeSource).
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.NGramPhraseQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.PhraseQuery
 
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.Query
Expert: called to re-write queries into primitive queries.
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.Sort
Rewrites the SortFields in this Sort, returning a new Sort if any of the fields changes during their rewriting.
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.SortField
Rewrites this SortField, returning a new SortField if a change is made.
rewrite(IndexSearcher) - Method in class org.apache.lucene.search.SynonymQuery
 
rewrite(Query) - Method in class org.apache.lucene.search.IndexSearcher
Expert: called to re-write queries into primitive queries.
rewrite(Query[]) - Method in class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
 
rewrite(Query[]) - Method in class org.apache.lucene.search.BlendedTermQuery.RewriteMethod
Merge the provided sub queries into a single Query object.
REWRITEABLE - org.apache.lucene.search.SortField.Type
Force rewriting of SortField using SortField.rewrite(IndexSearcher) before it can be used for sorting
rewriteMethod - Variable in class org.apache.lucene.search.MultiTermQuery
 
RewriteMethod() - Constructor for class org.apache.lucene.search.BlendedTermQuery.RewriteMethod
Sole constructor
RewriteMethod() - Constructor for class org.apache.lucene.search.MultiTermQuery.RewriteMethod
 
rm(Path...) - Static method in class org.apache.lucene.util.IOUtils
Deletes one or more files or directories (and everything underneath it).
RoaringDocIdSet - Class in org.apache.lucene.util
DocIdSet implementation inspired from http://roaringbitmap.org/
RoaringDocIdSet.Builder - Class in org.apache.lucene.util
A builder of RoaringDocIdSets.
rollback() - Method in class org.apache.lucene.index.IndexWriter
Close the IndexWriter without committing any changes that have occurred since the last commit (or since it was opened, if commit hasn't been called).
rollback() - Method in interface org.apache.lucene.index.TwoPhaseCommit
Discards any changes that have occurred since the last commit.
RollingBuffer<T extends RollingBuffer.Resettable> - Class in org.apache.lucene.util
Acts like forever growing T[], but internally uses a circular buffer to reuse instances of T.
RollingBuffer() - Constructor for class org.apache.lucene.util.RollingBuffer
 
RollingBuffer.Resettable - Interface in org.apache.lucene.util
Implement to reset an instance
round(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
Limit a date's resolution.
round(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
Limit a date's resolution.
RPAREN - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
 
run() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
 
run() - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
Locate the most recent segments file and run SegmentInfos.FindSegmentsFile.doBody(java.lang.String) on it.
run() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
 
run() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
run(byte[], int, int) - Method in class org.apache.lucene.util.automaton.ByteRunAutomaton
Returns true if the given byte array is accepted by this automaton
run(char[], int, int) - Method in class org.apache.lucene.util.automaton.CharacterRunAutomaton
Returns true if the given string is accepted by this automaton
run(String) - Method in class org.apache.lucene.util.automaton.CharacterRunAutomaton
Returns true if the given string is accepted by this automaton.
run(IndexCommit) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
run(Automaton, String) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given string is accepted by the automaton.
run(Automaton, IntsRef) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the given string (expressed as unicode codepoints) is accepted by the automaton.
runAutomaton - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Matcher for quickly determining if a byte[] is accepted.
RunAutomaton - Class in org.apache.lucene.util.automaton
Finite-state automaton with fast run operation.
RunAutomaton(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.RunAutomaton
Constructs a new RunAutomaton from a deterministic Automaton.
RunAutomaton(Automaton, int, int) - Constructor for class org.apache.lucene.util.automaton.RunAutomaton
Constructs a new RunAutomaton from a deterministic Automaton.
rwlock - Variable in class org.apache.lucene.util.hnsw.NeighborArray
 

S

s - Variable in class org.apache.lucene.search.similarities.Axiomatic
hyperparam for the growth function
s - Variable in class org.apache.lucene.util.automaton.RegExp
String expression
sameClassAs(Object) - Method in class org.apache.lucene.search.Query
Utility method to check whether other is not null and is exactly of the same class as this object's class.
sameLanguage(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if these two automata accept exactly the same language.
SameThreadExecutorService - Class in org.apache.lucene.util
An ExecutorService that executes tasks immediately in the calling thread during submit.
SameThreadExecutorService() - Constructor for class org.apache.lucene.util.SameThreadExecutorService
 
save(int, int) - Method in class org.apache.lucene.codecs.MutablePointTree
Save the i-th value into the j-th position in temporary storage.
save(int, int) - Method in class org.apache.lucene.util.StableMSBRadixSorter.MergeSorter
Save the i-th value into the j-th position in temporary storage.
save(int, int) - Method in class org.apache.lucene.util.StableMSBRadixSorter
Save the i-th value into the j-th position in temporary storage.
save(int, int) - Method in class org.apache.lucene.util.TimSorter
Save all elements between slots i and i+len into the temporary storage.
save(Path) - Method in class org.apache.lucene.util.fst.FST
Writes an automaton to a file.
save(DataOutput, DataOutput) - Method in class org.apache.lucene.util.fst.FST
Save the FST to DataOutput.
saveMetadata(DataOutput) - Method in class org.apache.lucene.util.fst.FST
Save the metadata to a DataOutput
SCALAR_QUANTIZATION_SAMPLE_SIZE - Static variable in class org.apache.lucene.util.quantization.ScalarQuantizer
 
ScalarQuantizedRandomVectorScorer - Class in org.apache.lucene.util.quantization
Quantized vector scorer
ScalarQuantizedRandomVectorScorer(VectorSimilarityFunction, ScalarQuantizer, RandomAccessQuantizedByteVectorValues, float[]) - Constructor for class org.apache.lucene.util.quantization.ScalarQuantizedRandomVectorScorer
 
ScalarQuantizedRandomVectorScorer(ScalarQuantizedVectorSimilarity, RandomAccessQuantizedByteVectorValues, byte[], float) - Constructor for class org.apache.lucene.util.quantization.ScalarQuantizedRandomVectorScorer
 
ScalarQuantizedRandomVectorScorerSupplier - Class in org.apache.lucene.util.quantization
Quantized vector scorer supplier
ScalarQuantizedRandomVectorScorerSupplier(VectorSimilarityFunction, ScalarQuantizer, RandomAccessQuantizedByteVectorValues) - Constructor for class org.apache.lucene.util.quantization.ScalarQuantizedRandomVectorScorerSupplier
 
ScalarQuantizedVectorSimilarity - Interface in org.apache.lucene.util.quantization
Calculates and adjust the scores correctly for quantized vectors given the scalar quantization parameters
ScalarQuantizedVectorSimilarity.DotProduct - Class in org.apache.lucene.util.quantization
Calculates dot product on quantized vectors, applying the appropriate corrections
ScalarQuantizedVectorSimilarity.Euclidean - Class in org.apache.lucene.util.quantization
Calculates euclidean distance on quantized vectors, applying the appropriate corrections
ScalarQuantizedVectorSimilarity.MaximumInnerProduct - Class in org.apache.lucene.util.quantization
Calculates max inner product on quantized vectors, applying the appropriate corrections
ScalarQuantizer - Class in org.apache.lucene.util.quantization
Will scalar quantize float vectors into `int8` byte values.
ScalarQuantizer(float, float, float) - Constructor for class org.apache.lucene.util.quantization.ScalarQuantizer
 
scaleMaxInnerProductScore(float) - Static method in class org.apache.lucene.util.VectorUtil
 
scanIsEmpty() - Method in class org.apache.lucene.util.FixedBitSet
Scans the backing store to check if all bits are clear.
scanIsEmpty() - Method in class org.apache.lucene.util.LongBitSet
Scans the backing store to check if all bits are clear.
Scorable - Class in org.apache.lucene.search
Allows access to the score of a Query
Scorable() - Constructor for class org.apache.lucene.search.Scorable
 
Scorable.ChildScorable - Class in org.apache.lucene.search
A child Scorer and its relationship to its parent.
score - Variable in class org.apache.lucene.search.ScoreDoc
The score of this document for the query.
score() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
score() - Method in class org.apache.lucene.search.ConstantScoreWeight
Return the score produced by this Weight.
score() - Method in class org.apache.lucene.search.FilterScorable
 
score() - Method in class org.apache.lucene.search.FilterScorer
 
score() - Method in class org.apache.lucene.search.IndriDisjunctionScorer
 
score() - Method in class org.apache.lucene.search.IndriScorer
 
score() - Method in class org.apache.lucene.search.Scorable
Returns the score of the current document matching the query.
score() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
score() - Method in class org.apache.lucene.search.TermScorer
 
score(byte[], float, byte[], float) - Method in class org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity.DotProduct
 
score(byte[], float, byte[], float) - Method in class org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity.Euclidean
 
score(byte[], float, byte[], float) - Method in class org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity.MaximumInnerProduct
 
score(byte[], float, byte[], float) - Method in interface org.apache.lucene.util.quantization.ScalarQuantizedVectorSimilarity
 
score(double, double) - Method in class org.apache.lucene.search.similarities.Independence
Computes distance from independence
score(double, double) - Method in class org.apache.lucene.search.similarities.IndependenceChiSquared
 
score(double, double) - Method in class org.apache.lucene.search.similarities.IndependenceSaturated
 
score(double, double) - Method in class org.apache.lucene.search.similarities.IndependenceStandardized
 
score(float, long) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
Score a single document.
score(int) - Method in interface org.apache.lucene.util.hnsw.RandomVectorScorer
Returns the score between the query and the provided node.
score(int) - Method in class org.apache.lucene.util.quantization.ScalarQuantizedRandomVectorScorer
 
score(int, float) - Method in class org.apache.lucene.search.LeafSimScorer
Score the provided document assuming the given term document frequency.
score(List<SegmentCommitInfo>, boolean, Map<SegmentCommitInfo, TieredMergePolicy.SegmentSizeAndDocs>) - Method in class org.apache.lucene.index.TieredMergePolicy
Expert: scores one merge; subclasses can override.
score(List<Scorer>) - Method in class org.apache.lucene.search.IndriAndScorer
 
score(LeafCollector, Bits) - Method in class org.apache.lucene.search.BulkScorer
Scores and collects all matching documents.
score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.BulkScorer
Collects matching documents in a range and return an estimation of the next matching document which is on or after max.
score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
 
score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.Weight.DefaultBulkScorer
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModel
Returns the informative content score combined with the after effect, more specifically informationContentScore * aeTimes1pTfn / (1 + tfn).
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelG
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelIF
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelIn
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.BasicModelIne
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.DFISimilarity
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.DFRSimilarity
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Distribution
Computes the score.
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.DistributionLL
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.DistributionSPL
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.IBSimilarity
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.IndriDirichletSimilarity
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
 
score(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.SimilarityBase
Scores the document doc.
SCORE - org.apache.lucene.search.SortField.Type
Sort by document score (relevance).
ScoreCachingWrappingScorer - Class in org.apache.lucene.search
A Scorer which wraps another scorer and caches the score of the current document.
scoreCorrectionConstant - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
ScoreDoc - Class in org.apache.lucene.search
Holds one hit in TopDocs.
ScoreDoc(int, float) - Constructor for class org.apache.lucene.search.ScoreDoc
Constructs a ScoreDoc.
ScoreDoc(int, float, int) - Constructor for class org.apache.lucene.search.ScoreDoc
Constructs a ScoreDoc.
scoreDocs - Variable in class org.apache.lucene.search.TopDocs
The top hits for the query.
scoreMode() - Method in interface org.apache.lucene.search.Collector
Indicates what features are required from the scorer.
scoreMode() - Method in class org.apache.lucene.search.FilterCollector
 
scoreMode() - Method in class org.apache.lucene.search.MultiCollector
 
scoreMode() - Method in class org.apache.lucene.search.TimeLimitingCollector
 
scoreMode() - Method in class org.apache.lucene.search.TopFieldCollector
 
scoreMode() - Method in class org.apache.lucene.search.TopScoreDocCollector
 
scoreMode() - Method in class org.apache.lucene.search.TotalHitCountCollector
 
ScoreMode - Enum in org.apache.lucene.search
Different modes of search.
scorer - Variable in class org.apache.lucene.search.DisiWrapper
 
scorer - Variable in class org.apache.lucene.search.TopScoreDocCollector.ScorerLeafCollector
 
scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.BM25Similarity
 
scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.BooleanSimilarity
 
scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
 
scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
 
scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.Similarity
Compute any collection-level weight (e.g.
scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.SimilarityBase
 
scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
 
scorer(int) - Method in class org.apache.lucene.util.hnsw.RandomVectorScorerSupplier.ByteScoringSupplier
 
scorer(int) - Method in class org.apache.lucene.util.hnsw.RandomVectorScorerSupplier.FloatScoringSupplier
 
scorer(int) - Method in interface org.apache.lucene.util.hnsw.RandomVectorScorerSupplier
This creates a RandomVectorScorer for scoring random nodes in batches against the given ordinal.
scorer(int) - Method in class org.apache.lucene.util.quantization.ScalarQuantizedRandomVectorScorerSupplier
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.FilterWeight
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.IndriAndWeight
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.PhraseWeight
 
scorer(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
Returns a Scorer which can iterate in order over all matching documents and assign them a score.
Scorer - Class in org.apache.lucene.search
Expert: Common scoring functionality for different types of queries.
Scorer(Weight) - Constructor for class org.apache.lucene.search.Scorer
Constructs a Scorer
ScorerLeafCollector() - Constructor for class org.apache.lucene.search.TopScoreDocCollector.ScorerLeafCollector
 
scorerSupplier - Variable in class org.apache.lucene.util.hnsw.IncrementalHnswGraphMerger
 
scorerSupplier(LeafReaderContext) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
 
scorerSupplier(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
Optional method.
ScorerSupplier - Class in org.apache.lucene.search
A supplier of Scorer.
ScorerSupplier() - Constructor for class org.apache.lucene.search.ScorerSupplier
 
scores() - Method in class org.apache.lucene.util.hnsw.NeighborArray
 
SCORES - Static variable in class org.apache.lucene.search.DoubleValuesSource
A DoubleValuesSource that exposes a document's score
scoreTimes1pTfn(BasicStats) - Method in class org.apache.lucene.search.similarities.AfterEffect
Returns the product of the after effect with 1+tfn.
scoreTimes1pTfn(BasicStats) - Method in class org.apache.lucene.search.similarities.AfterEffectB
 
scoreTimes1pTfn(BasicStats) - Method in class org.apache.lucene.search.similarities.AfterEffectL
 
SCORING_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
A rewrite method that first translates each term into BooleanClause.Occur.SHOULD clause in a BooleanQuery, and keeps the scores as computed by the query.
SCORING_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
A rewrite method that first translates each term into BooleanClause.Occur.SHOULD clause in a BooleanQuery, and keeps the scores as computed by the query.
ScoringRewrite<B> - Class in org.apache.lucene.search
Base rewrite method that translates each term into a query, and keeps the scores as computed by the query.
ScoringRewrite() - Constructor for class org.apache.lucene.search.ScoringRewrite
 
scratch1 - Variable in class org.apache.lucene.util.StringSorter
 
scratch2 - Variable in class org.apache.lucene.util.StringSorter
 
scratchBytes1 - Variable in class org.apache.lucene.util.StringSorter
 
scratchBytes2 - Variable in class org.apache.lucene.util.StringSorter
 
search() - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
 
search(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.codecs.KnnVectorsReader
Return the k nearest neighbor documents as determined by comparison of their vector values for this field, to the given vector, by the field's similarity function.
search(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
search(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
 
search(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.codecs.KnnVectorsReader
Return the k nearest neighbor documents as determined by comparison of their vector values for this field, to the given vector, by the field's similarity function.
search(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsReader
 
search(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.codecs.perfield.PerFieldKnnVectorsFormat.FieldsReader
 
search(List<LeafReaderContext>, Weight, Collector) - Method in class org.apache.lucene.search.IndexSearcher
Lower-level search API.
search(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
Finds the top n hits for query.
search(Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
Search implementation with arbitrary sorting.
search(Query, int, Sort, boolean) - Method in class org.apache.lucene.search.IndexSearcher
Search implementation with arbitrary sorting, plus control over whether hit scores and max score should be computed.
search(Query, Collector) - Method in class org.apache.lucene.search.IndexSearcher
Deprecated.
This method is being deprecated in favor of IndexSearcher.search(Query, CollectorManager) due to its support for concurrency in IndexSearcher
search(Query, CollectorManager<C, T>) - Method in class org.apache.lucene.search.IndexSearcher
Lower-level search API.
search(RandomVectorScorer, int, OnHeapHnswGraph, Bits, int) - Static method in class org.apache.lucene.util.hnsw.HnswGraphSearcher
Search OnHeapHnswGraph, this method is thread safe.
search(RandomVectorScorer, KnnCollector, HnswGraph, Bits) - Static method in class org.apache.lucene.util.hnsw.HnswGraphSearcher
Searches HNSW graph for the nearest neighbors of a query vector.
searchAfter(ScoreDoc, Query, int) - Method in class org.apache.lucene.search.IndexSearcher
Finds the top n hits for query where all results are after a previous result (after).
searchAfter(ScoreDoc, Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
Finds the top n hits for query where all results are after a previous result (after).
searchAfter(ScoreDoc, Query, int, Sort, boolean) - Method in class org.apache.lucene.search.IndexSearcher
Finds the top n hits for query where all results are after a previous result (after), allowing control over whether hit scores and max score should be computed.
SearcherFactory - Class in org.apache.lucene.search
Factory class used by SearcherManager to create new IndexSearchers.
SearcherFactory() - Constructor for class org.apache.lucene.search.SearcherFactory
 
SearcherLifetimeManager - Class in org.apache.lucene.search
Keeps track of current plus old IndexSearchers, closing the old ones once they have timed out.
SearcherLifetimeManager() - Constructor for class org.apache.lucene.search.SearcherLifetimeManager
 
SearcherLifetimeManager.PruneByAge - Class in org.apache.lucene.search
Simple pruner that drops any searcher older by more than the specified seconds, than the newest searcher.
SearcherLifetimeManager.Pruner - Interface in org.apache.lucene.search
SearcherManager - Class in org.apache.lucene.search
Utility class to safely share IndexSearcher instances across multiple threads, while periodically reopening.
SearcherManager(DirectoryReader, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
Creates and returns a new SearcherManager from an existing DirectoryReader.
SearcherManager(IndexWriter, boolean, boolean, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
Expert: creates and returns a new SearcherManager from the given IndexWriter, controlling whether past deletions should be applied.
SearcherManager(IndexWriter, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
Creates and returns a new SearcherManager from the given IndexWriter.
SearcherManager(Directory, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
Creates and returns a new SearcherManager from the given Directory.
searchLevel(RandomVectorScorer, int, int, int[], HnswGraph) - Method in class org.apache.lucene.util.hnsw.HnswGraphSearcher
Searches for the nearest neighbors of a query vector in a given level.
searchNearestVectors(String, byte[], int, Bits, int) - Method in class org.apache.lucene.index.LeafReader
Return the k nearest neighbor documents as determined by comparison of their vector values for this field, to the given vector, by the field's similarity function.
searchNearestVectors(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.index.CodecReader
 
searchNearestVectors(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
searchNearestVectors(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.index.FilterLeafReader
 
searchNearestVectors(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.index.LeafReader
Return the k nearest neighbor documents as determined by comparison of their vector values for this field, to the given vector, by the field's similarity function.
searchNearestVectors(String, byte[], KnnCollector, Bits) - Method in class org.apache.lucene.index.ParallelLeafReader
 
searchNearestVectors(String, float[], int, Bits, int) - Method in class org.apache.lucene.index.LeafReader
Return the k nearest neighbor documents as determined by comparison of their vector values for this field, to the given vector, by the field's similarity function.
searchNearestVectors(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.index.CodecReader
 
searchNearestVectors(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
searchNearestVectors(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.index.FilterLeafReader
 
searchNearestVectors(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.index.LeafReader
Return the k nearest neighbor documents as determined by comparison of their vector values for this field, to the given vector, by the field's similarity function.
searchNearestVectors(String, float[], KnnCollector, Bits) - Method in class org.apache.lucene.index.ParallelLeafReader
 
SECOND - org.apache.lucene.document.DateTools.Resolution
Limit a date's resolution to second granularity.
seek(int, int) - Method in class org.apache.lucene.util.hnsw.HnswGraph
Move the pointer to exactly the given level's target.
seek(int, int) - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
 
seek(long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
seek(long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
seek(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
seek(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
seek(long) - Method in class org.apache.lucene.store.ChecksumIndexInput
Sets current position in this file, where the next read will occur.
seek(long) - Method in class org.apache.lucene.store.FilterIndexInput
 
seek(long) - Method in class org.apache.lucene.store.IndexInput
Sets current position in this file, where the next read will occur.
seekCeil(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
This enum does not support seeking!
seekCeil(BytesRef) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
seekCeil(BytesRef) - Method in class org.apache.lucene.index.MultiTermsEnum
 
seekCeil(BytesRef) - Method in class org.apache.lucene.index.TermsEnum
Seeks to the specified term, if it exists, or to the next (ceiling) term.
seekCeil(BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
seekCeil(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
Seeks to smallest term that's >= target.
seekCeil(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
Seeks to smallest term that's >= target.
seekChild(int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
seekChild(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
Seeks the skip entry on the given level
seekExact(long) - Method in class org.apache.lucene.index.FilteredTermsEnum
This enum does not support seeking!
seekExact(long) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
seekExact(long) - Method in class org.apache.lucene.index.MultiTermsEnum
 
seekExact(long) - Method in class org.apache.lucene.index.TermsEnum
Seeks to the specified term by ordinal (position) as previously returned by TermsEnum.ord().
seekExact(long) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
seekExact(BytesRef) - Method in class org.apache.lucene.index.BaseTermsEnum
 
seekExact(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
This enum does not support seeking!
seekExact(BytesRef) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
seekExact(BytesRef) - Method in class org.apache.lucene.index.MultiTermsEnum
 
seekExact(BytesRef) - Method in class org.apache.lucene.index.TermsEnum
Attempts to seek to the exact term, returning true if the term is found.
seekExact(BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
seekExact(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
Seeks to exactly this term, returning null if the term doesn't exist.
seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.BaseTermsEnum
 
seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.FilteredTermsEnum
This enum does not support seeking!
seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.TermsEnum
Expert: Seeks a specific position by TermState previously obtained from TermsEnum.termState().
seekExact(BytesRef, TermState) - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
seekExact(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
Seeks to exactly this term, returning null if the term doesn't exist.
seekFloor(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
Seeks to biggest term that's <= target.
seekFloor(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
Seeks to biggest term that's <= target.
seekInternal(long) - Method in class org.apache.lucene.store.BufferedIndexInput
Expert: implements seek.
segment - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Segment name.
SEGMENT_FLUSH - org.apache.lucene.index.MergeTrigger
Merge was triggered by a segment flush.
SegmentCacheable - Interface in org.apache.lucene.search
Interface defining whether or not an object can be cached against a LeafReader
SegmentCommitInfo - Class in org.apache.lucene.index
Embeds a [read-only] SegmentInfo and adds per-commit fields.
SegmentCommitInfo(SegmentInfo, int, int, long, long, long, byte[]) - Constructor for class org.apache.lucene.index.SegmentCommitInfo
Sole constructor.
segmentFileName(String, String, String) - Static method in class org.apache.lucene.index.IndexFileNames
Returns a file name that includes the given segment name, your own custom name and extension.
segmentInfo - Variable in class org.apache.lucene.index.MergeState
SegmentInfo of the newly merged segment.
segmentInfo - Variable in class org.apache.lucene.index.SegmentReadState
SegmentInfo describing this segment.
segmentInfo - Variable in class org.apache.lucene.index.SegmentWriteState
SegmentInfo describing this segment.
SegmentInfo - Class in org.apache.lucene.index
Information about a segment such as its name, directory, and files related to the segment.
SegmentInfo(Directory, Version, Version, String, int, boolean, boolean, Codec, Map<String, String>, byte[], Map<String, String>, Sort) - Constructor for class org.apache.lucene.index.SegmentInfo
Construct a new complete SegmentInfo instance from input.
segmentInfoFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes segment info file
segmentInfoFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
SegmentInfoFormat - Class in org.apache.lucene.codecs
Expert: Controls the format of the SegmentInfo (segment metadata file).
SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.SegmentInfoFormat
Sole constructor.
segmentInfos - Variable in class org.apache.lucene.index.CheckIndex.Status
List of CheckIndex.Status.SegmentInfoStatus instances, detailing status of each segment.
SegmentInfos - Class in org.apache.lucene.index
A collection of segmentInfo objects with methods for operating on those segments in relation to the file system.
SegmentInfos(int) - Constructor for class org.apache.lucene.index.SegmentInfos
Sole constructor.
SegmentInfos.FindSegmentsFile<T> - Class in org.apache.lucene.index
Utility class for executing code that needs to do something with the current segments file.
SegmentReader - Class in org.apache.lucene.index
IndexReader implementation over a single segment.
SegmentReaderAccess - Interface in org.apache.lucene.internal.tests
Access to SegmentReader internals exposed to the test framework.
SegmentReadState - Class in org.apache.lucene.index
Holder class for common parameters used during read.
SegmentReadState(SegmentReadState, String) - Constructor for class org.apache.lucene.index.SegmentReadState
Create a SegmentReadState.
SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext) - Constructor for class org.apache.lucene.index.SegmentReadState
Create a SegmentReadState.
SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext, String) - Constructor for class org.apache.lucene.index.SegmentReadState
Create a SegmentReadState.
segments - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
Segments to be merged.
SEGMENTS - Static variable in class org.apache.lucene.index.IndexFileNames
Name of the index segment file
segmentsChecked - Variable in class org.apache.lucene.index.CheckIndex.Status
Empty unless you passed specific segments list to check as optional 3rd argument.
segmentsFileName - Variable in class org.apache.lucene.index.CheckIndex.Status
Name of latest segments_N file in the index.
segmentSuffix - Variable in class org.apache.lucene.index.SegmentReadState
Unique suffix for any postings files read for this segment.
segmentSuffix - Variable in class org.apache.lucene.index.SegmentWriteState
Unique suffix for any postings files written for this segment.
SegmentWriteState - Class in org.apache.lucene.index
Holder class for common parameters used during write.
SegmentWriteState(SegmentWriteState, String) - Constructor for class org.apache.lucene.index.SegmentWriteState
Create a shallow copy of SegmentWriteState with a new segment suffix.
SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, BufferedUpdates, IOContext) - Constructor for class org.apache.lucene.index.SegmentWriteState
Sole constructor.
SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, BufferedUpdates, IOContext, String) - Constructor for class org.apache.lucene.index.SegmentWriteState
Constructor which takes segment suffix.
segString() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Returns a readable description of the current merge state.
segString(IndexWriter) - Method in interface org.apache.lucene.internal.tests.IndexWriterAccess
 
segString(MergePolicy.MergeContext, Iterable<SegmentCommitInfo>) - Method in class org.apache.lucene.index.MergePolicy
Builds a String representation of the given SegmentCommitInfo instances
segString(Directory) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
Returns a description of the merges in this specification.
segUpdates - Variable in class org.apache.lucene.index.SegmentWriteState
Deletes and updates to apply while we are flushing the segment.
select(int, int, int) - Method in class org.apache.lucene.util.IntroSelector
 
select(int, int, int) - Method in class org.apache.lucene.util.RadixSelector
 
select(int, int, int) - Method in class org.apache.lucene.util.Selector
Reorder elements so that the element at position k is the same as if all elements were sorted and all other elements are partitioned around it: [from, k) only contains elements that are less than or equal to k and (k, to) only contains elements that are greater than or equal to k.
select(BKDRadixSelector.PathSlice, BKDRadixSelector.PathSlice[], long, long, long, int, int) - Method in class org.apache.lucene.util.bkd.BKDRadixSelector
It uses the provided points from the given from to the given to to populate the partitionSlices array holder (length > 1) with two path slices so the path slice at position 0 contains partition - from points where the value of the dim is lower or equal to the to -from points on the slice at position 1.
select(T[], int, int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Reorganize arr[from:to[ so that the element at offset k is at the same position as if arr[from:to] was sorted, and all elements on its left are less than or equal to it, and all elements on its right are greater than or equal to it.
Selector - Class in org.apache.lucene.util
An implementation of a selection algorithm, ie.
Selector() - Constructor for class org.apache.lucene.util.Selector
 
SentenceAttribute - Interface in org.apache.lucene.analysis.tokenattributes
This attribute tracks what sentence a given token belongs to as well as potentially other sentence specific attributes.
SentenceAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of SentenceAttribute.
SentenceAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
Initialize this attribute to default
SentinelIntSet - Class in org.apache.lucene.util
A native int hash-based set where one value is reserved to mean "EMPTY" internally.
SentinelIntSet(int, int) - Constructor for class org.apache.lucene.util.SentinelIntSet
 
SerialMergeScheduler - Class in org.apache.lucene.index
A MergeScheduler that simply does each merge sequentially, using the current thread.
SerialMergeScheduler() - Constructor for class org.apache.lucene.index.SerialMergeScheduler
Sole constructor.
set(int) - Method in class org.apache.lucene.util.BitSet
Set the bit at i.
set(int) - Method in class org.apache.lucene.util.FixedBitSet
 
set(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
Set the bit at index i.
set(int, int) - Method in class org.apache.lucene.util.FixedBitSet
Sets a range of bits
set(int, long) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
set(int, long) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
Set the value at the given index in the array.
set(int, long[], int, int) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
set(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
Bulk set: set at least one and at most len longs starting at off in arr into this mutable, starting at index.
set(long) - Method in class org.apache.lucene.util.LongBitSet
 
set(long, long) - Method in class org.apache.lucene.util.LongBitSet
Sets a range of bits
set(long, long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
Set value at index.
set(T) - Method in class org.apache.lucene.util.CloseableThreadLocal
 
set(T) - Method in class org.apache.lucene.util.SetOnce
Sets the given object.
setAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Marks this merge as aborted.
setAccept(int, boolean) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
Set or clear this state as an accept state.
setAccept(int, boolean) - Method in class org.apache.lucene.util.automaton.Automaton
Set or clear this state as an accept state.
setAnalyzer(Analyzer) - Method in class org.apache.lucene.util.QueryBuilder
Sets the analyzer used to tokenize text.
setAutoGenerateMultiTermSynonymsPhraseQuery(boolean) - Method in class org.apache.lucene.util.QueryBuilder
Set to true if phrase queries should be automatically generated for multi terms synonyms.
setAvgFieldLength(double) - Method in class org.apache.lucene.search.similarities.BasicStats
Sets the average field length.
setBaseline() - Method in class org.apache.lucene.search.TimeLimitingCollector
Syntactic sugar for TimeLimitingCollector.setBaseline(long) using Counter.get() on the clock passed to the constructor.
setBaseline(long) - Method in class org.apache.lucene.search.TimeLimitingCollector
Sets the baseline for this collector.
setBinaryValue(BytesRef) - Method in class org.apache.lucene.document.StoredValue
Set a binary value.
setBoost(float) - Method in interface org.apache.lucene.search.BoostAttribute
Sets the boost in this attribute
setBoost(float) - Method in class org.apache.lucene.search.BoostAttributeImpl
 
setBottom(int) - Method in class org.apache.lucene.search.comparators.DoubleComparator.DoubleLeafComparator
 
setBottom(int) - Method in class org.apache.lucene.search.comparators.FloatComparator.FloatLeafComparator
 
setBottom(int) - Method in class org.apache.lucene.search.comparators.IntComparator.IntLeafComparator
 
setBottom(int) - Method in class org.apache.lucene.search.comparators.LongComparator.LongLeafComparator
 
setBottom(int) - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
setBottom(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
Set the bottom slot, ie the "weakest" (sorted last) entry in the queue.
setBufferSize(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Sets the scanner buffer size in chars
setByteAt(int, byte) - Method in class org.apache.lucene.util.BytesRefBuilder
Set a byte.
setBytesComparator(Comparator<BytesRef>) - Method in class org.apache.lucene.search.SortField
 
setBytesRef(BytesRef) - Method in interface org.apache.lucene.analysis.tokenattributes.BytesTermAttribute
Sets the BytesRef of the term
setBytesRef(BytesRef) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
 
setBytesValue(byte[]) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.DoublePoint
 
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.FloatPoint
 
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.InetAddressPoint
 
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.IntPoint
 
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.KeywordField
 
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.LongPoint
 
setBytesValue(BytesRef) - Method in class org.apache.lucene.document.StringField
 
setByteValue(byte) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setCalibrateSizeByDeletes(boolean) - Method in class org.apache.lucene.index.LogMergePolicy
Sets whether the segment size should be calibrated by the number of deletes when choosing segments for merge.
setCharAt(int, char) - Method in class org.apache.lucene.util.CharsRefBuilder
Set a char.
setCheckPendingFlushUpdate(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
 
setCheckPendingFlushUpdate(boolean) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Expert: sets if indexing threads check for pending flushes on update in order to help our flushing indexing buffers to disk.
setChecksumsOnly(boolean) - Method in class org.apache.lucene.index.CheckIndex
If true, only validate physical integrity for all files.
setCodec(Codec) - Method in class org.apache.lucene.index.IndexWriterConfig
Set the Codec.
setCodec(Codec) - Method in class org.apache.lucene.index.SegmentInfo
Can only be called once.
setCollectionProbability(double) - Method in class org.apache.lucene.search.similarities.LMSimilarity.LMStats
Sets the probability that the current term is generated by the collection.
setCollector(Collector) - Method in class org.apache.lucene.search.TimeLimitingCollector
This is so the same timer can be used with a multi-phase search process such as grouping.
setCommitOnClose(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
Sets if calls IndexWriter.close() should first commit before closing.
setCompetitiveTerm(BytesRef) - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
This is the term or null of the term that triggered the boost change.
setCompetitiveTerm(BytesRef) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
setConcurrentMergeSchedulerAccess(ConcurrentMergeSchedulerAccess) - Static method in class org.apache.lucene.internal.tests.TestSecrets
For internal initialization only.
setCurBuf(ByteBuffer) - Method in class org.apache.lucene.store.ByteBufferIndexInput
 
setCurrentLabel(int) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
setCurrentLabel(int) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
setDefault(Codec) - Static method in class org.apache.lucene.codecs.Codec
expert: sets the default codec used for newly created IndexWriterConfigs.
setDefault(InfoStream) - Static method in class org.apache.lucene.util.InfoStream
Sets the default InfoStream used by a newly instantiated classes.
setDefaultMaxMergesAndThreads(boolean) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Sets max merges and threads to proper defaults for rotational or non-rotational storage.
setDefaultQueryCache(QueryCache) - Static method in class org.apache.lucene.search.IndexSearcher
Expert: set the default QueryCache instance.
setDefaultQueryCachingPolicy(QueryCachingPolicy) - Static method in class org.apache.lucene.search.IndexSearcher
Expert: set the default QueryCachingPolicy instance.
setDeletesPctAllowed(double) - Method in class org.apache.lucene.index.TieredMergePolicy
Controls the maximum percentage of deleted documents that is tolerated in the index.
setDelGen(long) - Method in class org.apache.lucene.index.PrefixCodedTerms
Records del gen for this packet.
setDimensions(int, int) - Method in class org.apache.lucene.document.FieldType
Enables points indexing.
setDimensions(int, int, int) - Method in class org.apache.lucene.document.FieldType
Enables points indexing with selectable dimension indexing.
setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.SimilarityBase
Determines whether overlap tokens (Tokens with 0 position increment) are ignored when computing norm.
setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Determines whether overlap tokens (Tokens with 0 position increment) are ignored when computing norm.
setDocFreq(long) - Method in class org.apache.lucene.search.similarities.BasicStats
Sets the document frequency.
setDocId(int) - Method in class org.apache.lucene.util.BitSetIterator
Set the current doc id that this iterator is on.
setDocValuesType(DocValuesType) - Method in class org.apache.lucene.document.FieldType
Sets the field's DocValuesType
setDocValuesType(DocValuesType) - Method in class org.apache.lucene.index.FieldInfo
Record that this field is indexed with docvalues, with the specified type
setDocValuesUpdatesFiles(Map<Integer, Set<String>>) - Method in class org.apache.lucene.index.SegmentCommitInfo
Sets the DocValues updates file names, per field number.
setDoSlowChecks(boolean) - Method in class org.apache.lucene.index.CheckIndex
If true, additional slow checks are performed.
setDoubleValue(double) - Method in class org.apache.lucene.document.DoubleDocValuesField
 
setDoubleValue(double) - Method in class org.apache.lucene.document.DoubleField
 
setDoubleValue(double) - Method in class org.apache.lucene.document.DoublePoint
 
setDoubleValue(double) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setDoubleValue(double) - Method in class org.apache.lucene.document.StoredValue
Set a double value.
setDoubleValues(double...) - Method in class org.apache.lucene.document.DoublePoint
Change the values of this field
setEmpty() - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Sets the length of the termBuffer to zero.
setEmpty() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
setEnableGraphQueries(boolean) - Method in class org.apache.lucene.util.QueryBuilder
Enable or disable graph TokenStream processing (enabled by default).
setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.util.QueryBuilder
Set to true to enable position increments in result query.
setExplicitLuceneMatchVersion(boolean) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
 
setFailFast(boolean) - Method in class org.apache.lucene.index.CheckIndex
If true, just throw the original exception immediately when corruption is detected, rather than continuing to iterate to other segments looking for more corruption.
setFeatureValue(float) - Method in class org.apache.lucene.document.FeatureField
Update the feature value of this field.
setField(boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipWriter
 
setField(FieldInfo) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
setField(FieldInfo) - Method in class org.apache.lucene.codecs.PostingsWriterBase
Sets the current field for writing.
setField(FieldInfo) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Sets the current field for writing, and returns the fixed length of long[] metadata (which is fixed per field), called when the writing switches to another field.
setFieldInfosFiles(Set<String>) - Method in class org.apache.lucene.index.SegmentCommitInfo
Sets the FieldInfos file names.
setFiles(Collection<String>) - Method in class org.apache.lucene.index.SegmentInfo
Sets the files written for this segment.
setFinalOffsetGapAsHole(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
If true, any final offset gaps will result in adding a position hole.
setFlags(int) - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute
Set the flags to a new bitset.
setFlags(int) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
setFloatValue(float) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setFloatValue(float) - Method in class org.apache.lucene.document.FloatDocValuesField
 
setFloatValue(float) - Method in class org.apache.lucene.document.FloatField
 
setFloatValue(float) - Method in class org.apache.lucene.document.FloatPoint
 
setFloatValue(float) - Method in class org.apache.lucene.document.StoredValue
Set a float value.
setFloatValues(float...) - Method in class org.apache.lucene.document.FloatPoint
Change the values of this field
setFloorSegmentMB(double) - Method in class org.apache.lucene.index.TieredMergePolicy
Segments smaller than this size are merged more aggressively: They are candidates for full-flush merges, in order to reduce the number of segments in the index prior to opening a new point-in-time view of the index.
setForceMergeDeletesPctAllowed(double) - Method in class org.apache.lucene.index.TieredMergePolicy
When forceMergeDeletes is called, we only merge away a segment if its delete percentage is over this threshold.
setForceMergeMBPerSec(double) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Set the per-merge IO throttle rate for forced merges (default: Double.POSITIVE_INFINITY).
setGreedy(boolean) - Method in class org.apache.lucene.search.TimeLimitingCollector
Sets whether this time limited collector is greedy.
setHitsThresholdReached() - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
setHitsThresholdReached() - Method in interface org.apache.lucene.search.LeafFieldComparator
Informs this leaf comparator that hits threshold is reached.
setIndexCommit(IndexCommit) - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: allows to open a certain commit point.
setIndexCreatedVersionMajor(int) - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: set the compatibility version to use for this index.
setIndexDeletionPolicy(IndexDeletionPolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: allows an optional IndexDeletionPolicy implementation to be specified.
setIndexOptions(IndexOptions) - Method in class org.apache.lucene.document.FieldType
Sets the indexing options for the field:
setIndexPackageAccess(IndexPackageAccess) - Static method in class org.apache.lucene.internal.tests.TestSecrets
For internal initialization only.
setIndexSort(Sort) - Method in class org.apache.lucene.index.IndexWriterConfig
Set the Sort order to use for all (flushed and merged) segments.
setIndexWriterAccess(IndexWriterAccess) - Static method in class org.apache.lucene.internal.tests.TestSecrets
For internal initialization only.
setIndexWriterEventListener(IndexWriterEventListener) - Method in class org.apache.lucene.index.IndexWriterConfig
Set event listener to record key events in IndexWriter
setIndexWriterMaxDocs(int) - Method in interface org.apache.lucene.internal.tests.IndexPackageAccess
 
setInetAddressValue(InetAddress) - Method in class org.apache.lucene.document.InetAddressPoint
Change the values of this field
setInfoStream(PrintStream) - Method in class org.apache.lucene.index.CheckIndex
Set infoStream where messages should go.
setInfoStream(PrintStream) - Method in class org.apache.lucene.index.IndexWriterConfig
Convenience method that uses PrintStreamInfoStream.
setInfoStream(PrintStream) - Static method in class org.apache.lucene.index.SegmentInfos
If non-null, information about retries when loading the segments file will be printed to this.
setInfoStream(PrintStream, boolean) - Method in class org.apache.lucene.index.CheckIndex
Set infoStream where messages should go.
setInfoStream(InfoStream) - Method in class org.apache.lucene.index.IndexWriterConfig
Information about merges, deletes and a message when maxFieldLength is reached will be printed to this.
setInfoStream(InfoStream) - Method in interface org.apache.lucene.util.hnsw.HnswBuilder
Set info-stream to output debugging information
setInfoStream(InfoStream) - Method in class org.apache.lucene.util.hnsw.HnswConcurrentMergeBuilder
 
setInfoStream(InfoStream) - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder
 
setInitialSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
Use this method to set the initial BytesRef to seek before iterating.
setIntAt(int, int) - Method in class org.apache.lucene.util.IntsRefBuilder
Set an int.
setIntValue(int) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setIntValue(int) - Method in class org.apache.lucene.document.IntField
 
setIntValue(int) - Method in class org.apache.lucene.document.IntPoint
 
setIntValue(int) - Method in class org.apache.lucene.document.StoredValue
Set an integer value.
setIntValues(int...) - Method in class org.apache.lucene.document.IntPoint
Change the values of this field
setKeyword(boolean) - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
Marks the current token as keyword if set to true.
setKeyword(boolean) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
setLastSkipData(int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
 
setLastSkipData(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
Copies the values of the last read skip entry on this level
setLeafSorter(Comparator<LeafReader>) - Method in class org.apache.lucene.index.IndexWriterConfig
Set the comparator for sorting leaf readers.
setLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Set number of valid characters (length of the term) in the termBuffer array.
setLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
setLength(int) - Method in class org.apache.lucene.index.FieldInvertState
Set length value.
setLength(int) - Method in class org.apache.lucene.util.BytesRefBuilder
Set the length.
setLength(int) - Method in class org.apache.lucene.util.CharsRefBuilder
Set the length.
setLength(int) - Method in class org.apache.lucene.util.IntsRefBuilder
Set the length.
setLiveCommitData(Iterable<Map.Entry<String, String>>) - Method in class org.apache.lucene.index.IndexWriter
Sets the iterator to provide the commit user data map at commit time.
setLiveCommitData(Iterable<Map.Entry<String, String>>, boolean) - Method in class org.apache.lucene.index.IndexWriter
Sets the commit user data iterator, controlling whether to advance the SegmentInfos.getVersion().
setLocationValue(double, double) - Method in class org.apache.lucene.document.LatLonDocValuesField
Change the values of this field
setLocationValue(double, double) - Method in class org.apache.lucene.document.LatLonPoint
Change the values of this field
setLocationValue(float, float) - Method in class org.apache.lucene.document.XYDocValuesField
Change the values of this field
setLocationValue(float, float) - Method in class org.apache.lucene.document.XYPointField
Change the values of this field
setLongValue(long) - Method in class org.apache.lucene.document.DoubleDocValuesField
 
setLongValue(long) - Method in class org.apache.lucene.document.DoubleField
 
setLongValue(long) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setLongValue(long) - Method in class org.apache.lucene.document.FloatDocValuesField
 
setLongValue(long) - Method in class org.apache.lucene.document.FloatField
 
setLongValue(long) - Method in class org.apache.lucene.document.LongField
 
setLongValue(long) - Method in class org.apache.lucene.document.LongPoint
 
setLongValue(long) - Method in class org.apache.lucene.document.StoredValue
Set a long value.
setLongValues(long...) - Method in class org.apache.lucene.document.LongPoint
Change the values of this field
setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.IndexWriterConfig
 
setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Determines the minimal number of documents required before the buffered in-memory documents are flushed as a new Segment.
setMaxCFSSegmentSizeMB(double) - Method in class org.apache.lucene.index.FilterMergePolicy
 
setMaxCFSSegmentSizeMB(double) - Method in class org.apache.lucene.index.MergePolicy
If a merged segment will be more than this value, leave the segment as non-compound file even if compound file is enabled.
setMaxCFSSegmentSizeMB(double) - Method in class org.apache.lucene.index.NoMergePolicy
 
setMaxClauseCount(int) - Static method in class org.apache.lucene.search.BooleanQuery
setMaxClauseCount(int) - Static method in class org.apache.lucene.search.IndexSearcher
Set the maximum number of clauses permitted per Query.
setMaxFullFlushMergeWaitMillis(long) - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: sets the amount of time to wait for merges (during IndexWriter.commit() or IndexWriter.getReader(boolean, boolean)) returned by MergePolicy.findFullFlushMerges(...).
setMaxMergeAtOnce(int) - Method in class org.apache.lucene.index.TieredMergePolicy
Maximum number of segments to be merged at a time during "normal" merging.
setMaxMergeDocs(int) - Method in class org.apache.lucene.index.LogMergePolicy
Determines the largest segment (measured by document count) that may be merged with other segments.
setMaxMergedSegmentMB(double) - Method in class org.apache.lucene.index.TieredMergePolicy
Maximum sized segment to produce during normal merging.
setMaxMergeMB(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
Determines the largest segment (measured by total byte size of the segment's files, in MB) that may be merged with other segments.
setMaxMergeMBForForcedMerge(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
Determines the largest segment (measured by total byte size of the segment's files, in MB) that may be merged with other segments during forceMerge.
setMaxMergesAndThreads(int, int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Expert: directly set the maximum number of merge threads and simultaneous merges allowed.
setMaxNonCompetitiveBoost(float) - Method in class org.apache.lucene.search.FuzzyTermsEnum
Sets the maximum non-competitive boost, which may allow switching to a lower max-edit automaton at run time
setMaxNonCompetitiveBoost(float) - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
This is the maximum boost that would not be competitive.
setMaxNonCompetitiveBoost(float) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
 
setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
Set the max allowed token length.
setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
Set the max allowed token length.
setMBPerSec(double) - Method in class org.apache.lucene.index.MergeRateLimiter
 
setMBPerSec(double) - Method in class org.apache.lucene.store.RateLimiter
Sets an updated MB per second rate limit.
setMBPerSec(double) - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
Sets an updated mb per second rate limit.
setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.IndexWriterConfig
 
setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Set the merged segment warmer.
setMergeFactor(int) - Method in class org.apache.lucene.index.LogMergePolicy
Determines how often segment indices are merged by addDocument().
setMergeInfo(SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Expert: Sets the SegmentCommitInfo of the merged segment.
setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
 
setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Expert: MergePolicy is invoked whenever there are changes to the segments in the index.
setMergeScheduler(MergeScheduler) - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: sets the merge scheduler used by this writer.
setMinCompetitiveScore(float) - Method in class org.apache.lucene.search.ConstantScoreScorer
 
setMinCompetitiveScore(float) - Method in class org.apache.lucene.search.ImpactsDISI
Set the minimum competitive score.
setMinCompetitiveScore(float) - Method in class org.apache.lucene.search.Scorable
Optional method: Tell the scorer that its iterator may safely ignore all documents whose score is less than the given minScore.
setMinCompetitiveScore(float) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
setMinCompetitiveScore(float) - Method in class org.apache.lucene.search.TermScorer
 
setMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.search.BooleanQuery.Builder
Specifies a minimum number of the optional BooleanClauses which must be satisfied.
setMinMergeDocs(int) - Method in class org.apache.lucene.index.LogDocMergePolicy
Sets the minimum size for the lowest level segments.
setMinMergeMB(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
Sets the minimum size for the lowest level segments.
setMissingValue(Object) - Method in class org.apache.lucene.search.SortedNumericSortField
 
setMissingValue(Object) - Method in class org.apache.lucene.search.SortedSetSortField
Set how missing values (the empty set) are sorted.
setMissingValue(Object) - Method in class org.apache.lucene.search.SortField
Set the value to use for documents that don't have a value.
setNextWriteGeneration(long) - Method in class org.apache.lucene.index.SegmentInfos
Set the generation to be used for the next commit
setNoCFSRatio(double) - Method in class org.apache.lucene.index.FilterMergePolicy
 
setNoCFSRatio(double) - Method in class org.apache.lucene.index.MergePolicy
If a merged segment will be more than this percentage of the total size of the index, leave the segment as non-compound file even if compound file is enabled.
setNoCFSRatio(double) - Method in class org.apache.lucene.index.NoMergePolicy
 
setNumberOfDocuments(long) - Method in class org.apache.lucene.search.similarities.BasicStats
Sets the number of documents.
setNumberOfFieldTokens(long) - Method in class org.apache.lucene.search.similarities.BasicStats
Sets the total number of tokens in the field.
setNumOverlap(int) - Method in class org.apache.lucene.index.FieldInvertState
Set number of terms with positionIncrement == 0.
setOffset(int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
Set the starting and ending offset.
setOffset(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
setOffset(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Set the starting and ending offset.
setOmitNorms(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to omit normalization values for the field.
setOmitsNorms() - Method in class org.apache.lucene.index.FieldInfo
Omit norms for this field.
SetOnce<T> - Class in org.apache.lucene.util
A convenient class which offers a semi-immutable object wrapper implementation which allows one to set the value of an object exactly once, and retrieve it many times.
SetOnce() - Constructor for class org.apache.lucene.util.SetOnce
A default constructor which does not set the internal object, and allows setting it by calling SetOnce.set(Object).
SetOnce(T) - Constructor for class org.apache.lucene.util.SetOnce
Creates a new instance with the internal object set to the given object.
SetOnce.AlreadySetException - Exception in org.apache.lucene.util
Thrown when SetOnce.set(Object) is called more than once.
setOpenMode(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.index.IndexWriterConfig
Specifies IndexWriterConfig.OpenMode of the index.
setOptimizeSortWithIndexedData(boolean) - Method in class org.apache.lucene.search.SortField
Deprecated.
should only be used for compatibility with 8.x indices that got created with inconsistent data across fields, or the wrong sort configuration in the index sort
setOptimizeSortWithPoints(boolean) - Method in class org.apache.lucene.search.SortField
Deprecated.
should only be used for compatibility with 8.x indices that got created with inconsistent data across fields, or the wrong sort configuration in the index sort. This is a duplicate method for SortField#setOptimizeSortWithIndexedData.
setOut(PrintStream) - Method in class org.apache.lucene.index.CheckIndex.Options
Set the PrintStream to use for reporting results.
setParentField(String) - Method in class org.apache.lucene.index.IndexWriterConfig
Sets the parent document field.
setPayload(BytesRef) - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
Sets this Token's payload.
setPayload(BytesRef) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
setPivot(int) - Method in class org.apache.lucene.util.IntroSelector
Save the value at slot i so that it can later be used as a pivot, see IntroSelector.comparePivot(int).
setPivot(int) - Method in class org.apache.lucene.util.IntroSorter
 
setPivot(int) - Method in class org.apache.lucene.util.Sorter
Save the value at slot i so that it can later be used as a pivot, see Sorter.comparePivot(int).
setPointDimensions(int, int, int) - Method in class org.apache.lucene.index.FieldInfo
Record that this field is indexed with points, with the specified number of dimensions and bytes per dimension.
setPosition(int) - Method in class org.apache.lucene.store.ByteArrayDataInput
 
setPosition(long) - Method in class org.apache.lucene.util.fst.FST.BytesReader
Set current read position.
setPosition(long) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
Seek to a position previously obtained from PagedBytes.PagedBytesDataInput.getPosition().
setPositionIncrement(int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Set the position increment.
setPositionIncrement(int) - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
Set the position increment.
setPositionIncrement(int) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
setPositionLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Set the position length of this Token.
setPositionLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
Set the position length of this Token.
setPositionLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
setPreload(boolean) - Method in class org.apache.lucene.store.MMapDirectory
Deprecated.
Use MMapDirectory.setPreload(BiPredicate) instead which provides more granular control.
setPreload(BiPredicate<String, IOContext>) - Method in class org.apache.lucene.store.MMapDirectory
Configure which files to preload in physical memory upon opening.
setPreservePositionIncrements(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
Whether to generate holes in the automaton for missing positions, true by default.
setQueryCache(QueryCache) - Method in class org.apache.lucene.search.IndexSearcher
Set the QueryCache to use when scores are not needed.
setQueryCachingPolicy(QueryCachingPolicy) - Method in class org.apache.lucene.search.IndexSearcher
Set the QueryCachingPolicy to use for query caching.
setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.IndexWriterConfig
 
setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Determines the amount of RAM that may be used for buffering added documents and deletions before they are flushed to the Directory.
setRAMPerThreadHardLimitMB(int) - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: Sets the maximum memory consumption per thread triggering a forced flush if exceeded.
setRangeValues(double[], double[]) - Method in class org.apache.lucene.document.DoubleRange
Changes the values of the field.
setRangeValues(float[], float[]) - Method in class org.apache.lucene.document.FloatRange
Changes the values of the field.
setRangeValues(int[], int[]) - Method in class org.apache.lucene.document.IntRange
Changes the values of the field.
setRangeValues(long[], long[]) - Method in class org.apache.lucene.document.LongRange
Changes the values of the field.
setRangeValues(InetAddress, InetAddress) - Method in class org.apache.lucene.document.InetAddressRange
Change (or set) the min/max values of the field.
setReader(Reader) - Method in class org.apache.lucene.analysis.Tokenizer
Expert: Set a new reader on the Tokenizer.
setReaderPooling(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
By default, IndexWriter does not pool the SegmentReaders it must open for deletions and merging, unless a near-real-time reader has been obtained by calling DirectoryReader.open(IndexWriter).
setReaderTestPoint() - Method in class org.apache.lucene.analysis.Tokenizer
 
setReaderValue(Reader) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setResolution(long) - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Set the timer resolution.
setReusableComponents(Analyzer, String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Stores the given TokenStreamComponents as the reusable components for the field with the give name.
setRewriteMethod(BlendedTermQuery.RewriteMethod) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
setRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.search.MultiTermQuery
Deprecated.
set this using a constructor instead
setScorer(Scorable) - Method in class org.apache.lucene.search.comparators.NumericComparator.NumericLeafComparator
 
setScorer(Scorable) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
setScorer(Scorable) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
setScorer(Scorable) - Method in class org.apache.lucene.search.FilterLeafCollector
 
setScorer(Scorable) - Method in interface org.apache.lucene.search.LeafCollector
Called before successive calls to LeafCollector.collect(int).
setScorer(Scorable) - Method in interface org.apache.lucene.search.LeafFieldComparator
Sets the Scorer to use in case a document's score is needed.
setScorer(Scorable) - Method in class org.apache.lucene.search.SimpleCollector
 
setScorer(Scorable) - Method in class org.apache.lucene.search.SimpleFieldComparator
 
setScorer(Scorable) - Method in class org.apache.lucene.search.TopScoreDocCollector.ScorerLeafCollector
 
setSegmentReaderAccess(SegmentReaderAccess) - Static method in class org.apache.lucene.internal.tests.TestSecrets
For internal initialization only.
setSegmentsPerTier(double) - Method in class org.apache.lucene.index.TieredMergePolicy
Sets the allowed number of segments per tier.
setSentenceIndex(int) - Method in interface org.apache.lucene.analysis.tokenattributes.SentenceAttribute
Set the sentence of the current token
setSentenceIndex(int) - Method in class org.apache.lucene.analysis.tokenattributes.SentenceAttributeImpl
 
setShortValue(short) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setSimilarity(Similarity) - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: set the Similarity implementation used by this IndexWriter.
setSimilarity(Similarity) - Method in class org.apache.lucene.search.IndexSearcher
Expert: Set the Similarity implementation used by this IndexSearcher.
setSingleSort() - Method in class org.apache.lucene.search.comparators.NumericComparator
 
setSingleSort() - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
 
setSingleSort() - Method in class org.apache.lucene.search.FieldComparator
Informs the comparator that sort is done on this single field.
setSlop(int) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
Sets the phrase slop for this query.
setSlop(int) - Method in class org.apache.lucene.search.PhraseQuery.Builder
Set the slop.
setSoftDeletesField(String) - Method in class org.apache.lucene.index.IndexWriterConfig
Sets the soft deletes field.
setStored(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to store this field.
setStoredValue(Analyzer, Object) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
Sets the stored value.
setStoreTermVectorOffsets(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to also store token character offsets into the term vector for this field.
setStoreTermVectorPayloads(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to also store token payloads into the term vector for this field.
setStoreTermVectorPositions(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to also store token positions into the term vector for this field.
setStoreTermVectors(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true if this field's indexed form should be also stored into term vectors.
setStringValue(String) - Method in class org.apache.lucene.document.Field
Expert: change the value of this field.
setStringValue(String) - Method in class org.apache.lucene.document.KeywordField
 
setStringValue(String) - Method in class org.apache.lucene.document.StoredValue
Set a string value.
setStringValue(String) - Method in class org.apache.lucene.document.StringField
 
setStringValue(String) - Method in class org.apache.lucene.document.TextField
 
setSuppressExceptions(ConcurrentMergeScheduler) - Method in interface org.apache.lucene.internal.tests.ConcurrentMergeSchedulerAccess
 
setTermFrequency(int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
 
setTermFrequency(int) - Method in interface org.apache.lucene.analysis.tokenattributes.TermFrequencyAttribute
Set the custom term frequency of the current term within one document.
setTermFrequency(int) - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
 
setThreadCount(int) - Method in class org.apache.lucene.index.CheckIndex
Set threadCount used for parallelizing index integrity checking.
setTimeout(QueryTimeout) - Method in class org.apache.lucene.search.IndexSearcher
Set a QueryTimeout for all searches that run through this IndexSearcher.
setTokenized(boolean) - Method in class org.apache.lucene.document.FieldType
Set to true to tokenize this field's contents via the configured Analyzer.
setTokenStream(TokenStream) - Method in class org.apache.lucene.document.Field
Expert: sets the token stream to be used for indexing and causes isIndexed() and isTokenized() to return true.
setTopLevelScoringClause() - Method in class org.apache.lucene.search.ScorerSupplier
Inform this ScorerSupplier that its returned scorers produce scores that get passed to the collector, as opposed to partial scores that then need to get combined (e.g.
setTopValue(Double) - Method in class org.apache.lucene.search.comparators.DoubleComparator
 
setTopValue(Float) - Method in class org.apache.lucene.search.comparators.FloatComparator
 
setTopValue(Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
setTopValue(Integer) - Method in class org.apache.lucene.search.comparators.DocComparator
 
setTopValue(Integer) - Method in class org.apache.lucene.search.comparators.IntComparator
 
setTopValue(Long) - Method in class org.apache.lucene.search.comparators.LongComparator
 
setTopValue(BytesRef) - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
 
setTopValue(BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
setTopValue(T) - Method in class org.apache.lucene.search.comparators.NumericComparator
 
setTopValue(T) - Method in class org.apache.lucene.search.FieldComparator
Record the top value, for future calls to LeafFieldComparator.compareTop(int).
setTotalTermFreq(long) - Method in class org.apache.lucene.search.similarities.BasicStats
Sets the total number of occurrences of this term across all documents.
setTriangleValue(int, int, boolean, int, int, boolean, int, int, boolean) - Method in class org.apache.lucene.document.ShapeField.Triangle
sets the vertices of the triangle as integer encoded values
setType(String) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Set the lexical type.
setType(String) - Method in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
Set the lexical type.
setType(String) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
setUnicodeArcs(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
Whether to make transition labels Unicode code points instead of UTF8 bytes, false by default
setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
 
setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
Sets if the IndexWriter should pack newly written segments in a compound file.
setUserData(Map<String, String>, boolean) - Method in class org.apache.lucene.index.SegmentInfos
Sets the commit data.
setUseUnmap(boolean) - Method in class org.apache.lucene.store.MMapDirectory
Deprecated, for removal: This API element is subject to removal in a future version.
Please use new system property MMapDirectory.ENABLE_UNMAP_HACK_SYSPROP instead
setValue(V) - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
sets the value associated with the last key returned
setValues(int, int, boolean, int, int, boolean, int, int, boolean) - Method in class org.apache.lucene.document.ShapeField.DecodedTriangle
Sets the values of the DecodedTriangle
setVectorAttributes(int, VectorEncoding, VectorSimilarityFunction) - Method in class org.apache.lucene.document.FieldType
Enable vector indexing, with the specified number of dimensions and distance function.
setVectorValue(byte[]) - Method in class org.apache.lucene.document.KnnByteVectorField
Set the vector value of this field
setVectorValue(float[]) - Method in class org.apache.lucene.document.KnnFloatVectorField
Set the vector value of this field
setVersion(int) - Method in class org.apache.lucene.util.fst.FSTCompiler.Builder
Expert: Set the codec version.
setVisitedCount(int) - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
setWeight(Weight) - Method in interface org.apache.lucene.search.Collector
Set the Weight that will be used to produce scorers that will feed LeafCollectors.
setWeight(Weight) - Method in class org.apache.lucene.search.FilterCollector
 
setWeight(Weight) - Method in class org.apache.lucene.search.MultiCollector
 
setWeight(Weight) - Method in class org.apache.lucene.search.TotalHitCountCollector
 
shallowSizeOf(boolean[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the boolean[] object.
shallowSizeOf(byte[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the byte[] object.
shallowSizeOf(char[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the char[] object.
shallowSizeOf(double[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the double[] object.
shallowSizeOf(float[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the float[] object.
shallowSizeOf(int[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the int[] object.
shallowSizeOf(long[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the long[] object.
shallowSizeOf(short[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the short[] object.
shallowSizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
Estimates a "shallow" memory usage of the given object.
shallowSizeOf(Object[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the shallow size in bytes of the Object[] object.
shallowSizeOfInstance(Class<?>) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the shallow instance size in bytes an instance of the given class would occupy.
shapeDocValues - Variable in class org.apache.lucene.document.ShapeDocValuesField
the binary doc value format for this field
ShapeDocValuesField - Class in org.apache.lucene.document
A doc values field for LatLonShape and XYShape that uses ShapeDocValues as the underlying binary doc value format.
ShapeField - Class in org.apache.lucene.document
A base shape utility class used for both LatLon (spherical) and XY (cartesian) shape fields.
ShapeField.DecodedTriangle - Class in org.apache.lucene.document
Represents a encoded triangle using ShapeField.decodeTriangle(byte[], DecodedTriangle).
ShapeField.DecodedTriangle.TYPE - Enum in org.apache.lucene.document
type of triangle
ShapeField.QueryRelation - Enum in org.apache.lucene.document
Query Relation Types *
ShapeField.Triangle - Class in org.apache.lucene.document
polygons are decomposed into tessellated triangles using Tessellator these triangles are encoded and inserted as separate indexed POINT fields
shardIndex - Variable in class org.apache.lucene.search.ScoreDoc
shiftConflictingKeys(int) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Shift all the slot-conflicting keys and values allocated to (and including) slot.
shortestPaths(FST<T>, FST.Arc<T>, T, Comparator<T>, int, boolean) - Static method in class org.apache.lucene.util.fst.Util
Starting from node, find the top N min cost completions to a final node.
SHOULD - org.apache.lucene.search.BooleanClause.Occur
Use this operator for clauses that should appear in the matching documents.
shouldCache(Query) - Method in interface org.apache.lucene.search.QueryCachingPolicy
Whether the given Query is worth caching.
shouldCache(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
 
shouldExit() - Method in interface org.apache.lucene.index.QueryTimeout
Called to determine whether to stop processing a query
shouldExit() - Method in class org.apache.lucene.index.QueryTimeoutImpl
Return true if QueryTimeoutImpl.reset() has not been called and the elapsed time has exceeded the time allowed.
shouldFallback(int, int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
 
shouldUpgradeSegment(SegmentCommitInfo) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
Returns if the given segment should be upgraded.
shutdown() - Method in class org.apache.lucene.util.SameThreadExecutorService
 
shutdownNow() - Method in class org.apache.lucene.util.SameThreadExecutorService
 
SI_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99SegmentInfoFormat
File extension used to store SegmentInfo.
sign() - Method in enum org.apache.lucene.geo.GeoUtils.WindingOrder
 
similarity - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
Similarity to use when encoding norms.
Similarity - Class in org.apache.lucene.search.similarities
Similarity defines the components of Lucene scoring.
Similarity() - Constructor for class org.apache.lucene.search.similarities.Similarity
Sole constructor.
Similarity.SimScorer - Class in org.apache.lucene.search.similarities
Stores the weight for a query across the indexed collection.
SimilarityBase - Class in org.apache.lucene.search.similarities
A subclass of Similarity that provides a simplified API for its descendants.
SimilarityBase() - Constructor for class org.apache.lucene.search.similarities.SimilarityBase
Sole constructor.
similarityToQueryVector(LeafReaderContext, byte[], String) - Static method in class org.apache.lucene.search.DoubleValuesSource
Returns a DoubleValues instance for computing the vector similarity score per document against the byte query vector
similarityToQueryVector(LeafReaderContext, float[], String) - Static method in class org.apache.lucene.search.DoubleValuesSource
Returns a DoubleValues instance for computing the vector similarity score per document against the float query vector
SimpleCollector - Class in org.apache.lucene.search
Base Collector implementation that is used to collect all contexts.
SimpleCollector() - Constructor for class org.apache.lucene.search.SimpleCollector
 
SimpleFieldComparator<T> - Class in org.apache.lucene.search
Base FieldComparator implementation that is used for all contexts.
SimpleFieldComparator() - Constructor for class org.apache.lucene.search.SimpleFieldComparator
 
SimpleFSLockFactory - Class in org.apache.lucene.store
SimpleMergedSegmentWarmer - Class in org.apache.lucene.index
A very simple merged segment warmer that just ensures data structures are initialized.
SimpleMergedSegmentWarmer(InfoStream) - Constructor for class org.apache.lucene.index.SimpleMergedSegmentWarmer
Creates a new SimpleMergedSegmentWarmer
SimpleRateLimiter(double) - Constructor for class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
mbPerSec is the MB/sec max IO rate
SimpleWKTShapeParser - Class in org.apache.lucene.geo
Parses shape geometry represented in WKT format
SimpleWKTShapeParser.ShapeType - Enum in org.apache.lucene.geo
Enumerated type for Shapes
sims - Variable in class org.apache.lucene.search.similarities.MultiSimilarity
the sub-similarities used to create the combined score
SimScorer() - Constructor for class org.apache.lucene.search.similarities.Similarity.SimScorer
Sole constructor.
SINGLE - org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Automaton that accepts only a single fixed string.
SingleInstanceLockFactory - Class in org.apache.lucene.store
Implements LockFactory for a single in-process instance, meaning all locking will take place through this one instance.
SingleInstanceLockFactory() - Constructor for class org.apache.lucene.store.SingleInstanceLockFactory
 
singleSort - Variable in class org.apache.lucene.search.comparators.NumericComparator
 
SingleTermsEnum - Class in org.apache.lucene.index
Subclass of FilteredTermsEnum for enumerating a single term.
SingleTermsEnum(TermsEnum, BytesRef) - Constructor for class org.apache.lucene.index.SingleTermsEnum
Creates a new SingleTermsEnum.
singleton(NumericDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns a multi-valued view over the provided NumericDocValues
singleton(SortedDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns a multi-valued view over the provided SortedDocValues
singletonDocID - Variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
docid when there is a single pulsed posting, otherwise -1.
singletonView(Iterable<Number>, Iterable<Number>, Number) - Static method in class org.apache.lucene.codecs.DocValuesConsumer
Helper: returns single-valued view, using missingValue when count is zero
sink - Variable in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Sink tokenstream, such as the outer tokenfilter decorating the chain.
sinkState - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
Which state, if any, accepts all suffixes, else -1.
size - Variable in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
size - Variable in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
size - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
size - Variable in class org.apache.lucene.util.hnsw.HnswGraph.NodesIterator
 
size() - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
size() - Method in class org.apache.lucene.analysis.CharArrayMap
 
size() - Method in class org.apache.lucene.analysis.CharArraySet
 
size() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
size() - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
 
size() - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
size() - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
size() - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
size() - Method in class org.apache.lucene.index.ByteVectorValues
Return the number of vectors for this field.
size() - Method in class org.apache.lucene.index.FieldInfos
Returns the number of fields
size() - Method in class org.apache.lucene.index.Fields
Returns the number of fields or -1 if the number of distinct field names is unknown.
size() - Method in class org.apache.lucene.index.FilterLeafReader.FilterFields
 
size() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
 
size() - Method in class org.apache.lucene.index.FilterVectorValues
 
size() - Method in class org.apache.lucene.index.FloatVectorValues
Return the number of vectors for this field.
size() - Method in class org.apache.lucene.index.MultiFields
 
size() - Method in class org.apache.lucene.index.MultiTerms
 
size() - Method in interface org.apache.lucene.index.PointValues.PointTree
Return the number of points below the current node.
size() - Method in class org.apache.lucene.index.PointValues
Returns the total number of indexed points across all documents.
size() - Method in class org.apache.lucene.index.PrefixCodedTerms
Return the number of terms stored in this PrefixCodedTerms.
size() - Method in class org.apache.lucene.index.SegmentInfos
Returns number of SegmentCommitInfos.
size() - Method in class org.apache.lucene.index.Sorter.DocMap
Return the number of documents in this map.
size() - Method in class org.apache.lucene.index.Terms
Returns the number of terms for this field, or -1 if this measure isn't stored by the codec.
size() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
size() - Method in class org.apache.lucene.search.LiveFieldValues
Returns the [approximate] number of id/value pairs buffered in RAM.
size() - Method in class org.apache.lucene.search.Multiset
 
size() - Method in class org.apache.lucene.store.ByteBuffersDataInput
Deprecated.
size() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
size() - Method in class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
Number of iterated finite strings.
size() - Method in class org.apache.lucene.util.bkd.BKDReader
 
size() - Method in class org.apache.lucene.util.BytesRefArray
Returns the current size of this BytesRefArray
size() - Method in class org.apache.lucene.util.BytesRefHash
Returns the number of BytesRef values in this BytesRefHash.
size() - Method in class org.apache.lucene.util.fst.OffHeapFSTStore
 
size() - Method in class org.apache.lucene.util.hnsw.BlockingFloatHeap
Returns the number of elements in this heap.
size() - Method in class org.apache.lucene.util.hnsw.FloatHeap
Returns the number of elements in this heap.
size() - Method in class org.apache.lucene.util.hnsw.HnswGraph.NodesIterator
The number of elements in this iterator *
size() - Method in class org.apache.lucene.util.hnsw.HnswGraph
Returns the number of nodes in the graph
size() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
size() - Method in class org.apache.lucene.util.hnsw.NeighborArray
 
size() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
size() - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
 
size() - Method in interface org.apache.lucene.util.hnsw.RandomAccessVectorValues
Return the number of vector values
size() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.IntContainer
 
size() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
size() - Method in class org.apache.lucene.util.LongHeap
Returns the number of elements currently stored in the PriorityQueue.
size() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
The number of values.
size() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
size() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
Returns the number of values
size() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
 
size() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
 
size() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
Returns number of values
size() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
Return the number of elements that have been added to this builder.
size() - Method in class org.apache.lucene.util.packed.PackedLongValues
Get the number of values in this array.
size() - Method in class org.apache.lucene.util.PriorityQueue
Returns the number of elements currently stored in the PriorityQueue.
size() - Method in class org.apache.lucene.util.SentinelIntSet
The number of integers in this set.
size() - Method in class org.apache.lucene.util.TermAndVector
 
size() - Method in class org.apache.lucene.util.WeakIdentityMap
Returns the number of key-value mappings in this map.
size(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
Return the cumulated number of points across all leaves of the given IndexReader.
size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
 
size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
 
size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogDocMergePolicy
 
size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
Return the byte size of the provided SegmentCommitInfo, pro-rated by percentage of non-deleted documents is set.
size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
 
sizeBytes(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
Return the byte size of the provided SegmentCommitInfo, pro-rated by percentage of non-deleted documents if LogMergePolicy.setCalibrateSizeByDeletes(boolean) is set.
sizeDocs(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
Return the number of documents in the provided SegmentCommitInfo, pro-rated by percentage of non-deleted documents if LogMergePolicy.setCalibrateSizeByDeletes(boolean) is set.
sizeInBytes() - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns total size in bytes of all files for this segment.
sizeMB - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Net size (MB) of the files referenced by this segment.
sizeOf(boolean[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the boolean[] object.
sizeOf(byte[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the byte[] object.
sizeOf(char[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the char[] object.
sizeOf(double[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the double[] object.
sizeOf(float[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the float[] object.
sizeOf(int[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the int[] object.
sizeOf(long[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the long[] object.
sizeOf(short[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the short[] object.
sizeOf(Integer) - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the shallow size of the provided Integer object.
sizeOf(Long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the shallow size of the provided Long object.
sizeOf(String) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the String object.
sizeOf(String[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the String[] object.
sizeOf(Query) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of a Query object.
sizeOf(Query, long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of a Query object.
sizeOf(Accountable) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of the Accountable object, using its Accountable.ramBytesUsed() method.
sizeOf(Accountable[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the size of the provided array of Accountables by summing up the shallow size of the array and the memory usage reported by each Accountable.
sizeOfCollection(Collection<?>) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of a Collection object, including sizes of its values, supplying RamUsageEstimator.UNKNOWN_DEFAULT_RAM_BYTES_USED when object type is not well known.
sizeOfCollection(Collection<?>, long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of a Collection object, including sizes of its values, supplying default object size when object type is not well known.
sizeOfMap(Map<?, ?>) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of a Map object, including sizes of its keys and values, supplying RamUsageEstimator.UNKNOWN_DEFAULT_RAM_BYTES_USED when object type is not well known.
sizeOfMap(Map<?, ?>, long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Returns the size in bytes of a Map object, including sizes of its keys and values, supplying default object size when object type is not well known.
sizeOfObject(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
Best effort attempt to estimate the size in bytes of an undetermined object.
sizeOfObject(Object, long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Best effort attempt to estimate the size in bytes of an undetermined object.
skip(long) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
Skip exactly count values.
skipBytes(long) - Method in class org.apache.lucene.store.ByteArrayDataInput
 
skipBytes(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
skipBytes(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
skipBytes(long) - Method in class org.apache.lucene.store.DataInput
Skip over numBytes bytes.
skipBytes(long) - Method in class org.apache.lucene.store.IndexInput
Skip over numBytes bytes.
skipBytes(long) - Method in class org.apache.lucene.store.InputStreamDataInput
 
skipBytes(long) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
skipDoc - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
Doc id of current skip entry per level.
skipFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
Skip the output previously written with Outputs.writeFinalOutput(T, org.apache.lucene.store.DataOutput); defaults to just calling Outputs.readFinalOutput(org.apache.lucene.store.DataInput) and discarding the result.
skipOffset - Variable in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
file offset for the start of the skip list, relative to docStartFP, if there are more than ForUtil.BLOCK_SIZE docs; otherwise -1
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
Skip the output; defaults to just calling Outputs.read(org.apache.lucene.store.DataInput) and discarding the result.
skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.PairOutputs
 
skipTo(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
Skips entries to the first beyond the current whose document number is greater than or equal to target.
skipToNextByte() - Method in class org.apache.lucene.util.packed.PackedDataInput
If there are pending bits (at most 7), they will be ignored and the next value will be read starting at the next byte.
SleepingLockWrapper - Class in org.apache.lucene.store
Directory that wraps another, and that sleeps and retries if obtaining the lock fails.
SleepingLockWrapper(Directory, long) - Constructor for class org.apache.lucene.store.SleepingLockWrapper
Create a new SleepingLockFactory
SleepingLockWrapper(Directory, long, long) - Constructor for class org.apache.lucene.store.SleepingLockWrapper
Create a new SleepingLockFactory
slice - Variable in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
slice - Variable in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
slice - Variable in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
slice - Variable in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
ReaderSlice describing how this sub-reader fits into the composite reader.
slice(long, long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
slice(String, long, long) - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
 
slice(String, long, long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
slice(String, long, long) - Method in class org.apache.lucene.store.ByteBufferIndexInput
Creates a slice of this index input, with the given description, offset, and length.
slice(String, long, long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
 
slice(String, long, long) - Method in class org.apache.lucene.store.FilterIndexInput
 
slice(String, long, long) - Method in class org.apache.lucene.store.IndexInput
Creates a slice of this index input, with the given description, offset, and length.
slices(List<LeafReaderContext>) - Method in class org.apache.lucene.search.IndexSearcher
Expert: Creates an array of leaf slices each holding a subset of the given leaves.
slices(List<LeafReaderContext>, int, int) - Static method in class org.apache.lucene.search.IndexSearcher
Static method to segregate LeafReaderContexts amongst multiple slices
SloppyMath - Class in org.apache.lucene.util
Math functions that trade off accuracy for speed.
SloppyMath() - Constructor for class org.apache.lucene.util.SloppyMath
 
SloppyPhraseMatcher - Class in org.apache.lucene.search
Find all slop-valid position-combinations (matches) encountered while traversing/hopping the PhrasePositions.
SloppyPhraseMatcher(PhraseQuery.PostingsAndFreq[], int, ScoreMode, Similarity.SimScorer, float, boolean) - Constructor for class org.apache.lucene.search.SloppyPhraseMatcher
 
sloppySin(double) - Static method in class org.apache.lucene.geo.GeoUtils
Returns the trigonometric sine of an angle converted as a cos operation.
slot - Variable in class org.apache.lucene.search.FieldValueHitQueue.Entry
 
slowAdvance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
Slow (linear) implementation of DocIdSetIterator.advance(int) relying on DocIdSetIterator.nextDoc() to advance beyond the target position.
SlowCodecReaderWrapper - Class in org.apache.lucene.index
Wraps arbitrary readers for merging.
SlowImpactsEnum - Class in org.apache.lucene.index
ImpactsEnum that doesn't index impacts but implements the API in a legal way.
SlowImpactsEnum(PostingsEnum) - Constructor for class org.apache.lucene.index.SlowImpactsEnum
Wrap the given PostingsEnum.
SmallFloat - Class in org.apache.lucene.util
Floating point numbers smaller than 32 bits.
smoothingScore(int) - Method in class org.apache.lucene.search.IndriDisjunctionScorer
 
smoothingScore(int) - Method in class org.apache.lucene.search.IndriScorer
 
smoothingScore(int) - Method in class org.apache.lucene.search.Scorable
Returns the smoothing score of the current document matching the query.
smoothingScore(int) - Method in class org.apache.lucene.search.TermScorer
 
smoothingScore(List<Scorer>, int) - Method in class org.apache.lucene.search.IndriAndScorer
 
smoothingScore(List<Scorer>, int) - Method in class org.apache.lucene.search.IndriDisjunctionScorer
 
snapshot() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
Snapshots the last commit.
snapshot() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Snapshots the last commit and returns it.
SnapshotDeletionPolicy - Class in org.apache.lucene.index
An IndexDeletionPolicy that wraps any other IndexDeletionPolicy and adds the ability to hold and later release snapshots of an index.
SnapshotDeletionPolicy(IndexDeletionPolicy) - Constructor for class org.apache.lucene.index.SnapshotDeletionPolicy
Sole constructor, taking the incoming IndexDeletionPolicy to wrap.
SNAPSHOTS_PREFIX - Static variable in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
Prefix used for the save file.
softDelCountOnFlush - Variable in class org.apache.lucene.index.SegmentWriteState
Number of only soft deleted documents set while flushing the segment.
SoftDeletesDirectoryReaderWrapper - Class in org.apache.lucene.index
This reader filters out documents that have a doc values value in the given field and treat these documents as soft deleted.
SoftDeletesDirectoryReaderWrapper(DirectoryReader, String) - Constructor for class org.apache.lucene.index.SoftDeletesDirectoryReaderWrapper
Creates a new soft deletes wrapper.
softDeletesField - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
soft deletes field
SoftDeletesRetentionMergePolicy - Class in org.apache.lucene.index
This MergePolicy allows to carry over soft deleted documents across merges.
SoftDeletesRetentionMergePolicy(String, Supplier<Query>, MergePolicy) - Constructor for class org.apache.lucene.index.SoftDeletesRetentionMergePolicy
softDeletesStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status of soft deletes
softUpdateDocument(Term, Iterable<? extends IndexableField>, Field...) - Method in class org.apache.lucene.index.IndexWriter
Expert: Updates a document by first updating the document(s) containing term with the given doc-values fields and then adding the new document.
softUpdateDocuments(Term, Iterable<? extends Iterable<? extends IndexableField>>, Field...) - Method in class org.apache.lucene.index.IndexWriter
Expert: Atomically updates documents matching the provided term with the given doc-values fields and adds a block of documents with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
sort() - Method in class org.apache.lucene.util.BytesRefHash
Returns the values array sorted by the referenced byte values.
sort(int, int) - Method in class org.apache.lucene.util.InPlaceMergeSorter
 
sort(int, int) - Method in class org.apache.lucene.util.IntroSorter
 
sort(int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
 
sort(int, int) - Method in class org.apache.lucene.util.Sorter
Sort the slice which starts at from (inclusive) and ends at to (exclusive).
sort(int, int) - Method in class org.apache.lucene.util.StableMSBRadixSorter.MergeSorter
 
sort(int, int) - Method in class org.apache.lucene.util.StringSorter
 
sort(int, int) - Method in class org.apache.lucene.util.TimSorter
 
sort(int, int[], int) - Method in class org.apache.lucene.util.LSBRadixSorter
Sort array[0:len] in place.
sort(int, int, int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
 
sort(String) - Method in class org.apache.lucene.util.OfflineSorter
Sort input to a new temp file, returning its name.
sort(Comparator<BytesRef>, boolean) - Method in class org.apache.lucene.util.BytesRefArray
Returns a BytesRefArray.SortState representing the order of elements in this array.
sort(BKDConfig, int, MutablePointTree, int, int) - Static method in class org.apache.lucene.util.bkd.MutablePointTreeReaderUtils
Sort the given MutablePointTree based on its packed value then doc ID.
Sort - Class in org.apache.lucene.search
Encapsulates sort criteria for returned hits.
Sort() - Constructor for class org.apache.lucene.search.Sort
Sorts by computed relevance.
Sort(SortField...) - Constructor for class org.apache.lucene.search.Sort
Sets the sort to the given criteria in succession: the first SortField is checked first, but if it produces a tie, then the second SortField is used to break the tie, etc.
sortableBytesToBigInt(byte[], int, int) - Static method in class org.apache.lucene.util.NumericUtils
Decodes a BigInteger value previously written with NumericUtils.bigIntToSortableBytes(java.math.BigInteger, int, byte[], int)
sortableBytesToInt(byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
Decodes an integer value previously written with NumericUtils.intToSortableBytes(int, byte[], int)
sortableBytesToLong(byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
Decodes a long value previously written with NumericUtils.longToSortableBytes(long, byte[], int)
sortableDoubleBits(long) - Static method in class org.apache.lucene.util.NumericUtils
Converts IEEE 754 representation of a double to sortable order (or back to the original)
sortableFloatBits(int) - Static method in class org.apache.lucene.util.NumericUtils
Converts IEEE 754 representation of a float to sortable order (or back to the original)
sortableIntToFloat(int) - Static method in class org.apache.lucene.util.NumericUtils
Converts a sortable int back to a float.
sortableLongToDouble(long) - Static method in class org.apache.lucene.util.NumericUtils
Converts a sortable long back to a double.
sortByDim(BKDConfig, int, int[], MutablePointTree, int, int, BytesRef, BytesRef) - Static method in class org.apache.lucene.util.bkd.MutablePointTreeReaderUtils
Sort points on the given dimension.
SORTED - org.apache.lucene.index.DocValuesType
A pre-sorted byte[].
SORTED_NUMERIC - org.apache.lucene.index.DocValuesType
A pre-sorted Number[].
SORTED_SET - org.apache.lucene.index.DocValuesType
A pre-sorted Set<byte[]>.
SortedDocValues - Class in org.apache.lucene.index
A per-document byte[] with presorted values.
SortedDocValues() - Constructor for class org.apache.lucene.index.SortedDocValues
Sole constructor.
SortedDocValuesField - Class in org.apache.lucene.document
Field that stores a per-document BytesRef value, indexed for sorting.
SortedDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.SortedDocValuesField
Create a new sorted DocValues field.
SortedNumericDocValues - Class in org.apache.lucene.index
A list of per-document numeric values, sorted according to Long.compare(long, long).
SortedNumericDocValues() - Constructor for class org.apache.lucene.index.SortedNumericDocValues
Sole constructor.
SortedNumericDocValuesField - Class in org.apache.lucene.document
Field that stores a per-document long values for scoring, sorting or value retrieval.
SortedNumericDocValuesField(String, long) - Constructor for class org.apache.lucene.document.SortedNumericDocValuesField
Creates a new DocValues field with the specified 64-bit long value
SortedNumericSelector - Class in org.apache.lucene.search
Selects a value from the document's list to use as the representative value
SortedNumericSelector() - Constructor for class org.apache.lucene.search.SortedNumericSelector
 
SortedNumericSelector.Type - Enum in org.apache.lucene.search
Type of selection to perform.
SortedNumericSortField - Class in org.apache.lucene.search
SortField for SortedNumericDocValues.
SortedNumericSortField(String, SortField.Type) - Constructor for class org.apache.lucene.search.SortedNumericSortField
Creates a sort, by the minimum value in the set for the document.
SortedNumericSortField(String, SortField.Type, boolean) - Constructor for class org.apache.lucene.search.SortedNumericSortField
Creates a sort, possibly in reverse, by the minimum value in the set for the document.
SortedNumericSortField(String, SortField.Type, boolean, SortedNumericSelector.Type) - Constructor for class org.apache.lucene.search.SortedNumericSortField
Creates a sort, possibly in reverse, specifying how the sort value from the document's set is selected.
SortedNumericSortField.Provider - Class in org.apache.lucene.search
A SortFieldProvider for this sort field
SortedSetDocValues - Class in org.apache.lucene.index
A multi-valued version of SortedDocValues.
SortedSetDocValues() - Constructor for class org.apache.lucene.index.SortedSetDocValues
Sole constructor.
SortedSetDocValuesField - Class in org.apache.lucene.document
Field that stores a set of per-document BytesRef values, indexed for faceting,grouping,joining.
SortedSetDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.SortedSetDocValuesField
Create a new sorted DocValues field.
SortedSetSelector - Class in org.apache.lucene.search
Selects a value from the document's set to use as the representative value
SortedSetSelector() - Constructor for class org.apache.lucene.search.SortedSetSelector
 
SortedSetSelector.Type - Enum in org.apache.lucene.search
Type of selection to perform.
SortedSetSortField - Class in org.apache.lucene.search
SortField for SortedSetDocValues.
SortedSetSortField(String, boolean) - Constructor for class org.apache.lucene.search.SortedSetSortField
Creates a sort, possibly in reverse, by the minimum value in the set for the document.
SortedSetSortField(String, boolean, SortedSetSelector.Type) - Constructor for class org.apache.lucene.search.SortedSetSortField
Creates a sort, possibly in reverse, specifying how the sort value from the document's set is selected.
SortedSetSortField.Provider - Class in org.apache.lucene.search
A SortFieldProvider for this sort
Sorter - Class in org.apache.lucene.index
Sorts documents of a given index by returning a permutation on the document IDs.
Sorter - Class in org.apache.lucene.util
Base class for sorting algorithms implementations.
Sorter() - Constructor for class org.apache.lucene.util.Sorter
Sole constructor, used for inheritance.
Sorter.DocMap - Class in org.apache.lucene.index
A permutation of doc IDs.
SortField - Class in org.apache.lucene.search
Stores information about how to sort documents by terms in an individual field.
SortField(String, FieldComparatorSource) - Constructor for class org.apache.lucene.search.SortField
Creates a sort with a custom comparison function.
SortField(String, FieldComparatorSource, boolean) - Constructor for class org.apache.lucene.search.SortField
Creates a sort, possibly in reverse, with a custom comparison function.
SortField(String, SortField.Type) - Constructor for class org.apache.lucene.search.SortField
Creates a sort by terms in the given field with the type of term values explicitly given.
SortField(String, SortField.Type, boolean) - Constructor for class org.apache.lucene.search.SortField
Creates a sort, possibly in reverse, by terms in the given field with the type of term values explicitly given.
SortField.Provider - Class in org.apache.lucene.search
A SortFieldProvider for field sorts
SortField.Type - Enum in org.apache.lucene.search
Specifies the type of the terms to be sorted, or special types such as CUSTOM
SortFieldProvider - Class in org.apache.lucene.index
Reads/Writes a named SortField from a segment info file, used to record index sorts
SortFieldProvider(String) - Constructor for class org.apache.lucene.index.SortFieldProvider
Creates a new SortFieldProvider.
SortInfo() - Constructor for class org.apache.lucene.util.OfflineSorter.SortInfo
create a new SortInfo (with empty statistics) for debugging
SortingCodecReader - Class in org.apache.lucene.index
An CodecReader which supports sorting documents by a given Sort.
sortKeyLength(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns the length of currentTerm needed for use as a sort key.
SortRescorer - Class in org.apache.lucene.search
A Rescorer that re-sorts according to a provided Sort.
SortRescorer(Sort) - Constructor for class org.apache.lucene.search.SortRescorer
Sole constructor.
sortTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
time spent sorting data (in milliseconds)
source - Variable in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Original source of the tokens.
source - Variable in class org.apache.lucene.util.automaton.Transition
Source state.
SOURCE - Static variable in class org.apache.lucene.index.IndexWriter
Key for the source of a segment in the diagnostics.
SOURCE_ADDINDEXES_READERS - Static variable in class org.apache.lucene.index.IndexWriter
Source of a segment which results from a call to IndexWriter.addIndexes(CodecReader...).
SOURCE_FLUSH - Static variable in class org.apache.lucene.index.IndexWriter
Source of a segment which results from a flush.
SOURCE_MERGE - Static variable in class org.apache.lucene.index.IndexWriter
Source of a segment which results from a merge of other segments.
SOUTH_EAST_ASIAN_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Chars in class \p{Line_Break = Complex_Context} are from South East Asian scripts (Thai, Lao, Myanmar, Khmer, etc.).
SOUTHEAST_ASIAN - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Southeast Asian token type
SPACE - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
 
SparseFixedBitSet - Class in org.apache.lucene.util
A bit set that only stores longs that have at least one bit which is set.
SparseFixedBitSet(int) - Constructor for class org.apache.lucene.util.SparseFixedBitSet
Create a SparseFixedBitSet that can contain bits between 0 included and length excluded.
split(byte[], byte[], int[]) - Method in class org.apache.lucene.util.bkd.BKDWriter
Pick the next dimension to split.
splitAt(char, String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
Splits a list separated by zero or more given separator characters.
splitFileNames(String) - Method in class org.apache.lucene.analysis.AbstractAnalysisFactory
Splits file names separated by comma character.
squareDistance(byte[], byte[]) - Method in interface org.apache.lucene.internal.vectorization.VectorUtilSupport
Returns the sum of squared differences of the two byte vectors.
squareDistance(byte[], byte[]) - Static method in class org.apache.lucene.util.VectorUtil
Returns the sum of squared differences of the two vectors.
squareDistance(float[], float[]) - Method in interface org.apache.lucene.internal.vectorization.VectorUtilSupport
Returns the sum of squared differences of the two vectors.
squareDistance(float[], float[]) - Static method in class org.apache.lucene.util.VectorUtil
Returns the sum of squared differences of the two vectors.
StableMSBRadixSorter - Class in org.apache.lucene.util
Stable radix sorter for variable-length strings.
StableMSBRadixSorter(int) - Constructor for class org.apache.lucene.util.StableMSBRadixSorter
 
StableMSBRadixSorter.MergeSorter - Class in org.apache.lucene.util
A MergeSorter taking advantage of temporary storage.
StandardAnalyzer - Class in org.apache.lucene.analysis.standard
Filters StandardTokenizer with LowerCaseFilter and StopFilter, using a configurable list of stop words.
StandardAnalyzer() - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
Builds an analyzer with no stop words.
StandardAnalyzer(Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
Builds an analyzer with the stop words from the given reader.
StandardAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
Builds an analyzer with the given stop words.
StandardDirectoryReader - Class in org.apache.lucene.index
Default implementation of DirectoryReader.
StandardTokenizer - Class in org.apache.lucene.analysis.standard
A grammar-based tokenizer constructed with JFlex.
StandardTokenizer() - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizer
Creates a new instance of the StandardTokenizer.
StandardTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizer
Creates a new StandardTokenizer with a given AttributeFactory
StandardTokenizerFactory - Class in org.apache.lucene.analysis.standard
Factory for StandardTokenizer.
StandardTokenizerFactory() - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizerFactory
Default ctor for compatibility with SPI
StandardTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizerFactory
Creates a new StandardTokenizerFactory
StandardTokenizerImpl - Class in org.apache.lucene.analysis.standard
This class implements Word Break rules from the Unicode Text Segmentation algorithm, as specified in Unicode Standard Annex #29.
StandardTokenizerImpl(Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Creates a new scanner
start - Variable in class org.apache.lucene.index.ReaderSlice
Document ID this slice starts from.
start - Variable in class org.apache.lucene.util.bkd.BKDRadixSelector.PathSlice
 
START_GUN_SIGNAL - Static variable in class org.apache.lucene.store.LockVerifyServer
 
startDoc(int, int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
startDoc(int, int) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Adds a new doc in this term.
startDocument() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
startDocument() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Called before writing the stored fields of the document.
startDocument(int) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
startDocument(int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called before writing the term vectors of the document.
startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Called before writing the terms of the field.
startOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
Returns this Token's starting offset, the position of the first character corresponding to this token in the source text.
startOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
startOffset() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Returns this Token's starting offset, the position of the first character corresponding to this token in the source text.
startOffset() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
startOffset() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
startOffset() - Method in class org.apache.lucene.index.PostingsEnum
Returns start offset for the current position, or -1 if offsets were not indexed.
startOffset() - Method in class org.apache.lucene.index.SlowImpactsEnum
 
startOffset() - Method in class org.apache.lucene.search.ExactPhraseMatcher
 
startOffset() - Method in class org.apache.lucene.search.FilterMatchesIterator
 
startOffset() - Method in interface org.apache.lucene.search.MatchesIterator
The starting offset of the current match, or -1 if offsets are not available
startOffset() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionFullPostingsEnum
 
startOffset() - Method in class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
startOffset() - Method in class org.apache.lucene.search.SloppyPhraseMatcher
 
startPosition() - Method in class org.apache.lucene.search.ExactPhraseMatcher
 
startPosition() - Method in class org.apache.lucene.search.FilterMatchesIterator
 
startPosition() - Method in interface org.apache.lucene.search.MatchesIterator
The start position of the current match
startPosition() - Method in class org.apache.lucene.search.SloppyPhraseMatcher
 
startSplit(String, List<Point>, List<Point>) - Method in interface org.apache.lucene.geo.Tessellator.Monitor
When a new polygon split is entered for mode=SPLIT, this is called.
startsWith(byte[], BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns true iff the ref starts with the given prefix.
startsWith(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
Returns true iff the ref starts with the given prefix.
startTerm(NumericDocValues) - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsWriter
 
startTerm(NumericDocValues) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
Start a new term.
startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsWriter
 
startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
Adds a term and its term frequency freq.
State() - Constructor for class org.apache.lucene.util.AttributeSource.State
 
StatePair - Class in org.apache.lucene.util.automaton
Pair of states.
StatePair(int, int) - Constructor for class org.apache.lucene.util.automaton.StatePair
Constructs a new state pair.
StaticImplementationAttributeFactory(AttributeFactory, Class<A>) - Constructor for class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
Expert: Creates an AttributeFactory returning clazz as instance for the attributes it implements and for all other attributes calls the given delegate factory.
Stats - Class in org.apache.lucene.codecs.lucene90.blocktree
BlockTree statistics for a single field returned by FieldReader.getStats().
step(int, int) - Method in class org.apache.lucene.util.automaton.Automaton
Performs lookup in transitions, assuming determinism.
step(int, int) - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns the state obtained by reading the given char from the given state.
STOP - org.apache.lucene.index.StoredFieldVisitor.Status
STOP: don't visit this field and stop processing any other fields for this document.
StopFilter - Class in org.apache.lucene.analysis
Removes stop words from a token stream.
StopFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.StopFilter
Constructs a filter which removes words from the input TokenStream that are named in the Set.
STOPPED - org.apache.lucene.index.MergePolicy.OneMergeProgress.PauseReason
Stopped (because of throughput rate set to 0, typically).
stopTimer() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Stops the timer thread
StopwordAnalyzerBase - Class in org.apache.lucene.analysis
Base class for Analyzers that need to make use of stopword sets.
StopwordAnalyzerBase() - Constructor for class org.apache.lucene.analysis.StopwordAnalyzerBase
Creates a new Analyzer with an empty stopword set
StopwordAnalyzerBase(CharArraySet) - Constructor for class org.apache.lucene.analysis.StopwordAnalyzerBase
Creates a new instance initialized with the given stopword set
stopwords - Variable in class org.apache.lucene.analysis.StopwordAnalyzerBase
An immutable stopword set
stored() - Method in class org.apache.lucene.document.FieldType
True if the field's value should be stored
stored() - Method in interface org.apache.lucene.index.IndexableFieldType
True if the field's value should be stored
StoredField - Class in org.apache.lucene.document
A field whose value is stored so that IndexSearcher.storedFields() and IndexReader.storedFields() will return the field and its value.
StoredField(String, byte[]) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given binary value.
StoredField(String, byte[], int, int) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given binary value.
StoredField(String, double) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given double value.
StoredField(String, float) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given float value.
StoredField(String, int) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given integer value.
StoredField(String, long) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given long value.
StoredField(String, CharSequence, FieldType) - Constructor for class org.apache.lucene.document.StoredField
Expert: allows you to customize the FieldType.
StoredField(String, String) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given string value.
StoredField(String, String, FieldType) - Constructor for class org.apache.lucene.document.StoredField
Expert: allows you to customize the FieldType.
StoredField(String, FieldType) - Constructor for class org.apache.lucene.document.StoredField
Expert: allows you to customize the FieldType.
StoredField(String, BytesRef) - Constructor for class org.apache.lucene.document.StoredField
Create a stored-only field with the given binary value.
StoredField(String, BytesRef, FieldType) - Constructor for class org.apache.lucene.document.StoredField
Expert: allows you to customize the FieldType.
storedFields() - Method in class org.apache.lucene.index.BaseCompositeReader
 
storedFields() - Method in class org.apache.lucene.index.CodecReader
 
storedFields() - Method in class org.apache.lucene.index.FilterLeafReader
 
storedFields() - Method in class org.apache.lucene.index.IndexReader
Returns a StoredFields reader for the stored fields of this index.
storedFields() - Method in class org.apache.lucene.index.ParallelLeafReader
 
storedFields() - Method in class org.apache.lucene.search.IndexSearcher
Returns a StoredFields reader for the stored fields of this index.
StoredFields - Class in org.apache.lucene.index
API for reading stored fields.
StoredFields() - Constructor for class org.apache.lucene.index.StoredFields
Sole constructor.
storedFieldsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes stored fields
storedFieldsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
StoredFieldsFormat - Class in org.apache.lucene.codecs
Controls the format of stored fields
StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.StoredFieldsFormat
Sole constructor.
StoredFieldsReader - Class in org.apache.lucene.codecs
Codec API for reading stored fields.
StoredFieldsReader() - Constructor for class org.apache.lucene.codecs.StoredFieldsReader
Sole constructor.
storedFieldsReaders - Variable in class org.apache.lucene.index.MergeState
Stored field producers being merged
storedFieldStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of stored fields (null if stored fields could not be tested).
StoredFieldsWriter - Class in org.apache.lucene.codecs
Codec API for writing stored fields: For every document, StoredFieldsWriter.startDocument() is called, informing the Codec that a new document has started.
StoredFieldsWriter() - Constructor for class org.apache.lucene.codecs.StoredFieldsWriter
Sole constructor.
StoredFieldsWriter.MergeVisitor - Class in org.apache.lucene.codecs
A visitor that adds every field it sees.
StoredFieldVisitor - Class in org.apache.lucene.index
Expert: provides a low-level means of accessing the stored field values in an index.
StoredFieldVisitor() - Constructor for class org.apache.lucene.index.StoredFieldVisitor
Sole constructor.
StoredFieldVisitor.Status - Enum in org.apache.lucene.index
Enumeration of possible return values for StoredFieldVisitor.needsField(org.apache.lucene.index.FieldInfo).
storedValue() - Method in class org.apache.lucene.document.DoubleField
 
storedValue() - Method in class org.apache.lucene.document.Field
 
storedValue() - Method in class org.apache.lucene.document.FloatField
 
storedValue() - Method in class org.apache.lucene.document.IntField
 
storedValue() - Method in class org.apache.lucene.document.KeywordField
 
storedValue() - Method in class org.apache.lucene.document.LongField
 
storedValue() - Method in class org.apache.lucene.document.StringField
 
storedValue() - Method in class org.apache.lucene.document.TextField
 
storedValue() - Method in interface org.apache.lucene.index.IndexableField
Stored value.
StoredValue - Class in org.apache.lucene.document
Abstraction around a stored value.
StoredValue(double) - Constructor for class org.apache.lucene.document.StoredValue
Ctor for double values.
StoredValue(float) - Constructor for class org.apache.lucene.document.StoredValue
Ctor for float values.
StoredValue(int) - Constructor for class org.apache.lucene.document.StoredValue
Ctor for integer values.
StoredValue(long) - Constructor for class org.apache.lucene.document.StoredValue
Ctor for long values.
StoredValue(String) - Constructor for class org.apache.lucene.document.StoredValue
Ctor for binary values.
StoredValue(BytesRef) - Constructor for class org.apache.lucene.document.StoredValue
Ctor for binary values.
StoredValue.Type - Enum in org.apache.lucene.document
Type of a StoredValue.
storeTermVectorOffsets() - Method in class org.apache.lucene.document.FieldType
True if this field's token character offsets should also be stored into term vectors.
storeTermVectorOffsets() - Method in interface org.apache.lucene.index.IndexableFieldType
True if this field's token character offsets should also be stored into term vectors.
storeTermVectorPayloads() - Method in class org.apache.lucene.document.FieldType
True if this field's token payloads should also be stored into the term vectors.
storeTermVectorPayloads() - Method in interface org.apache.lucene.index.IndexableFieldType
True if this field's token payloads should also be stored into the term vectors.
storeTermVectorPositions() - Method in class org.apache.lucene.document.FieldType
True if this field's token positions should also be stored into the term vectors.
storeTermVectorPositions() - Method in interface org.apache.lucene.index.IndexableFieldType
True if this field's token positions should also be stored into the term vectors.
storeTermVectors() - Method in class org.apache.lucene.document.FieldType
True if this field's indexed form should be also stored into term vectors.
storeTermVectors() - Method in interface org.apache.lucene.index.IndexableFieldType
True if this field's indexed form should be also stored into term vectors.
stream - Variable in class org.apache.lucene.util.PrintStreamInfoStream
 
Stream() - Constructor for class org.apache.lucene.search.PointInSetQuery.Stream
 
STRING - org.apache.lucene.document.StoredValue.Type
Type of string values.
STRING - org.apache.lucene.search.SortField.Type
Sort using term values as Strings.
STRING_FIRST - Static variable in class org.apache.lucene.search.SortField
Pass this to SortField.setMissingValue(java.lang.Object) to have missing string values sort first.
STRING_LAST - Static variable in class org.apache.lucene.search.SortField
Pass this to SortField.setMissingValue(java.lang.Object) to have missing string values sort last.
STRING_VAL - org.apache.lucene.search.SortField.Type
Sort using term values as Strings, but comparing by value (using String.compareTo) for all comparisons.
stringField(FieldInfo, String) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
 
stringField(FieldInfo, String) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
 
stringField(FieldInfo, String) - Method in class org.apache.lucene.index.StoredFieldVisitor
Process a string field.
StringField - Class in org.apache.lucene.document
A field that is indexed but not tokenized: the entire String value is indexed as a single token.
StringField(String, String, Field.Store) - Constructor for class org.apache.lucene.document.StringField
Creates a new textual StringField, indexing the provided String value as a single token.
StringField(String, BytesRef, Field.Store) - Constructor for class org.apache.lucene.document.StringField
Creates a new binary StringField, indexing the provided binary (BytesRef) value as a single token.
stringHashCode(char[], int, int) - Static method in class org.apache.lucene.util.CharsRef
 
StringHelper - Class in org.apache.lucene.util
Methods for manipulating strings.
StringSorter - Class in org.apache.lucene.util
StringSorter(String, Object, boolean, IndexSorter.SortedDocValuesProvider) - Constructor for class org.apache.lucene.index.IndexSorter.StringSorter
Creates a new StringSorter
StringSorter(Comparator<BytesRef>) - Constructor for class org.apache.lucene.util.StringSorter
 
StringSorter.MSBStringRadixSorter - Class in org.apache.lucene.util
A radix sorter for BytesRef
stringToDate(String) - Static method in class org.apache.lucene.document.DateTools
Converts a string produced by timeToString or dateToString back to a time, represented as a Date object.
stringToTime(String) - Static method in class org.apache.lucene.document.DateTools
Converts a string produced by timeToString or dateToString back to a time, represented as the number of milliseconds since January 1, 1970, 00:00:00 GMT.
stringValue() - Method in class org.apache.lucene.document.Field
The value of the field as a String, or null.
stringValue() - Method in class org.apache.lucene.document.ShapeDocValuesField
Currently there is no string representation for the ShapeDocValueField
stringValue() - Method in interface org.apache.lucene.index.IndexableField
Non-null if this field has a string value
stripExtension(String) - Static method in class org.apache.lucene.index.IndexFileNames
Removes the extension (anything after the first '.'), otherwise returns the original filename.
stripSegmentName(String) - Static method in class org.apache.lucene.index.IndexFileNames
Strips the segment name out of the given file name.
Sub(MergeState.DocMap) - Constructor for class org.apache.lucene.index.DocIDMerger.Sub
Sole constructor
subBlocksOnlyBlockCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
The number of "internal" blocks that do not contain terms (have only sub-blocks).
subIndex(int, int[]) - Static method in class org.apache.lucene.index.ReaderUtil
Returns index of the searcher/reader for document n in the array used to construct this searcher/reader.
subIndex(int, List<LeafReaderContext>) - Static method in class org.apache.lucene.index.ReaderUtil
Returns index of the searcher/reader for document n in the array used to construct this searcher/reader.
subReadersSorter - Variable in class org.apache.lucene.index.BaseCompositeReader
A comparator for sorting sub-readers
SubReaderWrapper() - Constructor for class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
Constructor
subSequence(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
subSequence(int, int) - Method in class org.apache.lucene.util.CharsRef
 
subsetOf(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns true if the language of a1 is a subset of the language of a2.
subtract(int, int, byte[], byte[], byte[]) - Static method in class org.apache.lucene.util.NumericUtils
Result = a - b, where a >= b, else IllegalArgumentException is thrown.
subtract(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
subtract(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
subtract(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
subtract(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
subtract(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
subtract(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
subtract(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg subtract("foobar", "foo") -> "bar"
suffixRAMLimitMB(double) - Method in class org.apache.lucene.util.fst.FSTCompiler.Builder
The approximate maximum amount of RAM (in MB) to use holding the suffix cache, which enables the FST to share common suffixes.
sumDocFreq() - Method in class org.apache.lucene.search.CollectionStatistics
The total number of posting list entries for this field.
sumRelativeErrorBound(int) - Static method in class org.apache.lucene.util.MathUtil
Return a relative error bound for a sum of numValues positive doubles, computed using recursive summation, ie.
sumTotalTermFreq() - Method in class org.apache.lucene.search.CollectionStatistics
The total number of tokens for this field.
sumUpperBound(double, int) - Static method in class org.apache.lucene.util.MathUtil
Return the maximum possible sum across numValues non-negative doubles, assuming one sum yielded sum.
SUN_OS - Static variable in class org.apache.lucene.util.Constants
True iff running on SunOS.
SuppressForbidden - Annotation Type in org.apache.lucene.util
Annotation to suppress forbidden-apis errors inside a whole class, a method, or a field.
swap(int, int) - Method in class org.apache.lucene.codecs.MutablePointTree
Swap the i-th and j-th values.
swap(int, int) - Method in class org.apache.lucene.util.Selector
Swap values at slots i and j.
swap(int, int) - Method in class org.apache.lucene.util.Sorter
Swap values at slots i and j.
swap(int, int) - Method in class org.apache.lucene.util.StringSorter.MSBStringRadixSorter
 
swap(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Swap values stored in slots i and j
sync() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Wait for any running merge threads to finish.
sync(Collection<String>) - Method in class org.apache.lucene.codecs.CompoundDirectory
 
sync(Collection<String>) - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
sync(Collection<String>) - Method in class org.apache.lucene.store.Directory
Ensures that any writes to these files are moved to stable storage (made durable).
sync(Collection<String>) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
sync(Collection<String>) - Method in class org.apache.lucene.store.FilterDirectory
 
sync(Collection<String>) - Method in class org.apache.lucene.store.FSDirectory
 
sync(Collection<String>) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
sync(Collection<String>) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
syncMetaData() - Method in class org.apache.lucene.codecs.CompoundDirectory
 
syncMetaData() - Method in class org.apache.lucene.store.ByteBuffersDirectory
 
syncMetaData() - Method in class org.apache.lucene.store.Directory
Ensures that directory metadata, such as recent file renames, are moved to stable storage.
syncMetaData() - Method in class org.apache.lucene.store.FileSwitchDirectory
 
syncMetaData() - Method in class org.apache.lucene.store.FilterDirectory
 
syncMetaData() - Method in class org.apache.lucene.store.FSDirectory
 
syncMetaData() - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
 
SynonymQuery - Class in org.apache.lucene.search
A query that treats multiple terms as synonyms.
SynonymQuery.Builder - Class in org.apache.lucene.search
A builder for SynonymQuery.

T

target() - Method in class org.apache.lucene.util.fst.FST.Arc
Ord/address to target node.
targetHasArcs(FST.Arc<T>) - Static method in class org.apache.lucene.util.fst.FST
returns true if the node at this address has any outgoing arcs
targetMBPerSec - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
Current IO writes throttle rate
targetMBPerSecChanged() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Subclass can override to tweak targetMBPerSec.
TaskExecutor - Class in org.apache.lucene.search
Executor wrapper responsible for the execution of concurrent tasks.
TaskExecutor(Executor) - Constructor for class org.apache.lucene.search.TaskExecutor
Creates a TaskExecutor instance
tempMergeFiles - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
number of temporary files created when merging partitions
tenum - Variable in class org.apache.lucene.index.FilteredTermsEnum
The delegate TermsEnum.
term - Variable in class org.apache.lucene.search.AutomatonQuery
term containing the field, and possibly some pattern structure
term - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
For CompiledAutomaton.AUTOMATON_TYPE.SINGLE this is the singleton term.
term - Variable in class org.apache.lucene.util.QueryBuilder.TermAndBoost
the term
term() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
term() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
term() - Method in class org.apache.lucene.index.MultiTermsEnum
 
term() - Method in class org.apache.lucene.index.TermsEnum
Returns current term.
term() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
term() - Method in class org.apache.lucene.search.TermStatistics
The term text.
Term - Class in org.apache.lucene.index
A Term represents a word from text.
Term(String) - Constructor for class org.apache.lucene.index.Term
Constructs a Term with the given field and empty text.
Term(String, String) - Constructor for class org.apache.lucene.index.Term
Constructs a Term with the given field and text.
Term(String, BytesRef) - Constructor for class org.apache.lucene.index.Term
Constructs a Term with the given field and bytes.
Term(String, BytesRefBuilder) - Constructor for class org.apache.lucene.index.Term
Constructs a Term with the given field and the bytes from a builder.
TermAndBoost(BytesRef, float) - Constructor for class org.apache.lucene.util.QueryBuilder.TermAndBoost
Creates a new TermAndBoost
TermAndVector - Class in org.apache.lucene.util
Word2Vec unit composed by a term with the associated vector
TermAndVector(BytesRef, float[]) - Constructor for class org.apache.lucene.util.TermAndVector
 
termBlockOrd - Variable in class org.apache.lucene.codecs.BlockTermState
the term's ord in the current block
termCollector(Set<Term>) - Static method in class org.apache.lucene.search.QueryVisitor
Builds a QueryVisitor instance that collects all terms that may match a query
termCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Number of terms with at least one live doc.
TermFrequencyAttribute - Interface in org.apache.lucene.analysis.tokenattributes
Sets the custom term frequency of a term within one document.
TermFrequencyAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of TermFrequencyAttribute.
TermFrequencyAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
Initialize this attribute with term frequency of 1
termIndexStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of indexed terms (null if indexed terms could not be tested).
TermInSetQuery - Class in org.apache.lucene.search
Specialization for a disjunction over many terms that, by default, behaves like a ConstantScoreQuery over a BooleanQuery containing only BooleanClause.Occur.SHOULD clauses.
TermInSetQuery(String, Collection<BytesRef>) - Constructor for class org.apache.lucene.search.TermInSetQuery
 
TermInSetQuery(String, BytesRef...) - Constructor for class org.apache.lucene.search.TermInSetQuery
Deprecated.
TermInSetQuery(MultiTermQuery.RewriteMethod, String, Collection<BytesRef>) - Constructor for class org.apache.lucene.search.TermInSetQuery
Creates a new TermInSetQuery from the given collection of terms.
TermInSetQuery(MultiTermQuery.RewriteMethod, String, BytesRef...) - Constructor for class org.apache.lucene.search.TermInSetQuery
TermOrdValComparator - Class in org.apache.lucene.search.comparators
Sorts by field's natural Term sort order, using ordinals.
TermOrdValComparator(int, String, boolean, boolean, Pruning) - Constructor for class org.apache.lucene.search.comparators.TermOrdValComparator
Creates this, with control over how missing values are sorted.
termPositionsCost(TermsEnum) - Static method in class org.apache.lucene.search.PhraseQuery
Returns an expected cost in simple operations of processing the occurrences of a term in a document that contains the term.
TermQuery - Class in org.apache.lucene.search
A Query that matches documents containing a term.
TermQuery(Term) - Constructor for class org.apache.lucene.search.TermQuery
Constructs a query for the term t.
TermQuery(Term, TermStates) - Constructor for class org.apache.lucene.search.TermQuery
Expert: constructs a TermQuery that will use the provided docFreq instead of looking up the docFreq against the searcher.
TermRangeQuery - Class in org.apache.lucene.search
A Query that matches documents within an range of terms.
TermRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeQuery
Constructs a query selecting all terms greater/equal than lowerTerm but less/equal than upperTerm.
TermRangeQuery(String, BytesRef, BytesRef, boolean, boolean, MultiTermQuery.RewriteMethod) - Constructor for class org.apache.lucene.search.TermRangeQuery
Constructs a query selecting all terms greater/equal than lowerTerm but less/equal than upperTerm.
terms(String) - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
 
terms(String) - Method in class org.apache.lucene.index.CodecReader
 
terms(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
 
terms(String) - Method in class org.apache.lucene.index.Fields
Get the Terms for this field.
terms(String) - Method in class org.apache.lucene.index.FilterLeafReader.FilterFields
 
terms(String) - Method in class org.apache.lucene.index.FilterLeafReader
 
terms(String) - Method in class org.apache.lucene.index.LeafReader
Returns the Terms index for this field, or null if it has none.
terms(String) - Method in class org.apache.lucene.index.MappedMultiFields
 
terms(String) - Method in class org.apache.lucene.index.MultiFields
 
terms(String) - Method in class org.apache.lucene.index.ParallelLeafReader
 
Terms - Class in org.apache.lucene.index
Access to the terms in a specific field.
Terms() - Constructor for class org.apache.lucene.index.Terms
Sole constructor.
TermScorer - Class in org.apache.lucene.search
Expert: A Scorer for documents matching a Term.
TermScorer(Weight, ImpactsEnum, LeafSimScorer, boolean) - Constructor for class org.apache.lucene.search.TermScorer
Construct a TermScorer that will use impacts to skip blocks of non-competitive documents.
TermScorer(Weight, PostingsEnum, LeafSimScorer) - Constructor for class org.apache.lucene.search.TermScorer
Construct a TermScorer that will iterate all documents.
termsEnum() - Method in class org.apache.lucene.index.FilterSortedDocValues
 
termsEnum() - Method in class org.apache.lucene.index.FilterSortedSetDocValues
 
termsEnum() - Method in class org.apache.lucene.index.SortedDocValues
Returns a TermsEnum over the values.
termsEnum() - Method in class org.apache.lucene.index.SortedSetDocValues
Returns a TermsEnum over the values.
TermsEnum - Class in org.apache.lucene.index
TermsEnum() - Constructor for class org.apache.lucene.index.TermsEnum
Sole constructor.
TermsEnum.SeekStatus - Enum in org.apache.lucene.index
termsOnlyBlockCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
The number of "leaf" blocks (blocks that have only terms).
termState() - Method in class org.apache.lucene.index.BaseTermsEnum
 
termState() - Method in class org.apache.lucene.index.FilteredTermsEnum
Returns the filtered enums term state
termState() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
termState() - Method in class org.apache.lucene.index.TermsEnum
Expert: Returns the TermsEnums internal state to position the TermsEnum without re-seeking the term dictionary.
termState() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
TermState - Class in org.apache.lucene.index
Encapsulates all required internal state to position the associated TermsEnum without re-seeking.
TermState() - Constructor for class org.apache.lucene.index.TermState
Sole constructor.
TermStates - Class in org.apache.lucene.index
Maintains a IndexReader TermState view over IndexReader instances containing a single term.
TermStates(IndexReaderContext) - Constructor for class org.apache.lucene.index.TermStates
Creates an empty TermStates from a IndexReaderContext
TermStates(IndexReaderContext, TermState, int, int, long) - Constructor for class org.apache.lucene.index.TermStates
Creates a TermStates with an initial TermState, IndexReader pair.
termStatistics(Term, int, long) - Method in class org.apache.lucene.search.IndexSearcher
Returns TermStatistics for a term.
TermStatistics - Class in org.apache.lucene.search
Contains statistics for a specific term
TermStatistics(BytesRef, long, long) - Constructor for class org.apache.lucene.search.TermStatistics
Creates statistics instance for a term.
TermStats - Class in org.apache.lucene.codecs
Holder for per-term statistics.
TermStats(int, long) - Constructor for class org.apache.lucene.codecs.TermStats
Sole constructor.
TermToBytesRefAttribute - Interface in org.apache.lucene.analysis.tokenattributes
This attribute is requested by TermsHashPerField to index the contents.
TermValComparator(int, String, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.TermValComparator
Sole constructor.
termVectors() - Method in class org.apache.lucene.index.BaseCompositeReader
 
termVectors() - Method in class org.apache.lucene.index.CodecReader
 
termVectors() - Method in class org.apache.lucene.index.FilterLeafReader
 
termVectors() - Method in class org.apache.lucene.index.IndexReader
Returns a TermVectors reader for the term vectors of this index.
termVectors() - Method in class org.apache.lucene.index.ParallelLeafReader
 
TermVectors - Class in org.apache.lucene.index
API for reading term vectors.
TermVectors() - Constructor for class org.apache.lucene.index.TermVectors
Sole constructor.
termVectorsFormat() - Method in class org.apache.lucene.codecs.Codec
Encodes/decodes term vectors
termVectorsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
 
termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene99.Lucene99Codec
 
TermVectorsFormat - Class in org.apache.lucene.codecs
Controls the format of term vectors
TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.TermVectorsFormat
Sole constructor.
TermVectorsReader - Class in org.apache.lucene.codecs
Codec API for reading term vectors:
TermVectorsReader() - Constructor for class org.apache.lucene.codecs.TermVectorsReader
Sole constructor.
termVectorsReaders - Variable in class org.apache.lucene.index.MergeState
Term vector producers being merged
termVectorStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of term vectors (null if term vectors could not be tested).
TermVectorsWriter - Class in org.apache.lucene.codecs
Codec API for writing term vectors: For every document, TermVectorsWriter.startDocument(int) is called, informing the Codec how many fields will be written.
TermVectorsWriter() - Constructor for class org.apache.lucene.codecs.TermVectorsWriter
Sole constructor.
tessellate(Polygon, boolean) - Static method in class org.apache.lucene.geo.Tessellator
 
tessellate(Polygon, boolean, Tessellator.Monitor) - Static method in class org.apache.lucene.geo.Tessellator
 
tessellate(XYPolygon, boolean) - Static method in class org.apache.lucene.geo.Tessellator
 
tessellate(XYPolygon, boolean, Tessellator.Monitor) - Static method in class org.apache.lucene.geo.Tessellator
 
Tessellator - Class in org.apache.lucene.geo
Computes a triangular mesh tessellation for a given polygon.
Tessellator.Monitor - Interface in org.apache.lucene.geo
Implementation of this interface will receive calls with internal data at each step of the triangulation algorithm.
Tessellator.Node - Class in org.apache.lucene.geo
Circular Doubly-linked list used for polygon coordinates
Tessellator.Triangle - Class in org.apache.lucene.geo
Triangle in the tessellated mesh
test(int, int) - Method in class org.apache.lucene.geo.GeoEncodingUtils.Component2DPredicate
Check whether the given point is within the considered polygon.
test(int, int) - Method in class org.apache.lucene.geo.GeoEncodingUtils.DistancePredicate
Check whether the given point is within a distance of another point.
testDocValues(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test docvalues.
testFieldInfos(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test field infos.
testFieldNorms(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test field norms.
testLiveDocs(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test live docs.
testPoints(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test the points index.
testPostings(CodecReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
Test the term index.
testPostings(CodecReader, PrintStream, boolean, boolean, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test the term index.
TestSecrets - Class in org.apache.lucene.internal.tests
A set of static methods returning accessors for internal, package-private functionality in Lucene.
testSort(CodecReader, Sort, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Tests index sort order.
testStoredFields(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test stored fields.
testTermVectors(CodecReader, PrintStream) - Static method in class org.apache.lucene.index.CheckIndex
Test term vectors.
testTermVectors(CodecReader, PrintStream, boolean, boolean, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test term vectors.
testVectors(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
Test the vectors index.
text() - Method in class org.apache.lucene.index.Term
Returns the text of this term.
TextField - Class in org.apache.lucene.document
A field that is indexed and tokenized, without term vectors.
TextField(String, Reader) - Constructor for class org.apache.lucene.document.TextField
Creates a new un-stored TextField with Reader value.
TextField(String, String, Field.Store) - Constructor for class org.apache.lucene.document.TextField
Creates a new TextField with String value.
TextField(String, TokenStream) - Constructor for class org.apache.lucene.document.TextField
Creates a new un-stored TextField with TokenStream value.
tf(float) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
Implemented as sqrt(freq).
tf(float) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
Computes a score factor based on a term or phrase's frequency in a document.
tf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
compute the term frequency component
tf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
compute the term frequency component
tf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
compute the term frequency component
tf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
compute the term frequency component
tf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
compute the term frequency component
tf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
compute the term frequency component
tf(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
compute the term frequency component
tfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
Explain the score of the term frequency component for a single document
tfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
 
tfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
 
tfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
 
tfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
 
tfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
 
tfExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
 
TFIDFSimilarity - Class in org.apache.lucene.search.similarities
Implementation of Similarity with the Vector Space Model.
TFIDFSimilarity() - Constructor for class org.apache.lucene.search.similarities.TFIDFSimilarity
Sole constructor.
tfln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
compute the mixed term frequency and document length component
tfln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
compute the mixed term frequency and document length component
tfln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
compute the mixed term frequency and document length component
tfln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
compute the mixed term frequency and document length component
tfln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
compute the mixed term frequency and document length component
tfln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
compute the mixed term frequency and document length component
tfln(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
compute the mixed term frequency and document length component
tflnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Axiomatic
Explain the score of the mixed term frequency and document length component for a single document
tflnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
 
tflnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
 
tflnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
 
tflnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
 
tflnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
 
tflnExplain(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
 
tfn(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
 
tfn(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.Normalization
Returns the normalized term frequency.
tfn(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationH1
 
tfn(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationH2
 
tfn(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationH3
 
tfn(BasicStats, double, double) - Method in class org.apache.lucene.search.similarities.NormalizationZ
 
THREAD_NAME - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
ThreadInterruptedException - Exception in org.apache.lucene.util
Thrown by lucene on detecting that Thread.interrupt() had been called.
ThreadInterruptedException(InterruptedException) - Constructor for exception org.apache.lucene.util.ThreadInterruptedException
 
TieredMergePolicy - Class in org.apache.lucene.index
Merges segments of approximately equal size, subject to an allowed number of segments per tier.
TieredMergePolicy() - Constructor for class org.apache.lucene.index.TieredMergePolicy
Sole constructor, setting all settings to their defaults.
TieredMergePolicy.MergeScore - Class in org.apache.lucene.index
Holds score and explanation for a single candidate merge.
timedOut() - Method in class org.apache.lucene.search.IndexSearcher
Returns true if any search hit the timeout.
TimeLimitingCollector - Class in org.apache.lucene.search
The TimeLimitingCollector is used to timeout search requests that take longer than the maximum allowed search time limit.
TimeLimitingCollector(Collector, Counter, long) - Constructor for class org.apache.lucene.search.TimeLimitingCollector
Create a TimeLimitedCollector wrapper over another Collector with a specified timeout.
TimeLimitingCollector.TimeExceededException - Exception in org.apache.lucene.search
Thrown when elapsed search time exceeds allowed search time.
TimeLimitingCollector.TimerThread - Class in org.apache.lucene.search
Thread used to timeout search requests.
TimerThread(long, Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
TimerThread(Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
timeToString(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
Converts a millisecond time to a string suitable for indexing.
timSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
Sorts the given random access List in natural order.
timSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
Sorts the given random access List using the Comparator.
timSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array in natural order.
timSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array slice in natural order.
timSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array slice using the Comparator.
timSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
Sorts the given array using the Comparator.
TimSorter - Class in org.apache.lucene.util
Sorter implementation based on the TimSort algorithm.
TimSorter(int) - Constructor for class org.apache.lucene.util.TimSorter
Create a new TimSorter.
to - Variable in class org.apache.lucene.util.automaton.RegExp
Extents for range type expressions
toArray() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.IntContainer
 
toArrayCopy() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
Return a contiguous array with the current content written to the output.
toArrayCopy() - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
toAutomaton() - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toAutomaton(int) - Method in class org.apache.lucene.util.automaton.LevenshteinAutomata
Compute a DFA that accepts all strings within an edit distance of n.
toAutomaton(int) - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toAutomaton(int, String) - Method in class org.apache.lucene.util.automaton.LevenshteinAutomata
Compute a DFA that accepts all strings within an edit distance of n, matching the specified exact prefix.
toAutomaton(Map<String, Automaton>, int) - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toAutomaton(TokenStream) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
Pulls the graph (including PositionLengthAttribute) from the provided TokenStream, and creates the corresponding automaton where arcs are bytes (or Unicode code points if unicodeArcs = true) from each term.
toAutomaton(Term) - Static method in class org.apache.lucene.search.WildcardQuery
Convert Lucene wildcard syntax into an automaton.
toAutomaton(AutomatonProvider, int) - Method in class org.apache.lucene.util.automaton.RegExp
Constructs new Automaton from this RegExp.
toAutomaton(BytesRef) - Static method in class org.apache.lucene.search.PrefixQuery
Build an automaton accepting all terms with the specified prefix.
toAutomaton(BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.search.TermRangeQuery
 
toBufferList() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
Return a list of read-only view of ByteBuffer blocks over the current content written to the output.
toBytesRef() - Method in class org.apache.lucene.util.BytesRefBuilder
Build a new BytesRef that has the same content as this buffer.
toBytesRef(IntsRef, BytesRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Just converts IntsRef to BytesRef; you must ensure the int values fit into a byte.
toChars(int[], int, int, char[], int) - Static method in class org.apache.lucene.analysis.CharacterUtils
Converts a sequence of unicode code points to a sequence of Java characters.
toCharsRef() - Method in class org.apache.lucene.util.CharsRefBuilder
Build a new CharsRef that has the same content as this builder.
toCodePoints(char[], int, int, int[], int) - Static method in class org.apache.lucene.analysis.CharacterUtils
Converts a sequence of Java characters to a sequence of unicode code points.
toComponent2D() - Method in class org.apache.lucene.geo.Circle
 
toComponent2D() - Method in class org.apache.lucene.geo.Geometry
get a Component2D from the geometry object
toComponent2D() - Method in class org.apache.lucene.geo.Line
 
toComponent2D() - Method in class org.apache.lucene.geo.Point
 
toComponent2D() - Method in class org.apache.lucene.geo.Polygon
 
toComponent2D() - Method in class org.apache.lucene.geo.Rectangle
 
toComponent2D() - Method in class org.apache.lucene.geo.XYCircle
 
toComponent2D() - Method in class org.apache.lucene.geo.XYLine
 
toComponent2D() - Method in class org.apache.lucene.geo.XYPoint
 
toComponent2D() - Method in class org.apache.lucene.geo.XYPolygon
 
toComponent2D() - Method in class org.apache.lucene.geo.XYRectangle
 
toDataInput() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
Return a ByteBuffersDataInput for the set of current buffers (ByteBuffersDataOutput.toBufferList()).
toDot() - Method in class org.apache.lucene.util.automaton.Automaton
Returns the dot (graphviz) representation of this automaton.
toDot(FST<T>, Writer, boolean, boolean) - Static method in class org.apache.lucene.util.fst.Util
Dumps an FST to a GraphViz's dot language description for visualization.
toDoubleValuesSource() - Method in class org.apache.lucene.search.LongValuesSource
Convert to a DoubleValuesSource by casting long values to doubles
toGeoJSON() - Method in class org.apache.lucene.geo.Line
prints lines as geojson
toGeoJSON() - Method in class org.apache.lucene.geo.Polygon
prints polygons as geojson
toHexString(String) - Static method in class org.apache.lucene.util.UnicodeUtil
 
toIntsRef() - Method in class org.apache.lucene.util.IntsRefBuilder
Build a new CharsRef that has the same content as this builder.
toIntsRef(BytesRef, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Just takes unsigned byte values from the BytesRef and converts into an IntsRef.
TOKEN_STREAM - org.apache.lucene.document.InvertableType
TOKEN_TYPES - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
String token types that correspond to token type int constants
TokenFilter - Class in org.apache.lucene.analysis
A TokenFilter is a TokenStream whose input is another TokenStream.
TokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.TokenFilter
Construct a token stream filtering the given input.
TokenFilterFactory - Class in org.apache.lucene.analysis
Abstract parent class for analysis factories that create TokenFilter instances.
TokenFilterFactory() - Constructor for class org.apache.lucene.analysis.TokenFilterFactory
Default ctor for compatibility with SPI
TokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.TokenFilterFactory
Initialize this factory via a set of key-value pairs.
tokenized() - Method in class org.apache.lucene.document.FieldType
True if this field's value should be analyzed by the Analyzer.
tokenized() - Method in interface org.apache.lucene.index.IndexableFieldType
True if this field's value should be analyzed by the Analyzer.
Tokenizer - Class in org.apache.lucene.analysis
A Tokenizer is a TokenStream whose input is a Reader.
Tokenizer() - Constructor for class org.apache.lucene.analysis.Tokenizer
Construct a tokenizer with no input, awaiting a call to Tokenizer.setReader(java.io.Reader) to provide input.
Tokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.Tokenizer
Construct a tokenizer with no input, awaiting a call to Tokenizer.setReader(java.io.Reader) to provide input.
TokenizerFactory - Class in org.apache.lucene.analysis
Abstract parent class for analysis factories that create Tokenizer instances.
TokenizerFactory() - Constructor for class org.apache.lucene.analysis.TokenizerFactory
Default ctor for compatibility with SPI
TokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.TokenizerFactory
Initialize this factory via a set of key-value pairs.
tokenStream - Variable in class org.apache.lucene.document.Field
Pre-analyzed tokenStream for indexed fields; this is separate from fieldsData because you are allowed to have both; eg maybe field has a String value but you customize how it's tokenized
tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
Returns a TokenStream suitable for fieldName, tokenizing the contents of reader.
tokenStream(String, String) - Method in class org.apache.lucene.analysis.Analyzer
Returns a TokenStream suitable for fieldName, tokenizing the contents of text.
tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.document.FeatureField
 
tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.document.Field
 
tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.document.ShapeDocValuesField
TokenStreams are not yet supported
tokenStream(Analyzer, TokenStream) - Method in interface org.apache.lucene.index.IndexableField
Creates the TokenStream used for indexing this field.
TokenStream - Class in org.apache.lucene.analysis
A TokenStream enumerates the sequence of tokens, either from Fields of a Document or from query text.
TokenStream() - Constructor for class org.apache.lucene.analysis.TokenStream
A TokenStream using the default attribute factory.
TokenStream(AttributeFactory) - Constructor for class org.apache.lucene.analysis.TokenStream
A TokenStream using the supplied AttributeFactory for creating new Attribute instances.
TokenStream(AttributeSource) - Constructor for class org.apache.lucene.analysis.TokenStream
A TokenStream that uses the same attributes as the supplied one.
TokenStreamComponents(Consumer<Reader>, TokenStream) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Creates a new Analyzer.TokenStreamComponents instance.
TokenStreamComponents(Tokenizer) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Creates a new Analyzer.TokenStreamComponents from a Tokenizer
TokenStreamComponents(Tokenizer, TokenStream) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
Creates a new Analyzer.TokenStreamComponents instance
TokenStreamToAutomaton - Class in org.apache.lucene.analysis
Consumes a TokenStream and creates an Automaton where the transition labels are UTF8 bytes (or Unicode code points if unicodeArcs is true) from the TermToBytesRefAttribute.
TokenStreamToAutomaton() - Constructor for class org.apache.lucene.analysis.TokenStreamToAutomaton
Sole constructor.
tokenStreamValue() - Method in class org.apache.lucene.document.Field
The TokenStream for this field to be used when indexing, or null.
toLongValuesSource() - Method in class org.apache.lucene.search.DoubleValuesSource
Convert to a LongValuesSource by casting the double values to longs
toLoseDocCount - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
doc count in this segment
toLowerCase(char[], int, int) - Static method in class org.apache.lucene.analysis.CharacterUtils
Converts each unicode codepoint to lowerCase via Character.toLowerCase(int) starting at the given offset.
toObject() - Method in class org.apache.lucene.util.mutable.MutableValue
 
toObject() - Method in class org.apache.lucene.util.mutable.MutableValueBool
 
toObject() - Method in class org.apache.lucene.util.mutable.MutableValueDate
 
toObject() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
 
toObject() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
 
toObject() - Method in class org.apache.lucene.util.mutable.MutableValueInt
 
toObject() - Method in class org.apache.lucene.util.mutable.MutableValueLong
 
toObject() - Method in class org.apache.lucene.util.mutable.MutableValueStr
 
TooComplexToDeterminizeException - Exception in org.apache.lucene.util.automaton
This exception is thrown when determinizing an automaton would require too much work.
TooComplexToDeterminizeException(Automaton, int) - Constructor for exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Use this constructor when the automaton failed to determinize.
TooComplexToDeterminizeException(RegExp, TooComplexToDeterminizeException) - Constructor for exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
Use this constructor when the RegExp failed to convert to an automaton.
toolOutOfDate - Variable in class org.apache.lucene.index.CheckIndex.Status
True if the index was created with a newer version of Lucene than the CheckIndex tool.
TooManyClauses() - Constructor for exception org.apache.lucene.search.BooleanQuery.TooManyClauses
Deprecated.
 
TooManyClauses() - Constructor for exception org.apache.lucene.search.IndexSearcher.TooManyClauses
 
TooManyClauses(String) - Constructor for exception org.apache.lucene.search.IndexSearcher.TooManyClauses
 
TooManyNestedClauses() - Constructor for exception org.apache.lucene.search.IndexSearcher.TooManyNestedClauses
 
top() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
top() - Method in class org.apache.lucene.util.LongHeap
Returns the least element of the LongHeap in constant time.
top() - Method in class org.apache.lucene.util.PriorityQueue
Returns the least element of the PriorityQueue in constant time.
TOP_DOCS - org.apache.lucene.search.ScoreMode
ScoreMode for top field collectors that can provide their own iterators, to optionally allow to skip for non-competitive docs
TOP_DOCS_WITH_SCORES - org.apache.lucene.search.ScoreMode
ScoreMode for top field collectors that can provide their own iterators, to optionally allow to skip for non-competitive docs.
TOP_SCORES - org.apache.lucene.search.ScoreMode
Produced scorers will optionally allow skipping over non-competitive hits using the Scorable.setMinCompetitiveScore(float) API.
top2() - Method in class org.apache.lucene.search.DisiPriorityQueue
Return the 2nd least value in this heap, or null if the heap contains less than 2 values.
topDocs() - Method in class org.apache.lucene.search.AbstractKnnCollector
 
topDocs() - Method in class org.apache.lucene.search.knn.MultiLeafTopKnnCollector
 
topDocs() - Method in interface org.apache.lucene.search.KnnCollector
This drains the collected nearest kNN results and returns them in a new TopDocs collection, ordered by score descending.
topDocs() - Method in class org.apache.lucene.search.TopDocsCollector
Returns the top docs that were collected by this collector.
topDocs() - Method in class org.apache.lucene.search.TopFieldCollector
 
topDocs() - Method in class org.apache.lucene.search.TopKnnCollector
 
topDocs() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
topDocs() - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
topDocs(int) - Method in class org.apache.lucene.search.TopDocsCollector
Returns the documents in the range [start ..
topDocs(int, int) - Method in class org.apache.lucene.search.TopDocsCollector
Returns the documents in the range [start ..
TopDocs - Class in org.apache.lucene.search
Represents hits returned by IndexSearcher.search(Query,int).
TopDocs(TotalHits, ScoreDoc[]) - Constructor for class org.apache.lucene.search.TopDocs
Constructs a TopDocs.
TopDocsCollector<T extends ScoreDoc> - Class in org.apache.lucene.search
A base class for all collectors that return a TopDocs output.
TopDocsCollector(PriorityQueue<T>) - Constructor for class org.apache.lucene.search.TopDocsCollector
 
topDocsSize() - Method in class org.apache.lucene.search.TopDocsCollector
The number of valid PQ entries
TopFieldCollector - Class in org.apache.lucene.search
A Collector that sorts by SortField using FieldComparators.
TopFieldCollectorManager - Class in org.apache.lucene.search
Create a TopFieldCollectorManager which uses a shared hit counter to maintain number of hits and a shared MaxScoreAccumulator to propagate the minimum score across segments if the primary sort is by relevancy.
TopFieldCollectorManager(Sort, int, int) - Constructor for class org.apache.lucene.search.TopFieldCollectorManager
Creates a new TopFieldCollectorManager from the given arguments, with thread-safe internal states.
TopFieldCollectorManager(Sort, int, FieldDoc, int) - Constructor for class org.apache.lucene.search.TopFieldCollectorManager
Creates a new TopFieldCollectorManager from the given arguments, with thread-safe internal states.
TopFieldCollectorManager(Sort, int, FieldDoc, int, boolean) - Constructor for class org.apache.lucene.search.TopFieldCollectorManager
Creates a new TopFieldCollectorManager from the given arguments.
TopFieldDocs - Class in org.apache.lucene.search
Represents hits returned by IndexSearcher.search(Query,int,Sort).
TopFieldDocs(TotalHits, ScoreDoc[], SortField[]) - Constructor for class org.apache.lucene.search.TopFieldDocs
Creates one of these objects.
TopKnnCollector - Class in org.apache.lucene.search
TopKnnCollector is a specific KnnCollector.
TopKnnCollector(int, int) - Constructor for class org.apache.lucene.search.TopKnnCollector
 
TopKnnCollectorManager - Class in org.apache.lucene.search.knn
TopKnnCollectorManager responsible for creating TopKnnCollector instances.
TopKnnCollectorManager(int, IndexSearcher) - Constructor for class org.apache.lucene.search.knn.TopKnnCollectorManager
 
topList() - Method in class org.apache.lucene.search.DisiPriorityQueue
Get the list of scorers which are on the current doc.
topN - Variable in class org.apache.lucene.util.fst.Util.TopResults
The top results
topNode() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
Returns the top element's node id.
TopNSearcher(FST<T>, int, int, Comparator<T>) - Constructor for class org.apache.lucene.util.fst.Util.TopNSearcher
Creates an unbounded TopNSearcher
TopNSearcher(FST<T>, int, int, Comparator<T>, Comparator<Util.FSTPath<T>>) - Constructor for class org.apache.lucene.util.fst.Util.TopNSearcher
 
topoSortStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns the topological sort of all states reachable from the initial state.
topScore() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
Returns the top element's node score.
TopScoreDocCollector - Class in org.apache.lucene.search
A Collector implementation that collects the top-scoring hits, returning them as a TopDocs.
TopScoreDocCollector.ScorerLeafCollector - Class in org.apache.lucene.search
Scorable leaf collector
TopScoreDocCollectorManager - Class in org.apache.lucene.search
Create a TopScoreDocCollectorManager which uses a shared hit counter to maintain number of hits and a shared MaxScoreAccumulator to propagate the minimum score across segments
TopScoreDocCollectorManager(int, int) - Constructor for class org.apache.lucene.search.TopScoreDocCollectorManager
Creates a new TopScoreDocCollectorManager given the number of hits to collect and the number of hits to count accurately, with thread-safe internal states.
TopScoreDocCollectorManager(int, ScoreDoc, int) - Constructor for class org.apache.lucene.search.TopScoreDocCollectorManager
Creates a new TopScoreDocCollectorManager given the number of hits to collect and the number of hits to count accurately, with thread-safe internal states.
TopScoreDocCollectorManager(int, ScoreDoc, int, boolean) - Constructor for class org.apache.lucene.search.TopScoreDocCollectorManager
Creates a new TopScoreDocCollectorManager given the number of hits to collect and the number of hits to count accurately.
TopTermsBlendedFreqScoringRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
Create a TopTermsBlendedScoringBooleanQueryRewrite for at most size terms.
TopTermsBoostOnlyBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
Create a TopTermsBoostOnlyBooleanQueryRewrite for at most size terms.
TopTermsRewrite<B> - Class in org.apache.lucene.search
Base rewrite method for collecting only the top terms via a priority queue.
TopTermsRewrite(int) - Constructor for class org.apache.lucene.search.TopTermsRewrite
Create a TopTermsBooleanQueryRewrite for at most size terms.
TopTermsScoringBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
Create a TopTermsScoringBooleanQueryRewrite for at most size terms.
topValue - Variable in class org.apache.lucene.search.comparators.DoubleComparator
 
topValue - Variable in class org.apache.lucene.search.comparators.FloatComparator
 
topValue - Variable in class org.apache.lucene.search.comparators.IntComparator
 
topValue - Variable in class org.apache.lucene.search.comparators.LongComparator
 
topValueSet - Variable in class org.apache.lucene.search.comparators.NumericComparator
 
toString() - Method in class org.apache.lucene.analysis.CharArrayMap
 
toString() - Method in class org.apache.lucene.analysis.CharArraySet
 
toString() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
Returns solely the term text as specified by the CharSequence interface.
toString() - Method in class org.apache.lucene.codecs.BlockTermState
 
toString() - Method in class org.apache.lucene.codecs.Codec
returns the codec's name.
toString() - Method in class org.apache.lucene.codecs.CompetitiveImpactAccumulator
 
toString() - Method in class org.apache.lucene.codecs.DocValuesFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene90.blocktree.FieldReader
 
toString() - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
 
toString() - Method in class org.apache.lucene.codecs.lucene90.blocktree.Stats
 
toString() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsReader
 
toString() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsReader
 
toString() - Method in class org.apache.lucene.codecs.lucene90.DeflateWithPresetDictCompressionMode
 
toString() - Method in class org.apache.lucene.codecs.lucene90.LZ4WithPresetDictCompressionMode
 
toString() - Method in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswScalarQuantizedVectorsFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat.IntBlockTermState
 
toString() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsFormat
 
toString() - Method in class org.apache.lucene.codecs.lucene99.Lucene99PostingsReader
 
toString() - Method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsFormat
 
toString() - Method in class org.apache.lucene.codecs.PostingsFormat
 
toString() - Method in enum org.apache.lucene.document.DateTools.Resolution
this method returns the name of the resolution in lowercase (for backwards compatibility)
toString() - Method in class org.apache.lucene.document.Document
Prints the fields of a document for human consumption.
toString() - Method in class org.apache.lucene.document.DoubleField
 
toString() - Method in class org.apache.lucene.document.DoublePoint
 
toString() - Method in class org.apache.lucene.document.DoubleRange
 
toString() - Method in class org.apache.lucene.document.Field
Prints a Field for human consumption.
toString() - Method in class org.apache.lucene.document.FieldType
Prints a Field for human consumption.
toString() - Method in class org.apache.lucene.document.FloatField
 
toString() - Method in class org.apache.lucene.document.FloatPoint
 
toString() - Method in class org.apache.lucene.document.FloatRange
 
toString() - Method in class org.apache.lucene.document.InetAddressPoint
 
toString() - Method in class org.apache.lucene.document.IntField
 
toString() - Method in class org.apache.lucene.document.IntPoint
 
toString() - Method in class org.apache.lucene.document.IntRange
 
toString() - Method in class org.apache.lucene.document.LatLonDocValuesField
 
toString() - Method in class org.apache.lucene.document.LatLonPoint
 
toString() - Method in class org.apache.lucene.document.LongField
 
toString() - Method in class org.apache.lucene.document.LongPoint
 
toString() - Method in class org.apache.lucene.document.LongRange
 
toString() - Method in class org.apache.lucene.document.ShapeField.DecodedTriangle
pretty print the triangle vertices
toString() - Method in class org.apache.lucene.document.XYDocValuesField
 
toString() - Method in class org.apache.lucene.document.XYPointField
 
toString() - Method in class org.apache.lucene.geo.Circle
 
toString() - Method in class org.apache.lucene.geo.Line
 
toString() - Method in class org.apache.lucene.geo.Point
 
toString() - Method in class org.apache.lucene.geo.Polygon
 
toString() - Method in class org.apache.lucene.geo.Rectangle
 
toString() - Method in class org.apache.lucene.geo.Tessellator.Node
 
toString() - Method in class org.apache.lucene.geo.Tessellator.Triangle
pretty print the triangle vertices
toString() - Method in class org.apache.lucene.geo.XYCircle
 
toString() - Method in class org.apache.lucene.geo.XYLine
 
toString() - Method in class org.apache.lucene.geo.XYPoint
 
toString() - Method in class org.apache.lucene.geo.XYPolygon
 
toString() - Method in class org.apache.lucene.geo.XYRectangle
 
toString() - Method in class org.apache.lucene.index.CompositeReader
 
toString() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
toString() - Method in class org.apache.lucene.index.ExitableDirectoryReader
 
toString() - Method in class org.apache.lucene.index.FilterLeafReader
 
toString() - Method in class org.apache.lucene.index.FilterMergePolicy
 
toString() - Method in class org.apache.lucene.index.Impact
 
toString() - Method in class org.apache.lucene.index.IndexWriterConfig
 
toString() - Method in class org.apache.lucene.index.LeafReaderContext
 
toString() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
 
toString() - Method in class org.apache.lucene.index.LogMergePolicy
 
toString() - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
 
toString() - Method in class org.apache.lucene.index.MultiBits
 
toString() - Method in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
 
toString() - Method in class org.apache.lucene.index.MultiPostingsEnum
 
toString() - Method in class org.apache.lucene.index.MultiTermsEnum
 
toString() - Method in class org.apache.lucene.index.NoMergePolicy
 
toString() - Method in class org.apache.lucene.index.OrdTermState
 
toString() - Method in class org.apache.lucene.index.ParallelLeafReader
 
toString() - Method in class org.apache.lucene.index.QueryTimeoutImpl
 
toString() - Method in class org.apache.lucene.index.ReaderSlice
 
toString() - Method in class org.apache.lucene.index.SegmentCommitInfo
 
toString() - Method in class org.apache.lucene.index.SegmentInfo
 
toString() - Method in class org.apache.lucene.index.SegmentInfos
Returns readable description of this segment.
toString() - Method in class org.apache.lucene.index.SegmentReader
 
toString() - Method in class org.apache.lucene.index.Sorter
 
toString() - Method in class org.apache.lucene.index.SortingCodecReader
 
toString() - Method in class org.apache.lucene.index.StandardDirectoryReader
 
toString() - Method in class org.apache.lucene.index.Term
 
toString() - Method in class org.apache.lucene.index.TermState
 
toString() - Method in class org.apache.lucene.index.TermStates
 
toString() - Method in class org.apache.lucene.index.TieredMergePolicy
 
toString() - Method in class org.apache.lucene.search.BooleanClause
 
toString() - Method in class org.apache.lucene.search.CollectionStatistics
 
toString() - Method in class org.apache.lucene.search.DoubleValuesSource
 
toString() - Method in class org.apache.lucene.search.Explanation
Render an explanation as text.
toString() - Method in class org.apache.lucene.search.FieldDoc
 
toString() - Method in class org.apache.lucene.search.FieldValueHitQueue.Entry
 
toString() - Method in class org.apache.lucene.search.FilterCollector
 
toString() - Method in class org.apache.lucene.search.FilterLeafCollector
 
toString() - Method in class org.apache.lucene.search.IndexSearcher
 
toString() - Method in class org.apache.lucene.search.knn.MultiLeafTopKnnCollector
 
toString() - Method in class org.apache.lucene.search.LongValuesSource.ConstantLongValuesSource
 
toString() - Method in class org.apache.lucene.search.LongValuesSource
 
toString() - Method in class org.apache.lucene.search.Query
Prints a query to a string.
toString() - Method in class org.apache.lucene.search.ScoreDoc
 
toString() - Method in class org.apache.lucene.search.similarities.AfterEffect
Subclasses must override this method to return the code of the after effect formula.
toString() - Method in class org.apache.lucene.search.similarities.AfterEffectB
 
toString() - Method in class org.apache.lucene.search.similarities.AfterEffectL
 
toString() - Method in class org.apache.lucene.search.similarities.Axiomatic
Name of the axiomatic method.
toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
 
toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
 
toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
 
toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
 
toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
 
toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
 
toString() - Method in class org.apache.lucene.search.similarities.BasicModel
Subclasses must override this method to return the code of the basic model formula.
toString() - Method in class org.apache.lucene.search.similarities.BasicModelG
 
toString() - Method in class org.apache.lucene.search.similarities.BasicModelIF
 
toString() - Method in class org.apache.lucene.search.similarities.BasicModelIn
 
toString() - Method in class org.apache.lucene.search.similarities.BasicModelIne
 
toString() - Method in class org.apache.lucene.search.similarities.BM25Similarity
 
toString() - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
 
toString() - Method in class org.apache.lucene.search.similarities.DFISimilarity
 
toString() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
 
toString() - Method in class org.apache.lucene.search.similarities.Distribution
Subclasses must override this method to return the name of the distribution.
toString() - Method in class org.apache.lucene.search.similarities.DistributionLL
 
toString() - Method in class org.apache.lucene.search.similarities.DistributionSPL
 
toString() - Method in class org.apache.lucene.search.similarities.IBSimilarity
The name of IB methods follow the pattern IB <distribution> <lambda><normalization>.
toString() - Method in class org.apache.lucene.search.similarities.Independence
 
toString() - Method in class org.apache.lucene.search.similarities.IndependenceChiSquared
 
toString() - Method in class org.apache.lucene.search.similarities.IndependenceSaturated
 
toString() - Method in class org.apache.lucene.search.similarities.IndependenceStandardized
 
toString() - Method in class org.apache.lucene.search.similarities.Lambda
Subclasses must override this method to return the code of the lambda formula.
toString() - Method in class org.apache.lucene.search.similarities.LambdaDF
 
toString() - Method in class org.apache.lucene.search.similarities.LambdaTTF
 
toString() - Method in class org.apache.lucene.search.similarities.LMSimilarity
Returns the name of the LM method.
toString() - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
 
toString() - Method in class org.apache.lucene.search.similarities.Normalization
Subclasses must override this method to return the code of the normalization formula.
toString() - Method in class org.apache.lucene.search.similarities.NormalizationH1
 
toString() - Method in class org.apache.lucene.search.similarities.NormalizationH2
 
toString() - Method in class org.apache.lucene.search.similarities.NormalizationH3
 
toString() - Method in class org.apache.lucene.search.similarities.NormalizationZ
 
toString() - Method in class org.apache.lucene.search.similarities.SimilarityBase
Subclasses must override this method to return the name of the Similarity and preferably the values of parameters (if any) as well.
toString() - Method in class org.apache.lucene.search.Sort
 
toString() - Method in class org.apache.lucene.search.SortedNumericSortField
 
toString() - Method in class org.apache.lucene.search.SortedSetSortField
 
toString() - Method in class org.apache.lucene.search.SortField
 
toString() - Method in class org.apache.lucene.search.TaskExecutor
 
toString() - Method in class org.apache.lucene.search.TermScorer
Returns a string representation of this TermScorer.
toString() - Method in class org.apache.lucene.search.TermStatistics
 
toString() - Method in class org.apache.lucene.search.TopKnnCollector
 
toString() - Method in class org.apache.lucene.search.TotalHits
 
toString() - Method in class org.apache.lucene.store.BaseDirectory
 
toString() - Method in class org.apache.lucene.store.ByteBuffersDataInput
 
toString() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
toString() - Method in class org.apache.lucene.store.Directory
 
toString() - Method in class org.apache.lucene.store.FilterDirectory
 
toString() - Method in class org.apache.lucene.store.FlushInfo
 
toString() - Method in class org.apache.lucene.store.FSDirectory
 
toString() - Method in class org.apache.lucene.store.IndexInput
 
toString() - Method in class org.apache.lucene.store.IndexOutput
 
toString() - Method in class org.apache.lucene.store.IOContext
 
toString() - Method in class org.apache.lucene.store.MergeInfo
 
toString() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
toString() - Method in class org.apache.lucene.store.SleepingLockWrapper
 
toString() - Method in class org.apache.lucene.util.AttributeSource
Returns a string consisting of the class's simple name, the hex representation of the identity hash code, and the current reflection of all attributes.
toString() - Method in class org.apache.lucene.util.automaton.RegExp
Constructs string from parsed regular expression.
toString() - Method in class org.apache.lucene.util.automaton.RunAutomaton
Returns a string representation of this automaton.
toString() - Method in class org.apache.lucene.util.automaton.StatePair
 
toString() - Method in class org.apache.lucene.util.automaton.Transition
 
toString() - Method in class org.apache.lucene.util.BitDocIdSet
 
toString() - Method in class org.apache.lucene.util.bkd.BKDRadixSelector.PathSlice
 
toString() - Method in class org.apache.lucene.util.bkd.HeapPointWriter
 
toString() - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
 
toString() - Method in class org.apache.lucene.util.BytesRef
Returns hex encoded bytes, eg [0x6c 0x75 0x63 0x65 0x6e 0x65]
toString() - Method in class org.apache.lucene.util.CharsRef
 
toString() - Method in class org.apache.lucene.util.CharsRefBuilder
 
toString() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
toString() - Method in class org.apache.lucene.util.fst.FST.Arc
 
toString() - Method in class org.apache.lucene.util.fst.FST
 
toString() - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
toString() - Method in class org.apache.lucene.util.fst.NoOutputs
 
toString() - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
 
toString() - Method in class org.apache.lucene.util.fst.PairOutputs
 
toString() - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
toString() - Method in class org.apache.lucene.util.fst.Util.FSTPath
 
toString() - Method in class org.apache.lucene.util.hnsw.NeighborArray
 
toString() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
toString() - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
 
toString() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.IntCursor
 
toString() - Method in class org.apache.lucene.util.hppc.IntIntHashMap.IntIntCursor
 
toString() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Convert the contents of this map to a human-friendly string.
toString() - Method in class org.apache.lucene.util.IntsRef
 
toString() - Method in class org.apache.lucene.util.LongsRef
 
toString() - Method in class org.apache.lucene.util.mutable.MutableValue
 
toString() - Method in class org.apache.lucene.util.OfflineSorter.SortInfo
 
toString() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
 
toString() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
 
toString() - Method in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
 
toString() - Method in class org.apache.lucene.util.PagedBytes.Reader
 
toString() - Method in class org.apache.lucene.util.quantization.ScalarQuantizer
 
toString() - Method in class org.apache.lucene.util.RoaringDocIdSet
 
toString() - Method in class org.apache.lucene.util.SparseFixedBitSet
 
toString() - Method in class org.apache.lucene.util.TermAndVector
 
toString() - Method in class org.apache.lucene.util.Version
 
toString(byte[]) - Method in class org.apache.lucene.search.PointInSetQuery
Returns a string of a single value in a human-readable format for debugging.
toString(byte[], int) - Method in class org.apache.lucene.document.RangeFieldQuery
Returns a string of a single value in a human-readable format for debugging.
toString(int) - Method in class org.apache.lucene.index.SegmentCommitInfo
Returns a description of this segment.
toString(int) - Method in class org.apache.lucene.index.SegmentInfo
Used for debugging.
toString(int, byte[]) - Method in class org.apache.lucene.search.PointRangeQuery
Returns a string of a single value in a human-readable format for debugging.
toString(String) - Method in class org.apache.lucene.document.RangeFieldQuery
 
toString(String) - Method in class org.apache.lucene.document.XYDocValuesPointInGeometryQuery
 
toString(String) - Method in class org.apache.lucene.search.AutomatonQuery
 
toString(String) - Method in class org.apache.lucene.search.BlendedTermQuery
 
toString(String) - Method in class org.apache.lucene.search.BooleanQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.BoostQuery
 
toString(String) - Method in class org.apache.lucene.search.ByteVectorSimilarityQuery
 
toString(String) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
toString(String) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Prettyprint us.
toString(String) - Method in class org.apache.lucene.search.FieldExistsQuery
 
toString(String) - Method in class org.apache.lucene.search.FloatVectorSimilarityQuery
 
toString(String) - Method in class org.apache.lucene.search.FuzzyQuery
 
toString(String) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
 
toString(String) - Method in class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
 
toString(String) - Method in class org.apache.lucene.search.IndriQuery
 
toString(String) - Method in class org.apache.lucene.search.KnnByteVectorQuery
 
toString(String) - Method in class org.apache.lucene.search.KnnFloatVectorQuery
 
toString(String) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
toString(String) - Method in class org.apache.lucene.search.MatchNoDocsQuery
 
toString(String) - Method in class org.apache.lucene.search.MultiPhraseQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.NGramPhraseQuery
 
toString(String) - Method in class org.apache.lucene.search.PhraseQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.PointInSetQuery
 
toString(String) - Method in class org.apache.lucene.search.PointRangeQuery
 
toString(String) - Method in class org.apache.lucene.search.PrefixQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.Query
Prints a query to a string, with field assumed to be the default field and omitted.
toString(String) - Method in class org.apache.lucene.search.RegexpQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.SynonymQuery
 
toString(String) - Method in class org.apache.lucene.search.TermInSetQuery
 
toString(String) - Method in class org.apache.lucene.search.TermQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.TermRangeQuery
Prints a user-readable version of this query.
toString(String) - Method in class org.apache.lucene.search.WildcardQuery
Prints a user-readable version of this query.
toString(Accountable) - Static method in class org.apache.lucene.util.Accountables
Returns a String description of an Accountable and any nested resources.
toString(BytesRef) - Static method in class org.apache.lucene.index.Term
Returns human-readable form of the term text.
toStringTree() - Method in class org.apache.lucene.util.automaton.RegExp
Like to string, but more verbose (shows the higherchy more clearly).
ToStringUtils - Class in org.apache.lucene.util
Helper methods to ease implementing Object.toString().
totalBinaryFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of binary fields
totalBlockCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Total number of blocks.
totalBlockOtherBytes - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Total bytes stored by the PostingsReaderBase, plus the other few vInts stored in the frame.
totalBlockStatsBytes - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Total number of bytes used to store term stats (not including what the PostingsReaderBase stores.
totalBlockSuffixBytes - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Total number of bytes used to store term suffixes.
totalBytesSize() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Returns the total size in bytes of this merge.
TotalHitCountCollector - Class in org.apache.lucene.search
Just counts the total number of hits.
TotalHitCountCollector() - Constructor for class org.apache.lucene.search.TotalHitCountCollector
 
TotalHitCountCollectorManager - Class in org.apache.lucene.search
Collector manager based on TotalHitCountCollector that allows users to parallelize counting the number of hits, expected to be used mostly wrapped in MultiCollectorManager.
TotalHitCountCollectorManager() - Constructor for class org.apache.lucene.search.TotalHitCountCollectorManager
 
totalHits - Variable in class org.apache.lucene.search.TopDocs
The total number of hits for the query.
totalHits - Variable in class org.apache.lucene.search.TopDocsCollector
The total number of documents that the collector encountered.
TotalHits - Class in org.apache.lucene.search
Description of the total number of hits of a query.
TotalHits(long, TotalHits.Relation) - Constructor for class org.apache.lucene.search.TotalHits
Sole constructor.
TotalHits.Relation - Enum in org.apache.lucene.search
How the TotalHits.value should be interpreted.
totalHitsRelation - Variable in class org.apache.lucene.search.TopDocsCollector
Whether TopDocsCollector.totalHits is exact or a lower bound.
totalKnnVectorFields - Variable in class org.apache.lucene.index.CheckIndex.Status.VectorValuesStatus
Total number of fields with vectors.
totalMaxDoc - Variable in class org.apache.lucene.store.MergeInfo
 
totalMaxDoc() - Method in class org.apache.lucene.index.SegmentInfos
Returns sum of all segment's maxDocs.
totalNumDocs() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Returns the total number of documents that are included with this merge.
totalNumericFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of numeric fields
totalSortedFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of sorted fields
totalSortedNumericFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of sortednumeric fields
totalSortedSetFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of sortedset fields
totalTermBytes - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Total number of bytes (sum of term lengths) across all terms in the field.
totalTermCount - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Total number of terms in the field.
totalTermFreq - Variable in class org.apache.lucene.codecs.BlockTermState
total number of occurrences of this term
totalTermFreq - Variable in class org.apache.lucene.codecs.TermStats
Total number of times this term occurs across all documents in the field.
totalTermFreq - Variable in class org.apache.lucene.search.similarities.BasicStats
The total number of occurrences of this term across all documents.
totalTermFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
 
totalTermFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
 
totalTermFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
 
totalTermFreq() - Method in class org.apache.lucene.index.TermsEnum
Returns the total number of occurrences of this term across all documents (the sum of the freq() for each doc that has this term).
totalTermFreq() - Method in class org.apache.lucene.index.TermStates
Returns the accumulated term frequency of all TermState instances passed to TermStates.register(TermState, int, int, long).
totalTermFreq() - Method in class org.apache.lucene.search.FuzzyTermsEnum
 
totalTermFreq() - Method in class org.apache.lucene.search.TermStatistics
The total number of occurrences of this term.
totalTermFreq(Term) - Method in class org.apache.lucene.index.BaseCompositeReader
 
totalTermFreq(Term) - Method in class org.apache.lucene.index.IndexReader
Returns the total number of occurrences of term across all documents (the sum of the freq() for each doc that has this term).
totalTermFreq(Term) - Method in class org.apache.lucene.index.LeafReader
Returns the number of documents containing the term t.
totalTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
total time spent (in milliseconds)
totalUncompressedBlockSuffixBytes - Variable in class org.apache.lucene.codecs.lucene90.blocktree.Stats
Total number of suffix bytes before compression.
totalValueFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
Total number of docValues tested.
totalValueFields - Variable in class org.apache.lucene.index.CheckIndex.Status.PointsStatus
Total number of fields with points.
totalValuePoints - Variable in class org.apache.lucene.index.CheckIndex.Status.PointsStatus
Total number of values points tested.
totalVectorCount() - Method in interface org.apache.lucene.util.hnsw.CloseableRandomVectorScorerSupplier
 
totalVectorValues - Variable in class org.apache.lucene.index.CheckIndex.Status.VectorValuesStatus
Total number of vector values tested.
totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldInfoStatus
Number of fields successfully tested
totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
Number of fields successfully tested
totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
Total number of stored fields tested.
totFreq - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Total frequency across all terms.
totLoseDocCount - Variable in class org.apache.lucene.index.CheckIndex.Status
How many documents will be lost to bad segments.
toTokenStream(Automaton) - Static method in class org.apache.lucene.analysis.AutomatonToTokenStream
converts an automaton into a TokenStream.
totPos - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Total number of positions.
totVectors - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
Total number of term vectors tested.
toUpperCase(char[], int, int) - Static method in class org.apache.lucene.analysis.CharacterUtils
Converts each unicode codepoint to UpperCase via Character.toUpperCase(int) starting at the given offset.
toUTF16(CharSequence, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Just maps each UTF16 unit (char) to the ints in an IntsRef.
toUTF32(char[], int, int, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Decodes the Unicode codepoints from the provided char[] and places them in the provided scratch IntsRef, which must not be null, returning it.
toUTF32(CharSequence, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
Decodes the Unicode codepoints from the provided CharSequence and places them in the provided scratch IntsRef, which must not be null, returning it.
toWriteableBufferList() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
Returns a list of writeable blocks over the (source) content buffers.
TrackingDirectoryWrapper - Class in org.apache.lucene.store
A delegating Directory that records which files were written to and deleted.
TrackingDirectoryWrapper(Directory) - Constructor for class org.apache.lucene.store.TrackingDirectoryWrapper
 
Transition - Class in org.apache.lucene.util.automaton
Holds one transition from an Automaton.
Transition() - Constructor for class org.apache.lucene.util.automaton.Transition
Sole constructor.
Triangle(Tessellator.Node, boolean, Tessellator.Node, boolean, Tessellator.Node, boolean) - Constructor for class org.apache.lucene.geo.Tessellator.Triangle
 
TRIANGLE - org.apache.lucene.document.ShapeField.DecodedTriangle.TYPE
all coordinates are different
trim(int) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipReader
Trim original docFreq to tell skipReader read proper number of skip points.
tryDeleteDocument(IndexReader, int) - Method in class org.apache.lucene.index.IndexWriter
Expert: attempts to delete by document ID, as long as the provided reader is a near-real-time reader (from DirectoryReader.open(IndexWriter)).
tryIncRef() - Method in class org.apache.lucene.index.IndexReader
Expert: increments the refCount of this IndexReader instance only if the IndexReader has not been closed yet and returns true iff the refCount was successfully incremented, otherwise false.
tryIncRef(G) - Method in class org.apache.lucene.search.ReferenceManager
Try to increment reference counting on the given reference.
tryIncRef(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
 
tryIncRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
 
tryPromoteNewEntryNode(int, int, int) - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
Try to promote the provided node to the entry node
trySet(T) - Method in class org.apache.lucene.util.SetOnce
Sets the given object if none was set before.
trySetNewEntryNode(int, int) - Method in class org.apache.lucene.util.hnsw.OnHeapHnswGraph
Try to set the entry node if the graph does not have one
tryUpdateDocValue(IndexReader, int, Field...) - Method in class org.apache.lucene.index.IndexWriter
Expert: attempts to update doc values by document ID, as long as the provided reader is a near-real-time reader (from DirectoryReader.open(IndexWriter)).
TwoPhaseCommit - Interface in org.apache.lucene.index
An interface for implementations that support 2-phase commit.
TwoPhaseCommitTool - Class in org.apache.lucene.index
A utility for executing 2-phase commit on several objects.
TwoPhaseCommitTool.CommitFailException - Exception in org.apache.lucene.index
Thrown by TwoPhaseCommitTool.execute(TwoPhaseCommit...) when an object fails to commit().
TwoPhaseCommitTool.PrepareCommitFailException - Exception in org.apache.lucene.index
Thrown by TwoPhaseCommitTool.execute(TwoPhaseCommit...) when an object fails to prepareCommit().
twoPhaseIterator() - Method in class org.apache.lucene.search.ConstantScoreScorer
 
twoPhaseIterator() - Method in class org.apache.lucene.search.FilterScorer
 
twoPhaseIterator() - Method in class org.apache.lucene.search.Scorer
Optional method: Return a TwoPhaseIterator view of this Scorer.
TwoPhaseIterator - Class in org.apache.lucene.search
Returned by Scorer.twoPhaseIterator() to expose an approximation of a DocIdSetIterator.
TwoPhaseIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.TwoPhaseIterator
Takes the approximation to be returned by TwoPhaseIterator.approximation.
twoPhaseView - Variable in class org.apache.lucene.search.DisiWrapper
 
type - Variable in class org.apache.lucene.document.Field
Field's type
type - Variable in class org.apache.lucene.document.ShapeField.DecodedTriangle
triangle type
type - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
If simplify is true this will be the "simplified" type; else, this is NORMAL
type() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
Returns this Token's lexical type.
type() - Method in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
Returns this Token's lexical type.
type() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
TYPE - Static variable in class org.apache.lucene.document.BinaryDocValuesField
Type for straight bytes DocValues.
TYPE - Static variable in class org.apache.lucene.document.LatLonDocValuesField
Type for a LatLonDocValuesField
TYPE - Static variable in class org.apache.lucene.document.LatLonPoint
Type for an indexed LatLonPoint
TYPE - Static variable in class org.apache.lucene.document.NumericDocValuesField
Type for numeric DocValues.
TYPE - Static variable in class org.apache.lucene.document.ShapeField
tessellated triangles are seven dimensions; the first four are the bounding box index dimensions
TYPE - Static variable in class org.apache.lucene.document.SortedDocValuesField
Type for sorted bytes DocValues
TYPE - Static variable in class org.apache.lucene.document.SortedNumericDocValuesField
Type for sorted numeric DocValues.
TYPE - Static variable in class org.apache.lucene.document.SortedSetDocValuesField
Type for sorted bytes DocValues
TYPE - Static variable in class org.apache.lucene.document.StoredField
Type for a stored-only field.
TYPE - Static variable in class org.apache.lucene.document.XYDocValuesField
Type for a XYDocValuesField
TYPE - Static variable in class org.apache.lucene.document.XYPointField
Type for an indexed XYPoint
TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.StringField
Indexed, not tokenized, omits norms, indexes DOCS_ONLY, not stored.
TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.TextField
Indexed, tokenized, not stored.
TYPE_STORED - Static variable in class org.apache.lucene.document.StringField
Indexed, not tokenized, omits norms, indexes DOCS_ONLY, stored
TYPE_STORED - Static variable in class org.apache.lucene.document.TextField
Indexed, tokenized, stored.
TypeAttribute - Interface in org.apache.lucene.analysis.tokenattributes
A Token's lexical type.
TypeAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
Default implementation of TypeAttribute.
TypeAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
Initialize this attribute with TypeAttribute.DEFAULT_TYPE
TypeAttributeImpl(String) - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
Initialize this attribute with type
typename() - Method in enum org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
 

U

UNI_REPLACEMENT_CHAR - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_HIGH_END - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_HIGH_START - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_LOW_END - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UNI_SUR_LOW_START - Static variable in class org.apache.lucene.util.UnicodeUtil
 
UnicodeUtil - Class in org.apache.lucene.util
Class to encode java's UTF16 char[] into UTF8 byte[] without always allocating a new byte[] as String.getBytes(StandardCharsets.UTF_8) does.
UnicodeUtil.UTF8CodePoint - Class in org.apache.lucene.util
Holds a codepoint along with the number of bytes required to represent it in UTF8
union(Collection<Automaton>) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the union of the languages of the given automata.
union(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
Returns an automaton that accepts the union of the languages of the given automata.
unionCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
Returns the popcount or cardinality of the union of the two sets.
UnionFullPostingsEnum(List<PostingsEnum>) - Constructor for class org.apache.lucene.search.MultiPhraseQuery.UnionFullPostingsEnum
 
UnionPostingsEnum(Collection<PostingsEnum>) - Constructor for class org.apache.lucene.search.MultiPhraseQuery.UnionPostingsEnum
 
UNKNOWN_DEFAULT_RAM_BYTES_USED - Static variable in class org.apache.lucene.util.RamUsageEstimator
Approximate memory usage that we assign to all unknown objects - this maps roughly to a few primitive fields and a couple short String-s.
UNMAP_NOT_SUPPORTED_REASON - Static variable in class org.apache.lucene.store.MMapDirectory
if MMapDirectory.UNMAP_SUPPORTED is false, this contains the reason why unmapping is not supported.
UNMAP_SUPPORTED - Static variable in class org.apache.lucene.store.MMapDirectory
true, if this platform supports unmapping mmapped files.
unmodifiableMap(CharArrayMap<V>) - Static method in class org.apache.lucene.analysis.CharArrayMap
Returns an unmodifiable CharArrayMap.
unmodifiableSet(CharArraySet) - Static method in class org.apache.lucene.analysis.CharArraySet
Returns an unmodifiable CharArraySet.
unpack(BytesRef, int, long[]) - Static method in class org.apache.lucene.document.LongPoint
Unpack a BytesRef into a long point.
unsignedBitsRequired(long) - Static method in class org.apache.lucene.util.packed.DirectWriter
Returns how many bits are required to hold values up to and including maxValue, interpreted as an unsigned value.
unsignedBitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
Returns how many bits are required to store bits, interpreted as an unsigned value.
unwrap() - Method in class org.apache.lucene.analysis.TokenFilter
 
unwrap() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
 
unwrap() - Method in class org.apache.lucene.index.FilterMergePolicy
 
unwrap() - Method in class org.apache.lucene.search.FilterScorer
 
unwrap() - Method in interface org.apache.lucene.util.Unwrappable
Unwraps this instance
unwrap(CodecReader) - Static method in class org.apache.lucene.index.FilterCodecReader
Get the wrapped instance by reader as long as this reader is an instance of FilterCodecReader.
unwrap(DirectoryReader) - Static method in class org.apache.lucene.index.FilterDirectoryReader
Get the wrapped instance by reader as long as this reader is an instance of FilterDirectoryReader.
unwrap(LeafReader) - Static method in class org.apache.lucene.index.FilterLeafReader
Get the wrapped instance by reader as long as this reader is an instance of FilterLeafReader.
unwrap(DocIdSetIterator) - Static method in class org.apache.lucene.search.TwoPhaseIterator
unwrap(Directory) - Static method in class org.apache.lucene.store.FilterDirectory
Get the wrapped instance by dir as long as this reader is an instance of FilterDirectory.
unwrap(IndexInput) - Static method in class org.apache.lucene.store.FilterIndexInput
Unwraps all FilterIndexInputs until the first non-FilterIndexInput IndexInput instance and returns it
unwrap(IndexOutput) - Static method in class org.apache.lucene.store.FilterIndexOutput
Unwraps all FilterIndexOutputs until the first non-FilterIndexOutput IndexOutput instance and returns it
unwrapAll(T) - Static method in interface org.apache.lucene.util.Unwrappable
Unwraps all Unwrappables around the given object.
Unwrappable<T> - Interface in org.apache.lucene.util
An object with this interface is a wrapper around another object (e.g., a filter with a delegate).
unwrapSingleton(SortedNumericDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns a single-valued view of the SortedNumericDocValues, if it was previously wrapped with DocValues.singleton(NumericDocValues), or null.
unwrapSingleton(SortedSetDocValues) - Static method in class org.apache.lucene.index.DocValues
Returns a single-valued view of the SortedSetDocValues, if it was previously wrapped with DocValues.singleton(SortedDocValues), or null.
update(byte[], int, int) - Method in class org.apache.lucene.store.BufferedChecksum
 
update(int) - Method in class org.apache.lucene.store.BufferedChecksum
 
updateBinaryDocValue(Term, String, BytesRef) - Method in class org.apache.lucene.index.IndexWriter
Updates a document's BinaryDocValues for field to the given value .
updateDocument(Term, Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.IndexWriter
Updates a document by first deleting the document(s) containing term and then adding the new document.
updateDocuments(Term, Iterable<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.IndexWriter
Atomically deletes documents matching the provided delTerm and adds a block of documents with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
updateDocuments(Query, Iterable<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.IndexWriter
Similar to IndexWriter.updateDocuments(Term, Iterable), but take a query instead of a term to identify the documents to be updated
updateDocValues(Term, Field...) - Method in class org.apache.lucene.index.IndexWriter
Updates documents' DocValues fields to the given values.
updateGeneration(SegmentInfos) - Method in class org.apache.lucene.index.SegmentInfos
Carry over generation numbers from another SegmentInfos
updateGlobalMinCompetitiveScore(Scorable) - Method in class org.apache.lucene.search.TopFieldCollector
 
updateGlobalMinCompetitiveScore(Scorable) - Method in class org.apache.lucene.search.TopScoreDocCollector
 
updateMergeThreads() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Called whenever the running merges have changed, to set merge IO limits.
updateMinCompetitiveScore(Scorable) - Method in class org.apache.lucene.search.TopFieldCollector
 
updateMinCompetitiveScore(Scorable) - Method in class org.apache.lucene.search.TopScoreDocCollector
 
updateNumericDocValue(Term, String, long) - Method in class org.apache.lucene.index.IndexWriter
Updates a document's NumericDocValues for field to the given value .
updateTop() - Method in class org.apache.lucene.search.DisiPriorityQueue
 
updateTop() - Method in class org.apache.lucene.util.PriorityQueue
Should be called when the Object at top changes values.
updateTop(long) - Method in class org.apache.lucene.util.LongHeap
Replace the top of the pq with newTop.
updateTop(T) - Method in class org.apache.lucene.util.PriorityQueue
Replace the top of the pq with newTop and run PriorityQueue.updateTop().
upgrade() - Method in class org.apache.lucene.index.IndexUpgrader
Perform the upgrade.
UpgradeIndexMergePolicy - Class in org.apache.lucene.index
This MergePolicy is used for upgrading all existing segments of an index when calling IndexWriter.forceMerge(int).
UpgradeIndexMergePolicy(MergePolicy) - Constructor for class org.apache.lucene.index.UpgradeIndexMergePolicy
Wrap the given MergePolicy and intercept forceMerge requests to only upgrade segments written with previous Lucene versions.
UsageTrackingQueryCachingPolicy - Class in org.apache.lucene.search
A QueryCachingPolicy that tracks usage statistics of recently-used filters in order to decide on which filters are worth caching.
UsageTrackingQueryCachingPolicy() - Constructor for class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
Create a new instance with an history size of 256.
UsageTrackingQueryCachingPolicy(int) - Constructor for class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
Expert: Create a new instance with a configurable history size.
useCompoundFile - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
True if segment flushes should use compound file format
useCompoundFile(SegmentInfos, SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
 
useCompoundFile(SegmentInfos, SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
Returns true if a new segment (regardless of its origin) should use the compound file format.
useCompoundFile(SegmentInfos, SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
 
useOrSuppress(T, T) - Static method in class org.apache.lucene.util.IOUtils
Returns the second throwable if the first is null otherwise adds the second as suppressed to the first and returns it.
userData - Variable in class org.apache.lucene.index.CheckIndex.Status
Holds the userData of the last commit in the index
userData - Variable in class org.apache.lucene.index.SegmentInfos
Opaque Map<String, String> that user can specify during IndexWriter.commit
UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
UTF-8 charset string.
UTF16toUTF8(char[], int, int, byte[]) - Static method in class org.apache.lucene.util.UnicodeUtil
Encode characters from a char[] source, starting at offset for length chars.
UTF16toUTF8(CharSequence, int, int, byte[]) - Static method in class org.apache.lucene.util.UnicodeUtil
Encode characters from this String, starting at offset for length characters.
UTF16toUTF8(CharSequence, int, int, byte[], int) - Static method in class org.apache.lucene.util.UnicodeUtil
Encode characters from this String, starting at offset for length characters.
UTF32ToUTF8 - Class in org.apache.lucene.util.automaton
Converts UTF-32 automata to the equivalent UTF-8 representation.
UTF32ToUTF8() - Constructor for class org.apache.lucene.util.automaton.UTF32ToUTF8
Sole constructor.
UTF8CodePoint() - Constructor for class org.apache.lucene.util.UnicodeUtil.UTF8CodePoint
 
utf8ToString() - Method in class org.apache.lucene.util.BytesRef
Interprets stored bytes as UTF8 bytes, returning the resulting string
UTF8toUTF16(byte[], int, int, char[]) - Static method in class org.apache.lucene.util.UnicodeUtil
Interprets the given byte array as UTF-8 and converts to UTF-16.
UTF8toUTF16(BytesRef, char[]) - Static method in class org.apache.lucene.util.UnicodeUtil
UTF8toUTF32(BytesRef, int[]) - Static method in class org.apache.lucene.util.UnicodeUtil
This method assumes valid UTF8 input.
Util - Class in org.apache.lucene.util.fst
Static helper methods.
Util.FSTPath<T> - Class in org.apache.lucene.util.fst
Represents a path in TopNSearcher.
Util.Result<T> - Class in org.apache.lucene.util.fst
Holds a single input (IntsRef) + output, returned by shortestPaths().
Util.TopNSearcher<T> - Class in org.apache.lucene.util.fst
Utility class to find top N shortest paths from start point(s).
Util.TopResults<T> - Class in org.apache.lucene.util.fst
Holds the results for a top N search using Util.TopNSearcher

V

validateSettings(int, int) - Static method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsWriter
Throws IllegalArgumentException if any of these settings is invalid.
validCounter - Variable in class org.apache.lucene.index.CheckIndex.Status
Whether the SegmentInfos.counter is greater than any of the segments' names.
validUTF16String(char[], int) - Static method in class org.apache.lucene.util.UnicodeUtil
 
validUTF16String(CharSequence) - Static method in class org.apache.lucene.util.UnicodeUtil
 
value - Variable in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
value - Variable in class org.apache.lucene.search.TotalHits
The value of the total hit count.
value - Variable in class org.apache.lucene.util.hppc.IntIntHashMap.IntCursor
The current value.
value - Variable in class org.apache.lucene.util.hppc.IntIntHashMap.IntIntCursor
The current value.
value - Variable in class org.apache.lucene.util.mutable.MutableValueBool
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueDouble
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueFloat
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueInt
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueLong
 
value - Variable in class org.apache.lucene.util.mutable.MutableValueStr
 
value(int) - Method in class org.apache.lucene.search.comparators.DocComparator
 
value(int) - Method in class org.apache.lucene.search.comparators.DoubleComparator
 
value(int) - Method in class org.apache.lucene.search.comparators.FloatComparator
 
value(int) - Method in class org.apache.lucene.search.comparators.IntComparator
 
value(int) - Method in class org.apache.lucene.search.comparators.LongComparator
 
value(int) - Method in class org.apache.lucene.search.comparators.TermOrdValComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
 
value(int) - Method in class org.apache.lucene.search.FieldComparator
Return the actual value in the slot.
valueCount - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
valueIterator() - Method in class org.apache.lucene.util.WeakIdentityMap
Returns an iterator over all values of this map.
valueOf(String) - Static method in enum org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.codecs.lucene99.Lucene99Codec.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.DateTools.Resolution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.Field.Store
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.InvertableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.RangeFieldQuery.QueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.ShapeField.DecodedTriangle.TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.ShapeField.QueryRelation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.document.StoredValue.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.geo.Component2D.WithinRelation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.geo.GeoUtils.WindingOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.DocValuesType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.IndexOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.IndexWriterConfig.OpenMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.MergePolicy.OneMergeProgress.PauseReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.MergeTrigger
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.PointValues.Relation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.StoredFieldVisitor.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.TermsEnum.SeekStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.VectorEncoding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.index.VectorSimilarityFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.BooleanClause.Occur
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.Pruning
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.ScoreMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.SortedNumericSelector.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.SortedSetSelector.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.SortField.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.search.TotalHits.Relation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.store.IOContext.Context
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.automaton.RegExp.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.FileDeleter.MsgType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.fst.FST.INPUT_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns the enum constant of this type with the specified name.
values - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
leaf values
values - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
leaf values
values - Variable in class org.apache.lucene.util.hppc.IntIntHashMap
The array holding values.
values() - Static method in enum org.apache.lucene.codecs.lucene90.Lucene90StoredFieldsFormat.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.codecs.lucene99.Lucene99Codec.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.DateTools.Resolution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.Field.Store
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.InvertableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.RangeFieldQuery.QueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.ShapeField.DecodedTriangle.TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.ShapeField.QueryRelation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.document.StoredValue.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.geo.Component2D.WithinRelation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.geo.GeoUtils.WindingOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.DocValuesType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.IndexOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.IndexWriterConfig.OpenMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.MergePolicy.OneMergeProgress.PauseReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.MergeTrigger
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.PointValues.Relation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.StoredFieldVisitor.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.TermsEnum.SeekStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.VectorEncoding
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.index.VectorSimilarityFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.BooleanClause.Occur
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.Pruning
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.ScoreMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.SortedNumericSelector.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.SortedSetSelector.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.SortField.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.search.TotalHits.Relation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.store.IOContext.Context
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.util.automaton.CompiledAutomaton.AUTOMATON_TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.util.automaton.RegExp.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.util.FileDeleter.MsgType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.lucene.util.fst.FST.INPUT_TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.lucene.util.hppc.IntIntHashMap
 
values() - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
Returns an array containing the constants of this enum type, in the order they are declared.
vectorDimension() - Method in class org.apache.lucene.document.FieldType
 
vectorDimension() - Method in interface org.apache.lucene.index.IndexableFieldType
The number of dimensions of the field's vector value
vectorEncoding() - Method in class org.apache.lucene.document.FieldType
 
vectorEncoding() - Method in interface org.apache.lucene.index.IndexableFieldType
The VectorEncoding of the field's vector value
VectorEncoding - Enum in org.apache.lucene.index
The numeric datatype of the vector values.
VectorizationProvider - Class in org.apache.lucene.internal.vectorization
A provider of vectorization implementations.
vectorSimilarityFunction() - Method in class org.apache.lucene.document.FieldType
 
vectorSimilarityFunction() - Method in interface org.apache.lucene.index.IndexableFieldType
The VectorSimilarityFunction of the field's vector value
VectorSimilarityFunction - Enum in org.apache.lucene.index
Vector similarity function; used in search to return top K most similar vectors to a target vector.
vectorsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsFormat
 
vectorsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.TermVectorsFormat
Returns a TermVectorsReader to read term vectors.
vectorsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingTermVectorsFormat
 
vectorsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.TermVectorsFormat
Returns a TermVectorsWriter to write term vectors.
VectorUtil - Class in org.apache.lucene.util
Utilities for computations with numeric arrays, especially algebraic operations like vector dot products.
VectorUtilSupport - Interface in org.apache.lucene.internal.vectorization
Interface for implementations of VectorUtil support.
vectorValue() - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues.DenseOffHeapVectorValues
 
vectorValue() - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues.DenseOffHeapVectorValues
 
vectorValue() - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues.DenseOffHeapVectorValues
 
vectorValue() - Method in class org.apache.lucene.document.KnnByteVectorField
Return the vector value of this field
vectorValue() - Method in class org.apache.lucene.document.KnnFloatVectorField
Return the vector value of this field
vectorValue() - Method in class org.apache.lucene.index.ByteVectorValues
Return the vector value for the current document ID.
vectorValue() - Method in class org.apache.lucene.index.FilterVectorValues
 
vectorValue() - Method in class org.apache.lucene.index.FloatVectorValues
Return the vector value for the current document ID.
vectorValue(int) - Method in class org.apache.lucene.codecs.lucene95.OffHeapByteVectorValues
 
vectorValue(int) - Method in class org.apache.lucene.codecs.lucene95.OffHeapFloatVectorValues
 
vectorValue(int) - Method in class org.apache.lucene.codecs.lucene99.OffHeapQuantizedByteVectorValues
 
vectorValue(int) - Method in interface org.apache.lucene.util.hnsw.RandomAccessVectorValues
Return the vector value indexed at the given ordinal.
VectorValues - Class in org.apache.lucene.index
Deprecated.
use FloatVectorValues instead
vectorValuesStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status of vectors
verbose() - Method in class org.apache.lucene.index.MergeScheduler
Returns true if infoStream messages are enabled.
verbose(MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
Returns true if the info-stream is in verbose mode
verifyAndCopyIndexHeader(IndexInput, DataOutput, byte[]) - Static method in class org.apache.lucene.codecs.CodecUtil
Expert: verifies the incoming IndexInput has an index header and that its segment ID matches the expected one, and then copies that index header into the provided DataOutput.
verifyAndEncode(double[], double[], byte[]) - Static method in class org.apache.lucene.document.DoubleRange
encode the ranges into a sortable byte array (Double.NaN not allowed)
verifyAndEncode(long[], long[], byte[]) - Static method in class org.apache.lucene.document.LongRange
encode the ranges into a sortable byte array
VerifyingLockFactory - Class in org.apache.lucene.store
A LockFactory that wraps another LockFactory and verifies that each lock obtain/release is "correct" (never results in two processes holding the lock at the same time).
VerifyingLockFactory(LockFactory, InputStream, OutputStream) - Constructor for class org.apache.lucene.store.VerifyingLockFactory
 
verifyLoadFactor(double) - Method in class org.apache.lucene.util.hppc.IntIntHashMap
Validate load factor range and return it.
VerifyPointsVisitor(String, int, PointValues) - Constructor for class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
Sole constructor
version - Variable in class org.apache.lucene.index.SegmentInfos
Counts how often the index has been changed.
Version - Class in org.apache.lucene.util
Use by certain classes to match version compatibility across releases of Lucene.
VERSION_70 - Static variable in class org.apache.lucene.index.SegmentInfos
The version that added information about the Lucene version at the time when the index has been created.
VERSION_72 - Static variable in class org.apache.lucene.index.SegmentInfos
The version that updated segment name counter to be long instead of int.
VERSION_74 - Static variable in class org.apache.lucene.index.SegmentInfos
The version that recorded softDelCount
VERSION_86 - Static variable in class org.apache.lucene.index.SegmentInfos
The version that recorded SegmentCommitInfo IDs
VERSION_90 - Static variable in class org.apache.lucene.util.fst.FST
Version that was used when releasing Lucene 9.0.
VERSION_CONTINUOUS_ARCS - Static variable in class org.apache.lucene.util.fst.FST
Version that started storing continuous arcs.
VERSION_CURRENT - Static variable in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
Current terms format.
VERSION_CURRENT - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsFormat
 
VERSION_CURRENT - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
 
VERSION_CURRENT - Static variable in class org.apache.lucene.util.bkd.BKDWriter
 
VERSION_CURRENT - Static variable in class org.apache.lucene.util.fst.FST
Current version.
VERSION_CURRENT - Static variable in class org.apache.lucene.util.packed.PackedInts
 
VERSION_FST_CONTINUOUS_ARCS - Static variable in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
The version that specialize arc store for continuous label in FST.
VERSION_LEAF_STORES_BOUNDS - Static variable in class org.apache.lucene.util.bkd.BKDWriter
 
VERSION_LOW_CARDINALITY_LEAVES - Static variable in class org.apache.lucene.util.bkd.BKDWriter
 
VERSION_META_FILE - Static variable in class org.apache.lucene.util.bkd.BKDWriter
 
VERSION_MONOTONIC_WITHOUT_ZIGZAG - Static variable in class org.apache.lucene.util.packed.PackedInts
 
VERSION_MSB_VLONG_OUTPUT - Static variable in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
Version that encode output as MSB VLong for better outputs sharing in FST, see GITHUB#12620.
VERSION_SELECTIVE_INDEXING - Static variable in class org.apache.lucene.util.bkd.BKDWriter
 
VERSION_START - Static variable in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsReader
Initial terms format.
VERSION_START - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99FlatVectorsFormat
 
VERSION_START - Static variable in class org.apache.lucene.codecs.lucene99.Lucene99HnswVectorsFormat
 
VERSION_START - Static variable in class org.apache.lucene.util.bkd.BKDWriter
 
VERSION_START - Static variable in class org.apache.lucene.util.fst.FST
First supported version, this is the version that was used when releasing Lucene 7.0.
VERSION_START - Static variable in class org.apache.lucene.util.packed.PackedInts
 
verticesToGeoJSON(double[], double[]) - Static method in class org.apache.lucene.geo.Polygon
 
VH_BE_DOUBLE - Static variable in class org.apache.lucene.util.BitUtil
Deprecated.
Better use little endian unless it is needed for backwards compatibility.
VH_BE_FLOAT - Static variable in class org.apache.lucene.util.BitUtil
Deprecated.
Better use little endian unless it is needed for backwards compatibility.
VH_BE_INT - Static variable in class org.apache.lucene.util.BitUtil
Deprecated.
Better use little endian unless it is needed for backwards compatibility.
VH_BE_LONG - Static variable in class org.apache.lucene.util.BitUtil
Deprecated.
Better use little endian unless it is needed for backwards compatibility.
VH_BE_SHORT - Static variable in class org.apache.lucene.util.BitUtil
Deprecated.
Better use little endian unless it is needed for backwards compatibility.
VH_LE_DOUBLE - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write little endian double from a byte array.
VH_LE_FLOAT - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write little endian float from a byte array.
VH_LE_INT - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write little endian int from a byte array.
VH_LE_LONG - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write little endian long from a byte array.
VH_LE_SHORT - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write little endian short from/to a byte array.
VH_NATIVE_DOUBLE - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write native endian double from a byte array.
VH_NATIVE_FLOAT - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write native endian float from a byte array.
VH_NATIVE_INT - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write native endian int from a byte array.
VH_NATIVE_LONG - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write native endian long from a byte array.
VH_NATIVE_SHORT - Static variable in class org.apache.lucene.util.BitUtil
A VarHandle to read/write native endian short from/to a byte array.
VirtualMethod<C> - Class in org.apache.lucene.util
A utility for keeping backwards compatibility on previously abstract methods (or similar replacements).
VirtualMethod(Class<C>, String, Class<?>...) - Constructor for class org.apache.lucene.util.VirtualMethod
Creates a new instance for the given baseClass and method declaration.
visit(int) - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
 
visit(int) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
Called for all documents in a leaf cell that's fully contained by the query.
visit(int, byte[]) - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
 
visit(int, byte[]) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
Called for all documents in a leaf cell that crosses the query.
visit(DocIdSetIterator) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
Similar to PointValues.IntersectVisitor.visit(int), but a bulk visit and implements may have their optimizations.
visit(DocIdSetIterator, byte[]) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
Similar to PointValues.IntersectVisitor.visit(int, byte[]) but in this case the packedValue can have more than one docID associated to it.
visit(QueryVisitor) - Method in class org.apache.lucene.document.RangeFieldQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.document.XYDocValuesPointInGeometryQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.AutomatonQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.BlendedTermQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.BooleanQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.BoostQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.FieldExistsQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.FuzzyQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.IndexSortSortedNumericDocValuesRangeQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.IndriQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.MatchNoDocsQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.NGramPhraseQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.PhraseQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.PointInSetQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.PointRangeQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.Query
Recurse through the query tree, visiting any child queries.
visit(QueryVisitor) - Method in class org.apache.lucene.search.SynonymQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.TermInSetQuery
 
visit(QueryVisitor) - Method in class org.apache.lucene.search.TermQuery
 
visit(QueryVisitor, Query, String) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
Report back to a QueryVisitor how this automaton matches terms
visitDocIDs(PointValues.IntersectVisitor) - Method in class org.apache.lucene.codecs.MutablePointTree
 
visitDocIDs(PointValues.IntersectVisitor) - Method in interface org.apache.lucene.index.PointValues.PointTree
Visit all the docs below the current node.
visitDocValues(PointValues.IntersectVisitor) - Method in interface org.apache.lucene.index.PointValues.PointTree
Visit all the docs and values below the current node.
visitedCount - Variable in class org.apache.lucene.search.AbstractKnnCollector
 
visitedCount() - Method in class org.apache.lucene.search.AbstractKnnCollector
 
visitedCount() - Method in interface org.apache.lucene.search.KnnCollector
 
visitedCount() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
visitedCount() - Method in class org.apache.lucene.util.hnsw.NeighborQueue
 
visitedCount() - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 
visitLeaf(Query) - Method in class org.apache.lucene.search.QueryVisitor
Called by leaf queries that do not match on terms
visitLimit() - Method in class org.apache.lucene.search.AbstractKnnCollector
 
visitLimit() - Method in interface org.apache.lucene.search.KnnCollector
 
visitLimit() - Method in class org.apache.lucene.util.hnsw.HnswGraphBuilder.GraphBuilderKnnCollector
 
visitLimit() - Method in class org.apache.lucene.util.hnsw.OrdinalTranslatedKnnCollector
 

W

waitForGeneration(long) - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
Waits for the target generation to become visible in the searcher.
waitForGeneration(long, int) - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
Waits for the target generation to become visible in the searcher, up to a maximum specified milli-seconds.
wakeup() - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
warm(LeafReader) - Method in interface org.apache.lucene.index.IndexWriter.IndexReaderWarmer
Invoked on the LeafReader for the newly merged segment, before that segment is made visible to near-real-time readers.
warm(LeafReader) - Method in class org.apache.lucene.index.SimpleMergedSegmentWarmer
 
wasBuiltFor(IndexReaderContext) - Method in class org.apache.lucene.index.TermStates
Expert: Return whether this TermStates was built for the given IndexReaderContext.
WeakIdentityMap<K,​V> - Class in org.apache.lucene.util
Implements a combination of WeakHashMap and IdentityHashMap.
weight - Variable in class org.apache.lucene.search.Scorer
the Scorer's parent Weight
Weight - Class in org.apache.lucene.search
Expert: Calculate query weights and build query scorers.
Weight(Query) - Constructor for class org.apache.lucene.search.Weight
Sole constructor, typically invoked by sub-classes.
Weight.DefaultBulkScorer - Class in org.apache.lucene.search
Just wraps a Scorer and performs top scoring using it.
weights - Variable in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
The Weights for our subqueries, in 1-1 correspondence with disjuncts
WILDCARD_CHAR - Static variable in class org.apache.lucene.search.WildcardQuery
Char equality with support for wildcards
WILDCARD_ESCAPE - Static variable in class org.apache.lucene.search.WildcardQuery
Escape character
WILDCARD_STRING - Static variable in class org.apache.lucene.search.WildcardQuery
String equality with support for wildcards
WildcardQuery - Class in org.apache.lucene.search
Implements the wildcard search query.
WildcardQuery(Term) - Constructor for class org.apache.lucene.search.WildcardQuery
Constructs a query for terms matching term.
WildcardQuery(Term, int) - Constructor for class org.apache.lucene.search.WildcardQuery
Constructs a query for terms matching term.
WildcardQuery(Term, int, MultiTermQuery.RewriteMethod) - Constructor for class org.apache.lucene.search.WildcardQuery
Constructs a query for terms matching term.
WINDOWS - Static variable in class org.apache.lucene.util.Constants
True iff running on Windows.
withDefault(DoubleValues, double) - Static method in class org.apache.lucene.search.DoubleValues
Wrap a DoubleValues instance, returning a default if the wrapped instance has no value
within(double, double, double, double, double, double, double, double) - Static method in interface org.apache.lucene.geo.Component2D
Compute whether the first bounding box 1 is within the second bounding box *
WITHIN - org.apache.lucene.document.RangeFieldQuery.QueryType
Use this for within queries.
WITHIN - org.apache.lucene.document.ShapeField.QueryRelation
used for WITHIN Queries
withinLine(double, double, boolean, double, double) - Method in interface org.apache.lucene.geo.Component2D
Compute the within relation of this component2D with a triangle *
withinLine(double, double, double, double, double, double, boolean, double, double) - Method in interface org.apache.lucene.geo.Component2D
Compute the within relation of this component2D with a line *
withinPoint(double, double) - Method in interface org.apache.lucene.geo.Component2D
Compute the within relation of this component2D with a point *
withinTriangle(double, double, boolean, double, double, boolean, double, double, boolean) - Method in interface org.apache.lucene.geo.Component2D
Compute the within relation of this component2D with a triangle *
withinTriangle(double, double, double, double, double, double, boolean, double, double, boolean, double, double, boolean) - Method in interface org.apache.lucene.geo.Component2D
Compute the within relation of this component2D with a triangle *
wktName() - Method in enum org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
wkt shape name
WORD_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Alphanumeric sequences
WordlistLoader - Class in org.apache.lucene.analysis
Loader for text files that represent a list of stopwords.
wrap(Iterable<? extends Collector>) - Static method in class org.apache.lucene.search.MultiCollector
Wraps a list of Collectors with a MultiCollector.
wrap(String, IndexInput, long, long) - Static method in class org.apache.lucene.store.BufferedIndexInput
Wraps a portion of another IndexInput with buffering.
wrap(List<? extends LeafReader>) - Method in class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
Wraps a list of LeafReaders
wrap(CodecReader, Sorter.DocMap, Sort) - Static method in class org.apache.lucene.index.SortingCodecReader
wrap(CodecReader, Sort) - Static method in class org.apache.lucene.index.SortingCodecReader
Return a sorted view of reader according to the order defined by sort .
wrap(DirectoryReader, QueryTimeout) - Static method in class org.apache.lucene.index.ExitableDirectoryReader
Wraps a provided DirectoryReader.
wrap(LeafReader) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableSubReaderWrapper
 
wrap(LeafReader) - Method in class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
Wrap one of the parent DirectoryReader's subreaders
wrap(LeafReader) - Static method in class org.apache.lucene.index.SlowCodecReaderWrapper
Returns a CodecReader view of reader.
wrap(SortedNumericDocValues, SortedNumericSelector.Type, SortField.Type) - Static method in class org.apache.lucene.search.SortedNumericSelector
Wraps a multi-valued SortedNumericDocValues as a single-valued view, using the specified selector and numericType.
wrap(SortedSetDocValues, SortedSetSelector.Type) - Static method in class org.apache.lucene.search.SortedSetSelector
Wraps a multi-valued SortedSetDocValues as a single-valued view, using the specified selector
wrap(Collector...) - Static method in class org.apache.lucene.search.MultiCollector
wrap(Scorable) - Static method in class org.apache.lucene.search.ScoreCachingWrappingScorer
Wraps the provided Scorable unless it's already an instance of ScoreCachingWrappingScorer, in which case it will just return the provided instance.
wrapComponents(String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
Wraps / alters the given TokenStreamComponents, taken from the wrapped Analyzer, to form new components.
wrapComponents(String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
 
wrapForMerge(CodecReader) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
Wrap a reader prior to merging in order to add/remove fields or documents.
wrapForMerge(MergePolicy.OneMerge, Directory) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
wrapForMerge(MergePolicy.OneMerge, Directory) - Method in class org.apache.lucene.index.MergeScheduler
Wraps the incoming Directory so that we can merge-throttle it using RateLimitedIndexOutput.
wrapForMerge(MergePolicy.OneMerge, Directory) - Method in class org.apache.lucene.index.NoMergeScheduler
 
wrapQuery(String, Query) - Static method in class org.apache.lucene.search.NamedMatches
Wrap a Query so that it associates a name with its Matches
wrapReader(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
Wraps / alters the given Reader.
wrapReader(String, Reader) - Method in class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
 
wrapReaderForNormalization(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
Wraps / alters the given Reader.
wrapReaderForNormalization(String, Reader) - Method in class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
 
wrapTokenStreamForNormalization(String, TokenStream) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
Wraps / alters the given TokenStream for normalization purposes, taken from the wrapped Analyzer, to form new components.
wrapTokenStreamForNormalization(String, TokenStream) - Method in class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
 
write(byte[]) - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Writes a byte array.
write(byte[], int, int) - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Writes a byte array.
write(Long, DataOutput) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
write(Object, DataOutput) - Method in class org.apache.lucene.util.fst.NoOutputs
 
write(Fields, NormsProducer) - Method in class org.apache.lucene.codecs.FieldsConsumer
Write all fields, terms and postings.
write(Fields, NormsProducer) - Method in class org.apache.lucene.codecs.lucene90.blocktree.Lucene90BlockTreeTermsWriter
 
write(SortField, DataOutput) - Static method in class org.apache.lucene.index.SortFieldProvider
Writes a SortField to a DataOutput
write(Directory, SegmentInfo, String, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.FieldInfosFormat
Writes the provided FieldInfos to the directory.
write(Directory, SegmentInfo, String, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene94.Lucene94FieldInfosFormat
 
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.CompoundFormat
Packs the provided segment's files into a compound format.
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene90.Lucene90CompoundFormat
 
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SegmentInfoFormat
 
write(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.SegmentInfoFormat
Write SegmentInfo data.
write(IndexOutput) - Method in class org.apache.lucene.index.SegmentInfos
Write ourselves to the provided IndexOutput
write(BytesRef) - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
Writes a BytesRef.
write(BytesRef, DataOutput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
write(CharsRef, DataOutput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
 
write(PairOutputs.Pair<A, B>, DataOutput) - Method in class org.apache.lucene.util.fst.PairOutputs
 
write(IntsRef, DataOutput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
write(T, DataOutput) - Method in class org.apache.lucene.util.fst.Outputs
Encode an output value into a DataOutput.
WRITE_LOCK_NAME - Static variable in class org.apache.lucene.index.IndexWriter
Name of the write lock in the index.
writeBEInt(DataOutput, int) - Static method in class org.apache.lucene.codecs.CodecUtil
write int value on header / footer with big endian order
writeBELong(DataOutput, long) - Static method in class org.apache.lucene.codecs.CodecUtil
write long value on header / footer with big endian order
writeBitSet(DocIdSetIterator, IndexOutput, byte) - Static method in class org.apache.lucene.codecs.lucene90.IndexedDISI
Writes the docIDs from it to out, in logical blocks, one for each 65536 docIDs in monotonically increasing gap-less order.
writeByte(byte) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.DataOutput
Writes a single byte.
writeByte(byte) - Method in class org.apache.lucene.store.FilterIndexOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
writeByte(byte) - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
writeByte(byte) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
 
writeBytes(byte[]) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeBytes(byte[], int) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeBytes(byte[], int) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeBytes(byte[], int) - Method in class org.apache.lucene.store.DataOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.DataOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.FilterIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
 
writeBytes(ByteBuffer) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeChildPointer(long, DataOutput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Writes the child pointer of a block to the given output.
writeField(FieldInfo, double) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
writeField(FieldInfo, double) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a stored double value.
writeField(FieldInfo, float) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
writeField(FieldInfo, float) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a stored float value.
writeField(FieldInfo, int) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
writeField(FieldInfo, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a stored int value.
writeField(FieldInfo, long) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
writeField(FieldInfo, long) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a stored long value.
writeField(FieldInfo, String) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
writeField(FieldInfo, String) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a stored String value.
writeField(FieldInfo, PointsReader) - Method in class org.apache.lucene.codecs.lucene90.Lucene90PointsWriter
 
writeField(FieldInfo, PointsReader) - Method in class org.apache.lucene.codecs.PointsWriter
Write all values contained in the provided reader
writeField(FieldInfo, ByteVectorValues, int) - Method in class org.apache.lucene.codecs.BufferingKnnVectorsWriter
Write the provided byte vector field
writeField(FieldInfo, FloatVectorValues, int) - Method in class org.apache.lucene.codecs.BufferingKnnVectorsWriter
Write the provided float vector field
writeField(FieldInfo, DataInput, int) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
writeField(FieldInfo, DataInput, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a stored binary value from a DataInput and a length.
writeField(FieldInfo, BytesRef) - Method in class org.apache.lucene.codecs.lucene90.compressing.Lucene90CompressingStoredFieldsWriter
 
writeField(FieldInfo, BytesRef) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
Writes a stored binary value.
writeField(IndexOutput, IndexOutput, IndexOutput, String, MutablePointTree) - Method in class org.apache.lucene.util.bkd.BKDWriter
Write a field from a MutablePointTree.
writeFinalOutput(T, DataOutput) - Method in class org.apache.lucene.util.fst.Outputs
Encode an final node output value into a DataOutput.
writeFooter(IndexOutput) - Static method in class org.apache.lucene.codecs.CodecUtil
Writes a codec footer, which records both a checksum algorithm ID and a checksum.
writeFreqs - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes freqs.
writeGroupVInts(long[], int) - Method in class org.apache.lucene.store.DataOutput
Encode integers using group-varint.
writeHeader(DataOutput, String, int) - Static method in class org.apache.lucene.codecs.CodecUtil
Writes a codec header, which records both a string to identify the file and a version number.
writeImpacts(CompetitiveImpactAccumulator, DataOutput) - Static method in class org.apache.lucene.codecs.lucene99.Lucene99SkipWriter
 
writeIndexHeader(DataOutput, String, int, byte[], String) - Static method in class org.apache.lucene.codecs.CodecUtil
Writes a codec header for an index file, which records both a string to identify the format of the file, a version number, and data to identify the file instance (ID and auxiliary suffix such as generation).
writeInt(int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
writeInt(int) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeInt(int) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeInt(int) - Method in class org.apache.lucene.store.DataOutput
Writes an int as four bytes (LE byte order).
writeInt(int) - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
writeInt(int) - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
writeLevelLength(long, IndexOutput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Writes the length of a level to the given output.
writeLiveDocs(Bits, Directory, SegmentCommitInfo, int, IOContext) - Method in class org.apache.lucene.codecs.LiveDocsFormat
Persist live docs bits.
writeLiveDocs(Bits, Directory, SegmentCommitInfo, int, IOContext) - Method in class org.apache.lucene.codecs.lucene90.Lucene90LiveDocsFormat
 
writeLong(long) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
writeLong(long) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeLong(long) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeLong(long) - Method in class org.apache.lucene.store.DataOutput
Writes a long as eight bytes (LE byte order).
writeLong(long) - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
writeLong(long) - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
writeLong(long, int) - Method in class org.apache.lucene.util.packed.PackedDataOutput
Write a value using exactly bitsPerValue bits.
writeMapOfStrings(Map<String, String>) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeMapOfStrings(Map<String, String>) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeMapOfStrings(Map<String, String>) - Method in class org.apache.lucene.store.DataOutput
Writes a String map.
writeOffsets - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes offsets.
writePayloads - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes payloads.
writePositions - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
True if the current field writes positions.
writeQuantizedVectorData(IndexOutput, QuantizedByteVectorValues) - Static method in class org.apache.lucene.codecs.lucene99.Lucene99ScalarQuantizedVectorsWriter
Writes the vector values to the output and returns a set of documents that contains vectors.
writer - Variable in class org.apache.lucene.util.bkd.BKDRadixSelector.PathSlice
 
Writer(DataOutput, int, int) - Constructor for class org.apache.lucene.util.packed.PackedInts.Writer
 
writeSetOfStrings(Set<String>) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeSetOfStrings(Set<String>) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeSetOfStrings(Set<String>) - Method in class org.apache.lucene.store.DataOutput
Writes a String set.
writeShort(short) - Method in class org.apache.lucene.store.ByteArrayDataOutput
 
writeShort(short) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeShort(short) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeShort(short) - Method in class org.apache.lucene.store.DataOutput
Writes a short as two bytes (LE byte order).
writeShort(short) - Method in class org.apache.lucene.store.OutputStreamIndexOutput
 
writeShort(short) - Method in class org.apache.lucene.store.RateLimitedIndexOutput
 
writeSkip(IndexOutput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Writes the buffered skip lists to the given output.
writeSkipData(int, DataOutput) - Method in class org.apache.lucene.codecs.lucene99.Lucene99SkipWriter
 
writeSkipData(int, DataOutput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
Subclasses must implement the actual skip data encoding in this method.
writeSortField(SortField, DataOutput) - Method in class org.apache.lucene.index.SortFieldProvider
Writes a SortField to a DataOutput
writeSortField(SortField, DataOutput) - Method in class org.apache.lucene.search.SortedNumericSortField.Provider
 
writeSortField(SortField, DataOutput) - Method in class org.apache.lucene.search.SortedSetSortField.Provider
 
writeSortField(SortField, DataOutput) - Method in class org.apache.lucene.search.SortField.Provider
 
writeStoredMeta(int, IndexOutput, IndexOutput, int, int, DocsWithFieldSet) - Static method in class org.apache.lucene.codecs.lucene95.OrdToDocDISIReaderConfiguration
Writes out the docsWithField and ordToDoc mapping to the outputMeta and vectorData respectively.
writeString(String) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
 
writeString(String) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
 
writeString(String) - Method in class org.apache.lucene.store.DataOutput
Writes a string.
writeTerm(BytesRef, TermsEnum, FixedBitSet, NormsProducer) - Method in class org.apache.lucene.codecs.PostingsWriterBase
Write all postings for one term; use the provided TermsEnum to pull a PostingsEnum.
writeTerm(BytesRef, TermsEnum, FixedBitSet, NormsProducer) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
 
writeTo(DataOutput) - Method in interface org.apache.lucene.util.fst.FSTReader
Write this FST to another DataOutput
writeTo(DataOutput) - Method in class org.apache.lucene.util.fst.OffHeapFSTStore
 
writeTo(DataOutput) - Method in class org.apache.lucene.util.fst.OnHeapFSTStore
 
writeVInt(int) - Method in class org.apache.lucene.store.DataOutput
Writes an int in a variable-length format.
writeVLong(long) - Method in class org.apache.lucene.store.DataOutput
Writes an long in a variable-length format.
writeZInt(int) - Method in class org.apache.lucene.store.DataOutput
Write a zig-zag-encoded variable-length integer.
writeZLong(long) - Method in class org.apache.lucene.store.DataOutput
Write a zig-zag-encoded variable-length long.

X

xor(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place XOR of the bits provided by the iterator.
xor(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this XOR other
xor(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
this = this XOR other
XYCircle - Class in org.apache.lucene.geo
Represents a circle on the XY plane.
XYCircle(float, float, float) - Constructor for class org.apache.lucene.geo.XYCircle
Creates a new circle from the supplied x/y center and radius.
XYDocValuesField - Class in org.apache.lucene.document
An per-document location field.
XYDocValuesField(String, float, float) - Constructor for class org.apache.lucene.document.XYDocValuesField
Creates a new XYDocValuesField with the specified x and y
XYDocValuesPointInGeometryQuery - Class in org.apache.lucene.document
XYGeometry query for XYDocValuesField.
XYEncodingUtils - Class in org.apache.lucene.geo
reusable cartesian geometry encoding methods
XYGeometry - Class in org.apache.lucene.geo
Cartesian Geometry object.
XYGeometry() - Constructor for class org.apache.lucene.geo.XYGeometry
 
XYLine - Class in org.apache.lucene.geo
Represents a line in cartesian space.
XYLine(float[], float[]) - Constructor for class org.apache.lucene.geo.XYLine
Creates a new Line from the supplied X/Y array.
XYPoint - Class in org.apache.lucene.geo
Represents a point on the earth's surface.
XYPoint(float, float) - Constructor for class org.apache.lucene.geo.XYPoint
Creates a new Point from the supplied latitude/longitude.
XYPointField - Class in org.apache.lucene.document
An indexed XY position field.
XYPointField(String, float, float) - Constructor for class org.apache.lucene.document.XYPointField
Creates a new XYPoint with the specified x and y
XYPolygon - Class in org.apache.lucene.geo
Represents a polygon in cartesian space.
XYPolygon(float[], float[], XYPolygon...) - Constructor for class org.apache.lucene.geo.XYPolygon
Creates a new Polygon from the supplied x, y arrays, and optionally any holes.
XYRectangle - Class in org.apache.lucene.geo
Represents a x/y cartesian rectangle.
XYRectangle(float, float, float, float) - Constructor for class org.apache.lucene.geo.XYRectangle
Constructs a bounding box by first validating the provided x and y coordinates
XYShape - Class in org.apache.lucene.document
A cartesian shape utility class for indexing and searching geometries whose vertices are unitless x, y values.
XYShapeDocValues - Class in org.apache.lucene.document
A concrete implementation of ShapeDocValues for storing binary doc value representation of XYShape geometries in a XYShapeDocValuesField
XYShapeDocValues(List<ShapeField.DecodedTriangle>) - Constructor for class org.apache.lucene.document.XYShapeDocValues
protected ctor for instantiating a cartesian doc value based on a tessellation
XYShapeDocValues(BytesRef) - Constructor for class org.apache.lucene.document.XYShapeDocValues
protected ctor for instantiating a cartesian doc value based on an already retrieved binary format
XYShapeDocValuesField - Class in org.apache.lucene.document
Concrete implementation of a ShapeDocValuesField for cartesian geometries.
XYShapeDocValuesField(String, List<ShapeField.DecodedTriangle>) - Constructor for class org.apache.lucene.document.XYShapeDocValuesField
constructs a XYShapeDocValueField from a pre-tessellated geometry
XYShapeDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.XYShapeDocValuesField
Creates a XYShapeDocValueField from a given serialized value

Y

YEAR - org.apache.lucene.document.DateTools.Resolution
Limit a date's resolution to year granularity.
YES - org.apache.lucene.document.Field.Store
Store the original field value in the index.
YES - org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Accept the term and position the enum at the next term.
YES - org.apache.lucene.index.StoredFieldVisitor.Status
YES: the field should be visited.
YES - Static variable in class org.apache.lucene.index.SegmentInfo
Used by some member fields to mean present (e.g., norms, deletions).
YES_AND_SEEK - org.apache.lucene.index.FilteredTermsEnum.AcceptStatus
Accept the term and advance (FilteredTermsEnum.nextSeekTerm(BytesRef)) to the next term.
yyatEOF() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Returns whether the scanner has reached the end of the reader it reads from.
yybegin(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Enters a new lexical state.
yychar() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Character count processed so far
yycharat(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Returns the character at the given position from the matched text.
yyclose() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Closes the input reader.
YYEOF - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
This character denotes the end of file.
YYINITIAL - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Lexical States.
yylength() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
How many characters were matched.
yypushback(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Pushes the specified amount of characters back into the input stream.
yyreset(Reader) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Resets the scanner to read from a new input stream.
yystate() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Returns the current lexical state.
yytext() - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Returns the text matched by the current regular expression.

Z

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

_

_innerIter - Variable in class org.apache.lucene.search.FilteredDocIdSetIterator
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages