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

A

AbstractAllTermDocs - Class in org.apache.lucene.index
Base class for enumerating all but deleted docs.
AbstractAllTermDocs(int) - Constructor for class org.apache.lucene.index.AbstractAllTermDocs
 
AbstractField - Class in org.apache.lucene.document
Base class for Field implementations
AbstractField() - Constructor for class org.apache.lucene.document.AbstractField
 
AbstractField(String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.AbstractField
 
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.LengthFilter
 
accept() - Method in class org.apache.lucene.analysis.StopFilter
Returns the next input Token whose term() is not a stop word.
accept(AttributeSource) - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkFilter
Returns true, iff the current state of the passed-in AttributeSource shall be stored in the sink.
accept() - Method in class org.apache.lucene.analysis.TypeTokenFilter
By default accept the token if its type is not a stop type.
accept(String) - Method in interface org.apache.lucene.document.FieldSelector
 
accept(String) - Method in class org.apache.lucene.document.LoadFirstFieldSelector
 
accept(String) - Method in class org.apache.lucene.document.MapFieldSelector
Load field according to its associated value in fieldSelections
accept(String) - Method in class org.apache.lucene.document.SetBasedFieldSelector
Indicate whether to load the field with the given name or not.
accept(File, String) - Method in class org.apache.lucene.index.IndexFileNameFilter
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
Implementing classes are required to return whether the current position is a match for the passed in "match" SpanQuery.
acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.CachingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.Collector
Return true if this collector does not require the matching docIDs to be delivered in int sort order (smallest to largest) to Collector.collect(int).
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.MultiCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TimeLimitingCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TopFieldCollector
 
acceptsDocsOutOfOrder() - Method in class org.apache.lucene.search.TotalHitCountCollector
 
acquire() - Method in class org.apache.lucene.search.ReferenceManager
Obtain the current reference.
acquire(long) - Method in class org.apache.lucene.search.SearcherLifetimeManager
Retrieve a previously recorded IndexSearcher, if it has not yet been closed NOTE: this may return null when the requested searcher has already timed out.
acquireWriteLock() - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
ACRONYM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
ACRONYM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
ACRONYM_DEP - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
Deprecated.
this solves a bug where HOSTs that end with '.' are identified as ACRONYMs.
ACRONYM_DEP - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated.
this solves a bug where HOSTs that end with '.' are identified as ACRONYMs.
actualEnum - Variable in class org.apache.lucene.search.FilteredTermEnum
the delegate enum - to set this member use FilteredTermEnum.setEnum(org.apache.lucene.index.TermEnum)
add(Object) - Method in class org.apache.lucene.analysis.CharArraySet
 
add(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
Add this CharSequence into the set
add(String) - Method in class org.apache.lucene.analysis.CharArraySet
Add this String into the set
add(char[]) - Method in class org.apache.lucene.analysis.CharArraySet
Add this char[] directly to the set.
add(String, String) - Method in class org.apache.lucene.analysis.NormalizeCharMap
Records a replacement to be applied to the inputs stream.
add(Fieldable) - Method in class org.apache.lucene.document.Document
Adds a field to a document.
add(FieldInfos) - Method in class org.apache.lucene.index.FieldInfos
 
add(Document) - Method in class org.apache.lucene.index.FieldInfos
Adds field info for a Document.
add(String, boolean) - Method in class org.apache.lucene.index.FieldInfos
Calls 5 parameter add with false for all TermVector parameters.
add(String, boolean, boolean) - Method in class org.apache.lucene.index.FieldInfos
Calls 5 parameter add with false for term vector positions and offsets.
add(String, boolean, boolean, boolean) - Method in class org.apache.lucene.index.FieldInfos
If the field is not yet known, adds it.
add(String, boolean, boolean, boolean, boolean, FieldInfo.IndexOptions) - Method in class org.apache.lucene.index.FieldInfos
If the field is not yet known, adds it.
add(FieldInfo) - Method in class org.apache.lucene.index.FieldInfos
 
add(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
 
add(IndexReader) - Method in class org.apache.lucene.index.ParallelReader
Add an IndexReader.
add(IndexReader, boolean) - Method in class org.apache.lucene.index.ParallelReader
Add an IndexReader whose stored fields will not be returned.
add(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
 
add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery
Adds a clause to a boolean query.
add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery
Adds a clause to a boolean query.
add(Query) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Add a subquery to this disjunction
add(Collection<Query>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Add a collection of disjuncts to this disjunction via Iterable
add(Term) - Method in class org.apache.lucene.search.MultiPhraseQuery
Add a single term at the next position in the phrase.
add(Term[]) - Method in class org.apache.lucene.search.MultiPhraseQuery
Add multiple terms at the next position in the phrase.
add(Term[], int) - Method in class org.apache.lucene.search.MultiPhraseQuery
Allows to specify the relative position of terms within the phrase.
add(Term) - Method in class org.apache.lucene.search.PhraseQuery
Adds a term to the end of the query phrase.
add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery
Adds a term to the end of the query phrase.
add(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef
add(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefHash
Adds a new BytesRef with a pre-calculated hash code.
add(IntsRef, T) - Method in class org.apache.lucene.util.fst.Builder
It's OK to add the same input twice in a row with different outputs, as long as outputs impls the merge method.
add(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
add(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
add(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
add(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg add("foo", "bar") -> "foobar"
add(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
add(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
add(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
add(E) - Method in class org.apache.lucene.util.MapBackedSet
 
add(long) - Method in class org.apache.lucene.util.packed.PackedInts.Writer
 
add(T) - Method in class org.apache.lucene.util.PriorityQueue
Adds an Object to a PriorityQueue in log(size) time.
add(int, IndexReader) - Method in class org.apache.lucene.util.ReaderUtil.Gather
 
addAll(Iterable<SegmentInfo>) - Method in class org.apache.lucene.index.SegmentInfos
 
addAnalyzer(String, Analyzer) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Deprecated.
Changing the Analyzer for a field after instantiation prevents reusability. Analyzers for fields should be set during construction.
addAndGet(long) - Method in class org.apache.lucene.util.Counter
Adds the given delta to the counters current value
addArc(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
addAttribute(Class<A>) - Method in class org.apache.lucene.util.AttributeSource
The caller must pass in a Class<?
addAttributeImpl(AttributeImpl) - Method in class org.apache.lucene.util.AttributeSource
Expert: Adds a custom AttributeImpl instance with one or more Attribute interfaces.
addBuffer(int) - Method in class org.apache.lucene.store.RAMFile
 
addByPoolOffset(int) - Method in class org.apache.lucene.util.BytesRefHash
 
addClause(List<BooleanClause>, int, int, Query) - Method in class org.apache.lucene.queryParser.QueryParser
 
addClause(BooleanQuery, Term, float) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
addClause(BooleanQuery, Term, float) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
addClause(SpanQuery) - Method in class org.apache.lucene.search.spans.SpanOrQuery
Adds a clause to this query
addCoreClosedListener(SegmentReader.CoreClosedListener) - Method in class org.apache.lucene.index.SegmentReader
Expert: adds a CoreClosedListener to this reader's shared core
addDetail(Explanation) - Method in class org.apache.lucene.search.Explanation
Adds a sub-node to this explanation node.
addDocument(Document) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index.
addDocument(Document, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
Adds a document to this index, using the provided analyzer instead of the value of IndexWriter.getAnalyzer().
addDocument(Document, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addDocument(Document) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addDocuments(Collection<Document>) - Method in class org.apache.lucene.index.IndexWriter
Atomically adds a block of documents with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
addDocuments(Collection<Document>, Analyzer) - Method in class org.apache.lucene.index.IndexWriter
Atomically adds a block of documents, analyzed using the provided analyzer, with sequentially assigned document IDs, such that an external reader will see all or none of the documents.
addDocuments(Collection<Document>, Analyzer) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addDocuments(Collection<Document>) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addEscapes(String) - Static method in error org.apache.lucene.queryParser.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addFile(String) - Method in class org.apache.lucene.index.CompoundFileWriter
Add a source stream.
addFile(String, Directory) - Method in class org.apache.lucene.index.CompoundFileWriter
Same as CompoundFileWriter.addFile(String), only for files that are found in an external Directory.
addIndexes(Directory...) - Method in class org.apache.lucene.index.IndexWriter
Adds all segments from an array of indexes into this index.
addIndexes(IndexReader...) - Method in class org.apache.lucene.index.IndexWriter
Merges the provided indexes into this index.
addIndexes(Directory...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addIndexes(IndexReader...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
addIndexesNoOptimize(Directory...) - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
addOffCorrectMap(int, int) - Method in class org.apache.lucene.analysis.BaseCharFilter
Adds an offset correction mapping at the given output stream offset.
addPosition(int, int) - Method in class org.apache.lucene.search.SpanFilterResult.PositionInfo
 
addRange(String, String) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRange(int, int, int) - Method in class org.apache.lucene.util.NumericUtils.IntRangeBuilder
Overwrite this method, if you like to receive the raw int range bounds.
addRange(String, String) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
Overwrite this method, if you like to receive the already prefix encoded range bounds.
addRange(long, long, int) - Method in class org.apache.lucene.util.NumericUtils.LongRangeBuilder
Overwrite this method, if you like to receive the raw long range bounds.
addReaderClosedListener(IndexReader.ReaderClosedListener) - Method in class org.apache.lucene.index.IndexReader
addSinkTokenStream(TeeSinkTokenFilter.SinkTokenStream) - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
Adds a TeeSinkTokenFilter.SinkTokenStream created by another TeeSinkTokenFilter to this one.
addWaitingListener(NRTManager.WaitingListener) - Method in class org.apache.lucene.search.NRTManager
Adds a listener, to be notified when a caller is waiting for a specific generation searcher to be visible.
adjustTop() - Method in class org.apache.lucene.util.ScorerDocQueue
Deprecated.
Should be called when the scorer at top changes doc() value.
advance(int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
advance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
Advances to the first beyond (see NOTE below) the current whose document number is greater than or equal to target.
advance(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
advance(int) - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
advance(int) - Method in class org.apache.lucene.search.spans.SpanScorer
 
advance(int) - Method in class org.apache.lucene.util.OpenBitSetIterator
 
afterClose() - Method in class org.apache.lucene.search.NRTManager
 
afterClose() - Method in class org.apache.lucene.search.ReferenceManager
Called after close(), so subclass can free any resources.
afterRefresh() - Method in class org.apache.lucene.search.NRTManager
 
afterRefresh() - Method in class org.apache.lucene.search.ReferenceManager
Called after swapReference has installed a new instance.
alignObjectSize(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
Aligns an object size to be the next multiple of RamUsageEstimator.NUM_BYTES_OBJECT_ALIGNMENT.
ALL - Static variable in class org.apache.lucene.index.SortedTermVectorMapper
Stand-in name for the field in TermVectorEntry.
allocSlice(byte[], int) - Method in class org.apache.lucene.util.ByteBlockPool
 
ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
 
ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
AlreadyClosedException - Exception in org.apache.lucene.store
This exception is thrown when there is an attempt to access something that has already been closed.
AlreadyClosedException(String) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
 
Analyzer - Class in org.apache.lucene.analysis
An Analyzer builds TokenStreams, which analyze text.
Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
 
AND - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
and(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place AND of the bits provided by the iterator.
and(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND other
and(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
 
AND_OPERATOR - Static variable in class org.apache.lucene.queryParser.QueryParser
Alternative form of QueryParser.Operator.AND
andNot(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
Does in-place AND NOT of the bits provided by the iterator.
andNot(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
this = this AND NOT other
andNot(OpenBitSet) - Method in class org.apache.lucene.util.OpenBitSet
 
andNotCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.lucene.util.OpenBitSet
Returns the popcount or cardinality of "a and not b" or "intersection(a, not(b))".
anyUnhandledExceptions() - Static method in class org.apache.lucene.index.ConcurrentMergeScheduler
Used for testing
APOSTROPHE - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
APOSTROPHE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
append(CharSequence) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(CharSequence, int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(char) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
 
append(String) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the specified String to this character sequence.
append(StringBuilder) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the specified StringBuilder to this character sequence.
append(CharTermAttribute) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Appends the contents of the other CharTermAttribute to this character sequence.
append(CharSequence) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(char) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(String) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(StringBuilder) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(CharTermAttribute) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
append(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Appends the bytes from the given BytesRef NOTE: if this would exceed the array size, this method creates a new reference array.
append(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
Appends the given array to this CharsRef
arcCount - Variable in class org.apache.lucene.util.fst.FST
 
arcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
arcWithOutputCount - Variable in class org.apache.lucene.util.fst.FST
 
ArrayUtil - Class in org.apache.lucene.util
Methods for manipulating arrays.
ArrayUtil() - Constructor for class org.apache.lucene.util.ArrayUtil
Deprecated.
This constructor was not intended to be public and should not be used. This class contains solely a static utility methods. It will be made private in Lucene 4.0
ASCIIFoldingFilter - Class in org.apache.lucene.analysis
This class converts alphabetic, numeric, and symbolic Unicode characters which are not in the first 127 ASCII characters (the "Basic Latin" Unicode block) into their ASCII equivalents, if one exists.
ASCIIFoldingFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ASCIIFoldingFilter
 
asList() - Method in class org.apache.lucene.index.SegmentInfos
Returns all contained segments as an unmodifiable List view.
asSet() - Method in class org.apache.lucene.index.SegmentInfos
Returns all contained segments as an unmodifiable Set view.
Attribute - Interface in org.apache.lucene.util
Base interface for attributes.
AttributeImpl - Class in org.apache.lucene.util
Base class for Attributes that can be added to a AttributeSource.
AttributeImpl() - Constructor for class org.apache.lucene.util.AttributeImpl
 
AttributeReflector - Interface in org.apache.lucene.util
This interface is used to reflect contents of AttributeSource or AttributeImpl.
AttributeSource - Class in org.apache.lucene.util
An AttributeSource contains a list of different AttributeImpls, and methods to add and get them.
AttributeSource() - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the default attribute factory AttributeSource.AttributeFactory.DEFAULT_ATTRIBUTE_FACTORY.
AttributeSource(AttributeSource) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource that uses the same attributes as the supplied one.
AttributeSource(AttributeSource.AttributeFactory) - Constructor for class org.apache.lucene.util.AttributeSource
An AttributeSource using the supplied AttributeSource.AttributeFactory for creating new Attribute instances.
AttributeSource.AttributeFactory - Class in org.apache.lucene.util
An AttributeFactory creates instances of AttributeImpls.
AttributeSource.AttributeFactory() - Constructor for class org.apache.lucene.util.AttributeSource.AttributeFactory
 
AttributeSource.State - Class in org.apache.lucene.util
This class holds the state of an AttributeSource.
AttributeSource.State() - Constructor for class org.apache.lucene.util.AttributeSource.State
 
AveragePayloadFunction - Class in org.apache.lucene.search.payloads
Calculate the final score as the average score of all payloads seen.
AveragePayloadFunction() - Constructor for class org.apache.lucene.search.payloads.AveragePayloadFunction
 

B

backup(int) - Method in interface org.apache.lucene.queryParser.CharStream
Backs up the input stream by amount steps.
backup(int) - Method in class org.apache.lucene.queryParser.FastCharStream
 
BAREOPER - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
base - Variable in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
base - Variable in class org.apache.lucene.search.CachingCollector
 
BaseCharFilter - Class in org.apache.lucene.analysis
Base utility class for implementing a CharFilter.
BaseCharFilter(CharStream) - Constructor for class org.apache.lucene.analysis.BaseCharFilter
 
beginColumn - Variable in class org.apache.lucene.queryParser.Token
The column number of the first character of this Token.
beginLine - Variable in class org.apache.lucene.queryParser.Token
The line number of the first character of this Token.
BeginToken() - Method in interface org.apache.lucene.queryParser.CharStream
Returns the next character that marks the beginning of the next token.
BeginToken() - Method in class org.apache.lucene.queryParser.FastCharStream
 
binaryLength - Variable in class org.apache.lucene.document.AbstractField
 
binaryOffset - Variable in class org.apache.lucene.document.AbstractField
 
binarySearch(String[], String) - Static method in class org.apache.lucene.search.FieldComparator
 
binarySearch(String[], String, int, int) - Static method in class org.apache.lucene.search.FieldComparator
 
binarySearchLookup(String) - Method in class org.apache.lucene.search.FieldCache.StringIndex
 
bitlist - Static variable in class org.apache.lucene.util.OpenBitSetIterator
 
Bits - Interface in org.apache.lucene.util
Interface for Bitset-like structures.
bits - Variable in class org.apache.lucene.util.OpenBitSet
 
Bits.MatchAllBits - Class in org.apache.lucene.util
Bits impl of the specified length with all bits set.
Bits.MatchAllBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchAllBits
 
Bits.MatchNoBits - Class in org.apache.lucene.util
Bits impl of the specified length with no bits set.
Bits.MatchNoBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchNoBits
 
bits2words(int) - Static method in class org.apache.lucene.util.FixedBitSet
returns the number of 64 bit words it would take to hold numBits
bits2words(long) - Static method in class org.apache.lucene.util.OpenBitSet
returns the number of 64 bit words it would take to hold numBits
bitSpans(IndexReader) - Method in class org.apache.lucene.search.CachingSpanFilter
 
bitSpans(IndexReader) - Method in class org.apache.lucene.search.SpanFilter
Returns a SpanFilterResult with true for documents which should be permitted in search results, and false for those that should not and Spans for where the true docs match.
bitSpans(IndexReader) - Method in class org.apache.lucene.search.SpanQueryFilter
 
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
 
bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
 
bitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
Returns how many bits are required to hold values up to and including maxValue
BitUtil - Class in org.apache.lucene.util
A variety of high efficiency bit twiddling routines.
BitVector - Class in org.apache.lucene.util
Optimized implementation of a vector of bits.
BitVector(int) - Constructor for class org.apache.lucene.util.BitVector
Constructs a vector capable of holding n bits.
BitVector(Directory, String) - Constructor for class org.apache.lucene.util.BitVector
Constructs a bit vector from the file name in Directory d, as written by the BitVector.write(org.apache.lucene.store.Directory, java.lang.String) method.
blockSize - Variable in class org.apache.lucene.util.ByteBlockPool.Allocator
 
BooleanClause - Class in org.apache.lucene.search
A clause in a BooleanQuery.
BooleanClause(Query, BooleanClause.Occur) - Constructor for class org.apache.lucene.search.BooleanClause
Constructs a BooleanClause.
BooleanClause.Occur - Enum in org.apache.lucene.search
Specifies how clauses are to occur in matching documents.
BooleanQuery - Class in org.apache.lucene.search
A Query that matches documents matching boolean combinations of other queries, e.g.
BooleanQuery() - Constructor for class org.apache.lucene.search.BooleanQuery
Constructs an empty boolean query.
BooleanQuery(boolean) - Constructor for class org.apache.lucene.search.BooleanQuery
Constructs an empty boolean query.
BooleanQuery.BooleanWeight - Class in org.apache.lucene.search
Expert: the Weight for BooleanQuery, used to normalize, score and explain these queries.
BooleanQuery.BooleanWeight(Searcher, boolean) - Constructor for class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
Thrown when an attempt is made to add more than BooleanQuery.getMaxClauseCount() clauses.
BooleanQuery.TooManyClauses() - Constructor for exception org.apache.lucene.search.BooleanQuery.TooManyClauses
 
boost - Variable in class org.apache.lucene.document.AbstractField
 
Boost - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
Lexical state.
boost(float) - Static method in class org.apache.lucene.util.ToStringUtils
for printing boost only if not 1.0
boosts - Variable in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
BUF_SIZE_INT - Static variable in class org.apache.lucene.util.NumericUtils
Expert: The maximum term length (used for char[] buffer size) for encoding int values.
BUF_SIZE_LONG - Static variable in class org.apache.lucene.util.NumericUtils
Expert: The maximum term length (used for char[] buffer size) for encoding long values.
buffer() - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Returns the internal termBuffer character array which you can then directly alter.
buffer() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
buffer - Variable in class org.apache.lucene.store.BufferedIndexInput
 
buffer - Variable in class org.apache.lucene.util.ByteBlockPool
 
BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
Default buffer size
BufferedIndexInput - Class in org.apache.lucene.store
Base implementation class for buffered IndexInput.
BufferedIndexInput() - Constructor for class org.apache.lucene.store.BufferedIndexInput
Deprecated.
please pass resourceDesc
BufferedIndexInput(String) - Constructor for class org.apache.lucene.store.BufferedIndexInput
 
BufferedIndexInput(int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
Deprecated.
please pass resourceDesc
BufferedIndexInput(String, int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
Inits BufferedIndexInput with a specific bufferSize
BufferedIndexOutput - Class in org.apache.lucene.store
Base implementation class for buffered IndexOutput.
BufferedIndexOutput() - Constructor for class org.apache.lucene.store.BufferedIndexOutput
 
buffers - Variable in class org.apache.lucene.store.RAMFile
 
buffers - Variable in class org.apache.lucene.util.ByteBlockPool
 
Builder<T> - Class in org.apache.lucene.util.fst
Builds a minimal FST (maps an IntsRef term to an arbitrary output) from pre-sorted terms with outputs.
Builder(FST.INPUT_TYPE, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.Builder
Instantiates an FST/FSA builder without any pruning.
Builder(FST.INPUT_TYPE, int, int, boolean, boolean, int, Outputs<T>, Builder.FreezeTail<T>, boolean) - Constructor for class org.apache.lucene.util.fst.Builder
Instantiates an FST/FSA builder with all the possible tuning and construction tweaks.
Builder.Arc<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) arc.
Builder.Arc() - Constructor for class org.apache.lucene.util.fst.Builder.Arc
 
Builder.FreezeTail<T> - Class in org.apache.lucene.util.fst
Expert: this is invoked by Builder whenever a suffix is serialized.
Builder.FreezeTail() - Constructor for class org.apache.lucene.util.fst.Builder.FreezeTail
 
Builder.UnCompiledNode<T> - Class in org.apache.lucene.util.fst
Expert: holds a pending (seen but not yet serialized) Node.
Builder.UnCompiledNode(Builder<T>, int) - Constructor for class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
BYTE - Static variable in class org.apache.lucene.search.function.FieldScoreQuery.Type
field values are interpreted as numeric byte values.
BYTE - Static variable in class org.apache.lucene.search.SortField
Sort using term values as encoded Bytes.
byte315ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
byteToFloat(b, mantissaBits=3, zeroExponent=15)
byte52ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
byteToFloat(b, mantissaBits=5, zeroExponent=2)
BYTE_BLOCK_MASK - Static variable in class org.apache.lucene.util.ByteBlockPool
 
BYTE_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.ByteBlockPool
 
BYTE_BLOCK_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
 
byteArray(StringBuilder, byte[]) - Static method in class org.apache.lucene.util.ToStringUtils
 
ByteArrayDataInput - Class in org.apache.lucene.store
DataInput backed by a byte array.
ByteArrayDataInput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataInput() - Constructor for class org.apache.lucene.store.ByteArrayDataInput
 
ByteArrayDataOutput - Class in org.apache.lucene.store
DataOutput backed by a byte array.
ByteArrayDataOutput(byte[]) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput(byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
ByteArrayDataOutput() - Constructor for class org.apache.lucene.store.ByteArrayDataOutput
 
byteAt(int) - Method in class org.apache.lucene.index.Payload
Returns the byte at the given index.
ByteBlockPool - Class in org.apache.lucene.util
Class that Posting and PostingVector use to write byte streams into shared fixed-size byte[] arrays.
ByteBlockPool(ByteBlockPool.Allocator) - Constructor for class org.apache.lucene.util.ByteBlockPool
 
ByteBlockPool.Allocator - Class in org.apache.lucene.util
Abstract class for allocating and freeing byte blocks.
ByteBlockPool.Allocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.Allocator
 
ByteBlockPool.DirectAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles.
ByteBlockPool.DirectAllocator() - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
ByteBlockPool.DirectAllocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
 
ByteBlockPool.DirectTrackingAllocator - Class in org.apache.lucene.util
A simple ByteBlockPool.Allocator that never recycles, but tracks how much total RAM is in use.
ByteBlockPool.DirectTrackingAllocator(AtomicLong) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
ByteBlockPool.DirectTrackingAllocator(int, AtomicLong) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
ByteFieldSource - Class in org.apache.lucene.search.function
Expert: obtains single byte field values from the FieldCache using getBytes() and makes those values available as other numeric types, casting as needed.
ByteFieldSource(String) - Constructor for class org.apache.lucene.search.function.ByteFieldSource
Create a cached byte field source with default string-to-byte parser.
ByteFieldSource(String, FieldCache.ByteParser) - Constructor for class org.apache.lucene.search.function.ByteFieldSource
Create a cached byte field source with a specific string-to-byte parser.
byteOffset - Variable in class org.apache.lucene.util.ByteBlockPool
 
bytes - Variable in class org.apache.lucene.util.BytesRef
The contents of the BytesRef.
bytes - Variable in class org.apache.lucene.util.fst.FST.BytesReader
 
bytesDifference(byte[], int, byte[], int) - Static method in class org.apache.lucene.util.StringHelper
Compares two byte[] arrays, element by element, and returns the number of elements common to both arrays.
bytesEquals(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Expert: compares the bytes against another BytesRef, returning true if the bytes are equal.
ByteSequenceOutputs - Class in org.apache.lucene.util.fst
An FST Outputs implementation where each output is a sequence of bytes.
BytesRef - Class in org.apache.lucene.util
Represents byte[], as a slice (offset + length) into an existing byte[].
BytesRef() - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef with BytesRef.EMPTY_BYTES
BytesRef(byte[], int, int) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(byte[]) - Constructor for class org.apache.lucene.util.BytesRef
This instance will directly reference bytes w/o making a copy.
BytesRef(int) - Constructor for class org.apache.lucene.util.BytesRef
Create a BytesRef pointing to a new array of size capacity.
BytesRef(CharSequence) - Constructor for class org.apache.lucene.util.BytesRef
Initialize the byte[] from the UTF8 bytes for the provided String.
BytesRefFSTEnum<T> - Class in org.apache.lucene.util.fst
Enumerates all input (BytesRef) + output pairs in an FST.
BytesRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum
doFloor controls the behavior of advance: if it's true doFloor is true, advance positions to the biggest term before target.
BytesRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
Holds a single input (BytesRef) + output pair.
BytesRefFSTEnum.InputOutput() - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
 
BytesRefHash - Class in org.apache.lucene.util
BytesRefHash is a special purpose hash-map like data-structure optimized for BytesRef instances.
BytesRefHash() - Constructor for class org.apache.lucene.util.BytesRefHash
BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.BytesRefHash
Creates a new BytesRefHash
BytesRefHash.BytesStartArray - Class in org.apache.lucene.util
Manages allocation of the per-term addresses.
BytesRefHash.BytesStartArray() - Constructor for class org.apache.lucene.util.BytesRefHash.BytesStartArray
 
BytesRefHash.DirectBytesStartArray - Class in org.apache.lucene.util
A simple BytesRefHash.BytesStartArray that tracks memory allocation using a private AtomicLong instance.
BytesRefHash.DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
Thrown if a BytesRef exceeds the BytesRefHash limit of ByteBlockPool.BYTE_BLOCK_SIZE-2.
BytesRefHash.TrackingDirectBytesStartArray - Class in org.apache.lucene.util
A simple BytesRefHash.BytesStartArray that tracks all memory allocation using a shared AtomicLong instance.
BytesRefHash.TrackingDirectBytesStartArray(int, AtomicLong) - Constructor for class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
BytesRefIterator - Interface in org.apache.lucene.util
A simple iterator interface for BytesRef iteration.
byteStart(int) - Method in class org.apache.lucene.util.BytesRefHash
Returns the bytesStart offset into the internally used ByteBlockPool for the given ord
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
A AtomicLong reference holding the number of bytes used by this BytesRefHash.BytesStartArray.
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
bytesUsed - Variable in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
bytesUsed() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
byteToFloat(byte, int, int) - Static method in class org.apache.lucene.util.SmallFloat
Converts an 8 bit float to a 32 bit float.
byteUpto - Variable in class org.apache.lucene.util.ByteBlockPool
 

C

cache - Variable in class org.apache.lucene.search.CachingWrapperFilter
 
cache - Variable in class org.apache.lucene.search.FilterManager
Deprecated.
The cache itself
cacheCleanSize - Variable in class org.apache.lucene.search.FilterManager
Deprecated.
Maximum allowed cache size
cachedDocs - Variable in class org.apache.lucene.search.CachingCollector
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.ByteFieldSource
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.FieldCacheSource
Check if equals to another FieldCacheSource, already knowing that cache and field are equal.
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.FloatFieldSource
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.IntFieldSource
 
cachedFieldSourceEquals(FieldCacheSource) - Method in class org.apache.lucene.search.function.ShortFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.ByteFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.FieldCacheSource
Return a hash code of a FieldCacheSource, without the hash-codes of the field and the cache (those are taken care of elsewhere).
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.FloatFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.IntFieldSource
 
cachedFieldSourceHashCode() - Method in class org.apache.lucene.search.function.ShortFieldSource
 
cachedSegs - Variable in class org.apache.lucene.search.CachingCollector
 
CachingCollector - Class in org.apache.lucene.search
Caches all docs, and optionally also scores, coming from a search, and is then able to replay them to another collector.
CachingSpanFilter - Class in org.apache.lucene.search
Wraps another SpanFilter's result and caches it.
CachingSpanFilter(SpanFilter) - Constructor for class org.apache.lucene.search.CachingSpanFilter
New deletions always result in a cache miss, by default (CachingWrapperFilter.DeletesMode.RECACHE.
CachingSpanFilter(SpanFilter, CachingWrapperFilter.DeletesMode) - Constructor for class org.apache.lucene.search.CachingSpanFilter
 
CachingTokenFilter - Class in org.apache.lucene.analysis
This class can be used if the token attributes of a TokenStream are intended to be consumed more than once.
CachingTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.CachingTokenFilter
 
CachingWrapperFilter - Class in org.apache.lucene.search
Wraps another filter's result and caches it.
CachingWrapperFilter(Filter) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
New deletes are ignored by default, which gives higher cache hit rate on reopened readers.
CachingWrapperFilter(Filter, CachingWrapperFilter.DeletesMode) - Constructor for class org.apache.lucene.search.CachingWrapperFilter
Expert: by default, the cached filter will be shared across reopened segments that only had changes to their deletions.
CachingWrapperFilter.DeletesMode - Enum in org.apache.lucene.search
Expert: Specifies how new deletions against a reopened reader should be handled.
calibrateSizeByDeletes - Variable in class org.apache.lucene.index.LogMergePolicy
 
cantOpenSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
True if we were unable to open the segments_N file.
capacity() - Method in class org.apache.lucene.util.OpenBitSet
Returns the current capacity in bits (1 greater than the index of the last bit)
captureState() - Method in class org.apache.lucene.util.AttributeSource
Captures the state of all Attributes.
CARAT - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
cardinality() - Method in class org.apache.lucene.util.FixedBitSet
Returns number of set bits.
cardinality() - Method in class org.apache.lucene.util.OpenBitSet
 
changed() - Method in class org.apache.lucene.index.SegmentInfos
Call this before committing if changes have been made to the segments.
CharacterUtils - Class in org.apache.lucene.util
CharacterUtils provides a unified interface to Character-related operations to implement backwards compatible character operations based on a Version instance.
CharacterUtils() - Constructor for class org.apache.lucene.util.CharacterUtils
 
CharacterUtils.CharacterBuffer - Class in org.apache.lucene.util
A simple IO buffer to use with CharacterUtils.fill(CharacterBuffer, Reader).
CharArrayMap<V> - Class in org.apache.lucene.analysis
A simple class that stores key Strings as char[]'s in a hash table.
CharArrayMap(Version, int, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
Create map with enough capacity to hold startSize terms
CharArrayMap(Version, Map<?, ? extends V>, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
Creates a map from the mappings in another map.
CharArrayMap.EntryIterator - Class in org.apache.lucene.analysis
public iterator class so efficient methods are exposed to users
CharArrayMap.EntrySet - Class in org.apache.lucene.analysis
public EntrySet class so efficient methods are exposed to users
CharArraySet - Class in org.apache.lucene.analysis
A simple class that stores Strings as char[]'s in a hash table.
CharArraySet(Version, int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
Create set with enough capacity to hold startSize terms
CharArraySet(Version, Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
Creates a set from a Collection of objects.
CharArraySet(int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
CharArraySet(Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
CharArraySet.CharArraySetIterator - Class in org.apache.lucene.analysis
Deprecated.
Use the standard iterator, which returns char[] instances.
charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
charAt(int) - Method in class org.apache.lucene.util.CharsRef
 
CharFilter - Class in org.apache.lucene.analysis
Subclasses of CharFilter can be chained to filter CharStream.
CharFilter(CharStream) - Constructor for class org.apache.lucene.analysis.CharFilter
 
CharReader - Class in org.apache.lucene.analysis
CharReader is a Reader wrapper.
chars - Variable in class org.apache.lucene.util.CharsRef
 
charsEquals(CharsRef) - Method in class org.apache.lucene.util.CharsRef
 
CHARSET_UTF_8 - Static variable in class org.apache.lucene.util.IOUtils
UTF-8 Charset instance to prevent repeated Charset.forName(String) lookups
CharsRef - Class in org.apache.lucene.util
Represents char[], as a slice (offset + length) into an existing char[].
CharsRef() - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized an empty array zero-length
CharsRef(int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with an array of the given capacity
CharsRef(char[], int, int) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given array, offset and length
CharsRef(String) - Constructor for class org.apache.lucene.util.CharsRef
Creates a new CharsRef initialized with the given Strings character array
CharStream - Class in org.apache.lucene.analysis
CharStream adds CharStream.correctOffset(int) functionality over Reader.
CharStream() - Constructor for class org.apache.lucene.analysis.CharStream
 
CharStream - Interface in org.apache.lucene.queryParser
This interface describes a character stream that maintains line and column number positions of the characters.
CharTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
The term text of a Token.
CharTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
The term text of a Token.
CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
CharTokenizer - Class in org.apache.lucene.analysis
An abstract base class for simple, character-oriented tokenizers.
CharTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Creates a new CharTokenizer instance
CharTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Creates a new CharTokenizer instance
CharTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Creates a new CharTokenizer instance
CharTokenizer(Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Deprecated.
use CharTokenizer.CharTokenizer(Version, Reader) instead. This will be removed in Lucene 4.0.
CharTokenizer(AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Deprecated.
use CharTokenizer.CharTokenizer(Version, AttributeSource, Reader) instead. This will be removed in Lucene 4.0.
CharTokenizer(AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.CharTokenizer
Deprecated.
check(FieldCache.CacheEntry...) - Method in class org.apache.lucene.util.FieldCacheSanityChecker
Tests a CacheEntry[] for indication of "insane" cache usage.
checkHeader(DataInput, String, int, int) - Static method in class org.apache.lucene.util.CodecUtil
 
CheckIndex - Class in org.apache.lucene.index
Basic tool and API to check the health of an index and write a new segments file that removes reference to problematic segments.
CheckIndex(Directory) - Constructor for class org.apache.lucene.index.CheckIndex
Create a new CheckIndex on the directory.
checkIndex() - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
checkIndex(List<String>) - Method in class org.apache.lucene.index.CheckIndex
Returns a CheckIndex.Status instance detailing the state of the index.
CheckIndex.Status - Class in org.apache.lucene.index
Returned from CheckIndex.checkIndex() detailing the health and status of the index.
CheckIndex.Status() - Constructor for class org.apache.lucene.index.CheckIndex.Status
 
CheckIndex.Status.FieldNormStatus - Class in org.apache.lucene.index
Status from testing field norms.
CheckIndex.Status.FieldNormStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
 
CheckIndex.Status.SegmentInfoStatus - Class in org.apache.lucene.index
Holds the status of each segment in the index.
CheckIndex.Status.SegmentInfoStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
 
CheckIndex.Status.StoredFieldStatus - Class in org.apache.lucene.index
Status from testing stored fields.
CheckIndex.Status.StoredFieldStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
 
CheckIndex.Status.TermIndexStatus - Class in org.apache.lucene.index
Status from testing term index.
CheckIndex.Status.TermIndexStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
 
CheckIndex.Status.TermVectorStatus - Class in org.apache.lucene.index
Status from testing stored fields.
CheckIndex.Status.TermVectorStatus() - Constructor for class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
 
checkSanity(FieldCache) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
Quick and dirty convenience method
checkSanity(FieldCache.CacheEntry...) - Static method in class org.apache.lucene.util.FieldCacheSanityChecker
Quick and dirty convenience method that instantiates an instance with "good defaults" and uses it to test the CacheEntrys
checkSnapshotted(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Checks if the given id is already used by another snapshot, and throws IllegalStateException if it is.
ChecksumIndexInput - Class in org.apache.lucene.store
Writes bytes through to a primary IndexOutput, computing checksum as it goes.
ChecksumIndexInput(IndexInput) - Constructor for class org.apache.lucene.store.ChecksumIndexInput
 
ChecksumIndexOutput - Class in org.apache.lucene.store
Writes bytes through to a primary IndexOutput, computing checksum.
ChecksumIndexOutput(IndexOutput) - Constructor for class org.apache.lucene.store.ChecksumIndexOutput
 
chunkSize - Variable in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
CJ - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
CJ - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
ClassicAnalyzer - Class in org.apache.lucene.analysis.standard
Filters ClassicTokenizer with ClassicFilter, LowerCaseFilter and StopFilter, using a list of English stop words.
ClassicAnalyzer(Version, Set<?>) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
Builds an analyzer with the given stop words.
ClassicAnalyzer(Version) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
Builds an analyzer with the default stop words (ClassicAnalyzer.STOP_WORDS_SET).
ClassicAnalyzer(Version, File) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
ClassicAnalyzer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
Builds an analyzer with the stop words from the given reader.
ClassicFilter - Class in org.apache.lucene.analysis.standard
Normalizes tokens extracted with ClassicTokenizer.
ClassicFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.standard.ClassicFilter
Construct filtering in.
ClassicTokenizer - Class in org.apache.lucene.analysis.standard
A grammar-based tokenizer constructed with JFlex This should be a good tokenizer for most European-language documents: Splits words at punctuation characters, removing punctuation.
ClassicTokenizer(Version, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
Creates a new instance of the ClassicTokenizer.
ClassicTokenizer(Version, AttributeSource, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
Creates a new ClassicTokenizer with a given AttributeSource.
ClassicTokenizer(Version, AttributeSource.AttributeFactory, Reader) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
Creates a new ClassicTokenizer with a given AttributeSource.AttributeFactory
Clause(String) - Method in class org.apache.lucene.queryParser.QueryParser
 
clauses() - Method in class org.apache.lucene.search.BooleanQuery
Returns the list of clauses in this query.
clauses - Variable in class org.apache.lucene.search.spans.SpanNearQuery
 
clean - Variable in class org.apache.lucene.index.CheckIndex.Status
True if no problems were found with the index.
cleanSleepTime - Variable in class org.apache.lucene.search.FilterManager
Deprecated.
Cache cleaning frequency
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.Token
Resets the term text, payload, flags, and positionIncrement, startOffset, endOffset and token type to default.
clear() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
clear() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
clear() - Method in class org.apache.lucene.index.SegmentInfos
 
clear() - Method in class org.apache.lucene.util.AttributeImpl
Clears the values in this AttributeImpl and resets it to its default value.
clear(int) - Method in class org.apache.lucene.util.BitVector
Sets the value of bit to zero.
clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
clears the BytesRefHash.BytesStartArray and returns the cleared instance.
clear(boolean) - Method in class org.apache.lucene.util.BytesRefHash
Clears the BytesRef which maps to the given BytesRef
clear() - Method in class org.apache.lucene.util.BytesRefHash
 
clear() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
clear() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
clear(int) - Method in class org.apache.lucene.util.FixedBitSet
 
clear(int, int) - Method in class org.apache.lucene.util.FixedBitSet
Clears a range of bits.
clear() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
clear() - Method in class org.apache.lucene.util.MapBackedSet
 
clear(long) - Method in class org.apache.lucene.util.OpenBitSet
clears a bit, allowing access beyond the current set size without changing the size.
clear(int, int) - Method in class org.apache.lucene.util.OpenBitSet
Clears a range of bits.
clear(long, long) - Method in class org.apache.lucene.util.OpenBitSet
Clears a range of bits.
clear() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
clear() - Method in interface org.apache.lucene.util.packed.PackedInts.Mutable
Sets all values to 0.
clear() - Method in class org.apache.lucene.util.PriorityQueue
Removes all entries from the PriorityQueue.
clear() - Method in class org.apache.lucene.util.ScorerDocQueue
Deprecated.
Removes all entries from the ScorerDocQueue.
clear() - Method in class org.apache.lucene.util.WeakIdentityMap
 
clearAttributes() - Method in class org.apache.lucene.util.AttributeSource
Resets all Attributes in this AttributeSource by calling AttributeImpl.clear() on each Attribute implementation.
clearLock(String) - Method in class org.apache.lucene.store.Directory
Attempt to clear (forcefully unlock and remove) the specified lock.
clearLock(String) - Method in class org.apache.lucene.store.LockFactory
Attempt to clear (forcefully unlock and remove) the specified lock.
clearLock(String) - Method in class org.apache.lucene.store.NativeFSLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.NoLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
clearLock(String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
 
clearLock(String) - Method in class org.apache.lucene.store.VerifyingLockFactory
 
clearTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQuery
Deprecated.
Don't use this method, as its not thread safe and useless.
clearTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
Don't use this method, as its not thread safe and useless.
clearUnhandledExceptions() - Static method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
clone() - Method in class org.apache.lucene.analysis.Token
 
clone(char[], int, int, int, int) - Method in class org.apache.lucene.analysis.Token
Makes a clone, but replaces the term buffer & start/end offset in the process.
clone() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
clone() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
clone() - Method in class org.apache.lucene.index.FieldInfo
 
clone() - Method in class org.apache.lucene.index.FieldInfos
Returns a deep clone of this FieldInfos instance.
clone() - Method in class org.apache.lucene.index.IndexReader
Efficiently clones the IndexReader (sharing most internal state).
clone(boolean) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. Use IndexReader.clone() instead.
clone() - Method in class org.apache.lucene.index.IndexWriterConfig
 
clone() - Method in class org.apache.lucene.index.MultiReader
 
clone(boolean) - Method in class org.apache.lucene.index.MultiReader
Deprecated.
Write support will be removed in Lucene 4.0. Use MultiReader.clone() instead.
clone() - Method in class org.apache.lucene.index.ParallelReader
 
clone(boolean) - Method in class org.apache.lucene.index.ParallelReader
Deprecated.
Write support will be removed in Lucene 4.0. Use ParallelReader.clone() instead.
clone() - Method in class org.apache.lucene.index.Payload
Clones this payload by creating a copy of the underlying byte array.
clone() - Method in class org.apache.lucene.index.SegmentInfo
 
clone() - Method in class org.apache.lucene.index.SegmentInfos
Returns a copy of this instance, also copying each SegmentInfo.
clone() - Method in class org.apache.lucene.index.SegmentReader
 
clone(boolean) - Method in class org.apache.lucene.index.SegmentReader
Deprecated.
clone() - Method in class org.apache.lucene.search.BooleanQuery
 
clone() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create a shallow copy of us -- used in rewriting if necessary
clone() - Method in class org.apache.lucene.search.function.CustomScoreQuery
 
clone() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
clone() - Method in class org.apache.lucene.search.Query
Returns a clone of this query.
clone() - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
clone() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
clone() - Method in class org.apache.lucene.store.BufferedIndexInput
 
clone() - Method in class org.apache.lucene.store.DataInput
Returns a clone of this stream.
clone() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
clone() - Method in class org.apache.lucene.util.AttributeImpl
Shallow clone.
clone() - Method in class org.apache.lucene.util.AttributeSource.State
 
clone() - Method in class org.apache.lucene.util.BitVector
 
clone() - Method in class org.apache.lucene.util.BytesRef
 
clone() - Method in class org.apache.lucene.util.CharsRef
 
clone() - Method in class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
 
clone() - Method in class org.apache.lucene.util.FixedBitSet
 
clone() - Method in class org.apache.lucene.util.IntsRef
 
clone() - Method in class org.apache.lucene.util.OpenBitSet
 
clone() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
 
cloneAttributes() - Method in class org.apache.lucene.util.AttributeSource
Performs a clone of all AttributeImpl instances returned in a new AttributeSource instance.
cloneDeletedDocs(BitVector) - Method in class org.apache.lucene.index.SegmentReader
Deprecated. 
cloneNormBytes(byte[]) - Method in class org.apache.lucene.index.SegmentReader
Deprecated. 
close() - Method in class org.apache.lucene.analysis.Analyzer
Frees persistent resources used by this Analyzer
close() - Method in class org.apache.lucene.analysis.CharFilter
 
close() - Method in class org.apache.lucene.analysis.CharReader
 
close() - Method in class org.apache.lucene.analysis.TokenFilter
Close the input TokenStream.
close() - Method in class org.apache.lucene.analysis.Tokenizer
By default, closes the input Reader.
close() - Method in class org.apache.lucene.analysis.TokenStream
Releases resources associated with this stream.
close() - Method in class org.apache.lucene.index.AbstractAllTermDocs
 
close() - Method in class org.apache.lucene.index.CompoundFileWriter
Merge files with the extensions added up to now.
close() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
close() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
 
close() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
 
close() - Method in class org.apache.lucene.index.IndexReader
Closes files associated with this index.
close() - Method in class org.apache.lucene.index.IndexWriter
Commits all changes to an index and closes all associated files.
close(boolean) - Method in class org.apache.lucene.index.IndexWriter
Closes the index with or without waiting for currently running merges to finish.
close() - Method in class org.apache.lucene.index.LogMergePolicy
 
close() - Method in class org.apache.lucene.index.MergePolicy
Release all resources for the policy.
close() - Method in class org.apache.lucene.index.MergeScheduler
Close this MergeScheduler.
close() - Method in class org.apache.lucene.index.MultipleTermPositions
 
close() - Method in class org.apache.lucene.index.NoMergePolicy
 
close() - Method in class org.apache.lucene.index.NoMergeScheduler
 
close() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
Closes the index which writes the snapshots to the directory.
close() - Method in class org.apache.lucene.index.SerialMergeScheduler
 
close() - Method in interface org.apache.lucene.index.TermDocs
Frees associated resources.
close() - Method in class org.apache.lucene.index.TermEnum
Closes the enumeration to further activity, freeing resources.
close() - Method in class org.apache.lucene.index.TieredMergePolicy
 
close() - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
close() - Method in class org.apache.lucene.search.FilteredTermEnum
Closes the enumeration to further activity, freeing resources.
close() - Method in class org.apache.lucene.search.FuzzyTermEnum
Closes the enumeration to further activity, freeing resources.
close() - Method in class org.apache.lucene.search.IndexSearcher
Note that the underlying IndexReader is not closed, if IndexSearcher was constructed with IndexSearcher(IndexReader r).
close() - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
 
close() - Method in class org.apache.lucene.search.NRTManagerReopenThread
 
close() - Method in class org.apache.lucene.search.ParallelMultiSearcher
Deprecated.
 
close() - Method in class org.apache.lucene.search.ReferenceManager
Close this ReferenceManager to future acquiring.
close() - Method in interface org.apache.lucene.search.Searchable
Deprecated.
Frees resources associated with this Searcher.
close() - Method in class org.apache.lucene.search.Searcher
Deprecated.
 
close() - Method in class org.apache.lucene.search.SearcherLifetimeManager
Close this to future searching; any searches still in process in other threads won't be affected, and they should still call SearcherLifetimeManager.release(org.apache.lucene.search.IndexSearcher) after they are done.
close() - Method in class org.apache.lucene.store.BufferedIndexOutput
Closes this stream to further operations.
close() - Method in class org.apache.lucene.store.ChecksumIndexInput
 
close() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
close() - Method in class org.apache.lucene.store.Directory
Closes the store.
close() - Method in class org.apache.lucene.store.FileSwitchDirectory
 
close() - Method in class org.apache.lucene.store.FSDirectory
Closes the store to future operations.
close() - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
 
close() - Method in class org.apache.lucene.store.IndexInput
Closes the stream to further operations.
close() - Method in class org.apache.lucene.store.IndexOutput
Closes this stream to further operations.
close() - Method in class org.apache.lucene.store.InputStreamDataInput
 
close() - Method in class org.apache.lucene.store.NIOFSDirectory.NIOFSIndexInput
 
close() - Method in class org.apache.lucene.store.NRTCachingDirectory
Close this directory, which flushes any cached files to the delegate and then closes the delegate.
close() - Method in class org.apache.lucene.store.OutputStreamDataOutput
 
close() - Method in class org.apache.lucene.store.RAMDirectory
Closes the store to future operations, releasing associated memory.
close() - Method in class org.apache.lucene.store.RAMInputStream
 
close() - Method in class org.apache.lucene.store.RAMOutputStream
 
close() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
close() - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput.Descriptor
 
close() - Method in class org.apache.lucene.util.BytesRefHash
Closes the BytesRefHash and releases all internally used memory
close() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
close(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables.
close(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
 
CloseableThreadLocal<T> - Class in org.apache.lucene.util
Java's builtin ThreadLocal has a serious flaw: it can take an arbitrarily long amount of time to dereference the things you had stored in it, even once the ThreadLocal instance itself is no longer referenced.
CloseableThreadLocal() - Constructor for class org.apache.lucene.util.CloseableThreadLocal
 
closeWhileHandlingException(E, Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(E, Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
 
closeWhileHandlingException(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
Closes all given Closeables, suppressing all thrown exceptions.
closeWhileHandlingException(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
 
CodecUtil - Class in org.apache.lucene.util
Utility class for reading and writing versioned headers.
codePointAt(char[], int) - Method in class org.apache.lucene.util.CharacterUtils
Returns the code point at the given index of the char array.
codePointAt(CharSequence, int) - Method in class org.apache.lucene.util.CharacterUtils
Returns the code point at the given index of the CharSequence.
codePointAt(char[], int, int) - Method in class org.apache.lucene.util.CharacterUtils
Returns the code point at the given index of the char array where only elements with index less than the limit are used.
CollationKeyAnalyzer - Class in org.apache.lucene.collation
CollationKeyAnalyzer(Collator) - Constructor for class org.apache.lucene.collation.CollationKeyAnalyzer
 
CollationKeyFilter - Class in org.apache.lucene.collation
Converts each token into its CollationKey, and then encodes the CollationKey with IndexableBinaryStringTools, to allow it to be stored as an index term.
CollationKeyFilter(TokenStream, Collator) - Constructor for class org.apache.lucene.collation.CollationKeyFilter
 
collect(int) - Method in class org.apache.lucene.search.Collector
Called once for every document matching a query, with the unbased document number.
collect(int) - Method in class org.apache.lucene.search.MultiCollector
 
collect(int) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
 
collect(int) - Method in class org.apache.lucene.search.TimeLimitingCollector
Calls Collector.collect(int) on the decorated Collector unless the allowed time has passed, in which case it throws an exception.
collect(int) - Method in class org.apache.lucene.search.TotalHitCountCollector
 
CollectionUtil - Class in org.apache.lucene.util
Methods for manipulating (sorting) collections.
Collector - Class in org.apache.lucene.search
Expert: Collectors are primarily meant to be used to gather raw results from a search, and implement sorting or custom result filtering, collation, etc.
Collector() - Constructor for class org.apache.lucene.search.Collector
 
COLON - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
combine(Query[]) - Method in class org.apache.lucene.search.Query
Expert: called when re-writing queries under MultiSearcher.
CommandLineUtil - Class in org.apache.lucene.util
Class containing some useful methods used by command line tools
commit() - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
commit(Map<String, String>) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
commit() - Method in class org.apache.lucene.index.IndexWriter
Commits all pending changes (added & deleted documents, segment merges, added indexes, etc.) to the index, and syncs all referenced index files, such that a reader will see the changes and the index updates will survive an OS or machine crash or power loss.
commit(Map<String, String>) - Method in class org.apache.lucene.index.IndexWriter
Commits all changes to the index, specifying a commitUserData Map (String -> String).
commit() - Method in interface org.apache.lucene.util.TwoPhaseCommit
The second phase of a 2-phase commit.
commit(Map<String, String>) - Method in interface org.apache.lucene.util.TwoPhaseCommit
Like TwoPhaseCommit.commit(), but takes an additional commit data to be included w/ the commit.
commit() - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
 
commit(Map<String, String>) - Method in class org.apache.lucene.util.TwoPhaseCommitTool.TwoPhaseCommitWrapper
 
common(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
common(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
common(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
 
common(T, T) - Method in class org.apache.lucene.util.fst.Outputs
Eg common("foo", "foobar") -> "foo"
common(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
 
common(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
common(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
compact() - Method in class org.apache.lucene.util.BytesRefHash
Returns the ords array in arbitrary order.
COMPANY - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
COMPANY - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
comparators - Variable in class org.apache.lucene.search.FieldValueHitQueue
 
compare(TermVectorEntry, TermVectorEntry) - Method in class org.apache.lucene.index.TermVectorEntryFreqSortedComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator
Compare hit at slot1 with hit at slot2.
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
compare(int, int) - Method in class org.apache.lucene.util.SorterTemplate
Compares slots i and j of you data.
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator
Compare the bottom of the queue with doc.
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
compareByMergeDocCount - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
 
compareImplementationDistance(Class<? extends C>, VirtualMethod<C>, VirtualMethod<C>) - Static method in class org.apache.lucene.util.VirtualMethod
Utility method that compares the implementation/override distance of two methods.
comparePivot(int) - Method in class org.apache.lucene.util.SorterTemplate
Implements the compare function for the previously stored pivot value.
compareTo(IndexCommit) - Method in class org.apache.lucene.index.IndexCommit
 
compareTo(Term) - Method in class org.apache.lucene.index.Term
Compares two terms, returning a negative integer if this term belongs before the argument, zero if this term is equal to the argument, and a positive integer if this term belongs after the argument.
compareTo(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Unsigned byte order comparison
compareTo(CharsRef) - Method in class org.apache.lucene.util.CharsRef
Signed int order comparison
compareTo(Util.MinResult<T>) - Method in class org.apache.lucene.util.fst.Util.MinResult
 
compareTo(IntsRef) - Method in class org.apache.lucene.util.IntsRef
Signed int order comparison
compareValues(T, T) - Method in class org.apache.lucene.search.FieldComparator
Returns -1 if first is less than second.
compareValues(Float, Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
compareValues(String, String) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
ComplexExplanation - Class in org.apache.lucene.search
Expert: Describes the score computation for document and query, and can distinguish a match independent of a positive value.
ComplexExplanation() - Constructor for class org.apache.lucene.search.ComplexExplanation
 
ComplexExplanation(boolean, float, String) - Constructor for class org.apache.lucene.search.ComplexExplanation
 
compound - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if segment is compound file format.
COMPOUND_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
File extensions of old-style index files
COMPOUND_FILE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of compound file
COMPOUND_FILE_STORE_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of compound file for doc store files
COMPOUND_FILES - Static variable in class org.apache.lucene.index.NoMergePolicy
A singleton NoMergePolicy which indicates the index uses compound files.
CompoundFileWriter - Class in org.apache.lucene.index
Combines multiple files into a single compound file.
CompoundFileWriter(Directory, String) - Constructor for class org.apache.lucene.index.CompoundFileWriter
Create the compound stream in the specified file.
compress(byte[], int, int, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the specified byte range using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
compress(byte[], int, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the specified byte range, with default BEST_COMPRESSION level
compress(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
Compresses all bytes in the array, with default BEST_COMPRESSION level
CompressionTools - Class in org.apache.lucene.document
Simple utility class providing static methods to compress and decompress binary data for stored fields.
compressString(String) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the String value, with default BEST_COMPRESSION level
compressString(String, int) - Static method in class org.apache.lucene.document.CompressionTools
Compresses the String value using the specified compressionLevel (constants are defined in java.util.zip.Deflater).
computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.DefaultSimilarity
Implemented as state.getBoost()*lengthNorm(numTerms), where numTerms is FieldInvertState.getLength() if DefaultSimilarity.setDiscountOverlaps(boolean) is false, else it's FieldInvertState.getLength() - FieldInvertState.getNumOverlap().
computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.Similarity
Computes the normalization value for a field, given the accumulated state of term processing for this field (see FieldInvertState).
computeNorm(String, FieldInvertState) - Method in class org.apache.lucene.search.SimilarityDelegator
Deprecated.
 
ConcurrentMergeScheduler - Class in org.apache.lucene.index
A MergeScheduler that runs each merge using a separate thread.
ConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler
 
ConcurrentMergeScheduler.MergeThread - Class in org.apache.lucene.index
 
ConcurrentMergeScheduler.MergeThread(IndexWriter, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
 
Conjunction() - Method in class org.apache.lucene.queryParser.QueryParser
 
CONSTANT_SCORE_AUTO_REWRITE_DEFAULT - Static variable in class org.apache.lucene.search.MultiTermQuery
Read-only default instance of MultiTermQuery.ConstantScoreAutoRewrite, with ConstantScoreAutoRewrite.setTermCountCutoff(int) set to ConstantScoreAutoRewrite.DEFAULT_TERM_COUNT_CUTOFF and ConstantScoreAutoRewrite.setDocCountPercent(double) set to ConstantScoreAutoRewrite.DEFAULT_DOC_COUNT_PERCENT.
CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
Like MultiTermQuery.SCORING_BOOLEAN_QUERY_REWRITE except scores are not computed.
CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
Like ScoringRewrite.SCORING_BOOLEAN_QUERY_REWRITE except scores are not computed.
CONSTANT_SCORE_FILTER_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
A rewrite method that first creates a private Filter, by visiting each term in sequence and marking all docs for that term.
Constants - Class in org.apache.lucene.util
Some useful constants.
ConstantScoreQuery - Class in org.apache.lucene.search
A query that wraps another query or a filter and simply returns a constant score equal to the query boost for every document that matches the filter or query.
ConstantScoreQuery(Query) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Strips off scores from the passed in Query.
ConstantScoreQuery(Filter) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
Wraps a Filter as a Query.
ConstantScoreQuery.ConstantScorer - Class in org.apache.lucene.search
 
ConstantScoreQuery.ConstantScorer(Similarity, DocIdSetIterator, Weight) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
ConstantScoreQuery.ConstantWeight - Class in org.apache.lucene.search
 
ConstantScoreQuery.ConstantWeight(Searcher) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
 
consumeAllTokens() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
TeeSinkTokenFilter passes all tokens to the added sinks when itself is consumed.
contains(Object) - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
 
contains(char[], int, int) - Method in class org.apache.lucene.analysis.CharArraySet
true if the len chars of text starting at off are in the set
contains(CharSequence) - Method in class org.apache.lucene.analysis.CharArraySet
true if the CharSequence is in the set
contains(Object) - Method in class org.apache.lucene.analysis.CharArraySet
 
contains(SegmentInfo) - Method in class org.apache.lucene.index.SegmentInfos
 
contains(Object) - Method in class org.apache.lucene.util.MapBackedSet
 
containsKey(char[], int, int) - Method in class org.apache.lucene.analysis.CharArrayMap
true if the len chars of text starting at off are in the CharArrayMap.keySet
containsKey(CharSequence) - Method in class org.apache.lucene.analysis.CharArrayMap
true if the CharSequence is in the CharArrayMap.keySet
containsKey(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
 
containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
 
coord(int, int) - Method in class org.apache.lucene.search.DefaultSimilarity
Implemented as overlap / maxOverlap.
coord(int, int) - Method in class org.apache.lucene.search.Similarity
Computes a score factor based on the fraction of all query terms that a document contains.
coord(int, int) - Method in class org.apache.lucene.search.SimilarityDelegator
Deprecated.
 
copy(Version, Map<?, ? extends V>) - Static method in class org.apache.lucene.analysis.CharArrayMap
Returns a copy of the given map as a CharArrayMap.
copy(Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
Deprecated.
copy(Version, Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
Returns a copy of the given set as a CharArraySet.
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ByteComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator
This method is called when a new hit is competitive.
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.ShortComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringComparatorLocale
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.StringValComparator
 
copy(Directory, String, String) - Method in class org.apache.lucene.store.Directory
Copies the file src to Directory to under the new file name dest.
copy(Directory, Directory, boolean) - Static method in class org.apache.lucene.store.Directory
Deprecated.
should be replaced with calls to Directory.copy(Directory, String, String) for every file that needs copying. You can use the following code:
 IndexFileNameFilter filter = IndexFileNameFilter.getFilter();
 for (String file : src.listAll()) {
   if (filter.accept(null, file)) {
     src.copy(dest, file, file);
   }
 }
 
copy(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
Copies the given BytesRef at the current positions ( ByteBlockPool.byteUpto across buffer boundaries
copy(IndexInput, long) - Method in class org.apache.lucene.util.PagedBytes
Read this many bytes from in
copy(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy BytesRef in
copy(BytesRef, BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy BytesRef in, setting BytesRef out to the result.
copyBuffer(char[], int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
Copies the contents of buffer, starting at offset for length characters, into the termBuffer array.
copyBuffer(char[], int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
 
copyBytes(DataInput, long) - Method in class org.apache.lucene.store.DataOutput
Copy numBytes bytes from input to ourself.
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.IndexInput
Copies numBytes bytes to the given IndexOutput.
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.RAMInputStream
 
copyBytes(DataInput, long) - Method in class org.apache.lucene.store.RAMOutputStream
 
copyBytes(IndexOutput, long) - Method in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
copyBytes(BytesRef) - Method in class org.apache.lucene.util.BytesRef
Copies the bytes from the given BytesRef NOTE: if this would exceed the array size, this method creates a new reference array.
copyChars(CharSequence) - Method in class org.apache.lucene.util.BytesRef
Copies the UTF8 bytes for this string.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.BytesRef
Copies the UTF8 bytes for this string.
copyChars(CharsRef) - Method in class org.apache.lucene.util.CharsRef
Copies the given CharsRef referenced content into this instance.
copyChars(char[], int, int) - Method in class org.apache.lucene.util.CharsRef
Copies the given array into this CharsRef.
copyFrom(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
 
copyFrom(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST.Arc
Returns this
copyInts(IntsRef) - Method in class org.apache.lucene.util.IntsRef
 
copyText(UnicodeUtil.UTF16Result) - Method in class org.apache.lucene.util.UnicodeUtil.UTF16Result
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.Token
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
copyTo(byte[], int) - Method in class org.apache.lucene.index.Payload
Copies the payload data to a byte array.
copyTo(AttributeImpl) - Method in class org.apache.lucene.util.AttributeImpl
Copies the values from this Attribute into the passed-in target attribute.
copyTo(AttributeSource) - Method in class org.apache.lucene.util.AttributeSource
Copies the contents of this AttributeSource to the given target AttributeSource.
copyUsingLengthPrefix(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
Copy bytes in, writing the length as a 1 or 2 byte vInt prefix.
correct(int) - Method in class org.apache.lucene.analysis.BaseCharFilter
Retrieve the corrected offset.
correct(int) - Method in class org.apache.lucene.analysis.CharFilter
Subclass may want to override to correct the current offset.
correctOffset(int) - Method in class org.apache.lucene.analysis.CharFilter
Chains the corrected offset through the input CharFilter.
correctOffset(int) - Method in class org.apache.lucene.analysis.CharReader
 
correctOffset(int) - Method in class org.apache.lucene.analysis.CharStream
Called by CharFilter(s) and Tokenizer to correct token offset.
correctOffset(int) - Method in class org.apache.lucene.analysis.Tokenizer
Return the corrected offset.
CorruptIndexException - Exception in org.apache.lucene.index
This exception is thrown when Lucene detects an inconsistency in the index.
CorruptIndexException(String) - Constructor for exception org.apache.lucene.index.CorruptIndexException
 
count - Variable in class org.apache.lucene.search.spans.TermSpans
 
count() - Method in class org.apache.lucene.util.BitVector
Returns the total number of one bits in this vector.
counter - Variable in class org.apache.lucene.index.SegmentInfos
 
Counter - Class in org.apache.lucene.util
Simple counter class
Counter() - Constructor for class org.apache.lucene.util.Counter
 
cp - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
create(boolean, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
Creates a CachingCollector which does not wrap another collector.
create(Collector, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
Create a new CachingCollector that wraps the given collector and caches documents and scores up to the specified RAM threshold.
create(Collector, boolean, int) - Static method in class org.apache.lucene.search.CachingCollector
Create a new CachingCollector that wraps the given collector and caches documents and scores up to the specified max docs threshold.
create(SortField[], int) - Static method in class org.apache.lucene.search.FieldValueHitQueue
Creates a hit queue sorted by the given list of fields.
create(Sort, int, boolean, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
Creates a new TopFieldCollector from the given arguments.
create(int, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect and whether documents are scored in order by the input Scorer to TopScoreDocCollector.setScorer(Scorer).
create(int, ScoreDoc, boolean) - Static method in class org.apache.lucene.search.TopScoreDocCollector
Creates a new TopScoreDocCollector given the number of hits to collect, the bottom of the previous page, and whether documents are scored in order by the input Scorer to TopScoreDocCollector.setScorer(Scorer).
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
 
createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource.AttributeFactory
returns an AttributeImpl for the supplied Attribute interface class.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.KeywordAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase
Creates a new ReusableAnalyzerBase.TokenStreamComponents instance for this analyzer.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.SimpleAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
 
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.StopAnalyzer
Creates ReusableAnalyzerBase.TokenStreamComponents used to tokenize all the text in the provided Reader.
createComponents(String, Reader) - Method in class org.apache.lucene.analysis.WhitespaceAnalyzer
 
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.IndexSearcher
Creates a normalized weight for a top-level Query.
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
Create weight in multiple index scenario.
createNormalizedWeight(Query) - Method in class org.apache.lucene.search.Searcher
Deprecated.
Creates a normalized weight for a top-level Query.
createOutput(String) - Method in class org.apache.lucene.store.Directory
Creates a new, empty file in the directory with the given name.
createOutput(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.FSDirectory
Creates an IndexOutput for the file with the given name.
createOutput(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
createOutput(String) - Method in class org.apache.lucene.store.RAMDirectory
Creates a new, empty file in the directory with the given name.
createTerm(String) - Method in class org.apache.lucene.index.Term
Optimized construction of new Terms by reusing same field as this Term - avoids field.intern() overhead
createWeight(Searcher) - Method in class org.apache.lucene.search.BooleanQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Create the Weight used to score us
createWeight(Searcher) - Method in class org.apache.lucene.search.FilteredQuery
Returns a Weight that applies the filter to the enclosed query's Weight.
createWeight(Searcher) - Method in class org.apache.lucene.search.function.CustomScoreQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.function.ValueSourceQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.PhraseQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.Query
Expert: Constructs an appropriate Weight implementation for this query.
createWeight(Query) - Method in class org.apache.lucene.search.Searcher
Deprecated.
never ever use this method in Weight implementations. Subclasses of Searcher should use Searcher.createNormalizedWeight(org.apache.lucene.search.Query), instead.
createWeight(Searcher) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.spans.SpanQuery
 
createWeight(Searcher) - Method in class org.apache.lucene.search.TermQuery
 
curChar - Variable in class org.apache.lucene.queryParser.QueryParserTokenManager
 
curDocs - Variable in class org.apache.lucene.search.CachingCollector
 
current - Variable in class org.apache.lucene.search.ReferenceManager
 
current() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
current() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
CURRENT_FORMAT - Static variable in class org.apache.lucene.index.SegmentInfos
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
Calculate the score up to this point for this doc and field
currentTerm - Variable in class org.apache.lucene.search.FilteredTermEnum
the current term
currentToken - Variable in exception org.apache.lucene.queryParser.ParseException
This is the last token that has been consumed successfully.
currentValue() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
returns the value associated with the last key returned
CUSTOM - Static variable in class org.apache.lucene.search.SortField
Sort using a custom Comparator.
customExplain(int, Explanation, Explanation[]) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Explain the custom score.
customExplain(int, Explanation, Explanation) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Explain the custom score.
customScore(int, float, float[]) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Compute a custom score by the subQuery score and a number of ValueSourceQuery scores.
customScore(int, float, float) - Method in class org.apache.lucene.search.function.CustomScoreProvider
Compute a custom score by the subQuery score and the ValueSourceQuery score.
CustomScoreProvider - Class in org.apache.lucene.search.function
An instance of this subclass should be returned by CustomScoreQuery.getCustomScoreProvider(org.apache.lucene.index.IndexReader), if you want to modify the custom score calculation of a CustomScoreQuery.
CustomScoreProvider(IndexReader) - Constructor for class org.apache.lucene.search.function.CustomScoreProvider
Creates a new instance of the provider class for the given IndexReader.
CustomScoreQuery - Class in org.apache.lucene.search.function
Query that sets document score as a programmatic function of several (sub) scores: the score of its subQuery (any query) (optional) the score of its ValueSourceQuery (or queries).
CustomScoreQuery(Query) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
Create a CustomScoreQuery over input subQuery.
CustomScoreQuery(Query, ValueSourceQuery) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
Create a CustomScoreQuery over input subQuery and a ValueSourceQuery.
CustomScoreQuery(Query, ValueSourceQuery...) - Constructor for class org.apache.lucene.search.function.CustomScoreQuery
Create a CustomScoreQuery over input subQuery and a ValueSourceQuery.

D

data - Variable in class org.apache.lucene.index.Payload
the byte array containing the payload data
DataInput - Class in org.apache.lucene.store
Abstract base class for performing read operations of Lucene's low-level data types.
DataInput() - Constructor for class org.apache.lucene.store.DataInput
 
DataOutput - Class in org.apache.lucene.store
Abstract base class for performing write operations of Lucene's low-level data types.
DataOutput() - Constructor for class org.apache.lucene.store.DataOutput
 
DateField - Class in org.apache.lucene.document
Deprecated.
If you build a new index, use DateTools or NumericField instead. This class is included for use with existing indices and will be removed in a future release (possibly Lucene 4.0).
DateTools - Class in org.apache.lucene.document
Provides support for converting dates to strings and vice-versa.
DateTools.Resolution - Enum in org.apache.lucene.document
Specifies the time granularity.
dateToString(Date) - Static method in class org.apache.lucene.document.DateField
Deprecated.
Converts a Date to a string suitable for indexing.
dateToString(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
Converts a Date to a string suitable for indexing.
debugStream - Variable in class org.apache.lucene.queryParser.QueryParserTokenManager
Debug output.
decode(CharBuffer, ByteBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.decode(char[], int, int, byte[], int, int) instead. This method will be removed in Lucene 4.0
decode(char[], int, int, byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Decodes the input char sequence into the output byte sequence.
decode(CharBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.decode(char[], int, int, byte[], int, int) instead. This method will be removed in Lucene 4.0
decodeNorm(byte) - Static method in class org.apache.lucene.search.Similarity
Deprecated.
decodeNormValue(byte) - Method in class org.apache.lucene.search.Similarity
Decodes a normalization factor stored in an index.
decompress(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
Decompress the byte array previously returned by compress
decompressString(byte[]) - Static method in class org.apache.lucene.document.CompressionTools
Decompress the byte array previously returned by compressString back into a String
decRef() - Method in class org.apache.lucene.index.IndexReader
Expert: decreases the refCount of this IndexReader instance.
decRef(IndexSearcher) - Method in class org.apache.lucene.search.NRTManager
 
decRef(G) - Method in class org.apache.lucene.search.ReferenceManager
Decrement reference counting on the given reference.
decRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
 
deepCopyOf(BytesRef) - Static method in class org.apache.lucene.util.BytesRef
Creates a new BytesRef that points to a copy of the bytes from other The returned BytesRef will have a length of other.length and an offset of zero.
deepCopyOf(CharsRef) - Static method in class org.apache.lucene.util.CharsRef
Creates a new CharsRef that points to a copy of the chars from other The returned CharsRef will have a length of other.length and an offset of zero.
deepCopyOf(IntsRef) - Static method in class org.apache.lucene.util.IntsRef
Creates a new IntsRef that points to a copy of the ints from other The returned IntsRef will have a length of other.length and an offset of zero.
DEFAULT - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
Lexical state.
DEFAULT - Static variable in interface org.apache.lucene.search.FieldCache
Expert: The cache used internally by sorting and range query classes.
DEFAULT_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.util.AttributeSource.AttributeFactory
This is the default factory that creates AttributeImpls using the class name of the supplied Attribute interface class by appending Impl to it.
DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
DEFAULT_BYTE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for byte values, which are encoded by Byte.toString(byte)
DEFAULT_CACHE_CLEAN_SIZE - Static variable in class org.apache.lucene.search.FilterManager
Deprecated.
The default maximum number of Filters in the cache
DEFAULT_CACHE_SLEEP_TIME - Static variable in class org.apache.lucene.search.FilterManager
Deprecated.
The default frequency of cache cleanup
DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
 
DEFAULT_DOUBLE_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for double values, which are encoded by Double.toString(double)
DEFAULT_FLOAT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for float values, which are encoded by Float.toString(float)
DEFAULT_INT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for int values, which are encoded by Integer.toString(int)
DEFAULT_LONG_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for long values, which are encoded by Long.toString(long)
DEFAULT_MAX_BUFF - Static variable in class org.apache.lucene.store.MMapDirectory
 
DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriter
DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriter
DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriterConfig
Disabled by default (because IndexWriter flushes by RAM usage by default).
DEFAULT_MAX_FIELD_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
Deprecated.
DEFAULT_MAX_MERGE_DOCS - Static variable in class org.apache.lucene.index.LogMergePolicy
Default maximum segment size.
DEFAULT_MAX_MERGE_MB - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
Default maximum segment size.
DEFAULT_MAX_MERGE_MB_FOR_FORCED_MERGE - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
Default maximum segment size.
DEFAULT_MAX_THREAD_STATES - Static variable in class org.apache.lucene.index.IndexWriterConfig
The maximum number of simultaneous threads that may be indexing documents at once in IndexWriter; if more than this many threads arrive they will wait for others to finish.
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.standard.ClassicAnalyzer
Default maximum allowed token length
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.standard.StandardAnalyzer
Default maximum allowed token length
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
Default maximum allowed token length
DEFAULT_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_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_RAM_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.index.IndexWriter
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_READ_CHUNK_SIZE - Static variable in class org.apache.lucene.store.FSDirectory
Default read chunk size.
DEFAULT_READER_POOLING - Static variable in class org.apache.lucene.index.IndexWriterConfig
DEFAULT_READER_TERMS_INDEX_DIVISOR - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 1.
DEFAULT_RESOLUTION - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
 
DEFAULT_SHORT_PARSER - Static variable in interface org.apache.lucene.search.FieldCache
The default parser for short values, which are encoded by Short.toString(short)
DEFAULT_TERM_INDEX_INTERVAL - Static variable in class org.apache.lucene.index.IndexWriter
DEFAULT_TERM_INDEX_INTERVAL - Static variable in class org.apache.lucene.index.IndexWriterConfig
Default value is 128.
DEFAULT_TYPE - Static variable in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
the default type
defaultMaxExpansions - Static variable in class org.apache.lucene.search.FuzzyQuery
 
defaultMinSimilarity - Static variable in class org.apache.lucene.search.FuzzyQuery
 
defaultPrefixLength - Static variable in class org.apache.lucene.search.FuzzyQuery
 
DefaultSimilarity - Class in org.apache.lucene.search
Expert: Default scoring implementation.
DefaultSimilarity() - Constructor for class org.apache.lucene.search.DefaultSimilarity
 
DELETABLE - Static variable in class org.apache.lucene.index.IndexFileNames
Name of the index deletable file (only used in pre-lockless indices)
delete() - Method in class org.apache.lucene.index.IndexCommit
Delete this commit point.
delete() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
deleteAll() - Method in class org.apache.lucene.index.IndexWriter
Delete all documents in the index.
deleteAll() - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
deletedDocs - Variable in class org.apache.lucene.index.SegmentWriteState
 
deleteDocument(int) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. Use IndexWriter.deleteDocuments(Term) instead
deleteDocuments(Term) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. Use IndexWriter.deleteDocuments(Term) instead
deleteDocuments(Term) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) containing term.
deleteDocuments(Term...) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) containing any of the terms.
deleteDocuments(Query) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) matching the provided query.
deleteDocuments(Query...) - Method in class org.apache.lucene.index.IndexWriter
Deletes the document(s) matching any of the provided queries.
deleteDocuments(Term) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
deleteDocuments(Term...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
deleteDocuments(Query) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
deleteDocuments(Query...) - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
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.FSDirectory
Removes an existing file in the directory.
deleteFile(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
deleteFile(String) - Method in class org.apache.lucene.store.RAMDirectory
Removes an existing file in the directory.
deleteLast(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
DELETES_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of deletes
deleteUnusedFiles() - Method in class org.apache.lucene.index.IndexWriter
Expert: remove any index files that are no longer used.
deletionsFileName - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Name of the current deletions file name.
depth - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
This node's depth, starting from the automaton root.
description() - Method in class org.apache.lucene.search.function.ByteFieldSource
 
description() - Method in class org.apache.lucene.search.function.FieldCacheSource
 
description() - Method in class org.apache.lucene.search.function.FloatFieldSource
 
description() - Method in class org.apache.lucene.search.function.IntFieldSource
 
description() - Method in class org.apache.lucene.search.function.OrdFieldSource
 
description() - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
 
description() - Method in class org.apache.lucene.search.function.ShortFieldSource
 
description() - Method in class org.apache.lucene.search.function.ValueSource
description of field, used in explain()
description - Variable in enum org.apache.lucene.util.RamUsageEstimator.JvmFeature
 
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
difference() - Method in class org.apache.lucene.search.FilteredTermEnum
Equality measure on the term
difference() - Method in class org.apache.lucene.search.FuzzyTermEnum
Equality measure on the term
difference() - Method in class org.apache.lucene.search.PrefixTermEnum
 
difference() - Method in class org.apache.lucene.search.SingleTermEnum
 
difference() - Method in class org.apache.lucene.search.TermRangeTermEnum
 
difference() - Method in class org.apache.lucene.search.WildcardTermEnum
 
dir - Variable in class org.apache.lucene.index.CheckIndex.Status
Directory index is in.
dir - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
 
dir - Variable in class org.apache.lucene.index.SegmentInfo
 
directory() - Method in class org.apache.lucene.index.FilterIndexReader
 
directory() - Method in class org.apache.lucene.index.IndexReader
Returns the directory associated with this index.
directory() - Method in class org.apache.lucene.index.SegmentReader
Returns the directory this index resides in.
directory - Variable in class org.apache.lucene.index.SegmentWriteState
 
Directory - Class in org.apache.lucene.store
A Directory is a flat list of files.
Directory() - Constructor for class org.apache.lucene.store.Directory
 
directory - Variable in class org.apache.lucene.store.FSDirectory
 
DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriter
Deprecated.
DISABLE_AUTO_FLUSH - Static variable in class org.apache.lucene.index.IndexWriterConfig
Denotes a flush trigger is disabled.
disable_tracing() - Method in class org.apache.lucene.queryParser.QueryParser
Disable tracing.
discountOverlaps - Variable in class org.apache.lucene.search.DefaultSimilarity
 
DisjunctionMaxQuery - Class in org.apache.lucene.search
A query that generates the union of documents produced by its subqueries, and that scores each document with the maximum score for that document as produced by any subquery, plus a tie breaking increment for any additional matching subqueries.
DisjunctionMaxQuery(float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
Creates a new empty DisjunctionMaxQuery.
DisjunctionMaxQuery(Collection<Query>, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
Creates a new DisjunctionMaxQuery
DisjunctionMaxQuery.DisjunctionMaxWeight - Class in org.apache.lucene.search
Expert: the Weight for DisjunctionMaxQuery, used to normalize, score and explain these queries.
DisjunctionMaxQuery.DisjunctionMaxWeight(Searcher) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Construct the Weight for this Query searched by searcher.
doAfterFlush() - Method in class org.apache.lucene.index.IndexWriter
A hook for extending classes to execute operations after pending added and deleted documents have been flushed to the Directory but before the change is committed (new segments_N file written).
doBeforeFlush() - Method in class org.apache.lucene.index.IndexWriter
A hook for extending classes to execute operations before pending added and deleted documents are flushed to the Directory.
doBody(String) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
Subclass must implement this.
doBody() - Method in class org.apache.lucene.store.Lock.With
Code to execute with exclusive access.
doc - Variable in class org.apache.lucene.index.AbstractAllTermDocs
 
doc() - Method in class org.apache.lucene.index.AbstractAllTermDocs
 
doc() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
 
doc() - Method in class org.apache.lucene.index.MultipleTermPositions
 
doc() - Method in interface org.apache.lucene.index.TermDocs
Returns the current document number.
doc(int) - Method in class org.apache.lucene.search.IndexSearcher
 
doc(int, FieldSelector) - Method in class org.apache.lucene.search.IndexSearcher
 
doc(int) - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
 
doc(int, FieldSelector) - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
 
doc - Variable in class org.apache.lucene.search.ScoreDoc
Expert: A hit document's number.
doc(int) - Method in interface org.apache.lucene.search.Searchable
Deprecated.
Returns the stored fields of document i.
doc(int, FieldSelector) - Method in interface org.apache.lucene.search.Searchable
Deprecated.
Get the Document at the nth position.
doc(int) - Method in class org.apache.lucene.search.Searcher
Deprecated.
 
doc(int, FieldSelector) - Method in class org.apache.lucene.search.Searcher
Deprecated.
 
DOC - Static variable in class org.apache.lucene.search.SortField
Sort by document number (index order).
doc() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
doc() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
doc() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
doc() - Method in class org.apache.lucene.search.spans.Spans
Returns the document number of the current match.
doc - Variable in class org.apache.lucene.search.spans.SpanScorer
 
doc - Variable in class org.apache.lucene.search.spans.TermSpans
 
doc() - Method in class org.apache.lucene.search.spans.TermSpans
 
doCacheWrite(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
Subclass can override this to customize logic; return true if this file should be written to the RAMDirectory.
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Document count (does not take deletions into account).
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
Number of documents tested.
docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
Number of documents tested.
docCount - Variable in class org.apache.lucene.index.SegmentInfo
 
docFreq(Term) - Method in class org.apache.lucene.index.FilterIndexReader
 
docFreq() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
 
docFreq(Term) - Method in class org.apache.lucene.index.IndexReader
Returns the number of documents containing the term t.
docFreq(Term) - Method in class org.apache.lucene.index.MultiReader
 
docFreq(Term) - Method in class org.apache.lucene.index.ParallelReader
 
docFreq(Term) - Method in class org.apache.lucene.index.SegmentReader
 
docFreq() - Method in class org.apache.lucene.index.TermEnum
Returns the docFreq of the current Term in the enumeration.
docFreq() - Method in class org.apache.lucene.search.FilteredTermEnum
Returns the docFreq of the current Term in the enumeration.
docFreq(Term) - Method in class org.apache.lucene.search.IndexSearcher
Returns total docFreq for this term.
docFreq(Term) - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
 
docFreq(Term) - Method in class org.apache.lucene.search.ParallelMultiSearcher
Deprecated.
Executes each Searchable's docFreq() in its own thread and waits for each search to complete and merge the results back together.
docFreq(Term) - Method in interface org.apache.lucene.search.Searchable
Deprecated.
Expert: Returns the number of documents containing term.
docFreq(Term) - Method in class org.apache.lucene.search.Searcher
Deprecated.
 
docFreqs(Term[]) - Method in interface org.apache.lucene.search.Searchable
Deprecated.
Expert: For each term in the terms array, calculates the number of documents containing term.
docFreqs(Term[]) - Method in class org.apache.lucene.search.Searcher
Deprecated.
 
docID() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantScorer
 
docID() - Method in class org.apache.lucene.search.DocIdSetIterator
Returns the following: -1 or DocIdSetIterator.NO_MORE_DOCS if DocIdSetIterator.nextDoc() or DocIdSetIterator.advance(int) were not called yet.
docID() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
 
docID() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
docID() - Method in class org.apache.lucene.search.spans.SpanScorer
 
docID() - Method in class org.apache.lucene.util.OpenBitSetIterator
 
DocIdBitSet - Class in org.apache.lucene.util
Simple DocIdSet and DocIdSetIterator backed by a BitSet
DocIdBitSet(BitSet) - Constructor for class org.apache.lucene.util.DocIdBitSet
 
DocIdSet - Class in org.apache.lucene.search
A DocIdSet contains a set of doc ids.
DocIdSet() - Constructor for class org.apache.lucene.search.DocIdSet
 
DocIdSetIterator - Class in org.apache.lucene.search
This abstract class defines methods to iterate over a set of non-decreasing doc ids.
DocIdSetIterator() - Constructor for class org.apache.lucene.search.DocIdSetIterator
 
docIdSetToCache(DocIdSet, IndexReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
Provide the DocIdSet to be cached, using the DocIdSet provided by the wrapped Filter.
doClose() - Method in class org.apache.lucene.index.FilterIndexReader
 
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.ParallelReader
 
doClose() - Method in class org.apache.lucene.index.SegmentReader
 
doCommit(Map<String, String>) - Method in class org.apache.lucene.index.FilterIndexReader
Deprecated.
doCommit(Map<String, String>) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
doCommit(Map<String, String>) - Method in class org.apache.lucene.index.MultiReader
Deprecated.
doCommit(Map<String, String>) - Method in class org.apache.lucene.index.ParallelReader
Deprecated.
doCommit(Map<String, String>) - Method in class org.apache.lucene.index.SegmentReader
Deprecated.
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
docScore(int, String, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
Calculate the final score for all the payloads seen so far for this doc/field
docStarts - Variable in class org.apache.lucene.search.IndexSearcher
 
docStoreCompoundFile - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if the shared doc store files are compound file format.
docStoreOffset - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Doc store offset, if this segment shares the doc store files (stored fields and term vectors) with other segments.
docStoreSegment - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
String of the shared doc store segment, or null if this segment does not share the doc store files.
docsWithField - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
 
Document - Class in org.apache.lucene.document
Documents are the unit of indexing and search.
Document() - Constructor for class org.apache.lucene.document.Document
Constructs a new document with no fields.
document(int, FieldSelector) - Method in class org.apache.lucene.index.FilterIndexReader
 
document(int) - Method in class org.apache.lucene.index.IndexReader
Returns the stored fields of the nth Document in this index.
document(int, FieldSelector) - Method in class org.apache.lucene.index.IndexReader
Get the Document at the n th position.
document(int, FieldSelector) - Method in class org.apache.lucene.index.MultiReader
 
document(int, FieldSelector) - Method in class org.apache.lucene.index.ParallelReader
 
document(int, FieldSelector) - Method in class org.apache.lucene.index.SegmentReader
 
DocValues - Class in org.apache.lucene.search.function
Expert: represents field values as different types.
DocValues() - Constructor for class org.apache.lucene.search.function.DocValues
 
doDelete(int) - Method in class org.apache.lucene.index.FilterIndexReader
Deprecated.
doDelete(int) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. Use IndexWriter.deleteDocuments(Term) instead
doDelete(int) - Method in class org.apache.lucene.index.MultiReader
Deprecated.
doDelete(int) - Method in class org.apache.lucene.index.ParallelReader
Deprecated.
doDelete(int) - Method in class org.apache.lucene.index.SegmentReader
Deprecated.
doMerge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Done() - Method in interface org.apache.lucene.queryParser.CharStream
The lexer calls this function to indicate that it is done with the stream and hence implementations can free any resources held by this class.
Done() - Method in class org.apache.lucene.queryParser.FastCharStream
 
doNext() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
doOpenIfChanged() - Method in class org.apache.lucene.index.IndexReader
If the index has changed since it was opened, open and return a new reader; else, return null.
doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. Use IndexReader.doOpenIfChanged() instead
doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.IndexReader
If the index has changed since it was opened, open and return a new reader; else, return null.
doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.IndexReader
If the index has changed since it was opened, open and return a new reader; else, return null.
doOpenIfChanged() - Method in class org.apache.lucene.index.MultiReader
 
doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.MultiReader
Deprecated.
Write support will be removed in Lucene 4.0. Use MultiReader.doOpenIfChanged() instead.
doOpenIfChanged() - Method in class org.apache.lucene.index.ParallelReader
 
doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.ParallelReader
Deprecated.
Write support will be removed in Lucene 4.0. Use ParallelReader.doOpenIfChanged() instead.
doOpenIfChanged() - Method in class org.apache.lucene.index.SegmentReader
 
doOpenIfChanged(boolean) - Method in class org.apache.lucene.index.SegmentReader
Deprecated.
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.
doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.FilterIndexReader
Deprecated.
doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. There will be no replacement for this method.
doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.MultiReader
Deprecated.
doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.ParallelReader
Deprecated.
doSetNorm(int, String, byte) - Method in class org.apache.lucene.index.SegmentReader
Deprecated.
DOUBLE - Static variable in class org.apache.lucene.search.SortField
Sort using term values as encoded Doubles.
DoubleBarrelLRUCache<K extends DoubleBarrelLRUCache.CloneableKey,V> - Class in org.apache.lucene.util
Simple concurrent LRU cache, using a "double barrel" approach where two ConcurrentHashMaps record entries.
DoubleBarrelLRUCache(int) - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache
 
DoubleBarrelLRUCache.CloneableKey - Class in org.apache.lucene.util
Object providing clone(); the key class must subclass this.
DoubleBarrelLRUCache.CloneableKey() - Constructor for class org.apache.lucene.util.DoubleBarrelLRUCache.CloneableKey
 
doubleToPrefixCoded(double) - Static method in class org.apache.lucene.util.NumericUtils
 
doubleToSortableLong(double) - Static method in class org.apache.lucene.util.NumericUtils
Converts a double value to a sortable signed long.
doubleVal(int) - Method in class org.apache.lucene.search.function.DocValues
Return doc value as a double.
doUndeleteAll() - Method in class org.apache.lucene.index.FilterIndexReader
Deprecated.
doUndeleteAll() - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0. There will be no replacement for this method.
doUndeleteAll() - Method in class org.apache.lucene.index.MultiReader
Deprecated.
doUndeleteAll() - Method in class org.apache.lucene.index.ParallelReader
Deprecated.
doUndeleteAll() - Method in class org.apache.lucene.index.SegmentReader
Deprecated.
dropBuffersAndReset() - Method in class org.apache.lucene.util.ByteBlockPool
 
DummyConcurrentLock - Class in org.apache.lucene.util
A dummy lock as a replacement for ReentrantLock to disable locking
DummyConcurrentLock() - Constructor for class org.apache.lucene.util.DummyConcurrentLock
 

E

EMAIL - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
EMAIL - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
 
EMAIL - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
Deprecated.
 
EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
Deprecated.
 
EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
Deprecated.
EMAIL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
 
EMPTY - Static variable in interface org.apache.lucene.util.BytesRefIterator
Singleton BytesRefIterator that iterates over 0 BytesRefs.
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
 
EMPTY_DOCIDSET - Static variable in class org.apache.lucene.search.DocIdSet
An empty DocIdSet instance for easy use, e.g. in Filters that hit no documents.
EMPTY_INTS - Static variable in class org.apache.lucene.util.IntsRef
 
EMPTY_OFFSET_INFO - Static variable in class org.apache.lucene.index.TermVectorOffsetInfo
Convenience declaration when creating a TermPositionVector that stores only position information.
EMPTY_SET - Static variable in class org.apache.lucene.analysis.CharArraySet
 
EMPTY_TOPDOCS - Static variable in class org.apache.lucene.search.TopDocsCollector
 
emptyMap() - Static method in class org.apache.lucene.analysis.CharArrayMap
Returns an empty, unmodifiable map.
enable_tracing() - Method in class org.apache.lucene.queryParser.QueryParser
Enable tracing.
enableBackwards - Variable in class org.apache.lucene.util.AttributeImpl
Deprecated.
this will be removed in Lucene 4.0.
encode(ByteBuffer, CharBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.encode(byte[], int, int, char[], int, int) instead. This method will be removed in Lucene 4.0
encode(byte[], int, int, char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Encodes the input byte sequence into the output char sequence.
encode(ByteBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.encode(byte[], int, int, char[], int, int) instead. This method will be removed in Lucene 4.0
encodeNorm(float) - Static method in class org.apache.lucene.search.Similarity
Deprecated.
encodeNormValue(float) - Method in class org.apache.lucene.search.Similarity
Encodes a normalization factor for storage in an index.
end() - Method in class org.apache.lucene.analysis.CachingTokenFilter
 
end() - Method in class org.apache.lucene.analysis.CharTokenizer
 
end() - Method in class org.apache.lucene.analysis.KeywordTokenizer
 
end() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
end() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
 
end() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
end() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
 
end() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkTokenStream
 
end() - Method in class org.apache.lucene.analysis.TokenFilter
Performs end-of-stream operations, if any, and calls then end() on the input TokenStream.
end() - Method in class org.apache.lucene.analysis.TokenStream
This method is called by the consumer after the last token has been consumed, after TokenStream.incrementToken() returned false (using the new TokenStream API).
end() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
end() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
end() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
end - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
end() - Method in class org.apache.lucene.search.spans.Spans
Returns the end position of the current match.
end() - Method in class org.apache.lucene.search.spans.TermSpans
 
END_LABEL - Static variable in class org.apache.lucene.util.fst.FST
 
endColumn - Variable in class org.apache.lucene.queryParser.Token
The column number of the last character of this Token.
endEnum() - Method in class org.apache.lucene.search.FilteredTermEnum
Indicates the end of the enumeration has been reached
endEnum() - Method in class org.apache.lucene.search.FuzzyTermEnum
Indicates the end of the enumeration has been reached
endEnum() - Method in class org.apache.lucene.search.PrefixTermEnum
 
endEnum() - Method in class org.apache.lucene.search.SingleTermEnum
 
endEnum() - Method in class org.apache.lucene.search.TermRangeTermEnum
 
endEnum() - Method in class org.apache.lucene.search.WildcardTermEnum
 
endLine - Variable in class org.apache.lucene.queryParser.Token
The line number of the last character of this Token.
endOffset() - Method in class org.apache.lucene.analysis.Token
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
endOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
endOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
Returns this Token's ending offset, one greater than the position of the last character corresponding to this token in the source text.
endsWith(BytesRef) - Method in class org.apache.lucene.util.BytesRef
 
ENGLISH_STOP_WORDS_SET - Static variable in class org.apache.lucene.analysis.StopAnalyzer
An unmodifiable set containing some common English words that are not usually useful for searching.
ensureCanWrite(String) - Method in class org.apache.lucene.store.FSDirectory
 
ensureCapacity(long) - Method in class org.apache.lucene.util.OpenBitSet
Ensure that the long[] is big enough to hold numBits, expanding it if necessary.
ensureCapacityWords(int) - Method in class org.apache.lucene.util.OpenBitSet
Expand the long[] with the size given as a number of words (64 bit longs).
ensureOpen() - Method in class org.apache.lucene.index.IndexReader
 
ensureOpen(boolean) - Method in class org.apache.lucene.index.IndexWriter
Used internally to throw an AlreadyClosedException if this IndexWriter has been closed.
ensureOpen() - Method in class org.apache.lucene.index.IndexWriter
 
ensureOpen() - Method in class org.apache.lucene.store.Directory
 
entrySet() - Method in class org.apache.lucene.analysis.CharArrayMap
 
EOF - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
End of File.
eof() - Method in class org.apache.lucene.store.ByteArrayDataInput
 
eol - Variable in exception org.apache.lucene.queryParser.ParseException
The end of line string for this machine.
equals(Object) - Method in class org.apache.lucene.analysis.Token
 
equals(Object) - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
equals(Object) - Method in class org.apache.lucene.index.IndexCommit
Two IndexCommits are equal if both their Directory and versions are equal.
equals(Object) - Method in class org.apache.lucene.index.Payload
 
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.index.TermVectorEntry
 
equals(Object) - Method in class org.apache.lucene.index.TermVectorOffsetInfo
Two TermVectorOffsetInfos are equals if both the start and end offsets are the same
equals(Object) - Method in class org.apache.lucene.search.BooleanClause
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.BooleanQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.CachingSpanFilter
 
equals(Object) - Method in class org.apache.lucene.search.CachingWrapperFilter
 
equals(Object) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
equals(Object) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
Return true iff we represent the same query as o
equals(Object) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
 
equals(Object) - Method in class org.apache.lucene.search.FieldValueFilter
 
equals(Object) - Method in class org.apache.lucene.search.FilteredQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.function.CustomScoreQuery
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.function.FieldCacheSource
 
equals(Object) - Method in class org.apache.lucene.search.function.OrdFieldSource
 
equals(Object) - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
 
equals(Object) - Method in class org.apache.lucene.search.function.ValueSource
Needed for possible caching of query results - used by ValueSourceQuery.equals(Object).
equals(Object) - Method in class org.apache.lucene.search.function.ValueSourceQuery
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.FuzzyQuery
 
equals(Object) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
equals(Object) - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.MultiTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
 
equals(Object) - Method in class org.apache.lucene.search.NGramPhraseQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.NumericRangeQuery
 
equals(Object) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadFunction
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
equals(Object) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.PhraseQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.PrefixQuery
 
equals(Object) - Method in class org.apache.lucene.search.Query
 
equals(Object) - Method in class org.apache.lucene.search.QueryWrapperFilter
 
equals(Object) - Method in class org.apache.lucene.search.Sort
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.SortField
Returns true if o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.SpanQueryFilter
 
equals(Object) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanNearQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.spans.SpanNotQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
equals(Object) - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
equals(Object) - Method in class org.apache.lucene.search.TermQuery
Returns true iff o is equal to this.
equals(Object) - Method in class org.apache.lucene.search.TermRangeQuery
 
equals(Object) - Method in class org.apache.lucene.search.TopTermsRewrite
 
equals(Object) - Method in class org.apache.lucene.search.WildcardQuery
 
equals(char[], int, char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
See if two array slices are the same.
equals(int[], int, int[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
See if two array slices are the same.
equals(Object) - Method in class org.apache.lucene.util.AttributeSource
 
equals(Object) - Method in class org.apache.lucene.util.BytesRef
 
equals(Object) - Method in class org.apache.lucene.util.CharsRef
 
equals(Object) - Method in class org.apache.lucene.util.FixedBitSet
returns true if both sets have the same bits set
equals(Object) - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
 
equals(Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
 
equals(Object) - Method in class org.apache.lucene.util.IntsRef
 
equals(Object) - Method in class org.apache.lucene.util.OpenBitSet
returns true if both sets have the same bits set
error - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
Exception thrown during stored fields test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
Exception thrown during term index test (null on success)
error - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
Exception thrown during term vector test (null on success)
escape(String) - Static method in class org.apache.lucene.queryParser.QueryParser
Returns a String where those characters that QueryParser expects to be escaped are escaped by a preceding \.
estimatedMergeBytes - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
 
estimateRamUsage(Object) - Method in class org.apache.lucene.util.RamUsageEstimator
Deprecated.
Don't create instances of this class, instead use the static RamUsageEstimator.sizeOf(Object) method.
estimateSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
Computes (and stores) the estimated size of the cache Value
execute(TwoPhaseCommit...) - Static method in class org.apache.lucene.util.TwoPhaseCommitTool
Executes a 2-phase commit algorithm by first TwoPhaseCommit.prepareCommit() all objects and only if all succeed, it proceeds with TwoPhaseCommit.commit().
expandingWordNum(long) - Method in class org.apache.lucene.util.OpenBitSet
 
EXPECTED - Static variable in class org.apache.lucene.util.FieldCacheSanityChecker.InsanityType
Indicates an expected bit of "insanity".
expectedTokenSequences - Variable in exception org.apache.lucene.queryParser.ParseException
Each entry in this array is an array of integers.
explain(IndexReader, int) - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
explain(IndexReader, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
 
explain(IndexReader, int) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Explain the score we computed for doc
explain() - Method in class org.apache.lucene.search.Explanation.IDFExplanation
This should be calculated lazily if possible.
explain(int) - Method in class org.apache.lucene.search.function.DocValues
Explain the scoring value for the input doc.
explain(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
Returns an Explanation that describes how doc scored against query.
explain(Weight, int) - Method in class org.apache.lucene.search.IndexSearcher
Expert: low-level implementation method Returns an Explanation that describes how doc scored against weight.
explain(Weight, int) - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
 
explain(int, int, float) - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
explain(int, int, float) - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
explain(int, int, float) - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
explain(int, int, float) - Method in class org.apache.lucene.search.payloads.PayloadFunction
 
explain(int) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
 
explain(IndexReader, int) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight
 
explain(int) - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
 
explain(Weight, int) - Method in interface org.apache.lucene.search.Searchable
Deprecated.
Expert: low-level implementation method Returns an Explanation that describes how doc scored against weight.
explain(Query, int) - Method in class org.apache.lucene.search.Searcher
Deprecated.
Returns an Explanation that describes how doc scored against query.
explain(Weight, int) - Method in class org.apache.lucene.search.Searcher
Deprecated.
 
explain(int) - Method in class org.apache.lucene.search.spans.SpanScorer
This method is no longer an official member of Scorer, but it is needed by SpanWeight to build an explanation.
explain(IndexReader, int) - Method in class org.apache.lucene.search.spans.SpanWeight
 
explain(IndexReader, int) - Method in class org.apache.lucene.search.Weight
An explanation of the score computation for the named document.
Explanation - Class in org.apache.lucene.search
Expert: Describes the score computation for document and query.
Explanation() - Constructor for class org.apache.lucene.search.Explanation
 
Explanation(float, String) - Constructor for class org.apache.lucene.search.Explanation
 
Explanation.IDFExplanation - Class in org.apache.lucene.search
Small Util class used to pass both an idf factor as well as an explanation for that factor.
Explanation.IDFExplanation() - Constructor for class org.apache.lucene.search.Explanation.IDFExplanation
 
expungeDeletes(boolean) - Method in class org.apache.lucene.index.IndexWriter
Deprecated. 
expungeDeletes() - Method in class org.apache.lucene.index.IndexWriter
Deprecated. 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.BooleanQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.ConstantScoreQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.FilteredQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.function.CustomScoreQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.function.ValueSourceQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.MultiPhraseQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.PhraseQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.Query
Expert: adds all terms occurring in this query to the terms set.
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
extractTerms(Set<Term>) - Method in class org.apache.lucene.search.TermQuery
 

F

failureReason - Variable in class org.apache.lucene.store.Lock
If a lock obtain called, this failureReason may be set with the "root cause" Exception as to why the lock was not obtained.
FastCharStream - Class in org.apache.lucene.queryParser
An efficient implementation of JavaCC's CharStream interface.
FastCharStream(Reader) - Constructor for class org.apache.lucene.queryParser.FastCharStream
Constructs from a Reader.
fastClear(int) - Method in class org.apache.lucene.util.OpenBitSet
clears a bit.
fastClear(long) - Method in class org.apache.lucene.util.OpenBitSet
clears a bit.
fastFlip(int) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit.
fastFlip(long) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit.
fastGet(int) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index.
fastGet(long) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index.
fastSet(int) - Method in class org.apache.lucene.util.OpenBitSet
Sets the bit at the specified index.
fastSet(long) - Method in class org.apache.lucene.util.OpenBitSet
Sets the bit at the specified index.
Field - Class in org.apache.lucene.document
A field is a section of a Document.
Field(String, String, Field.Store, Field.Index) - Constructor for class org.apache.lucene.document.Field
Create a field by specifying its name, value and how it will be saved in the index.
Field(String, String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
Create a field by specifying its name, value and how it will be saved in the index.
Field(String, boolean, String, Field.Store, Field.Index, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
Create a field by specifying its name, value and how it will be saved in the index.
Field(String, Reader) - Constructor for class org.apache.lucene.document.Field
Create a tokenized and indexed field that is not stored.
Field(String, Reader, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
Create a tokenized and indexed field that is not stored, optionally with storing term vectors.
Field(String, TokenStream) - Constructor for class org.apache.lucene.document.Field
Create a tokenized and indexed field that is not stored.
Field(String, TokenStream, Field.TermVector) - Constructor for class org.apache.lucene.document.Field
Create a tokenized and indexed field that is not stored, optionally with storing term vectors.
Field(String, byte[], Field.Store) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Field(String, byte[]) - Constructor for class org.apache.lucene.document.Field
Create a stored field with binary value.
Field(String, byte[], int, int, Field.Store) - Constructor for class org.apache.lucene.document.Field
Deprecated.
Field(String, byte[], int, int) - Constructor for class org.apache.lucene.document.Field
Create a stored field with binary value.
field() - Method in class org.apache.lucene.index.Term
Returns the field of this term, an interned string.
field - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
 
field() - Method in class org.apache.lucene.search.FieldValueFilter
Returns the field this filter is applied on.
field - Variable in class org.apache.lucene.search.function.OrdFieldSource
 
field - Variable in class org.apache.lucene.search.function.ReverseOrdFieldSource
 
field - Variable in class org.apache.lucene.search.spans.SpanNearQuery
 
Field.Index - Enum in org.apache.lucene.document
Specifies whether and how a field should be indexed.
Field.Store - Enum in org.apache.lucene.document
Specifies whether and how a field should be stored.
Field.TermVector - Enum in org.apache.lucene.document
Specifies whether and how a field should have term vectors.
FIELD_DOC - Static variable in class org.apache.lucene.search.SortField
Represents sorting by document number (index order).
FIELD_INFOS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of field infos
FIELD_SCORE - Static variable in class org.apache.lucene.search.SortField
Represents sorting by document score (relevance).
Fieldable - Interface in org.apache.lucene.document
Synonymous with Field.
FieldCache - Interface in org.apache.lucene.search
Expert: Maintains caches of term values.
FieldCache.ByteParser - Interface in org.apache.lucene.search
Interface to parse bytes from document fields.
FieldCache.CacheEntry - Class in org.apache.lucene.search
EXPERT: A unique Identifier/Description for each item in the FieldCache.
FieldCache.CacheEntry() - Constructor for class org.apache.lucene.search.FieldCache.CacheEntry
 
FieldCache.CreationPlaceholder - Class in org.apache.lucene.search
 
FieldCache.CreationPlaceholder() - Constructor for class org.apache.lucene.search.FieldCache.CreationPlaceholder
 
FieldCache.DoubleParser - Interface in org.apache.lucene.search
Interface to parse doubles from document fields.
FieldCache.FloatParser - Interface in org.apache.lucene.search
Interface to parse floats from document fields.
FieldCache.IntParser - Interface in org.apache.lucene.search
Interface to parse ints from document fields.
FieldCache.LongParser - Interface in org.apache.lucene.search
Interface to parse long from document fields.
FieldCache.Parser - Interface in org.apache.lucene.search
Marker interface as super-interface to all parsers.
FieldCache.ShortParser - Interface in org.apache.lucene.search
Interface to parse shorts from document fields.
FieldCache.StringIndex - Class in org.apache.lucene.search
Expert: Stores term text values and document ordering data.
FieldCache.StringIndex(int[], String[]) - Constructor for class org.apache.lucene.search.FieldCache.StringIndex
Creates one of these objects
FieldCacheDocIdSet - Class in org.apache.lucene.search
Base class for DocIdSet to be used with FieldCache.
FieldCacheDocIdSet(IndexReader) - Constructor for class org.apache.lucene.search.FieldCacheDocIdSet
 
FieldCacheRangeFilter<T> - Class in org.apache.lucene.search
A range filter built on top of a cached single term field (in FieldCache).
FieldCacheSanityChecker - Class in org.apache.lucene.util
Provides methods for sanity checking that entries in the FieldCache are not wasteful or inconsistent.
FieldCacheSanityChecker() - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker
 
FieldCacheSanityChecker.Insanity - Class in org.apache.lucene.util
Simple container for a collection of related CacheEntry objects that in conjunction with each other represent some "insane" usage of the FieldCache.
FieldCacheSanityChecker.Insanity(FieldCacheSanityChecker.InsanityType, String, FieldCache.CacheEntry...) - Constructor for class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
 
FieldCacheSanityChecker.InsanityType - Class in org.apache.lucene.util
An Enumeration of the different types of "insane" behavior that may be detected in a FieldCache.
FieldCacheSource - Class in org.apache.lucene.search.function
Expert: A base class for ValueSource implementations that retrieve values for a single field from the FieldCache.
FieldCacheSource(String) - Constructor for class org.apache.lucene.search.function.FieldCacheSource
Create a cached field source for the input field.
FieldCacheTermsFilter - Class in org.apache.lucene.search
A Filter that only accepts documents whose single term value in the specified field is contained in the provided set of allowed terms.
FieldCacheTermsFilter(String, String...) - Constructor for class org.apache.lucene.search.FieldCacheTermsFilter
 
FieldComparator<T> - Class in org.apache.lucene.search
Expert: a FieldComparator compares hits so as to determine their sort order when collecting the top results with TopFieldCollector.
FieldComparator() - Constructor for class org.apache.lucene.search.FieldComparator
 
FieldComparator.ByteComparator - Class in org.apache.lucene.search
Parses field's values as byte (using FieldCache.getBytes(org.apache.lucene.index.IndexReader, java.lang.String) and sorts by ascending value
FieldComparator.DocComparator - Class in org.apache.lucene.search
Sorts by ascending docID
FieldComparator.DoubleComparator - Class in org.apache.lucene.search
Parses field's values as double (using FieldCache.getDoubles(org.apache.lucene.index.IndexReader, java.lang.String) and sorts by ascending value
FieldComparator.FloatComparator - Class in org.apache.lucene.search
Parses field's values as float (using FieldCache.getFloats(org.apache.lucene.index.IndexReader, java.lang.String) and sorts by ascending value
FieldComparator.IntComparator - Class in org.apache.lucene.search
Parses field's values as int (using FieldCache.getInts(org.apache.lucene.index.IndexReader, java.lang.String) and sorts by ascending value
FieldComparator.LongComparator - Class in org.apache.lucene.search
Parses field's values as long (using FieldCache.getLongs(org.apache.lucene.index.IndexReader, java.lang.String) and sorts by ascending value
FieldComparator.NumericComparator<T extends Number> - Class in org.apache.lucene.search
 
FieldComparator.NumericComparator(String, T) - Constructor for class org.apache.lucene.search.FieldComparator.NumericComparator
 
FieldComparator.RelevanceComparator - Class in org.apache.lucene.search
Sorts by descending relevance.
FieldComparator.ShortComparator - Class in org.apache.lucene.search
Parses field's values as short (using FieldCache.getShorts(org.apache.lucene.index.IndexReader, java.lang.String) and sorts by ascending value
FieldComparator.StringComparatorLocale - Class in org.apache.lucene.search
Sorts by a field's value using the Collator for a given Locale.
FieldComparator.StringOrdValComparator - Class in org.apache.lucene.search
Sorts by field's natural String sort order, using ordinals.
FieldComparator.StringOrdValComparator(int, String, int, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
FieldComparator.StringValComparator - Class in org.apache.lucene.search
Sorts by field's natural String sort order.
FieldComparatorSource - Class in org.apache.lucene.search
Provides a FieldComparator for custom field sorting.
FieldComparatorSource() - Constructor for class org.apache.lucene.search.FieldComparatorSource
 
FieldDoc - Class in org.apache.lucene.search
Expert: A ScoreDoc which also contains information about how to sort the referenced document.
FieldDoc(int, float) - Constructor for class org.apache.lucene.search.FieldDoc
Expert: Creates one of these objects with empty sort information.
FieldDoc(int, float, Object[]) - Constructor for class org.apache.lucene.search.FieldDoc
Expert: Creates one of these objects with the given sort information.
FieldDoc(int, float, Object[], int) - Constructor for class org.apache.lucene.search.FieldDoc
Expert: Creates one of these objects with the given sort information.
FieldInfo - Class in org.apache.lucene.index
Access to the Fieldable Info file that describes document fields and whether or not they are indexed.
fieldInfo(String) - Method in class org.apache.lucene.index.FieldInfos
 
fieldInfo(int) - Method in class org.apache.lucene.index.FieldInfos
Return the fieldinfo object referenced by the fieldNumber.
FieldInfo.IndexOptions - Enum in org.apache.lucene.index
Controls how much information is stored in the postings lists.
FieldInfos - Class in org.apache.lucene.index
Collection of FieldInfos (accessible by number or by name).
FieldInfos() - Constructor for class org.apache.lucene.index.FieldInfos
 
FieldInfos(Directory, String) - Constructor for class org.apache.lucene.index.FieldInfos
Construct a FieldInfos object using the directory and the name of the file IndexInput
fieldInfos - Variable in class org.apache.lucene.index.SegmentWriteState
 
FieldInvertState - Class in org.apache.lucene.index
This class tracks the number and position / offset parameters of terms being added to the index.
FieldInvertState() - Constructor for class org.apache.lucene.index.FieldInvertState
 
FieldInvertState(int, int, int, int, float) - Constructor for class org.apache.lucene.index.FieldInvertState
 
FieldMaskingSpanQuery - Class in org.apache.lucene.search.spans
Wrapper to allow SpanQuery objects participate in composite single-field SpanQueries by 'lying' about their search field.
FieldMaskingSpanQuery(SpanQuery, String) - Constructor for class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
fieldName(int) - Method in class org.apache.lucene.index.FieldInfos
Return the fieldName identified by its number.
fieldName - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
 
fieldNormStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
Status for testing of field norms (null if field norms could not be tested).
fieldNumber(String) - Method in class org.apache.lucene.index.FieldInfos
lookup the number of a field by name.
FieldReaderException - Exception in org.apache.lucene.index
Exception thrown when stored fields have an unexpected format.
FieldReaderException() - Constructor for exception org.apache.lucene.index.FieldReaderException
Constructs a new runtime exception with null as its detail message.
FieldReaderException(Throwable) - Constructor for exception org.apache.lucene.index.FieldReaderException
Constructs a new runtime exception with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
FieldReaderException(String) - Constructor for exception org.apache.lucene.index.FieldReaderException
Constructs a new runtime exception with the specified detail message.
FieldReaderException(String, Throwable) - Constructor for exception org.apache.lucene.index.FieldReaderException
Constructs a new runtime exception with the specified detail message and cause.
fields - Variable in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
fields - Variable in class org.apache.lucene.search.FieldDoc
Expert: The values which are used to sort the referenced document.
fields - Variable in class org.apache.lucene.search.FieldValueHitQueue
Stores the sort criteria being used.
fields - Variable in class org.apache.lucene.search.TopFieldDocs
The fields which were used to sort results by.
FIELDS_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of stored fields file
FIELDS_INDEX_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of stored fields index file
FieldScoreQuery - Class in org.apache.lucene.search.function
A query that scores each document as the value of the numeric input field.
FieldScoreQuery(String, FieldScoreQuery.Type) - Constructor for class org.apache.lucene.search.function.FieldScoreQuery
Create a FieldScoreQuery - a query that scores each document as the value of the numeric input field.
FieldScoreQuery.Type - Class in org.apache.lucene.search.function
Type of score field, indicating how field values are interpreted/parsed.
fieldsData - Variable in class org.apache.lucene.document.AbstractField
 
FieldSelector - Interface in org.apache.lucene.document
Similar to a FileFilter, the FieldSelector allows one to make decisions about what Fields get loaded on a Document by IndexReader.document(int,org.apache.lucene.document.FieldSelector)
FieldSelectorResult - Enum in org.apache.lucene.document
Provides information about what should be done with this Field
FieldSortedTermVectorMapper - Class in org.apache.lucene.index
For each Field, store a sorted collection of TermVectorEntrys

This is not thread-safe.

FieldSortedTermVectorMapper(Comparator<TermVectorEntry>) - Constructor for class org.apache.lucene.index.FieldSortedTermVectorMapper
 
FieldSortedTermVectorMapper(boolean, boolean, Comparator<TermVectorEntry>) - Constructor for class org.apache.lucene.index.FieldSortedTermVectorMapper
 
FieldValueFilter - Class in org.apache.lucene.search
A Filter that accepts all documents that have one or more values in a given field.
FieldValueFilter(String) - Constructor for class org.apache.lucene.search.FieldValueFilter
Creates a new FieldValueFilter
FieldValueFilter(String, boolean) - Constructor for class org.apache.lucene.search.FieldValueFilter
Creates a new FieldValueFilter
FieldValueHitQueue<T extends FieldValueHitQueue.Entry> - Class in org.apache.lucene.search
Expert: A hit queue for sorting by hits by terms in more than one field.
FieldValueHitQueue.Entry - Class in org.apache.lucene.search
 
FieldValueHitQueue.Entry(int, int, float) - Constructor for class org.apache.lucene.search.FieldValueHitQueue.Entry
 
file - Variable in class org.apache.lucene.store.SimpleFSDirectory.SimpleFSIndexInput
 
fileExists(String) - Method in class org.apache.lucene.store.Directory
Returns true iff a file with the given name exists.
fileExists(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
fileExists(String) - Method in class org.apache.lucene.store.FSDirectory
Returns true iff a file with the given name exists.
fileExists(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
fileExists(String) - Method in class org.apache.lucene.store.RAMDirectory
Returns true iff the named file exists in this directory.
fileLength(String) - Method in class org.apache.lucene.store.Directory
Returns the length of a file in the directory.
fileLength(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
fileLength(String) - Method in class org.apache.lucene.store.FSDirectory
Returns the length in bytes of a file in the directory.
fileLength(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
fileLength(String) - Method in class org.apache.lucene.store.RAMDirectory
Returns the length in bytes of a file in the directory.
fileMap - Variable in class org.apache.lucene.store.RAMDirectory
 
fileModified(String) - Method in class org.apache.lucene.store.Directory
Deprecated. 
fileModified(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
 
fileModified(String) - Method in class org.apache.lucene.store.FSDirectory
Returns the time the named file was last modified.
fileModified(File, String) - Static method in class org.apache.lucene.store.FSDirectory
Returns the time the named file was last modified.
fileModified(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
 
fileModified(String) - Method in class org.apache.lucene.store.RAMDirectory
Returns the time the named file was last modified.
fileNameFromGeneration(String, String, long) - Static method in class org.apache.lucene.index.IndexFileNames
Computes the full file name from base, extension and generation.
files() - Method in class org.apache.lucene.index.SegmentInfo
 
files(Directory, boolean) - Method in class org.apache.lucene.index.SegmentInfos
Returns all file names referenced by SegmentInfo instances matching the provided Directory (ie files associated with any "external" segments are skipped).
FileSwitchDirectory - Class in org.apache.lucene.store
Expert: A Directory instance that switches files between two other Directory instances.
FileSwitchDirectory(Set<String>, Directory, Directory, boolean) - Constructor for class org.apache.lucene.store.FileSwitchDirectory
 
fill(CharacterUtils.CharacterBuffer, Reader) - Method in class org.apache.lucene.util.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.
fillAndGetIndex(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
Reads length as 1 or 2 byte vInt prefix, starting at start. * Note: this method does not support slices spanning across block borders.
fillAndGetStart(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
Reads length as 1 or 2 byte vInt prefix, starting at start and returns the start offset of the next part, suitable as start parameter on next call to sequentially read all BytesRef.
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.
fillSliceWithPrefix(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
Gets a slice out of PagedBytes starting at start, the length is read as 1 or 2 byte vInt prefix.
filter - Variable in class org.apache.lucene.search.ConstantScoreQuery
 
Filter - Class in org.apache.lucene.search
Abstract base class for restricting which documents may be returned during searching.
Filter() - Constructor for class org.apache.lucene.search.Filter
 
filter - Variable in class org.apache.lucene.search.FilterManager.FilterItem
Deprecated.
 
filterCleaner - Variable in class org.apache.lucene.search.FilterManager
Deprecated.
Cache cleaner that runs in a separate thread
FilteredDocIdSet - Class in org.apache.lucene.search
Abstract decorator class for a DocIdSet implementation that provides on-demand filtering/validation mechanism on a given DocIdSet.
FilteredDocIdSet(DocIdSet) - Constructor for class org.apache.lucene.search.FilteredDocIdSet
Constructor.
FilteredDocIdSetIterator - Class in org.apache.lucene.search
Abstract decorator class of a DocIdSetIterator implementation that provides on-demand filter/validation mechanism on an underlying DocIdSetIterator.
FilteredDocIdSetIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.FilteredDocIdSetIterator
Constructor.
FilteredQuery - Class in org.apache.lucene.search
A query that applies a filter to the results of another query.
FilteredQuery(Query, Filter) - Constructor for class org.apache.lucene.search.FilteredQuery
Constructs a new query which applies a filter to the results of the original query.
FilteredTermEnum - Class in org.apache.lucene.search
Abstract class for enumerating a subset of all terms.
FilteredTermEnum() - Constructor for class org.apache.lucene.search.FilteredTermEnum
 
FilterIndexReader - Class in org.apache.lucene.index
A FilterIndexReader contains another IndexReader, which it uses as its basic source of data, possibly transforming the data along the way or providing additional functionality.
FilterIndexReader(IndexReader) - Constructor for class org.apache.lucene.index.FilterIndexReader
Construct a FilterIndexReader based on the specified base reader.
FilterIndexReader.FilterTermDocs - Class in org.apache.lucene.index
Base class for filtering TermDocs implementations.
FilterIndexReader.FilterTermDocs(TermDocs) - Constructor for class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
 
FilterIndexReader.FilterTermEnum - Class in org.apache.lucene.index
Base class for filtering TermEnum implementations.
FilterIndexReader.FilterTermEnum(TermEnum) - Constructor for class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
 
FilterIndexReader.FilterTermPositions - Class in org.apache.lucene.index
Base class for filtering TermPositions implementations.
FilterIndexReader.FilterTermPositions(TermPositions) - Constructor for class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
 
FilteringTokenFilter - Class in org.apache.lucene.analysis
Abstract base class for TokenFilters that may remove tokens.
FilteringTokenFilter(boolean, TokenStream) - Constructor for class org.apache.lucene.analysis.FilteringTokenFilter
 
FilterManager - Class in org.apache.lucene.search
Deprecated.
used by remote package which is deprecated as well. You should use CachingWrapperFilter if you wish to cache Filters.
FilterManager() - Constructor for class org.apache.lucene.search.FilterManager
Deprecated.
Sets up the FilterManager singleton.
FilterManager.FilterCleaner - Class in org.apache.lucene.search
Deprecated.
Keeps the cache from getting too big.
FilterManager.FilterCleaner() - Constructor for class org.apache.lucene.search.FilterManager.FilterCleaner
Deprecated.
 
FilterManager.FilterItem - Class in org.apache.lucene.search
Deprecated.
Holds the filter and the last time the filter was used, to make LRU-based cache cleaning possible.
FilterManager.FilterItem(Filter) - Constructor for class org.apache.lucene.search.FilterManager.FilterItem
Deprecated.
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
Finds merges necessary to force-merge all deletes from the index.
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations is necessary in order to expunge all deletes from the index.
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedDeletesMerges(SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.LogMergePolicy
Returns the merges necessary to merge the index down to a specified number of segments.
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations is necessary in order to merge to <= the specified segment count.
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.NoMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findForcedMerges(SegmentInfos, int, Map<SegmentInfo, Boolean>) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findMerges(SegmentInfos) - Method in class org.apache.lucene.index.LogMergePolicy
Checks if any merges are now necessary and returns a MergePolicy.MergeSpecification if so.
findMerges(SegmentInfos) - Method in class org.apache.lucene.index.MergePolicy
Determine what set of merge operations are now necessary on the index.
findMerges(SegmentInfos) - Method in class org.apache.lucene.index.NoMergePolicy
 
findMerges(SegmentInfos) - Method in class org.apache.lucene.index.TieredMergePolicy
 
findMerges(SegmentInfos) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
 
findTargetArc(int, FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
Finds an arc leaving the incoming arc, replacing the arc in place.
finish() - Method in class org.apache.lucene.util.fst.Builder
Returns final FST.
finish() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
 
finishCommit() - Method in class org.apache.lucene.store.ChecksumIndexOutput
first - Variable in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
 
FIRST_LEVEL_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
 
FixedBitSet - Class in org.apache.lucene.util
BitSet of fixed length (numBits), backed by accessible (FixedBitSet.getBits()) long[], accessed with an int index, implementing Bits and DocIdSet.
FixedBitSet(int) - Constructor for class org.apache.lucene.util.FixedBitSet
 
FixedBitSet(FixedBitSet) - Constructor for class org.apache.lucene.util.FixedBitSet
Makes full copy.
fixIndex(CheckIndex.Status) - Method in class org.apache.lucene.index.CheckIndex
Repairs the index using previously returned result from CheckIndex.checkIndex().
FlagsAttribute - Interface in org.apache.lucene.analysis.tokenattributes
This attribute can be used to pass different flags down the Tokenizer chain, eg from one TokenFilter to another one.
FlagsAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
This attribute can be used to pass different flags down the tokenizer chain, eg from one TokenFilter to another one.
FlagsAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
 
flip(int, int) - Method in class org.apache.lucene.util.FixedBitSet
Flips a range of bits
flip(long) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit, expanding the set size if necessary
flip(long, long) - Method in class org.apache.lucene.util.OpenBitSet
Flips a range of bits, expanding the set size if necessary
flipAndGet(int) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit and returns the resulting bit value.
flipAndGet(long) - Method in class org.apache.lucene.util.OpenBitSet
flips a bit and returns the resulting bit value.
FLOAT - Static variable in class org.apache.lucene.search.function.FieldScoreQuery.Type
field values are interpreted as numeric float values.
FLOAT - Static variable in class org.apache.lucene.search.SortField
Sort using term values as encoded Floats.
FloatFieldSource - Class in org.apache.lucene.search.function
Expert: obtains float field values from the FieldCache using getFloats() and makes those values available as other numeric types, casting as needed.
FloatFieldSource(String) - Constructor for class org.apache.lucene.search.function.FloatFieldSource
Create a cached float field source with default string-to-float parser.
FloatFieldSource(String, FieldCache.FloatParser) - Constructor for class org.apache.lucene.search.function.FloatFieldSource
Create a cached float field source with a specific string-to-float parser.
floatToByte(float, int, int) - Static method in class org.apache.lucene.util.SmallFloat
Converts a 32 bit float to an 8 bit float.
floatToByte315(float) - Static method in class org.apache.lucene.util.SmallFloat
floatToByte(b, mantissaBits=3, zeroExponent=15)
smallest non-zero value = 5.820766E-10
largest value = 7.5161928E9
epsilon = 0.125
floatToByte52(float) - Static method in class org.apache.lucene.util.SmallFloat
floatToByte(b, mantissaBits=5, zeroExponent=2)
smallest nonzero value = 0.033203125
largest value = 1984.0
epsilon = 0.03125
floatToPrefixCoded(float) - Static method in class org.apache.lucene.util.NumericUtils
 
floatToSortableInt(float) - Static method in class org.apache.lucene.util.NumericUtils
Converts a float value to a sortable signed int.
floatVal(int) - Method in class org.apache.lucene.search.function.DocValues
Return doc value as a float.
flush() - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
flush(Map<String, String>) - Method in class org.apache.lucene.index.IndexReader
Deprecated.
Write support will be removed in Lucene 4.0.
flush(boolean, boolean, boolean) - Method in class org.apache.lucene.index.IndexWriter
NOTE: flushDocStores is ignored now (hardwired to true); this method is only here for backwards compatibility
flush(boolean, boolean) - Method in class org.apache.lucene.index.IndexWriter
Flush all in-memory buffered updates (adds and deletes) to the Directory.
flush() - Method in class org.apache.lucene.store.BufferedIndexOutput
Forces any buffered output to be written.
flush() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
flush() - Method in class org.apache.lucene.store.IndexOutput
Forces any buffered output to be written.
flush() - Method in class org.apache.lucene.store.RAMOutputStream
 
flushBuffer(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
Flushes the in-memory bufer to the given output, copying at most numBytes.
flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexOutput
Expert: implements buffer write.
flushBuffer(byte[], int, int) - Method in class org.apache.lucene.store.FSDirectory.FSIndexOutput
output methods:
foldToASCII(char[], int) - Method in class org.apache.lucene.analysis.ASCIIFoldingFilter
Converts characters above ASCII to their ASCII equivalents.
foldToASCII(char[], int, char[], int, int) - Static method in class org.apache.lucene.analysis.ASCIIFoldingFilter
Converts characters above ASCII to their ASCII equivalents.
forceMerge(int) - Method in class org.apache.lucene.index.IndexWriter
Forces merge policy to merge segments until there's <= maxNumSegments.
forceMerge(int, boolean) - Method in class org.apache.lucene.index.IndexWriter
Just like IndexWriter.forceMerge(int), except you can specify whether the call should block until all merging completes.
forceMergeDeletes(boolean) - Method in class org.apache.lucene.index.IndexWriter
Just like IndexWriter.forceMergeDeletes(), except you can specify whether the call should block until the operation completes.
forceMergeDeletes() - Method in class org.apache.lucene.index.IndexWriter
Forces merging of all segments that have deleted documents.
FORMAT - Static variable in class org.apache.lucene.index.SegmentInfos
The file format version, a negative number.
FORMAT_3_1 - Static variable in class org.apache.lucene.index.SegmentInfos
Each segment records the Lucene version that created it.
FORMAT_CHECKSUM - Static variable in class org.apache.lucene.index.SegmentInfos
This format adds a checksum at the end of the file to ensure all bytes were successfully written.
FORMAT_DEL_COUNT - Static variable in class org.apache.lucene.index.SegmentInfos
This format adds the deletion count for each segment.
FORMAT_DIAGNOSTICS - Static variable in class org.apache.lucene.index.SegmentInfos
This format adds optional per-segment String diagnostics storage, and switches userData to Map
FORMAT_HAS_PROX - Static variable in class org.apache.lucene.index.SegmentInfos
This format adds the boolean hasProx to record if any fields in the segment store prox information (ie, have omitTermFreqAndPositions==false)
FORMAT_HAS_VECTORS - Static variable in class org.apache.lucene.index.SegmentInfos
Each segment records whether it has term vectors
FORMAT_LOCKLESS - Static variable in class org.apache.lucene.index.SegmentInfos
This format adds details used for lockless commits.
FORMAT_MAXIMUM - Static variable in class org.apache.lucene.index.SegmentInfos
 
FORMAT_MINIMUM - Static variable in class org.apache.lucene.index.SegmentInfos
 
FORMAT_OMIT_POSITIONS - Static variable in class org.apache.lucene.index.FieldInfos
 
FORMAT_PRE - Static variable in class org.apache.lucene.index.FieldInfos
 
FORMAT_SHARED_DOC_STORE - Static variable in class org.apache.lucene.index.SegmentInfos
This format allows multiple segments to share a single vectors and stored fields file.
FORMAT_SINGLE_NORM_FILE - Static variable in class org.apache.lucene.index.SegmentInfos
This format adds a "hasSingleNormFile" flag into each segment info.
FORMAT_START - Static variable in class org.apache.lucene.index.FieldInfos
 
FORMAT_USER_DATA - Static variable in class org.apache.lucene.index.SegmentInfos
This format adds optional commit userData (String) storage.
freeBefore(int) - Method in class org.apache.lucene.util.RollingCharBuffer
Call this to notify us that no chars before this absolute position are needed anymore.
freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
Removes the given number of byte blocks from the buffer if possible.
freeze(Builder.UnCompiledNode<T>[], int, IntsRef) - Method in class org.apache.lucene.util.fst.Builder.FreezeTail
 
freeze(boolean) - Method in class org.apache.lucene.util.PagedBytes
Commits final byte[], trimming it if necessary and if trim=true
freq() - Method in class org.apache.lucene.index.AbstractAllTermDocs
 
freq() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
 
freq() - Method in class org.apache.lucene.index.MultipleTermPositions
 
freq() - Method in interface org.apache.lucene.index.TermDocs
Returns the frequency of the term within the current document.
freq() - Method in class org.apache.lucene.search.Scorer
Returns number of matches for the current document.
freq - Variable in class org.apache.lucene.search.spans.SpanScorer
 
freq() - Method in class org.apache.lucene.search.spans.SpanScorer
 
freq - Variable in class org.apache.lucene.search.spans.TermSpans
 
FREQ_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of freq postings file
FSDirectory - Class in org.apache.lucene.store
FSDirectory(File, LockFactory) - Constructor for class org.apache.lucene.store.FSDirectory
Create a new FSDirectory for the named location (ctor for subclasses).
FSDirectory.FSIndexOutput - Class in org.apache.lucene.store
 
FSDirectory.FSIndexOutput(FSDirectory, String) - Constructor for class org.apache.lucene.store.FSDirectory.FSIndexOutput
 
FSLockFactory - Class in org.apache.lucene.store
Base class for file system based locking implementation.
FSLockFactory() - Constructor for class org.apache.lucene.store.FSLockFactory
 
FST<T> - Class in org.apache.lucene.util.fst
Represents an finite state machine (FST), using a compact byte[] format.
FST(DataInput, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.FST
Load a previously saved FST.
FST.Arc<T> - Class in org.apache.lucene.util.fst
Represents a single arc.
FST.Arc() - Constructor for class org.apache.lucene.util.fst.FST.Arc
 
FST.BytesReader - Class in org.apache.lucene.util.fst
Reads the bytes from this FST.
FST.BytesReader(byte[], int) - Constructor for class org.apache.lucene.util.fst.FST.BytesReader
 
FST.INPUT_TYPE - Enum in org.apache.lucene.util.fst
Specifies allowed range of each int input label for this FST.
fsync(String) - Method in class org.apache.lucene.store.FSDirectory
 
function - Variable in class org.apache.lucene.search.payloads.PayloadNearQuery
 
function - Variable in class org.apache.lucene.search.payloads.PayloadTermQuery
 
FUZZY_SLOP - Static variable in interface org.apache.lucene.queryParser.QueryParserConstants
RegularExpression Id.
FuzzyQuery - Class in org.apache.lucene.search
Implements the fuzzy search query.
FuzzyQuery(Term, float, int, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
Create a new FuzzyQuery that will match terms with a similarity of at least minimumSimilarity to term.
FuzzyQuery(Term, float, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
FuzzyQuery(Term, float) - Constructor for class org.apache.lucene.search.FuzzyQuery
FuzzyQuery(Term) - Constructor for class org.apache.lucene.search.FuzzyQuery
FuzzyTermEnum - Class in org.apache.lucene.search
Subclass of FilteredTermEnum for enumerating all terms that are similar to the specified filter term.
FuzzyTermEnum(IndexReader, Term) - Constructor for class org.apache.lucene.search.FuzzyTermEnum
Creates a FuzzyTermEnum with an empty prefix and a minSimilarity of 0.5f.
FuzzyTermEnum(IndexReader, Term, float) - Constructor for class org.apache.lucene.search.FuzzyTermEnum
Creates a FuzzyTermEnum with an empty prefix.
FuzzyTermEnum(IndexReader, Term, float, int) - Constructor for class org.apache.lucene.search.FuzzyTermEnum
Constructor for enumeration of all terms from specified reader which share a prefix of length prefixLength with term and which have a fuzzy similarity > minSimilarity.

G

gatherSubReaders(List<IndexReader>, IndexReader) - Method in class org.apache.lucene.search.IndexSearcher
 
gatherSubReaders(List<IndexReader>, IndexReader) - Static method in class org.apache.lucene.util.ReaderUtil
Gathers sub-readers from reader into a List.
GEN_EXTENSION - Static variable in class org.apache.lucene.index.IndexFileNames
Extension of gen file
generateParseException() - Method in class org.apache.lucene.queryParser.QueryParser
Generate ParseException.
generationFromSegmentsFileName(String) - Static method in class org.apache.lucene.index.SegmentInfos
Parse the generation off the segments file name and return it.
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(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(Reader) - Static method in class org.apache.lucene.analysis.CharReader
 
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(boolean, SegmentInfo, int) - Static method in class org.apache.lucene.index.SegmentReader
 
get(boolean, Directory, SegmentInfo, int, boolean, int) - Static method in class org.apache.lucene.index.SegmentReader
 
get() - Static method in class org.apache.lucene.LucenePackage
Return Lucene's package, including version information.
get(int) - Method in interface org.apache.lucene.util.Bits
 
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.BitVector
Returns true if bit is one and false if it is zero.
get(int, BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
Populates and returns a BytesRef with the bytes for the given ord.
get() - Method in class org.apache.lucene.util.CloseableThreadLocal
 
get() - Method in class org.apache.lucene.util.Counter
Returns the counters current value
get(K) - Method in class org.apache.lucene.util.DoubleBarrelLRUCache
 
get(int) - Method in class org.apache.lucene.util.FixedBitSet
 
get(long) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
get(long, long) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
get(FST<T>, IntsRef) - Static method in class org.apache.lucene.util.fst.Util
Looks up the output for this input, or null if the input is not accepted.
get(FST<T>, BytesRef) - Static method in class org.apache.lucene.util.fst.Util
Looks up the output for this input, or null if the input is not accepted
get(int) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index.
get(long) - Method in class org.apache.lucene.util.OpenBitSet
Returns true or false for the specified bit index
get(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
 
get(int) - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
 
get(int) - Method in class org.apache.lucene.util.RollingCharBuffer
 
get(int, int) - Method in class org.apache.lucene.util.RollingCharBuffer
 
get() - Method in class org.apache.lucene.util.SetOnce
Returns the object set by SetOnce.set(Object).
get(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
 
getAllowLeadingWildcard() - Method in class org.apache.lucene.queryParser.QueryParser
 
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
Returns the default analyzer to use for indexing documents.
getAnalyzer() - Method in class org.apache.lucene.queryParser.QueryParser
 
getAndClear(int) - Method in class org.apache.lucene.util.FixedBitSet
 
getAndSet(int) - Method in class org.apache.lucene.util.BitVector
Sets the value of bit to true, and returns true if bit was already set
getAndSet(int) - Method in class org.apache.lucene.util.FixedBitSet
 
getAndSet(int) - Method in class org.apache.lucene.util.OpenBitSet
Sets a bit and returns the previous value.
getAndSet(long) - Method in class org.apache.lucene.util.OpenBitSet
Sets a bit and returns the previous value.
getArcCount() - Method in class org.apache.lucene.util.fst.FST
 
getArcWithOutputCount() - Method in class org.apache.lucene.util.fst.FST
 
getArray() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getArray() - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
Expert: if the bit-width of this reader matches one of java's native types, returns the underlying array (ie, byte[], short[], int[], long[]); else, returns null.
getArray() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
 
getAttribute(Class<A>) - Method in class org.apache.lucene.util.AttributeSource
The caller must pass in a Class<?
getAttributeClassesIterator() - Method in class org.apache.lucene.util.AttributeSource
Returns a new iterator that iterates the attribute classes in the same order they were added in.
getAttributeFactory() - Method in class org.apache.lucene.util.AttributeSource
returns the used AttributeFactory.
getAttributeImplsIterator() - Method in class org.apache.lucene.util.AttributeSource
Returns a new iterator that iterates all unique Attribute implementations.
getAttributeSource() - Method in class org.apache.lucene.index.FieldInvertState
 
getAutoGeneratePhraseQueries() - Method in class org.apache.lucene.queryParser.QueryParser
 
getAverageValue() - Method in class org.apache.lucene.search.function.DocValues
Returns the average of all values or Float.NaN if this DocValues instance does not contain any value. * This operation is optional
getBeginColumn() - Method in interface org.apache.lucene.queryParser.CharStream
Returns the column number of the first character for current token (being matched after the last call to BeginTOken).
getBeginColumn() - Method in class org.apache.lucene.queryParser.FastCharStream
 
getBeginLine() - Method in interface org.apache.lucene.queryParser.CharStream
Returns the line number of the first character for current token (being matched after the last call to BeginTOken).
getBeginLine() - Method in class org.apache.lucene.queryParser.FastCharStream
 
getBinaryLength() - Method in class org.apache.lucene.document.AbstractField
Returns length of byte[] segment that is used as value, if Field is not binary returned value is undefined
getBinaryLength() - Method in interface org.apache.lucene.document.Fieldable
Returns length of byte[] segment that is used as value, if Field is not binary returned value is undefined
getBinaryOffset() - Method in class org.apache.lucene.document.AbstractField
Returns offset into byte[] segment that is used as value, if Field is not binary returned value is undefined
getBinaryOffset() - Method in interface org.apache.lucene.document.Fieldable
Returns offset into byte[] segment that is used as value, if Field is not binary returned value is undefined
getBinaryValue() - Method in class org.apache.lucene.document.AbstractField
Return the raw byte[] for the binary field.
getBinaryValue(byte[]) - Method in class org.apache.lucene.document.AbstractField
 
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.
getBinaryValue() - Method in interface org.apache.lucene.document.Fieldable
Return the raw byte[] for the binary field.
getBinaryValue(byte[]) - Method in interface org.apache.lucene.document.Fieldable
Return the raw byte[] for the binary field.
getBinaryValue(byte[]) - Method in class org.apache.lucene.document.NumericField
Returns always null for numeric fields
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.
getBit(int) - Method in class org.apache.lucene.util.OpenBitSet
returns 1 if the bit is set, 0 if not.
getBits() - Method in class org.apache.lucene.util.FixedBitSet
Expert.
getBits() - Method in class org.apache.lucene.util.OpenBitSet
Expert: returns the long[] storing the bits
getBitSet() - Method in class org.apache.lucene.util.DocIdBitSet
Returns the underlying BitSet.
getBitsPerValue() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getBitsPerValue() - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
 
getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
 
getBlockEnds() - Method in class org.apache.lucene.util.PagedBytes.Reader
 
getBlocks() - Method in class org.apache.lucene.util.PagedBytes.Reader
 
getBooleanQuery(List<BooleanClause>) - Method in class org.apache.lucene.queryParser.QueryParser
Factory method for generating query, given a set of clauses.
getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.apache.lucene.queryParser.QueryParser
Factory method for generating query, given a set of clauses.
getBoost() - Method in class org.apache.lucene.document.AbstractField
Returns the boost factor for hits for this field.
getBoost() - Method in class org.apache.lucene.document.Document
Returns, at indexing time, the boost factor as set by Document.setBoost(float).
getBoost() - Method in interface org.apache.lucene.document.Fieldable
Returns the boost factor for hits for this field.
getBoost() - Method in class org.apache.lucene.index.FieldInvertState
Get boost value.
getBoost() - Method in class org.apache.lucene.search.Query
Gets the boost for this clause.
getBottomSlot() - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
getBuffer(int) - Method in class org.apache.lucene.store.RAMFile
 
getBuffer() - Method in class org.apache.lucene.util.CharacterUtils.CharacterBuffer
Returns the internal buffer
getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexInput
Returns buffer size.
getByOutput(FST<Long>, long) - Static method in class org.apache.lucene.util.fst.Util
Reverse lookup (lookup by output instead of by input), in the special case when your FSTs outputs are strictly ascending.
getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
 
getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
 
getByteBlock() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
 
getBytes(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as a single byte and returns an array of size reader.maxDoc() of the value each document has in the given field.
getBytes(IndexReader, String, FieldCache.ByteParser) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as bytes and returns an array of size reader.maxDoc() of the value each document has in the given field.
getBytes(IndexReader, String, FieldCache.ByteParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as bytes and returns an array of size reader.maxDoc() of the value each document has in the given field.
getByteSize() - Method in class org.apache.lucene.util.SortedVIntList
 
getBytesReader(int) - Method in class org.apache.lucene.util.fst.FST
 
getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.ByteFieldSource
 
getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.FieldCacheSource
Return cached DocValues for input field and reader.
getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.FloatFieldSource
 
getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.IntFieldSource
 
getCachedFieldValues(FieldCache, String, IndexReader) - Method in class org.apache.lucene.search.function.ShortFieldSource
 
getCacheEntries() - Method in interface org.apache.lucene.search.FieldCache
EXPERT: Generates an array of CacheEntry objects representing all items currently in the FieldCache.
getCacheEntries() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
CacheEntry objects which suggest a problem
getCacheType() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getCalibrateSizeByDeletes() - Method in class org.apache.lucene.index.LogMergePolicy
Returns true if the segment size should be calibrated by the number of deletes when choosing segments for merge.
getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexInput
 
getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
getClauses() - Method in class org.apache.lucene.search.BooleanQuery
Returns the set of clauses in this query.
getClauses() - Method in class org.apache.lucene.search.spans.SpanNearQuery
Return the clauses whose spans are matched.
getClauses() - Method in class org.apache.lucene.search.spans.SpanOrQuery
Return the clauses whose spans are matched.
getCollator() - Method in class org.apache.lucene.search.TermRangeFilter
Returns the collator used to determine range inclusion, if any.
getCollator() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the collator used to determine range inclusion, if any.
getColumn() - Method in interface org.apache.lucene.queryParser.CharStream
Deprecated.
getColumn() - Method in class org.apache.lucene.queryParser.FastCharStream
 
getCommitUserData() - Method in class org.apache.lucene.index.FilterIndexReader
 
getCommitUserData(Directory) - Static method in class org.apache.lucene.index.IndexReader
Deprecated.
Call IndexReader.getIndexCommit() on an open IndexReader, and then call IndexCommit.getUserData().
getCommitUserData() - Method in class org.apache.lucene.index.IndexReader
getComparator() - Method in class org.apache.lucene.index.FieldSortedTermVectorMapper
 
getComparator(int, int) - Method in class org.apache.lucene.search.SortField
Returns the FieldComparator to use for sorting.
getComparator() - Method in interface org.apache.lucene.util.BytesRefIterator
Return the BytesRef Comparator used to sort terms provided by the iterator.
getComparators() - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getComparatorSource() - Method in class org.apache.lucene.search.SortField
Returns the FieldComparatorSource used for custom sorting
getConfig() - Method in class org.apache.lucene.index.IndexWriter
getCoreCacheKey() - Method in class org.apache.lucene.index.FilterIndexReader
If the subclass of FilteredIndexReader modifies the contents of the FieldCache, you must override this method to provide a different key
getCoreCacheKey() - Method in class org.apache.lucene.index.IndexReader
Expert
getCoreCacheKey() - Method in class org.apache.lucene.index.SegmentReader
 
getCurrentLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
getCurrentLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
getCurrentMerge() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
 
getCurrentSearchingGen() - Method in class org.apache.lucene.search.NRTManager
Returns generation of current searcher.
getCurrentVersion(Directory) - Static method in class org.apache.lucene.index.IndexReader
Deprecated.
Use IndexReader.getVersion() on an opened IndexReader.
getCustom() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getCustomScoreProvider(IndexReader) - Method in class org.apache.lucene.search.function.CustomScoreQuery
Returns a CustomScoreProvider that calculates the custom scores for the given IndexReader.
getData() - Method in class org.apache.lucene.index.Payload
Returns a reference to the underlying byte array that holds this payloads data.
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.
getDataType() - Method in class org.apache.lucene.document.NumericField
Returns the data type of the current value, null if not yet set.
getDateResolution(String) - Method in class org.apache.lucene.queryParser.QueryParser
Returns the date resolution that is used by RangeQueries for the given field.
getDecodedLength(CharBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.getDecodedLength(char[], int, int) instead. This method will be removed in Lucene 4.0
getDecodedLength(char[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Returns the number of bytes required to decode the given char sequence.
getDecodingReader(InputStream, Charset) - Static method in class org.apache.lucene.util.IOUtils
Wrapping the given InputStream in a reader using a CharsetDecoder.
getDecodingReader(File, Charset) - Static method in class org.apache.lucene.util.IOUtils
Opens a Reader for the given File using a CharsetDecoder.
getDecodingReader(Class<?>, String, Charset) - Static method in class org.apache.lucene.util.IOUtils
Opens a Reader for the given resource using a CharsetDecoder.
getDefault() - Static method in class org.apache.lucene.search.Similarity
Return the default Similarity implementation used by indexing and search code.
getDefaultGenLookahedCount() - Static method in class org.apache.lucene.index.SegmentInfos
 
getDefaultInfoStream() - Static method in class org.apache.lucene.index.IndexWriter
Returns the current default infoStream for newly instantiated IndexWriters.
getDefaultOperator() - Method in class org.apache.lucene.queryParser.QueryParser
Gets implicit operator setting, which will be either AND_OPERATOR or OR_OPERATOR.
getDefaultWriteLockTimeout() - Static method in class org.apache.lucene.index.IndexWriter
getDefaultWriteLockTimeout() - Static method in class org.apache.lucene.index.IndexWriterConfig
Returns the default write lock timeout for newly instantiated IndexWriterConfigs.
getDelCount() - Method in class org.apache.lucene.index.SegmentInfo
 
getDeletesCacheKey() - Method in class org.apache.lucene.index.FilterIndexReader
If the subclass of FilteredIndexReader modifies the deleted docs, you must override this method to provide a different key
getDeletesCacheKey() - Method in class org.apache.lucene.index.IndexReader
Expert.
getDeletesCacheKey() - Method in class org.apache.lucene.index.SegmentReader
 
getDelFileName() - Method in class org.apache.lucene.index.SegmentInfo
 
getDescription() - Method in class org.apache.lucene.search.Explanation
A description of this explanation node.
getDetails() - Method in class org.apache.lucene.search.Explanation
The sub-nodes of this explanation node.
getDiagnostics() - Method in class org.apache.lucene.index.SegmentInfo
 
getDirectory() - Method in class org.apache.lucene.index.CompoundFileWriter
Returns the directory of the compound file.
getDirectory() - Method in class org.apache.lucene.index.IndexCommit
Returns the Directory for the index.
getDirectory() - Method in class org.apache.lucene.index.IndexWriter
Returns the Directory used by this index.
getDirectory() - Method in exception org.apache.lucene.index.MergePolicy.MergeException
Returns the Directory of the index that hit the exception.
getDirectory() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
getDirectory() - Method in class org.apache.lucene.store.FSDirectory
 
getDirProcessor(Directory) - Method in class org.apache.lucene.index.PayloadProcessorProvider
Deprecated.
Use PayloadProcessorProvider.getReaderProcessor(org.apache.lucene.index.IndexReader) instead. You can still select by Directory, if you retrieve the underlying directory from IndexReader.directory().
getDiscountOverlaps() - Method in class org.apache.lucene.search.DefaultSimilarity
 
getDoc() - Method in class org.apache.lucene.search.SpanFilterResult.PositionInfo
 
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.CachingSpanFilter
 
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.CachingWrapperFilter
 
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.FieldCacheRangeFilter
This method is implemented for each data type
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.FieldCacheTermsFilter
 
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.FieldValueFilter
 
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.Filter
Creates a DocIdSet enumerating the documents that should be permitted in search results.
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Returns a DocIdSet with documents that should be permitted in search results.
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.QueryWrapperFilter
 
getDocIdSet() - Method in class org.apache.lucene.search.SpanFilterResult
Returns the docIdSet
getDocIdSet(IndexReader) - Method in class org.apache.lucene.search.SpanQueryFilter
 
getDocStoreIsCompoundFile() - Method in class org.apache.lucene.index.SegmentInfo
 
getDocStoreOffset() - Method in class org.apache.lucene.index.SegmentInfo
 
getDocStoreSegment() - Method in class org.apache.lucene.index.SegmentInfo
 
getDocsWithField(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field and returns a bit set at the size of reader.maxDoc(), with turned on bits for each docid that does have a value for this field.
getDoubles(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as integers and returns an array of size reader.maxDoc() of the value each document has in the given field.
getDoubles(IndexReader, String, FieldCache.DoubleParser) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as doubles and returns an array of size reader.maxDoc() of the value each document has in the given field.
getDoubles(IndexReader, String, FieldCache.DoubleParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as doubles and returns an array of size reader.maxDoc() of the value each document has in the given field.
getEmptyOutput() - Method in class org.apache.lucene.util.fst.FST
 
getEnablePositionIncrements() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
 
getEnablePositionIncrements() - Method in class org.apache.lucene.queryParser.QueryParser
 
getEnablePositionIncrementsVersionDefault(Version) - Static method in class org.apache.lucene.analysis.StopFilter
getEncodedLength(ByteBuffer) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Deprecated.
Use IndexableBinaryStringTools.getEncodedLength(byte[], int, int) instead. This method will be removed in Lucene 4.0
getEncodedLength(byte[], int, int) - Static method in class org.apache.lucene.util.IndexableBinaryStringTools
Returns the number of chars required to encode the given bytes.
getEnd() - Method in class org.apache.lucene.search.SpanFilterResult.StartEnd
 
getEnd() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
getEndColumn() - Method in interface org.apache.lucene.queryParser.CharStream
Returns the column number of the last character for current token (being matched after the last call to BeginTOken).
getEndColumn() - Method in class org.apache.lucene.queryParser.FastCharStream
 
getEndLine() - Method in interface org.apache.lucene.queryParser.CharStream
Returns the line number of the last character for current token (being matched after the last call to BeginTOken).
getEndLine() - Method in class org.apache.lucene.queryParser.FastCharStream
 
getEndOffset() - Method in class org.apache.lucene.index.TermVectorOffsetInfo
The accessor for the ending offset for the term
getEnum(IndexReader) - Method in class org.apache.lucene.search.FuzzyQuery
 
getEnum(IndexReader) - Method in class org.apache.lucene.search.MultiTermQuery
Construct the enumeration to be used, expanding the pattern term.
getEnum(IndexReader) - Method in class org.apache.lucene.search.NumericRangeQuery
 
getEnum(IndexReader) - Method in class org.apache.lucene.search.PrefixQuery
 
getEnum(IndexReader) - Method in class org.apache.lucene.search.TermRangeQuery
 
getEnum(IndexReader) - Method in class org.apache.lucene.search.WildcardQuery
 
getEstimatedSize() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
The most recently estimated size of the value, null unless estimateSize has been called.
getExclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
Return the SpanQuery whose matches must not overlap those returned.
getExtension(String) - Static method in class org.apache.lucene.store.FileSwitchDirectory
Utility method to return a file's extension.
getField(String) - Method in class org.apache.lucene.document.Document
Deprecated.
use Document.getFieldable(java.lang.String) instead and cast depending on data type.
getField() - Method in interface org.apache.lucene.index.TermFreqVector
The Fieldable name.
getField() - Method in class org.apache.lucene.index.TermVectorEntry
 
getField() - Method in class org.apache.lucene.queryParser.QueryParser
 
getField() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the field name for this filter
getField() - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
getField() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns the field name for this filter
getField() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns the field name for this query
getField() - Method in class org.apache.lucene.search.QueryTermVector
 
getField() - Method in class org.apache.lucene.search.SortField
Returns the name of the field.
getField() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
getField() - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
getField() - Method in class org.apache.lucene.search.spans.SpanQuery
Returns the name of the field matched by this query.
getField() - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
getField() - Method in class org.apache.lucene.search.TermRangeFilter
Returns the field name for this filter
getField() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the field name for this query
getFieldable(String) - Method in class org.apache.lucene.document.Document
Returns a field with the given name if any exist in this document, or null.
getFieldables(String) - Method in class org.apache.lucene.document.Document
Returns an array of Fieldables with the given name.
getFieldCache() - Method in class org.apache.lucene.search.FieldCacheTermsFilter
 
getFieldInfos() - Method in class org.apache.lucene.index.FilterIndexReader
 
getFieldInfos() - Method in class org.apache.lucene.index.IndexReader
Get the FieldInfos describing all fields in this reader.
getFieldInfos() - Method in class org.apache.lucene.index.MultiReader
 
getFieldInfos() - Method in class org.apache.lucene.index.ParallelReader
 
getFieldInfos() - Method in class org.apache.lucene.index.SegmentReader
 
getFieldName() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
getFieldQuery(String, String) - Method in class org.apache.lucene.queryParser.QueryParser
getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryParser.QueryParser
 
getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryParser.QueryParser
Base implementation delegates to QueryParser.getFieldQuery(String,String,boolean).
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
Deprecated.
use Document.getFieldable(java.lang.String) instead and cast depending on data type.
getFieldToTerms() - Method in class org.apache.lucene.index.FieldSortedTermVectorMapper
Get the mapping between fields and terms, sorted by the comparator
getFieldToTerms() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper
Get the mapping between fields and terms, sorted by the comparator
getFile() - Method in class org.apache.lucene.store.FSDirectory
Deprecated.
getFileNames() - Method in class org.apache.lucene.index.IndexCommit
Returns all index files referenced by this commit point.
getFileNames() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexOutput
Returns the current position in this file, where the next write will occur.
getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexInput
 
getFilePointer() - Method in class org.apache.lucene.store.ChecksumIndexOutput
 
getFilePointer() - Method in class org.apache.lucene.store.IndexInput
Returns the current position in this file, where the next read will occur.
getFilePointer() - Method in class org.apache.lucene.store.IndexOutput
Returns the current position in this file, where the next write will occur.
getFilePointer() - Method in class org.apache.lucene.store.RAMInputStream
 
getFilePointer() - Method in class org.apache.lucene.store.RAMOutputStream
 
getFilter() - Static method in class org.apache.lucene.index.IndexFileNameFilter
 
getFilter() - Method in class org.apache.lucene.search.ConstantScoreQuery
Returns the encapsulated filter, returns null if a query is wrapped.
getFilter() - Method in class org.apache.lucene.search.FilteredQuery
 
getFilter(Filter) - Method in class org.apache.lucene.search.FilterManager
Deprecated.
Returns the cached version of the filter.
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
getFlags() - Method in class org.apache.lucene.analysis.Token

Get the bitset for any bits that have been set.

getFlags() - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute

Get the bitset for any bits that have been set.

getFlags() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl

Get the bitset for any bits that have been set.

getFloats(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as floats and returns an array of size reader.maxDoc() of the value each document has in the given field.
getFloats(IndexReader, String, FieldCache.FloatParser) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as floats and returns an array of size reader.maxDoc() of the value each document has in the given field.
getFloats(IndexReader, String, FieldCache.FloatParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as floats and returns an array of size reader.maxDoc() of the value each document has in the given field.
getFloorSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
 
getForceMergeDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
 
getFormat() - Method in class org.apache.lucene.index.SegmentInfos
 
getFrequency() - Method in class org.apache.lucene.index.TermVectorEntry
 
getFuzzyMinSim() - Method in class org.apache.lucene.queryParser.QueryParser
Get the minimal similarity for fuzzy queries.
getFuzzyPrefixLength() - Method in class org.apache.lucene.queryParser.QueryParser
Get the prefix length for fuzzy queries.
getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryParser.QueryParser
Factory method for generating a query (similar to QueryParser.getWildcardQuery(java.lang.String, java.lang.String)).
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
 
getGeneration() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
getGeneration() - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
getGlobalCounter() - Static method in class org.apache.lucene.search.TimeLimitingCollector
Returns the global TimerThreads Counter Invoking this creates may create a new instance of TimeLimitingCollector.TimerThread iff the global TimeLimitingCollector.TimerThread has never been accessed before.
getGlobalTimerThread() - Static method in class org.apache.lucene.search.TimeLimitingCollector
getHasProx() - Method in class org.apache.lucene.index.SegmentInfo
 
getHasVectors() - Method in class org.apache.lucene.index.SegmentInfo
 
getHeapArray() - Method in class org.apache.lucene.util.PriorityQueue
This method returns the internal heap array as Object[].
getIdf() - Method in class org.apache.lucene.search.Explanation.IDFExplanation
 
GetImage() - Method in interface org.apache.lucene.queryParser.CharStream
Returns a string made up of characters from the marked token beginning to the current buffer position.
GetImage() - Method in class org.apache.lucene.queryParser.FastCharStream
 
getImplementationDistance(Class<? extends C>) - Method in class org.apache.lucene.util.VirtualMethod
Returns the distance from the baseClass in which this method is overridden/implemented in the inheritance path between baseClass and the given subclass subclazz.
getInclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
Return the SpanQuery whose matches are filtered.
getIndexCommit() - Method in class org.apache.lucene.index.FilterIndexReader
 
getIndexCommit() - Method in class org.apache.lucene.index.IndexReader
Expert: return the IndexCommit that this reader has opened.
getIndexCommit() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the IndexCommit as specified in IndexWriterConfig.setIndexCommit(IndexCommit) or the default, null which specifies to open the latest index commit point.
getIndexDeletionPolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
getIndexedFields(IndexReader) - Static method in class org.apache.lucene.util.ReaderUtil
 
getIndexOptions() - Method in class org.apache.lucene.document.AbstractField
 
getIndexOptions() - Method in interface org.apache.lucene.document.Fieldable
 
getIndexReader() - Method in class org.apache.lucene.search.IndexSearcher
Return the IndexReader this searches.
getIndexWriter() - Method in class org.apache.lucene.search.NRTManager.TrackingIndexWriter
 
getInfoStream() - Method in class org.apache.lucene.index.IndexWriter
Returns the current infoStream in use by this writer.
getInfoStream() - Static method in class org.apache.lucene.index.SegmentInfos
 
getInfoStream() - Method in interface org.apache.lucene.search.FieldCache
getInputType() - Method in class org.apache.lucene.util.fst.FST
 
getInstance() - Static method in class org.apache.lucene.search.FilterManager
Deprecated.
 
getInstance(Version) - Static method in class org.apache.lucene.util.CharacterUtils
Returns a CharacterUtils implementation according to the given Version instance.
getInts(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as integers and returns an array of size reader.maxDoc() of the value each document has in the given field.
getInts(IndexReader, String, FieldCache.IntParser) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as integers and returns an array of size reader.maxDoc() of the value each document has in the given field.
getInts(IndexReader, String, FieldCache.IntParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as integers and returns an array of size reader.maxDoc() of the value each document has in the given field.
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.
getLastCumulativeDiff() - Method in class org.apache.lucene.analysis.BaseCharFilter
 
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
 
getLastModified() - Method in class org.apache.lucene.store.RAMFile
 
getLastOutput(int) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
 
getLength() - Method in class org.apache.lucene.index.FieldInvertState
Get total number of terms in this field.
getLength() - Method in class org.apache.lucene.store.RAMFile
 
getLength() - Method in class org.apache.lucene.util.CharacterUtils.CharacterBuffer
Return the length of the data in the internal buffer starting at CharacterUtils.CharacterBuffer.getOffset()
getLimit() - Method in class org.apache.lucene.index.IndexWriter.MaxFieldLength
Deprecated.
 
getLine() - Method in interface org.apache.lucene.queryParser.CharStream
Deprecated.
getLine() - Method in class org.apache.lucene.queryParser.FastCharStream
 
getLocale() - Method in class org.apache.lucene.queryParser.QueryParser
Returns current locale, allowing access by subclasses.
getLocale() - Method in class org.apache.lucene.search.SortField
Returns the Locale by which term values are interpreted.
getLockDir() - Method in class org.apache.lucene.store.FSLockFactory
Retrieve the lock directory.
getLockFactory() - Method in class org.apache.lucene.store.Directory
Get the LockFactory that this Directory instance is using for its locking implementation.
getLockFactory() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
getLockID() - Method in class org.apache.lucene.store.Directory
Return a string identifier that uniquely differentiates this Directory instance from other Directory instances.
getLockID() - Method in class org.apache.lucene.store.FSDirectory
 
getLockID() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
getLockPrefix() - Method in class org.apache.lucene.store.LockFactory
Get the prefix in use for all locks created in this LockFactory.
getLongs(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as longs and returns an array of size reader.maxDoc() of the value each document has in the given field.
getLongs(IndexReader, String, FieldCache.LongParser) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as longs and returns an array of size reader.maxDoc() of the value each document has in the given field.
getLongs(IndexReader, String, FieldCache.LongParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as longs and returns an array of size reader.maxDoc() of the value each document has in the given field.
getLowercaseExpandedTerms() - Method in class org.apache.lucene.queryParser.QueryParser
 
getLowerTerm() - Method in class org.apache.lucene.search.TermRangeFilter
Returns the lower value of this range filter
getLowerTerm() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the lower value of this range query
getLowerVal() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the lower value of this range filter
getMap() - Method in class org.apache.lucene.util.MapOfSets
 
getMappedStateCount() - Method in class org.apache.lucene.util.fst.Builder
 
getMaskedQuery() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
getMatch() - Method in class org.apache.lucene.search.ComplexExplanation
The match status of this explanation node.
getMatch() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
getMax() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns the upper value of this range filter
getMax() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns the upper value of this range query
getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.IndexWriter
getMaxBufferedDeleteTerms() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the number of buffered deleted terms that will trigger a flush if enabled.
getMaxBufferedDocs() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
getMaxBufferedDocs() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the number of buffered added documents that will trigger a flush if enabled.
getMaxChunkSize() - Method in class org.apache.lucene.store.MMapDirectory
Returns the current mmap chunk size.
getMaxClauseCount() - Static method in class org.apache.lucene.search.BooleanQuery
Return the maximum number of clauses permitted, 1024 by default.
getMaxFieldLength() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
use LimitTokenCountAnalyzer to limit number of tokens.
getMaxMergeAtOnce() - Method in class org.apache.lucene.index.TieredMergePolicy
 
getMaxMergeAtOnceExplicit() - Method in class org.apache.lucene.index.TieredMergePolicy
 
getMaxMergeCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
getMaxMergeDocs() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
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
 
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.
getMaxMergeMBForOptimize() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
getMaxScore() - Method in class org.apache.lucene.search.TopDocs
Returns the maximum score value encountered.
getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
getMaxSize() - Method in class org.apache.lucene.search.TopTermsRewrite
return the maximum size of the priority queue (for boolean rewrites this is BooleanQuery#getMaxClauseCount).
getMaxTermFrequency() - Method in class org.apache.lucene.index.FieldInvertState
Get the maximum term-frequency encountered for any term in the field.
getMaxThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
 
getMaxThreadStates() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the max number of simultaneous threads that may be indexing documents at once in IndexWriter.
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
 
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
 
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
 
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
 
getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
getMaxValue() - Method in class org.apache.lucene.search.function.DocValues
Returns the maximum of all values or Float.NaN if this DocValues instance does not contain any value.
getMaxValue() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
 
getMergedFieldInfos(IndexReader) - Static method in class org.apache.lucene.util.ReaderUtil
Call this to get the (merged) FieldInfos for a composite reader
getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriter
getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the current merged segment warmer.
getMergeFactor() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
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.
getMergePolicy() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
getMergePolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the current MergePolicy in use by this writer.
getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriterConfig
getMergeScheduler() - Method in class org.apache.lucene.store.NRTCachingDirectory
 
getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Create and return a new MergeThread
getMergeThreadPriority() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
Return the priority that merge threads run at.
getMergingSegments() - Method in class org.apache.lucene.index.IndexWriter
Expert: to be used by a MergePolicy to avoid selecting merges for segments already being merged.
getMessage() - Method in error org.apache.lucene.queryParser.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMilliseconds() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Get the timer value in milliseconds.
getMin() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns the lower value of this range filter
getMin() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns the lower value of this range query
getMinimumNumberShouldMatch() - Method in class org.apache.lucene.search.BooleanQuery
Gets the minimum number of the optional BooleanClauses which must be satisfied.
getMinMergeDocs() - Method in class org.apache.lucene.index.LogDocMergePolicy
Get the minimum size for a segment to remain un-merged.
getMinMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
Get the minimum size for a segment to remain un-merged.
getMinSimilarity() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the minimum similarity that is required for this query to match.
getMinValue() - Method in class org.apache.lucene.search.function.DocValues
Returns the minimum of all values or Float.NaN if this DocValues instance does not contain any value.
getMsg() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
Description of hte insane behavior
getMultiTermRewriteMethod() - Method in class org.apache.lucene.queryParser.QueryParser
 
getMutable() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
getMutable(int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Create a packed integer array with the given amount of values initialized to 0. the valueCount and the bitsPerValue cannot be changed after creation.
getName() - Method in class org.apache.lucene.index.CompoundFileWriter
Returns the name of the compound file.
getNextFixedSize(int) - Static method in class org.apache.lucene.util.packed.PackedInts
Rounds bitsPerValue up to 8, 16, 32 or 64.
getNextMerge() - Method in class org.apache.lucene.index.IndexWriter
Expert: the MergeScheduler calls this method to retrieve the next merge requested by the MergePolicy
getNextSegmentFileName() - Method in class org.apache.lucene.index.SegmentInfos
Get the next segments_N filename that will be written.
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.
getNextToken() - Method in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
getNextToken() - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
Deprecated.
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
getNextToken() - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
Deprecated.
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
getNextToken() - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
Deprecated.
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
getNextToken() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
getNextToken() - Method in class org.apache.lucene.queryParser.QueryParser
Get the next Token.
getNextToken() - Method in class org.apache.lucene.queryParser.QueryParserTokenManager
Get the next Token.
getNoCFSRatio() - Method in class org.apache.lucene.index.LogMergePolicy
 
getNoCFSRatio() - Method in class org.apache.lucene.index.TieredMergePolicy
 
getNodeCount() - Method in class org.apache.lucene.util.fst.FST
 
getNoLockFactory() - Static method in class org.apache.lucene.store.NoLockFactory
 
getNoOutput() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
getNoOutput() - Method in class org.apache.lucene.util.fst.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
 
getNoOutput() - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
getNormDecoder() - Static method in class org.apache.lucene.search.Similarity
Deprecated.
Use instance methods for encoding/decoding norm values to enable customization.
getNormFileName(int) - Method in class org.apache.lucene.index.SegmentInfo
Get the file name for the norms file for this field.
getNumericValue() - Method in class org.apache.lucene.document.NumericField
Returns the current numeric value as a subclass of Number, null if not yet initialized.
getNumOverlap() - Method in class org.apache.lucene.index.FieldInvertState
Get the number of terms with positionIncrement == 0.
getNumWords() - Method in class org.apache.lucene.util.OpenBitSet
Expert: gets the number of longs in the array that are in use
getOccur() - Method in class org.apache.lucene.search.BooleanClause
 
getOffset() - Method in class org.apache.lucene.index.FieldInvertState
Get end offset of the last processed term.
getOffset() - Method in class org.apache.lucene.index.Payload
Returns the offset in the underlying byte array
getOffset() - Method in class org.apache.lucene.util.CharacterUtils.CharacterBuffer
Returns the data offset in the internal buffer.
getOffsetGap(Fieldable) - Method in class org.apache.lucene.analysis.Analyzer
Just like Analyzer.getPositionIncrementGap(java.lang.String), except for Token offsets instead.
getOffsetGap(Fieldable) - Method in class org.apache.lucene.analysis.LimitTokenCountAnalyzer
 
getOffsetGap(Fieldable) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Return the offsetGap from the analyzer assigned to field
getOffsets() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper.TVPositionInfo
Parallel list (to PositionBasedTermVectorMapper.TVPositionInfo.getTerms()) of TermVectorOffsetInfo objects.
getOffsets(int) - Method in interface org.apache.lucene.index.TermPositionVector
Returns an array of TermVectorOffsetInfo in which the term is found.
getOffsets() - Method in class org.apache.lucene.index.TermVectorEntry
 
getOmitNorms() - Method in class org.apache.lucene.document.AbstractField
True if norms are omitted for this indexed field
getOmitNorms() - Method in interface org.apache.lucene.document.Fieldable
True if norms are omitted for this indexed field
getOmitTermFreqAndPositions() - Method in class org.apache.lucene.document.AbstractField
Deprecated.
getOpenMode() - Method in class org.apache.lucene.index.IndexWriterConfig
getParser() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the current numeric parser (null for T is String}
getParser() - Method in class org.apache.lucene.search.SortField
Returns the instance of a FieldCache parser that fits to the given sort type.
getPause() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
 
getPayload() - Method in class org.apache.lucene.analysis.Token
Returns this Token's payload.
getPayload() - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
Returns this Token's payload.
getPayload() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
Returns this Token's payload.
getPayload(byte[], int) - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
 
getPayload(byte[], int) - Method in class org.apache.lucene.index.MultipleTermPositions
Not implemented.
getPayload(byte[], int) - Method in interface org.apache.lucene.index.TermPositions
Returns the payload data at the current term position.
getPayload() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
getPayload() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
WARNING: The List is not necessarily in order of the the positions
getPayload() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.PositionCheckSpan
 
getPayload() - Method in class org.apache.lucene.search.spans.Spans
Returns the payload data for the current span.
getPayload() - Method in class org.apache.lucene.search.spans.TermSpans
 
getPayloadLength() - Method in class org.apache.lucene.index.FilterIndexReader.FilterTermPositions
 
getPayloadLength() - Method in class org.apache.lucene.index.MultipleTermPositions
Not implemented.
getPayloadLength() - Method in interface org.apache.lucene.index.TermPositions
Returns the length of the payload at the current term position.
getPayloadProcessorProvider() - Method in class org.apache.lucene.index.IndexWriter
Returns the PayloadProcessorProvider that is used during segment merges to process payloads.
getPayloads(Spans[]) - Method in class org.apache.lucene.search.payloads.PayloadNearQuery.PayloadNearSpanScorer
 
getPayloadScore() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
The score for the payload
getPayloadsForQuery(Query) - Method in class org.apache.lucene.search.payloads.PayloadSpanUtil
Query should be rewritten for wild/fuzzy support.
getPhraseSlop() - Method in class org.apache.lucene.queryParser.QueryParser
Gets the default slop for phrases.
getPointer() - Method in class org.apache.lucene.util.PagedBytes
 
getPosition() - Method in class org.apache.lucene.index.FieldInvertState
Get the last processed term position.
getPosition() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper.TVPositionInfo
 
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.PagedBytes.PagedBytesDataInput
Returns the current byte position.
getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
Return the current byte position.
getPositionIncrement() - Method in class org.apache.lucene.analysis.Token
Returns the position increment of this Token.
getPositionIncrement() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
Returns the position increment of this Token.
getPositionIncrement() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
Returns the position increment of this Token.
getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.Analyzer
Invoked before indexing a Fieldable instance if terms have already been added to that field.
getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.LimitTokenCountAnalyzer
 
getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.PerFieldAnalyzerWrapper
Return the positionIncrementGap from the analyzer assigned to fieldName
getPositionLength() - Method in class org.apache.lucene.analysis.Token
Get the position length.
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
Returns the position length of this Token.
getPositions() - Method in class org.apache.lucene.index.TermVectorEntry
 
getPositions() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns the relative positions of terms in this phrase.
getPositions() - Method in class org.apache.lucene.search.PhraseQuery
Returns the relative positions of terms in this phrase.
getPositions() - Method in class org.apache.lucene.search.SpanFilterResult
The first entry in the array corresponds to the first "on" bit.
getPositions() - Method in class org.apache.lucene.search.SpanFilterResult.PositionInfo
 
getPositions() - Method in class org.apache.lucene.search.spans.TermSpans
 
getPrecisionStep() - Method in class org.apache.lucene.analysis.NumericTokenStream
Returns the precision step.
getPrecisionStep() - Method in class org.apache.lucene.document.NumericField
Returns the precision step.
getPrecisionStep() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns the precision step.
getPrecisionStep() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns the precision step.
getPrefix() - Method in class org.apache.lucene.search.PrefixFilter
 
getPrefix() - Method in class org.apache.lucene.search.PrefixQuery
Returns the prefix of this query.
getPrefixLength() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the non-fuzzy prefix length.
getPrefixQuery(String, String) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
getPrefixQuery(String, String) - Method in class org.apache.lucene.queryParser.QueryParser
Factory method for generating a query (similar to QueryParser.getWildcardQuery(java.lang.String, java.lang.String)).
getPrefixTerm() - Method in class org.apache.lucene.search.PrefixTermEnum
 
getPreviousTokenStream() - Method in class org.apache.lucene.analysis.Analyzer
Used by Analyzers that implement reusableTokenStream to retrieve previously saved TokenStreams for re-use by the same thread.
getPrimaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
Return the primary directory
getProcessor(Term) - Method in class org.apache.lucene.index.PayloadProcessorProvider.ReaderPayloadProcessor
Returns a PayloadProcessorProvider.PayloadProcessor for the given term.
getQuery() - Method in class org.apache.lucene.search.BooleanClause
 
getQuery() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
 
getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery
Returns the encapsulated query, returns null if a filter is wrapped.
getQuery() - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Return our associated DisjunctionMaxQuery
getQuery() - Method in class org.apache.lucene.search.FilteredQuery
 
getQuery() - Method in class org.apache.lucene.search.SpanQueryFilter
 
getQuery() - Method in class org.apache.lucene.search.spans.SpanWeight
 
getQuery() - Method in class org.apache.lucene.search.Weight
The query that this concerns.
getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the value set by IndexWriterConfig.setRAMBufferSizeMB(double) if enabled.
getRangeCollator() - Method in class org.apache.lucene.queryParser.QueryParser
 
getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
getRangeQuery(String, String, String, boolean) - Method in class org.apache.lucene.queryParser.QueryParser
 
getReadChunkSize() - Method in class org.apache.lucene.store.FSDirectory
The maximum number of bytes to read at once from the underlying file during DataInput.readBytes(byte[], int, int).
getReader() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
getReader(int) - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
Please use IndexReader.open(IndexWriter,boolean) instead. Furthermore, this method cannot guarantee the reader (and its sub-readers) will be opened with the termInfosIndexDivisor setting because some of them may have already been opened according to IndexWriterConfig.setReaderTermsIndexDivisor(int). You should set the requested termInfosIndexDivisor through IndexWriterConfig.setReaderTermsIndexDivisor(int) and use IndexWriter.getReader().
getReader(DataInput) - Static method in class org.apache.lucene.util.packed.PackedInts
Retrieve PackedInt data from the DataInput and return a packed int structure based on it.
getReaderKey() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getReaderPooling() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns true if IndexWriter should pool readers even if IndexWriter.getReader() has not been called.
getReaderProcessor(IndexReader) - Method in class org.apache.lucene.index.PayloadProcessorProvider
Returns a PayloadProcessorProvider.ReaderPayloadProcessor for the given Directory, through which PayloadProcessorProvider.PayloadProcessors can be obtained for each Term, or null if none should be used.
getReaderTermsIndexDivisor() - Method in class org.apache.lucene.index.IndexWriter
getReaderTermsIndexDivisor() - Method in class org.apache.lucene.index.IndexWriterConfig
 
getReclaimDeletesWeight() - Method in class org.apache.lucene.index.TieredMergePolicy
getRecomputedCount() - Method in class org.apache.lucene.util.BitVector
For testing
getRefCount() - Method in class org.apache.lucene.index.IndexReader
Expert: returns the current refCount for this reader
getResolution() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
Return the timer resolution.
getReverse() - Method in class org.apache.lucene.search.SortField
Returns whether the sort should be reversed.
getReverseMul() - Method in class org.apache.lucene.search.FieldValueHitQueue
 
getRewriteMethod() - Method in class org.apache.lucene.search.MultiTermQuery
 
getRewriteMethod() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
Expert: returns the rewriteMethod
getRoundedFixedSize(int) - Static method in class org.apache.lucene.util.packed.PackedInts
Possibly wastes some storage in exchange for faster lookups
getRunningMerge() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
 
getSearchables() - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
Return the array of Searchables this searches.
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() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
getSegmentName() - Method in class org.apache.lucene.index.SegmentReader
Return the name of the segment this reader is reading.
getSegmentsFileName() - Method in class org.apache.lucene.index.IndexCommit
Get the segments file (segments_N) associated with this commit point.
getSegmentsFileName() - Method in class org.apache.lucene.index.SegmentInfos
Get the segments_N filename in use by this segment infos.
getSegmentsFileName() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
getSegmentsPerTier() - Method in class org.apache.lucene.index.TieredMergePolicy
 
getSentinelObject() - Method in class org.apache.lucene.util.PriorityQueue
This method can be overridden by extending classes to return a sentinel object which will be used by PriorityQueue.initialize(int) to fill the queue, so that the code which uses that queue can always assume it's full and only change the top without attempting to insert any new object.
getSequentialSubReaders() - Method in class org.apache.lucene.index.FilterIndexReader
 
getSequentialSubReaders() - Method in class org.apache.lucene.index.IndexReader
Expert: returns the sequential sub readers that this reader is logically composed of.
getSequentialSubReaders() - Method in class org.apache.lucene.index.MultiReader
 
getShorts(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as shorts and returns an array of size reader.maxDoc() of the value each document has in the given field.
getShorts(IndexReader, String, FieldCache.ShortParser) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as shorts and returns an array of size reader.maxDoc() of the value each document has in the given field.
getShorts(IndexReader, String, FieldCache.ShortParser, boolean) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the terms in field as shorts and returns an array of size reader.maxDoc() of the value each document has in the given field.
getShrinkSize(int, int, int) - Static method in class org.apache.lucene.util.ArrayUtil
 
getSimilarity() - Method in class org.apache.lucene.index.IndexWriter
Deprecated.
getSimilarity() - Method in class org.apache.lucene.index.IndexWriterConfig
Expert: returns the Similarity implementation used by this IndexWriter.
getSimilarity() - Method in class org.apache.lucene.search.IndexSearcher
 
getSimilarity(Searcher) - Method in class org.apache.lucene.search.Query
Deprecated.
Instead of using "runtime" subclassing/delegation, subclass the Weight instead.
getSimilarity() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
 
getSimilarity() - Method in class org.apache.lucene.search.Scorer
Deprecated.
Store any Similarity you might need privately in your implementation instead.
getSimilarity() - Method in class org.apache.lucene.search.Searcher
Deprecated.
Expert: Return the Similarity implementation used by this Searcher.
getSingleton() - Static method in class org.apache.lucene.util.fst.ByteSequenceOutputs
 
getSingleton() - Static method in class org.apache.lucene.util.fst.IntSequenceOutputs
 
getSingleton() - Static method in class org.apache.lucene.util.fst.NoOutputs
 
getSingleton(boolean) - Static method in class org.apache.lucene.util.fst.PositiveIntOutputs
 
getSingleton(boolean) - Static method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
 
getSize() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
return the maximum priority queue size
getSize() - Method in class org.apache.lucene.search.TopTermsRewrite
return the maximum priority queue size
getSizeInBytes() - Method in class org.apache.lucene.store.RAMFile
 
getSlop() - Method in class org.apache.lucene.search.MultiPhraseQuery
Sets the phrase slop for this query.
getSlop() - Method in class org.apache.lucene.search.PhraseQuery
Returns the slop.
getSlop() - Method in class org.apache.lucene.search.spans.SpanNearQuery
Return the maximum number of intervening unmatched positions permitted.
getSnapshot(String) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Get a snapshotted IndexCommit by ID.
getSnapshots() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
Get all the snapshots in a map of snapshot IDs to the segments they 'cover.'
getSnowballWordSet(Reader, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.
getSnowballWordSet(Reader, Version) - Static method in class org.apache.lucene.analysis.WordlistLoader
Reads stopwords from a stopword list in Snowball format.
getSort() - Method in class org.apache.lucene.search.Sort
Representation of the sort criteria.
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
 
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanQuery
Expert: Returns the matches for this query in an index.
getSpans(IndexReader) - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
getSpanScore() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery.PayloadTermWeight.PayloadTermSpanScorer
Returns the SpanScorer score only.
getStart() - Method in class org.apache.lucene.search.SpanFilterResult.StartEnd
The Start position
getStart() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
getStartOffset() - Method in class org.apache.lucene.index.TermVectorOffsetInfo
The accessor for the starting offset of the term.
getStarts() - Method in class org.apache.lucene.search.MultiSearcher
Deprecated.
 
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
getStringIndex(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found reads the term values in field and returns an array of them in natural order, along with an array telling which element in the term array each document uses.
getStrings(IndexReader, String) - Method in interface org.apache.lucene.search.FieldCache
Checks the internal cache for an appropriate entry, and if none is found, reads the term values in field and returns an array of size reader.maxDoc() containing the value each document has in the given field.
getSubReaders() - Method in class org.apache.lucene.search.IndexSearcher
Returns the atomic subReaders used by this searcher.
getSubSpans() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
 
getSubSpans() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
 
GetSuffix(int) - Method in interface org.apache.lucene.queryParser.CharStream
Returns an array of characters that make up the suffix of length 'len' for the currently matched token.
GetSuffix(int) - Method in class org.apache.lucene.queryParser.FastCharStream
 
getSummary() - Method in class org.apache.lucene.search.ComplexExplanation
 
getSummary() - Method in class org.apache.lucene.search.Explanation
A short one line summary which should contain all high level information about this Explanation, without the "Details"
getSupportedFeatures() - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the set of supported JVM features that improve the estimation.
getTargetLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
getTargetLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
getTerm() - Method in class org.apache.lucene.index.TermVectorEntry
 
getTerm() - Method in class org.apache.lucene.search.FuzzyQuery
Returns the pattern term.
getTerm() - Method in class org.apache.lucene.search.spans.SpanTermQuery
Return the term whose spans are matched.
getTerm() - Method in class org.apache.lucene.search.TermQuery
Returns the term of this query.
getTerm() - Method in class org.apache.lucene.search.WildcardQuery
Returns the pattern term.
getTermArrays() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns a List of the terms in the multiphrase.
getTermCount() - Method in class org.apache.lucene.util.fst.Builder
 
getTermFrequencies() - Method in interface org.apache.lucene.index.TermFreqVector
Array of term frequencies.
getTermFrequencies() - Method in class org.apache.lucene.search.QueryTermVector
 
getTermFreqVector(int, String) - Method in class org.apache.lucene.index.FilterIndexReader
 
getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.FilterIndexReader
 
getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.FilterIndexReader
 
getTermFreqVector(int, String) - Method in class org.apache.lucene.index.IndexReader
Return a term frequency vector for the specified document and field.
getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.IndexReader
Load the Term Vector into a user-defined data structure instead of relying on the parallel arrays of the TermFreqVector.
getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.IndexReader
Map all the term vectors for all fields in a Document
getTermFreqVector(int, String) - Method in class org.apache.lucene.index.MultiReader
 
getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.MultiReader
 
getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.MultiReader
 
getTermFreqVector(int, String) - Method in class org.apache.lucene.index.ParallelReader
 
getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.ParallelReader
 
getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.ParallelReader
 
getTermFreqVector(int, String) - Method in class org.apache.lucene.index.SegmentReader
Return a term frequency vector for the specified document and field.
getTermFreqVector(int, String, TermVectorMapper) - Method in class org.apache.lucene.index.SegmentReader
 
getTermFreqVector(int, TermVectorMapper) - Method in class org.apache.lucene.index.SegmentReader
 
getTermFreqVectors(int) - Method in class org.apache.lucene.index.FilterIndexReader
 
getTermFreqVectors(int) - Method in class org.apache.lucene.index.IndexReader
Return an array of term frequency vectors for the specified document.
getTermFreqVectors(int) - Method in class org.apache.lucene.index.MultiReader
 
getTermFreqVectors(int) - Method in class org.apache.lucene.index.ParallelReader
 
getTermFreqVectors(int) - Method in class org.apache.lucene.index.SegmentReader
Return an array of term frequency vectors for the specified document.
getTermIndexInterval() - Method in class org.apache.lucene.index.IndexWriter
getTermIndexInterval() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns the interval between indexed terms.
getTermInfosIndexDivisor() - Method in class org.apache.lucene.index.FilterIndexReader
 
getTermInfosIndexDivisor() - Method in class org.apache.lucene.index.IndexReader
For IndexReader implementations that use TermInfosReader to read terms, this returns the current indexDivisor as specified when the reader was opened.
getTermInfosIndexDivisor() - Method in class org.apache.lucene.index.SegmentReader
 
getTermPositions(int) - Method in interface org.apache.lucene.index.TermPositionVector
Returns an array of positions in which the term is found.
getTerms() - Method in class org.apache.lucene.index.PositionBasedTermVectorMapper.TVPositionInfo
Note, there may be multiple terms at the same position
getTerms() - Method in interface org.apache.lucene.index.TermFreqVector
 
getTerms() - Method in class org.apache.lucene.search.PhraseQuery
Returns the set of terms in this phrase.
getTerms() - Method in class org.apache.lucene.search.QueryTermVector
 
getTermsEnum(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
getTermVectorEntrySet() - Method in class org.apache.lucene.index.SortedTermVectorMapper
The TermVectorEntrySet.
getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
Fills CharTermAttribute with the current token text.
getText(CharTermAttribute) - Method in interface org.apache.lucene.analysis.standard.StandardTokenizerInterface
Copies the matched text into the CharTermAttribute
getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
Deprecated.
Fills CharTermAttribute with the current token text.
getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
Deprecated.
Fills CharTermAttribute with the current token text.
getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
Deprecated.
Fills CharTermAttribute with the current token text.
getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
Fills CharTermAttribute with the current token text.
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).
getTimestamp() - Method in class org.apache.lucene.index.IndexCommit
Deprecated.
If you need to track commit time of an index, you can store it in the commit data (see IndexWriter.commit(Map)
getToken(int) - Method in class org.apache.lucene.queryParser.QueryParser
Get the specific Token.
getTokenStream() - Method in class org.apache.lucene.analysis.ReusableAnalyzerBase.TokenStreamComponents
Returns the sink TokenStream
getTopLevelQuery() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
 
getTopLevelQuery() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
 
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.
getTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQuery
Deprecated.
Don't use this method, as its not thread safe and useless.
getTotalNumberOfTerms() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
Deprecated.
Don't use this method, as its not thread safe and useless.
getTotStateCount() - Method in class org.apache.lucene.util.fst.Builder
 
getType() - Method in class org.apache.lucene.search.SortField
Returns the type of contents in the field.
getType() - Method in class org.apache.lucene.util.FieldCacheSanityChecker.Insanity
Type of insane behavior this object represents
getUniqueTermCount() - Method in class org.apache.lucene.index.FieldInvertState
Return the number of unique terms encountered in this field.
getUniqueTermCount() - Method in class org.apache.lucene.index.FilterIndexReader
 
getUniqueTermCount() - Method in class org.apache.lucene.index.IndexReader
Returns the number of unique terms (across all fields) in this reader.
getUniqueTermCount() - Method in class org.apache.lucene.index.SegmentReader
 
getUnsupportedFeatures() - Static method in class org.apache.lucene.util.RamUsageEstimator
Return the set of unsupported JVM features that improve the estimation.
getUpperTerm() - Method in class org.apache.lucene.search.TermRangeFilter
Returns the upper value of this range filter
getUpperTerm() - Method in class org.apache.lucene.search.TermRangeQuery
Returns the upper value of this range query
getUpperVal() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns the upper value of this range filter
getUseCompoundFile() - Method in class org.apache.lucene.index.IndexWriter
getUseCompoundFile() - Method in class org.apache.lucene.index.LogMergePolicy
Returns true if newly flushed and newly merge segments are written in compound file format.
getUseCompoundFile() - Method in class org.apache.lucene.index.SegmentInfo
Returns true if this segment is stored as a compound file; else, false.
getUseCompoundFile() - Method in class org.apache.lucene.index.TieredMergePolicy
 
getUserData() - Method in class org.apache.lucene.index.IndexCommit
Returns userData, previously passed to IndexWriter.commit(Map) for this commit.
getUserData() - Method in class org.apache.lucene.index.SegmentInfos
 
getUserData() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy.SnapshotCommitPoint
 
getUseUnmap() - Method in class org.apache.lucene.store.MMapDirectory
Returns true, if the unmap workaround is enabled.
getUTF16SortedAsUTF8Comparator() - Static method in class org.apache.lucene.util.CharsRef
 
getUTF8SortedAsUnicodeComparator() - Static method in class org.apache.lucene.util.BytesRef
 
getUTF8SortedAsUTF16Comparator() - Static method in class org.apache.lucene.util.BytesRef
 
getValue() - Method in class org.apache.lucene.queryParser.Token
An optional attribute value of the Token.
getValue() - Method in class org.apache.lucene.search.BooleanQuery.BooleanWeight
 
getValue() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantWeight
 
getValue() - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
Return our boost
getValue() - Method in class org.apache.lucene.search.Explanation
The value assigned to this explanation node.
getValue() - Method in class org.apache.lucene.search.FieldCache.CacheEntry
 
getValue() - Method in class org.apache.lucene.search.spans.SpanWeight
 
getValue() - Method in class org.apache.lucene.search.Weight
The weight for this query.
getValues(String) - Method in class org.apache.lucene.document.Document
Returns an array of values of the field specified as the method parameter.
getValues() - Method in class org.apache.lucene.search.FieldComparator.StringOrdValComparator
 
getValues(IndexReader) - Method in class org.apache.lucene.search.function.FieldCacheSource
 
getValues(IndexReader) - Method in class org.apache.lucene.search.function.OrdFieldSource
 
getValues(IndexReader) - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
 
getValues(IndexReader) - Method in class org.apache.lucene.search.function.ValueSource
Return the DocValues used by the function query.
getVersion() - Method in class org.apache.lucene.index.FilterIndexReader
 
getVersion() - Method in class org.apache.lucene.index.IndexCommit
Deprecated.
getVersion() - Method in class org.apache.lucene.index.IndexReader
Version number when this IndexReader was opened.
getVersion() - Method in class org.apache.lucene.index.MultiReader
Not implemented.
getVersion() - Method in class org.apache.lucene.index.ParallelReader
Not implemented.
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.SnapshotDeletionPolicy.SnapshotCommitPoint
 
getVersionComparator() - Static method in class org.apache.lucene.util.StringHelper
 
getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.MultiFieldQueryParser
 
getWildcardQuery(String, String) - Method in class org.apache.lucene.queryParser.QueryParser
Factory method for generating a query.
getWordSet(Reader, CharArraySet) - 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, Version) - 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, Version) - 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-comment line as an entry to a CharArraySet (omitting leading and trailing whitespace).
getWriteLockTimeout() - Method in class org.apache.lucene.index.IndexWriter
getWriteLockTimeout() - Method in class org.apache.lucene.index.IndexWriterConfig
Returns allowed timeout when acquiring the write lock.
getWriter(DataOutput, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
Create a packed integer array writer for the given number of values at the given bits/value.
grow(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(short[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(float[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(float[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(double[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(double[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(int[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(long[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(byte[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(boolean[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(boolean[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(char[]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(int[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(int[][]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(float[][], int) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(float[][]) - Static method in class org.apache.lucene.util.ArrayUtil
 
grow(int) - Method in class org.apache.lucene.util.BytesRef
Used to grow the reference array.
grow() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
grow() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
 
grow() - Method in class org.apache.lucene.util.BytesRefHash.TrackingDirectBytesStartArray
 
grow(int) - Method in class org.apache.lucene.util.CharsRef
Used to grow the reference array.
grow() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
 
grow() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
 
grow(int) - Method in class org.apache.lucene.util.IntsRef
Used to grow the reference array.
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, boolean) - Constructor for class org.apache.lucene.util.packed.GrowableWriter
 

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 - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
 
HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
Deprecated.
 
HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
Deprecated.
 
HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
Deprecated.
 
HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
Deprecated.
HANGUL_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
 
hasArray() - Method in class org.apache.lucene.util.packed.GrowableWriter
 
hasArray() - Method in interface org.apache.lucene.util.packed.PackedInts.Reader
Returns true if this implementation is backed by a native java array.
hasArray() - Method in class org.apache.lucene.util.packed.PackedInts.ReaderImpl
 
hasAttribute(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeSource
The caller must pass in a Class<?
hasAttributes() - Method in class org.apache.lucene.util.AttributeSource
Returns true, iff this AttributeSource has any attributes
hasChanges - Variable in class org.apache.lucene.index.IndexReader
 
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.FilterIndexReader
 
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
 
hasDeletions() - Method in class org.apache.lucene.index.MultiReader
 
hasDeletions() - Method in class org.apache.lucene.index.ParallelReader
 
hasDeletions() - Method in class org.apache.lucene.index.SegmentInfo
 
hasDeletions() - Method in class org.apache.lucene.index.SegmentReader
 
hashCode() - Method in class org.apache.lucene.analysis.Token
 
hashCode() - Method in class org.apache.lucene.analysis.Token.TokenAttributeFactory
 
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.PayloadAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
 
hashCode() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
 
hashCode() - Method in class org.apache.lucene.index.IndexCommit
 
hashCode() - Method in class org.apache.lucene.index.Payload
 
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.index.TermVectorEntry
 
hashCode() - Method in class org.apache.lucene.index.TermVectorOffsetInfo
 
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
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.CachingSpanFilter
 
hashCode() - Method in class org.apache.lucene.search.CachingWrapperFilter
 
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.FieldCacheRangeFilter
 
hashCode() - Method in class org.apache.lucene.search.FieldValueFilter
 
hashCode() - Method in class org.apache.lucene.search.FilteredQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.function.CustomScoreQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.function.FieldCacheSource
 
hashCode() - Method in class org.apache.lucene.search.function.OrdFieldSource
 
hashCode() - Method in class org.apache.lucene.search.function.ReverseOrdFieldSource
 
hashCode() - Method in class org.apache.lucene.search.function.ValueSource
Needed for possible caching of query results - used by ValueSourceQuery.hashCode().
hashCode() - Method in class org.apache.lucene.search.function.ValueSourceQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.FuzzyQuery
 
hashCode() - Method in class org.apache.lucene.search.MatchAllDocsQuery
 
hashCode() - Method in class org.apache.lucene.search.MultiPhraseQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.MultiTermQuery
 
hashCode() - Method in class org.apache.lucene.search.MultiTermQueryWrapperFilter
 
hashCode() - Method in class org.apache.lucene.search.NGramPhraseQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.NumericRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.payloads.AveragePayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.MaxPayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.MinPayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.PayloadFunction
 
hashCode() - Method in class org.apache.lucene.search.payloads.PayloadNearQuery
 
hashCode() - Method in class org.apache.lucene.search.payloads.PayloadTermQuery
 
hashCode() - Method in class org.apache.lucene.search.PhraseQuery
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.PrefixQuery
 
hashCode() - Method in class org.apache.lucene.search.Query
 
hashCode() - Method in class org.apache.lucene.search.QueryWrapperFilter
 
hashCode() - Method in class org.apache.lucene.search.Sort
Returns a hash code value for this object.
hashCode() - Method in class org.apache.lucene.search.SortField
Returns true if o is equal to this.
hashCode() - Method in class org.apache.lucene.search.SpanQueryFilter
 
hashCode() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanFirstQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanNearPayloadCheckQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanNearQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanNotQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanOrQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanPayloadCheckQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
 
hashCode() - Method in class org.apache.lucene.search.spans.SpanTermQuery
 
hashCode() - Method in class org.apache.lucene.search.TermQuery
Returns a hash code value for this object.
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.WildcardQuery
 
hashCode(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns hash of chars in range start (inclusive) to end (inclusive)
hashCode(byte[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
Returns hash of bytes in range start (inclusive) to end (inclusive)
hashCode() - Method in class org.apache.lucene.util.AttributeSource
 
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.CharsRef
 
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.fst.UpToTwoPositiveIntOutputs.TwoLongs
 
hashCode() - Method in class org.apache.lucene.util.IntsRef
 
hashCode() - Method in class org.apache.lucene.util.OpenBitSet
 
hasNext() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
 
hasNext() - Method in class org.apache.lucene.analysis.CharArraySet.CharArraySetIterator
Deprecated.
 
hasNorms(String) - Method in class org.apache.lucene.index.FilterIndexReader
 
hasNorms(String) - Method in class org.apache.lucene.index.IndexReader
Returns true if there are norms stored for this field.
hasNorms(String) - Method in class org.apache.lucene.index.MultiReader
 
hasNorms(String) - Method in class org.apache.lucene.index.ParallelReader
 
hasNorms(String) - Method in class org.apache.lucene.index.SegmentReader
 
hasProx - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
True if at least one of the fields in this segment has position data
hasProx() - Method in class org.apache.lucene.index.FieldInfos
Returns true if any fields do not omitTermFreqAndPositions
hasSeparateNorms(int) - Method in class org.apache.lucene.index.SegmentInfo
Returns true if this field for this segment has saved a separate norms file (__N.sX).
hasSeparateNorms() - Method in class org.apache.lucene.index.SegmentInfo
Returns true if any fields in this segment have separate norms.
hasVectors() - Method in class org.apache.lucene.index.FieldInfos
 
hasVectors - Variable in class org.apache.lucene.index.SegmentWriteState
 
headerLength(String) - Static method in class org.apache.lucene.util.CodecUtil
 
HIRAGANA - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
 
HIRAGANA - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
 
HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
Deprecated.
 
HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
Deprecated.
 
HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
Deprecated.
 
HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
Deprecated.
HIRAGANA_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
 
HOST - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
HOST - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
Deprecated. 
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).
humanSizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
Return a human-readable size of a given object.

I

IDEOGRAPHIC - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
 
IDEOGRAPHIC - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
 
IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.StandardTokenizerImpl31
Deprecated.
 
IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std31.UAX29URLEmailTokenizerImpl31
Deprecated.
 
IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.std34.UAX29URLEmailTokenizerImpl34
Deprecated.
 
IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
Deprecated.
IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
 
idf(int, int) - Method in class org.apache.lucene.search.DefaultSimilarity
Implemented as log(numDocs/(docFreq+1)) + 1.
idf(int, int) - Method in class org.apache.lucene.search.Similarity
Computes a score factor based on a term's document frequency (the number of documents which contain the term).
idf(int, int) - Method in class org.apache.lucene.search.SimilarityDelegator
Deprecated.
 
idf - Variable in class org.apache.lucene.search.spans.SpanWeight
 
idfExplain(Term, Searcher, int) - Method in class org.apache.lucene.search.Similarity
Computes a score factor for a simple term and returns an explanation for that score factor.
idfExplain(Term, Searcher) - Method in class org.apache.lucene.search.Similarity
This method forwards to Similarity.idfExplain(Term,Searcher,int) by passing searcher.docFreq(term) as the docFreq.
idfExplain(Collection<Term>, Searcher) - Method in class org.apache.lucene.search.Similarity
Computes a score factor for a phrase.
image - Variable in class org.apache.lucene.queryParser.Token
The string image of the token.
in - Variable in class org.apache.lucene.index.FilterIndexReader.FilterTermDocs
 
in - Variable in class org.apache.lucene.index.FilterIndexReader.FilterTermEnum
 
in - Variable in class org.apache.lucene.index.FilterIndexReader
 
includesLower() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns true if the lower endpoint is inclusive
includesLower() - Method in class org.apache.lucene.search.TermRangeFilter
Returns true if the lower endpoint is inclusive
includesLower() - Method in class org.apache.lucene.search.TermRangeQuery
Returns true if the lower endpoint is inclusive
includesMax() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns true if the upper endpoint is inclusive
includesMax() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns true if the upper endpoint is inclusive
includesMin() - Method in class org.apache.lucene.search.NumericRangeFilter
Returns true if the lower endpoint is inclusive
includesMin() - Method in class org.apache.lucene.search.NumericRangeQuery
Returns true if the lower endpoint is inclusive
includesUpper() - Method in class org.apache.lucene.search.FieldCacheRangeFilter
Returns true if the upper endpoint is inclusive
includesUpper() - Method in class org.apache.lucene.search.TermRangeFilter
Returns true if the upper endpoint is inclusive
includesUpper() - Method in class org.apache.lucene.search.TermRangeQuery
Returns true if the upper endpoint is inclusive
incRef() - Method in class org.apache.lucene.index.IndexReader
Expert: increments the refCount of this IndexReader instance.
incrementToken() - Method in class org.apache.lucene.analysis.ASCIIFoldingFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.CachingTokenFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.CharTokenizer
 
incrementToken() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.ISOLatin1AccentFilter
Deprecated.
 
incrementToken() - Method in class org.apache.lucene.analysis.KeywordMarkerFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.KeywordTokenizer
 
incrementToken() - Method in class org.apache.lucene.analysis.LimitTokenCountFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.LowerCaseFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.NumericTokenStream
 
incrementToken() - Method in class org.apache.lucene.analysis.PorterStemFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.standard.ClassicFilter
Returns the next token in the stream, or null at EOS.
incrementToken() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
 
incrementToken() - Method in class org.apache.lucene.analysis.standard.StandardFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
 
incrementToken() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
 
incrementToken() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter
 
incrementToken() - Method in class org.apache.lucene.analysis.TeeSinkTokenFilter.SinkTokenStream
 
incrementToken() - Method in class org.apache.lucene.analysis.TokenStream
Consumers (i.e., IndexWriter) use this method to advance the stream to the next token.
incrementToken() - Method in class org.apache.lucene.collation.CollationKeyFilter
 
incrementTokenClassic() - Method in class org.apache.lucene.analysis.standard.StandardFilter
 
incTotalNumberOfTerms(int) - Method in class org.apache.lucene.search.MultiTermQuery
Deprecated.
Don't use this method, as its not thread safe and useless.
INDEX_EXTENSIONS - Static variable in class org.apache.lucene.index.IndexFileNames
This array contains all filename extensions used by Lucene's index files, with two exceptions, namely the extension made up from .f + a number and from .s + a number.
INDEX_EXTENSIONS_IN_COMPOUND_FILE - Static variable in class org.apache.lucene.index.IndexFileNames
File extensions that are added to a compound file (same as above, minus "del", "gen", "cfs").
IndexableBinaryStringTools - Class in org.apache.lucene.util
Provides support for converting byte sequences to Strings and back again.
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
 
IndexDeletionPolicy - Interface in org.apache.lucene.index
Expert: policy for deletion of stale index commits.
indexesOf(String[], int, int) - Method in interface org.apache.lucene.index.TermFreqVector
Just like indexOf(int) but searches for a number of terms at the same time.
indexesOf(String[], int, int) - Method in class org.apache.lucene.search.QueryTermVector
 
indexExists(Directory) - Static method in class org.apache.lucene.index.IndexReader
Returns true if an index exists at the specified directory.
IndexFileNameFilter - Class in org.apache.lucene.index
Filename filter that accept filenames and extensions only created by Lucene.
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).
IndexFileNames() - Constructor for class org.apache.lucene.index.IndexFileNames
 
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
 
IndexFormatTooNewException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
 
IndexFormatTooOldException - Exception in org.apache.lucene.index
This exception is thrown when Lucene detects an index that is too old for this Lucene version
IndexFormatTooOldException(String, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
 
IndexFormatTooOldException(DataInput, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
 
IndexFormatTooOldException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
 
IndexFormatTooOldException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
 
IndexInput - Class in org.apache.lucene.store
Abstract base class for input from a file in a Directory.
IndexInput() - Constructor for class org.apache.lucene.store.IndexInput
Deprecated.
please pass resourceDescription
IndexInput(String) - Constructor for class org.apache.lucene.store.IndexInput
resourceDescription should be