- a - Variable in class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- a - Variable in class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
- ab - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The x/y scaling factor
- abort() - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
-
Abort the merge this progress tracks at the next
possible moment.
- ABSOLUTE_MIN_SORT_BUFFER_SIZE - Static variable in class org.apache.lucene.util.OfflineSorter
-
Absolute minimum required buffer size for sorting.
- AbstractAnalysisFactory - Class in org.apache.lucene.analysis.util
-
- AbstractAnalysisFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
Initialize this factory via a set of key-value pairs.
- AbstractEncoder - Class in org.apache.lucene.analysis.payloads
-
Base class for payload encoders.
- AbstractEncoder() - Constructor for class org.apache.lucene.analysis.payloads.AbstractEncoder
-
- AbstractPagedMutable<T extends AbstractPagedMutable<T>> - Class in org.apache.lucene.util.packed
-
- AbstractPrefixTreeQuery - Class in org.apache.lucene.spatial.prefix
-
Base class for Lucene Queries on SpatialPrefixTree fields.
- AbstractPrefixTreeQuery(Shape, String, SpatialPrefixTree, int) - Constructor for class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery
-
- AbstractPrefixTreeQuery.BaseTermsEnumTraverser - Class in org.apache.lucene.spatial.prefix
-
- AbstractQueryConfig - Class in org.apache.lucene.queryparser.flexible.core.config
-
- AbstractQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
Abstract base query maker.
- AbstractQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- AbstractRangeQueryNode<T extends FieldValuePairQueryNode<?>> - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
This class should be extended by nodes intending to represent range queries.
- AbstractRangeQueryNode() - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
- AbstractVisitingPrefixTreeQuery - Class in org.apache.lucene.spatial.prefix
-
Traverses a
SpatialPrefixTree
indexed field, using the template and
visitor design patterns for subclasses to guide the traversal and collect
matching documents.
- AbstractVisitingPrefixTreeQuery(Shape, String, SpatialPrefixTree, int, int) - Constructor for class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery
-
- AbstractVisitingPrefixTreeQuery.VisitorTemplate - Class in org.apache.lucene.spatial.prefix
-
An abstract class designed to make it easy to implement predicates or
other operations on a
SpatialPrefixTree
indexed field.
- AbstractVisitingPrefixTreeQuery.VNode - Class in org.apache.lucene.spatial.prefix
-
- accept() - Method in class org.apache.lucene.analysis.core.TypeTokenFilter
-
By default accept the token if its type is not a stop type.
- accept() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
-
- accept() - Method in class org.apache.lucene.analysis.ja.JapanesePartOfSpeechStopFilter
-
- accept() - Method in class org.apache.lucene.analysis.ko.KoreanPartOfSpeechStopFilter
-
- accept() - Method in class org.apache.lucene.analysis.miscellaneous.CodepointCountFilter
-
- accept() - Method in class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilter
-
- accept() - Method in class org.apache.lucene.analysis.miscellaneous.KeepWordFilter
-
- accept() - Method in class org.apache.lucene.analysis.miscellaneous.LengthFilter
-
- accept() - Method in class org.apache.lucene.analysis.StopFilter
-
Returns the next input Token whose term() is not a stop word.
- accept(double) - Method in class org.apache.lucene.facet.range.DoubleRange
-
True if this range accepts the provided value.
- accept(long) - Method in class org.apache.lucene.facet.range.LongRange
-
True if this range accepts the provided value.
- accept(BytesRef) - Method in class org.apache.lucene.index.AutomatonTermsEnum
-
Returns true if the term matches the automaton.
- accept(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
Return if term is accepted, not accepted or the iteration should ended
(and possibly seek).
- accept(BytesRef) - Method in class org.apache.lucene.index.SingleTermsEnum
-
- accept() - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- accept(Spans) - Method in class org.apache.lucene.search.spans.FilterSpans
-
Returns YES if the candidate should be an accepted match,
NO if it should not, and NO_MORE_IN_CURRENT_DOC if iteration
should move on to the next document.
- accept(int, Bits) - Method in class org.apache.lucene.search.suggest.document.CompletionScorer
-
Returns true if a document with docID
is accepted,
false if the docID maps to a deleted
document or has been filtered out
- accept(T) - Method in interface org.apache.lucene.util.IOUtils.IOConsumer
-
Performs this operation on the given argument.
- acceptPartialPath(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-
Override this to prevent considering a path before it's complete
- acceptPhrase(FieldPhraseList.WeightedPhraseInfo, int, int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragListBuilder
-
- acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
-
- acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-
Implementing classes are required to return whether the current position is a match for the passed in
"match"
SpanQuery
.
- acceptPosition(Spans) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-
- acceptResult(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-
- acceptResult(IntsRef, T) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-
- Accountable - Interface in org.apache.lucene.util
-
An object whose RAM usage can be computed.
- Accountables - Class in org.apache.lucene.util
-
Helper methods for constructing nested resource descriptions
and debugging RAM usage.
- accumulateArray(Object, long, List<Object>, Collection<Object>) - Method in class org.apache.lucene.util.RamUsageTester.Accumulator
-
Accumulate transitive references for the provided values of the given
array into queue
and return the shallow size of this array.
- accumulateObject(Object, long, Map<Field, Object>, Collection<Object>) - Method in class org.apache.lucene.util.RamUsageTester.Accumulator
-
Accumulate transitive references for the provided fields of the given
object into queue
and return the shallow size of this object.
- accumulateStatistics(int, long) - Method in class org.apache.lucene.index.TermContext
-
Expert: Accumulate term statistics.
- Accumulator() - Constructor for class org.apache.lucene.util.RamUsageTester.Accumulator
-
- acosh(double) - Static method in class org.apache.lucene.util.MathUtil
-
Calculates inverse hyperbolic cosine of a double
value.
- acquire() - Method in class org.apache.lucene.search.ReferenceManager
-
Obtain the current reference.
- acquire(long) - Method in class org.apache.lucene.search.SearcherLifetimeManager
-
Retrieve a previously recorded
IndexSearcher
, if it
has not yet been closed
- acquire() - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- acquire(long[]) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- ACRONYM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- ACRONYM_DEP - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- ACRONYM_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- actualTerm - Variable in class org.apache.lucene.index.FilteredTermsEnum
-
Which term the enum is currently positioned to.
- 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.charfilter.NormalizeCharMap.Builder
-
Records a replacement to be applied to the input
stream.
- add(AttributeSource.State) - Method in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
-
- add(CharSequence, CharSequence) - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter.Builder
-
Adds an input string and its stemmer override output to this builder.
- add(CharsRef, CharsRef, boolean) - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
Add a phrase->phrase synonym mapping.
- add(TaskStats) - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
Add data from another stat, for aggregation
- add(BytesRef, TermStats, long) - Method in class org.apache.lucene.codecs.blockterms.TermsIndexWriterBase.FieldWriter
-
- add(IndexableField) - Method in class org.apache.lucene.document.Document
-
Adds a field to a document.
- add(SortField) - Method in class org.apache.lucene.expressions.SimpleBindings
-
Adds a SortField to the bindings.
- add(String, DoubleValuesSource) - Method in class org.apache.lucene.expressions.SimpleBindings
-
- add(String, Expression) - Method in class org.apache.lucene.expressions.SimpleBindings
-
Adds an Expression to the bindings.
- add(String, String...) - Method in class org.apache.lucene.facet.DrillDownQuery
-
Adds one dimension of drill downs; if you pass the same
dimension more than once it is OR'd with the previous
cofnstraints on that dimension, and all dimensions are
AND'd against each other and the base query.
- add(String, Query) - Method in class org.apache.lucene.facet.DrillDownQuery
-
Expert: add a custom drill-down subQuery.
- add(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
-
- add(Term) - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
-
add a term
- add(String, BytesRef) - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
-
add a term.
- add(SegmentCommitInfo) - Method in class org.apache.lucene.index.SegmentInfos
-
- add(Term) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- add(String, ParserExtension) - Method in class org.apache.lucene.queryparser.ext.Extensions
-
- add(QueryNode) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
- add(List<QueryNode>) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
- add(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- add(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- add(QueryNodeProcessor) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- add(int, QueryNodeProcessor) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- add(Term) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
-
Add a new
Term
to this builder, with a default boost of
1
.
- add(Term, float) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
-
Add a
Term
with the provided boost.
- add(Term, float, TermContext) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
-
Expert: Add a
Term
with the provided boost and context.
- add(BooleanClause) - Method in class org.apache.lucene.search.BooleanQuery.Builder
-
- add(Query, BooleanClause.Occur) - Method in class org.apache.lucene.search.BooleanQuery.Builder
-
- add(DisiWrapper) - Method in class org.apache.lucene.search.DisiPriorityQueue
-
- add(String, T) - Method in class org.apache.lucene.search.LiveFieldValues
-
Call this after you've successfully added a document
to the index, to record what value you just set the
field to.
- add(Term) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
-
Add a single term at the next position in the phrase.
- add(Term[]) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
-
Add multiple terms at the next position in the phrase.
- add(Term[], int) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
-
Allows to specify the relative position of terms within the phrase.
- add(Term) - Method in class org.apache.lucene.search.PhraseQuery.Builder
-
Adds a term to the end of the query phrase.
- add(Term, int) - Method in class org.apache.lucene.search.PhraseQuery.Builder
-
Adds a term to the end of the query phrase.
- add(BytesRef, Set<BytesRef>, long, BytesRef) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Adds a new suggestion.
- add(BytesRef) - Method in interface org.apache.lucene.search.suggest.fst.BytesRefSorter
-
Adds a single suggestion entry (possibly compound with its bucket).
- add(BytesRef) - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
-
- add(BytesRef, int) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
-
Appends a single suggestion and its weight to the internal buffers.
- add(BytesRef) - Method in class org.apache.lucene.search.suggest.InMemorySorter
-
- add(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
Adds a new node if key
already exists,
otherwise replaces its value.
- add(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
Adds a new node if key
already exists,
otherwise replaces its value.
- add(int, int, List<FieldPhraseList.WeightedPhraseInfo>) - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList
-
convert the list of WeightedPhraseInfo to WeightedFragInfo, then add it to the fragInfos
- add(int, int, List<FieldPhraseList.WeightedPhraseInfo>) - Method in class org.apache.lucene.search.vectorhighlight.SimpleFieldFragList
-
- add(int, int, List<FieldPhraseList.WeightedPhraseInfo>) - Method in class org.apache.lucene.search.vectorhighlight.WeightedFieldFragList
-
- add(int, T) - Method in class org.apache.lucene.spatial.util.ShapeFieldCache
-
- add(CharsRef) - Method in class org.apache.lucene.util.automaton.DaciukMihovAutomatonBuilder
-
Add another character sequence to this automaton.
- add(byte[], int) - Method in class org.apache.lucene.util.bkd.BKDWriter
-
- add(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
-
- add(DocIdSetIterator) - Method in class org.apache.lucene.util.DocIdSetBuilder
-
- add(int) - Method in class org.apache.lucene.util.DocIdSetBuilder.BulkAdder
-
- add(int) - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
-
Add a new item to this ring buffer, potentially removing the oldest
entry from this buffer if it is already full.
- add(IntsRef, T) - Method in class org.apache.lucene.util.fst.Builder
-
Add the next input/output pair.
- add(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- add(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- add(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- add(Object, Object) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- 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(int, int, byte[], byte[], byte[]) - Static method in class org.apache.lucene.util.NumericUtils
-
Result = a + b, where a and b are unsigned.
- add(long) - Method in class org.apache.lucene.util.packed.DirectMonotonicWriter
-
Write a new value.
- add(long) - Method in class org.apache.lucene.util.packed.DirectWriter
-
Adds a value to this writer
- add(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
-
- add(long) - Method in class org.apache.lucene.util.packed.PackedInts.Writer
-
Add a value to the stream.
- add(long) - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
-
Add a new element to this builder.
- add(T) - Method in class org.apache.lucene.util.PriorityQueue
-
Adds an Object to a PriorityQueue in log(size) time.
- add(BooleanQuery.Builder, List<Term>, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
-
- add(int) - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
-
Add a new doc-id to this builder.
- add(DocIdSetIterator) - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
-
- add(CharSequence, CharSequence) - Method in class org.egothor.stemmer.MultiTrie
-
Add an element to this structure consisting of the given key and patch
command.
- add(CharSequence, CharSequence) - Method in class org.egothor.stemmer.MultiTrie2
-
Add an element to this structure consisting of the given key and patch
command.
- addAll(Iterable<SegmentCommitInfo>) - Method in class org.apache.lucene.index.SegmentInfos
-
- addAll(Collection<? extends QueryNodeProcessor>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- addAll(int, Collection<? extends QueryNodeProcessor>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- addAllContexts() - Method in class org.apache.lucene.search.suggest.document.ContextQuery
-
Add all contexts with a boost of 1f
- addAllDocVectors(Fields, MergeState) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Safe (but, slowish) default method to write every
vector field in the document.
- addAndGet(long) - Method in class org.apache.lucene.util.Counter
-
Adds the given delta to the counters current value
- addAnyTransition(int, int) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Adds a transition matching any term.
- addArc(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- addAttribute(Class<T>) - Method in class org.apache.lucene.util.AttributeSource
-
The caller must pass in a Class<? extends Attribute> value.
- addAttributeImpl(AttributeImpl) - Method in class org.apache.lucene.util.AttributeSource
-
Expert: Adds a custom AttributeImpl instance with one or more Attribute interfaces.
- addAttributes(FieldInfo) - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Hook to add any codec attributes to fieldinfo
instances added in this test.
- addBinaryField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Writes binary docvalues for a field.
- addBuffer(int) - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
- addBuilder(String, SpanQueryBuilder) - Method in class org.apache.lucene.queryparser.xml.builders.SpanQueryBuilderFactory
-
- addBuilder(String, QueryBuilder) - Method in class org.apache.lucene.queryparser.xml.QueryBuilderFactory
-
- addByPoolOffset(int) - Method in class org.apache.lucene.util.BytesRefHash
-
Adds a "arbitrary" int offset instead of a BytesRef
term.
- addBytes(long) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
update count of bytes generated by this source
- addCategory(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- addCategory(FacetLabel) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyWriter
-
addCategory() adds a category with a given path name to the taxonomy,
and returns its ordinal.
- addCharFilter(Class<? extends CharFilterFactory>, String...) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given char filter.
- addCharFilter(Class<? extends CharFilterFactory>, Map<String, String>) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given char filter.
- addCharFilter(String, String...) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given char filter.
- addCharFilter(String, Map<String, String>) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given char filter.
- addCircle(double, double, double, boolean) - Method in class org.apache.lucene.geo.EarthDebugger
-
- addClass(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Add a character class to the tree.
- addClass(String) - Method in interface org.apache.lucene.analysis.compound.hyphenation.PatternConsumer
-
Add a character class.
- addClause(List<BooleanClause>, int, int, Query) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- addClause(BlendedTermQuery.Builder, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
-
- addClause(BooleanQuery.Builder, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-
- addClause(BooleanQuery.Builder, Term, int, float, TermContext) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
-
- addClause(SpanQuery) - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
-
Add a new clause
- addClosedListener(IndexReader.ClosedListener) - Method in interface org.apache.lucene.index.IndexReader.CacheHelper
-
- addContext(CharSequence) - Method in class org.apache.lucene.search.suggest.document.ContextQuery
-
Adds an exact context with default boost of 1
- addContext(CharSequence, float) - Method in class org.apache.lucene.search.suggest.document.ContextQuery
-
Adds an exact context with boost
- addContext(CharSequence, float, boolean) - Method in class org.apache.lucene.search.suggest.document.ContextQuery
-
Adds a context with boost, set exact
to false
if the context is a prefix of any indexed contexts
- addContextToQuery(BooleanQuery.Builder, BytesRef, BooleanClause.Occur) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
This method is handy as we do not need access to internal fields such as CONTEXTS_FIELD_NAME in order to build queries
However, here may not be its best location.
- addCount - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- AddDocTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Add a document, optionally of a certain size.
- AddDocTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
- addDocument(Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.IndexWriter
-
Adds a document to this index.
- addDocument(Iterable<T>) - Method in class org.apache.lucene.index.RandomIndexWriter
-
Adds a Document.
- addDocument(Term, Iterable<? extends IndexableField>) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- addDocuments(Iterable<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.IndexWriter
-
Atomically adds a block of documents with sequentially
assigned document IDs, such that an external reader
will see all or none of the documents.
- addDocuments(Iterable<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- addDocuments(Term, List<? extends Iterable<? extends IndexableField>>) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- addDone() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
-
- addDone() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
-
- addDone() - Method in interface org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.OrdinalMap
-
Call addDone() to say that all addMapping() have been done.
- addEpsilon(int, int) - Method in class org.apache.lucene.util.automaton.Automaton
-
Add a [virtual] epsilon transition between source and dest.
- addEpsilon(int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Add a [virtual] epsilon transition between source and dest.
- addEscapes(String) - Static method in error org.apache.lucene.queryparser.classic.TokenMgrError
-
Replaces unprintable characters by their escaped (or unicode escaped)
equivalents in the given string
- addEscapes(String) - Static method in error org.apache.lucene.queryparser.flexible.standard.parser.TokenMgrError
-
Replaces unprintable characters by their escaped (or unicode escaped)
equivalents in the given string
- addEscapes(String) - Static method in error org.apache.lucene.queryparser.surround.parser.TokenMgrError
-
Replaces unprintable characters by their escaped (or unicode escaped)
equivalents in the given string
- addException(String, ArrayList<Object>) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Add an exception to the tree.
- addException(String, ArrayList<Object>) - Method in interface org.apache.lucene.analysis.compound.hyphenation.PatternConsumer
-
Add a hyphenation exception.
- addFacetCount(BytesRef, int) - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.GroupedFacetResult
-
- AddFacetedDocTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Add a faceted document.
- AddFacetedDocTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.AddFacetedDocTask
-
- addField(FieldInfo, long) - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexWriter
-
- addField(FieldInfo, long) - Method in class org.apache.lucene.codecs.blockterms.TermsIndexWriterBase
-
- addField(FieldInfo, long) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter
-
- addField(String, String, Analyzer) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Convenience method; Tokenizes the given field text and adds the resulting
terms to the index; Equivalent to adding an indexed non-keyword Lucene
Field
that is tokenized, not stored,
termVectorStored with positions (or termVectorStored with positions and offsets),
- addField(IndexableField, Analyzer) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Adds a lucene
IndexableField
to the MemoryIndex using the provided analyzer.
- addField(String, TokenStream) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Iterates over the given token stream and adds the resulting terms to the index;
Equivalent to adding a tokenized, indexed, termVectorStored, unstored,
Lucene
Field
.
- addField(String, TokenStream, int) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Iterates over the given token stream and adds the resulting terms to the index;
Equivalent to adding a tokenized, indexed, termVectorStored, unstored,
Lucene
Field
.
- addField(String, TokenStream, int, int) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Iterates over the given token stream and adds the resulting terms to the index;
Equivalent to adding a tokenized, indexed, termVectorStored, unstored,
Lucene
Field
.
- addFieldConfigListener(FieldConfigListener) - Method in class org.apache.lucene.queryparser.flexible.core.config.QueryConfigHandler
-
Adds a listener.
- addFile(String) - Method in class org.apache.lucene.index.SegmentInfo
-
Add this file to the set of files written for this
segment.
- addFiles(Collection<String>) - Method in class org.apache.lucene.index.SegmentInfo
-
Add these files to the set of files written for this
segment.
- addGap(int) - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
-
Add a gap after the previous clause of a defined width
- addHorizontalPlane(PlanetModel, double, Plane, Membership...) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add a horizontal plane to the bounds description.
- addHorizontalPlane(PlanetModel, double, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addHorizontalPlane(PlanetModel, double, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Add a horizontal plane to the bounds description.
- addId(Document, String) - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- addIfCompetitive(Util.FSTPath<T>) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-
- addIfNoOverlap(FieldPhraseList.WeightedPhraseInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList
-
- addIndexes(Directory...) - Method in class org.apache.lucene.index.IndexWriter
-
Adds all segments from an array of indexes into this index.
- addIndexes(CodecReader...) - Method in class org.apache.lucene.index.IndexWriter
-
Merges the provided indexes into this index.
- addIndexes(Directory...) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- addIndexes(CodecReader...) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- ADDINDEXES_INPUT_DIR - Static variable in class org.apache.lucene.benchmark.byTask.tasks.AddIndexesTask
-
- addIndexesSlowly(IndexWriter, DirectoryReader...) - Static method in class org.apache.lucene.util.TestUtil
-
- AddIndexesTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
- AddIndexesTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.AddIndexesTask
-
- addIntersection(PlanetModel, Plane, Plane, Membership...) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add the intersection between two planes to the bounds description.
- addIntersection(PlanetModel, Plane, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addIntersection(PlanetModel, Plane, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- addItem() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
update count of items generated by this source
- addLabel(FacetLabel, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.LabelToOrdinal
-
Adds a new label if its not yet in the table.
- addLatLine(double, double, double) - Method in class org.apache.lucene.geo.EarthDebugger
-
Draws a line a fixed latitude, spanning the min/max longitude
- addListener(ReferenceManager.RefreshListener) - Method in class org.apache.lucene.search.ReferenceManager
-
Adds a listener, to be notified when a reference is refreshed/swapped.
- addLonLine(double, double, double) - Method in class org.apache.lucene.geo.EarthDebugger
-
Draws a line a fixed longitude, spanning the min/max latitude
- addMapping(int, int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
-
- addMapping(int, int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
-
- addMapping(int, int) - Method in interface org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.OrdinalMap
-
Record a mapping.
- addMatch(int, int, BytesRef, int) - Method in class org.apache.lucene.search.uhighlight.Passage
-
- addMultiTermClauses(List<BooleanClause>, Query) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Adds clauses generated from analysis over text containing whitespace.
- addNonMatch(StringBuilder, String) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Called while highlighting a single result, to append a
non-matching chunk of text from the suggestion to the
provided fragments list.
- addNormsField(FieldInfo, NormsProducer) - Method in class org.apache.lucene.codecs.NormsConsumer
-
Writes normalization values for a field.
- addNormsField(FieldInfo, NormsProducer) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsConsumer
-
- addNumericField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Writes numeric docvalues for a field.
- addOffCorrectMap(int, int) - Method in class org.apache.lucene.analysis.charfilter.BaseCharFilter
-
Adds an offset correction mapping at the given output stream offset.
- addOffCorrectMap(int, int) - Method in class org.apache.lucene.analysis.MockCharFilter
-
- addPattern(String, String) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Add a pattern to the tree.
- addPattern(String, String) - Method in interface org.apache.lucene.analysis.compound.hyphenation.PatternConsumer
-
Add hyphenation patterns.
- addPlane(PlanetModel, Plane, Membership...) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add a general plane to the bounds description.
- addPlane(PlanetModel, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addPlane(PlanetModel, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- addPoint(double, double) - Method in class org.apache.lucene.geo.EarthDebugger
-
- addPoint(GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add a single point.
- addPoint(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addPoint(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- addPointToDoc(String, Document, double, double) - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- addPolygon(Polygon) - Method in class org.apache.lucene.geo.EarthDebugger
-
- addPolygon(Polygon, String) - Method in class org.apache.lucene.geo.EarthDebugger
-
- addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- addPosition(int, BytesRef, int, int) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
-
Add a new position and payload, and start/end offset.
- addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsWriter
-
- addPosition(int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Adds a term position and offsets
- addPositionSpans(List<PositionSpan>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
-
- addPrefixMatch(StringBuilder, String, String, String) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Called while highlighting a single result, to append a
matched prefix token, to the provided fragments list.
- addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- addProx(int, DataInput, DataInput) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Called by IndexWriter when writing new segments.
- addQueryBuilder(String, QueryBuilder) - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- addRandomFields(Document) - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- addRange(Document, BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- addRect(double, double, double, double) - Method in class org.apache.lucene.geo.EarthDebugger
-
- addRect(double, double, double, double, String) - Method in class org.apache.lucene.geo.EarthDebugger
-
- addResult(int, boolean, long) - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Add a (possibly relevant) doc.
- addShape(T) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
Add a shape to the composite.
- addSortedField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Writes pre-sorted binary docvalues for a field.
- addSortedNumericField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Writes pre-sorted numeric docvalues for a field
- addSortedSetField(FieldInfo, DocValuesProducer) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Writes pre-sorted set docvalues for a field
- addSpanBuilder(String, SpanQueryBuilder) - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
- addSpanQueries(SpanNearClauseFactory) - Method in class org.apache.lucene.queryparser.surround.query.DistanceQuery
-
- addSpanQueries(SpanNearClauseFactory) - Method in interface org.apache.lucene.queryparser.surround.query.DistanceSubQuery
-
- addSpanQueries(SpanNearClauseFactory) - Method in class org.apache.lucene.queryparser.surround.query.OrQuery
-
- addSpanQueries(SpanNearClauseFactory) - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- addSpanQuery(Query) - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- addSpanQueryBuilder(String, SpanQueryBuilder) - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
- addSpanQueryWeighted(SpanQuery, float) - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- addStartPaths(FST.Arc<T>, T, boolean, IntsRefBuilder) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-
- addStartPaths(FST.Arc<T>, T, boolean, IntsRefBuilder, float, CharSequence, int) - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-
Adds all leaving arcs, including 'finished' arc, if
the node is final, from this node into the queue.
- addTask(PerfTask) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- addTaxonomy(Directory, DirectoryTaxonomyWriter.OrdinalMap) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Takes the categories from the given taxonomy directory, and adds the
missing ones to this taxonomy.
- addTerms(String, String) - Method in class org.apache.lucene.classification.utils.NearestFuzzyQuery
-
Adds user input for "fuzzification"
- addTerms(String, String, float, int) - Method in class org.apache.lucene.sandbox.queries.FuzzyLikeThisQuery
-
Adds user input for "fuzzification"
- addTermWeighted(Term, float) - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- addTokenFilter(Class<? extends TokenFilterFactory>, String...) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given token filter.
- addTokenFilter(Class<? extends TokenFilterFactory>, Map<String, String>) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given token filter.
- addTokenFilter(String, String...) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given token filter.
- addTokenFilter(String, Map<String, String>) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Adds the given token filter.
- addTokenFilter(String, Map<String, String>) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.ConditionBuilder
-
Adds the given token filter.
- addTokenFilter(String, String...) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.ConditionBuilder
-
Adds the given token filter.
- addTokenFilter(Class<? extends TokenFilterFactory>, Map<String, String>) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.ConditionBuilder
-
Adds the given token filter.
- addTokenFilter(Class<? extends TokenFilterFactory>, String...) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.ConditionBuilder
-
Adds the given token filter.
- addTransition(int, int, String) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Adds a transition to the automaton.
- addTransition(int, int, BytesRef) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Adds a transition to the automaton.
- addTransition(int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton
-
Add a new transition with min = max = label.
- addTransition(int, int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton
-
Add a new transition with the specified source, dest, min, max.
- addTransition(int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Add a new transition with min = max = label.
- addTransition(int, int, int, int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Add a new transition with the specified source, dest, min, max.
- addValue(BytesRef) - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
Records a value in the set.
- addVerticalPlane(PlanetModel, double, Plane, Membership...) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add a vertical plane to the bounds description.
- addVerticalPlane(PlanetModel, double, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addVerticalPlane(PlanetModel, double, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Add a vertical plane to the bounds description.
- addVirusChecker(Path) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- addWholeMatch(StringBuilder, String, String) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Called while highlighting a single result, to append
the whole matched token to the provided fragments list.
- addXValue(GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add an X value.
- addXValue(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addXValue(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- addXValue(double) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Add a specific X value.
- addYValue(GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add a Y value.
- addYValue(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addYValue(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- addYValue(double) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Add a specific Y value.
- addZValue(GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Add a Z value.
- addZValue(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- addZValue(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- addZValue(double) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Add a specific Z value.
- advance() - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter.NumberBuffer
-
- advance(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- advance(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- advance(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- advance(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- advance(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- advance(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- advance(int) - Method in class org.apache.lucene.index.FilterBinaryDocValues
-
- advance(int) - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- advance(int) - Method in class org.apache.lucene.index.FilterNumericDocValues
-
- advance(int) - Method in class org.apache.lucene.index.LegacyBinaryDocValuesWrapper
-
Deprecated.
- advance(int) - Method in class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- advance(int) - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- advance(int) - Method in class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- advance(int) - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- advance(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- advance(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- advance(int) - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- advance(int) - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- advance(int) - Method in class org.apache.lucene.search.ConjunctionDISI
-
- advance(int) - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
-
- advance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
-
Advances to the first beyond the current whose document number is greater
than or equal to target, and returns the document number itself.
- advance(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-
- advance(int) - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- advance(int) - Method in class org.apache.lucene.search.spans.FilterSpans
-
- advance(int) - Method in class org.apache.lucene.search.spans.TermSpans
-
- advance(int) - Method in class org.apache.lucene.util.BitSetIterator
-
- advanceExact(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.FilterBinaryDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.FilterNumericDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.LegacyBinaryDocValuesWrapper
-
Deprecated.
- advanceExact(int) - Method in class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- advanceExact(int) - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- advanceExact(int) - Method in class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- advanceExact(int) - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- advanceExact(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- advanceExact(int) - Method in class org.apache.lucene.search.DoubleValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.apache.lucene.search.LongValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.apache.lucene.spatial.ShapeValues
-
Advance the iterator to the given document
- advanceSegmentInfosVersion(long) - Method in class org.apache.lucene.index.IndexWriter
-
- advanceTo(int) - Method in class org.apache.lucene.search.grouping.GroupSelector
-
Advance the GroupSelector's iterator to the given document
- advanceTo(int) - Method in class org.apache.lucene.search.grouping.TermGroupSelector
-
- advanceTo(int) - Method in class org.apache.lucene.search.grouping.ValueSourceGroupSelector
-
- advise(FileDescriptor, long, long, int) - Static method in class org.apache.lucene.store.NativePosixUtil
-
- afterAlways(List<Throwable>) - Method in class org.apache.lucene.util.TestRuleLimitSysouts
-
- afterAlways(List<Throwable>) - Method in class org.apache.lucene.util.TestRuleRestoreSystemProperties
-
- afterClass() - Static method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- afterClass() - Static method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- afterClassTestExplanations() - Static method in class org.apache.lucene.search.BaseExplanationTestCase
-
- afterClose() - Method in class org.apache.lucene.search.ReferenceManager
-
Called after close(), so subclass can free any resources.
- AfterEffect - Class in org.apache.lucene.search.similarities
-
This class acts as the base class for the implementations of the first
normalization of the informative content in the DFR framework.
- AfterEffect() - Constructor for class org.apache.lucene.search.similarities.AfterEffect
-
Sole constructor.
- afterEffect - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
-
The first normalization of the information content.
- AfterEffect.NoAfterEffect - Class in org.apache.lucene.search.similarities
-
Implementation used when there is no aftereffect.
- AfterEffectB - Class in org.apache.lucene.search.similarities
-
Model of the information gain based on the ratio of two Bernoulli processes.
- AfterEffectB() - Constructor for class org.apache.lucene.search.similarities.AfterEffectB
-
Sole constructor: parameter-free
- AfterEffectL - Class in org.apache.lucene.search.similarities
-
Model of the information gain based on Laplace's law of succession.
- AfterEffectL() - Constructor for class org.apache.lucene.search.similarities.AfterEffectL
-
Sole constructor: parameter-free
- afterIfSuccessful() - Method in class org.apache.lucene.util.TestRuleLimitSysouts
-
We're only interested in failing the suite if it was successful (otherwise
just propagate the original problem and don't bother doing anything else).
- afterMaybeRefresh() - Method in class org.apache.lucene.search.ReferenceManager
-
Called after a refresh was attempted, regardless of
whether a new reference was in fact created.
- afterPosition() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
-
This is called when all input tokens leaving a given
position have been returned.
- afterPosition() - Method in class org.apache.lucene.analysis.MockGraphTokenFilter
-
- afterPosition() - Method in class org.apache.lucene.analysis.MockRandomLookaheadTokenFilter
-
- afterRefresh(boolean) - Method in class org.apache.lucene.search.LiveFieldValues
-
- afterRefresh(boolean) - Method in interface org.apache.lucene.search.ReferenceManager.RefreshListener
-
Called after the attempted refresh; if the refresh
did open a new reference then didRefresh will be true
and
ReferenceManager.acquire()
is guaranteed to return the new
reference.
- aggregateDistances(double, double) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Aggregate two distances together to produce a "sum".
- AlcoholicMergePolicy - Class in org.apache.lucene.index
-
Merge policy for testing, it is like an alcoholic.
- AlcoholicMergePolicy(TimeZone, Random) - Constructor for class org.apache.lucene.index.AlcoholicMergePolicy
-
- ALEF - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- ALEF - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- ALEF_HAMZA_ABOVE - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- ALEF_HAMZA_BELOW - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- ALEF_MADDA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- Algorithm - Class in org.apache.lucene.benchmark.byTask.utils
-
Test algorithm, as read from file
- Algorithm(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.utils.Algorithm
-
Read algorithm from file
Property examined: alt.tasks.packages == comma separated list of
alternate package names where tasks would be searched for, when not found
in the default package (that of
PerfTask
Object.getClass()
).
- alignObjectSize(long) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
- ALL - Static variable in class org.apache.lucene.index.PostingsEnum
-
- all(int) - Static method in class org.apache.lucene.search.DocIdSetIterator
-
- ALL - Static variable in class org.apache.lucene.util.automaton.RegExp
-
Syntax flag, enables all optional regexp syntax.
- AllDeletedFilterReader - Class in org.apache.lucene.index
-
Filters the incoming reader and makes all documents appear deleted.
- AllDeletedFilterReader(LeafReader) - Constructor for class org.apache.lucene.index.AllDeletedFilterReader
-
- allExists(int, FunctionValues[]) - Static method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- allExists(int, FunctionValues, FunctionValues) - Static method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
Equivalent to the FunctionValues[]
method with the same name, but optimized for
dealing with exactly 2 arguments.
- allFragmentsProcessed() - Method in class org.apache.lucene.search.highlight.QueryTermScorer
-
- AllGroupHeadsCollector<T> - Class in org.apache.lucene.search.grouping
-
This collector specializes in collecting the most relevant document (group head) for each
group that matches the query.
- AllGroupHeadsCollector.GroupHead<T> - Class in org.apache.lucene.search.grouping
-
Represents a group head.
- AllGroupsCollector<T> - Class in org.apache.lucene.search.grouping
-
A collector that collects all groups that match the
query.
- AllGroupsCollector(GroupSelector<T>) - Constructor for class org.apache.lucene.search.grouping.AllGroupsCollector
-
Create a new AllGroupsCollector
- alloc(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
This is to implement memory allocation in the array.
- alloc(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- allocate() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- allocate(int) - Method in class org.apache.lucene.store.ByteBuffersDataOutput.ByteBufferRecycler
-
- ALLOCATE_BB_ON_HEAP - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
-
- Allocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.Allocator
-
- Allocator(int) - Constructor for class org.apache.lucene.util.IntBlockPool.Allocator
-
- allocSlice(byte[], int) - Method in class org.apache.lucene.util.ByteBlockPool
-
Creates a new byte slice with the given starting size and
returns the slices offset in the pool.
- ALLOW_LEADING_WILDCARD - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set whether leading wildcards are supported
- allowedSuffix(String) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- allowedTruncation(String) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- AllowLeadingWildcardProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- AllowLeadingWildcardProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.AllowLeadingWildcardProcessor
-
- AllScorer(LeafReaderContext, FunctionQuery.FunctionWeight, float) - Constructor for class org.apache.lucene.queries.function.FunctionQuery.AllScorer
-
- ALPHA - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- ALPHA - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- ALPHA - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- ALPHA - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
-
- ALPHA - Static variable in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
The constant used for backoff smoothing; during
lookup, this means that if a given trigram did not
occur, and we backoff to the bigram, the overall score
will be 0.4 times what the bigram model would have
assigned.
- ALPHANUM - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- ALPHANUM - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
-
- ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Alpha/numeric token type
- ALPHANUM - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Alpha/numeric token type
- ALPHANUM_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- AlreadyClosedException - Exception in org.apache.lucene.store
-
This exception is thrown when there is an attempt to
access something that has already been closed.
- AlreadyClosedException(String) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
-
- AlreadyClosedException(String, Throwable) - Constructor for exception org.apache.lucene.store.AlreadyClosedException
-
- AlreadySetException() - Constructor for exception org.apache.lucene.util.SetOnce.AlreadySetException
-
- ALTFIELD - Static variable in class org.apache.lucene.search.BaseExplanationTestCase
-
- ALWAYS_CACHE - Static variable in interface org.apache.lucene.search.QueryCachingPolicy
-
- alwaysDocValuesFormat(DocValuesFormat) - Static method in class org.apache.lucene.util.TestUtil
-
Return a Codec that can read any of the
default codecs and formats, but always writes in the specified
format.
- alwaysPostingsFormat(PostingsFormat) - Static method in class org.apache.lucene.util.TestUtil
-
Return a Codec that can read any of the
default codecs and formats, but always writes in the specified
format.
- Among - Class in org.tartarus.snowball
-
This is the rev 502 of the Snowball SVN trunk,
now located at
GitHub,
but modified:
made abstract and introduced abstract method stem to avoid expensive reflection in filter class.
- Among(String, int, int, String, MethodHandles.Lookup) - Constructor for class org.tartarus.snowball.Among
-
- amortizeFacetCounts(FacetResult, FacetsConfig, IndexSearcher) - Method in class org.apache.lucene.facet.RandomSamplingFacetsCollector
-
Note: if you use a counting
Facets
implementation, you can amortize the
sampled counts by calling this method.
- ANALYSIS_DATA_DIR - Static variable in class org.apache.lucene.analysis.cn.smart.AnalyzerProfile
-
Global indicating the configured analysis data directory
- AnalysisOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
Provides a base class for analysis based offset strategies to extend from.
- AnalysisOffsetStrategy(UHComponents, Analyzer) - Constructor for class org.apache.lucene.search.uhighlight.AnalysisOffsetStrategy
-
- AnalysisSPILoader<S extends AbstractAnalysisFactory> - Class in org.apache.lucene.analysis.util
-
Helper class for loading named SPIs from classpath (e.g.
- AnalysisSPILoader(Class<S>) - Constructor for class org.apache.lucene.analysis.util.AnalysisSPILoader
-
- AnalysisSPILoader(Class<S>, ClassLoader) - Constructor for class org.apache.lucene.analysis.util.AnalysisSPILoader
-
- AnalysisSPILoader(Class<S>, String[]) - Constructor for class org.apache.lucene.analysis.util.AnalysisSPILoader
-
- AnalysisSPILoader(Class<S>, String[], ClassLoader) - Constructor for class org.apache.lucene.analysis.util.AnalysisSPILoader
-
- analyze(String, CharsRefBuilder) - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Parser
-
- analyzeBoolean(String, TokenStream) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates simple boolean query from the cached tokenstream contents
- analyzeGraphBoolean(String, TokenStream, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a boolean query from a graph token stream.
- analyzeGraphPhrase(TokenStream, String, int) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates graph phrase query from the tokenstream contents
- analyzeMultiBoolean(String, TokenStream, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates complex boolean query from the cached tokenstream contents
- analyzeMultiPhrase(String, TokenStream, int) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates complex phrase query from the cached tokenstream contents
- analyzePhrase(String, TokenStream, int) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates simple phrase query from the cached tokenstream contents
- Analyzer - Class in org.apache.lucene.analysis
-
An Analyzer builds TokenStreams, which analyze text.
- Analyzer() - Constructor for class org.apache.lucene.analysis.Analyzer
-
- Analyzer(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.Analyzer
-
- analyzer - Variable in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
Analyzer
to be used for tokenizing unseen input text
- ANALYZER - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
Analyzer
used for terms found in the query
- analyzer - Variable in class org.apache.lucene.queryparser.xml.CoreParser
-
- analyzer - Static variable in class org.apache.lucene.search.BaseExplanationTestCase
-
- analyzer - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- analyzer - Variable in class org.apache.lucene.search.suggest.document.PrefixCompletionQuery
-
Used to analyze the term text
- analyzer - Variable in class org.apache.lucene.search.uhighlight.AnalysisOffsetStrategy
-
- analyzer - Variable in class org.apache.lucene.util.QueryBuilder
-
- Analyzer.ReuseStrategy - Class in org.apache.lucene.analysis
-
- Analyzer.TokenStreamComponents - Class in org.apache.lucene.analysis
-
This class encapsulates the outer components of a token stream.
- AnalyzerFactory - Class in org.apache.lucene.benchmark.byTask.utils
-
A factory to create an analyzer.
- AnalyzerFactory(List<CharFilterFactory>, TokenizerFactory, List<TokenFilterFactory>) - Constructor for class org.apache.lucene.benchmark.byTask.utils.AnalyzerFactory
-
- AnalyzerFactoryTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Analyzer factory construction task.
- AnalyzerFactoryTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.AnalyzerFactoryTask
-
- AnalyzerProfile - Class in org.apache.lucene.analysis.cn.smart
-
Manages analysis data configuration for SmartChineseAnalyzer
- AnalyzerProfile() - Constructor for class org.apache.lucene.analysis.cn.smart.AnalyzerProfile
-
- AnalyzerQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- AnalyzerQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.AnalyzerQueryNodeProcessor
-
- AnalyzerWrapper - Class in org.apache.lucene.analysis
-
Extension to
Analyzer
suitable for Analyzers which wrap
other Analyzers.
- AnalyzerWrapper(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.AnalyzerWrapper
-
Creates a new AnalyzerWrapper with the given reuse strategy.
- analyzeTerm(String, TokenStream) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates simple term query from the cached tokenstream contents
- AnalyzingInfixSuggester - Class in org.apache.lucene.search.suggest.analyzing
-
Analyzes the input text and then suggests matches based
on prefix matches to any tokens in the indexed text.
- AnalyzingInfixSuggester(Directory, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
- AnalyzingInfixSuggester(Directory, Analyzer, Analyzer, int, boolean) - Constructor for class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
- AnalyzingInfixSuggester(Directory, Analyzer, Analyzer, int, boolean, boolean, boolean) - Constructor for class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
- AnalyzingInfixSuggester(Directory, Analyzer, Analyzer, int, boolean, boolean, boolean, boolean) - Constructor for class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Create a new instance, loading from a previously built
AnalyzingInfixSuggester directory, if it exists.
- AnalyzingSuggester - Class in org.apache.lucene.search.suggest.analyzing
-
Suggester that first analyzes the surface form, adds the
analyzed form to a weighted FST, and then does the same
thing at lookup time.
- AnalyzingSuggester(Directory, String, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- AnalyzingSuggester(Directory, String, Analyzer, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- AnalyzingSuggester(Directory, String, Analyzer, Analyzer, int, int, int, boolean) - Constructor for class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
Creates a new suggester.
- AND - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- AND - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- AND - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- and(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
-
this = this AND other
- and(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
-
this = this AND other
- AND_OPERATOR - Static variable in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Alternative form of QueryParser.Operator.AND
- AND_OPERATOR - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables AND
operator (+)
- andNot(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
-
this = this AND NOT other
- andNot(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
-
this = this AND NOT other
- andNotCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
-
Returns the popcount or cardinality of "a and not b" or
"intersection(a, not(b))".
- AndQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- AndQuery - Class in org.apache.lucene.queryparser.surround.query
-
Factory for conjunctions
- AndQuery(List<SrndQuery>, boolean, String) - Constructor for class org.apache.lucene.queryparser.surround.query.AndQuery
-
- AndQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
AndQueryNode
represents an AND boolean operation performed on a
list of nodes.
- AndQueryNode(List<QueryNode>) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.AndQueryNode
-
- anyExists(int, FunctionValues[]) - Static method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- anyExists(int, FunctionValues, FunctionValues) - Static method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
Equivalent to the FunctionValues[]
method with the same name, but optimized for
dealing with exactly 2 arguments.
- anyFilesExceptWriteLock(Directory) - Static method in class org.apache.lucene.util.TestUtil
-
- AnyQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
AnyQueryNode
represents an ANY operator performed on a list of
nodes.
- AnyQueryNode(List<QueryNode>, CharSequence, int) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
- AnyQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
Builds a BooleanQuery of SHOULD clauses, possibly with
some minimum number to match.
- AnyQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.AnyQueryNodeBuilder
-
- ANYSTRING - Static variable in class org.apache.lucene.util.automaton.RegExp
-
Syntax flag, enables anystring (@).
- APOSTROPHE - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- APOSTROPHE_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- ApostropheFilter - Class in org.apache.lucene.analysis.tr
-
Strips all characters after an apostrophe (including the apostrophe itself).
- ApostropheFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.tr.ApostropheFilter
-
- ApostropheFilterFactory - Class in org.apache.lucene.analysis.tr
-
- ApostropheFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.tr.ApostropheFilterFactory
-
- 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(CharSequence) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- append(CharSequence, int, int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- append(char) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- append(StringBuilder, String, int, int) - Method in class org.apache.lucene.search.uhighlight.DefaultPassageFormatter
-
Appends original text to the response.
- append(byte[], long, int) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- append(byte[], long, int) - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- append(byte[], long, int) - Method in interface org.apache.lucene.util.bkd.PointWriter
-
Add a new point
- append(BytesRef) - Method in class org.apache.lucene.util.ByteBlockPool
-
Appends the bytes in the provided
BytesRef
at
the current position.
- append(BytesRef) - Method in class org.apache.lucene.util.BytesRefArray
-
- append(byte) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Append a single byte to this builder.
- append(byte[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Append the provided bytes to this builder.
- append(BytesRef) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Append the provided bytes to this builder.
- append(BytesRefBuilder) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Append the provided bytes to this builder.
- append(CharSequence) - Method in class org.apache.lucene.util.CharsRefBuilder
-
- append(CharSequence, int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
-
- append(char) - Method in class org.apache.lucene.util.CharsRefBuilder
-
- append(char[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Appends the given array to this CharsRef
- append(int) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Append the provided int to this buffer.
- appendAnyChar(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Automata
-
Accept any single character starting from the specified state, returning the new state
- appendChar(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Automata
-
Appends the specified character to the specified state, returning a new state.
- appendRegExpForChar(char, StringBuilder) - Method in class org.apache.lucene.queryparser.surround.query.SrndTruncQuery
-
- apply(char[], int) - Method in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
-
- apply(String) - Method in interface org.apache.lucene.index.RandomIndexWriter.TestPoint
-
- apply(Statement, Description) - Method in class org.apache.lucene.util.TestRuleAssertionsRequired
-
- apply(Statement, Description) - Method in class org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures
-
- apply(Statement, Description) - Method in class org.apache.lucene.util.TestRuleIgnoreTestSuites
-
- apply(Statement, Description) - Method in class org.apache.lucene.util.TestRuleMarkFailure
-
- apply(Statement, Description) - Method in class org.apache.lucene.util.TestRuleStoreClassName
-
- apply(StringBuilder, CharSequence) - Static method in class org.egothor.stemmer.Diff
-
Apply the given patch string diff to the given string
dest.
- applyDeletes(SegmentInfos, int) - Static method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Apply numDeletes
uniformly across all segments of infos
.
- applyMerge(SegmentInfos, MergePolicy.OneMerge, String, BaseMergePolicyTestCase.IOStats) - Static method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Apply a merge to a
SegmentInfos
instance, accumulating the number
of written bytes into
stats
.
- applyToAll(Collection<T>, IOUtils.IOConsumer<T>) - Static method in class org.apache.lucene.util.IOUtils
-
Applies the consumer to all non-null elements in the collection even if an exception is thrown.
- approximateCardinality() - Method in class org.apache.lucene.util.BitSet
-
Return an approximation of the cardinality of this set.
- approximateCardinality() - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- approximation - Variable in class org.apache.lucene.search.DisiWrapper
-
- approximation - Variable in class org.apache.lucene.search.TwoPhaseIterator
-
- approximation() - Method in class org.apache.lucene.search.TwoPhaseIterator
-
Return an approximation.
- ArabicAnalyzer - Class in org.apache.lucene.analysis.ar
-
- ArabicAnalyzer() - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
- ArabicAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Builds an analyzer with the given stop words
- ArabicAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Builds an analyzer with the given stop word.
- ArabicNormalizationFilter - Class in org.apache.lucene.analysis.ar
-
- ArabicNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ar.ArabicNormalizationFilter
-
- ArabicNormalizationFilterFactory - Class in org.apache.lucene.analysis.ar
-
- ArabicNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ar.ArabicNormalizationFilterFactory
-
Creates a new ArabicNormalizationFilterFactory
- ArabicNormalizer - Class in org.apache.lucene.analysis.ar
-
Normalizer for Arabic.
- ArabicNormalizer() - Constructor for class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- ArabicStemFilter - Class in org.apache.lucene.analysis.ar
-
- ArabicStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ar.ArabicStemFilter
-
- ArabicStemFilterFactory - Class in org.apache.lucene.analysis.ar
-
- ArabicStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ar.ArabicStemFilterFactory
-
Creates a new ArabicStemFilterFactory
- ArabicStemmer - Class in org.apache.lucene.analysis.ar
-
Stemmer for Arabic.
- ArabicStemmer() - Constructor for class org.apache.lucene.analysis.ar.ArabicStemmer
-
- ArabicStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- ArabicStemmer() - Constructor for class org.tartarus.snowball.ext.ArabicStemmer
-
- ARC - Static variable in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Arc distance calculator
- Arc() - Constructor for class org.apache.lucene.util.fst.Builder.Arc
-
- Arc() - Constructor for class org.apache.lucene.util.fst.FST.Arc
-
- arc - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-
Holds the last arc appended to this path
- ArcDistance - Class in org.apache.lucene.spatial3d.geom
-
Arc distance computation style.
- ArcDistance() - Constructor for class org.apache.lucene.spatial3d.geom.ArcDistance
-
Constructor.
- arcDistance(Vector) - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Compute an arc distance between two points.
- arcDistance(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Compute an arc distance between two points.
- arcDistance(PlanetModel, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute arc distance from plane to a vector expressed with a
GeoPoint
.
- arcDistance(PlanetModel, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute arc distance from plane to a vector.
- arcIdx - Variable in class org.apache.lucene.util.fst.FST.Arc
-
Where we are in the array; only valid if bytesPerArc != 0.
- arcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- area(Rectangle) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- area(Circle) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- arePointsCoplanar(GeoPoint, GeoPoint, GeoPoint) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Checks if three points are coplanar in any of the three planes they can describe.
- args - Variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- ArmenianAnalyzer - Class in org.apache.lucene.analysis.hy
-
- ArmenianAnalyzer() - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
- ArmenianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
Builds an analyzer with the given stop words.
- ArmenianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
Builds an analyzer with the given stop words.
- ArmenianStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- ArmenianStemmer() - Constructor for class org.tartarus.snowball.ext.ArmenianStemmer
-
- ArrayUtil - Class in org.apache.lucene.util
-
Methods for manipulating arrays.
- articulationPoints() - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
-
Returns the articulation points (or cut vertices) of the graph:
https://en.wikipedia.org/wiki/Biconnected_component
- ASCIIFoldingFilter - Class in org.apache.lucene.analysis.miscellaneous
-
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.miscellaneous.ASCIIFoldingFilter
-
- ASCIIFoldingFilter(TokenStream, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilter
-
- ASCIIFoldingFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- ASCIIFoldingFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilterFactory
-
Creates a new ASCIIFoldingFilterFactory
- asDocIdSetIterator(TwoPhaseIterator) - Static method in class org.apache.lucene.search.TwoPhaseIterator
-
- asDoubleValuesSource() - Method in class org.apache.lucene.queries.function.ValueSource
-
Expose this ValueSource as a DoubleValuesSource
- asin(double) - Static method in class org.apache.lucene.util.SloppyMath
-
Returns the arc sine of a value.
- asinh(double) - Static method in class org.apache.lucene.util.MathUtil
-
Calculates inverse hyperbolic sine of a double
value.
- asList() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns all contained segments as an unmodifiable List
view.
- asList(Object) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- asLongValuesSource() - Method in class org.apache.lucene.queries.function.ValueSource
-
Expose this ValueSource as a LongValuesSource
- asReadOnlyBits() - Method in class org.apache.lucene.util.FixedBitSet
-
Convert this instance to read-only
Bits
.
- assertAnalyzesTo(Analyzer, String, String[], int[], int[], String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[], int[], int[], String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[], int[], int[], String[], int[], int[], boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[], int[], int[], String[], int[], int[], boolean, byte[][]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[], String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesTo(Analyzer, String, String[], int[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesToPositions(Analyzer, String, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAnalyzesToPositions(Analyzer, String, String[], String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertAttributeReflection(AttributeImpl, Map<String, T>) - Static method in class org.apache.lucene.util.TestUtil
-
Checks some basic behaviour of an AttributeImpl
- assertDelCount(int, SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy
-
Asserts that the delCount for this SegmentCommitInfo is valid
- assertDeletedDocsEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
- assertDocsAndPositionsEnumEquals(String, PostingsEnum, PostingsEnum) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks docs + freqs + positions + payloads, sequentially
- assertDocsEnumEquals(String, PostingsEnum, PostingsEnum, boolean) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks docs + freqs, sequentially
- assertDocsSkippingEquals(String, IndexReader, int, PostingsEnum, PostingsEnum, boolean) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks advancing docs
- assertDocValuesEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks that docvalues across all fields are equivalent
- assertDocValuesEquals(String, int, NumericDocValues, NumericDocValues) - Method in class org.apache.lucene.util.LuceneTestCase
-
- assertEqualArrays(String, byte[], byte[], int, int) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- assertEquals(FieldInfos, FieldInfos) - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
equality for entirety of fieldinfos
- assertEquals(FieldInfo, FieldInfo) - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
equality for two individual fieldinfo objects
- assertEquals(SegmentInfo, SegmentInfo) - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
- assertEquals(BaseTermVectorsFormatTestCase.RandomDocument, Fields) - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- assertEquals(BaseTermVectorsFormatTestCase.RandomTokenStream, FieldType, Terms) - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- assertEquals(BitSet, T, int) - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- assertEquals(int, BitSet, T) - Method in class org.apache.lucene.util.BaseDocIdSetTestCase
-
Assert that the content of the
DocIdSet
is the same as the content of the
BitSet
.
- assertEquals(TopDocs, TopDocs) - Static method in class org.apache.lucene.util.TestUtil
-
- assertFieldInfosEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
- assertFieldsEquals(String, IndexReader, Fields, Fields, boolean) - Method in class org.apache.lucene.util.LuceneTestCase
-
Fields api equivalency
- assertFieldStatisticsEquals(String, Fields, Fields) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks that top-level statistics on Fields are the same
- assertFinished(Spans) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Assert that spans
is exhausted.
- assertGraphStrings(Analyzer, String, String...) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Enumerates all accepted strings in the token graph created by the analyzer on the provided text, and then
asserts that it's equal to the expected strings.
- assertGraphStrings(TokenStream, String...) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Enumerates all accepted strings in the token graph created by the already initialized
TokenStream
.
- assertIDEquals(byte[], byte[]) - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
- AssertingBinaryDocValues(BinaryDocValues, int) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- AssertingBits(Bits) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingBits
-
- AssertingCodec - Class in org.apache.lucene.codecs.asserting
-
Acts like the default codec but with additional asserts.
- AssertingCodec() - Constructor for class org.apache.lucene.codecs.asserting.AssertingCodec
-
- AssertingDirectoryReader - Class in org.apache.lucene.index
-
- AssertingDirectoryReader(DirectoryReader) - Constructor for class org.apache.lucene.index.AssertingDirectoryReader
-
- AssertingDocValuesFormat - Class in org.apache.lucene.codecs.asserting
-
Just like the default but with additional asserts.
- AssertingDocValuesFormat() - Constructor for class org.apache.lucene.codecs.asserting.AssertingDocValuesFormat
-
- AssertingFields(Fields) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingFields
-
- AssertingIndexSearcher - Class in org.apache.lucene.search
-
Helper class that adds some extra checks to ensure correct
usage of IndexSearcher
and Weight
.
- AssertingIndexSearcher(Random, IndexReader) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
-
- AssertingIndexSearcher(Random, IndexReaderContext) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
-
- AssertingIndexSearcher(Random, IndexReader, ExecutorService) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
-
- AssertingIndexSearcher(Random, IndexReaderContext, ExecutorService) - Constructor for class org.apache.lucene.search.AssertingIndexSearcher
-
- AssertingLeafReader - Class in org.apache.lucene.index
-
- AssertingLeafReader(LeafReader) - Constructor for class org.apache.lucene.index.AssertingLeafReader
-
- AssertingLeafReader.AssertingBinaryDocValues - Class in org.apache.lucene.index
-
Wraps a BinaryDocValues but with additional asserts
- AssertingLeafReader.AssertingBits - Class in org.apache.lucene.index
-
Wraps a Bits but with additional asserts
- AssertingLeafReader.AssertingFields - Class in org.apache.lucene.index
-
Wraps a Fields but with additional asserts
- AssertingLeafReader.AssertingNumericDocValues - Class in org.apache.lucene.index
-
Wraps a NumericDocValues but with additional asserts
- AssertingLeafReader.AssertingPointValues - Class in org.apache.lucene.index
-
Wraps a SortedSetDocValues but with additional asserts
- AssertingLeafReader.AssertingPostingsEnum - Class in org.apache.lucene.index
-
Wraps a docsenum with additional checks
- AssertingLeafReader.AssertingSortedDocValues - Class in org.apache.lucene.index
-
Wraps a SortedDocValues but with additional asserts
- AssertingLeafReader.AssertingSortedNumericDocValues - Class in org.apache.lucene.index
-
Wraps a SortedNumericDocValues but with additional asserts
- AssertingLeafReader.AssertingSortedSetDocValues - Class in org.apache.lucene.index
-
Wraps a SortedSetDocValues but with additional asserts
- AssertingLeafReader.AssertingTerms - Class in org.apache.lucene.index
-
Wraps a Terms but with additional asserts
- AssertingLiveDocsFormat - Class in org.apache.lucene.codecs.asserting
-
Just like the default live docs format but with additional asserts.
- AssertingLiveDocsFormat() - Constructor for class org.apache.lucene.codecs.asserting.AssertingLiveDocsFormat
-
- AssertingNormsFormat - Class in org.apache.lucene.codecs.asserting
-
Just like the default but with additional asserts.
- AssertingNormsFormat() - Constructor for class org.apache.lucene.codecs.asserting.AssertingNormsFormat
-
- AssertingNumericDocValues(NumericDocValues, int) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- AssertingPointsFormat - Class in org.apache.lucene.codecs.asserting
-
Just like the default point format but with additional asserts.
- AssertingPointsFormat() - Constructor for class org.apache.lucene.codecs.asserting.AssertingPointsFormat
-
Create a new AssertingPointsFormat
- AssertingPointsFormat(PointsFormat) - Constructor for class org.apache.lucene.codecs.asserting.AssertingPointsFormat
-
Expert: Create an AssertingPointsFormat.
- AssertingPointValues(PointValues, int) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
Sole constructor.
- AssertingPostingsEnum(PostingsEnum) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- AssertingPostingsFormat - Class in org.apache.lucene.codecs.asserting
-
Just like the default postings format but with additional asserts.
- AssertingPostingsFormat() - Constructor for class org.apache.lucene.codecs.asserting.AssertingPostingsFormat
-
- AssertingQuery - Class in org.apache.lucene.search
-
Assertion-enabled query.
- AssertingQuery(Random, Query) - Constructor for class org.apache.lucene.search.AssertingQuery
-
Sole constructor.
- AssertingScorer - Class in org.apache.lucene.search
-
Wraps a Scorer with additional checks
- AssertingSortedDocValues(SortedDocValues, int) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- AssertingSortedNumericDocValues(SortedNumericDocValues, int) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- AssertingSortedSetDocValues(SortedSetDocValues, int) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- AssertingSpanQuery - Class in org.apache.lucene.search.spans
-
Wraps a span query with asserts
- AssertingSpanQuery(SpanQuery) - Constructor for class org.apache.lucene.search.spans.AssertingSpanQuery
-
- AssertingSpanWeight - Class in org.apache.lucene.search.spans
-
Wraps a SpanWeight with additional asserts
- AssertingSpanWeight(IndexSearcher, SpanWeight) - Constructor for class org.apache.lucene.search.spans.AssertingSpanWeight
-
Create an AssertingSpanWeight
- AssertingStoredFieldsFormat - Class in org.apache.lucene.codecs.asserting
-
Just like the default stored fields format but with additional asserts.
- AssertingStoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.asserting.AssertingStoredFieldsFormat
-
- AssertingTerms(Terms) - Constructor for class org.apache.lucene.index.AssertingLeafReader.AssertingTerms
-
- AssertingTermVectorsFormat - Class in org.apache.lucene.codecs.asserting
-
Just like the default vectors format but with additional asserts.
- AssertingTermVectorsFormat() - Constructor for class org.apache.lucene.codecs.asserting.AssertingTermVectorsFormat
-
- assertMerge(MergePolicy, MergePolicy.MergeSpecification) - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Assert that the given merge matches expectations of the merge policy.
- assertMergedSegmentsWarmed - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- assertNext(Spans, int, int, int) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Assert the next iteration from spans
is a match
from start
to end
in doc
.
- assertNoDetachedStates(Automaton) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Checks that an automaton has no detached states that are unreachable
from the initial state.
- assertNormsEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks that norms are the same across all fields
- assertPointsEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
- assertPositionsSkippingEquals(String, IndexReader, int, PostingsEnum, PostingsEnum) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks advancing docs + positions
- assertReaderEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
- assertReaderStatisticsEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks that reader-level statistics are the same
- assertReused(String, PostingsEnum, PostingsEnum) - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- assertSameScores(Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
Assert that two queries return the same documents and with the same scores.
- assertSameScores(Query, Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- assertSameSeekBehavior(String, IndexInput, IndexInput) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- assertSameSet(Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
Asserts that the documents returned by q1
are the same as of those returned by q2
- assertSameStreams(String, IndexInput, IndexInput) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- assertSameStreams(String, IndexInput, IndexInput, long) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- assertsAreEnabled - Static variable in class org.apache.lucene.util.LuceneTestCase
-
True if assertions (-ea) are enabled (at least for this class).
- assertSegmentInfos(MergePolicy, SegmentInfos) - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Assert that the given segment infos match expectations of the merge
policy, assuming segments that have only been either flushed or merged with
this merge policy.
- assertsOn() - Static method in class org.apache.lucene.index.CheckIndex
-
Check whether asserts are enabled or not.
- assertStoredFieldEquals(String, IndexableField, IndexableField) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks that two stored fields are equivalent
- assertStoredFieldsEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks that stored fields of all documents are the same
- assertStreamHasNumberOfTokens(TokenStream, int) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Asserts that the given stream has expected number of tokens.
- assertSubsetOf(Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
Asserts that the documents returned by q1
are a subset of those returned by q2
- assertSubsetOf(Query, Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
Asserts that the documents returned by q1
are a subset of those returned by q2
.
- assertTermsEnumEquals(String, IndexReader, TermsEnum, TermsEnum, boolean) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks the terms enum sequentially
if deep is false, it does a 'shallow' test that doesnt go down to the docsenums
- assertTermsEquals(String, IndexReader, Terms, Terms, boolean) - Method in class org.apache.lucene.util.LuceneTestCase
-
Terms api equivalency
- assertTermsStatisticsEquals(String, Terms, Terms) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks collection-level statistics on Terms
- assertTermStatsEquals(String, TermsEnum, TermsEnum) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks term-level statistics
- assertTermVectorsEquals(String, IndexReader, IndexReader) - Method in class org.apache.lucene.util.LuceneTestCase
-
checks that term vectors across all fields are equivalent
- assertThreadSafe(Analyzer) - Method in class org.apache.lucene.analysis.CollationTestBase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], int[], Integer, Integer, boolean[], boolean, byte[][]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], int[], Integer, boolean[], boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], int[], Integer, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], String[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], int[]) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertTokenStreamContents(TokenStream, String[], int[], int[], int[], int[], Integer) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- assertVocabulary(Analyzer, InputStream, InputStream) - Static method in class org.apache.lucene.analysis.VocabularyAssert
-
Run a vocabulary test against two data files.
- assertVocabulary(Analyzer, InputStream) - Static method in class org.apache.lucene.analysis.VocabularyAssert
-
Run a vocabulary test against one file: tab separated.
- assertVocabulary(Analyzer, Path, String, String) - Static method in class org.apache.lucene.analysis.VocabularyAssert
-
Run a vocabulary test against two data files inside a zip file
- assertVocabulary(Analyzer, Path, String) - Static method in class org.apache.lucene.analysis.VocabularyAssert
-
Run a vocabulary test against a tab-separated data file inside a zip file
- asSet(T...) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Return args
as a Set
instance.
- assign_to(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
-
- assignClass(String) - Method in class org.apache.lucene.classification.BM25NBClassifier
-
- assignClass(String) - Method in class org.apache.lucene.classification.BooleanPerceptronClassifier
-
- assignClass(String) - Method in interface org.apache.lucene.classification.Classifier
-
Assign a class (with score) to the given text String
- assignClass(Document) - Method in interface org.apache.lucene.classification.document.DocumentClassifier
-
Assign a class (with score) to the given
Document
- assignClass(Document) - Method in class org.apache.lucene.classification.document.KNearestNeighborDocumentClassifier
-
- assignClass(Document) - Method in class org.apache.lucene.classification.document.SimpleNaiveBayesDocumentClassifier
-
- assignClass(String) - Method in class org.apache.lucene.classification.KNearestFuzzyClassifier
-
- assignClass(String) - Method in class org.apache.lucene.classification.KNearestNeighborClassifier
-
- assignClass(String) - Method in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
- assignClassNormalizedList(String) - Method in class org.apache.lucene.classification.CachingNaiveBayesClassifier
-
- assignClassNormalizedList(String) - Method in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
Calculate probabilities for all classes for a given input text
- assoc - Variable in class org.apache.lucene.facet.taxonomy.AssociationFacetField
-
Associated value.
- AssociationFacetField - Class in org.apache.lucene.facet.taxonomy
-
Add an instance of this to your
Document
to add
a facet label associated with an arbitrary byte[].
- AssociationFacetField(BytesRef, String, String...) - Constructor for class org.apache.lucene.facet.taxonomy.AssociationFacetField
-
Creates this from dim
and path
and an
association
- AssociationsFacetsExample - Class in org.apache.lucene.demo.facet
-
Shows example usage of category associations.
- AssociationsFacetsExample() - Constructor for class org.apache.lucene.demo.facet.AssociationsFacetsExample
-
Empty constructor
- assumeFalse(String, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- assumeNoException(String, Exception) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- assumeTrue(String, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- assumeWorkingMMapOnWindows() - Static method in class org.apache.lucene.util.LuceneTestCase
-
Assumes that the current MMapDirectory implementation supports unmapping, so the test will not fail on Windows.
- asTwoPhaseIterator() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- asTwoPhaseIterator() - Method in class org.apache.lucene.search.spans.Spans
-
- atanh(double) - Static method in class org.apache.lucene.util.MathUtil
-
Calculates inverse hyperbolic tangent of a double
value.
- atLeast(SpanWeight.Postings) - Method in enum org.apache.lucene.search.spans.SpanWeight.Postings
-
- atLeast(Random, int) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a number of at least i
- atLeast(int) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- Attribute - Interface in org.apache.lucene.util
-
Base interface for attributes.
- attributeFactory(String) - Method in class org.apache.lucene.analysis.Analyzer
-
- attributeFactory(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
- attributeFactory(String) - Method in class org.apache.lucene.analysis.MockBytesAnalyzer
-
- attributeFactory(String) - Method in class org.apache.lucene.collation.CollationKeyAnalyzer
-
- AttributeFactory - Class in org.apache.lucene.util
-
- AttributeFactory() - Constructor for class org.apache.lucene.util.AttributeFactory
-
- AttributeFactory.StaticImplementationAttributeFactory<A extends AttributeImpl> - Class in org.apache.lucene.util
-
Expert: AttributeFactory returning an instance of the given clazz
for the
attributes it implements.
- AttributeImpl - Class in org.apache.lucene.util
-
- AttributeImpl() - Constructor for class org.apache.lucene.util.AttributeImpl
-
- AttributeReflector - Interface in org.apache.lucene.util
-
- attributes() - Method in class org.apache.lucene.index.FieldInfo
-
Returns internal codec attributes map.
- attributes() - Method in class org.apache.lucene.index.FilteredTermsEnum
-
Returns the related attributes, the returned
AttributeSource
is shared with the delegate
TermsEnum
.
- attributes() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- attributes() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- attributes() - Method in class org.apache.lucene.index.PostingsEnum
-
- attributes() - Method in class org.apache.lucene.index.TermsEnum
-
Returns the related attributes.
- AttributeSource - Class in org.apache.lucene.util
-
An AttributeSource contains a list of different
AttributeImpl
s,
and methods to add and get them.
- AttributeSource() - Constructor for class org.apache.lucene.util.AttributeSource
-
- AttributeSource(AttributeSource) - Constructor for class org.apache.lucene.util.AttributeSource
-
An AttributeSource that uses the same attributes as the supplied one.
- AttributeSource(AttributeFactory) - Constructor for class org.apache.lucene.util.AttributeSource
-
- AttributeSource.State - Class in org.apache.lucene.util
-
This class holds the state of an AttributeSource.
- AUTO_DETECT_MERGES_AND_THREADS - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Dynamic default for maxThreadCount
and maxMergeCount
,
used to detect whether the index is backed by an SSD or rotational disk and
set maxThreadCount
accordingly.
- autoGenerateMultiTermSynonymsPhraseQuery - Variable in class org.apache.lucene.util.QueryBuilder
-
- automata() - Method in interface org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttribute
-
- automata() - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-
- Automata - Class in org.apache.lucene.util.automaton
-
Construction of basic automata.
- automatic() - Static method in class org.apache.lucene.util.OfflineSorter.BufferSize
-
- automaton - Variable in class org.apache.lucene.search.AutomatonQuery
-
the automaton to match index terms against
- Automaton - Class in org.apache.lucene.util.automaton
-
Represents an automaton and all its states and transitions.
- Automaton() - Constructor for class org.apache.lucene.util.automaton.Automaton
-
Sole constructor; creates an automaton with no states.
- Automaton(int, int) - Constructor for class org.apache.lucene.util.automaton.Automaton
-
Constructor which creates an automaton with enough space for the given
number of states and transitions.
- automaton - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-
Two dimensional array of transitions, indexed by state
number for traversal.
- AUTOMATON - Static variable in class org.apache.lucene.util.automaton.RegExp
-
Syntax flag, enables named automata (<identifier>).
- Automaton.Builder - Class in org.apache.lucene.util.automaton
-
- automatonIsBinary - Variable in class org.apache.lucene.search.AutomatonQuery
-
- AutomatonProvider - Interface in org.apache.lucene.util.automaton
-
- AutomatonQuery - Class in org.apache.lucene.search
-
A
Query
that will match terms against a finite-state machine.
- AutomatonQuery(Term, Automaton) - Constructor for class org.apache.lucene.search.AutomatonQuery
-
Create a new AutomatonQuery from an
Automaton
.
- AutomatonQuery(Term, Automaton, int) - Constructor for class org.apache.lucene.search.AutomatonQuery
-
Create a new AutomatonQuery from an
Automaton
.
- AutomatonQuery(Term, Automaton, int, boolean) - Constructor for class org.apache.lucene.search.AutomatonQuery
-
Create a new AutomatonQuery from an
Automaton
.
- AutomatonTermsEnum - Class in org.apache.lucene.index
-
A FilteredTermsEnum that enumerates terms based upon what is accepted by a
DFA.
- AutomatonTermsEnum(TermsEnum, CompiledAutomaton) - Constructor for class org.apache.lucene.index.AutomatonTermsEnum
-
Construct an enumerator based upon an automaton, enumerating the specified
field, working on a supplied TermsEnum
- AutomatonTestUtil - Class in org.apache.lucene.util.automaton
-
Utilities for testing automata.
- AutomatonTestUtil() - Constructor for class org.apache.lucene.util.automaton.AutomatonTestUtil
-
- AutomatonTestUtil.RandomAcceptedStrings - Class in org.apache.lucene.util.automaton
-
Lets you retrieve random strings accepted
by an Automaton.
- available() - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- available() - Method in class org.apache.lucene.replicator.IndexInputInputStream
-
- availableCharFilters() - Static method in class org.apache.lucene.analysis.util.CharFilterFactory
-
returns a list of all available charfilter names
- availableCodecs() - Static method in class org.apache.lucene.codecs.Codec
-
returns a list of all available codec names
- availableDocValuesFormats() - Static method in class org.apache.lucene.codecs.DocValuesFormat
-
returns a list of all available format names
- availablePostingsFormats() - Static method in class org.apache.lucene.codecs.PostingsFormat
-
returns a list of all available format names
- availableServices() - Method in class org.apache.lucene.analysis.util.AnalysisSPILoader
-
- availableServices() - Method in class org.apache.lucene.util.NamedSPILoader
-
- availableTokenFilters() - Static method in class org.apache.lucene.analysis.util.TokenFilterFactory
-
returns a list of all available tokenfilter names from context classpath
- availableTokenizers() - Static method in class org.apache.lucene.analysis.util.TokenizerFactory
-
returns a list of all available tokenizer names from context classpath
- average(QualityStats[]) - Static method in class org.apache.lucene.benchmark.quality.QualityStats
-
Create a QualityStats object that is the average of the input QualityStats objects.
- AveragePayloadFunction - Class in org.apache.lucene.queries.payloads
-
Calculate the final score as the average score of all payloads seen.
- AveragePayloadFunction() - Constructor for class org.apache.lucene.queries.payloads.AveragePayloadFunction
-
- avgFieldLength - Variable in class org.apache.lucene.search.similarities.BasicStats
-
The average field length.
- avgFieldLength(CollectionStatistics) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
The default implementation computes the average as sumTotalTermFreq / docCount
- AVOID_BAD_URL - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
- avoidCodecs - Variable in class org.apache.lucene.index.RandomCodec
-
- awaitTermination(long, TimeUnit) - Method in class org.apache.lucene.util.SameThreadExecutorService
-
- Axiomatic - Class in org.apache.lucene.search.similarities
-
Axiomatic approaches for IR.
- Axiomatic(float, int, float) - Constructor for class org.apache.lucene.search.similarities.Axiomatic
-
Constructor setting all Axiomatic hyperparameters
- Axiomatic(float) - Constructor for class org.apache.lucene.search.similarities.Axiomatic
-
Constructor setting only s, letting k and queryLen to default
- Axiomatic(float, int) - Constructor for class org.apache.lucene.search.similarities.Axiomatic
-
Constructor setting s and queryLen, letting k to default
- Axiomatic() - Constructor for class org.apache.lucene.search.similarities.Axiomatic
-
Default constructor
- AxiomaticF1EXP - Class in org.apache.lucene.search.similarities
-
F1EXP is defined as Sum(tf(term_doc_freq)*ln(docLen)*IDF(term))
where IDF(t) = pow((N+1)/df(t), k) N=total num of docs, df=doc freq
- AxiomaticF1EXP(float, float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
Constructor setting s and k, letting queryLen to default
- AxiomaticF1EXP(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
Constructor setting s only, letting k and queryLen to default
- AxiomaticF1EXP() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
Default constructor
- AxiomaticF1LOG - Class in org.apache.lucene.search.similarities
-
F1LOG is defined as Sum(tf(term_doc_freq)*ln(docLen)*IDF(term))
where IDF(t) = ln((N+1)/df(t)) N=total num of docs, df=doc freq
- AxiomaticF1LOG(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
Constructor setting s only, letting k and queryLen to default
- AxiomaticF1LOG() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
Default constructor
- AxiomaticF2EXP - Class in org.apache.lucene.search.similarities
-
F2EXP is defined as Sum(tfln(term_doc_freq, docLen)*IDF(term))
where IDF(t) = pow((N+1)/df(t), k) N=total num of docs, df=doc freq
- AxiomaticF2EXP(float, float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
Constructor setting s and k, letting queryLen to default
- AxiomaticF2EXP(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
Constructor setting s only, letting k and queryLen to default
- AxiomaticF2EXP() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
Default constructor
- AxiomaticF2LOG - Class in org.apache.lucene.search.similarities
-
F2EXP is defined as Sum(tfln(term_doc_freq, docLen)*IDF(term))
where IDF(t) = ln((N+1)/df(t)) N=total num of docs, df=doc freq
- AxiomaticF2LOG(float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
Constructor setting s only, letting k and queryLen to default
- AxiomaticF2LOG() - Constructor for class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
Default constructor
- AxiomaticF3EXP - Class in org.apache.lucene.search.similarities
-
F2EXP is defined as Sum(tf(term_doc_freq)*IDF(term)-gamma(docLen, queryLen))
where IDF(t) = pow((N+1)/df(t), k) N=total num of docs, df=doc freq
gamma(docLen, queryLen) = (docLen-queryLen)*queryLen*s/avdl
- AxiomaticF3EXP(float, int, float) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
Constructor setting all Axiomatic hyperparameters
- AxiomaticF3EXP(float, int) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
Constructor setting s and queryLen, letting k to default
- AxiomaticF3LOG - Class in org.apache.lucene.search.similarities
-
F2EXP is defined as Sum(tf(term_doc_freq)*IDF(term)-gamma(docLen, queryLen))
where IDF(t) = ln((N+1)/df(t)) N=total num of docs, df=doc freq
gamma(docLen, queryLen) = (docLen-queryLen)*queryLen*s/avdl
- AxiomaticF3LOG(float, int) - Constructor for class org.apache.lucene.search.similarities.AxiomaticF3LOG
-
Constructor setting s and queryLen, letting k to default
- axisLat(double, double) - Static method in class org.apache.lucene.geo.Rectangle
-
Calculate the latitude of a circle's intersections with its bbox meridians.
- AXISLAT_ERROR - Static variable in class org.apache.lucene.geo.Rectangle
-
- b - Variable in class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- b - Variable in class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
- b_len - Variable in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- b_off - Variable in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- backup(int) - Method in interface org.apache.lucene.queryparser.classic.CharStream
-
Backs up the input stream by amount steps.
- backup(int) - Method in class org.apache.lucene.queryparser.classic.FastCharStream
-
- backup(int) - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.CharStream
-
Backs up the input stream by amount steps.
- backup(int) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.FastCharStream
-
- backup(int) - Method in interface org.apache.lucene.queryparser.surround.parser.CharStream
-
Backs up the input stream by amount steps.
- backup(int) - Method in class org.apache.lucene.queryparser.surround.parser.FastCharStream
-
- balance() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Balance the tree for best search performance
- balancedTree(Object[], Object[], int, int, TernaryTreeNode) - Method in class org.apache.lucene.search.suggest.tst.TSTAutocomplete
-
Inserting keys in TST in the order middle,small,big (lexicographic measure)
recursively creates a balanced tree which reduces insertion and search
times significantly.
- BAREOPER - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- BaseBitSetTestCase<T extends BitSet> - Class in org.apache.lucene.util
-
Base test case for BitSets.
- BaseBitSetTestCase() - Constructor for class org.apache.lucene.util.BaseBitSetTestCase
-
- BaseCharFilter - Class in org.apache.lucene.analysis.charfilter
-
- BaseCharFilter(Reader) - Constructor for class org.apache.lucene.analysis.charfilter.BaseCharFilter
-
- BaseCompositeReader<R extends IndexReader> - Class in org.apache.lucene.index
-
Base class for implementing
CompositeReader
s based on an array
of sub-readers.
- BaseCompositeReader(R[]) - Constructor for class org.apache.lucene.index.BaseCompositeReader
-
Constructs a BaseCompositeReader
on the given subReaders.
- BaseCompoundFormatTestCase - Class in org.apache.lucene.index
-
Abstract class to do basic tests for a compound format.
- BaseCompoundFormatTestCase() - Constructor for class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- BaseCompressingDocValuesFormatTestCase - Class in org.apache.lucene.index
-
- BaseCompressingDocValuesFormatTestCase() - Constructor for class org.apache.lucene.index.BaseCompressingDocValuesFormatTestCase
-
- BaseDirectory - Class in org.apache.lucene.store
-
- BaseDirectory(LockFactory) - Constructor for class org.apache.lucene.store.BaseDirectory
-
Sole constructor.
- BaseDirectoryTestCase - Class in org.apache.lucene.store
-
Base class for per-Directory tests.
- BaseDirectoryTestCase() - Constructor for class org.apache.lucene.store.BaseDirectoryTestCase
-
- BaseDirectoryWrapper - Class in org.apache.lucene.store
-
Calls check index on close.
- BaseDirectoryWrapper(Directory) - Constructor for class org.apache.lucene.store.BaseDirectoryWrapper
-
- BaseDocIdSetTestCase<T extends DocIdSet> - Class in org.apache.lucene.util
-
- BaseDocIdSetTestCase() - Constructor for class org.apache.lucene.util.BaseDocIdSetTestCase
-
- BaseDocValuesFormatTestCase - Class in org.apache.lucene.index
-
Abstract class to do basic tests for a docvalues format.
- BaseDocValuesFormatTestCase() - Constructor for class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- BaseExplanationTestCase - Class in org.apache.lucene.search
-
Tests primitive queries (ie: that rewrite to themselves) to
insure they match the expected set of docs, and that the score of each
match is equal to the value of the scores explanation.
- BaseExplanationTestCase() - Constructor for class org.apache.lucene.search.BaseExplanationTestCase
-
- BaseFieldInfoFormatTestCase - Class in org.apache.lucene.index
-
Abstract class to do basic tests for fis format.
- BaseFieldInfoFormatTestCase() - Constructor for class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
- BaseFormAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
-
- BaseFormAttributeImpl - Class in org.apache.lucene.analysis.ja.tokenattributes
-
- BaseFormAttributeImpl() - Constructor for class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
-
- BaseFragListBuilder - Class in org.apache.lucene.search.vectorhighlight
-
- BaseFragListBuilder(int) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragListBuilder
-
- BaseFragListBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragListBuilder
-
- BaseFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
-
Base FragmentsBuilder implementation that supports colored pre/post
tags and multivalued fields.
- BaseFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- BaseFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- BaseFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- BaseFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- BaseGeoPointTestCase - Class in org.apache.lucene.geo
-
Abstract class to do basic tests for a geospatial impl (high level
fields and queries)
NOTE: This test focuses on geospatial (distance queries, polygon
queries, etc) indexing and search, not any underlying storage
format or encoding: it merely supplies two hooks for the encoding
so that tests can be exact.
- BaseGeoPointTestCase() - Constructor for class org.apache.lucene.geo.BaseGeoPointTestCase
-
- baselineTf(float) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Implemented as:
(x <= min) ? base : sqrt(x+(base**2)-min)
...but with a special case check for 0.
- BaseLiveDocsFormatTestCase - Class in org.apache.lucene.index
-
Abstract class that performs basic testing of a codec's
LiveDocsFormat
.
- BaseLiveDocsFormatTestCase() - Constructor for class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
- BaseLockFactoryTestCase - Class in org.apache.lucene.store
-
Base class for per-LockFactory tests.
- BaseLockFactoryTestCase() - Constructor for class org.apache.lucene.store.BaseLockFactoryTestCase
-
- BaseMergePolicyTestCase - Class in org.apache.lucene.index
-
- BaseMergePolicyTestCase() - Constructor for class org.apache.lucene.index.BaseMergePolicyTestCase
-
- BaseMergePolicyTestCase.IOStats - Class in org.apache.lucene.index
-
Statistics about bytes written to storage.
- BaseMergePolicyTestCase.MockMergeContext - Class in org.apache.lucene.index
-
Simple mock merge context for tests
- BaseNormsFormatTestCase - Class in org.apache.lucene.index
-
Abstract class to do basic tests for a norms format.
- BaseNormsFormatTestCase() - Constructor for class org.apache.lucene.index.BaseNormsFormatTestCase
-
- BasePlanetObject - Class in org.apache.lucene.spatial3d.geom
-
All Geo3D shapes can derive from this base class, which furnishes
some common code
- BasePlanetObject(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.BasePlanetObject
-
Constructor creating class instance given a planet model.
- BasePointsFormatTestCase - Class in org.apache.lucene.index
-
Abstract class to do basic tests for a points format.
- BasePointsFormatTestCase() - Constructor for class org.apache.lucene.index.BasePointsFormatTestCase
-
- BasePostingsFormatTestCase - Class in org.apache.lucene.index
-
Abstract class to do basic tests for a postings format.
- BasePostingsFormatTestCase() - Constructor for class org.apache.lucene.index.BasePostingsFormatTestCase
-
- baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
-
- baseRamBytesUsed() - Method in class org.apache.lucene.util.packed.PagedMutable
-
- BaseRangeFieldQueryTestCase - Class in org.apache.lucene.search
-
Abstract class to do basic tests for a RangeField query.
- BaseRangeFieldQueryTestCase() - Constructor for class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- BaseRangeFieldQueryTestCase.Range - Class in org.apache.lucene.search
-
base class for range verification
- BaseRangeFieldQueryTestCase.Range.QueryType - Enum in org.apache.lucene.search
-
supported query relations
- BaseSegmentInfoFormatTestCase - Class in org.apache.lucene.index
-
Abstract class to do basic tests for si format.
- BaseSegmentInfoFormatTestCase() - Constructor for class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
- BaseStoredFieldsFormatTestCase - Class in org.apache.lucene.index
-
- BaseStoredFieldsFormatTestCase() - Constructor for class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- BaseTermsEnumTraverser(LeafReaderContext) - Constructor for class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- BaseTermVectorsFormatTestCase - Class in org.apache.lucene.index
-
- BaseTermVectorsFormatTestCase() - Constructor for class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- BaseTermVectorsFormatTestCase.Options - Enum in org.apache.lucene.index
-
A combination of term vectors options.
- BaseTermVectorsFormatTestCase.RandomDocument - Class in org.apache.lucene.index
-
- BaseTermVectorsFormatTestCase.RandomDocumentFactory - Class in org.apache.lucene.index
-
- BaseTermVectorsFormatTestCase.RandomTokenStream - Class in org.apache.lucene.index
-
Produces a random TokenStream based off of provided terms.
- BaseTestCheckIndex - Class in org.apache.lucene.index
-
Base class for CheckIndex tests.
- BaseTestCheckIndex() - Constructor for class org.apache.lucene.index.BaseTestCheckIndex
-
- BaseTokenStreamTestCase - Class in org.apache.lucene.analysis
-
Base class for all Lucene unit tests that use TokenStreams.
- BaseTokenStreamTestCase() - Constructor for class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- BaseTokenStreamTestCase.CheckClearAttributesAttribute - Interface in org.apache.lucene.analysis
-
Attribute that records if it was cleared or not.
- BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl - Class in org.apache.lucene.analysis
-
Attribute that records if it was cleared or not.
- BasicModel - Class in org.apache.lucene.search.similarities
-
This class acts as the base class for the specific basic model
implementations in the DFR framework.
- BasicModel() - Constructor for class org.apache.lucene.search.similarities.BasicModel
-
Sole constructor.
- basicModel - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
-
The basic model for information content.
- BasicModelBE - Class in org.apache.lucene.search.similarities
-
Limiting form of the Bose-Einstein model.
- BasicModelBE() - Constructor for class org.apache.lucene.search.similarities.BasicModelBE
-
Sole constructor: parameter-free
- BasicModelD - Class in org.apache.lucene.search.similarities
-
Implements the approximation of the binomial model with the divergence
for DFR.
- BasicModelD() - Constructor for class org.apache.lucene.search.similarities.BasicModelD
-
Sole constructor: parameter-free
- BasicModelG - Class in org.apache.lucene.search.similarities
-
Geometric as limiting form of the Bose-Einstein model.
- BasicModelG() - Constructor for class org.apache.lucene.search.similarities.BasicModelG
-
Sole constructor: parameter-free
- BasicModelIF - Class in org.apache.lucene.search.similarities
-
An approximation of the I(ne) model.
- BasicModelIF() - Constructor for class org.apache.lucene.search.similarities.BasicModelIF
-
Sole constructor: parameter-free
- BasicModelIn - Class in org.apache.lucene.search.similarities
-
The basic tf-idf model of randomness.
- BasicModelIn() - Constructor for class org.apache.lucene.search.similarities.BasicModelIn
-
Sole constructor: parameter-free
- BasicModelIne - Class in org.apache.lucene.search.similarities
-
Tf-idf model of randomness, based on a mixture of Poisson and inverse
document frequency.
- BasicModelIne() - Constructor for class org.apache.lucene.search.similarities.BasicModelIne
-
Sole constructor: parameter-free
- BasicModelP - Class in org.apache.lucene.search.similarities
-
Implements the Poisson approximation for the binomial model for DFR.
- BasicModelP() - Constructor for class org.apache.lucene.search.similarities.BasicModelP
-
Sole constructor: parameter-free
- BasicQueryFactory - Class in org.apache.lucene.queryparser.surround.query
-
Factory for creating basic term queries
- BasicQueryFactory(int) - Constructor for class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- BasicQueryFactory() - Constructor for class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- BasicStats - Class in org.apache.lucene.search.similarities
-
Stores all statistics commonly used ranking methods.
- BasicStats(String, float) - Constructor for class org.apache.lucene.search.similarities.BasicStats
-
Constructor.
- BasqueAnalyzer - Class in org.apache.lucene.analysis.eu
-
- BasqueAnalyzer() - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
- BasqueAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
Builds an analyzer with the given stop words.
- BasqueAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
Builds an analyzer with the given stop words.
- BasqueStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- BasqueStemmer() - Constructor for class org.tartarus.snowball.ext.BasqueStemmer
-
- BBoxIntersects - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
- BBoxOverlapRatioValueSource - Class in org.apache.lucene.spatial.bbox
-
The algorithm is implemented as envelope on envelope (rect on rect) overlays rather than
complex polygon on complex polygon overlays.
- BBoxOverlapRatioValueSource(ShapeValuesSource, boolean, Rectangle, double, double) - Constructor for class org.apache.lucene.spatial.bbox.BBoxOverlapRatioValueSource
-
- BBoxOverlapRatioValueSource(ShapeValuesSource, Rectangle) - Constructor for class org.apache.lucene.spatial.bbox.BBoxOverlapRatioValueSource
-
Construct with 75% weighting towards target (roughly GeoPortal's default), geo degrees assumed, no
minimum side length.
- BBoxSimilarityValueSource - Class in org.apache.lucene.spatial.bbox
-
A base class for calculating a spatial relevance rank per document from a provided
ShapeValuesSource
returning a
Rectangle
per-document.
- BBoxSimilarityValueSource(ShapeValuesSource) - Constructor for class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
- BBoxStrategy - Class in org.apache.lucene.spatial.bbox
-
A SpatialStrategy for indexing and searching Rectangles by storing its
coordinates in numeric fields.
- BBoxStrategy(SpatialContext, String, FieldType) - Constructor for class org.apache.lucene.spatial.bbox.BBoxStrategy
-
Creates this strategy.
- BBoxWithin - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
- before() - Method in class org.apache.lucene.util.TestRuleLimitSysouts
-
- before() - Method in class org.apache.lucene.util.TestRuleRestoreSystemProperties
-
- beforeClass() - Static method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- beforeClassTestExplanations() - Static method in class org.apache.lucene.search.BaseExplanationTestCase
-
- beforeRefresh() - Method in class org.apache.lucene.search.LiveFieldValues
-
- beforeRefresh() - Method in interface org.apache.lucene.search.ReferenceManager.RefreshListener
-
Called right before a refresh attempt starts.
- begin - Variable in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
The term's begin position.
- beginColumn - Variable in class org.apache.lucene.queryparser.classic.Token
-
The column number of the first character of this Token.
- beginColumn - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
The column number of the first character of this Token.
- beginColumn - Variable in class org.apache.lucene.queryparser.surround.parser.Token
-
The column number of the first character of this Token.
- beginLine - Variable in class org.apache.lucene.queryparser.classic.Token
-
The line number of the first character of this Token.
- beginLine - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
The line number of the first character of this Token.
- beginLine - Variable in class org.apache.lucene.queryparser.surround.parser.Token
-
The line number of the first character of this Token.
- BeginToken() - Method in interface org.apache.lucene.queryparser.classic.CharStream
-
Returns the next character that marks the beginning of the next token.
- BeginToken() - Method in class org.apache.lucene.queryparser.classic.FastCharStream
-
- BeginToken() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.CharStream
-
Returns the next character that marks the beginning of the next token.
- BeginToken() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.FastCharStream
-
- BeginToken() - Method in interface org.apache.lucene.queryparser.surround.parser.CharStream
-
Returns the next character that marks the beginning of the next token.
- BeginToken() - Method in class org.apache.lucene.queryparser.surround.parser.FastCharStream
-
- BEH - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- BeiderMorseFilter - Class in org.apache.lucene.analysis.phonetic
-
TokenFilter for Beider-Morse phonetic encoding.
- BeiderMorseFilter(TokenStream, PhoneticEngine) - Constructor for class org.apache.lucene.analysis.phonetic.BeiderMorseFilter
-
- BeiderMorseFilter(TokenStream, PhoneticEngine, Languages.LanguageSet) - Constructor for class org.apache.lucene.analysis.phonetic.BeiderMorseFilter
-
Create a new BeiderMorseFilter
- BeiderMorseFilterFactory - Class in org.apache.lucene.analysis.phonetic
-
- BeiderMorseFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.phonetic.BeiderMorseFilterFactory
-
Creates a new BeiderMorseFilterFactory
- Benchmark - Class in org.apache.lucene.benchmark.byTask
-
Run the benchmark algorithm.
- Benchmark(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.Benchmark
-
- BengaliAnalyzer - Class in org.apache.lucene.analysis.bn
-
Analyzer for Bengali.
- BengaliAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.bn.BengaliAnalyzer
-
Builds an analyzer with the given stop words
- BengaliAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.bn.BengaliAnalyzer
-
Builds an analyzer with the given stop words
- BengaliAnalyzer() - Constructor for class org.apache.lucene.analysis.bn.BengaliAnalyzer
-
- BengaliNormalizationFilter - Class in org.apache.lucene.analysis.bn
-
- BengaliNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.bn.BengaliNormalizationFilter
-
- BengaliNormalizationFilterFactory - Class in org.apache.lucene.analysis.bn
-
- BengaliNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.bn.BengaliNormalizationFilterFactory
-
- BengaliNormalizer - Class in org.apache.lucene.analysis.bn
-
Normalizer for Bengali.
- BengaliNormalizer() - Constructor for class org.apache.lucene.analysis.bn.BengaliNormalizer
-
- BengaliStemFilter - Class in org.apache.lucene.analysis.bn
-
- BengaliStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.bn.BengaliStemFilter
-
- BengaliStemFilterFactory - Class in org.apache.lucene.analysis.bn
-
- BengaliStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.bn.BengaliStemFilterFactory
-
- BengaliStemmer - Class in org.apache.lucene.analysis.bn
-
Stemmer for Bengali.
- BengaliStemmer() - Constructor for class org.apache.lucene.analysis.bn.BengaliStemmer
-
- BIG_TERM - Static variable in class org.apache.lucene.util.UnicodeUtil
-
A binary term consisting of a number of 0xff bytes, likely to be bigger than other terms
(e.g.
- BigIntegerPoint - Class in org.apache.lucene.document
-
An indexed 128-bit BigInteger
field.
- BigIntegerPoint(String, BigInteger...) - Constructor for class org.apache.lucene.document.BigIntegerPoint
-
Creates a new BigIntegerPoint, indexing the
provided N-dimensional big integer point.
- bigIntToSortableBytes(BigInteger, int, byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
-
Encodes a BigInteger value
such that unsigned byte order comparison
is consistent with BigInteger.compareTo(BigInteger)
.
- BinaryDictionary - Class in org.apache.lucene.analysis.ja.dict
-
Base class for a binary-encoded in-memory dictionary.
- BinaryDictionary() - Constructor for class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- BinaryDictionary - Class in org.apache.lucene.analysis.ko.dict
-
Base class for a binary-encoded in-memory dictionary.
- BinaryDictionary() - Constructor for class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- BinaryDocValues - Class in org.apache.lucene.index
-
A per-document numeric value.
- BinaryDocValues() - Constructor for class org.apache.lucene.index.BinaryDocValues
-
Sole constructor.
- BinaryDocValuesField - Class in org.apache.lucene.document
-
Field that stores a per-document
BytesRef
value.
- BinaryDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.BinaryDocValuesField
-
Create a new binary DocValues field.
- binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
- binaryField(FieldInfo, byte[]) - Method in class org.apache.lucene.index.StoredFieldVisitor
-
Process a binary field.
- binaryIterable(FieldInfo, DocValuesProducer, int) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- BinaryPoint - Class in org.apache.lucene.document
-
An indexed binary field for fast range filters.
- BinaryPoint(String, byte[]...) - Constructor for class org.apache.lucene.document.BinaryPoint
-
General purpose API: creates a new BinaryPoint, indexing the
provided N-dimensional binary point.
- BinaryPoint(String, byte[], IndexableFieldType) - Constructor for class org.apache.lucene.document.BinaryPoint
-
Expert API
- BinaryToken(BytesRef) - Constructor for class org.apache.lucene.analysis.CannedBinaryTokenStream.BinaryToken
-
- BinaryToken(BytesRef, int, int) - Constructor for class org.apache.lucene.analysis.CannedBinaryTokenStream.BinaryToken
-
- binaryValue() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- binaryValue() - Method in class org.apache.lucene.document.Field
-
- binaryValue() - Method in class org.apache.lucene.document.LazyDocument.LazyField
-
- binaryValue() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- binaryValue() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- binaryValue() - Method in class org.apache.lucene.index.BinaryDocValues
-
Returns the binary value for the current document ID.
- binaryValue() - Method in class org.apache.lucene.index.FilterBinaryDocValues
-
- binaryValue() - Method in interface org.apache.lucene.index.IndexableField
-
Non-null if this field has a binary value
- binaryValue() - Method in class org.apache.lucene.index.LegacyBinaryDocValuesWrapper
-
Deprecated.
- binaryValue() - Method in class org.apache.lucene.index.SortedDocValues
-
- Bindings - Class in org.apache.lucene.expressions
-
Binds variable names in expressions to actual data.
- Bindings() - Constructor for class org.apache.lucene.expressions.Bindings
-
Sole constructor.
- bisection(GeoPoint, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Compute a GeoPoint that's a bisection between two other GeoPoints.
- BIT_ARC_HAS_OUTPUT - Static variable in class org.apache.lucene.util.fst.FST
-
This flag is set if the arc has an output.
- BitDocIdSet - Class in org.apache.lucene.util
-
- BitDocIdSet(BitSet, long) - Constructor for class org.apache.lucene.util.BitDocIdSet
-
- BitDocIdSet(BitSet) - Constructor for class org.apache.lucene.util.BitDocIdSet
-
- bits - Variable in class org.apache.lucene.facet.FacetsCollector.MatchingDocs
-
Which documents were seen.
- BITS - Static variable in class org.apache.lucene.geo.GeoEncodingUtils
-
number of bits used for quantizing latitude and longitude values
- bits() - Method in class org.apache.lucene.search.DocIdSet
-
Optionally provides a
Bits
interface for random access
to matching documents.
- bits() - Method in class org.apache.lucene.util.BitDocIdSet
-
- Bits - Interface in org.apache.lucene.util
-
Interface for Bitset-like structures.
- bits() - Method in class org.apache.lucene.util.NotDocIdSet
-
- Bits.MatchAllBits - Class in org.apache.lucene.util
-
Bits impl of the specified length with all bits set.
- Bits.MatchNoBits - Class in org.apache.lucene.util
-
Bits impl of the specified length with no bits set.
- bits2words(int) - Static method in class org.apache.lucene.util.FixedBitSet
-
returns the number of 64 bit words it would take to hold numBits
- bits2words(long) - Static method in class org.apache.lucene.util.LongBitSet
-
Returns the number of 64 bit words it would take to hold numBits
- BitSet - Class in org.apache.lucene.util
-
Base implementation for a bit set.
- BitSet() - Constructor for class org.apache.lucene.util.BitSet
-
- BitSetIterator - Class in org.apache.lucene.util
-
- BitSetIterator(BitSet, long) - Constructor for class org.apache.lucene.util.BitSetIterator
-
Sole constructor.
- BitSetProducer - Interface in org.apache.lucene.search.join
-
A producer of
BitSet
s per segment.
- bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
-
- bitsPerValue - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
-
- bitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
-
The number of bits per value.
- BitsProducer - Class in org.apache.lucene.search.suggest
-
A producer of
Bits
per segment.
- BitsProducer() - Constructor for class org.apache.lucene.search.suggest.BitsProducer
-
Sole constructor, typically invoked by sub-classes.
- bitsRequired(long) - Static method in class org.apache.lucene.util.packed.DirectWriter
-
Returns how many bits are required to hold values up
to and including maxValue
- bitsRequired(long) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Returns how many bits are required to hold values up
to and including maxValue
NOTE: This method returns at least 1.
- BitUtil - Class in org.apache.lucene.util
-
A variety of high efficiency bit twiddling routines.
- BKDReader - Class in org.apache.lucene.util.bkd
-
Handles intersection of an multi-dimensional shape in byte[] space with a block KD-tree previously written with
BKDWriter
.
- BKDReader(IndexInput) - Constructor for class org.apache.lucene.util.bkd.BKDReader
-
- BKDReader.IndexTree - Class in org.apache.lucene.util.bkd
-
Used to walk the in-heap index
- BKDReader.IntersectState - Class in org.apache.lucene.util.bkd
-
- BKDWriter - Class in org.apache.lucene.util.bkd
-
Recursively builds a block KD-tree to assign all incoming points in N-dim space to smaller
and smaller N-dim rectangles (cells) until the number of points in a given
rectangle is <= maxPointsInLeafNode
.
- BKDWriter(int, Directory, String, int, int, int, int, double, long, boolean) - Constructor for class org.apache.lucene.util.bkd.BKDWriter
-
- BKDWriter(int, Directory, String, int, int, int, int, double, long, boolean, boolean, long, int) - Constructor for class org.apache.lucene.util.bkd.BKDWriter
-
- BlendedInfixSuggester - Class in org.apache.lucene.search.suggest.analyzing
-
Extension of the AnalyzingInfixSuggester which transforms the weight
after search to take into account the position of the searched term into
the indexed text.
- BlendedInfixSuggester(Directory, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
Create a new instance, loading from a previously built
directory, if it exists.
- BlendedInfixSuggester(Directory, Analyzer, Analyzer, int, BlendedInfixSuggester.BlenderType, int, boolean) - Constructor for class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
Create a new instance, loading from a previously built
directory, if it exists.
- BlendedInfixSuggester(Directory, Analyzer, Analyzer, int, BlendedInfixSuggester.BlenderType, int, Double, boolean, boolean, boolean) - Constructor for class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
Create a new instance, loading from a previously built
directory, if it exists.
- BlendedInfixSuggester.BlenderType - Enum in org.apache.lucene.search.suggest.analyzing
-
The different types of blender.
- BlendedTermQuery - Class in org.apache.lucene.search
-
A
Query
that blends index statistics across multiple terms.
- BlendedTermQuery.Builder - Class in org.apache.lucene.search
-
- BlendedTermQuery.DisjunctionMaxRewrite - Class in org.apache.lucene.search
-
- BlendedTermQuery.RewriteMethod - Class in org.apache.lucene.search
-
- BLOCK_SIZE - Static variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.blocktreeords.BlockTreeOrdsPostingsFormat
-
Fixed packed block size, number of integers encoded in
a single packed block.
- BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
Fixed packed block size, number of integers encoded in
a single packed block.
- blockCountByPrefixLen - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Number of blocks at each prefix depth.
- blockFilePointer - Variable in class org.apache.lucene.codecs.BlockTermState
-
fp into the terms dict primary file (_X.tim) that holds this term
- BlockGroupingCollector - Class in org.apache.lucene.search.grouping
-
BlockGroupingCollector performs grouping with a
single pass collector, as long as you are grouping by a
doc block field, ie all documents sharing a given group
value were indexed as a doc block using the atomic
IndexWriter.addDocuments()
or
IndexWriter.updateDocuments()
API.
- BlockGroupingCollector(Sort, int, boolean, Weight) - Constructor for class org.apache.lucene.search.grouping.BlockGroupingCollector
-
Create the single pass collector.
- BlockJoinSelector - Class in org.apache.lucene.search.join
-
Select a value from a block of documents.
- BlockJoinSelector.Type - Enum in org.apache.lucene.search.join
-
Type of selection to perform.
- BlockPackedReader - Class in org.apache.lucene.util.packed
-
- BlockPackedReader(IndexInput, int, int, long, boolean) - Constructor for class org.apache.lucene.util.packed.BlockPackedReader
-
Sole constructor.
- BlockPackedReaderIterator - Class in org.apache.lucene.util.packed
-
- BlockPackedReaderIterator(DataInput, int, int, long) - Constructor for class org.apache.lucene.util.packed.BlockPackedReaderIterator
-
Sole constructor.
- BlockPackedWriter - Class in org.apache.lucene.util.packed
-
A writer for large sequences of longs.
- BlockPackedWriter(DataOutput, int) - Constructor for class org.apache.lucene.util.packed.BlockPackedWriter
-
Sole constructor.
- blocks - Variable in class org.apache.lucene.util.bkd.HeapPointWriter
-
- blockSize - Variable in class org.apache.lucene.util.ByteBlockPool.Allocator
-
- blockSize - Variable in class org.apache.lucene.util.IntBlockPool.Allocator
-
- BlockTermsReader - Class in org.apache.lucene.codecs.blockterms
-
Handles a terms dict, but decouples all details of
doc/freqs/positions reading to an instance of
PostingsReaderBase
.
- BlockTermsReader(TermsIndexReaderBase, PostingsReaderBase, SegmentReadState) - Constructor for class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- BlockTermState - Class in org.apache.lucene.codecs
-
- BlockTermState() - Constructor for class org.apache.lucene.codecs.BlockTermState
-
Sole constructor.
- BlockTermsWriter - Class in org.apache.lucene.codecs.blockterms
-
Writes terms dict, block-encoding (column stride) each
term's metadata for each set of terms between two
index terms.
- BlockTermsWriter(TermsIndexWriterBase, SegmentWriteState, PostingsWriterBase) - Constructor for class org.apache.lucene.codecs.blockterms.BlockTermsWriter
-
- BlockTreeOrdsPostingsFormat - Class in org.apache.lucene.codecs.blocktreeords
-
- BlockTreeOrdsPostingsFormat() - Constructor for class org.apache.lucene.codecs.blocktreeords.BlockTreeOrdsPostingsFormat
-
Creates Lucene41PostingsFormat
with default
settings.
- BlockTreeOrdsPostingsFormat(int, int) - Constructor for class org.apache.lucene.codecs.blocktreeords.BlockTreeOrdsPostingsFormat
-
Creates Lucene41PostingsFormat
with custom
values for minBlockSize
and maxBlockSize
passed to block terms dictionary.
- blockTreeStats - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
-
Holds details of block allocations in the block
tree terms dictionary (this is only set if the
PostingsFormat
for this segment uses block
tree.
- BlockTreeTermsReader - Class in org.apache.lucene.codecs.blocktree
-
A block-based terms index and dictionary that assigns
terms to variable length blocks according to how they
share prefixes.
- BlockTreeTermsReader(PostingsReaderBase, SegmentReadState) - Constructor for class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
Sole constructor.
- BlockTreeTermsWriter - Class in org.apache.lucene.codecs.blocktree
-
Block-based terms index and dictionary writer.
- BlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int) - Constructor for class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
-
Create a new writer.
- BLOOM_CODEC_NAME - Static variable in class org.apache.lucene.codecs.bloom.BloomFilteringPostingsFormat
-
- BloomFilterFactory - Class in org.apache.lucene.codecs.bloom
-
Class used to create index-time
FuzzySet
appropriately configured for
each field.
- BloomFilterFactory() - Constructor for class org.apache.lucene.codecs.bloom.BloomFilterFactory
-
- BloomFilteringPostingsFormat - Class in org.apache.lucene.codecs.bloom
-
A
PostingsFormat
useful for low doc-frequency fields such as primary
keys.
- BloomFilteringPostingsFormat(PostingsFormat, BloomFilterFactory) - Constructor for class org.apache.lucene.codecs.bloom.BloomFilteringPostingsFormat
-
Creates Bloom filters for a selection of fields created in the index.
- BloomFilteringPostingsFormat(PostingsFormat) - Constructor for class org.apache.lucene.codecs.bloom.BloomFilteringPostingsFormat
-
Creates Bloom filters for a selection of fields created in the index.
- BloomFilteringPostingsFormat() - Constructor for class org.apache.lucene.codecs.bloom.BloomFilteringPostingsFormat
-
- BM25NBClassifier - Class in org.apache.lucene.classification
-
A classifier approximating naive bayes classifier by using pure queries on BM25.
- BM25NBClassifier(IndexReader, Analyzer, Query, String, String...) - Constructor for class org.apache.lucene.classification.BM25NBClassifier
-
Creates a new NaiveBayes classifier.
- BM25Similarity - Class in org.apache.lucene.search.similarities
-
BM25 Similarity.
- BM25Similarity(float, float) - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
-
BM25 with the supplied parameter values.
- BM25Similarity() - Constructor for class org.apache.lucene.search.similarities.BM25Similarity
-
BM25 with these default values:
k1 = 1.2
b = 0.75
- body - Variable in class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser.Parser
-
- BODY_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- bodyValType - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- BOKMAAL - Static variable in class org.apache.lucene.analysis.no.NorwegianLightStemmer
-
Constant to remove Bokmål-specific endings
- BOLD - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- BOLD_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- BOLD_ITALICS - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- BOLD_ITALICS_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- BoolDocValues - Class in org.apache.lucene.queries.function.docvalues
-
Abstract
FunctionValues
implementation which supports retrieving boolean values.
- BoolDocValues(ValueSource) - Constructor for class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.BlendedTermQuery
-
- 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.
- BooleanModifierNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
- BooleanModifierNode(QueryNode, ModifierQueryNode.Modifier) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.BooleanModifierNode
-
- BooleanModifiersQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.precedence.processors
-
- BooleanModifiersQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.precedence.processors.BooleanModifiersQueryNodeProcessor
-
- BooleanPerceptronClassifier - Class in org.apache.lucene.classification
-
A perceptron (see
http://en.wikipedia.org/wiki/Perceptron
) based
Boolean
Classifier
.
- BooleanPerceptronClassifier(IndexReader, Analyzer, Query, Integer, Double, String, String) - Constructor for class org.apache.lucene.classification.BooleanPerceptronClassifier
-
- BooleanQuery - Class in org.apache.lucene.search
-
A Query that matches documents matching boolean combinations of other
queries, e.g.
- BooleanQuery.Builder - Class in org.apache.lucene.search
-
A builder for boolean queries.
- BooleanQuery.TooManyClauses - Exception in org.apache.lucene.search
-
- BooleanQuery2ModifierNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- BooleanQuery2ModifierNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- BooleanQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- BooleanQueryBuilder(QueryBuilder) - Constructor for class org.apache.lucene.queryparser.xml.builders.BooleanQueryBuilder
-
- BooleanQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
BooleanQueryNode
represents a list of elements which do not have an
explicit boolean operator defined between them.
- BooleanQueryNode(List<QueryNode>) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.BooleanQueryNode
-
- BooleanQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- BooleanQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.BooleanQueryNodeBuilder
-
- BOOLEANS - Static variable in class org.apache.lucene.benchmark.Constants
-
- BooleanSimilarity - Class in org.apache.lucene.search.similarities
-
Simple similarity that gives terms a score that is equal to their query
boost.
- BooleanSimilarity() - Constructor for class org.apache.lucene.search.similarities.BooleanSimilarity
-
Sole constructor
- BooleanSingleChildOptimizationQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
This processor removes every
BooleanQueryNode
that contains only one
child and returns this child.
- BooleanSingleChildOptimizationQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
-
- BoolFunction - Class in org.apache.lucene.queries.function.valuesource
-
Abstract parent class for those
ValueSource
implementations which
apply boolean logic to their values
- BoolFunction() - Constructor for class org.apache.lucene.queries.function.valuesource.BoolFunction
-
- boolVal(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- boolVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- boolVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- boolVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- boolVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- boolVal(int) - Method in class org.apache.lucene.queries.function.docvalues.StrDocValues
-
- boolVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- boost - Variable in class org.apache.lucene.queries.function.FunctionQuery.FunctionWeight
-
- Boost - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
Lexical state.
- BOOST - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the boost value in
FieldConfig
objects.
- Boost - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
Lexical state.
- Boost - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
Lexical state.
- boost - Variable in class org.apache.lucene.search.similarities.BasicStats
-
A query boost.
- boost - Variable in class org.apache.lucene.search.spell.DirectSpellChecker.ScoreTerm
-
The boost representing the similarity from the FuzzyTermsEnum (internal similarity score)
- boost() - Method in class org.apache.lucene.search.suggest.document.CompletionWeight
-
- boost - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-
- BoostAttribute - Interface in org.apache.lucene.search
-
- BoostAttributeImpl - Class in org.apache.lucene.search
-
- BoostAttributeImpl() - Constructor for class org.apache.lucene.search.BoostAttributeImpl
-
- boostByQuery(Query, Query, float) - Static method in class org.apache.lucene.queries.function.FunctionScoreQuery
-
Returns a FunctionScoreQuery where the scores of a wrapped query are multiplied by
a boost factor if the document being scored also matches a separate boosting query.
- boostByValue(Query, DoubleValuesSource) - Static method in class org.apache.lucene.queries.function.FunctionScoreQuery
-
Returns a FunctionScoreQuery where the scores of a wrapped query are multiplied by
the value of a DoubleValuesSource.
- BoostedQuery - Class in org.apache.lucene.queries.function
-
- BoostedQuery(Query, ValueSource) - Constructor for class org.apache.lucene.queries.function.BoostedQuery
-
Deprecated.
- BoostingQuery - Class in org.apache.lucene.queries
-
- BoostingQuery(Query, Query, float) - Constructor for class org.apache.lucene.queries.BoostingQuery
-
Deprecated.
- BoostingQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- BoostingQueryBuilder(QueryBuilder) - Constructor for class org.apache.lucene.queryparser.xml.builders.BoostingQueryBuilder
-
- BoostingTermBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- BoostingTermBuilder() - Constructor for class org.apache.lucene.queryparser.xml.builders.BoostingTermBuilder
-
- BoostQuery - Class in org.apache.lucene.search
-
A
Query
wrapper that allows to give a boost to the wrapped query.
- BoostQuery(Query, float) - Constructor for class org.apache.lucene.search.BoostQuery
-
Sole constructor: wrap query
in such a way that the produced
scores will be boosted by boost
.
- BoostQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
- BoostQueryNode(QueryNode, float) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.BoostQueryNode
-
Constructs a boost node
- BoostQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- BoostQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.BoostQueryNodeBuilder
-
- BoostQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- BoostQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.BoostQueryNodeProcessor
-
- boosts - Variable in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
- BOTH - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Output the both the untokenized token and the splits
- bottomLat - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Bottom latitude of the vertical line
- bottomPlane - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Bottom end cutoff plane
- boundaryChars - Variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- BoundaryScanner - Interface in org.apache.lucene.search.vectorhighlight
-
- Bounded - Interface in org.apache.lucene.spatial3d.geom
-
This interface describes methods that determine what the bounds are
for a shape.
- boundingBox - Variable in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- boundingPlane - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Back-side cutoff plane
- Bounds - Interface in org.apache.lucene.spatial3d.geom
-
An interface for accumulating bounds information.
- bqtest(Query, int[]) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
Tests a query using qtest after wrapping it with both optB and reqB
- bra - Variable in class org.tartarus.snowball.SnowballProgram
-
- BrazilianAnalyzer - Class in org.apache.lucene.analysis.br
-
Analyzer
for Brazilian Portuguese language.
- BrazilianAnalyzer() - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
- BrazilianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Builds an analyzer with the given stop words
- BrazilianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Builds an analyzer with the given stop words and stemming exclusion words
- BrazilianStemFilter - Class in org.apache.lucene.analysis.br
-
- BrazilianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.br.BrazilianStemFilter
-
Creates a new BrazilianStemFilter
- BrazilianStemFilterFactory - Class in org.apache.lucene.analysis.br
-
- BrazilianStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.br.BrazilianStemFilterFactory
-
Creates a new BrazilianStemFilterFactory
- BrazilianStemmer - Class in org.apache.lucene.analysis.br
-
A stemmer for Brazilian Portuguese words.
- BrazilianStemmer() - Constructor for class org.apache.lucene.analysis.br.BrazilianStemmer
-
- breakIterator - Variable in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- BreakIteratorBoundaryScanner - Class in org.apache.lucene.search.vectorhighlight
-
A
BoundaryScanner
implementation that uses
BreakIterator
to find
boundaries in the text.
- BreakIteratorBoundaryScanner(BreakIterator) - Constructor for class org.apache.lucene.search.vectorhighlight.BreakIteratorBoundaryScanner
-
- bucket - Variable in class org.apache.lucene.search.suggest.fst.FSTCompletion.Completion
-
source bucket (weight) of the suggestion
- buf - Variable in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- 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.analysis.util.SegmentingTokenizerBase
-
- buffer - Variable in class org.apache.lucene.store.BufferedIndexInput
-
- buffer - Variable in class org.apache.lucene.util.ByteBlockPool
-
Current head buffer
- buffer - Variable in class org.apache.lucene.util.IntBlockPool
-
Current head buffer
- BUFFER_SIZE - Static variable in class org.apache.lucene.benchmark.byTask.utils.StreamUtils
-
Buffer size used across the benchmark package
- BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
-
Default buffer size set to 1024.
- BufferedChecksum - Class in org.apache.lucene.store
-
Wraps another Checksum
with an internal buffer
to speed up checksum calculations.
- BufferedChecksum(Checksum) - Constructor for class org.apache.lucene.store.BufferedChecksum
-
- BufferedChecksum(Checksum, int) - Constructor for class org.apache.lucene.store.BufferedChecksum
-
Create a new BufferedChecksum with the specified bufferSize
- BufferedChecksumIndexInput - Class in org.apache.lucene.store
-
- BufferedChecksumIndexInput(IndexInput) - Constructor for class org.apache.lucene.store.BufferedChecksumIndexInput
-
Creates a new BufferedChecksumIndexInput
- BufferedIndexInput - Class in org.apache.lucene.store
-
Base implementation class for buffered
IndexInput
.
- BufferedIndexInput(String) - Constructor for class org.apache.lucene.store.BufferedIndexInput
-
- BufferedIndexInput(String, IOContext) - Constructor for class org.apache.lucene.store.BufferedIndexInput
-
- BufferedIndexInput(String, int) - Constructor for class org.apache.lucene.store.BufferedIndexInput
-
Inits BufferedIndexInput with a specific bufferSize
- BufferedInputIterator - Class in org.apache.lucene.search.suggest
-
This wrapper buffers incoming elements.
- BufferedInputIterator(InputIterator) - Constructor for class org.apache.lucene.search.suggest.BufferedInputIterator
-
Creates a new iterator, buffering entries from the specified iterator
- BUFFERMAX - Static variable in class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
- buffers - Variable in class org.apache.lucene.store.RAMFile
-
Deprecated.
- buffers - Variable in class org.apache.lucene.util.ByteBlockPool
-
array of buffers currently used in the pool.
- buffers - Variable in class org.apache.lucene.util.IntBlockPool
-
array of buffers currently used in the pool.
- bufferShape(Shape, double) - Method in class org.apache.lucene.spatial.prefix.WithinPrefixTreeQuery
-
Returns a new shape that is larger than shape by at distErr.
- bufferSize(IOContext) - Static method in class org.apache.lucene.store.BufferedIndexInput
-
Returns default buffer sizes for the given
IOContext
- bufferSize - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
read buffer size (in bytes)
- bufferSkip(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
-
Writes the current skip data to the buffers.
- bugfix - Variable in class org.apache.lucene.util.Version
-
Bugfix number, incremented on release branches
- build() - Method in class org.apache.lucene.analysis.charfilter.NormalizeCharMap.Builder
-
- build() - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer.Builder
-
Builds the analyzer.
- build() - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter.Builder
-
- build() - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
- build(Document) - Method in class org.apache.lucene.facet.FacetsConfig
-
- build(TaxonomyWriter, Document) - Method in class org.apache.lucene.facet.FacetsConfig
-
Translates any added
FacetField
s into normal fields for indexing.
- build(IndexReader.CacheKey, SortedDocValues[], float) - Static method in class org.apache.lucene.index.OrdinalMap
-
Create an ordinal map that uses the number of unique values of each
SortedDocValues
instance as a weight.
- build(IndexReader.CacheKey, SortedSetDocValues[], float) - Static method in class org.apache.lucene.index.OrdinalMap
-
Create an ordinal map that uses the number of unique values of each
SortedSetDocValues
instance as a weight.
- build(IndexReader.CacheKey, TermsEnum[], long[], float) - Static method in class org.apache.lucene.index.OrdinalMap
-
Creates an ordinal map that allows mapping ords to/from a merged
space from subs
.
- build(IndexReaderContext, Term) - Static method in class org.apache.lucene.index.TermContext
-
- build(QueryNode) - Method in interface org.apache.lucene.queryparser.flexible.core.builders.QueryBuilder
-
Builds some kind of object from a query tree.
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.builders.QueryTreeBuilder
-
Builds some kind of object from a query tree.
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.AnyQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.BooleanQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.BoostQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.DummyQueryNodeBuilder
-
Always return null
.
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.FieldQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.FuzzyQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.GroupQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.MatchAllDocsQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.MatchNoDocsQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.ModifierQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.MultiPhraseQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.PhraseQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.PointRangeQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.PrefixWildcardQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.RegexpQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.SlopQueryNodeBuilder
-
- build(QueryNode) - Method in interface org.apache.lucene.queryparser.flexible.standard.builders.StandardQueryBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.StandardQueryTreeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.SynonymQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.TermRangeQueryNodeBuilder
-
- build(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.builders.WildcardQueryNodeBuilder
-
- build() - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
-
- build() - Method in class org.apache.lucene.search.BooleanQuery.Builder
-
Create a new
BooleanQuery
based on the parameters that have
been set on this builder.
- build() - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
-
- build(BlendedTermQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
-
- build(BooleanQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-
- build(BooleanQuery.Builder) - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
-
- build() - Method in class org.apache.lucene.search.PhraseQuery.Builder
-
Build a phrase query based on the terms that have been added.
- build() - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
-
Build the query
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
- build(InputIterator, double) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Build the suggest index, using up to the specified
amount of temporary RAM while building.
- build() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
-
Builds the final automaton from a list of added entries.
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
- build(Dictionary) - Method in class org.apache.lucene.search.suggest.Lookup
-
Build lookup from a dictionary.
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.Lookup
-
- build(InputIterator) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
- build(double, double, int, List<Cell>, long, Shape, int) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- build(Collection<BytesRef>) - Static method in class org.apache.lucene.util.automaton.DaciukMihovAutomatonBuilder
-
Build a minimal, deterministic automaton from a sorted list of
BytesRef
representing
strings in UTF-8.
- build() - Method in class org.apache.lucene.util.DocIdSetBuilder
-
Build a
DocIdSet
from the accumulated doc IDs.
- build() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
-
Build a
PackedLongValues
instance that contains values that
have been added to this builder.
- build() - Method in class org.apache.lucene.util.RoaringDocIdSet.Builder
-
Build an instance.
- Builder() - Constructor for class org.apache.lucene.analysis.charfilter.NormalizeCharMap.Builder
-
- builder() - Static method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
Returns a builder for custom analyzers that loads all resources from
Lucene's classloader.
- builder(Path) - Static method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
Returns a builder for custom analyzers that loads all resources from the given
file system base directory.
- builder(ResourceLoader) - Static method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
Returns a builder for custom analyzers that loads all resources using the given
ResourceLoader
.
- builder() - Method in interface org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttribute
-
Returns the builder from which the term is derived.
- builder() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
- Builder() - Constructor for class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter.Builder
-
- Builder(boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter.Builder
-
- Builder() - Constructor for class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
Default constructor, passes dedup=true
.
- Builder(boolean) - Constructor for class org.apache.lucene.analysis.synonym.SynonymMap.Builder
-
If dedup is true then identical rules (same input,
same output) will be added only once.
- builder - Variable in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- Builder() - Constructor for class org.apache.lucene.index.PrefixCodedTerms.Builder
-
Sole constructor.
- Builder() - Constructor for class org.apache.lucene.search.BlendedTermQuery.Builder
-
Sole constructor.
- Builder() - Constructor for class org.apache.lucene.search.BooleanQuery.Builder
-
Sole constructor.
- Builder() - Constructor for class org.apache.lucene.search.MultiPhraseQuery.Builder
-
Default constructor.
- Builder(MultiPhraseQuery) - Constructor for class org.apache.lucene.search.MultiPhraseQuery.Builder
-
Copy constructor: this will create a builder that has the same
configuration as the provided builder.
- Builder() - Constructor for class org.apache.lucene.search.PhraseQuery.Builder
-
Sole constructor.
- Builder(String, boolean) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery.Builder
-
Construct a new builder
- Builder() - Constructor for class org.apache.lucene.util.automaton.Automaton.Builder
-
Default constructor, pre-allocating for 16 states and transitions.
- Builder(int, int) - Constructor for class org.apache.lucene.util.automaton.Automaton.Builder
-
Constructor which creates a builder with enough space for the given
number of states and transitions.
- Builder<T> - Class in org.apache.lucene.util.fst
-
Builds a minimal FST (maps an IntsRef term to an arbitrary
output) from pre-sorted terms with outputs.
- Builder(FST.INPUT_TYPE, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.Builder
-
Instantiates an FST/FSA builder without any pruning.
- Builder(FST.INPUT_TYPE, int, int, boolean, boolean, int, Outputs<T>, boolean, int) - Constructor for class org.apache.lucene.util.fst.Builder
-
Instantiates an FST/FSA builder with all the possible tuning and construction
tweaks.
- Builder(int) - Constructor for class org.apache.lucene.util.RoaringDocIdSet.Builder
-
Sole constructor.
- Builder.Arc<T> - Class in org.apache.lucene.util.fst
-
Expert: holds a pending (seen but not yet serialized) arc.
- Builder.UnCompiledNode<T> - Class in org.apache.lucene.util.fst
-
Expert: holds a pending (seen but not yet serialized) Node.
- buildExtensionField(String) - Method in class org.apache.lucene.queryparser.ext.Extensions
-
Builds an extension field string from a given extension key and the default
query field.
- buildExtensionField(String, String) - Method in class org.apache.lucene.queryparser.ext.Extensions
-
Builds an extension field string from a given extension key and the
extensions field.
- buildFacetsResult(FacetsCollector, FacetsCollector[], String[]) - Method in class org.apache.lucene.facet.DrillSideways
-
Subclass can override to customize per-dim Facets
impl.
- buildFieldConfig(FieldConfig) - Method in interface org.apache.lucene.queryparser.flexible.core.config.FieldConfigListener
-
This method is called ever time a field configuration is requested.
- buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryparser.flexible.standard.config.FieldBoostMapFCListener
-
- buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryparser.flexible.standard.config.FieldDateResolutionFCListener
-
- buildFieldConfig(FieldConfig) - Method in class org.apache.lucene.queryparser.flexible.standard.config.PointsConfigListener
-
- buildIndex(Codec, Directory, IndexOptions, boolean, boolean) - Method in class org.apache.lucene.index.RandomPostingsTester
-
- buildListFromTopDocs(TopDocs) - Method in class org.apache.lucene.classification.KNearestNeighborClassifier
-
build a list of classification results from search results
- buildQuery(int, TermContext[], Term[]) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- BulgarianAnalyzer - Class in org.apache.lucene.analysis.bg
-
- BulgarianAnalyzer() - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
- BulgarianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
Builds an analyzer with the given stop words.
- BulgarianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
Builds an analyzer with the given stop words and a stem exclusion set.
- BulgarianStemFilter - Class in org.apache.lucene.analysis.bg
-
- BulgarianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.bg.BulgarianStemFilter
-
- BulgarianStemFilterFactory - Class in org.apache.lucene.analysis.bg
-
- BulgarianStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.bg.BulgarianStemFilterFactory
-
Creates a new BulgarianStemFilterFactory
- BulgarianStemmer - Class in org.apache.lucene.analysis.bg
-
Light Stemmer for Bulgarian.
- BulgarianStemmer() - Constructor for class org.apache.lucene.analysis.bg.BulgarianStemmer
-
- BulkAdder() - Constructor for class org.apache.lucene.util.DocIdSetBuilder.BulkAdder
-
- BulkScorer - Class in org.apache.lucene.search
-
- BulkScorer() - Constructor for class org.apache.lucene.search.BulkScorer
-
- bulkScorer(LeafReaderContext) - Method in class org.apache.lucene.search.suggest.document.CompletionWeight
-
- bulkScorer(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
-
- BulkScorerWrapperScorer - Class in org.apache.lucene.search
-
- BulkScorerWrapperScorer(Weight, BulkScorer, int) - Constructor for class org.apache.lucene.search.BulkScorerWrapperScorer
-
Sole constructor.
- byId(int) - Static method in enum org.apache.lucene.util.packed.PackedInts.Format
-
Get a format according to its ID.
- byte315ToFloat(byte) - Static method in class org.apache.lucene.util.SmallFloat
-
byteToFloat(b, mantissaBits=3, zeroExponent=15)
- byte4ToInt(byte) - Static method in class org.apache.lucene.util.SmallFloat
-
- 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
-
- ByteArrayIndexInput - Class in org.apache.lucene.store
-
- ByteArrayIndexInput(String, byte[]) - Constructor for class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- ByteArrayIndexInput(String, byte[], int, int) - Constructor for class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- byteAt(int) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Return the byte at the given offset.
- byteAt(BytesRef, int) - Method in class org.apache.lucene.util.BytesRefComparator
-
Return the unsigned byte to use for comparison at index i
, or
-1
if all bytes that are useful for comparisons are exhausted.
- byteAt(int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
-
Return the k-th byte of the entry at index i
, or -1
if
its length is less than or equal to k
.
- byteAt(int, int) - Method in class org.apache.lucene.util.RadixSelector
-
Return the k-th byte of the entry at index i
, or -1
if
its length is less than or equal to k
.
- byteBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
The minimum number of byte blocks to encode in a single iteration, when
using byte encoding.
- byteBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
-
The minimum number of byte blocks to encode in a single iteration, when
using byte encoding.
- ByteBlockPool - Class in org.apache.lucene.util
-
Class that Posting and PostingVector use to write byte
streams into shared fixed-size byte[] arrays.
- ByteBlockPool(ByteBlockPool.Allocator) - Constructor for class org.apache.lucene.util.ByteBlockPool
-
- ByteBlockPool.Allocator - Class in org.apache.lucene.util
-
Abstract class for allocating and freeing byte
blocks.
- ByteBlockPool.DirectAllocator - Class in org.apache.lucene.util
-
- ByteBlockPool.DirectTrackingAllocator - Class in org.apache.lucene.util
-
- ByteBufferRecycler(IntFunction<ByteBuffer>) - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput.ByteBufferRecycler
-
- ByteBuffersDataInput - Class in org.apache.lucene.store
-
- ByteBuffersDataInput(List<ByteBuffer>) - Constructor for class org.apache.lucene.store.ByteBuffersDataInput
-
Read data from a set of contiguous buffers.
- ByteBuffersDataOutput - Class in org.apache.lucene.store
-
A
DataOutput
storing data in a list of
ByteBuffer
s.
- ByteBuffersDataOutput(long) - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput
-
- ByteBuffersDataOutput() - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput
-
- ByteBuffersDataOutput(int, int, IntFunction<ByteBuffer>, Consumer<ByteBuffer>) - Constructor for class org.apache.lucene.store.ByteBuffersDataOutput
-
- ByteBuffersDataOutput.ByteBufferRecycler - Class in org.apache.lucene.store
-
An implementation of a ByteBuffer
allocation and recycling policy.
- ByteBuffersDirectory - Class in org.apache.lucene.store
-
A
ByteBuffer
-based
Directory
implementation that
can be used to store index files on the heap.
- ByteBuffersDirectory() - Constructor for class org.apache.lucene.store.ByteBuffersDirectory
-
- ByteBuffersDirectory(LockFactory) - Constructor for class org.apache.lucene.store.ByteBuffersDirectory
-
- ByteBuffersDirectory(LockFactory, Supplier<ByteBuffersDataOutput>, BiFunction<String, ByteBuffersDataOutput, IndexInput>) - Constructor for class org.apache.lucene.store.ByteBuffersDirectory
-
- ByteBuffersIndexInput - Class in org.apache.lucene.store
-
- ByteBuffersIndexInput(ByteBuffersDataInput, String) - Constructor for class org.apache.lucene.store.ByteBuffersIndexInput
-
- ByteBuffersIndexOutput - Class in org.apache.lucene.store
-
- ByteBuffersIndexOutput(ByteBuffersDataOutput, String, String) - Constructor for class org.apache.lucene.store.ByteBuffersIndexOutput
-
- ByteBuffersIndexOutput(ByteBuffersDataOutput, String, String, Checksum, Consumer<ByteBuffersDataOutput>) - Constructor for class org.apache.lucene.store.ByteBuffersIndexOutput
-
- byteCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
-
Computes how many byte blocks are needed to store values
values of size bitsPerValue
.
- byteOffset - Variable in class org.apache.lucene.util.ByteBlockPool
-
Current head offset
- ByteRunAutomaton - Class in org.apache.lucene.util.automaton
-
Automaton representation for matching UTF-8 byte[].
- ByteRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
-
Converts incoming automaton to byte-based (UTF32ToUTF8) first
- ByteRunAutomaton(Automaton, boolean, int) - Constructor for class org.apache.lucene.util.automaton.ByteRunAutomaton
-
expert: if isBinary is true, the input is already byte-based
- BYTES - Static variable in class org.apache.lucene.document.BigIntegerPoint
-
The number of bytes per dimension: 128 bits.
- BYTES - Static variable in class org.apache.lucene.document.DoubleRange
-
stores double values so number of bytes is 8
- BYTES - Static variable in class org.apache.lucene.document.FloatRange
-
stores float values so number of bytes is 4
- BYTES - Static variable in class org.apache.lucene.document.HalfFloatPoint
-
The number of bytes used to represent a half-float value.
- BYTES - Static variable in class org.apache.lucene.document.InetAddressPoint
-
The number of bytes per dimension: 128 bits
- BYTES - Static variable in class org.apache.lucene.document.InetAddressRange
-
The number of bytes per dimension : sync w/ InetAddressPoint
- BYTES - Static variable in class org.apache.lucene.document.IntRange
-
stores integer values so number of bytes is 4
- BYTES - Static variable in class org.apache.lucene.document.LatLonBoundingBox
-
uses same encoding as
LatLonPoint
so numBytes is the same
- BYTES - Static variable in class org.apache.lucene.document.LatLonPoint
-
LatLonPoint is encoded as integer values so number of bytes is 4
- BYTES - Static variable in class org.apache.lucene.document.LongRange
-
stores long values so number of bytes is 8
- bytes() - Method in class org.apache.lucene.index.Term
-
Returns the bytes of this term, these should not be modified.
- bytes - Variable in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- bytes - Variable in class org.apache.lucene.util.BytesRef
-
The contents of the BytesRef.
- bytes() - Method in class org.apache.lucene.util.BytesRefBuilder
-
Return a reference to the bytes of this builder.
- BYTES_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- bytesDifference(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
-
Compares two
BytesRef
, element by element, and returns the
number of elements common to both arrays (from the start of each).
- bytesEquals(BytesRef) - Method in class org.apache.lucene.util.BytesRef
-
Expert: compares the bytes against another BytesRef,
returning true if the bytes are equal.
- ByteSequenceOutputs - Class in org.apache.lucene.util.fst
-
An FST
Outputs
implementation where each output
is a sequence of bytes.
- ByteSequencesReader(ChecksumIndexInput, String) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
-
Constructs a ByteSequencesReader from the provided IndexInput
- ByteSequencesWriter(IndexOutput) - Constructor for class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
-
Constructs a ByteSequencesWriter to the provided DataOutput
- bytesPerArc - Variable in class org.apache.lucene.util.fst.FST.Arc
-
Non-zero if this arc is part of an array, which means all
arcs for the node are encoded with a fixed number of bytes so
that we can random access by index.
- bytesPerDim - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
How many bytes each value in each dimension takes.
- BytesReader() - Constructor for class org.apache.lucene.util.fst.FST.BytesReader
-
- bytesRef - Variable in class org.apache.lucene.queries.function.valuesource.LiteralValueSource
-
- bytesRef - Variable in class org.apache.lucene.spatial.prefix.CellToBytesRefIterator
-
- BytesRef - Class in org.apache.lucene.util
-
Represents byte[], as a slice (offset + length) into an
existing byte[].
- BytesRef() - Constructor for class org.apache.lucene.util.BytesRef
-
- BytesRef(byte[], int, int) - Constructor for class org.apache.lucene.util.BytesRef
-
This instance will directly reference bytes w/o making a copy.
- BytesRef(byte[]) - Constructor for class org.apache.lucene.util.BytesRef
-
This instance will directly reference bytes w/o making a copy.
- BytesRef(int) - Constructor for class org.apache.lucene.util.BytesRef
-
Create a BytesRef pointing to a new array of size capacity
.
- BytesRef(CharSequence) - Constructor for class org.apache.lucene.util.BytesRef
-
Initialize the byte[] from the UTF8 bytes
for the provided String.
- BytesRefArray - Class in org.apache.lucene.util
-
A simple append only random-access
BytesRef
array that stores full
copies of the appended bytes in a
ByteBlockPool
.
- BytesRefArray(Counter) - Constructor for class org.apache.lucene.util.BytesRefArray
-
Creates a new
BytesRefArray
with a counter to track allocated bytes
- BytesRefBuilder - Class in org.apache.lucene.util
-
- BytesRefBuilder() - Constructor for class org.apache.lucene.util.BytesRefBuilder
-
Sole constructor.
- BytesRefBuilderTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
Sole constructor
no-op
- BytesRefComparator - Class in org.apache.lucene.util
-
Specialized
BytesRef
comparator that
FixedLengthBytesRefArray.iterator(Comparator)
has optimizations
for.
- BytesRefComparator(int) - Constructor for class org.apache.lucene.util.BytesRefComparator
-
Sole constructor.
- BytesRefFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
An implementation for retrieving
FunctionValues
instances for string based fields.
- BytesRefFieldSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.BytesRefFieldSource
-
- BytesRefFSTEnum<T> - Class in org.apache.lucene.util.fst
-
Enumerates all input (BytesRef) + output pairs in an
FST.
- BytesRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum
-
doFloor controls the behavior of advance: if it's true
doFloor is true, advance positions to the biggest
term before target.
- BytesRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
-
Holds a single input (BytesRef) + output pair.
- BytesRefHash - Class in org.apache.lucene.util
-
- BytesRefHash() - Constructor for class org.apache.lucene.util.BytesRefHash
-
- BytesRefHash(ByteBlockPool) - Constructor for class org.apache.lucene.util.BytesRefHash
-
- BytesRefHash(ByteBlockPool, int, BytesRefHash.BytesStartArray) - Constructor for class org.apache.lucene.util.BytesRefHash
-
- BytesRefHash.BytesStartArray - Class in org.apache.lucene.util
-
Manages allocation of the per-term addresses.
- BytesRefHash.DirectBytesStartArray - Class in org.apache.lucene.util
-
- BytesRefHash.MaxBytesLengthExceededException - Exception in org.apache.lucene.util
-
- BytesRefIterator - Interface in org.apache.lucene.util
-
A simple iterator interface for
BytesRef
iteration.
- BytesRefSorter - Interface in org.apache.lucene.search.suggest.fst
-
Collects
BytesRef
and then allows one to iterate over their sorted order.
- bytesRefToFloat(BytesRef) - Static method in class org.apache.lucene.facet.taxonomy.FloatAssociationFacetField
-
Decodes a previously encoded float
.
- bytesRefToInt(BytesRef) - Static method in class org.apache.lucene.facet.taxonomy.IntAssociationFacetField
-
Decodes a previously encoded int
.
- bytesRefToString(BytesRef) - Static method in class org.apache.lucene.util.TestUtil
-
For debugging: tries to include br.utf8ToString(), but if that
fails (because it's not valid utf8, which is fine!), just
use ordinary toString.
- BytesStartArray() - Constructor for class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
- byteStart(int) - Method in class org.apache.lucene.util.BytesRefHash
-
Returns the bytesStart offset into the internally used
ByteBlockPool
for the given bytesID
- BytesTermAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
This attribute can be used if you have the raw term bytes to be indexed.
- BytesTermAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- BytesTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
-
Initialize this attribute with no bytes.
- bytesToCharSequence(BytesRef, Random) - Static method in class org.apache.lucene.util.TestUtil
-
- bytesToCopy - Variable in class org.apache.lucene.replicator.nrt.CopyOneFile
-
- bytesToLong(BytesRef) - Static method in class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
- bytesToString(long) - Static method in class org.apache.lucene.replicator.nrt.Node
-
- bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
- bytesUsed() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-
- bytesUsed() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- bytesUsed() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- bytesVal(int, BytesRefBuilder) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- bytesVal(int, BytesRefBuilder) - Method in class org.apache.lucene.queries.function.FunctionValues
-
returns the bytes representation of the string val - TODO: should this return the indexed raw bytes not?
- byteToFloat(byte, int, int) - Static method in class org.apache.lucene.util.SmallFloat
-
Converts an 8 bit float to a 32 bit float.
- byteUpto - Variable in class org.apache.lucene.util.ByteBlockPool
-
Where we are in head buffer
- byteVal(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- byteVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- byteVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- byteVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- byteVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- byteVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- byteVal(int, byte[]) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- byteValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
- byteValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
-
- ByteVector - Class in org.apache.lucene.analysis.compound.hyphenation
-
This class implements a simple byte vector with access to the underlying
array.
- ByteVector() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- ByteVector(int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- ByteVector(byte[]) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- ByteVector(byte[], int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- c - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The z scaling factor
- CachedOrdinalsReader - Class in org.apache.lucene.facet.taxonomy
-
A per-segment cache of documents' facet ordinals.
- CachedOrdinalsReader(OrdinalsReader) - Constructor for class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader
-
Sole constructor.
- CachedOrdinalsReader.CachedOrds - Class in org.apache.lucene.facet.taxonomy
-
Holds the cached ordinals in two parallel int[]
arrays.
- CachedOrds(OrdinalsReader.OrdinalsSegmentReader, int) - Constructor for class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader.CachedOrds
-
- cacheImpl(BulkScorer, int) - Method in class org.apache.lucene.search.LRUQueryCache
-
- 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.
- CachingDoubleValueSource - Class in org.apache.lucene.spatial.util
-
Caches the doubleVal of another value source in a HashMap
so that it is computed only once.
- CachingDoubleValueSource(DoubleValuesSource) - Constructor for class org.apache.lucene.spatial.util.CachingDoubleValueSource
-
- CachingNaiveBayesClassifier - Class in org.apache.lucene.classification
-
A simplistic Lucene based NaiveBayes classifier, with caching feature, see
http://en.wikipedia.org/wiki/Naive_Bayes_classifier
- CachingNaiveBayesClassifier(IndexReader, Analyzer, Query, String, String...) - Constructor for class org.apache.lucene.classification.CachingNaiveBayesClassifier
-
Creates a new NaiveBayes classifier with inside caching.
- CachingTokenFilter - Class in org.apache.lucene.analysis
-
This class can be used if the token attributes of a TokenStream
are intended to be consumed more than once.
- CachingTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.CachingTokenFilter
-
Create a new CachingTokenFilter around input
.
- calcBoxByDistFromPt(Point, double, SpatialContext, Rectangle) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- calcBoxByDistFromPt_yHorizAxisDEG(Point, double, SpatialContext) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- calcDistanceFromErrPct(Shape, double, SpatialContext) - Static method in class org.apache.lucene.spatial.query.SpatialArgs
-
Computes the distance given a shape and the distErrPct
.
- calcFacets(PrefixTreeStrategy, IndexReaderContext, Bits, Shape, int, int) - Static method in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter
-
Calculates spatial 2D facets (aggregated counts) in a grid, sometimes called a heatmap.
- calcFacets(IndexReaderContext, Bits, NumberRangePrefixTree.UnitNRShape, NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy
-
Calculates facets between start
and end
to a detail level one greater than that provided by the
arguments.
- calcFacets(IndexReaderContext, Bits, Shape, int) - Method in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy
-
Calculates facets (aggregated counts) given a range shape (start-end span) and a level, which specifies the detail.
- calcFacets(IndexReaderContext, Bits, Shape, int, int) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
Computes spatial facets in two dimensions as a grid of numbers.
- calcHighFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- calcLowFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- calcNBestCost(String) - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
- calculateCoefficient(int) - Method in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
Calculate the weight coefficient based on the position of the first matching word.
- calcUTF16toUTF8Length(CharSequence, int, int) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Calculates the number of UTF8 bytes necessary to write a UTF16 string.
- calibrateSizeByDeletes - Variable in class org.apache.lucene.index.LogMergePolicy
-
If true, we pro-rate a segment's size by the
percentage of non-deleted documents.
- cancel(String, Throwable) - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
- cancelReason - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- canEarlyTerminate(Sort, Sort) - Static method in class org.apache.lucene.search.EarlyTerminatingSortingCollector
-
Deprecated.
Returns whether collection can be early-terminated if it sorts with the
provided
Sort
and if segments are merged with the provided
Sort
.
- CannedBinaryTokenStream - Class in org.apache.lucene.analysis
-
TokenStream from a canned list of binary (BytesRef-based)
tokens.
- CannedBinaryTokenStream(CannedBinaryTokenStream.BinaryToken...) - Constructor for class org.apache.lucene.analysis.CannedBinaryTokenStream
-
- CannedBinaryTokenStream.BinaryToken - Class in org.apache.lucene.analysis
-
Represents a binary token.
- CannedTokenStream - Class in org.apache.lucene.analysis
-
TokenStream from a canned list of Tokens.
- CannedTokenStream(Token...) - Constructor for class org.apache.lucene.analysis.CannedTokenStream
-
- CannedTokenStream(int, int, Token...) - Constructor for class org.apache.lucene.analysis.CannedTokenStream
-
If you want trailing holes, pass a non-zero
finalPosInc.
- canReuse(MultiTermsEnum) - Method in class org.apache.lucene.index.MultiPostingsEnum
-
Returns
true
if this instance can be reused by
the provided
MultiTermsEnum
.
- capacity() - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
returns current capacity of array
- capacity() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
returns current capacity of array
- capacity() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- CapitalizationFilter - Class in org.apache.lucene.analysis.miscellaneous
-
A filter to apply normal capitalization rules to Tokens.
- CapitalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.CapitalizationFilter
-
Creates a CapitalizationFilter with the default parameters.
- CapitalizationFilter(TokenStream, boolean, CharArraySet, boolean, Collection<char[]>, int, int, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.CapitalizationFilter
-
Creates a CapitalizationFilter with the specified parameters.
- CapitalizationFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- CapitalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
Creates a new CapitalizationFilterFactory
- captureState() - Method in class org.apache.lucene.util.AttributeSource
-
Captures the state of all Attributes.
- CARAT - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- CARAT - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- CARAT - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- cardinality() - Method in class org.apache.lucene.util.BitSet
-
Return the number of bits that are set.
- cardinality() - Method in class org.apache.lucene.util.FixedBitSet
-
Returns number of set bits.
- cardinality() - Method in class org.apache.lucene.util.LongBitSet
-
Returns number of set bits.
- cardinality() - Method in class org.apache.lucene.util.RoaringDocIdSet
-
Return the exact number of documents that are contained in this set.
- cardinality() - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- CatalanAnalyzer - Class in org.apache.lucene.analysis.ca
-
- CatalanAnalyzer() - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
- CatalanAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
Builds an analyzer with the given stop words.
- CatalanAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
Builds an analyzer with the given stop words.
- CatalanStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- CatalanStemmer() - Constructor for class org.tartarus.snowball.ext.CatalanStemmer
-
- categoriesLineFile(Path) - Static method in class org.apache.lucene.benchmark.byTask.tasks.WriteEnwikiLineDocTask
-
Compose categories line file out of original line file
- CATEGORY - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- CATEGORY_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- CATENATE_ALL - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
Causes all subword parts to be catenated:
- CATENATE_ALL - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes all subword parts to be catenated:
- CATENATE_NUMBERS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
Causes maximum runs of word parts to be catenated:
- CATENATE_NUMBERS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes maximum runs of number parts to be catenated:
- CATENATE_WORDS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
Causes maximum runs of word parts to be catenated:
- CATENATE_WORDS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes maximum runs of word parts to be catenated:
- Cell(byte[], byte[]) - Constructor for class org.apache.lucene.index.PointsStackTracker.Cell
-
- Cell - Interface in org.apache.lucene.spatial.prefix.tree
-
Represents a grid cell.
- CellCanPrune - Interface in org.apache.lucene.spatial.prefix.tree
-
- cellIter - Variable in class org.apache.lucene.spatial.prefix.CellToBytesRefIterator
-
- CellIterator - Class in org.apache.lucene.spatial.prefix.tree
-
An Iterator of SpatialPrefixTree Cells.
- CellIterator() - Constructor for class org.apache.lucene.spatial.prefix.tree.CellIterator
-
- CellToBytesRefIterator - Class in org.apache.lucene.spatial.prefix
-
- CellToBytesRefIterator() - Constructor for class org.apache.lucene.spatial.prefix.CellToBytesRefIterator
-
- center - Variable in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- centerPoint - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
A computed center point for the line
- changed() - Method in class org.apache.lucene.index.SegmentInfos
-
Call this before committing if changes have been made to the
segments.
- changeToken(BytesRef) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
-
Subclass and implement this if you need to change the
token (such as escaping certain bytes) before it's
turned into a graph.
- CharacterDefinition - Class in org.apache.lucene.analysis.ja.dict
-
Character category data.
- CharacterDefinition - Class in org.apache.lucene.analysis.ko.dict
-
Character category data.
- CharacterRunAutomaton - Class in org.apache.lucene.util.automaton
-
Automaton representation for matching char[].
- CharacterRunAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CharacterRunAutomaton
-
Construct with a default number of maxDeterminizedStates.
- CharacterRunAutomaton(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.CharacterRunAutomaton
-
Construct specifying maxDeterminizedStates.
- characters(char[], int, int) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- CharacterUtils - Class in org.apache.lucene.analysis
-
Utility class to write tokenizers or token filters.
- CharacterUtils.CharacterBuffer - Class in org.apache.lucene.analysis
-
- charArray - Variable in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
-
Character array containing token text
- CharArrayIterator - Class in org.apache.lucene.analysis.util
-
A CharacterIterator used internally for use with BreakIterator
- CharArrayIterator() - Constructor for class org.apache.lucene.analysis.util.CharArrayIterator
-
- CharArrayMap<V> - Class in org.apache.lucene.analysis
-
A simple class that stores key Strings as char[]'s in a
hash table.
- CharArrayMap(int, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
-
Create map with enough capacity to hold startSize terms
- CharArrayMap(Map<?, ? extends V>, boolean) - Constructor for class org.apache.lucene.analysis.CharArrayMap
-
Creates a map from the mappings in another map.
- CharArrayMap.EntryIterator - Class in org.apache.lucene.analysis
-
public iterator class so efficient methods are exposed to users
- CharArrayMap.EntrySet - Class in org.apache.lucene.analysis
-
public EntrySet class so efficient methods are exposed to users
- CharArraySet - Class in org.apache.lucene.analysis
-
A simple class that stores Strings as char[]'s in a
hash table.
- CharArraySet(int, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
-
Create set with enough capacity to hold startSize terms
- CharArraySet(Collection<?>, boolean) - Constructor for class org.apache.lucene.analysis.CharArraySet
-
Creates a set from a Collection of objects.
- charAt(int) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter.NumberBuffer
-
- charAt(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- charAt(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- charAt(int) - Method in class org.apache.lucene.queryparser.flexible.core.util.UnescapedCharSequence
-
- charAt(int) - Method in class org.apache.lucene.util.CharsRef
-
- charAt(int) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Return the char at the given offset.
- CharFilter - Class in org.apache.lucene.analysis
-
Subclasses of CharFilter can be chained to filter a Reader
They can be used as Reader
with additional offset
correction.
- CharFilter(Reader) - Constructor for class org.apache.lucene.analysis.CharFilter
-
Create a new CharFilter wrapping the provided reader.
- CharFilterFactory - Class in org.apache.lucene.analysis.util
-
Abstract parent class for analysis factories that create
CharFilter
instances.
- CharFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.util.CharFilterFactory
-
Initialize this factory via a set of key-value pairs.
- chars - Variable in class org.apache.lucene.util.CharsRef
-
The contents of the CharsRef.
- chars() - Method in class org.apache.lucene.util.CharsRefBuilder
-
Return a reference to the chars of this builder.
- charsEquals(CharsRef) - Method in class org.apache.lucene.util.CharsRef
-
- CHARSEQUENCE_COMPARATOR - Static variable in class org.apache.lucene.search.suggest.Lookup
-
A simple char-by-char comparator for CharSequence
- CharSequenceOutputs - Class in org.apache.lucene.util.fst
-
An FST
Outputs
implementation where each output
is a sequence of characters.
- charset - Variable in class org.apache.lucene.analysis.payloads.IdentityEncoder
-
- CharsRef - Class in org.apache.lucene.util
-
Represents char[], as a slice (offset + length) into an existing char[].
- CharsRef() - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized an empty array zero-length
- CharsRef(int) - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized with an array of the given
capacity
- CharsRef(char[], int, int) - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized with the given array, offset and
length
- CharsRef(String) - Constructor for class org.apache.lucene.util.CharsRef
-
Creates a new
CharsRef
initialized with the given Strings character
array
- CharsRefBuilder - Class in org.apache.lucene.util
-
- CharsRefBuilder() - Constructor for class org.apache.lucene.util.CharsRefBuilder
-
Sole constructor.
- CharStream - Interface in org.apache.lucene.queryparser.classic
-
This interface describes a character stream that maintains line and
column number positions of the characters.
- CharStream - Interface in org.apache.lucene.queryparser.flexible.standard.parser
-
This interface describes a character stream that maintains line and
column number positions of the characters.
- CharStream - Interface in org.apache.lucene.queryparser.surround.parser
-
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
-
- CharTermAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Initialize this attribute with empty term text
- CharTokenizer - Class in org.apache.lucene.analysis.util
-
An abstract base class for simple, character-oriented tokenizers.
- CharTokenizer() - Constructor for class org.apache.lucene.analysis.util.CharTokenizer
-
- CharTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.util.CharTokenizer
-
- CharTokenizer(AttributeFactory, int) - Constructor for class org.apache.lucene.analysis.util.CharTokenizer
-
- CharType - Class in org.apache.lucene.analysis.cn.smart
-
Internal SmartChineseAnalyzer character type constants.
- CharType() - Constructor for class org.apache.lucene.analysis.cn.smart.CharType
-
- CharVector - Class in org.apache.lucene.analysis.compound.hyphenation
-
This class implements a simple char vector with access to the underlying
array.
- CharVector() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- CharVector(int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- CharVector(char[]) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- CharVector(char[], int) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- CheapBastardCodec - Class in org.apache.lucene.codecs.cheapbastard
-
Codec that tries to use as little ram as possible because he spent all his money on beer
- CheapBastardCodec() - Constructor for class org.apache.lucene.codecs.cheapbastard.CheapBastardCodec
-
- check(IndexReader, BitSetProducer) - Static method in class org.apache.lucene.search.join.CheckJoinIndex
-
Check that the given index is good to use for block joins.
- check(Query) - Static method in class org.apache.lucene.search.QueryUtils
-
Check the types of things query objects should be able to do.
- check(Random, Query, IndexSearcher) - Static method in class org.apache.lucene.search.QueryUtils
-
Various query sanity checks on a searcher, some checks are only done for
instanceof IndexSearcher.
- check(Random, Query, IndexSearcher, boolean) - Static method in class org.apache.lucene.search.QueryUtils
-
- checkAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Checks if merge has been aborted and throws a merge exception if so.
- checkAccess(Path, AccessMode...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- checkAnalysisConsistency(Random, Analyzer, boolean, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- checkAnalysisConsistency(Random, Analyzer, boolean, String, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- checkArgs(String, Object, Object) - Static method in class org.apache.lucene.search.PointRangeQuery
-
Check preconditions for all factory methods
- checkBattenberg(byte, double, double, int, List<Cell>, long, Shape, int) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- checkBattenberg(char, double, double, int, List<Cell>, BytesRef, Shape, int) - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- checkBulkScorerSkipTo(Random, Query, IndexSearcher) - Static method in class org.apache.lucene.search.QueryUtils
-
Check that the scorer and bulk scorer advance consistently.
- checkCaptureStreams() - Static method in class org.apache.lucene.util.TestRuleLimitSysouts
-
Ensures System.out
and System.err
point to delegate streams.
- CheckClearAttributesAttributeImpl() - Constructor for class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
-
- checkConsistency() - Method in class org.apache.lucene.index.FieldInfo
-
Performs internal consistency checks.
- checkDistanceSubQueries(DistanceQuery, String) - Static method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- checkDocIds(String, int[], ScoreDoc[]) - Static method in class org.apache.lucene.search.CheckHits
-
Tests that a Hits has an expected order of documents
- checkEqual(Query, ScoreDoc[], ScoreDoc[]) - Static method in class org.apache.lucene.search.CheckHits
-
- checkEqual(Query, Query) - Static method in class org.apache.lucene.search.QueryUtils
-
- checkExit(int) - Method in class org.apache.lucene.util.TestSecurityManager
- checkExplanations(Query, String, IndexSearcher) - Static method in class org.apache.lucene.search.CheckHits
-
Asserts that the explanation value for every document matching a
query corresponds with the true score.
- checkExplanations(Query, String, IndexSearcher, boolean) - Static method in class org.apache.lucene.search.CheckHits
-
Asserts that the explanation value for every document matching a
query corresponds with the true score.
- checkExplanations(Query) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
-
- checkExplanations(Query, IndexSearcher) - Static method in class org.apache.lucene.search.QueryUtils
-
deep check that explanations of a query 'score' correctly
- checkFirstSkipTo(Query, IndexSearcher) - Static method in class org.apache.lucene.search.QueryUtils
-
check that first skip on just created scorers always goes to the right doc
- checkFooter(ChecksumIndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
-
- checkFooter(ChecksumIndexInput, Throwable) - Static method in class org.apache.lucene.codecs.CodecUtil
-
- checkForUpdate(String) - Method in class org.apache.lucene.replicator.http.HttpReplicator
-
- checkForUpdate(String) - Method in class org.apache.lucene.replicator.LocalReplicator
-
- checkForUpdate(String) - Method in interface org.apache.lucene.replicator.Replicator
-
Check whether the given version is up-to-date and returns a
SessionToken
which can be used for fetching the revision files,
otherwise returns
null
.
- checkFromIndexSize(int, int, int) - Static method in class org.apache.lucene.util.FutureObjects
-
Behaves like Java 9's Objects.checkFromIndexSize
- checkFromToIndex(int, int, int) - Static method in class org.apache.lucene.util.FutureObjects
-
Behaves like Java 9's Objects.checkFromToIndex
- checkHashEquals(Query) - Static method in class org.apache.lucene.search.QueryUtils
-
check very basic hashCode and equals
- checkHeader(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
-
- checkHeaderNoMagic(DataInput, String, int, int) - Static method in class org.apache.lucene.codecs.CodecUtil
-
- checkHitCollector(Random, Query, String, IndexSearcher, int[]) - Static method in class org.apache.lucene.search.CheckHits
-
Tests that a query matches the an expected set of documents using a
HitCollector.
- CheckHits - Class in org.apache.lucene.search
-
Utility class for asserting expected hits in tests.
- CheckHits() - Constructor for class org.apache.lucene.search.CheckHits
-
- checkHits(Random, Query, String, IndexSearcher, int[]) - Static method in class org.apache.lucene.search.CheckHits
-
Tests that a query matches the an expected set of documents using Hits.
- CheckHits.ExplanationAsserter - Class in org.apache.lucene.search
-
Asserts that the score explanation for every document matching a
query corresponds with the true score.
- CheckHits.ExplanationAssertingSearcher - Class in org.apache.lucene.search
-
an IndexSearcher that implicitly checks hte explanation of every match
whenever it executes a search.
- CheckHits.MatchesAsserter - Class in org.apache.lucene.search
-
Asserts that the
Matches
from a query is non-null whenever
the document its created for is a hit.
- CheckHits.SetCollector - Class in org.apache.lucene.search
-
Just collects document ids into a set.
- checkHitsQuery(Query, ScoreDoc[], ScoreDoc[], int[]) - Static method in class org.apache.lucene.search.CheckHits
-
Tests that two queries have an expected order of documents,
and that the two queries have the same score values.
- checkIfFrozen() - Method in class org.apache.lucene.document.FieldType
-
Throws an exception if this FieldType is frozen.
- CheckIndex - Class in org.apache.lucene.index
-
Basic tool and API to check the health of an index and
write a new segments file that removes reference to
problematic segments.
- CheckIndex(Directory) - Constructor for class org.apache.lucene.index.CheckIndex
-
Create a new CheckIndex on the directory.
- CheckIndex(Directory, Lock) - Constructor for class org.apache.lucene.index.CheckIndex
-
Expert: create a directory with the specified lock.
- checkIndex() - Method in class org.apache.lucene.index.CheckIndex
-
- checkIndex(List<String>) - Method in class org.apache.lucene.index.CheckIndex
-
- checkIndex(int, int) - Static method in class org.apache.lucene.util.FutureObjects
-
Behaves like Java 9's Objects.checkIndex
- checkIndex(Directory) - Static method in class org.apache.lucene.util.TestUtil
-
This runs the CheckIndex tool on the index in.
- checkIndex(Directory, boolean) - Static method in class org.apache.lucene.util.TestUtil
-
- checkIndex(Directory, boolean, boolean, ByteArrayOutputStream) - Static method in class org.apache.lucene.util.TestUtil
-
If failFast is true, then throw the first exception when index corruption is hit, instead of moving on to other fields/segments to
look for any other corruption.
- CheckIndex.Options - Class in org.apache.lucene.index
-
Run-time configuration options for CheckIndex commands.
- CheckIndex.Status - Class in org.apache.lucene.index
-
- CheckIndex.Status.DocValuesStatus - Class in org.apache.lucene.index
-
Status from testing DocValues
- CheckIndex.Status.FieldInfoStatus - Class in org.apache.lucene.index
-
Status from testing field infos.
- CheckIndex.Status.FieldNormStatus - Class in org.apache.lucene.index
-
Status from testing field norms.
- CheckIndex.Status.IndexSortStatus - Class in org.apache.lucene.index
-
Status from testing index sort
- CheckIndex.Status.LiveDocStatus - Class in org.apache.lucene.index
-
Status from testing livedocs
- CheckIndex.Status.PointsStatus - Class in org.apache.lucene.index
-
Status from testing PointValues
- CheckIndex.Status.SegmentInfoStatus - Class in org.apache.lucene.index
-
Holds the status of each segment in the index.
- CheckIndex.Status.StoredFieldStatus - Class in org.apache.lucene.index
-
Status from testing stored fields.
- CheckIndex.Status.TermIndexStatus - Class in org.apache.lucene.index
-
Status from testing term index.
- CheckIndex.Status.TermVectorStatus - Class in org.apache.lucene.index
-
Status from testing stored fields.
- CheckIndex.VerifyPointsVisitor - Class in org.apache.lucene.index
-
Walks the entire N-dimensional points space, verifying that all points fall within the last cell's boundaries.
- checkIndexHeader(DataInput, String, int, int, byte[], String) - Static method in class org.apache.lucene.codecs.CodecUtil
-
- checkIndexHeaderID(DataInput, byte[]) - Static method in class org.apache.lucene.codecs.CodecUtil
-
Expert: just reads and verifies the object ID of an index header
- checkIndexHeaderSuffix(DataInput, String) - Static method in class org.apache.lucene.codecs.CodecUtil
-
Expert: just reads and verifies the suffix of an index header
- checkIndexTerm(BytesRef, TermStats) - Method in class org.apache.lucene.codecs.blockterms.TermsIndexWriterBase.FieldWriter
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.DocValuesProducer
-
Checks consistency of this producer
- checkIntegrity() - Method in class org.apache.lucene.codecs.FieldsProducer
-
Checks consistency of this reader.
- checkIntegrity() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.NormsProducer
-
Checks consistency of this producer
- checkIntegrity() - Method in class org.apache.lucene.codecs.PointsReader
-
Checks consistency of this reader.
- checkIntegrity() - Method in class org.apache.lucene.codecs.PostingsReaderBase
-
Checks consistency of this reader.
- checkIntegrity() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsProducer
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsReader
-
- checkIntegrity() - Method in class org.apache.lucene.codecs.StoredFieldsReader
-
Checks consistency of this reader.
- checkIntegrity() - Method in class org.apache.lucene.codecs.TermVectorsReader
-
Checks consistency of this reader.
- checkIntegrity() - Method in class org.apache.lucene.index.CodecReader
-
- checkIntegrity() - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
- checkIntegrity() - Method in class org.apache.lucene.index.FilterCodecReader
-
- checkIntegrity() - Method in class org.apache.lucene.index.FilterLeafReader
-
- checkIntegrity() - Method in class org.apache.lucene.index.LeafReader
-
Checks consistency of this reader.
- checkIntegrity() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- checkIntegrity() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- checkIterator(Iterator<T>, long, boolean) - Static method in class org.apache.lucene.util.TestUtil
-
Checks that the provided iterator is well-formed.
- checkIterator(Iterator<T>) - Static method in class org.apache.lucene.util.TestUtil
-
Checks that the provided iterator is well-formed.
- CheckJoinIndex - Class in org.apache.lucene.search.join
-
Utility class to check a block join index.
- checkLatitude(double) - Static method in class org.apache.lucene.geo.GeoUtils
-
validates latitude value is within standard +/-90 coordinate bounds
- checkLongitude(double) - Static method in class org.apache.lucene.geo.GeoUtils
-
validates longitude value is within standard +/-180 coordinate bounds
- checkMatches(Query, IndexSearcher) - Static method in class org.apache.lucene.search.CheckHits
-
- checkMax() - Method in class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- checkMaxClauseCount(int) - Method in class org.apache.lucene.search.ScoringRewrite
-
This method is called after every new term to check if the number of max clauses
(e.g.
- checkNoBottomLatitudeBound() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Check if there's no bottom latitude bound.
- checkNoLongitudeBound() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Check if there's no longitude bound.
- checkNoMatchExplanations(Query, String, IndexSearcher, int[]) - Static method in class org.apache.lucene.search.CheckHits
-
Tests that all documents up to maxDoc which are *not* in the
expected result set, have an explanation which indicates that
the document does not match
- checkNoTopLatitudeBound() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Check if there's no top latitude bound.
- checkOneTerm(Analyzer, String, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- checkPendingFlushOnUpdate - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
if an indexing thread should check for pending flushes on update in order to help out on a full flush
- checkPosition(int) - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
-
Checks to see if this term is valid at position
.
- checkRandomData(Random, Analyzer, int) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
utility method for blasting tokenstreams with data to make sure they don't do anything crazy
- checkRandomData(Random, Analyzer, int, int) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
utility method for blasting tokenstreams with data to make sure they don't do anything crazy
- checkRandomData(Random, Analyzer, int, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
utility method for blasting tokenstreams with data to make sure they don't do anything crazy
- checkRandomData(Random, Analyzer, int, int, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- checkRandomData(Random, Analyzer, int, int, boolean, boolean) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- checkReader(IndexReader) - Static method in class org.apache.lucene.util.TestUtil
-
This runs the CheckIndex tool on the Reader.
- checkReader(LeafReader, boolean) - Static method in class org.apache.lucene.util.TestUtil
-
- checkReadOnly(Collection<T>) - Static method in class org.apache.lucene.util.TestUtil
-
Checks that the provided collection is read-only.
- checkReuse(TermsEnum, int, int, boolean) - Static method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- checkServiceName(String) - Static method in class org.apache.lucene.util.NamedSPILoader
-
- checkSkipTo(Query, IndexSearcher) - Static method in class org.apache.lucene.search.QueryUtils
-
alternate scorer advance(),advance(),next(),next(),advance(),advance(), etc
and ensure a hitcollector receives same docs and scores
- checksum - Variable in class org.apache.lucene.replicator.nrt.FileMetaData
-
- checksumEntireFile(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
-
- ChecksumIndexInput - Class in org.apache.lucene.store
-
Extension of IndexInput, computing checksum as it goes.
- ChecksumIndexInput(String) - Constructor for class org.apache.lucene.store.ChecksumIndexInput
-
resourceDescription should be a non-null, opaque string
describing this resource; it's returned from
IndexInput.toString()
.
- checkUnequal(Query, Query) - Static method in class org.apache.lucene.search.QueryUtils
-
- checkUnpositioned(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
-
Assert that the current doc is -1.
- checkVersion(int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Check the validity of a version number.
- child - Variable in class org.apache.lucene.search.Scorer.ChildScorer
-
Child Scorer.
- childCount - Variable in class org.apache.lucene.facet.FacetResult
-
How many child labels were encountered.
- childCounts - Variable in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets.FacetParentVal
-
The detail level counts.
- childCountsLen - Variable in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets.FacetParentVal
-
- children() - Method in class org.apache.lucene.facet.taxonomy.ParallelTaxonomyArrays
-
Returns the children array, where children[i]
denotes a child of
category ordinal i
.
- children() - Method in class org.apache.lucene.index.CompositeReaderContext
-
- children() - Method in class org.apache.lucene.index.IndexReaderContext
-
Returns the context's children iff this context is a composite context
otherwise null
.
- children() - Method in class org.apache.lucene.index.LeafReaderContext
-
- childrenLoaded() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
Returns true if the (costly, and lazily initialized) children int[] was initialized.
- ChildScorer(Scorer, String) - Constructor for class org.apache.lucene.search.Scorer.ChildScorer
-
Creates a new ChildScorer node with the specified relationship.
- CHINESE_WORD - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
Chinese Word
- circle(double, double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- circle(Point, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- CITATION - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- CITATION_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- CJ - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- CJ_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- CJKAnalyzer - Class in org.apache.lucene.analysis.cjk
-
- CJKAnalyzer() - Constructor for class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
- CJKAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
Builds an analyzer with the given stop words
- CJKBigramFilter - Class in org.apache.lucene.analysis.cjk
-
Forms bigrams of CJK terms that are generated from StandardTokenizer
or ICUTokenizer.
- CJKBigramFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
- CJKBigramFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
- CJKBigramFilter(TokenStream, int, boolean) - Constructor for class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
Create a new CJKBigramFilter, specifying which writing systems should be bigrammed,
and whether or not unigrams should also be output.
- CJKBigramFilterFactory - Class in org.apache.lucene.analysis.cjk
-
- CJKBigramFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.cjk.CJKBigramFilterFactory
-
Creates a new CJKBigramFilterFactory
- CJKWidthFilter - Class in org.apache.lucene.analysis.cjk
-
A
TokenFilter
that normalizes CJK width differences:
Folds fullwidth ASCII variants into the equivalent basic latin
Folds halfwidth Katakana variants into the equivalent kana
- CJKWidthFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cjk.CJKWidthFilter
-
- CJKWidthFilterFactory - Class in org.apache.lucene.analysis.cjk
-
- CJKWidthFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.cjk.CJKWidthFilterFactory
-
Creates a new CJKWidthFilterFactory
- CLASS_COUNT - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- CLASS_COUNT - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- classFieldName - Variable in class org.apache.lucene.classification.KNearestNeighborClassifier
-
the name of the field used as the output text
- classFieldName - Variable in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
name of the field to be used as a class / category output
- classHash() - Method in class org.apache.lucene.search.Query
-
Provides a constant integer for a given class, derived from the name of the class.
- ClassicAnalyzer - Class in org.apache.lucene.analysis.standard
-
- ClassicAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
Builds an analyzer with the given stop words.
- ClassicAnalyzer() - Constructor for class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
- ClassicAnalyzer(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
-
- ClassicFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.standard.ClassicFilter
-
Construct filtering in.
- ClassicFilterFactory - Class in org.apache.lucene.analysis.standard
-
- ClassicFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.standard.ClassicFilterFactory
-
Creates a new ClassicFilterFactory
- ClassicSimilarity - Class in org.apache.lucene.search.similarities
-
Expert: Historical scoring implementation.
- ClassicSimilarity() - Constructor for class org.apache.lucene.search.similarities.ClassicSimilarity
-
Sole constructor: parameter-free
- ClassicTokenizer - Class in org.apache.lucene.analysis.standard
-
A grammar-based tokenizer constructed with JFlex
- ClassicTokenizer() - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- ClassicTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- ClassicTokenizerFactory - Class in org.apache.lucene.analysis.standard
-
- ClassicTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.standard.ClassicTokenizerFactory
-
Creates a new ClassicTokenizerFactory
- ClassificationResult<T> - Class in org.apache.lucene.classification
-
- ClassificationResult(T, double) - Constructor for class org.apache.lucene.classification.ClassificationResult
-
Constructor
- Classifier<T> - Interface in org.apache.lucene.classification
-
A classifier, see http://en.wikipedia.org/wiki/Classifier_(mathematics)
, which assign classes of type
T
- classifyFromTopDocs(TopDocs) - Method in class org.apache.lucene.classification.KNearestNeighborClassifier
-
TODO
- classmap - Variable in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
This map stores the character classes
- ClasspathResourceLoader - Class in org.apache.lucene.analysis.util
-
Simple
ResourceLoader
that uses
ClassLoader.getResourceAsStream(String)
and
Class.forName(String,boolean,ClassLoader)
to open resources and
classes, respectively.
- ClasspathResourceLoader() - Constructor for class org.apache.lucene.analysis.util.ClasspathResourceLoader
-
- ClasspathResourceLoader(ClassLoader) - Constructor for class org.apache.lucene.analysis.util.ClasspathResourceLoader
-
Creates an instance using the given classloader to load Resources and classes.
- ClasspathResourceLoader(Class<?>) - Constructor for class org.apache.lucene.analysis.util.ClasspathResourceLoader
-
Creates an instance using the context classloader to load Resources and classes
Resources are resolved relative to the given class, if path is not absolute.
- classRules - Static variable in class org.apache.lucene.util.LuceneTestCase
-
This controls how suite-level rules are nested.
- Clause(String) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
- Clause(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- clauses() - Method in class org.apache.lucene.search.BooleanQuery
-
- clauses - Variable in class org.apache.lucene.search.spans.SpanNearQuery
-
- clean - Variable in class org.apache.lucene.index.CheckIndex.Status
-
True if no problems were found with the index.
- cleanupFilesOnFailure(Directory, List<String>) - Static method in class org.apache.lucene.replicator.IndexReplicationHandler
-
Cleanup the index directory by deleting all given files.
- cleanupOldIndexFiles(Directory, String, InfoStream) - Static method in class org.apache.lucene.replicator.IndexReplicationHandler
-
Cleans up the index directory from old index files.
- cleanupSession(String) - Method in class org.apache.lucene.replicator.PerSessionDirectoryFactory
-
- cleanupSession(String) - Method in interface org.apache.lucene.replicator.ReplicationClient.SourceDirectoryFactory
-
Called to denote that the replication actions for this session were finished and the directory is no longer needed.
- clear() - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
-
- 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.compound.hyphenation.CharVector
-
Reset Vector but don't resize or clear elements
- clear() - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.ko.tokenattributes.ReadingAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
- clear() - Method in interface org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttribute
-
Clear to default value.
- clear() - Method in class org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.Token
-
Resets the term text, payload, flags, positionIncrement, positionLength,
startOffset, endOffset and token type to default.
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Resets the attributes
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
-
- clear() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-
- clear() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- clear() - Method in class org.apache.lucene.document.Document
-
Removes all the fields from document.
- clear() - Method in class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
- clear() - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
Clears the content of the cache.
- clear() - Method in class org.apache.lucene.facet.taxonomy.writercache.UTF8TaxonomyWriterCache
-
- clear() - Method in class org.apache.lucene.index.SegmentInfos
-
- clear() - Method in class org.apache.lucene.index.TermContext
-
- clear() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- clear() - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- clear() - Method in class org.apache.lucene.search.BoostAttributeImpl
-
- clear() - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-
- clear() - Method in class org.apache.lucene.search.LRUQueryCache
-
Clear the content of this cache.
- clear() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- clear() - Method in class org.apache.lucene.util.AttributeImpl
-
Clears the values in this AttributeImpl and resets it to its
default value.
- clear(int) - Method in class org.apache.lucene.util.BitSet
-
Clear the bit at i
.
- clear(int, int) - Method in class org.apache.lucene.util.BitSet
-
Clears a range of bits.
- clear() - Method in class org.apache.lucene.util.BytesRefArray
-
- clear() - Method in class org.apache.lucene.util.BytesRefBuilder
-
Reset this builder to the empty state.
- clear() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
- clear(boolean) - Method in class org.apache.lucene.util.BytesRefHash
-
- clear() - Method in class org.apache.lucene.util.BytesRefHash
-
- clear() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-
- clear() - Method in class org.apache.lucene.util.CharsRefBuilder
-
Reset this builder to the empty state.
- clear(int) - Method in class org.apache.lucene.util.FixedBitSet
-
- clear(int, int) - Method in class org.apache.lucene.util.FixedBitSet
-
- clear() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- clear() - Method in class org.apache.lucene.util.IntsRefBuilder
-
Empty this builder.
- clear(long) - Method in class org.apache.lucene.util.LongBitSet
-
- clear(long, long) - Method in class org.apache.lucene.util.LongBitSet
-
Clears a range of bits.
- clear() - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- clear() - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
-
Sets all values to 0.
- clear() - Method in class org.apache.lucene.util.PriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in class org.apache.lucene.util.SentinelIntSet
-
- clear(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
-
Clear the bit at index i.
- clear(int, int) - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- clear() - Method in class org.apache.lucene.util.WeakIdentityMap
-
Removes all of the mappings from this map.
- clearAttributes() - Method in class org.apache.lucene.util.AttributeSource
-
Resets all Attributes in this AttributeSource by calling
AttributeImpl.clear()
on each Attribute implementation.
- clearCoreCacheKey(Object) - Method in class org.apache.lucene.search.LRUQueryCache
-
Remove all cache entries for the given core cache key.
- clearCrash() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- clearCreatedFiles() - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-
- clearData() - Method in class org.apache.lucene.benchmark.byTask.stats.Points
-
Clear all data, prepare for more tests.
- clearDoFail() - Method in class org.apache.lucene.store.MockDirectoryWrapper.Failure
-
- clearFieldsAfter(Calendar, int) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Calendar utility method:
Calls Calendar.clear(int)
for every field after field
.
- clearIndex() - Method in class org.apache.lucene.search.spell.SpellChecker
-
Removes all terms from the spell check index.
- clearQuery(Query) - Method in class org.apache.lucene.search.LRUQueryCache
-
Remove all cache entries for the given query.
- ClearStatsTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Clear statistics data.
- ClearStatsTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ClearStatsTask
-
- clnName - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
-
- clone() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- clone() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- clone() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
- clone() - Method in class org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttributeImpl
-
- clone() - Method in class org.apache.lucene.analysis.Token
-
- clone() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
-
- clone() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- clone() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
- clone() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
- clone() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- clone() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- clone() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- clone() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- clone() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexReader
-
- clone() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
- clone() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
- clone() - Method in class org.apache.lucene.codecs.compressing.Decompressor
-
- clone() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsReader
-
- clone() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsReader
-
- clone() - Method in class org.apache.lucene.codecs.StoredFieldsReader
-
- clone() - Method in class org.apache.lucene.codecs.TermVectorsReader
-
Create a clone that one caller at a time may use to
read term vectors.
- clone() - Method in class org.apache.lucene.facet.DrillDownQuery
-
- clone() - Method in class org.apache.lucene.facet.taxonomy.LRUHashMap
-
- clone() - Method in class org.apache.lucene.index.NoMergeScheduler
-
- clone() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
- clone() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns a copy of this instance, also copying each
SegmentInfo.
- clone() - Method in class org.apache.lucene.index.TermState
-
- clone() - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
- clone() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode.QueryText
-
- clone() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- clone() - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- clone() - Method in class org.apache.lucene.search.spans.AssertingSpanQuery
-
- clone() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- clone() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- clone() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
A deep clone.
- clone() - Method in interface org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.UnitNRShape
-
Deep clone
- clone() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- clone() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- clone() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- clone() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- clone() - Method in class org.apache.lucene.store.DataInput
-
Returns a clone of this stream.
- clone() - Method in class org.apache.lucene.store.IndexInput
-
Returns a clone of this stream.
- clone() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- clone() - Method in class org.apache.lucene.util.AttributeImpl
-
In most cases the clone is, and should be, deep in order to be able to
properly capture the state of all attributes.
- clone() - Method in class org.apache.lucene.util.AttributeSource.State
-
- clone() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
Clone, but you are not allowed to pop up past the point where the clone happened.
- clone() - Method in class org.apache.lucene.util.BytesRef
-
Returns a shallow clone of this instance (the underlying bytes are
not copied and will be shared by both the returned object and this
object.
- clone() - Method in class org.apache.lucene.util.CharsRef
-
Returns a shallow clone of this instance (the underlying characters are
not copied and will be shared by both the returned object and this
object.
- clone() - Method in class org.apache.lucene.util.FixedBitSet
-
- clone() - Method in class org.apache.lucene.util.IntsRef
-
Returns a shallow clone of this instance (the underlying ints are
not copied and will be shared by both the returned object and this
object.
- clone() - Method in class org.apache.lucene.util.LongBitSet
-
- clone() - Method in class org.apache.lucene.util.LongsRef
-
Returns a shallow clone of this instance (the underlying longs are
not copied and will be shared by both the returned object and this
object.
- clone() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-
- cloneAttributes() - Method in class org.apache.lucene.util.AttributeSource
-
Performs a clone of all
AttributeImpl
instances returned in a new
AttributeSource
instance.
- cloneDocument(Document) - Static method in class org.apache.lucene.util.TestUtil
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BooleanQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BoostQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.DeletedQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.GroupQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.MatchAllDocsQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.NoTokenFoundQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.OpaqueQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- cloneTree() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
Recursive clone the QueryNode tree The tags are not copied to the new tree
when you call the cloneTree() method
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QuotedFieldQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.TokenizedPhraseQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.MultiPhraseQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PrefixWildcardQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- cloneTree() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.WildcardQueryNode
-
- close() - Method in class org.apache.lucene.analysis.Analyzer
-
Frees persistent resources used by this Analyzer
- close() - Method in class org.apache.lucene.analysis.CharFilter
-
Closes the underlying input stream.
- close() - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
-
- close() - Method in class org.apache.lucene.analysis.CrankyTokenFilter
-
- close() - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
- close() - Method in class org.apache.lucene.analysis.ko.KoreanTokenizer
-
- close() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
- close() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenatingTokenStream
-
- close() - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilter
-
- close() - Method in class org.apache.lucene.analysis.MockGraphTokenFilter
-
- close() - Method in class org.apache.lucene.analysis.MockReaderWrapper
-
- close() - Method in class org.apache.lucene.analysis.MockTokenizer
-
- close() - Method in class org.apache.lucene.analysis.pattern.PatternTokenizer
-
- close() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- close() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
-
- close() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
- close() - Method in class org.apache.lucene.analysis.TokenFilter
-
Releases resources associated with this stream.
- close() - Method in class org.apache.lucene.analysis.Tokenizer
-
Releases resources associated with this stream.
- close() - Method in class org.apache.lucene.analysis.TokenStream
-
Releases resources associated with this stream.
- close() - Method in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Called when reading from this content source is no longer required.
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.EnwikiContentSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishContentSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.RandomFacetSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.ReutersContentSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.SingleDocSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- close() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- close() - Method in class org.apache.lucene.benchmark.byTask.tasks.NearRealtimeReaderTask
-
- close() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- close() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- close() - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteEnwikiLineDocTask
-
- close() - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
- close() - Method in class org.apache.lucene.benchmark.byTask.utils.Algorithm
-
- close() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- close() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsWriter
-
- close() - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexReader
-
- close() - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexWriter
-
- close() - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase
-
- close() - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexReader
-
- close() - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter
-
- close() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- close() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
-
- close() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- close() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsWriter
-
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexWriter
-
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
- close() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- close() - Method in class org.apache.lucene.codecs.FieldsConsumer
-
- close() - Method in class org.apache.lucene.codecs.FieldsProducer
-
- close() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- close() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsWriter
-
- close() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- close() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- close() - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsReader
-
- close() - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsWriter
-
- close() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- close() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsWriter
-
- close() - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- close() - Method in class org.apache.lucene.codecs.memory.FSTTermsWriter
-
- close() - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
- close() - Method in class org.apache.lucene.codecs.PostingsReaderBase
-
- close() - Method in class org.apache.lucene.codecs.PostingsWriterBase
-
- close() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsConsumer
-
- close() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsProducer
-
- close() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsReader
-
- close() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsWriter
-
- close() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsReader
-
- close() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsWriter
-
- close() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
-
- close() - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
- close() - Method in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
- close() - Method in class org.apache.lucene.demo.facet.RangeFacetsExample
-
- close() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Frees used resources as well as closes the underlying
IndexWriter
,
which commits whatever changes made to it to the underlying
Directory
.
- close() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
- close() - Method in class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
- close() - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
Let go of whatever resources the cache is holding.
- close() - Method in class org.apache.lucene.facet.taxonomy.writercache.UTF8TaxonomyWriterCache
-
- close() - Method in class org.apache.lucene.index.CheckIndex
-
- close() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- close() - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
Closes this doc values producer.
- close() - Method in class org.apache.lucene.index.IndexReader
-
Closes files associated with this index.
- close() - Method in class org.apache.lucene.index.IndexWriter
-
Closes all open resources and releases the write lock.
- close() - Method in class org.apache.lucene.index.MergeScheduler
-
Close this MergeScheduler.
- close() - Method in class org.apache.lucene.index.NoMergeScheduler
-
- close() - Method in class org.apache.lucene.index.RandomIndexWriter
-
Close this writer.
- close() - Method in class org.apache.lucene.index.SerialMergeScheduler
-
- close() - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- close() - Method in class org.apache.lucene.mockfile.FilterDirectoryStream
-
- close() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- close() - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- close() - Method in class org.apache.lucene.mockfile.FilterOutputStream2
-
- close() - Method in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
- close() - Method in class org.apache.lucene.replicator.http.HttpClientBase
-
- close() - Method in class org.apache.lucene.replicator.IndexInputInputStream
-
- close() - Method in class org.apache.lucene.replicator.LocalReplicator
-
- close() - Method in class org.apache.lucene.replicator.nrt.CopyOneFile
-
- close() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
- close() - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- close() - Method in class org.apache.lucene.replicator.ReplicationClient
-
- close() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
-
- close() - Method in class org.apache.lucene.search.LiveFieldValues
-
- close() - Method in class org.apache.lucene.search.ReferenceManager
-
Closes this ReferenceManager to prevent future
acquiring
.
- close() - Method in class org.apache.lucene.search.SearcherLifetimeManager
-
- close() - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- close() - Method in class org.apache.lucene.search.spell.SpellChecker
-
Close the IndexSearcher used by this SpellChecker
- close() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- close() - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
-
Removes any written temporary files.
- close() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum
-
- close() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.MultiOffsetsEnum
-
- close() - Method in class org.apache.lucene.store.BaseDirectoryWrapper
-
- close() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- close() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- close() - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- close() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- close() - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
-
- close() - Method in class org.apache.lucene.store.CorruptingIndexOutput
-
- close() - Method in class org.apache.lucene.store.Directory
-
Closes the directory.
- close() - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- close() - Method in class org.apache.lucene.store.FilterDirectory
-
- close() - Method in class org.apache.lucene.store.FSDirectory
-
- close() - Method in class org.apache.lucene.store.IndexInput
-
Closes the stream to further operations.
- close() - Method in class org.apache.lucene.store.IndexOutput
-
Closes this stream to further operations.
- close() - Method in class org.apache.lucene.store.InputStreamDataInput
-
- close() - Method in class org.apache.lucene.store.Lock
-
Releases exclusive access.
- close() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- close() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- close() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
-
- close() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
Close this directory, which flushes any cached files
to the delegate and then closes the delegate.
- close() - Method in class org.apache.lucene.store.OutputStreamDataOutput
-
- close() - Method in class org.apache.lucene.store.OutputStreamIndexOutput
-
- close() - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
Closes the store to future operations, releasing associated memory.
- close() - Method in class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- close() - Method in class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
- close() - Method in class org.apache.lucene.store.RateLimitedIndexOutput
-
- close() - Method in class org.apache.lucene.util.bkd.BKDWriter
-
- close() - Method in class org.apache.lucene.util.bkd.HeapPointReader
-
- close() - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- close() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
-
- close() - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- close() - Method in class org.apache.lucene.util.BytesRefHash
-
Closes the BytesRefHash and releases all internally used memory
- close() - Method in class org.apache.lucene.util.CloseableThreadLocal
-
- close() - Method in class org.apache.lucene.util.FailOnNonBulkMergesInfoStream
-
- close(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
-
Closes all given Closeables.
- close(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
-
Closes all given Closeables.
- close() - Method in class org.apache.lucene.util.LineFileDocs
-
- close() - Method in class org.apache.lucene.util.NullInfoStream
-
- close() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
-
- close() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
-
- close() - Method in class org.apache.lucene.util.PrintStreamInfoStream
-
- close() - Method in class org.apache.lucene.util.ThrottledIndexOutput
-
- 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
-
- closeAfterSuite(T) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Registers a Closeable
resource that should be closed after the suite
completes.
- closeAfterTest(T) - Method in class org.apache.lucene.util.LuceneTestCase
-
Registers a Closeable
resource that should be closed after the test
completes.
- CloseIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Close index writer.
- CloseIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseIndexTask
-
- CloseReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Close index reader.
- CloseReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseReaderTask
-
- closeResources() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
A hook for extending classes to close additional resources that were used.
- CloseTaxonomyIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Close taxonomy index.
- CloseTaxonomyIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseTaxonomyIndexTask
-
- CloseTaxonomyReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Close taxonomy reader.
- CloseTaxonomyReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CloseTaxonomyReaderTask
-
- closeWhileHandlingException(Closeable...) - Static method in class org.apache.lucene.util.IOUtils
-
Closes all given Closeables, suppressing all thrown exceptions.
- closeWhileHandlingException(Iterable<? extends Closeable>) - Static method in class org.apache.lucene.util.IOUtils
-
Closes all given Closeables, suppressing all thrown non VirtualMachineError
exceptions.
- code() - Method in enum org.apache.lucene.analysis.ko.POS.Tag
-
Returns the code associated with the tag (as defined in pos-id.def).
- Codec - Class in org.apache.lucene.codecs
-
Encodes/decodes an inverted index segment.
- Codec(String) - Constructor for class org.apache.lucene.codecs.Codec
-
Creates a new codec.
- codec - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Codec used to read this segment.
- codec - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
Codec
used to write new segments.
- CODEC_FILE_PATTERN - Static variable in class org.apache.lucene.index.IndexFileNames
-
All files created by codecs much match this pattern (checked in
SegmentInfo).
- CODEC_MAGIC - Static variable in class org.apache.lucene.codecs.CodecUtil
-
Constant to identify the start of a codec header.
- CODEC_NAME - Static variable in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Codec name used in the header for the saved model.
- CODEC_NAME - Static variable in class org.apache.lucene.util.bkd.BKDWriter
-
- CODEC_NAME - Static variable in class org.apache.lucene.util.packed.PackedInts
-
- codecAcceptsHugeBinaryValues(String) - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- CodecReader - Class in org.apache.lucene.index
-
LeafReader implemented by codec APIs.
- CodecReader() - Constructor for class org.apache.lucene.index.CodecReader
-
Sole constructor.
- codecSupportsSparsity() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
Whether the codec supports sparse values.
- CodecUtil - Class in org.apache.lucene.codecs
-
Utility class for reading and writing versioned headers.
- codePointCount(BytesRef) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Returns the number of code points in this UTF8 sequence.
- CodepointCountFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Removes words that are too long or too short from the stream.
- CodepointCountFilter(TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.CodepointCountFilter
-
- CodepointCountFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- CodepointCountFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.CodepointCountFilterFactory
-
Creates a new CodepointCountFilterFactory
- collate(Collator, String, String) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Compares two strings with a collator, also looking to see if the the strings
are impacted by jdk bugs.
- CollatedTermAttributeImpl - Class in org.apache.lucene.collation.tokenattributes
-
Extension of
CharTermAttributeImpl
that encodes the term
text as a binary Unicode collation key instead of as UTF-8 bytes.
- CollatedTermAttributeImpl(Collator) - Constructor for class org.apache.lucene.collation.tokenattributes.CollatedTermAttributeImpl
-
Create a new CollatedTermAttributeImpl
- CollationAttributeFactory - Class in org.apache.lucene.collation
-
Converts each token into its CollationKey
, and then
encodes the bytes as an index term.
- CollationAttributeFactory(Collator) - Constructor for class org.apache.lucene.collation.CollationAttributeFactory
-
- CollationAttributeFactory(AttributeFactory, Collator) - Constructor for class org.apache.lucene.collation.CollationAttributeFactory
-
Create a CollationAttributeFactory, using the supplied Attribute Factory
as the factory for all other attributes.
- CollationDocValuesField - Class in org.apache.lucene.collation
-
- CollationDocValuesField(String, Collator) - Constructor for class org.apache.lucene.collation.CollationDocValuesField
-
Create a new ICUCollationDocValuesField.
- CollationKeyAnalyzer - Class in org.apache.lucene.collation
-
- CollationKeyAnalyzer(Collator) - Constructor for class org.apache.lucene.collation.CollationKeyAnalyzer
-
Create a new CollationKeyAnalyzer, using the specified collator.
- CollationTestBase - Class in org.apache.lucene.analysis
-
Base test class for testing Unicode collation.
- CollationTestBase() - Constructor for class org.apache.lucene.analysis.CollationTestBase
-
- collect(int) - Method in class org.apache.lucene.facet.FacetsCollector
-
- collect(int) - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
-
- collect(int) - Method in class org.apache.lucene.search.CheckHits.MatchesAsserter
-
- collect(int) - Method in class org.apache.lucene.search.CheckHits.SetCollector
-
- collect(int) - Method in class org.apache.lucene.search.FilterLeafCollector
-
- collect(int) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- collect(int) - Method in class org.apache.lucene.search.grouping.AllGroupsCollector
-
- collect(int) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
-
- collect(int) - Method in class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
- collect(T, int) - Method in class org.apache.lucene.search.grouping.GroupReducer
-
Collect a given document into a given group
- collect(int) - Method in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- collect(int) - Method in interface org.apache.lucene.search.LeafCollector
-
Called once for every document matching a query, with the unbased document
number.
- collect(int) - Method in class org.apache.lucene.search.MultiCollectorManager.Collectors.LeafCollectors
-
- collect(int) - Method in class org.apache.lucene.search.SimpleCollector
-
- collect(SpanCollector) - Method in class org.apache.lucene.search.spans.FilterSpans
-
- collect(SpanCollector) - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-
- collect(SpanCollector) - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-
- collect(SpanCollector) - Method in class org.apache.lucene.search.spans.Spans
-
Collect postings data from the leaves of the current Spans.
- collect(SpanCollector) - Method in class org.apache.lucene.search.spans.TermSpans
-
- collect(int, CharSequence, CharSequence, float) - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
- collect(int) - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
Ignored
- collect(int) - Method in class org.apache.lucene.search.TotalHitCountCollector
-
- collectDocs(BitSet) - Method in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- collectDocs(DocIdSetBuilder) - Method in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- CollectedSearchGroup<T> - Class in org.apache.lucene.search.grouping
-
- CollectedSearchGroup() - Constructor for class org.apache.lucene.search.grouping.CollectedSearchGroup
-
- collectFiles(Path, ArrayList<Path>) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
A convenience method for collecting all the files of a content source from
a given directory.
- collectionModel - Variable in class org.apache.lucene.search.similarities.LMSimilarity
-
The collection model.
- CollectionStatistics - Class in org.apache.lucene.search
-
Contains statistics for a collection (field)
- CollectionStatistics(String, long, long, long, long) - Constructor for class org.apache.lucene.search.CollectionStatistics
-
- collectionStatistics(String) - Method in class org.apache.lucene.search.IndexSearcher
-
- collectionStatistics(String) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- CollectionTerminatedException - Exception in org.apache.lucene.search
-
- CollectionTerminatedException() - Constructor for exception org.apache.lucene.search.CollectionTerminatedException
-
Sole constructor.
- CollectionUtil - Class in org.apache.lucene.util
-
Methods for manipulating (sorting) collections.
- collectLeaf(PostingsEnum, int, Term) - Method in class org.apache.lucene.payloads.PayloadSpanCollector
-
- collectLeaf(PostingsEnum, int, Term) - Method in interface org.apache.lucene.search.spans.SpanCollector
-
Collect information from postings
- Collector - Interface in org.apache.lucene.search
-
Expert: Collectors are primarily meant to be used to
gather raw results from a search, and implement sorting
or custom result filtering, collation, etc.
- CollectorManager<C extends Collector,T> - Interface in org.apache.lucene.search
-
A manager of collectors.
- collectorResult - Variable in class org.apache.lucene.facet.DrillSideways.ConcurrentDrillSidewaysResult
-
The merged search results
- collectSpanQueryFields(SpanQuery, Set<String>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- collectTermContext(IndexReader, List<LeafReaderContext>, TermContext[], Term[]) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- COLON - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- COLON - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- COLORED_POST_TAGS - Static variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- COLORED_PRE_TAGS - Static variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- COLS - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- columns - Variable in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter.Heatmap
-
- combine(float, boolean, float) - Method in class org.apache.lucene.search.QueryRescorer
-
Implement this in a subclass to combine the first pass and
second pass scores.
- combineCJ() - Method in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
- combineCJ() - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizerConfig
-
true if Han, Hiragana, and Katakana scripts should all be returned as Japanese
- CombineSuggestion - Class in org.apache.lucene.search.spell
-
A suggestion generated by combining one or more original query terms
- CombineSuggestion(SuggestWord, int[]) - Constructor for class org.apache.lucene.search.spell.CombineSuggestion
-
Creates a new CombineSuggestion from a suggestion
and
an array of term ids (referencing the indexes to the original terms that
form this combined suggestion)
- COMMA - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
-
- COMMA - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- CommandLineUtil - Class in org.apache.lucene.util
-
Class containing some useful methods used by command line tools
- commit() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- commit() - Method in class org.apache.lucene.index.IndexWriter
-
Commits all pending changes (added and deleted
documents, segment merges, added
indexes, etc.) to the index, and syncs all referenced
index files, such that a reader will see the changes
and the index updates will survive an OS or machine
crash or power loss.
- commit - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- commit() - Method in class org.apache.lucene.index.RandomIndexWriter
-
- commit(Directory) - Method in class org.apache.lucene.index.SegmentInfos
-
Writes and syncs to the Directory dir, taking care to
remove the segments file on exception
- commit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
-
The second phase of a 2-phase commit.
- commit() - Method in class org.apache.lucene.replicator.nrt.Node
-
- commit() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
- commit() - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- commit() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Commits all pending changes made to this suggester to disk.
- CommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.CommitFailException
-
Sole constructor.
- CommitIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Commits the IndexWriter.
- CommitIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CommitIndexTask
-
- commitOnClose - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- CommitTaxonomyIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Commits the Taxonomy Index.
- CommitTaxonomyIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CommitTaxonomyIndexTask
-
- common(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- common(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- common(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- common(Object, Object) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- common(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
-
- common(T, T) - Method in class org.apache.lucene.util.fst.Outputs
-
Eg common("foobar", "food") -> "foo"
- common(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
-
- common(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-
- common(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
-
- COMMON_DELIMITER - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
- CommonGramsFilter - Class in org.apache.lucene.analysis.commongrams
-
Construct bigrams for frequently occurring terms while indexing.
- CommonGramsFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.commongrams.CommonGramsFilter
-
Construct a token stream filtering the given input using a Set of common
words to create bigrams.
- CommonGramsFilterFactory - Class in org.apache.lucene.analysis.commongrams
-
- CommonGramsFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.commongrams.CommonGramsFilterFactory
-
Creates a new CommonGramsFilterFactory
- CommonGramsQueryFilter - Class in org.apache.lucene.analysis.commongrams
-
Wrap a CommonGramsFilter optimizing phrase queries by only returning single
words when they are not a member of a bigram.
- CommonGramsQueryFilter(CommonGramsFilter) - Constructor for class org.apache.lucene.analysis.commongrams.CommonGramsQueryFilter
-
Constructs a new CommonGramsQueryFilter based on the provided CommomGramsFilter
- CommonGramsQueryFilterFactory - Class in org.apache.lucene.analysis.commongrams
-
- CommonGramsQueryFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.commongrams.CommonGramsQueryFilterFactory
-
Creates a new CommonGramsQueryFilterFactory
- CommonQueryParserConfiguration - Interface in org.apache.lucene.queryparser.flexible.standard
-
Configuration options common across queryparser implementations.
- commonSuffixRef - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-
Shared common suffix accepted by the automaton.
- CommonTermsQuery - Class in org.apache.lucene.queries
-
A query that executes high-frequency terms in a optional sub-query to prevent
slow queries due to "common" terms like stopwords.
- CommonTermsQuery(BooleanClause.Occur, BooleanClause.Occur, float) - Constructor for class org.apache.lucene.queries.CommonTermsQuery
-
- compact() - Method in class org.apache.lucene.util.BytesRefHash
-
Returns the ids array in arbitrary order.
- COMPACT - Static variable in class org.apache.lucene.util.packed.PackedInts
-
No memory overhead at all, but the returned implementation may be slow.
- COMPANY - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- COMPANY_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- comparators - Variable in class org.apache.lucene.search.FieldValueHitQueue
-
- compare(byte[], byte[]) - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
-
- compare(byte[], byte[]) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
-
Called for non-leaf cells to test how the cell relates to the query, to
determine how to further recurse down the tree.
- compare(TermStats, TermStats) - Method in class org.apache.lucene.misc.HighFreqTerms.DocFreqComparator
-
- compare(TermStats, TermStats) - Method in class org.apache.lucene.misc.HighFreqTerms.TotalTermFreqComparator
-
- compare(int, FunctionValues, FunctionValues) - Method in class org.apache.lucene.queries.function.valuesource.ComparisonBoolFunction
-
Perform the comparison, returning true or false
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator
-
Compare hit at slot1 with hit at slot2.
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- compare(int, int) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector.GroupHead
-
Compares the specified document for a specified comparator against the current most relevant document.
- compare(SuggestWord, SuggestWord) - Method in class org.apache.lucene.search.spell.SuggestWordFrequencyComparator
-
- compare(SuggestWord, SuggestWord) - Method in class org.apache.lucene.search.spell.SuggestWordScoreComparator
-
- compare(FieldFragList.WeightedFragInfo, FieldFragList.WeightedFragInfo) - Method in class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder.ScoreComparator
-
- compare(byte[], int, int, byte[], int, int) - Static method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- compare(BytesRef, BytesRef) - Method in class org.apache.lucene.util.BytesRefComparator
-
- compare(char[], int, int, char[], int, int) - Static method in class org.apache.lucene.util.FutureArrays
-
Behaves like Java 9's Arrays.compare
- compare(int[], int, int, int[], int, int) - Static method in class org.apache.lucene.util.FutureArrays
-
Behaves like Java 9's Arrays.compare
- compare(long[], int, int, long[], int, int) - Static method in class org.apache.lucene.util.FutureArrays
-
Behaves like Java 9's Arrays.compare
- compare(int, int) - Method in class org.apache.lucene.util.IntroSelector
-
Compare entries found in slots i
and j
.
- compare(int, int) - Method in class org.apache.lucene.util.IntroSorter
-
- compare(int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
-
- compare(int, int) - Method in class org.apache.lucene.util.Sorter
-
Compare entries found in slots i
and j
.
- compare(int, byte[], int, byte[], int) - Static method in class org.apache.lucene.util.StringHelper
-
- compareArray(char[], int, char[], int) - Static method in class org.apache.lucene.analysis.cn.smart.Utility
-
compare two arrays starting at the specified offsets.
- compareArrayByPrefix(char[], int, char[], int) - Static method in class org.apache.lucene.analysis.cn.smart.Utility
-
Compare two arrays, starting at the specified offsets, but treating shortArray as a prefix to longArray.
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- compareBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- compareBottom(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
-
Compare the bottom of the queue with this doc.
- compareImplementationDistance(Class<? extends C>, VirtualMethod<C>, VirtualMethod<C>) - Static method in class org.apache.lucene.util.VirtualMethod
-
Utility method that compares the implementation/override distance of two methods.
- comparePivot(int) - Method in class org.apache.lucene.util.IntroSelector
-
Compare the pivot with the slot at
j
, similarly to
compare(i, j)
.
- comparePivot(int) - Method in class org.apache.lucene.util.IntroSorter
-
- comparePivot(int) - Method in class org.apache.lucene.util.Sorter
-
Compare the pivot with the slot at
j
, similarly to
compare(i, j)
.
- comparePrefix(NumberRangePrefixTree.UnitNRShape, NumberRangePrefixTree.UnitNRShape) - Static method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
Compares a to b, returning less than 0, 0, or greater than 0, if a is less than, equal to, or
greater than b, respectively, up to their common prefix (i.e.
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValue
-
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueBool
-
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueInt
-
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueLong
-
- compareSameType(Object) - Method in class org.apache.lucene.util.mutable.MutableValueStr
-
- compareSaved(int, int) - Method in class org.apache.lucene.util.TimSorter
-
Compare element
i
from the temporary storage with element
j
from the slice to sort, similarly to
Sorter.compare(int, int)
.
- compareTo(QualityQuery) - Method in class org.apache.lucene.benchmark.quality.QualityQuery
-
- compareTo(ClassificationResult<T>) - Method in class org.apache.lucene.classification.ClassificationResult
-
- compareTo(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.FacetLabel
-
Compares this path with another
FacetLabel
for lexicographic
order.
- compareTo(ConcurrentMergeScheduler.MergeThread) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
-
- compareTo(IndexCommit) - Method in class org.apache.lucene.index.IndexCommit
-
- compareTo(Term) - Method in class org.apache.lucene.index.Term
-
Compares two terms, returning a negative integer if this
term belongs before the argument, zero if this term is equal to the
argument, and a positive integer if this term belongs after the argument.
- compareTo(Path) - Method in class org.apache.lucene.mockfile.FilterPath
-
- compareTo(SimpleTerm) - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- compareTo(String) - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- compareTo(Revision) - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- compareTo(String) - Method in class org.apache.lucene.replicator.IndexRevision
-
- compareTo(Revision) - Method in class org.apache.lucene.replicator.IndexRevision
-
- compareTo(String) - Method in interface org.apache.lucene.replicator.Revision
-
Compares the revision to the given version string.
- compareTo(DirectSpellChecker.ScoreTerm) - Method in class org.apache.lucene.search.spell.DirectSpellChecker.ScoreTerm
-
- compareTo(TopSuggestDocs.SuggestScoreDoc) - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocs.SuggestScoreDoc
-
- compareTo(FSTCompletion.Completion) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion.Completion
-
- compareTo(Lookup.LookupResult) - Method in class org.apache.lucene.search.suggest.Lookup.LookupResult
-
Compare alphabetically.
- compareTo(OffsetsEnum) - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum
-
- compareTo(FieldPhraseList.WeightedPhraseInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- compareTo(FieldPhraseList.WeightedPhraseInfo.Toffs) - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
-
- compareTo(FieldTermStack.TermInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
- compareTo(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- 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(FSTTester.InputOutput<T>) - Method in class org.apache.lucene.util.fst.FSTTester.InputOutput
-
- compareTo(IntsRef) - Method in class org.apache.lucene.util.IntsRef
-
Signed int order comparison
- compareTo(LongsRef) - Method in class org.apache.lucene.util.LongsRef
-
Signed int order comparison
- compareTo(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValue
-
- compareToNoLeaf(Cell) - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Equivalent to this.getTokenBytesNoLeaf(null).compareTo(fromCell.getTokenBytesNoLeaf(null))
.
- compareToNoLeaf(Cell) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- compareToNoLeaf(Cell) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- compareToNoLeaf(Cell) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- compareTop(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- compareTop(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
-
Compare the top value with this doc.
- compareUnsigned(byte[], int, int, byte[], int, int) - Static method in class org.apache.lucene.util.FutureArrays
-
Behaves like Java 9's Arrays.compareUnsigned
- compareValues(T, T) - Method in class org.apache.lucene.search.FieldComparator
-
Returns a negative integer if first is less than second,
0 if they are equal and a positive integer otherwise.
- compareValues(Float, Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- compareValues(BytesRef, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- compareValues(BytesRef, BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- ComparisonBoolFunction - Class in org.apache.lucene.queries.function.valuesource
-
Base class for comparison operators useful within an "if"/conditional.
- ComparisonBoolFunction(ValueSource, ValueSource, String) - Constructor for class org.apache.lucene.queries.function.valuesource.ComparisonBoolFunction
-
- compIDXEnd - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- compile(String) - Static method in class org.apache.lucene.expressions.js.JavascriptCompiler
-
Compiles the given expression.
- compile(String, Map<String, Method>, ClassLoader) - Static method in class org.apache.lucene.expressions.js.JavascriptCompiler
-
Compiles the given expression with the supplied custom functions.
- Compile - Class in org.egothor.stemmer
-
The Compile class is used to compile a stemmer table.
- compiled - Variable in class org.apache.lucene.search.AutomatonQuery
-
- CompiledAutomaton - Class in org.apache.lucene.util.automaton
-
Immutable class holding compiled details for a given
Automaton.
- CompiledAutomaton(Automaton) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
-
Create this, passing simplify=true and finite=null, so that we try
to simplify the automaton and determine if it is finite.
- CompiledAutomaton(Automaton, Boolean, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
-
Create this.
- CompiledAutomaton(Automaton, Boolean, boolean, int, boolean) - Constructor for class org.apache.lucene.util.automaton.CompiledAutomaton
-
Create this.
- CompiledAutomaton.AUTOMATON_TYPE - Enum in org.apache.lucene.util.automaton
-
Automata are compiled into different internal forms for the
most efficient execution depending upon the language they accept.
- complement(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns a (deterministic) automaton that accepts the complement of the
language of the given automaton.
- COMPLEMENT - Static variable in class org.apache.lucene.util.automaton.RegExp
-
Syntax flag, enables complement (~).
- complete() - Method in class org.apache.lucene.util.automaton.DaciukMihovAutomatonBuilder
-
Finalize the automaton and return the root state.
- completedMergeFiles - Variable in class org.apache.lucene.replicator.nrt.CopyState
-
- Completion50PostingsFormat - Class in org.apache.lucene.search.suggest.document
-
- Completion50PostingsFormat() - Constructor for class org.apache.lucene.search.suggest.document.Completion50PostingsFormat
-
Sole Constructor
- CompletionAnalyzer - Class in org.apache.lucene.search.suggest.document
-
Wraps an
Analyzer
to provide additional completion-only tuning
(e.g.
- CompletionAnalyzer(Analyzer, boolean, boolean, int) - Constructor for class org.apache.lucene.search.suggest.document.CompletionAnalyzer
-
Wraps an analyzer to convert its output token stream to an automaton
- CompletionAnalyzer(Analyzer) - Constructor for class org.apache.lucene.search.suggest.document.CompletionAnalyzer
-
- CompletionAnalyzer(Analyzer, boolean, boolean) - Constructor for class org.apache.lucene.search.suggest.document.CompletionAnalyzer
-
- CompletionAnalyzer(Analyzer, int) - Constructor for class org.apache.lucene.search.suggest.document.CompletionAnalyzer
-
- CompletionPostingsFormat - Class in org.apache.lucene.search.suggest.document
-
- CompletionPostingsFormat() - Constructor for class org.apache.lucene.search.suggest.document.CompletionPostingsFormat
-
Used only by core Lucene at read-time via Service Provider instantiation
- CompletionQuery - Class in org.apache.lucene.search.suggest.document
-
Abstract
Query
that match documents containing terms with a specified prefix
filtered by
BitsProducer
.
- CompletionQuery(Term, BitsProducer) - Constructor for class org.apache.lucene.search.suggest.document.CompletionQuery
-
Creates a base Completion query against a term
with a filter
to scope the documents
- CompletionScorer - Class in org.apache.lucene.search.suggest.document
-
Expert: Responsible for executing the query against an
appropriate suggester and collecting the results
via a collector.
- CompletionScorer(CompletionWeight, NRTSuggester, LeafReader, Bits, boolean, Automaton) - Constructor for class org.apache.lucene.search.suggest.document.CompletionScorer
-
Creates a scorer for a field-specific suggester
scoped by acceptDocs
- CompletionsTermsReader - Class in org.apache.lucene.search.suggest.document
-
Holder for suggester and field-level info
for a suggest field
- CompletionTerms - Class in org.apache.lucene.search.suggest.document
-
- CompletionTokenStream - Class in org.apache.lucene.search.suggest.document
-
- CompletionWeight - Class in org.apache.lucene.search.suggest.document
-
Expert: the Weight for CompletionQuery, used to
score and explain these queries.
- CompletionWeight(CompletionQuery, Automaton) - Constructor for class org.apache.lucene.search.suggest.document.CompletionWeight
-
Creates a weight for query
with an automaton
,
using the reader
for index stats
- ComplexPhraseQueryParser - Class in org.apache.lucene.queryparser.complexPhrase
-
QueryParser which permits complex phrase query syntax eg "(john jon
jonathan~) peters*".
- ComplexPhraseQueryParser(String, Analyzer) - Constructor for class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- componentRelate(double, double, double, double) - Method in class org.apache.lucene.geo.EdgeTree
-
- componentRelate(double, double, double, double) - Method in class org.apache.lucene.geo.Polygon2D
-
Returns relation to the provided rectangle for this component
- componentRelateTriangle(double, double, double, double, double, double) - Method in class org.apache.lucene.geo.EdgeTree
-
- componentRelateTriangle(double, double, double, double, double, double) - Method in class org.apache.lucene.geo.Polygon2D
-
- components - Variable in class org.apache.lucene.facet.taxonomy.FacetLabel
-
- components - Variable in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- ComposedQuery - Class in org.apache.lucene.queryparser.surround.query
-
Base class for composite queries (such as AND/OR/NOT)
- ComposedQuery(List<SrndQuery>, boolean, String) - Constructor for class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- CompositeReader - Class in org.apache.lucene.index
-
Instances of this reader type can only
be used to get stored fields from the underlying LeafReaders,
but it is not possible to directly retrieve postings.
- CompositeReader() - Constructor for class org.apache.lucene.index.CompositeReader
-
Sole constructor.
- CompositeReaderContext - Class in org.apache.lucene.index
-
- CompositeSpatialStrategy - Class in org.apache.lucene.spatial.composite
-
- CompositeSpatialStrategy(String, RecursivePrefixTreeStrategy, SerializedDVStrategy) - Constructor for class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
- CompositeVerifyQuery - Class in org.apache.lucene.spatial.composite
-
A Query that considers an "indexQuery" to have approximate results, and a follow-on
ShapeValuesSource is called to verify each hit from
TwoPhaseIterator.matches()
.
- CompositeVerifyQuery(Query, ShapeValuesPredicate) - Constructor for class org.apache.lucene.spatial.composite.CompositeVerifyQuery
-
- compound - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
True if segment is compound file format.
- compoundFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes compound files
- CompoundFormat - Class in org.apache.lucene.codecs
-
Encodes/decodes compound files
- CompoundFormat() - Constructor for class org.apache.lucene.codecs.CompoundFormat
-
Sole constructor.
- compoundFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- compoundFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- compoundFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- compoundFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- compoundFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- compoundFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- CompoundToken(int, int) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase.CompoundToken
-
- CompoundWordTokenFilterBase - Class in org.apache.lucene.analysis.compound
-
Base class for decomposition token filters.
- CompoundWordTokenFilterBase(TokenStream, CharArraySet, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- CompoundWordTokenFilterBase(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- CompoundWordTokenFilterBase(TokenStream, CharArraySet, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- CompoundWordTokenFilterBase.CompoundToken - Class in org.apache.lucene.analysis.compound
-
Helper class to hold decompounded token information
- compress(byte[], int, int, DataOutput) - Method in class org.apache.lucene.codecs.compressing.Compressor
-
Compress bytes into out
.
- COMPRESSED_REFS_ENABLED - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
True, iff compressed references (oops) are enabled by this JVM
- CompressingCodec - Class in org.apache.lucene.codecs.compressing
-
- CompressingCodec(String, String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingCodec
-
Creates a compressing codec with a given segment suffix
- CompressingCodec(String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingCodec
-
Creates a compressing codec with an empty segment suffix
- CompressingStoredFieldsFormat - Class in org.apache.lucene.codecs.compressing
-
A
StoredFieldsFormat
that compresses documents in chunks in
order to improve the compression ratio.
- CompressingStoredFieldsFormat(String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-
- CompressingStoredFieldsFormat(String, String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-
- CompressingStoredFieldsIndexReader - Class in org.apache.lucene.codecs.compressing
-
- CompressingStoredFieldsIndexWriter - Class in org.apache.lucene.codecs.compressing
-
Efficient index format for block-based
Codec
s.
- CompressingStoredFieldsReader - Class in org.apache.lucene.codecs.compressing
-
- CompressingStoredFieldsReader(Directory, SegmentInfo, String, FieldInfos, IOContext, String, CompressionMode) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
Sole constructor.
- CompressingStoredFieldsWriter - Class in org.apache.lucene.codecs.compressing
-
- CompressingStoredFieldsWriter(Directory, SegmentInfo, String, IOContext, String, CompressionMode, int, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
Sole constructor.
- CompressingTermVectorsFormat - Class in org.apache.lucene.codecs.compressing
-
A
TermVectorsFormat
that compresses chunks of documents together in
order to improve the compression ratio.
- CompressingTermVectorsFormat(String, String, CompressionMode, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
-
- CompressingTermVectorsReader - Class in org.apache.lucene.codecs.compressing
-
- CompressingTermVectorsReader(Directory, SegmentInfo, String, FieldInfos, IOContext, String, CompressionMode) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
Sole constructor.
- CompressingTermVectorsWriter - Class in org.apache.lucene.codecs.compressing
-
- CompressingTermVectorsWriter(Directory, SegmentInfo, String, IOContext, String, CompressionMode, int, int) - Constructor for class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
Sole constructor.
- CompressionMode - Class in org.apache.lucene.codecs.compressing
-
A compression mode.
- CompressionMode() - Constructor for class org.apache.lucene.codecs.compressing.CompressionMode
-
Sole constructor.
- Compressor - Class in org.apache.lucene.codecs.compressing
-
A data compressor.
- Compressor() - Constructor for class org.apache.lucene.codecs.compressing.Compressor
-
Sole constructor, typically called from sub-classes.
- compute(PrefixTreeStrategy, IndexReaderContext, Bits, Shape, int, PrefixTreeFacetCounter.FacetVisitor) - Static method in class org.apache.lucene.spatial.prefix.PrefixTreeFacetCounter
-
Computes facets using a callback/visitor style design, allowing flexibility for the caller to determine what to do
with each underlying count.
- compute(PrefixTreeStrategy, LeafReaderContext, Bits, Shape, int, PrefixTreeFacetCounter.FacetVisitor) - Static method in class org.apache.lucene.spatial.prefix.PrefixTreeFacetCounter
-
Lower-level per-leaf segment method.
- computeDeltaDistance(DistanceStyle, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
- computeDeltaDistance(DistanceStyle, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
- computeDeltaDistance(DistanceStyle, GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.GeoDistance
-
Compute the shape's delta distance given a point.
- computeDeltaDistance(DistanceStyle, double, double, double) - Method in interface org.apache.lucene.spatial3d.geom.GeoDistance
-
Compute the shape's delta distance given a point.
- computeDistance(GeoPoint, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.ArcDistance
-
- computeDistance(GeoPoint, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.ArcDistance
-
- computeDistance(PlanetModel, Plane, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.ArcDistance
-
- computeDistance(PlanetModel, Plane, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.ArcDistance
-
- computeDistance(GeoPoint, GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Compute the distance from a point to another point.
- computeDistance(GeoPoint, double, double, double) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Compute the distance from a point to another point.
- computeDistance(PlanetModel, Plane, GeoPoint, Membership...) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Compute the distance from a plane to a point.
- computeDistance(PlanetModel, Plane, double, double, double, Membership...) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Compute the distance from a plane to a point.
- computeDistance(DistanceStyle, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
- computeDistance(DistanceStyle, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
- computeDistance(DistanceStyle, GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.GeoDistance
-
Compute this shape's internal "distance" to the GeoPoint.
- computeDistance(DistanceStyle, double, double, double) - Method in interface org.apache.lucene.spatial3d.geom.GeoDistance
-
Compute this shape's internal "distance" to the GeoPoint.
- computeDistance(GeoPoint, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.LinearDistance
-
- computeDistance(GeoPoint, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.LinearDistance
-
- computeDistance(PlanetModel, Plane, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LinearDistance
-
- computeDistance(PlanetModel, Plane, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LinearDistance
-
- computeDistance(GeoPoint, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- computeDistance(GeoPoint, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- computeDistance(PlanetModel, Plane, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- computeDistance(PlanetModel, Plane, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- computeDistance(GeoPoint, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.NormalDistance
-
- computeDistance(GeoPoint, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.NormalDistance
-
- computeDistance(PlanetModel, Plane, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.NormalDistance
-
- computeDistance(PlanetModel, Plane, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.NormalDistance
-
- computeDistance(GeoPoint, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- computeDistance(GeoPoint, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- computeDistance(PlanetModel, Plane, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- computeDistance(PlanetModel, Plane, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- computeNearestDistance(DistanceStyle, GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.GeoPath
-
Compute the nearest path distance to the GeoPoint.
- computeNearestDistance(DistanceStyle, double, double, double) - Method in interface org.apache.lucene.spatial3d.geom.GeoPath
-
Compute the nearest path distance to the GeoPoint.
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.BooleanSimilarity
-
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
-
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.Similarity
-
Computes the normalization value for a field, given the accumulated
state of term processing for this field (see
FieldInvertState
).
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
- computeNorm(FieldInvertState) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
- computeOutsideDistance(DistanceStyle, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseMembershipShape
-
- computeOutsideDistance(DistanceStyle, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseMembershipShape
-
- computeOutsideDistance(DistanceStyle, GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.GeoOutsideDistance
-
Compute this shape's distance to the GeoPoint.
- computeOutsideDistance(DistanceStyle, double, double, double) - Method in interface org.apache.lucene.spatial3d.geom.GeoOutsideDistance
-
Compute this shape's distance to the GeoPoint.
- computePathCenterDistance(DistanceStyle, GeoPoint) - Method in interface org.apache.lucene.spatial3d.geom.GeoPath
-
Compute the shortest distance from the path center to the GeoPoint.
- computePathCenterDistance(DistanceStyle, double, double, double) - Method in interface org.apache.lucene.spatial3d.geom.GeoPath
-
Compute the shortest distance from the path center to the GeoPoint.
- computePayloadFactor(int, int, int, BytesRef) - Method in interface org.apache.lucene.queries.payloads.PayloadDecoder
-
- computePayloadFactor(BytesRef) - Method in interface org.apache.lucene.queries.payloads.PayloadDecoder
-
Compute a float value for the given payload
- computePayloadFactor(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
-
Deprecated.
- computeProbability(BasicStats) - Method in interface org.apache.lucene.search.similarities.LMSimilarity.CollectionModel
-
Computes the probability p(w|C)
according to the language model
strategy for the current term.
- computeProbability(BasicStats) - Method in class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
-
- computeSlopFactor(int) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
-
Deprecated.
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.BooleanSimilarity
-
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
-
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.Similarity
-
Compute any collection-level weight (e.g.
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
- computeWeight(float, CollectionStatistics, TermStatistics...) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
- concat(byte) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- concat(BytesRef, byte) - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- concatenate(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton that accepts the concatenation of the languages of the
given automata.
- concatenate(List<Automaton>) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton that accepts the concatenation of the languages of the
given automata.
- ConcatenateGraphFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Concatenates/Joins every incoming token with a separator into one output token for every path through the
token stream (which is a graph).
- ConcatenateGraphFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
Creates a token stream to convert input
to a token stream
of accepted strings by its token stream graph.
- ConcatenateGraphFilter(TokenStream, boolean, boolean, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
Creates a token stream to convert input
to a token stream
of accepted strings by its token stream graph.
- ConcatenateGraphFilter.BytesRefBuilderTermAttribute - Interface in org.apache.lucene.analysis.miscellaneous
-
Attribute providing access to the term builder and UTF-16 conversion
- ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl - Class in org.apache.lucene.analysis.miscellaneous
-
- ConcatenateGraphFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- ConcatenateGraphFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilterFactory
-
- ConcatenatingTokenStream - Class in org.apache.lucene.analysis.miscellaneous
-
A TokenStream that takes an array of input TokenStreams as sources, and
concatenates them together.
- ConcatenatingTokenStream(TokenStream...) - Constructor for class org.apache.lucene.analysis.miscellaneous.ConcatenatingTokenStream
-
Create a new ConcatenatingTokenStream from a set of inputs
- ConcurrentMergeScheduler - Class in org.apache.lucene.index
-
- ConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler
-
Sole constructor, with all settings set to default
values.
- ConcurrentMergeScheduler.MergeThread - Class in org.apache.lucene.index
-
Runs a merge thread to execute a single merge, then exits.
- ConcurrentSortedSetDocValuesFacetCounts - Class in org.apache.lucene.facet.sortedset
-
- ConcurrentSortedSetDocValuesFacetCounts(SortedSetDocValuesReaderState, ExecutorService) - Constructor for class org.apache.lucene.facet.sortedset.ConcurrentSortedSetDocValuesFacetCounts
-
- ConcurrentSortedSetDocValuesFacetCounts(SortedSetDocValuesReaderState, FacetsCollector, ExecutorService) - Constructor for class org.apache.lucene.facet.sortedset.ConcurrentSortedSetDocValuesFacetCounts
-
Counts all facet dimensions across the provided hits.
- ConditionalTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Allows skipping TokenFilters based on the current set of attributes.
- ConditionalTokenFilter(TokenStream, Function<TokenStream, TokenStream>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilter
-
Create a new ConditionalTokenFilter
- ConditionalTokenFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- ConditionalTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilterFactory
-
- config - Variable in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- config - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- Config - Class in org.apache.lucene.benchmark.byTask.utils
-
Perf run configuration properties.
- Config(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.utils.Config
-
Read both algorithm and config properties.
- Config(Properties) - Constructor for class org.apache.lucene.benchmark.byTask.utils.Config
-
Create config without algorithm - useful for a programmatic perf test.
- config - Variable in class org.apache.lucene.facet.DrillSideways
-
- config - Variable in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
FacetsConfig
provided to the constructor.
- ConfigurationKey<T> - Class in org.apache.lucene.queryparser.flexible.core.config
-
An instance of this class represents a key that is used to retrieve a value
from
AbstractQueryConfig
.
- ConfigurationKeys() - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
- configure(FacetsConfig) - Method in class org.apache.lucene.benchmark.byTask.feeds.FacetSource
-
- configure(FacetsConfig) - Method in class org.apache.lucene.benchmark.byTask.feeds.RandomFacetSource
-
- configureWriter(Config, PerfRunData, IndexWriterConfig.OpenMode, IndexCommit) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
-
- conflicts(CopyJob) - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
Return true if this job is trying to copy any of the same files as the other job
- ConfusionMatrixGenerator - Class in org.apache.lucene.classification.utils
-
Utility class to generate the confusion matrix of a
Classifier
- ConfusionMatrixGenerator.ConfusionMatrix - Class in org.apache.lucene.classification.utils
-
a confusion matrix, backed by a Map
representing the linearized matrix
- ConjQuery(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- Conjunction() - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
- ConjunctionDISI - Class in org.apache.lucene.search
-
A conjunction of DocIdSetIterators.
- ConnectionCosts - Class in org.apache.lucene.analysis.ja.dict
-
n-gram connection cost data
- ConnectionCosts - Class in org.apache.lucene.analysis.ko.dict
-
n-gram connection cost data
- constant(double) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Creates a DoubleValuesSource that always returns a constant value
- constant(long) - Static method in class org.apache.lucene.search.LongValuesSource
-
Creates a LongValuesSource that always returns a constant value
- CONSTANT_SCORE_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
-
- CONSTANT_SCORE_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
-
- CONSTANT_SCORE_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
-
A rewrite method that first creates a private Filter,
by visiting each term in sequence and marking all docs
for that term.
- ConstantBulkScorer(BulkScorer, Weight, float) - Constructor for class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
-
- Constants - Class in org.apache.lucene.benchmark
-
Various benchmarking constants (mostly defaults)
- Constants() - Constructor for class org.apache.lucene.benchmark.Constants
-
- Constants - Class in org.apache.lucene.util
-
Some useful constants.
- ConstantScoreQuery - Class in org.apache.lucene.search
-
A query that wraps another query and simply returns a constant score equal to
1 for every document that matches the query.
- ConstantScoreQuery(Query) - Constructor for class org.apache.lucene.search.ConstantScoreQuery
-
Strips off scores from the passed in Query.
- ConstantScoreQuery.ConstantBulkScorer - Class in org.apache.lucene.search
-
We return this as our
BulkScorer
so that if the CSQ
wraps a query with its own optimized top-level
scorer (e.g.
- ConstantScoreQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- ConstantScoreQueryBuilder(QueryBuilderFactory) - Constructor for class org.apache.lucene.queryparser.xml.builders.ConstantScoreQueryBuilder
-
- ConstantScoreScorer - Class in org.apache.lucene.search
-
- ConstantScoreScorer(Weight, float, DocIdSetIterator) - Constructor for class org.apache.lucene.search.ConstantScoreScorer
-
- ConstantScoreScorer(Weight, float, TwoPhaseIterator) - Constructor for class org.apache.lucene.search.ConstantScoreScorer
-
- ConstantScoreWeight - Class in org.apache.lucene.search
-
A Weight that has a constant score equal to the boost of the wrapped query.
- ConstantScoreWeight(Query, float) - Constructor for class org.apache.lucene.search.ConstantScoreWeight
-
- ConstNumberSource - Class in org.apache.lucene.queries.function.valuesource
-
ConstNumberSource
is the base class for all constant numbers
- ConstNumberSource() - Constructor for class org.apache.lucene.queries.function.valuesource.ConstNumberSource
-
- constructNormalizedPerpendicularSidedPlane(Vector, Vector, Vector, Vector) - Static method in class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from two points and a third normal vector.
- constructNormalizedThreePointSidedPlane(Vector, Vector, Vector, Vector) - Static method in class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from three points.
- constructNormalizedXPlane(Vector...) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Construct the most accurate normalized plane through an y-z point and including the X axis.
- constructNormalizedXPlane(double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Construct a normalized plane through a y-z point and parallel to the X axis.
- constructNormalizedYPlane(Vector...) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Construct the most accurate normalized plane through an x-z point and including the Y axis.
- constructNormalizedYPlane(double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Construct a normalized plane through an x-z point and parallel to the Y axis.
- constructNormalizedZPlane(Vector...) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Construct the most accurate normalized plane through an x-y point and including the Z axis.
- constructNormalizedZPlane(double, double) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Construct a normalized plane through an x-y point and including the Z axis.
- ConstValueSource - Class in org.apache.lucene.queries.function.valuesource
-
ConstValueSource
returns a constant for all documents
- ConstValueSource(float) - Constructor for class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- CONSUME_ALL_TOKENS_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilterFactory
-
- CONSUME_ALL_TOKENS_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.LimitTokenOffsetFilterFactory
-
- CONSUME_ALL_TOKENS_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilterFactory
-
- consumeAllTokens() - Method in class org.apache.lucene.analysis.sinks.TeeSinkTokenFilter
-
TeeSinkTokenFilter
passes all tokens to the added sinks when itself is consumed.
- ConsumeContentSourceTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
- ConsumeContentSourceTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ConsumeContentSourceTask
-
- containedBy(IntervalsSource, IntervalsSource) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Create a contained-by
IntervalsSource
Returns intervals from the small query that appear within intervals of the big query
- containing(IntervalsSource, IntervalsSource) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Create a containing
IntervalsSource
Returns intervals from the big source that contain one or more intervals from
the small source
- 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(BytesRef) - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
The main method required for a Bloom filter which, given a value determines set membership.
- contains(double, double) - Method in class org.apache.lucene.geo.Polygon2D
-
Returns true if the point is contained within this polygon.
- contains(PointsStackTracker.Cell) - Method in class org.apache.lucene.index.PointsStackTracker.Cell
-
- contains(Object) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- contains(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- Contains - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
Meets the "Covers" OGC definition (boundary-neutral).
- CONTAINS - Static variable in interface org.apache.lucene.spatial3d.geom.GeoArea
-
The referenced shape CONTAINS this area
- containsAll(Collection<?>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- containsKey(char[], int, int) - Method in class org.apache.lucene.analysis.CharArrayMap
-
- containsKey(CharSequence) - Method in class org.apache.lucene.analysis.CharArrayMap
-
- containsKey(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
-
- containsKey(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
-
Returns true
if this map contains a mapping for the specified key.
- containsPoint(double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.Rectangle
-
returns true if rectangle (defined by minLat, maxLat, minLon, maxLon) contains the lat lon point
- containsPoint(double, double) - Method in class org.apache.lucene.geo.Tessellator.Triangle
-
utility method to compute whether the point is in the triangle
- ContainsPrefixTreeQuery - Class in org.apache.lucene.spatial.prefix
-
Finds docs where its indexed shape
CONTAINS
the query shape.
- ContainsPrefixTreeQuery(Shape, String, SpatialPrefixTree, int, boolean) - Constructor for class org.apache.lucene.spatial.prefix.ContainsPrefixTreeQuery
-
- containsSlowly(Polygon, double, double) - Static method in class org.apache.lucene.geo.GeoTestUtil
-
Simple slow point in polygon check (for testing)
- containsTag(String) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
verify if a node contains a tag
- containsTag(String) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
verify if a node contains a tag
- containsTriangle(int, int, int, int, int, int) - Method in class org.apache.lucene.geo.Rectangle2D
-
Checks if the rectangle contains the provided triangle
- ContentItemsSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Base class for source of data for benchmarking
- ContentItemsSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
- ContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Represents content from a specified source, such as TREC, Reuters etc.
- ContentSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.ContentSource
-
- context - Variable in class org.apache.lucene.facet.FacetsCollector.MatchingDocs
-
Context for this segment.
- context - Variable in class org.apache.lucene.index.SegmentReadState
-
- context - Variable in class org.apache.lucene.index.SegmentWriteState
-
- context - Variable in class org.apache.lucene.queries.CustomScoreProvider
-
- context - Variable in class org.apache.lucene.queries.function.FunctionQuery.FunctionWeight
-
- context - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- context() - Method in class org.apache.lucene.search.suggest.document.CompletionWeight
-
- context - Variable in class org.apache.lucene.search.suggest.document.TopSuggestDocs.SuggestScoreDoc
-
Context for the completion
- context - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- context - Variable in class org.apache.lucene.store.IOContext
-
An object of a enumerator Context type
- context - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-
- CONTEXT_SEPARATOR - Static variable in class org.apache.lucene.search.suggest.document.ContextSuggestField
-
Separator used between context value and the suggest field value
- ContextQuery - Class in org.apache.lucene.search.suggest.document
-
- ContextQuery(CompletionQuery) - Constructor for class org.apache.lucene.search.suggest.document.ContextQuery
-
Constructs a context completion query that matches
documents specified by query
.
- contexts() - Method in class org.apache.lucene.search.suggest.BufferedInputIterator
-
- contexts() - Method in class org.apache.lucene.search.suggest.document.ContextSuggestField
-
Expert: Sub-classes can inject contexts at
index-time
- contexts() - Method in class org.apache.lucene.search.suggest.DocumentDictionary.DocumentInputIterator
-
- contexts() - Method in interface org.apache.lucene.search.suggest.InputIterator
-
A term's contexts context can be used to filter suggestions.
- contexts() - Method in class org.apache.lucene.search.suggest.InputIterator.InputIteratorWrapper
-
- contexts - Variable in class org.apache.lucene.search.suggest.Lookup.LookupResult
-
the key's contexts (null if not present)
- contexts() - Method in class org.apache.lucene.search.suggest.SortedInputIterator
-
- contexts() - Method in class org.apache.lucene.search.suggest.UnsortedInputIterator
-
- CONTEXTS_FIELD_NAME - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Field name used for the indexed context, as a
StringField and a SortedSetDVField, for filtering.
- contextSets - Variable in class org.apache.lucene.search.suggest.BufferedInputIterator
-
buffered context set entries
- contextsField - Variable in class org.apache.lucene.search.suggest.DocumentDictionary
-
Field to read contexts from
- ContextSuggestField - Class in org.apache.lucene.search.suggest.document
-
- ContextSuggestField(String, String, int, CharSequence...) - Constructor for class org.apache.lucene.search.suggest.document.ContextSuggestField
-
Creates a context-enabled suggest field
- ControlledRealTimeReopenThread<T> - Class in org.apache.lucene.search
-
Utility class that runs a thread to manage periodicc
reopens of a
ReferenceManager
, with methods to wait for a specific
index changes to become visible.
- ControlledRealTimeReopenThread(IndexWriter, ReferenceManager<T>, double, double) - Constructor for class org.apache.lucene.search.ControlledRealTimeReopenThread
-
Create ControlledRealTimeReopenThread, to periodically
reopen the a
ReferenceManager
.
- convert(Shape) - Method in interface org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker.ShapeConverter
-
- convert(Automaton) - Method in class org.apache.lucene.util.automaton.UTF32ToUTF8
-
Converts an incoming utf32 automaton to an equivalent
utf8 one.
- convertAutomaton(Automaton) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
Used by subclass to change the lookup automaton, if
necessary.
- convertAutomaton(Automaton) - Method in class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
- copiedFiles - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- copy(Map<?, ? extends V>) - Static method in class org.apache.lucene.analysis.CharArrayMap
-
- copy(Set<?>) - Static method in class org.apache.lucene.analysis.CharArraySet
-
- copy(Path, Path, CopyOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- copy(Path, Path, CopyOption...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- copy(int, int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- copy(int, int) - Method in interface org.apache.lucene.search.LeafFieldComparator
-
This method is called when a new hit is competitive.
- copy(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Copies over all states/transitions from other.
- copy(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton
-
Copies over all states/transitions from other.
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValue
-
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueBool
-
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueInt
-
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueLong
-
- copy(MutableValue) - Method in class org.apache.lucene.util.mutable.MutableValueStr
-
- copy(PackedInts.Reader, int, PackedInts.Mutable, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Copy src[srcPos:srcPos+len]
into
dest[destPos:destPos+len]
using at most mem
bytes.
- copy(IndexInput, long) - Method in class org.apache.lucene.util.PagedBytes
-
Read this many bytes from in
- copy(BytesRef, BytesRef) - Method in class org.apache.lucene.util.PagedBytes
-
Copy BytesRef in, setting BytesRef out to the result.
- copy(int, int) - Method in class org.apache.lucene.util.TimSorter
-
Copy data from slot src
to slot dest
.
- copy_from(SnowballProgram) - Method in class org.tartarus.snowball.SnowballProgram
-
- copyBuffer(char[], int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Copies the contents of buffer, starting at offset for
length characters, into the termBuffer array.
- copyBuffer(char[], int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- copyBytes(DataInput, long) - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
-
- copyBytes(DataInput, long) - Method in class org.apache.lucene.store.DataOutput
-
Copy numBytes bytes from input to ourself.
- copyBytes(DataInput, long) - Method in class org.apache.lucene.store.MockIndexOutputWrapper
-
- copyBytes(byte[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Replace the content of this builder with the provided bytes.
- copyBytes(BytesRef) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Replace the content of this builder with the provided bytes.
- copyBytes(BytesRefBuilder) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Replace the content of this builder with the provided bytes.
- copyBytes(DataInput, long) - Method in class org.apache.lucene.util.ThrottledIndexOutput
-
- copyChars(CharSequence) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Replace the content of this buffer with UTF-8 encoded bytes that would
represent the provided text.
- copyChars(CharSequence, int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Replace the content of this buffer with UTF-8 encoded bytes that would
represent the provided text.
- copyChars(char[], int, int) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Replace the content of this buffer with UTF-8 encoded bytes that would
represent the provided text.
- copyChars(CharsRef) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Copies the given
CharsRef
referenced content into this instance.
- copyChars(char[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Copies the given array into this instance.
- copyFiles(Directory, Directory, List<String>) - Static method in class org.apache.lucene.replicator.IndexReplicationHandler
-
Copies the files from the source directory to the target one, if they are
not the same.
- copyFrom(TermState) - Method in class org.apache.lucene.codecs.BlockTermState
-
- copyFrom(TermState) - Method in class org.apache.lucene.index.OrdTermState
-
- copyFrom(TermState) - Method in class org.apache.lucene.index.TermState
-
Copies the content of the given
TermState
to this instance
- copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.Directory
-
Copies an existing src
file from directory from
to a non-existent file dest
in this directory.
- copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.HardlinkCopyDirectoryWrapper
-
- copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
-
- copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.RawDirectoryWrapper
-
- copyFrom(Directory, String, String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-
- copyFrom(HeapPointWriter) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- copyFrom(FST.Arc<T>) - Method in class org.apache.lucene.util.fst.FST.Arc
-
Returns this
- copyInts(int[], int, int) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Copies the given array into this instance.
- copyInts(IntsRef) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Copies the given array into this instance.
- CopyJob - Class in org.apache.lucene.replicator.nrt
-
Handles copying one set of files, e.g.
- CopyJob(String, Map<String, FileMetaData>, ReplicaNode, boolean, CopyJob.OnceDone) - Constructor for class org.apache.lucene.replicator.nrt.CopyJob
-
- CopyJob.OnceDone - Interface in org.apache.lucene.replicator.nrt
-
Callback invoked by CopyJob once all files have (finally) finished copying
- copyOf(BitSet, int) - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
Create a copy of the given
BitSet
which has
length
bits.
- copyOf(BitSet, int) - Method in class org.apache.lucene.util.BaseDocIdSetTestCase
-
Create a copy of the given
BitSet
which has
length
bits.
- copyOf(Bits) - Static method in class org.apache.lucene.util.FixedBitSet
-
Make a copy of the given bits.
- copyOfSubArray(byte[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- copyOfSubArray(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- copyOfSubArray(short[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- copyOfSubArray(int[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- copyOfSubArray(long[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- copyOfSubArray(float[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- copyOfSubArray(double[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- copyOfSubArray(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Copies the specified range of the given array into a new sub array.
- CopyOneFile - Class in org.apache.lucene.replicator.nrt
-
Copies one file from an incoming DataInput to a dest filename in a local Directory
- CopyOneFile(DataInput, ReplicaNode, String, FileMetaData, byte[]) - Constructor for class org.apache.lucene.replicator.nrt.CopyOneFile
-
- CopyOneFile(CopyOneFile, DataInput) - Constructor for class org.apache.lucene.replicator.nrt.CopyOneFile
-
Transfers this file copy to another input, continuing where the first one left off
- CopyState - Class in org.apache.lucene.replicator.nrt
-
Holds incRef'd file level details for one point-in-time segment infos on the primary node.
- CopyState(Map<String, FileMetaData>, long, long, byte[], Set<String>, long, SegmentInfos) - Constructor for class org.apache.lucene.replicator.nrt.CopyState
-
- copyStates(Automaton) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Copies over all states from other.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.ko.tokenattributes.ReadingAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.Token
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.search.BoostAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-
- copyTo(AttributeImpl) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- copyTo(DataOutput) - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
Copy the current content of this object into another
DataOutput
.
- copyTo(AttributeImpl) - Method in class org.apache.lucene.util.AttributeImpl
-
Copies the values from this Attribute into the passed-in
target attribute.
- copyTo(AttributeSource) - Method in class org.apache.lucene.util.AttributeSource
-
Copies the contents of this AttributeSource
to the given target AttributeSource
.
- copyUsingLengthPrefix(BytesRef) - Method in class org.apache.lucene.util.PagedBytes
-
Copy bytes in, writing the length as a 1 or 2 byte
vInt prefix.
- copyUTF8Bytes(byte[], int, int) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Copy the provided bytes, interpreted as UTF-8 bytes.
- copyUTF8Bytes(BytesRef) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Copy the provided bytes, interpreted as UTF-8 bytes.
- copyUTF8Bytes(BytesRef) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Copy the given UTF-8 bytes into this builder.
- copyValue() - Method in class org.apache.lucene.search.grouping.GroupSelector
-
- copyValue() - Method in class org.apache.lucene.search.grouping.TermGroupSelector
-
- copyValue() - Method in class org.apache.lucene.search.grouping.ValueSourceGroupSelector
-
- CoreParser - Class in org.apache.lucene.queryparser.xml
-
Assembles a QueryBuilder which uses only core Lucene Query objects
- CoreParser(Analyzer, QueryParser) - Constructor for class org.apache.lucene.queryparser.xml.CoreParser
-
Construct an XML parser that uses a single instance QueryParser for handling
UserQuery tags - all parse operations are synchronised on this parser
- CoreParser(String, Analyzer) - Constructor for class org.apache.lucene.queryparser.xml.CoreParser
-
Constructs an XML parser that creates a QueryParser for each UserQuery request.
- CoreParser(String, Analyzer, QueryParser) - Constructor for class org.apache.lucene.queryparser.xml.CoreParser
-
- CorePlusExtensionsParser - Class in org.apache.lucene.queryparser.xml
-
Assembles a QueryBuilder which uses Query objects from
Lucene's sandbox
and queries
modules in addition to core queries.
- CorePlusExtensionsParser(Analyzer, QueryParser) - Constructor for class org.apache.lucene.queryparser.xml.CorePlusExtensionsParser
-
Construct an XML parser that uses a single instance QueryParser for handling
UserQuery tags - all parse operations are synchronized on this parser
- CorePlusExtensionsParser(String, Analyzer) - Constructor for class org.apache.lucene.queryparser.xml.CorePlusExtensionsParser
-
Constructs an XML parser that creates a QueryParser for each UserQuery request.
- CorePlusQueriesParser - Class in org.apache.lucene.queryparser.xml
-
Assembles a QueryBuilder which uses Query objects from
Lucene's queries
module in addition to core queries.
- CorePlusQueriesParser(Analyzer, QueryParser) - Constructor for class org.apache.lucene.queryparser.xml.CorePlusQueriesParser
-
Construct an XML parser that uses a single instance QueryParser for handling
UserQuery tags - all parse operations are synchronized on this parser
- CorePlusQueriesParser(String, Analyzer) - Constructor for class org.apache.lucene.queryparser.xml.CorePlusQueriesParser
-
Constructs an XML parser that creates a QueryParser for each UserQuery request.
- CorePlusQueriesParser(String, Analyzer, QueryParser) - Constructor for class org.apache.lucene.queryparser.xml.CorePlusQueriesParser
-
- correct(int) - Method in class org.apache.lucene.analysis.charfilter.BaseCharFilter
-
Retrieve the corrected offset.
- correct(int) - Method in class org.apache.lucene.analysis.CharFilter
-
Subclasses override to correct the current offset.
- correct(int) - Method in class org.apache.lucene.analysis.fa.PersianCharFilter
-
- correct(int) - Method in class org.apache.lucene.analysis.ja.JapaneseIterationMarkCharFilter
-
- correct(int) - Method in class org.apache.lucene.analysis.MockCharFilter
-
- correct(int) - Method in class org.apache.lucene.analysis.pattern.PatternReplaceCharFilter
-
- correctOffset(int) - Method in class org.apache.lucene.analysis.CharFilter
-
Chains the corrected offset through the input
CharFilter(s).
- correctOffset(int) - Method in class org.apache.lucene.analysis.Tokenizer
-
Return the corrected offset.
- corruptFile() - Method in class org.apache.lucene.store.CorruptingIndexOutput
-
- corruptFiles(Collection<String>) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- CorruptIndexException - Exception in org.apache.lucene.index
-
This exception is thrown when Lucene detects
an inconsistency in the index.
- CorruptIndexException(String, DataInput) - Constructor for exception org.apache.lucene.index.CorruptIndexException
-
Create exception with a message only
- CorruptIndexException(String, DataOutput) - Constructor for exception org.apache.lucene.index.CorruptIndexException
-
Create exception with a message only
- CorruptIndexException(String, DataInput, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
-
Create exception with message and root cause.
- CorruptIndexException(String, DataOutput, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
-
Create exception with message and root cause.
- CorruptIndexException(String, String) - Constructor for exception org.apache.lucene.index.CorruptIndexException
-
Create exception with a message only
- CorruptIndexException(String, String, Throwable) - Constructor for exception org.apache.lucene.index.CorruptIndexException
-
Create exception with message and root cause.
- CorruptingIndexOutput - Class in org.apache.lucene.store
-
Corrupts on bit of a file after close
- CorruptingIndexOutput(Directory, long, IndexOutput) - Constructor for class org.apache.lucene.store.CorruptingIndexOutput
-
- corruptUnknownFiles() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- cos(double) - Static method in class org.apache.lucene.util.SloppyMath
-
Returns the trigonometric cosine of an angle.
- cost() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- cost() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- cost() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- cost() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- cost() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- cost() - Method in class org.apache.lucene.index.FilterBinaryDocValues
-
- cost() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- cost() - Method in class org.apache.lucene.index.FilterNumericDocValues
-
- cost() - Method in class org.apache.lucene.index.LegacyBinaryDocValuesWrapper
-
Deprecated.
- cost() - Method in class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- cost() - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- cost() - Method in class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- cost() - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- cost() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- cost() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- cost() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- cost() - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- cost() - Method in class org.apache.lucene.search.BulkScorer
-
- cost() - Method in class org.apache.lucene.search.ConjunctionDISI
-
- cost() - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
-
- cost - Variable in class org.apache.lucene.search.DisiWrapper
-
- cost() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
-
- cost() - Method in class org.apache.lucene.search.DocIdSetIterator
-
- cost() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-
- cost() - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- cost() - Method in class org.apache.lucene.search.ScorerSupplier
-
- cost() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- cost() - Method in class org.apache.lucene.search.spans.TermSpans
-
- cost() - Method in class org.apache.lucene.search.suggest.document.CompletionScorer
-
- cost() - Method in class org.apache.lucene.search.Weight.DefaultBulkScorer
-
- cost() - Method in class org.apache.lucene.util.BitSetIterator
-
- COULD_NOT_PARSE_NUMBER - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- count - Static variable in class org.apache.lucene.benchmark.utils.ExtractWikipedia
-
- count() - Method in class org.apache.lucene.index.LegacySortedNumericDocValues
-
Deprecated.
Retrieves the count of values for the current document.
- count() - Method in class org.apache.lucene.search.DocValuesStats
-
The number of documents which have a value of the field.
- count(Query) - Method in class org.apache.lucene.search.IndexSearcher
-
Count how many documents match the given query.
- count - Variable in class org.apache.lucene.search.spans.TermSpans
-
- count - Variable in class org.apache.lucene.util.SentinelIntSet
-
- countDocsWithClass() - Method in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
count the number of documents in the index having at least a value for the 'class' field
- counter - Variable in class org.apache.lucene.facet.taxonomy.writercache.LabelToOrdinal
-
How many ordinals we've seen.
- counter - Variable in class org.apache.lucene.index.SegmentInfos
-
Used to name new segments.
- Counter - Class in org.apache.lucene.util
-
Simple counter class
- Counter() - Constructor for class org.apache.lucene.util.Counter
-
- counts - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
- counts - Variable in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter.Heatmap
-
- CoveringQuery - Class in org.apache.lucene.search
-
A
Query
that allows to have a configurable number or required
matches per document.
- CoveringQuery(Collection<Query>, LongValuesSource) - Constructor for class org.apache.lucene.search.CoveringQuery
-
Sole constructor.
- CrankyCodec - Class in org.apache.lucene.codecs.cranky
-
Codec for testing that throws random IOExceptions
- CrankyCodec(Codec, Random) - Constructor for class org.apache.lucene.codecs.cranky.CrankyCodec
-
Wrap the provided codec with crankiness.
- CrankyTokenFilter - Class in org.apache.lucene.analysis
-
Throws IOException from random Tokenstream methods.
- CrankyTokenFilter(TokenStream, Random) - Constructor for class org.apache.lucene.analysis.CrankyTokenFilter
-
Creates a new CrankyTokenFilter
- crash() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Simulates a crash of OS or machine by overwriting
unsynced files.
- create(TokenStream) - Method in class org.apache.lucene.analysis.ar.ArabicNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ar.ArabicStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.bg.BulgarianStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.bn.BengaliNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.bn.BengaliStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.br.BrazilianStemFilterFactory
-
- create(Reader) - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilterFactory
-
- create(Reader) - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.cjk.CJKBigramFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.cjk.CJKWidthFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ckb.SoraniNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ckb.SoraniStemFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.cn.smart.HMMChineseTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.commongrams.CommonGramsFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.commongrams.CommonGramsQueryFilterFactory
-
Create a CommonGramsFilter and wrap it with a CommonGramsQueryFilter
- create(TokenStream) - Method in class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.core.DecimalDigitFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.core.FlattenGraphFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.core.KeywordTokenizerFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.core.LetterTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.core.LowerCaseFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.core.LowerCaseTokenizerFactory
-
Deprecated.
- create(TokenStream) - Method in class org.apache.lucene.analysis.core.StopFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.core.TypeTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.core.UpperCaseFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.core.WhitespaceTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.cz.CzechStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.de.GermanLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.de.GermanMinimalStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.de.GermanNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.de.GermanStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.el.GreekLowerCaseFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.el.GreekStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.en.EnglishMinimalStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.en.EnglishPossessiveFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.en.KStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.en.PorterStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.es.SpanishLightStemFilterFactory
-
- create(Reader) - Method in class org.apache.lucene.analysis.fa.PersianCharFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.fa.PersianNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.fi.FinnishLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.fr.FrenchLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.fr.FrenchMinimalStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ga.IrishLowerCaseFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.gl.GalicianMinimalStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.gl.GalicianStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.hi.HindiNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.hi.HindiStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.hu.HungarianLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.icu.ICUFoldingFilterFactory
-
- create(Reader) - Method in class org.apache.lucene.analysis.icu.ICUNormalizer2CharFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.icu.ICUNormalizer2FilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.icu.ICUTransformFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.id.IndonesianStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.in.IndicNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.it.ItalianLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ja.JapaneseBaseFormFilterFactory
-
- create(Reader) - Method in class org.apache.lucene.analysis.ja.JapaneseIterationMarkCharFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ja.JapaneseKatakanaStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ja.JapanesePartOfSpeechStopFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ja.JapaneseReadingFormFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ko.KoreanPartOfSpeechStopFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ko.KoreanReadingFormFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.ko.KoreanTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.lv.LatvianStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.minhash.MinHashFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.CodepointCountFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilterFactory
-
- create(TokenStream, Function<TokenStream, TokenStream>) - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.DelimitedTermFrequencyTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.FingerprintFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.FixBrokenOffsetsFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.HyphenatedWordsFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.KeepWordFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.KeywordMarkerFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.KeywordRepeatFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.LengthFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenOffsetFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilterFactory
-
- create(TokenStream, Function<TokenStream, TokenStream>) - Method in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.RemoveDuplicatesTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.ScandinavianFoldingFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.ScandinavianNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.TrimFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.TruncateTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.TypeAsSynonymFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilterFactory
-
Deprecated.
- create(TokenStream) - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.morfologik.MorfologikFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ngram.EdgeNGramFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ngram.NGramFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.ngram.NGramTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.no.NorwegianLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.no.NorwegianMinimalStemFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.path.PathHierarchyTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.pattern.PatternCaptureGroupFilterFactory
-
- create(Reader) - Method in class org.apache.lucene.analysis.pattern.PatternReplaceCharFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.pattern.PatternReplaceFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.pattern.PatternTokenizerFactory
-
Split the input using configured pattern
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizerFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.pattern.SimplePatternTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.payloads.NumericPayloadTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.payloads.TokenOffsetPayloadTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.payloads.TypeAsPayloadTokenFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.phonetic.BeiderMorseFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.phonetic.DaitchMokotoffSoundexFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.phonetic.PhoneticFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.pt.PortugueseLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.pt.PortugueseMinimalStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.pt.PortugueseStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.reverse.ReverseStringFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.ru.RussianLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.shingle.FixedShingleFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.shingle.ShingleFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.snowball.SnowballPorterFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.sr.SerbianNormalizationFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.standard.ClassicFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.standard.ClassicTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.standard.StandardFilterFactory
-
Deprecated.
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.stempel.StempelPolishStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.sv.SwedishLightStemFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.synonym.SynonymFilterFactory
-
Deprecated.
- create(TokenStream) - Method in class org.apache.lucene.analysis.synonym.SynonymGraphFilterFactory
-
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.th.ThaiTokenizerFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.tr.ApostropheFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.tr.TurkishLowerCaseFilterFactory
-
- create(Reader) - Method in class org.apache.lucene.analysis.util.CharFilterFactory
-
Wraps the given Reader with a CharFilter.
- create(TokenStream) - Method in class org.apache.lucene.analysis.util.ElisionFilterFactory
-
- create(TokenStream) - Method in class org.apache.lucene.analysis.util.TokenFilterFactory
-
Transform the specified input TokenStream
- create() - Method in class org.apache.lucene.analysis.util.TokenizerFactory
-
Creates a TokenStream of the specified input using the default attribute factory.
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.util.TokenizerFactory
-
Creates a TokenStream of the specified input using the given AttributeFactory
- create(AttributeFactory) - Method in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizerFactory
-
- create() - Method in class org.apache.lucene.benchmark.byTask.utils.AnalyzerFactory
-
- create(String, String, String, String) - Method in class org.apache.lucene.benchmark.utils.ExtractWikipedia
-
- create(Line...) - Static method in class org.apache.lucene.geo.Line2D
-
create a Line2D edge tree from provided array of Linestrings
- create(Polygon...) - Static method in class org.apache.lucene.geo.Polygon2D
-
Builds a Polygon2D from multipolygon
- create(Rectangle) - Static method in class org.apache.lucene.geo.Rectangle2D
-
Builds a Rectangle2D from rectangle
- create(boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
-
- create(Collector, boolean, double) - Static method in class org.apache.lucene.search.CachingCollector
-
Create a new
CachingCollector
that wraps the given collector and
caches documents and scores up to the specified RAM threshold.
- create(Collector, boolean, int) - Static method in class org.apache.lucene.search.CachingCollector
-
Create a new
CachingCollector
that wraps the given collector and
caches documents and scores up to the specified max docs threshold.
- create(SortField[], int) - Static method in class org.apache.lucene.search.FieldValueHitQueue
-
Creates a hit queue sorted by the given list of fields.
- create(TokenStream) - Method in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilterFactory
-
- create(Sort, int, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
-
- create(Sort, int, boolean, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
-
- create(Sort, int, FieldDoc, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
-
- create(Sort, int, FieldDoc, boolean, boolean, boolean, boolean) - Static method in class org.apache.lucene.search.TopFieldCollector
-
- create(int) - Static method in class org.apache.lucene.search.TopScoreDocCollector
-
- create(int, ScoreDoc) - Static method in class org.apache.lucene.search.TopScoreDocCollector
-
- createAnalyzer(String) - Static method in class org.apache.lucene.benchmark.byTask.tasks.NewAnalyzerTask
-
- createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeFactory
-
- createAttributeInstance(Class<? extends Attribute>) - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
-
- createBooleanQuery(String, String) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a boolean query from the query text.
- createBooleanQuery(String, String, BooleanClause.Occur) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a boolean query from the query text.
- createCellIteratorToIndex(Shape, int, Iterator<Cell>) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- createCellIteratorToIndex(Shape, int, Iterator<Cell>) - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- createClosestToLength(BreakIterator, int) - Static method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
Breaks will be on average targetLength
apart; the closest break to this target (before or after)
is chosen.
- createCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
- createCollector() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
-
- createComponents(String) - Method in class org.apache.lucene.analysis.Analyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.bn.BengaliAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ckb.SoraniAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.core.KeywordAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.core.SimpleAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.core.StopAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.core.UnicodeWhitespaceAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.core.WhitespaceAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.cz.CzechAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.da.DanishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.de.GermanAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.el.GreekAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.en.EnglishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.es.SpanishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ga.IrishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.hi.HindiAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.it.ItalianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ja.JapaneseAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ko.KoreanAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.lt.LithuanianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.MockBytesAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.MockPayloadAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.MockSynonymAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.morfologik.MorfologikAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Returns a (possibly reused)
TokenStream
which tokenizes all the
text in the provided
Reader
.
- createComponents(String) - Method in class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.ru.RussianAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.th.ThaiAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.analysis.uk.UkrainianMorfologikAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.collation.CollationKeyAnalyzer
-
- createComponents(String) - Method in class org.apache.lucene.collation.ICUCollationKeyAnalyzer
-
- createDirectory(Path, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.ExtrasFS
-
- createDirectory(Path, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- createDirectory(Path, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- createDistancePredicate(double, double, double) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
-
Create a predicate that checks whether points are within a distance of a given point.
- createDoc(int) - Static method in class org.apache.lucene.search.BaseExplanationTestCase
-
- createdVersionMajor - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
Compatibility version to use for this index.
- createFieldFragList(FieldPhraseList, FieldFragList, int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragListBuilder
-
- createFieldFragList(FieldPhraseList, int) - Method in interface org.apache.lucene.search.vectorhighlight.FragListBuilder
-
create a FieldFragList.
- createFieldFragList(FieldPhraseList, int) - Method in class org.apache.lucene.search.vectorhighlight.SimpleFragListBuilder
-
- createFieldFragList(FieldPhraseList, int) - Method in class org.apache.lucene.search.vectorhighlight.SingleFragListBuilder
-
- createFieldFragList(FieldPhraseList, int) - Method in class org.apache.lucene.search.vectorhighlight.WeightedFragListBuilder
-
- createFieldQuery(Analyzer, BooleanClause.Occur, String, String, boolean, int) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a query from the analysis chain.
- createFieldQuery(TokenStream, BooleanClause.Occur, String, boolean, int) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a query from a token stream.
- createFragment(IndexReader, int, String, FieldFragList) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- createFragment(IndexReader, int, String, FieldFragList, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- createFragment(IndexReader, int, String, FieldFragList) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
-
create a fragment.
- createFragment(IndexReader, int, String, FieldFragList, String[], String[], Encoder) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
-
create a fragment.
- createFragments(IndexReader, int, String, FieldFragList, int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- createFragments(IndexReader, int, String, FieldFragList, int, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- createFragments(IndexReader, int, String, FieldFragList, int) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
-
create multiple fragments.
- createFragments(IndexReader, int, String, FieldFragList, int, String[], String[], Encoder) - Method in interface org.apache.lucene.search.vectorhighlight.FragmentsBuilder
-
create multiple fragments.
- createIndexableFields(String, Polygon) - Static method in class org.apache.lucene.document.LatLonShape
-
create indexable fields for polygon geometry
- createIndexableFields(String, Line) - Static method in class org.apache.lucene.document.LatLonShape
-
create indexable fields for line geometry
- createIndexableFields(String, double, double) - Static method in class org.apache.lucene.document.LatLonShape
-
create indexable fields for point geometry
- createIndexableFields(Shape) - Method in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- createIndexableFields(Shape) - Method in class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
- createIndexableFields(Shape) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- createIndexableFields(Shape, double) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- createIndexableFields(Shape, int) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- createIndexableFields(Shape) - Method in class org.apache.lucene.spatial.serialized.SerializedDVStrategy
-
- createIndexableFields(Shape) - Method in class org.apache.lucene.spatial.SpatialStrategy
-
Returns the IndexableField(s) from the
shape
that are to be
added to the
Document
.
- createIndexableFields(Shape) - Method in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
- createIndexableFields(Point) - Method in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
- CreateIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Create an index.
- CreateIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
-
- createIndexWriterConfig(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Create the
IndexWriterConfig
that would be used for opening the internal index writer.
- createIndexWriterConfig(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter
-
- createInstance() - Method in class org.apache.lucene.collation.CollationAttributeFactory
-
- createInstance() - Method in class org.apache.lucene.collation.ICUCollationAttributeFactory
-
- createInstance() - Method in class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
-
Creates an instance of A
.
- createJoinQuery(String, boolean, String, Query, IndexSearcher, ScoreMode) - Static method in class org.apache.lucene.search.join.JoinUtil
-
Method for query time joining.
- createJoinQuery(String, boolean, String, Class<? extends Number>, Query, IndexSearcher, ScoreMode) - Static method in class org.apache.lucene.search.join.JoinUtil
-
Method for query time joining for numeric fields.
- createJoinQuery(String, Query, Query, IndexSearcher, ScoreMode, OrdinalMap) - Static method in class org.apache.lucene.search.join.JoinUtil
-
- createJoinQuery(String, Query, Query, IndexSearcher, ScoreMode, OrdinalMap, int, int) - Static method in class org.apache.lucene.search.join.JoinUtil
-
A query time join using global ordinals over a dedicated join field.
- createLargeCFS(Directory) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
Setup a large compound file with a number of components, each of
which is a sequential file (so that we can easily tell that we are
reading in the right byte).
- createLink(Path, Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- createLink(Path, Path) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- createMinLength(BreakIterator, int) - Static method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
Breaks will be at least minLength
apart (to the extent possible).
- createMinShouldMatchQuery(String, String, float) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a minimum-should-match query from the query text.
- createNormalizedWeight(Query, boolean) - Method in class org.apache.lucene.search.IndexSearcher
-
- createOffsetsEnumFromReader(LeafReader, int) - Method in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- createOffsetsEnumsForAutomata(Terms, int, List<OffsetsEnum>) - Method in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- createOffsetsEnumsForSpans(LeafReader, int, List<OffsetsEnum>) - Method in class org.apache.lucene.search.uhighlight.PhraseHelper
-
Given the internal SpanQueries, produce a number of OffsetsEnum into the results
param.
- createOffsetsEnumsForTerms(BytesRef[], Terms, int, List<OffsetsEnum>) - Method in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- createOffsetsEnumsWeightMatcher(LeafReader, int, List<OffsetsEnum>) - Method in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.Directory
-
Creates a new, empty file in the directory and returns an
IndexOutput
instance for appending data to this file.
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.FSDirectory
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.NativeUnixDirectory
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- createOutput(String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-
- createPhraseQuery(String, String) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a phrase query from the query text.
- createPhraseQuery(String, String, int) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a phrase query from the query text.
- createPolygonPredicate(Polygon[], Polygon2D) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
-
Create a predicate that checks whether points are within a polygon.
- createPostings() - Static method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- createQueryParser(String, Analyzer) - Method in class org.apache.lucene.queryparser.xml.builders.UserInputQueryBuilder
-
Method to create a QueryParser - designed to be overridden
- createRandomFile(Directory, String, int, byte[]) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
Creates a file of the specified size with random data.
- createRegularPolygon(double, double, double, int) - Static method in class org.apache.lucene.geo.GeoTestUtil
-
Makes an n-gon, centered at the provided lat/lon, and each vertex approximately
distanceMeters away from the center.
- createResults(IndexSearcher, TopFieldDocs, int, CharSequence, boolean, Set<String>, String) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Create the results based on the search hits.
- createResults(IndexSearcher, TopFieldDocs, int, CharSequence, boolean, Set<String>, String) - Method in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
- createSearcher() - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Creates and returns a searcher that can be used to execute arbitrary
Lucene queries and to collect the resulting query results as hits.
- createSegmentResult() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- createSequenceFile(Directory, String, byte, int, byte[], String) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
Creates a file of the specified size with sequential data.
- createSetBasedOnMaxMemory(int) - Static method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- createSetBasedOnQuality(int, float) - Static method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- createSpanQuery(TokenStream, String) - Method in class org.apache.lucene.util.QueryBuilder
-
Creates a span query from the tokenstream.
- createState() - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Returns a new state; state 0 is always the initial state.
- createState() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Create a new state.
- createState() - Method in class org.apache.lucene.util.automaton.Automaton
-
Create a new state.
- createSurfacePoint(Vector) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Compute a GeoPoint that's scaled to actually be on the planet surface.
- createSurfacePoint(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Compute a GeoPoint that's based on (x,y,z) values, but is scaled to actually be on the planet surface.
- createSymbolicLink(Path, Path, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- createSymbolicLink(Path, Path, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- CreateTaxonomyIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Create a taxonomy index.
- CreateTaxonomyIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.CreateTaxonomyIndexTask
-
- createTempDir() - Static method in class org.apache.lucene.util.LuceneTestCase
-
Creates an empty, temporary folder (when the name of the folder is of no importance).
- createTempDir(String) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- createTempFile(String, String) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- createTempFile() - Static method in class org.apache.lucene.util.LuceneTestCase
-
Creates an empty temporary file.
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.Directory
-
Creates a new, empty, temporary file in the directory and returns an
IndexOutput
instance for appending data to this file.
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
-
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.FSDirectory
-
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- createTempOutput(String, String, IOContext) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-
- createTermGroupFacetCollector(String, String, boolean, BytesRef, int) - Static method in class org.apache.lucene.search.grouping.TermGroupFacetCollector
-
Factory method for creating the right implementation based on the fact whether the facet field contains
multiple tokens per documents.
- createTree(EdgeTree[], int, int, boolean) - Static method in class org.apache.lucene.geo.EdgeTree
-
Creates tree from sorted components (with range low and high inclusive)
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.BoostingQuery
-
Deprecated.
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.function.BoostedQuery
-
Deprecated.
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.function.FunctionMatchQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.function.FunctionQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.function.FunctionRangeQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.function.FunctionScoreQuery
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.ComparisonBoolFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.ValueSource
-
Implementations should propagate createWeight to sub-ValueSources which can optionally store
weight info in the context.
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.IfFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.LinearFloatFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.MaxDocValueSource
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.MultiBoolFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.MultiFloatFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.NormValueSource
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.QueryValueSource
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.ScaleFloatFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.SimpleBoolFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.SingleFunction
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.SumTotalTermFreqValueSource
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- createWeight(Map, IndexSearcher) - Method in class org.apache.lucene.queries.function.valuesource.VectorValueSource
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery
-
- createWeight(Query, boolean, float) - Method in class org.apache.lucene.search.AssertingIndexSearcher
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.AssertingQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.BooleanQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.BoostQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.ConstantScoreQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.CoveringQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Create the Weight used to score us
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.DocValuesFieldExistsQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.DocValuesNumbersQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.DocValuesTermsQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
-
- createWeight(Query, boolean, float) - Method in class org.apache.lucene.search.IndexSearcher
-
Creates a
Weight
for the given query, potentially adding caching
if possible and configured.
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.intervals.IntervalQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.join.ParentChildrenBlockJoinQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.MatchAllDocsQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.MatchNoDocsQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.MultiPhraseQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.NormsFieldExistsQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.PhraseQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.PointInSetQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.PointRangeQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.Query
-
Expert: Constructs an appropriate Weight implementation for this query.
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.RandomApproximationQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.AssertingSpanQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanBoostQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanContainingQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanTermQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.spans.SpanWithinQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.suggest.document.ContextQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.suggest.document.PrefixCompletionQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.suggest.document.RegexCompletionQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.SynonymQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.TermInSetQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.search.TermQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.spatial.composite.CompositeVerifyQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.spatial.composite.IntersectsRPTVerifyQuery
-
- createWeight(IndexSearcher, boolean, float) - Method in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery
-
- createWriterConfig(Config, PerfRunData, IndexWriterConfig.OpenMode, IndexCommit) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
-
- crosses(PlanetModel, Plane, GeoPoint[], GeoPoint[], Membership[], Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Determine whether the plane crosses another plane within the
bounds provided.
- crossesDateline() - Method in class org.apache.lucene.geo.Rectangle
-
Returns true if this bounding box crosses the dateline
- crossesDateline() - Method in class org.apache.lucene.geo.Rectangle2D
-
- crossProductEvaluateIsZero(Vector, Vector, Vector) - Static method in class org.apache.lucene.spatial3d.geom.Vector
-
Evaluate the cross product of two vectors against a point.
- CSVUtil - Class in org.apache.lucene.analysis.ja.util
-
Utility class for parsing CSV text
- CSVUtil - Class in org.apache.lucene.analysis.ko.util
-
Utility class for parsing CSV text
- ctx - Variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
- ctx - Variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- ctx - Variable in class org.apache.lucene.spatial.SpatialStrategy
-
- cud - Variable in class org.apache.lucene.queryparser.ext.Extensions.Pair
-
- cur - Variable in class org.apache.lucene.queryparser.ext.Extensions.Pair
-
- curChar - Variable in class org.apache.lucene.queryparser.classic.QueryParserTokenManager
-
- curChar - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
- curChar - Variable in class org.apache.lucene.queryparser.surround.parser.QueryParserTokenManager
-
- curNRTCopy - Variable in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Non-null when we are currently copying files from a new NRT point:
- curPos - Variable in class org.apache.lucene.search.suggest.BufferedInputIterator
-
current buffer position
- current() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- current - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- current - Variable in class org.apache.lucene.search.ReferenceManager
-
- current() - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- current() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- current() - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- current() - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- current() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
- current() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
- currentField - Variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter.LimitedStoredFieldVisitor
-
- currentNodeVersions - Variable in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- currentReaderValues - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
-
- currentRevisionFiles() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyReplicationHandler
-
- currentRevisionFiles() - Method in class org.apache.lucene.replicator.IndexReplicationHandler
-
- currentRevisionFiles() - Method in interface org.apache.lucene.replicator.ReplicationClient.ReplicationHandler
-
Returns the current revision files held by the handler.
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.queries.payloads.AveragePayloadFunction
-
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.queries.payloads.MaxPayloadFunction
-
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.queries.payloads.MinPayloadFunction
-
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.queries.payloads.PayloadFunction
-
Calculate the score up to this point for this doc and field
- currentScore(int, String, int, int, int, float, float) - Method in class org.apache.lucene.queries.payloads.SumPayloadFunction
-
- currentToken - Variable in exception org.apache.lucene.queryparser.classic.ParseException
-
This is the last token that has been consumed successfully.
- currentToken - Variable in exception org.apache.lucene.queryparser.flexible.standard.parser.ParseException
-
This is the last token that has been consumed successfully.
- currentToken - Variable in exception org.apache.lucene.queryparser.surround.parser.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
- currentValue() - Method in class org.apache.lucene.search.grouping.GroupSelector
-
Get the group value of the current document
N.B.
- currentValue() - Method in class org.apache.lucene.search.grouping.TermGroupSelector
-
- currentValue() - Method in class org.apache.lucene.search.grouping.ValueSourceGroupSelector
-
- currentVersion() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyReplicationHandler
-
- currentVersion() - Method in class org.apache.lucene.replicator.IndexReplicationHandler
-
- currentVersion() - Method in interface org.apache.lucene.replicator.ReplicationClient.ReplicationHandler
-
Returns the current revision version held by the handler.
- cursor - Variable in class org.tartarus.snowball.SnowballProgram
-
- CustomAnalyzer - Class in org.apache.lucene.analysis.custom
-
A general-purpose Analyzer that can be created with a builder-style API.
- CustomAnalyzer.Builder - Class in org.apache.lucene.analysis.custom
-
- CustomAnalyzer.ConditionBuilder - Class in org.apache.lucene.analysis.custom
-
- customExplain(int, Explanation, Explanation[]) - Method in class org.apache.lucene.queries.CustomScoreProvider
-
Explain the custom score.
- customExplain(int, Explanation, Explanation) - Method in class org.apache.lucene.queries.CustomScoreProvider
-
Explain the custom score.
- customScore(int, float, float[]) - Method in class org.apache.lucene.queries.CustomScoreProvider
-
Compute a custom score by the subQuery score and a number of
FunctionQuery
scores.
- customScore(int, float, float) - Method in class org.apache.lucene.queries.CustomScoreProvider
-
Compute a custom score by the subQuery score and the
FunctionQuery
score.
- CustomScoreProvider - Class in org.apache.lucene.queries
-
- CustomScoreProvider(LeafReaderContext) - Constructor for class org.apache.lucene.queries.CustomScoreProvider
-
Creates a new instance of the provider class for the given
IndexReader
.
- CustomScoreQuery - Class in org.apache.lucene.queries
-
- CustomScoreQuery(Query) - Constructor for class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
Create a CustomScoreQuery over input subQuery.
- CustomScoreQuery(Query, FunctionQuery) - Constructor for class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
Create a CustomScoreQuery over input subQuery and a
FunctionQuery
.
- CustomScoreQuery(Query, FunctionQuery...) - Constructor for class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
Create a CustomScoreQuery over input subQuery and a
FunctionQuery
.
- CustomSeparatorBreakIterator - Class in org.apache.lucene.search.uhighlight
-
A BreakIterator
that breaks the text whenever a certain separator, provided as a constructor argument, is found.
- CustomSeparatorBreakIterator(char) - Constructor for class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- CYRILLIC - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- CYRILLIC - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- CzechAnalyzer - Class in org.apache.lucene.analysis.cz
-
- CzechAnalyzer() - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
- CzechAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Builds an analyzer with the given stop words.
- CzechAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Builds an analyzer with the given stop words and a set of work to be
excluded from the
CzechStemFilter
.
- CzechStemFilter - Class in org.apache.lucene.analysis.cz
-
- CzechStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.cz.CzechStemFilter
-
- CzechStemFilterFactory - Class in org.apache.lucene.analysis.cz
-
- CzechStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.cz.CzechStemFilterFactory
-
Creates a new CzechStemFilterFactory
- CzechStemmer - Class in org.apache.lucene.analysis.cz
-
Light Stemmer for Czech.
- CzechStemmer() - Constructor for class org.apache.lucene.analysis.cz.CzechStemmer
-
- D - Variable in class org.apache.lucene.spatial3d.geom.Plane
-
Ax + By + Cz + D = 0
- DaciukMihovAutomatonBuilder - Class in org.apache.lucene.util.automaton
-
Builds a minimal, deterministic
Automaton
that accepts a set of
strings.
- DaitchMokotoffSoundexFilter - Class in org.apache.lucene.analysis.phonetic
-
Create tokens for phonetic matches based on Daitch–Mokotoff Soundex.
- DaitchMokotoffSoundexFilter(TokenStream, boolean) - Constructor for class org.apache.lucene.analysis.phonetic.DaitchMokotoffSoundexFilter
-
Creates a DaitchMokotoffSoundexFilter by either adding encoded forms as synonyms (
inject=true
) or replacing them.
- DaitchMokotoffSoundexFilterFactory - Class in org.apache.lucene.analysis.phonetic
-
- DaitchMokotoffSoundexFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.phonetic.DaitchMokotoffSoundexFilterFactory
-
Creates a new PhoneticFilterFactory
- DAMMA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- DAMMATAN - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- DanishAnalyzer - Class in org.apache.lucene.analysis.da
-
- DanishAnalyzer() - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
-
- DanishAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
-
Builds an analyzer with the given stop words.
- DanishAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.da.DanishAnalyzer
-
Builds an analyzer with the given stop words.
- DanishStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- DanishStemmer() - Constructor for class org.tartarus.snowball.ext.DanishStemmer
-
- data - Variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Deprecated.
The key to the node.
- DATA_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene60.Lucene60PointsFormat
-
Filename extension for the leaf blocks
- DataInput - Class in org.apache.lucene.store
-
Abstract base class for performing read operations of Lucene's low-level
data types.
- DataInput() - Constructor for class org.apache.lucene.store.DataInput
-
- dataOut - Variable in class org.apache.lucene.codecs.lucene60.Lucene60PointsWriter
-
Output used to write the BKD tree data file
- 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
-
- DatasetSplitter - Class in org.apache.lucene.classification.utils
-
Utility class for creating training / test / cross validation indexes from the original index.
- DatasetSplitter(double, double) - Constructor for class org.apache.lucene.classification.utils.DatasetSplitter
-
- DATE_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- DATE_MSEC_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- DATE_PATTERN - Static variable in class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilterFactory
-
- DATE_RESOLUTION - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
- DATE_TYPE - Static variable in class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilter
-
- DateRangePrefixTree - Class in org.apache.lucene.spatial.prefix.tree
-
A PrefixTree for date ranges in which the levels of the tree occur at natural periods of time (e.g.
- DateRangePrefixTree(Calendar) - Constructor for class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Constructs with the specified calendar used as a template to be cloned whenever a new
Calendar needs to be created.
- DateRecognizerFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Filters all tokens that cannot be parsed to a date, using the provided DateFormat
.
- DateRecognizerFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilter
-
Uses DateFormat.DEFAULT
and Locale.ENGLISH
to create a DateFormat
instance.
- DateRecognizerFilter(TokenStream, DateFormat) - Constructor for class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilter
-
- DateRecognizerFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- DateRecognizerFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilterFactory
-
Creates a new FingerprintFilterFactory
- DateTools - Class in org.apache.lucene.document
-
Provides support for converting dates to strings and vice-versa.
- DateTools.Resolution - Enum in org.apache.lucene.document
-
Specifies the time granularity.
- dateToString(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Converts a Date to a string suitable for indexing.
- DBBI_AVAILABLE - Static variable in class org.apache.lucene.analysis.th.ThaiTokenizer
-
True if the JRE supports a working dictionary-based breakiterator for Thai.
- DecimalDigitFilter - Class in org.apache.lucene.analysis.core
-
Folds all Unicode digits in [:General_Category=Decimal_Number:]
to Basic Latin digits (0-9
).
- DecimalDigitFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.core.DecimalDigitFilter
-
Creates a new DecimalDigitFilter over input
- DecimalDigitFilterFactory - Class in org.apache.lucene.analysis.core
-
- DecimalDigitFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.core.DecimalDigitFilterFactory
-
Creates a new DecimalDigitFilterFactory
- decode(byte[]) - Static method in class org.apache.lucene.document.InetAddressPoint
-
Decodes InetAddress value from binary encoding
- decode(BytesRef, IntsRef) - Method in class org.apache.lucene.facet.taxonomy.DocValuesOrdinalsReader
-
Subclass and override if you change the encoding.
- decode(BytesRef, ByteArrayDataInput) - Method in class org.apache.lucene.search.suggest.SortedInputIterator
-
decodes the weight at the current position
- decode(long[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
Read iterations * blockCount()
blocks from blocks
,
decode them and write iterations * valueCount()
values into
values
.
- decode(byte[], int, long[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
Read 8 * iterations * blockCount()
blocks from blocks
,
decode them and write iterations * valueCount()
values into
values
.
- decode(long[], int, int[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
Read iterations * blockCount()
blocks from blocks
,
decode them and write iterations * valueCount()
values into
values
.
- decode(byte[], int, int[], int, int) - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
Read 8 * iterations * blockCount()
blocks from blocks
,
decode them and write iterations * valueCount()
values into
values
.
- decodeContexts(BytesRef, ByteArrayDataInput) - Method in class org.apache.lucene.search.suggest.SortedInputIterator
-
decodes the contexts at the current position
- decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.BigIntegerPoint
-
Decode single BigInteger dimension
- decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.DoublePoint
-
Decode single double dimension
- decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.FloatPoint
-
Decode single float dimension
- decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Decode single float dimension
- decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.IntPoint
-
Decode single integer dimension
- decodeDimension(byte[], int) - Static method in class org.apache.lucene.document.LongPoint
-
Decode single long dimension
- decodeDimension(byte[], int) - Static method in class org.apache.lucene.spatial3d.Geo3DPoint
-
Decode single dimension
- decodeFloat(byte[]) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
-
- decodeFloat(byte[], int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
-
- decodeInt(byte[], int) - Static method in class org.apache.lucene.analysis.payloads.PayloadHelper
-
- decodeLatitude(int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
-
- decodeLatitude(byte[], int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
-
Turns quantized value from byte array back into a double.
- decodeLatitude(long) - Static method in class org.apache.lucene.spatial.util.MortonEncoder
-
decode latitude value from morton encoded geo point
- decodeLongitude(int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
-
- decodeLongitude(byte[], int) - Static method in class org.apache.lucene.geo.GeoEncodingUtils
-
Turns quantized value from byte array back into a double.
- decodeLongitude(long) - Static method in class org.apache.lucene.spatial.util.MortonEncoder
-
decode longitude value from morton encoded geo point
- decodePayload(BytesRef, ByteArrayDataInput) - Method in class org.apache.lucene.search.suggest.SortedInputIterator
-
decodes the payload at the current position
- decodePoint(long) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Decode GeoPoint value from long docvalues value.
- decodeTerm(long[], DataInput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- decodeTerm(long[], DataInput, FieldInfo, BlockTermState, boolean) - Method in class org.apache.lucene.codecs.PostingsReaderBase
-
Actually decode metadata for next term
- decodeTriangle(byte[], int[]) - Static method in class org.apache.lucene.document.LatLonShape
-
- decodeXValue(long) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Decode X value from long docvalues value.
- decodeYValue(long) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Decode Y value from long docvalues value.
- decodeZValue(long) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Decode Z value from long docvalues value.
- decompose() - Method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- decompose() - Method in class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
- decompose() - Method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
- decompose(CharSequence) - Method in class org.egothor.stemmer.MultiTrie2
-
Break the given patch command into its constituent pieces.
- DecompoundToken - Class in org.apache.lucene.analysis.ko
-
A token that was generated from a compound.
- DecompoundToken(POS.Tag, String, int, int) - Constructor for class org.apache.lucene.analysis.ko.DecompoundToken
-
Creates a new DecompoundToken
- decompress(DataInput, int, int, int, BytesRef) - Method in class org.apache.lucene.codecs.compressing.Decompressor
-
Decompress bytes that were stored between offsets offset
and
offset+length
in the original stream from the compressed
stream in
to bytes
.
- Decompressor - Class in org.apache.lucene.codecs.compressing
-
A decompressor.
- Decompressor() - Constructor for class org.apache.lucene.codecs.compressing.Decompressor
-
Sole constructor, typically called from sub-classes.
- decRef(SearcherTaxonomyManager.SearcherAndTaxonomy) - Method in class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
- decRef() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Expert: decreases the refCount of this TaxonomyReader instance.
- decRef() - Method in class org.apache.lucene.index.IndexReader
-
Expert: decreases the refCount of this IndexReader
instance.
- decRef(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-
- decRef(G) - Method in class org.apache.lucene.search.ReferenceManager
-
Decrement reference counting on the given reference.
- decRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
-
- decRef() - Method in class org.apache.lucene.util.RefCount
-
Decrements the reference counting of this object.
- decRefDeleter(SegmentInfos) - Method in class org.apache.lucene.index.IndexWriter
-
Record that the files referenced by this
SegmentInfos
are no longer in use.
- dedupAndEncode(IntsRef) - Method in class org.apache.lucene.facet.FacetsConfig
-
Encodes ordinals into a BytesRef; expert: subclass can
override this to change encoding.
- deepCopyOf(BytesRef) - Static method in class org.apache.lucene.util.BytesRef
-
Creates a new BytesRef that points to a copy of the bytes from
other
- deepCopyOf(CharsRef) - Static method in class org.apache.lucene.util.CharsRef
-
Creates a new CharsRef that points to a copy of the chars from
other
- deepCopyOf(IntsRef) - Static method in class org.apache.lucene.util.IntsRef
-
Creates a new IntsRef that points to a copy of the ints from
other
- deepCopyOf(LongsRef) - Static method in class org.apache.lucene.util.LongsRef
-
Creates a new LongsRef that points to a copy of the longs from
other
- DEFAULT - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- DEFAULT - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- DEFAULT - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
Lexical state.
- DEFAULT - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
Lexical state.
- DEFAULT - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
Lexical state.
- DEFAULT - Static variable in class org.apache.lucene.store.IOContext
-
- DEFAULT - Static variable in class org.apache.lucene.util.packed.PackedInts
-
At most 25% memory overhead.
- DEFAULT_ACCURACY - Static variable in class org.apache.lucene.search.spell.SpellChecker
-
- DEFAULT_ALL_TERMS_REQUIRED - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Default boolean clause option for multiple terms matching (all terms required).
- DEFAULT_ARTICLES - Static variable in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Default set of articles for ElisionFilter
- DEFAULT_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.util.AttributeFactory
-
This is the default factory that creates
AttributeImpl
s using the
class name of the supplied
Attribute
interface class by appending
Impl
to it.
- DEFAULT_BOOST - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Boost terms in query based on score.
- DEFAULT_BOUNDARY_CHARS - Static variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- DEFAULT_BUCKET_COUNT - Static variable in class org.apache.lucene.analysis.minhash.MinHashFilter
-
- DEFAULT_BUCKETS - Static variable in class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Default number of buckets.
- DEFAULT_BUCKETS - Static variable in class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
-
Default number of buckets.
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.lucene.analysis.core.KeywordTokenizer
-
Default read buffer size
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.lucene.util.packed.PackedInts
-
Default amount of memory to use for bulk operations.
- DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- DEFAULT_BUFFERED_BLOCKS - Static variable in class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- DEFAULT_BUFFERSIZE - Static variable in class org.apache.lucene.store.BufferedChecksum
-
Default buffer size: 256
- DEFAULT_CACHE_CHARS_THRESHOLD - Static variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- DEFAULT_CAL - Static variable in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
The Java platform default Calendar
with UTC & ROOT Locale.
- DEFAULT_CAPACITY - Static variable in class org.apache.lucene.util.BytesRefHash
-
- DEFAULT_CLOSE_INDEXWRITER_ON_BUILD - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Default option to close the IndexWriter once the index has been built.
- DEFAULT_COMMIT_ON_CLOSE - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
- DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.search.spell.SuggestWordQueue
-
Default comparator: score then frequency.
- DEFAULT_COMPARATOR - Static variable in class org.apache.lucene.util.OfflineSorter
-
Default comparator: sorts in binary (codepoint) order
- DEFAULT_CONNECTION_TIMEOUT - Static variable in class org.apache.lucene.replicator.http.HttpClientBase
-
Default connection timeout for this client, in milliseconds.
- DEFAULT_CPU_CORE_COUNT_PROPERTY - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Used for testing.
- DEFAULT_DECOMPOUND - Static variable in class org.apache.lucene.analysis.ko.KoreanTokenizer
-
- DEFAULT_DELIMITER - Static variable in class org.apache.lucene.analysis.miscellaneous.DelimitedTermFrequencyTokenFilter
-
- DEFAULT_DELIMITER - Static variable in class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- DEFAULT_DELIMITER - Static variable in class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- DEFAULT_DELIMITER - Static variable in class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilter
-
- DEFAULT_DIM_CONFIG - Static variable in class org.apache.lucene.facet.FacetsConfig
-
Default per-dimension configuration.
- DEFAULT_DISTERRPCT - Static variable in class org.apache.lucene.spatial.query.SpatialArgs
-
- DEFAULT_EXTENSION_FIELD_DELIMITER - Static variable in class org.apache.lucene.queryparser.ext.Extensions
-
The default extension field delimiter character.
- DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.lucene.search.suggest.FileDictionary
-
Tab-delimited fields are most common thus the default, but one can override this via the constructor
- DEFAULT_FIELD_MATCH - Static variable in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
- DEFAULT_FIELD_NAMES - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Default field names.
- DEFAULT_FIELDS - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
Fields to be written by default
- DEFAULT_FIELDTYPE - Static variable in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
pointValues, docValues, and nothing else.
- DEFAULT_FIELDTYPE - Static variable in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
pointValues, docValues, and nothing else.
- DEFAULT_FILLER_TOKEN - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
filler token for when positionIncrement is more than 1
- DEFAULT_FUNCTIONS - Static variable in class org.apache.lucene.expressions.js.JavascriptCompiler
-
The default set of functions available to expressions.
- DEFAULT_GRAMS - Static variable in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
By default we use a bigram model.
- DEFAULT_HASH_COUNT - Static variable in class org.apache.lucene.analysis.minhash.MinHashFilter
-
- DEFAULT_HASH_SET_SIZE - Static variable in class org.apache.lucene.analysis.minhash.MinHashFilter
-
- DEFAULT_HIGHLIGHT - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Default higlighting option.
- DEFAULT_INDEX_FIELD_NAME - Static variable in class org.apache.lucene.facet.FacetsConfig
-
Which Lucene field holds the drill-downs and ords (as
doc values).
- DEFAULT_LINE_DOCS_FILE - Static variable in class org.apache.lucene.util.LuceneTestCase
-
TODO: javadoc?
- DEFAULT_LOG_STEP - Static variable in class org.apache.lucene.benchmark.Constants
-
- DEFAULT_MAX_BITS_PER_BLOCK - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
-
- DEFAULT_MAX_BLOCK_BITS - Static variable in class org.apache.lucene.util.fst.FST
-
- DEFAULT_MAX_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
-
- DEFAULT_MAX_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsWriter
-
- DEFAULT_MAX_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsWriter
-
- DEFAULT_MAX_BUFFERED - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
-
- DEFAULT_MAX_BUFFERED_DELETE_TERMS - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Disabled by default (because IndexWriter flushes by RAM usage by default).
- DEFAULT_MAX_BUFFERED_DOCS - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Disabled by default (because IndexWriter flushes by RAM usage by default).
- DEFAULT_MAX_CFS_SEGMENT_SIZE - Static variable in class org.apache.lucene.index.MergePolicy
-
Default max segment size in order to use compound file system.
- DEFAULT_MAX_CHARS_TO_ANALYZE - Static variable in class org.apache.lucene.search.highlight.Highlighter
-
- DEFAULT_MAX_CHUNK_SIZE - Static variable in class org.apache.lucene.store.MMapDirectory
-
Default max chunk size.
- DEFAULT_MAX_CODE_LENGTH - Static variable in class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilterFactory
-
default maxCodeLength if not specified
- DEFAULT_MAX_DETERMINIZED_STATES - Static variable in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
- DEFAULT_MAX_DETERMINIZED_STATES - Static variable in class org.apache.lucene.util.automaton.Operations
-
- DEFAULT_MAX_DOC_FREQ - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Ignore words which occur in more than this many docs.
- DEFAULT_MAX_EDITS - Static variable in class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
The default maximum number of edits for fuzzy
suggestions.
- DEFAULT_MAX_EDITS - Static variable in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
The default maximum number of edits for fuzzy
suggestions.
- DEFAULT_MAX_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
-
- DEFAULT_MAX_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
- DEFAULT_MAX_GRAPH_EXPANSIONS - Static variable in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
- DEFAULT_MAX_LENGTH - Static variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- DEFAULT_MAX_LEVELS - Static variable in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- DEFAULT_MAX_MB_SORT_IN_HEAP - Static variable in class org.apache.lucene.util.bkd.BKDWriter
-
Default maximum heap to use, before spilling to (slower) disk
- DEFAULT_MAX_MERGE_DOCS - Static variable in class org.apache.lucene.index.LogMergePolicy
-
Default maximum segment size.
- DEFAULT_MAX_MERGE_MB - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Default maximum segment size.
- DEFAULT_MAX_MERGE_MB_FOR_FORCED_MERGE - Static variable in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Default maximum segment size.
- DEFAULT_MAX_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
- DEFAULT_MAX_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenizer
-
- DEFAULT_MAX_NUM_TOKENS_PARSED - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Default maximum number of tokens to parse in each example doc field that is not stored with TermVector support.
- DEFAULT_MAX_OUTPUT_TOKEN_SIZE - Static variable in class org.apache.lucene.analysis.miscellaneous.FingerprintFilter
-
- DEFAULT_MAX_POINTS_IN_LEAF_NODE - Static variable in class org.apache.lucene.util.bkd.BKDWriter
-
Default maximum number of point in each leaf block
- DEFAULT_MAX_QUERY_TERMS - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Return a Query with no more than this many terms.
- DEFAULT_MAX_SCAN - Static variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- DEFAULT_MAX_SHINGLE_SIZE - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
default maximum shingle size is 2.
- DEFAULT_MAX_SUBWORD_SIZE - Static variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
The default for maximal length of subwords that get propagated to the output of this filter
- DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilter
-
- DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.MockTokenizer
-
- 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_MAX_WORD_COUNT - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilter
-
- DEFAULT_MAX_WORD_LEN - Static variable in class org.apache.lucene.analysis.util.CharTokenizer
-
- DEFAULT_MAX_WORD_LENGTH - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Ignore words greater than this length or if 0 then this has no effect.
- DEFAULT_MAXIMUM_DOCUMENTS - Static variable in class org.apache.lucene.benchmark.Constants
-
- DEFAULT_MERGE_BUFFER_SIZE - Static variable in class org.apache.lucene.store.NativeUnixDirectory
-
Default buffer size before writing to disk (256 KB);
larger means less IO load but more RAM and direct
buffer storage space consumed during merging.
- 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_MERGE_PFACTOR - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
-
- DEFAULT_MIN_BITS_PER_BLOCK - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
-
- DEFAULT_MIN_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.blocktree.BlockTreeTermsWriter
-
- DEFAULT_MIN_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsWriter
-
- DEFAULT_MIN_BLOCK_SIZE - Static variable in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsWriter
-
- DEFAULT_MIN_BYTES_DIRECT - Static variable in class org.apache.lucene.store.NativeUnixDirectory
-
Default min expected merge size before direct IO is
used (10 MB):
- DEFAULT_MIN_DOC_FREQ - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Ignore words which do not occur in at least this many docs.
- DEFAULT_MIN_FUZZY_LENGTH - Static variable in class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
- DEFAULT_MIN_FUZZY_LENGTH - Static variable in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
The default minimum length of the key before any edits are allowed.
- DEFAULT_MIN_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
-
- DEFAULT_MIN_GRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenizer
-
- DEFAULT_MIN_LENGTH - Static variable in class org.apache.lucene.analysis.stempel.StempelFilter
-
Minimum length of input words to be processed.
- 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_MIN_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
- DEFAULT_MIN_NGRAM_SIZE - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenizer
-
- DEFAULT_MIN_PREFIX_CHARS - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Default minimum number of leading characters before
PrefixQuery is used (4).
- DEFAULT_MIN_SHINGLE_SIZE - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
default minimum shingle size is 2.
- DEFAULT_MIN_SUBWORD_SIZE - Static variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
The default for minimal length of subwords that get propagated to the output of this filter
- DEFAULT_MIN_TERM_FREQ - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Ignore terms with less than this frequency in the source doc.
- DEFAULT_MIN_WORD_LENGTH - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Ignore words less than this length or if 0 then this has no effect.
- DEFAULT_MIN_WORD_SIZE - Static variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
The default for minimal word length that gets decomposed
- DEFAULT_MIN_WRITTEN_BYTES - Static variable in class org.apache.lucene.util.ThrottledIndexOutput
-
- DEFAULT_MINIMUM_LENGTH - Static variable in class org.apache.lucene.analysis.ja.JapaneseKatakanaStemFilter
-
- DEFAULT_MODE - Static variable in class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
Default tokenization mode.
- DEFAULT_NO_CFS_RATIO - Static variable in class org.apache.lucene.index.LogMergePolicy
-
Default noCFSRatio.
- DEFAULT_NO_CFS_RATIO - Static variable in class org.apache.lucene.index.MergePolicy
-
Default ratio for compound file system usage.
- DEFAULT_NO_CFS_RATIO - Static variable in class org.apache.lucene.index.TieredMergePolicy
-
Default noCFSRatio.
- DEFAULT_NON_FUZZY_PREFIX - Static variable in class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
The default prefix length where edits are not allowed.
- DEFAULT_NON_FUZZY_PREFIX - Static variable in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
The default prefix length where edits are not allowed.
- DEFAULT_NUM_FACTOR - Static variable in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
Default factor
- DEFAULT_NUMTERMS - Static variable in class org.apache.lucene.misc.HighFreqTerms
-
- DEFAULT_OPERATOR - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the default boolean operator
- DEFAULT_PATH_TYPE - Static variable in class org.apache.lucene.benchmark.byTask.feeds.TrecDocParser
-
trec parser type used for unknown extensions
- DEFAULT_PHRASE_HIGHLIGHT - Static variable in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
- DEFAULT_POLL_INTERVAL - Static variable in class org.apache.lucene.store.SleepingLockWrapper
-
- DEFAULT_PRESERVE_ORIGINAL - Static variable in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
-
- DEFAULT_PRESERVE_ORIGINAL - Static variable in class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
- DEFAULT_PRESERVE_POSITION_INCREMENTS - Static variable in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
- DEFAULT_PRESERVE_SEP - Static variable in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
- DEFAULT_RAM_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Default value is 16 MB (which means flush when buffered docs consume
approximately 16 MB RAM).
- DEFAULT_RAM_FLUSH_MB - Static variable in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
-
- DEFAULT_RAM_PER_THREAD_HARD_LIMIT_MB - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Default value is 1945.
- DEFAULT_READER_POOLING - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
- DEFAULT_RESOLUTION - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
- DEFAULT_RUN_COUNT - Static variable in class org.apache.lucene.benchmark.Constants
-
- DEFAULT_SCALE_UP - Static variable in class org.apache.lucene.benchmark.Constants
-
- DEFAULT_SEPARATOR - Static variable in class org.apache.lucene.analysis.miscellaneous.FingerprintFilter
-
- DEFAULT_SEPARATOR - Static variable in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
The default character used to join multiple tokens
into a single ngram token.
- DEFAULT_SESSION_EXPIRATION_THRESHOLD - Static variable in class org.apache.lucene.replicator.LocalReplicator
-
Threshold for expiring inactive sessions.
- DEFAULT_SKIP - Static variable in class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- DEFAULT_SKIP - Static variable in class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- DEFAULT_SO_TIMEOUT - Static variable in class org.apache.lucene.replicator.http.HttpClientBase
-
Default socket timeout for this client, in milliseconds.
- DEFAULT_SPINS_PROPERTY - Static variable in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Used for testing.
- DEFAULT_SPLIT_ON_WHITESPACE - Static variable in class org.apache.lucene.queryparser.classic.QueryParser
-
default split on whitespace behavior
- DEFAULT_STEMMER_FILE - Static variable in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
File containing default Polish stemmer table.
- DEFAULT_STOP_TAGS - Static variable in class org.apache.lucene.analysis.ko.KoreanPartOfSpeechStopFilter
-
Default list of tags to filter.
- DEFAULT_STOP_WORDS - Static variable in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Default set of stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
File containing default Arabic stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
File containing default Bulgarian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.bn.BengaliAnalyzer
-
File containing default Bengali stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
File containing default Brazilian Portuguese stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
File containing default Catalan stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
File containing default CJK stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.ckb.SoraniAnalyzer
-
File containing default Kurdish stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.cz.CzechAnalyzer
-
File containing default Czech stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.da.DanishAnalyzer
-
File containing default Danish stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.de.GermanAnalyzer
-
File containing default German stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.el.GreekAnalyzer
-
File containing default Greek stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.es.SpanishAnalyzer
-
File containing default Spanish stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
File containing default Basque stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
File containing default Persian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
File containing default Italian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
File containing default French stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.ga.IrishAnalyzer
-
File containing default Irish stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
File containing default Galician stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.hi.HindiAnalyzer
-
File containing default Hindi stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
File containing default Hungarian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
File containing default Armenian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
File containing default Indonesian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.it.ItalianAnalyzer
-
File containing default Italian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.lt.LithuanianAnalyzer
-
File containing default Lithuanian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
File containing default Latvian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
File containing default Dutch stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
File containing default Norwegian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
File containing default Polish stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
File containing default Portuguese stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
File containing default Romanian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.ru.RussianAnalyzer
-
File containing default Russian stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
File containing default Swedish stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.th.ThaiAnalyzer
-
File containing default Thai stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
File containing default Turkish stopwords.
- DEFAULT_STOPWORD_FILE - Static variable in class org.apache.lucene.analysis.uk.UkrainianMorfologikAnalyzer
-
File containing default Ukrainian stopwords.
- DEFAULT_SUFFICIENT_FIELDS - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
Default fields which at least one of them is required to not skip the doc.
- DEFAULT_SYSOUT_BYTES_THRESHOLD - Static variable in class org.apache.lucene.util.TestRuleLimitSysouts
-
Max limit of bytes printed to either System.out
or System.err
.
- DEFAULT_TERM_INDEX_INTERVAL - Static variable in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexWriter
-
- DEFAULT_TOKEN_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.analysis.TokenStream
-
- DEFAULT_TOKEN_SEPARATOR - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
The default string to use when joining adjacent tokens to form a shingle
- DEFAULT_TOKEN_TYPE - Static variable in class org.apache.lucene.analysis.shingle.ShingleFilter
-
default token type attribute value is "shingle"
- DEFAULT_TRANSPOSITIONS - Static variable in class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
- DEFAULT_TRANSPOSITIONS - Static variable in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
- DEFAULT_TYPE - Static variable in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
-
the default type
- DEFAULT_UNICODE_AWARE - Static variable in class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
Measure maxEdits, minFuzzyLength, transpositions and nonFuzzyPrefix
parameters in Unicode code points (actual letters)
instead of bytes.
- DEFAULT_UNICODE_AWARE - Static variable in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Measure maxEdits, minFuzzyLength, transpositions and nonFuzzyPrefix
parameters in Unicode code points (actual letters)
instead of bytes.
- DEFAULT_USE_COMPOUND_FILE_SYSTEM - Static variable in class org.apache.lucene.index.IndexWriterConfig
-
Default value for compound file system for newly written segments
(set to true
).
- DEFAULT_WORD_DELIM_TABLE - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
-
- DefaultBloomFilterFactory - Class in org.apache.lucene.codecs.bloom
-
Default policy is to allocate a bitset with 10% saturation given a unique term per document.
- DefaultBloomFilterFactory() - Constructor for class org.apache.lucene.codecs.bloom.DefaultBloomFilterFactory
-
- DefaultBulkScorer(Scorer) - Constructor for class org.apache.lucene.search.Weight.DefaultBulkScorer
-
Sole constructor.
- DefaultCollectionModel() - Constructor for class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
-
Sole constructor: parameter-free
- DefaultEncoder - Class in org.apache.lucene.search.highlight
-
Simple
Encoder
implementation that does not modify the output
- DefaultEncoder() - Constructor for class org.apache.lucene.search.highlight.DefaultEncoder
-
- defaultField - Variable in class org.apache.lucene.queryparser.xml.CoreParser
-
- defaultFieldValuesArrayLen - Variable in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- DefaultICUTokenizerConfig - Class in org.apache.lucene.analysis.icu.segmentation
-
- DefaultICUTokenizerConfig(boolean, boolean) - Constructor for class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
Creates a new config.
- defaultLength - Variable in class org.apache.lucene.spatial.util.ShapeFieldCache
-
- defaultMaxDocFreqPercent - Static variable in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
- defaultMaxEdits - Static variable in class org.apache.lucene.search.FuzzyQuery
-
- defaultMaxExpansions - Static variable in class org.apache.lucene.search.FuzzyQuery
-
- defaultMinSimilarity - Static variable in class org.apache.lucene.search.FuzzyQuery
-
- DefaultPassageFormatter - Class in org.apache.lucene.search.uhighlight
-
Creates a formatted snippet from the top passages.
- DefaultPassageFormatter() - Constructor for class org.apache.lucene.search.uhighlight.DefaultPassageFormatter
-
Creates a new DefaultPassageFormatter with the default tags.
- DefaultPassageFormatter(String, String, String, boolean) - Constructor for class org.apache.lucene.search.uhighlight.DefaultPassageFormatter
-
Creates a new DefaultPassageFormatter with custom tags.
- DefaultPhraseSlopQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- DefaultPhraseSlopQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.DefaultPhraseSlopQueryNodeProcessor
-
- defaultPrefixLength - Static variable in class org.apache.lucene.search.FuzzyQuery
-
- defaultSize - Variable in class org.apache.lucene.spatial.util.ShapeFieldCacheProvider
-
- DefaultSortedSetDocValuesReaderState - Class in org.apache.lucene.facet.sortedset
-
- DefaultSortedSetDocValuesReaderState(IndexReader) - Constructor for class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
- DefaultSortedSetDocValuesReaderState(IndexReader, String) - Constructor for class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
Creates this, pulling doc values from the specified
field.
- defaultTaxonomyWriterCache() - Static method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- defaultTranspositions - Static variable in class org.apache.lucene.search.FuzzyQuery
-
- defaultVal - Variable in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- DefFunction - Class in org.apache.lucene.queries.function.valuesource
-
ValueSource
implementation which only returns the values from the provided
ValueSources which are available for a particular docId.
- DefFunction(List<ValueSource>) - Constructor for class org.apache.lucene.queries.function.valuesource.DefFunction
-
- deinterleave(long) - Static method in class org.apache.lucene.util.BitUtil
-
Extract just the even-bits value as a long from the bit-interleaved value
- delCount - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- delCountOnFlush - Variable in class org.apache.lucene.index.SegmentWriteState
-
Number of deleted documents set while flushing the
segment.
- delegate - Variable in class org.apache.lucene.codecs.FilterCodec
-
The codec to filter.
- delegate - Variable in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
The underlying AsynchronousFileChannel
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterDirectoryStream
-
The underlying DirectoryStream
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterFileChannel
-
The underlying FileChannel
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterFileStore
-
The underlying FileStore
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterFileSystem
-
The underlying FileSystem
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
The underlying FileSystemProvider
.
- delegate - Variable in class org.apache.lucene.mockfile.FilterInputStream2
-
The underlying InputStream
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterOutputStream2
-
The underlying OutputStream
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterPath
-
The underlying Path
instance.
- delegate - Variable in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
The underlying SeekableByteChannel
instance.
- delegatePostingsFormat() - Method in class org.apache.lucene.search.suggest.document.Completion50PostingsFormat
-
- delegatePostingsFormat() - Method in class org.apache.lucene.search.suggest.document.CompletionPostingsFormat
-
Concrete implementation should specify the delegating postings format
- DelegatingAnalyzerWrapper - Class in org.apache.lucene.analysis
-
An analyzer wrapper, that doesn't allow to wrap components or readers.
- DelegatingAnalyzerWrapper(Analyzer.ReuseStrategy) - Constructor for class org.apache.lucene.analysis.DelegatingAnalyzerWrapper
-
Constructor.
- delete(char[], int, int) - Static method in class org.apache.lucene.analysis.util.StemmerUtil
-
Delete a character in-place
- delete() - Method in class org.apache.lucene.index.IndexCommit
-
Delete this commit point.
- delete(Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- delete(Path) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- delete(Path) - Method in class org.apache.lucene.mockfile.VirusCheckingFS
-
- delete(Path) - Method in class org.apache.lucene.mockfile.WindowsFS
-
- delete(String) - Method in class org.apache.lucene.search.LiveFieldValues
-
Call this after you've successfully deleted a document
from the index.
- deleteAll() - Method in class org.apache.lucene.index.IndexWriter
-
Delete all documents in the index.
- deleteAll() - Method in class org.apache.lucene.index.RandomIndexWriter
-
- deleteDocuments(Term...) - Method in class org.apache.lucene.index.IndexWriter
-
Deletes the document(s) containing any of the
terms.
- deleteDocuments(Query...) - Method in class org.apache.lucene.index.IndexWriter
-
Deletes the document(s) matching any of the provided queries.
- deleteDocuments(Term) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- deleteDocuments(Query) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- deleteDocuments(Term) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- DeletedQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
- DeletedQueryNode() - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.DeletedQueryNode
-
- deleteFile(String) - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- deleteFile(String) - Method in class org.apache.lucene.store.Directory
-
Removes an existing file in the directory.
- deleteFile(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- deleteFile(String) - Method in class org.apache.lucene.store.FilterDirectory
-
- deleteFile(String) - Method in class org.apache.lucene.store.FSDirectory
-
- deleteFile(String) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
-
- deleteFile(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- deleteFile(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- deleteFile(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- deleteFile(String) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-
- deleteFiles(Directory, Collection<String>) - Static method in class org.apache.lucene.util.IOUtils
-
Deletes all given file names.
- deleteFilesIfExist(Path...) - Static method in class org.apache.lucene.util.IOUtils
-
Deletes all given Paths, if they exist.
- deleteFilesIfExist(Collection<? extends Path>) - Static method in class org.apache.lucene.util.IOUtils
-
Deletes all given Paths, if they exist.
- deleteFilesIgnoringExceptions(Directory, Collection<String>) - Static method in class org.apache.lucene.util.IOUtils
-
Deletes all given files, suppressing all thrown IOExceptions.
- deleteFilesIgnoringExceptions(Directory, String...) - Static method in class org.apache.lucene.util.IOUtils
-
- deleteFilesIgnoringExceptions(Path...) - Static method in class org.apache.lucene.util.IOUtils
-
Deletes all given files, suppressing all thrown IOExceptions.
- deleteFilesIgnoringExceptions(Collection<? extends Path>) - Static method in class org.apache.lucene.util.IOUtils
-
Deletes all given files, suppressing all thrown IOExceptions.
- deleteIfExists(Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- deleteIfExists(Path) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- deleteIfExists(Path) - Method in class org.apache.lucene.mockfile.WindowsFS
-
- deleteLast(int, Builder.Node) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- deleteN(char[], int, int, int) - Static method in class org.apache.lucene.analysis.util.StemmerUtil
-
Delete n characters in-place
- deletePendingFiles() - Method in class org.apache.lucene.store.FSDirectory
-
Try to delete any pending files that we had previously tried to delete but failed
because we are on Windows and the files were still held open.
- deleteUnusedFiles() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: remove any index files that are no longer
used.
- deletionsGen - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Current deletions generation.
- delGen() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
-
- DelimitedPayloadTokenFilter - Class in org.apache.lucene.analysis.payloads
-
Characters before the delimiter are the "token", those after are the payload.
- DelimitedPayloadTokenFilter(TokenStream, char, PayloadEncoder) - Constructor for class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilter
-
- DelimitedPayloadTokenFilterFactory - Class in org.apache.lucene.analysis.payloads
-
- DelimitedPayloadTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilterFactory
-
Creates a new DelimitedPayloadTokenFilterFactory
- DelimitedTermFrequencyTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Characters before the delimiter are the "token", the textual integer after is the term frequency.
- DelimitedTermFrequencyTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.DelimitedTermFrequencyTokenFilter
-
- DelimitedTermFrequencyTokenFilter(TokenStream, char) - Constructor for class org.apache.lucene.analysis.miscellaneous.DelimitedTermFrequencyTokenFilter
-
- DelimitedTermFrequencyTokenFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- DelimitedTermFrequencyTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.DelimitedTermFrequencyTokenFilterFactory
-
Creates a new DelimitedPayloadTokenFilterFactory
- DELIMITER - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Punctuation Characters
- DELIMITER - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
Punctuation Symbol
- DELIMITER_ATTR - Static variable in class org.apache.lucene.analysis.miscellaneous.DelimitedTermFrequencyTokenFilterFactory
-
- DELIMITER_ATTR - Static variable in class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilterFactory
-
- delPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- deltaDistance(DistanceStyle, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
Called by a computeDeltaDistance
method if X/Y/Z is within this shape.
- deltaPackedBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
-
- deltaPackedBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
-
- delTermCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
-
Number of terms with zero live docs docs.
- DemoHTMLParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Simple HTML Parser extracting title, meta tags, and body text
that is based on
NekoHTML.
- DemoHTMLParser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser
-
- DemoHTMLParser.Parser - Class in org.apache.lucene.benchmark.byTask.feeds
-
The actual parser to read HTML documents
- depth - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
This node's depth, starting from the automaton root.
- describeParams() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Describe the parameters that control how the "more like this" query is formed.
- description() - Method in enum org.apache.lucene.analysis.ko.POS.Tag
-
Returns the description associated with the tag.
- description() - Method in class org.apache.lucene.queries.function.valuesource.ComparisonBoolFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- description() - Method in class org.apache.lucene.queries.function.ValueSource
-
description of field, used in explain()
- description() - Method in class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.DoubleFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.EnumFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.FieldCacheSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.FloatFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.IfFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.IntFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.JoinDocFreqValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.LinearFloatFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.LiteralValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MaxDocValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MultiBoolFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MultiFloatFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- description(String, List<ValueSource>) - Static method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedDoubleFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedFloatFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedIntFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedLongFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.NormValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.NumDocsValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.QueryValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.ScaleFloatFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.SimpleBoolFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.SingleFunction
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.SortedSetFieldSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.SumTotalTermFreqValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- description() - Method in class org.apache.lucene.queries.function.valuesource.VectorValueSource
-
- deserialize(DataInput) - Static method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- dest - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- dest - Variable in class org.apache.lucene.util.automaton.Transition
-
Destination state.
- destroy() - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- destroy() - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- destroy() - Method in interface org.apache.lucene.util.bkd.PointWriter
-
Removes any temp files behind this writer
- detailLevel - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery
-
- detailLevel - Variable in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets
-
The bottom-most detail-level counted, as requested.
- determinize(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
-
Determinizes the given automaton.
- determinizeSimple(Automaton) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Simple, original brics implementation of determinize()
- determinizeSimple(Automaton, Set<Integer>) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Simple, original brics implementation of determinize()
Determinizes the given automaton using the given set of initial states.
- DFISimilarity - Class in org.apache.lucene.search.similarities
-
Implements the Divergence from Independence (DFI) model based on Chi-square statistics
(i.e., standardized Chi-squared distance from independence in term frequency tf).
- DFISimilarity(Independence) - Constructor for class org.apache.lucene.search.similarities.DFISimilarity
-
Create DFI with the specified divergence from independence measure
- DFRSimilarity - Class in org.apache.lucene.search.similarities
-
Implements the divergence from randomness (DFR) framework
introduced in Gianni Amati and Cornelis Joost Van Rijsbergen.
- DFRSimilarity(BasicModel, AfterEffect, Normalization) - Constructor for class org.apache.lucene.search.similarities.DFRSimilarity
-
Creates DFRSimilarity from the three components.
- diagnostics - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Map that includes certain
debugging details that IndexWriter records into
each segment it creates
- DICT_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- DICT_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- DICT_HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- DICT_HEADER - Static variable in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- dictionary - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- Dictionary - Class in org.apache.lucene.analysis.hunspell
-
In-memory structure for the dictionary (.dic) and affix (.aff)
data of a hunspell dictionary.
- Dictionary(Directory, String, InputStream, InputStream) - Constructor for class org.apache.lucene.analysis.hunspell.Dictionary
-
Creates a new Dictionary containing the information read from the provided InputStreams to hunspell affix
and dictionary files.
- Dictionary(Directory, String, InputStream, List<InputStream>, boolean) - Constructor for class org.apache.lucene.analysis.hunspell.Dictionary
-
Creates a new Dictionary containing the information read from the provided InputStreams to hunspell affix
and dictionary files.
- Dictionary - Interface in org.apache.lucene.analysis.ja.dict
-
Dictionary interface for retrieving morphological data
by id.
- Dictionary - Interface in org.apache.lucene.analysis.ko.dict
-
Dictionary interface for retrieving morphological data
by id.
- Dictionary - Interface in org.apache.lucene.search.spell
-
A simple interface representing a Dictionary.
- Dictionary.Morpheme - Class in org.apache.lucene.analysis.ko.dict
-
A morpheme extracted from a compound token.
- DICTIONARY_ATTRIBUTE - Static variable in class org.apache.lucene.analysis.morfologik.MorfologikFilterFactory
-
Dictionary resource attribute (should have
".dict"
suffix), loaded from
ResourceLoader
.
- DictionaryCompoundWordTokenFilter - Class in org.apache.lucene.analysis.compound
-
A
TokenFilter
that decomposes compound words found in many Germanic languages.
- DictionaryCompoundWordTokenFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
- DictionaryCompoundWordTokenFilter(TokenStream, CharArraySet, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilter
-
- DictionaryCompoundWordTokenFilterFactory - Class in org.apache.lucene.analysis.compound
-
- DictionaryCompoundWordTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilterFactory
-
Creates a new DictionaryCompoundWordTokenFilterFactory
- DictionaryToken - Class in org.apache.lucene.analysis.ko
-
- DictionaryToken(KoreanTokenizer.Type, Dictionary, int, char[], int, int, int, int) - Constructor for class org.apache.lucene.analysis.ko.DictionaryToken
-
- Diff - Class in org.egothor.stemmer
-
The Diff object generates a patch string.
- Diff() - Constructor for class org.egothor.stemmer.Diff
-
Constructor for the Diff object.
- Diff(int, int, int, int) - Constructor for class org.egothor.stemmer.Diff
-
Constructor for the Diff object
- DiffIt - Class in org.egothor.stemmer
-
The DiffIt class is a means generate patch commands from an already prepared
stemmer table.
- DIGIT - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Numeric Digits
- DIGIT - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- dim - Variable in class org.apache.lucene.facet.FacetField
-
Dimension for this field.
- dim - Variable in class org.apache.lucene.facet.FacetResult
-
Dimension that was requested.
- dim - Variable in class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetField
-
Dimension.
- dim - Variable in class org.apache.lucene.facet.taxonomy.AssociationFacetField
-
Dimension for this field.
- DimConfig() - Constructor for class org.apache.lucene.facet.FacetsConfig.DimConfig
-
Default constructor.
- dimension() - Method in class org.apache.lucene.queries.function.valuesource.MultiValueSource
-
- dimension() - Method in class org.apache.lucene.queries.function.valuesource.VectorValueSource
-
- dimension() - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- dir - Variable in class org.apache.lucene.index.CheckIndex.Status
-
Directory index is in.
- dir - Variable in class org.apache.lucene.index.SegmentInfo
-
Where this segment resides.
- dir - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- dir - Variable in class org.apache.lucene.replicator.nrt.Node
-
- dir - Variable in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- DirContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
- DirContentSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DirContentSource
-
- DirContentSource.Iterator - Class in org.apache.lucene.benchmark.byTask.feeds
-
Iterator over the files in the directory
- DirectAllocator() - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
-
- DirectAllocator(int) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectAllocator
-
- DirectAllocator() - Constructor for class org.apache.lucene.util.IntBlockPool.DirectAllocator
-
- DirectBytesStartArray(int, Counter) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-
- DirectBytesStartArray(int) - Constructor for class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-
- DirectDocValuesFormat - Class in org.apache.lucene.codecs.memory
-
In-memory docvalues format that does no (or very little)
compression.
- DirectDocValuesFormat() - Constructor for class org.apache.lucene.codecs.memory.DirectDocValuesFormat
-
Sole constructor.
- DirectMonotonicReader - Class in org.apache.lucene.util.packed
-
- DirectMonotonicReader() - Constructor for class org.apache.lucene.util.packed.DirectMonotonicReader
-
- DirectMonotonicReader.Meta - Class in org.apache.lucene.util.packed
-
- DirectMonotonicWriter - Class in org.apache.lucene.util.packed
-
Write monotonically-increasing sequences of integers.
- directory(int, Path) - Method in class org.apache.lucene.benchmark.utils.ExtractWikipedia
-
- directory - Variable in class org.apache.lucene.index.DirectoryReader
-
The index directory.
- directory() - Method in class org.apache.lucene.index.DirectoryReader
-
Returns the directory this index resides in.
- directory() - Method in class org.apache.lucene.index.SegmentReader
-
Returns the directory this index resides in.
- directory - Variable in class org.apache.lucene.index.SegmentReadState
-
- directory - Variable in class org.apache.lucene.index.SegmentWriteState
-
Directory
where this segment will be written
to.
- directory - Static variable in class org.apache.lucene.search.BaseExplanationTestCase
-
- directory - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- Directory - Class in org.apache.lucene.store
-
A Directory
provides an abstraction layer for storing a
list of files.
- Directory() - Constructor for class org.apache.lucene.store.Directory
-
- directory - Variable in class org.apache.lucene.store.FSDirectory
-
- DirectoryReader - Class in org.apache.lucene.index
-
- DirectoryReader(Directory, LeafReader[]) - Constructor for class org.apache.lucene.index.DirectoryReader
-
Expert: Constructs a DirectoryReader
on the given subReaders.
- DirectoryTaxonomyReader - Class in org.apache.lucene.facet.taxonomy.directory
-
- DirectoryTaxonomyReader(Directory) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
Open for reading a taxonomy stored in a given
Directory
.
- DirectoryTaxonomyReader(DirectoryTaxonomyWriter) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- DirectoryTaxonomyWriter - Class in org.apache.lucene.facet.taxonomy.directory
-
TaxonomyWriter
which uses a
Directory
to store the taxonomy
information on disk, and keeps an additional in-memory cache of some or all
categories.
- DirectoryTaxonomyWriter(Directory, IndexWriterConfig.OpenMode, TaxonomyWriterCache) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Construct a Taxonomy writer.
- DirectoryTaxonomyWriter(Directory, IndexWriterConfig.OpenMode) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- DirectoryTaxonomyWriter(Directory) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Create this with OpenMode.CREATE_OR_APPEND
.
- DirectoryTaxonomyWriter.DiskOrdinalMap - Class in org.apache.lucene.facet.taxonomy.directory
-
- DirectoryTaxonomyWriter.MemoryOrdinalMap - Class in org.apache.lucene.facet.taxonomy.directory
-
- DirectoryTaxonomyWriter.OrdinalMap - Interface in org.apache.lucene.facet.taxonomy.directory
-
Mapping from old ordinal to new ordinals, used when merging indexes
with separate taxonomies.
- DirectPostingsFormat - Class in org.apache.lucene.codecs.memory
-
Wraps
Lucene50PostingsFormat
format for on-disk
storage, but then at read time loads and stores all
terms and postings directly in RAM as byte[], int[].
- DirectPostingsFormat() - Constructor for class org.apache.lucene.codecs.memory.DirectPostingsFormat
-
- DirectPostingsFormat(int, int) - Constructor for class org.apache.lucene.codecs.memory.DirectPostingsFormat
-
minSkipCount is how many terms in a row must have the
same prefix before we put a skip pointer down.
- DirectReader - Class in org.apache.lucene.util.packed
-
- DirectReader() - Constructor for class org.apache.lucene.util.packed.DirectReader
-
- DirectSpellChecker - Class in org.apache.lucene.search.spell
-
Simple automaton-based spellchecker.
- DirectSpellChecker() - Constructor for class org.apache.lucene.search.spell.DirectSpellChecker
-
Creates a DirectSpellChecker with default configuration values
- DirectSpellChecker.ScoreTerm - Class in org.apache.lucene.search.spell
-
- DirectTrackingAllocator(Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-
- DirectTrackingAllocator(int, Counter) - Constructor for class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-
- DirectWriter - Class in org.apache.lucene.util.packed
-
Class for writing packed integers to be directly read from Directory.
- disable() - Method in class org.apache.lucene.mockfile.VirusCheckingFS
-
- 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.classic.QueryParser
-
Disable tracing.
- disable_tracing() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Disable tracing.
- disable_tracing() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
Disable tracing.
- disableAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Turn off auto IO throttling.
- disableCaching() - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Disables any enabled cache.
- DisableFsyncFS - Class in org.apache.lucene.mockfile
-
Disables actual calls to fsync.
- DisableFsyncFS(FileSystem) - Constructor for class org.apache.lucene.mockfile.DisableFsyncFS
-
Create a new instance, wrapping delegate
.
- disableVirusChecker(Directory) - Static method in class org.apache.lucene.util.TestUtil
-
Returns true if VirusCheckingFS is in use and was in fact already enabled
- DISALLOW_EXTERNAL_ENTITY_RESOLVER - Static variable in class org.apache.lucene.queryparser.xml.CoreParser
-
- discardEscapeChar(CharSequence) - Static method in class org.apache.lucene.queryparser.flexible.standard.parser.EscapeQuerySyntaxImpl
-
Returns a String where the escape char has been removed, or kept only once
if there was a double escape.
- discountOverlaps - Variable in class org.apache.lucene.search.similarities.BM25Similarity
-
True if overlap tokens (tokens with a position of increment of zero) are
discounted from the document's length.
- discountOverlaps - Variable in class org.apache.lucene.search.similarities.SimilarityBase
-
True if overlap tokens (tokens with a position of increment of zero) are
discounted from the document's length.
- discountOverlaps - Variable in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
True if overlap tokens (tokens with a position of increment of zero) are
discounted from the document's length.
- discreteMultiValueHighlighting(List<FieldFragList.WeightedFragInfo>, Field[]) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- DisiPriorityQueue - Class in org.apache.lucene.search
-
A priority queue of DocIdSetIterators that orders by current doc ID.
- DisiPriorityQueue(int) - Constructor for class org.apache.lucene.search.DisiPriorityQueue
-
- DisiWrapper - Class in org.apache.lucene.search
-
- DisiWrapper(Scorer) - Constructor for class org.apache.lucene.search.DisiWrapper
-
- DisiWrapper(Spans) - Constructor for class org.apache.lucene.search.DisiWrapper
-
- DISJOINT - Static variable in interface org.apache.lucene.spatial3d.geom.GeoArea
-
The referenced shape has no relation to this area
- DisjQuery(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- disjunction(List<MatchesIterator>) - Static method in class org.apache.lucene.search.MatchesUtils
-
Create a MatchesIterator that iterates in order over all matches in a set of subiterators
- DISJUNCTION_MAX_REWRITE - Static variable in class org.apache.lucene.search.BlendedTermQuery
-
- DisjunctionDISIApproximation - Class in org.apache.lucene.search
-
A
DocIdSetIterator
which is a disjunction of the approximations of
the provided iterators.
- DisjunctionDISIApproximation(DisiPriorityQueue) - Constructor for class org.apache.lucene.search.DisjunctionDISIApproximation
-
- DisjunctionMaxQuery - Class in org.apache.lucene.search
-
A query that generates the union of documents produced by its subqueries, and that scores each document with the maximum
score for that document as produced by any subquery, plus a tie breaking increment for any additional matching subqueries.
- DisjunctionMaxQuery(Collection<Query>, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery
-
Creates a new DisjunctionMaxQuery
- DisjunctionMaxQuery.DisjunctionMaxWeight - Class in org.apache.lucene.search
-
Expert: the Weight for DisjunctionMaxQuery, used to
normalize, score and explain these queries.
- DisjunctionMaxQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- DisjunctionMaxQueryBuilder(QueryBuilder) - Constructor for class org.apache.lucene.queryparser.xml.builders.DisjunctionMaxQueryBuilder
-
- DisjunctionMaxRewrite(float) - Constructor for class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
-
- DisjunctionMaxWeight(IndexSearcher, boolean, float) - Constructor for class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
Construct the Weight for this Query searched by searcher.
- DiskOrdinalMap(Path) - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
-
Sole constructor.
- DIST_ERR - Static variable in class org.apache.lucene.spatial.query.SpatialArgsParser
-
- DIST_ERR_PCT - Static variable in class org.apache.lucene.spatial.query.SpatialArgsParser
-
- distance(Point, Point) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- distance(Point, double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- distance(DistanceStyle, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
Called by a computeDistance
method if X/Y/Z is within this shape.
- distanceBounds(Bounds, DistanceStyle, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
Called by a getDistanceBounds
method if distanceValue is not Double.POSITIVE_INFINITY.
- DistanceFacetsExample - Class in org.apache.lucene.demo.facet
-
Shows simple usage of dynamic range faceting, using the
expressions module to calculate distance.
- DistanceFacetsExample() - Constructor for class org.apache.lucene.demo.facet.DistanceFacetsExample
-
Empty constructor
- DistanceQuery - Class in org.apache.lucene.queryparser.surround.query
-
Factory for NEAR queries
- DistanceQuery(List<SrndQuery>, boolean, int, String, boolean) - Constructor for class org.apache.lucene.queryparser.surround.query.DistanceQuery
-
- distanceQuerySortKey(double) - Static method in class org.apache.lucene.geo.GeoUtils
-
binary search to find the exact sortKey needed to match the specified radius
any sort key lte this is a query match.
- DistanceStyle - Interface in org.apache.lucene.spatial3d.geom
-
Distance computation styles, supporting various ways of computing
distance to shapes.
- DistanceSubQuery - Interface in org.apache.lucene.queryparser.surround.query
-
Interface for queries that can be nested as subqueries
into a span near.
- distanceSubQueryNotAllowed() - Method in class org.apache.lucene.queryparser.surround.query.DistanceQuery
-
- distanceSubQueryNotAllowed() - Method in interface org.apache.lucene.queryparser.surround.query.DistanceSubQuery
-
When distanceSubQueryNotAllowed() returns non null, the reason why the subquery
is not allowed as a distance subquery is returned.
- distanceSubQueryNotAllowed() - Method in class org.apache.lucene.queryparser.surround.query.OrQuery
-
- distanceSubQueryNotAllowed() - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- DistanceToShapeValueSource - Class in org.apache.lucene.spatial.util
-
The distance from a provided Point to a Point retrieved from an ShapeValuesSource.
- DistanceToShapeValueSource(ShapeValuesSource, Point, double, SpatialContext) - Constructor for class org.apache.lucene.spatial.util.DistanceToShapeValueSource
-
- DistanceValueSource - Class in org.apache.lucene.spatial.vector
-
- DistanceValueSource(PointVectorStrategy, Point, double) - Constructor for class org.apache.lucene.spatial.vector.DistanceValueSource
-
Constructor.
- distErrPct - Variable in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- distErrPct - Variable in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- DistinctValuesCollector<T,R> - Class in org.apache.lucene.search.grouping
-
A second pass grouping collector that keeps track of distinct values for a specified field for the top N group.
- DistinctValuesCollector(GroupSelector<T>, Collection<SearchGroup<T>>, GroupSelector<R>) - Constructor for class org.apache.lucene.search.grouping.DistinctValuesCollector
-
Create a DistinctValuesCollector
- DistinctValuesCollector.GroupCount<T,R> - Class in org.apache.lucene.search.grouping
-
- Distribution - Class in org.apache.lucene.search.similarities
-
The probabilistic distribution used to model term occurrence
in information-based models.
- Distribution() - Constructor for class org.apache.lucene.search.similarities.Distribution
-
Sole constructor.
- distribution - Variable in class org.apache.lucene.search.similarities.IBSimilarity
-
The probabilistic distribution used to model term occurrence.
- DistributionLL - Class in org.apache.lucene.search.similarities
-
Log-logistic distribution.
- DistributionLL() - Constructor for class org.apache.lucene.search.similarities.DistributionLL
-
Sole constructor: parameter-free
- DistributionSPL - Class in org.apache.lucene.search.similarities
-
The smoothed power-law (SPL) distribution for the information-based framework
that is described in the original paper.
- DistributionSPL() - Constructor for class org.apache.lucene.search.similarities.DistributionSPL
-
Sole constructor: parameter-free
- DiversifiedTopDocsCollector - Class in org.apache.lucene.search
-
A
TopDocsCollector
that controls diversity in results by ensuring no
more than maxHitsPerKey results from a common source are collected in the
final results.
- DiversifiedTopDocsCollector(int, int) - Constructor for class org.apache.lucene.search.DiversifiedTopDocsCollector
-
- DiversifiedTopDocsCollector.ScoreDocKey - Class in org.apache.lucene.search
-
An extension to ScoreDoc that includes a key used for grouping purposes
- DivFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
Function to divide "a" by "b"
- DivFloatFunction(ValueSource, ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.DivFloatFunction
-
- doAccumulate(int) - Method in class org.apache.lucene.search.DocValuesStats
-
- doAccumulate(int) - Method in class org.apache.lucene.search.DocValuesStats.DoubleDocValuesStats
-
- doAccumulate(int) - Method in class org.apache.lucene.search.DocValuesStats.LongDocValuesStats
-
- doAccumulate(int) - Method in class org.apache.lucene.search.DocValuesStats.SortedDocValuesStats
-
- doAccumulate(int) - Method in class org.apache.lucene.search.DocValuesStats.SortedDoubleDocValuesStats
-
- doAccumulate(int) - Method in class org.apache.lucene.search.DocValuesStats.SortedLongDocValuesStats
-
- doAccumulate(int) - Method in class org.apache.lucene.search.DocValuesStats.SortedSetDocValuesStats
-
- doAction(HttpResponse, Callable<T>) - Method in class org.apache.lucene.replicator.http.HttpClientBase
-
- doAction(HttpResponse, boolean, Callable<T>) - Method in class org.apache.lucene.replicator.http.HttpClientBase
-
Do a specific action and validate after the action that the status is still OK,
and if not, attempt to extract the actual server side exception.
- 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).
- doAfterIndexingThreadDone() - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- doAfterWriter(ExecutorService) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- doBeforeFlush() - Method in class org.apache.lucene.index.IndexWriter
-
A hook for extending classes to execute operations before pending added and
deleted documents are flushed to the Directory.
- doBody(String) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
-
Subclass must implement this.
- DOC - Static variable in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- doc - Variable in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
volatile data passed between setup(), doLogic(), tearDown().
- doc - Variable in class org.apache.lucene.search.DisiWrapper
-
- doc - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector.GroupHead
-
- doc(int) - Method in class org.apache.lucene.search.IndexSearcher
-
Sugar for .getIndexReader().document(docID)
- doc(int, StoredFieldVisitor) - Method in class org.apache.lucene.search.IndexSearcher
-
Sugar for .getIndexReader().document(docID, fieldVisitor)
- doc(int, Set<String>) - Method in class org.apache.lucene.search.IndexSearcher
-
Sugar for .getIndexReader().document(docID, fieldsToLoad)
- doc - Variable in class org.apache.lucene.search.ScoreDoc
-
A hit document's number.
- doc - Variable in class org.apache.lucene.search.spans.TermSpans
-
- DOC_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
Filename extension for document number, frequencies, and skip data.
- doCache(Weight, QueryCachingPolicy) - Method in class org.apache.lucene.search.LRUQueryCache
-
- doCache(Weight, QueryCachingPolicy) - Method in interface org.apache.lucene.search.QueryCache
-
Return a wrapper around the provided weight
that will cache
matching docs per-segment accordingly to the given policy
.
- doCacheWrite(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
Subclass can override this to customize logic; return
true if this file should be written to the RAMDirectory.
- docBase - Variable in class org.apache.lucene.index.LeafReaderContext
-
The reader's absolute doc base
- docBase - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector.GroupHead
-
- docBase - Variable in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
Document base offset for the current Leaf
- docBaseInParent - Variable in class org.apache.lucene.index.IndexReaderContext
-
the doc base for this reader in the parent, 0 if parent is null
- docBases - Variable in class org.apache.lucene.index.PerThreadPKLookup
-
- DocComparator(int) - Constructor for class org.apache.lucene.search.FieldComparator.DocComparator
-
Creates a new comparator based on document ids for numHits
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
-
Number of documents tested.
- docCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
-
Number of documents tested.
- docCount(String) - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the docCount for a given field
- docCount() - Method in class org.apache.lucene.search.CollectionStatistics
-
returns the total number of documents that
have at least one term for this field.
- DocData - Class in org.apache.lucene.benchmark.byTask.feeds
-
Output of parsing (e.g.
- DocData() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- docFields - Static variable in class org.apache.lucene.search.BaseExplanationTestCase
-
- docFreq - Variable in class org.apache.lucene.codecs.BlockTermState
-
how many docs have this term
- docFreq() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- docFreq() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- docFreq - Variable in class org.apache.lucene.codecs.TermStats
-
How many documents have at least one occurrence of
this term.
- docFreq(Term) - Method in class org.apache.lucene.index.BaseCompositeReader
-
- docFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
-
- docFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- docFreq(Term) - Method in class org.apache.lucene.index.IndexReader
-
Returns the number of documents containing the
term
.
- docFreq(Term) - Method in class org.apache.lucene.index.LeafReader
-
- docFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
-
- docFreq - Variable in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- docFreq() - Method in class org.apache.lucene.index.TermContext
-
- docFreq() - Method in class org.apache.lucene.index.TermsEnum
-
Returns the number of documents containing the current
term.
- docFreq - Variable in class org.apache.lucene.misc.TermStats
-
- docFreq(Term) - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the docFreq of a given term
- docFreq() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- docFreq - Variable in class org.apache.lucene.search.similarities.BasicStats
-
The document frequency.
- docfreq - Variable in class org.apache.lucene.search.spell.DirectSpellChecker.ScoreTerm
-
The df of the spellcheck correction.
- docFreq() - Method in class org.apache.lucene.search.TermStatistics
-
returns the number of documents this term occurs in
- DocFreqComparator() - Constructor for class org.apache.lucene.misc.HighFreqTerms.DocFreqComparator
-
- DocFreqValueSource - Class in org.apache.lucene.queries.function.valuesource
-
DocFreqValueSource
returns the number of documents containing the term.
- DocFreqValueSource(String, String, String, BytesRef) - Constructor for class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- doCheck(CheckIndex.Options) - Method in class org.apache.lucene.index.CheckIndex
-
Actually perform the index check
- docID() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- docID() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- docID() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- docID() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- docID() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- docID() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- docID(IndexReader, String) - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- docID() - Method in class org.apache.lucene.index.FilterBinaryDocValues
-
- docID() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- docID() - Method in class org.apache.lucene.index.FilterNumericDocValues
-
- docID() - Method in class org.apache.lucene.index.LegacyBinaryDocValuesWrapper
-
Deprecated.
- docID() - Method in class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- docID() - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- docID() - Method in class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- docID() - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- docID() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- docID() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- docID() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- docID() - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- docID() - Method in class org.apache.lucene.queries.function.FunctionQuery.AllScorer
-
- docID() - Method in class org.apache.lucene.queries.function.ValueSourceScorer
-
- docID() - Method in class org.apache.lucene.search.AssertingScorer
-
- docID() - Method in class org.apache.lucene.search.BulkScorerWrapperScorer
-
- docID() - Method in class org.apache.lucene.search.ConjunctionDISI
-
- docID() - Method in class org.apache.lucene.search.ConstantScoreScorer
-
- docID() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
-
- docID() - Method in class org.apache.lucene.search.DocIdSetIterator
-
- docID() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-
- docID() - Method in class org.apache.lucene.search.FilterScorer
-
- docID() - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- docID() - Method in class org.apache.lucene.search.Scorer
-
Returns the doc ID that is currently being scored.
- docID() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- docID() - Method in class org.apache.lucene.search.spans.SpanScorer
-
- docID() - Method in class org.apache.lucene.search.spans.TermSpans
-
- docID() - Method in class org.apache.lucene.util.BitSetIterator
-
- docID() - Method in class org.apache.lucene.util.bkd.HeapPointReader
-
- docID() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
-
- docID() - Method in class org.apache.lucene.util.bkd.PointReader
-
DocID for this point
- DocIDMerger<T extends DocIDMerger.Sub> - Class in org.apache.lucene.index
-
Utility class to help merging documents from sub-readers according to either simple
concatenated (unsorted) order, or by a specified index-time sort, skipping
deleted documents and remapping non-deleted documents.
- DocIDMerger.Sub - Class in org.apache.lucene.index
-
Represents one sub-reader being merged
- docIDs - Variable in class org.apache.lucene.util.bkd.HeapPointWriter
-
- DocIdSet - Class in org.apache.lucene.search
-
A DocIdSet contains a set of doc ids.
- DocIdSet() - Constructor for class org.apache.lucene.search.DocIdSet
-
- DocIdSetBuilder - Class in org.apache.lucene.util
-
- DocIdSetBuilder(int) - Constructor for class org.apache.lucene.util.DocIdSetBuilder
-
Create a builder that can contain doc IDs between 0
and maxDoc
.
- DocIdSetBuilder(int, Terms) - Constructor for class org.apache.lucene.util.DocIdSetBuilder
-
Create a
DocIdSetBuilder
instance that is optimized for
accumulating docs that match the given
Terms
.
- DocIdSetBuilder(int, PointValues, String) - Constructor for class org.apache.lucene.util.DocIdSetBuilder
-
- DocIdSetBuilder.BulkAdder - Class in org.apache.lucene.util
-
Utility class to efficiently add many docs in one go.
- DocIdSetIterator - Class in org.apache.lucene.search
-
This abstract class defines methods to iterate over a set of non-decreasing
doc ids.
- DocIdSetIterator() - Constructor for class org.apache.lucene.search.DocIdSetIterator
-
- doClose() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- doClose() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
performs the actual task of closing the resources that are used by the
taxonomy reader.
- doClose() - Method in class org.apache.lucene.index.CodecReader
-
- doClose() - Method in class org.apache.lucene.index.FilterCodecReader
-
- doClose() - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- doClose() - Method in class org.apache.lucene.index.FilterLeafReader
-
- doClose() - Method in class org.apache.lucene.index.IndexReader
-
Implements close.
- doClose() - Method in class org.apache.lucene.index.MultiReader
-
- doClose() - Method in class org.apache.lucene.index.ParallelCompositeReader
-
- doClose() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- doClose() - Method in class org.apache.lucene.index.SegmentReader
-
- doClose() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- doClose() - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- doClose() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- DocMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
- DocMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- docMaker - Variable in class org.apache.lucene.benchmark.utils.ExtractWikipedia
-
- DocMaker.DocState - Class in org.apache.lucene.benchmark.byTask.feeds
-
Document state, supports reuse of field instances
across documents (see reuseFields
parameter).
- DocMap() - Constructor for class org.apache.lucene.index.MergeState.DocMap
-
Sole constructor
- docMaps - Variable in class org.apache.lucene.index.MergeState
-
Maps document IDs from old segments to document IDs in the new segment
- docName(IndexSearcher, int) - Method in class org.apache.lucene.benchmark.quality.utils.DocNameExtractor
-
Extract the name of the input doc from the index.
- DocNameExtractor - Class in org.apache.lucene.benchmark.quality.utils
-
Utility: extract doc names from an index
- DocNameExtractor(String) - Constructor for class org.apache.lucene.benchmark.quality.utils.DocNameExtractor
-
Constructor for DocNameExtractor.
- docNameField - Variable in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
index field to extract doc name for each search result; used for judging the results.
- DOCNO - Static variable in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- docs(Random, IndexReader, String, BytesRef, PostingsEnum, int) - Static method in class org.apache.lucene.util.TestUtil
-
- docs(Random, TermsEnum, PostingsEnum, int) - Static method in class org.apache.lucene.util.TestUtil
-
- docScore(int, String, int, float) - Method in class org.apache.lucene.queries.payloads.AveragePayloadFunction
-
- docScore(int, String, int, float) - Method in class org.apache.lucene.queries.payloads.MaxPayloadFunction
-
- docScore(int, String, int, float) - Method in class org.apache.lucene.queries.payloads.MinPayloadFunction
-
- docScore(int, String, int, float) - Method in class org.apache.lucene.queries.payloads.PayloadFunction
-
Calculate the final score for all the payloads seen so far for this doc/field
- docScore(int, String, int, float) - Method in class org.apache.lucene.queries.payloads.SumPayloadFunction
-
- docScorer - Variable in class org.apache.lucene.search.spans.SpanScorer
-
- docsSeen - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
- docStarts - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- docStarts - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- DocState(boolean, FieldType, FieldType) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DocMaker.DocState
-
- DocTermsIndexDocValues - Class in org.apache.lucene.queries.function.docvalues
-
Serves as base class for FunctionValues based on DocTermsIndex.
- DocTermsIndexDocValues(ValueSource, LeafReaderContext, String) - Constructor for class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- DocTermsIndexDocValues(String, ValueSource, SortedDocValues) - Constructor for class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- DocTermsIndexDocValues.DocTermsIndexException - Exception in org.apache.lucene.queries.function.docvalues
-
Custom Exception to be thrown when the DocTermsIndex for a field cannot be generated
- DocTermsIndexException(String, RuntimeException) - Constructor for exception org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues.DocTermsIndexException
-
- DocToDoubleVectorUtils - Class in org.apache.lucene.classification.utils
-
utility class for converting Lucene
Document
s to
Double
vectors.
- Document - Class in org.apache.lucene.document
-
Documents are the unit of indexing and search.
- Document() - Constructor for class org.apache.lucene.document.Document
-
Constructs a new document with no fields.
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.BaseCompositeReader
-
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.CodecReader
-
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.FilterLeafReader
-
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.IndexReader
-
Expert: visits the fields of a stored document, for
custom processing/loading of each field.
- document(int) - Method in class org.apache.lucene.index.IndexReader
-
Returns the stored fields of the n
th
Document
in this index.
- document(int, Set<String>) - Method in class org.apache.lucene.index.IndexReader
-
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.MismatchedLeafReader
-
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- document(int, StoredFieldVisitor) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- DocumentClassifier<T> - Interface in org.apache.lucene.classification.document
-
A classifier, see
http://en.wikipedia.org/wiki/Classifier_(mathematics)
, which assign classes of type
T
to a
Document
s
- DocumentDictionary - Class in org.apache.lucene.search.suggest
-
Dictionary with terms, weights, payload (optional) and contexts (optional)
information taken from stored/indexed fields in a Lucene index.
- DocumentDictionary(IndexReader, String, String) - Constructor for class org.apache.lucene.search.suggest.DocumentDictionary
-
Creates a new dictionary with the contents of the fields named field
for the terms and weightField
for the weights that will be used for
the corresponding terms.
- DocumentDictionary(IndexReader, String, String, String) - Constructor for class org.apache.lucene.search.suggest.DocumentDictionary
-
Creates a new dictionary with the contents of the fields named field
for the terms, weightField
for the weights that will be used for the
the corresponding terms and payloadField
for the corresponding payloads
for the entry.
- DocumentDictionary(IndexReader, String, String, String, String) - Constructor for class org.apache.lucene.search.suggest.DocumentDictionary
-
Creates a new dictionary with the contents of the fields named field
for the terms, weightField
for the weights that will be used for the
the corresponding terms, payloadField
for the corresponding payloads
for the entry and contextsField
for associated contexts.
- DocumentDictionary.DocumentInputIterator - Class in org.apache.lucene.search.suggest
-
- DocumentInputIterator(boolean, boolean) - Constructor for class org.apache.lucene.search.suggest.DocumentDictionary.DocumentInputIterator
-
Creates an iterator over term, weight and payload fields from the lucene
index.
- DocumentStoredFieldVisitor - Class in org.apache.lucene.document
-
- DocumentStoredFieldVisitor(Set<String>) - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
-
Load only fields named in the provided Set<String>
.
- DocumentStoredFieldVisitor(String...) - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
-
Load only fields named in the provided fields.
- DocumentStoredFieldVisitor() - Constructor for class org.apache.lucene.document.DocumentStoredFieldVisitor
-
Load all stored fields.
- DocumentValueSourceDictionary - Class in org.apache.lucene.search.suggest
-
Dictionary with terms and optionally payload and
optionally contexts information
taken from stored fields in a Lucene index.
- DocumentValueSourceDictionary(IndexReader, String, LongValuesSource, String, String) - Constructor for class org.apache.lucene.search.suggest.DocumentValueSourceDictionary
-
Creates a new dictionary with the contents of the fields named field
for the terms, payload
for the corresponding payloads, contexts
for the associated contexts and uses the weightsValueSource
supplied
to determine the score.
- DocumentValueSourceDictionary(IndexReader, String, LongValuesSource, String) - Constructor for class org.apache.lucene.search.suggest.DocumentValueSourceDictionary
-
Creates a new dictionary with the contents of the fields named field
for the terms, payloadField
for the corresponding payloads
and uses the weightsValueSource
supplied to determine the
score.
- DocumentValueSourceDictionary(IndexReader, String, LongValuesSource) - Constructor for class org.apache.lucene.search.suggest.DocumentValueSourceDictionary
-
Creates a new dictionary with the contents of the fields named field
for the terms and uses the weightsValueSource
supplied to determine the
score.
- doCurrentSpans() - Method in class org.apache.lucene.search.spans.Spans
-
Called each time the scorer's SpanScorer is advanced during frequency calculation
- docValueCount() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- docValueCount() - Method in class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- docValueCount() - Method in class org.apache.lucene.index.SortedNumericDocValues
-
Retrieves the number of values for the current document.
- DocValues - Class in org.apache.lucene.index
-
This class contains utility methods and constants for DocValues
- DocValuesConsumer - Class in org.apache.lucene.codecs
-
Abstract API that consumes numeric, binary and
sorted docvalues.
- DocValuesConsumer() - Constructor for class org.apache.lucene.codecs.DocValuesConsumer
-
Sole constructor.
- DocValuesFieldExistsQuery - Class in org.apache.lucene.search
-
A
Query
that matches documents that have a value for a given field
as reported by doc values iterators.
- DocValuesFieldExistsQuery(String) - Constructor for class org.apache.lucene.search.DocValuesFieldExistsQuery
-
Create a query that will match that have a value for the given
field
.
- docValuesFormat() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- docValuesFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes docvalues
- docValuesFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- DocValuesFormat - Class in org.apache.lucene.codecs
-
Encodes/decodes per-document values.
- DocValuesFormat(String) - Constructor for class org.apache.lucene.codecs.DocValuesFormat
-
Creates a new docvalues format.
- docValuesFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- docValuesFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- docValuesFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- DocValuesNumbersQuery - Class in org.apache.lucene.search
-
- DocValuesNumbersQuery(String, long[]) - Constructor for class org.apache.lucene.search.DocValuesNumbersQuery
-
- DocValuesNumbersQuery(String, Collection<Long>) - Constructor for class org.apache.lucene.search.DocValuesNumbersQuery
-
- DocValuesNumbersQuery(String, Long...) - Constructor for class org.apache.lucene.search.DocValuesNumbersQuery
-
- DocValuesOrdinalsReader - Class in org.apache.lucene.facet.taxonomy
-
Decodes ordinals previously indexed into a BinaryDocValues field
- DocValuesOrdinalsReader() - Constructor for class org.apache.lucene.facet.taxonomy.DocValuesOrdinalsReader
-
Default constructor.
- DocValuesOrdinalsReader(String) - Constructor for class org.apache.lucene.facet.taxonomy.DocValuesOrdinalsReader
-
Create this, with the specified indexed field name.
- DocValuesProducer - Class in org.apache.lucene.codecs
-
Abstract API that produces numeric, binary, sorted, sortedset,
and sortednumeric docvalues.
- DocValuesProducer() - Constructor for class org.apache.lucene.codecs.DocValuesProducer
-
Sole constructor.
- docValuesProducers - Variable in class org.apache.lucene.index.MergeState
-
DocValues producers being merged
- DocValuesRewriteMethod - Class in org.apache.lucene.search
-
Rewrites MultiTermQueries into a filter, using DocValues for term enumeration.
- DocValuesRewriteMethod() - Constructor for class org.apache.lucene.search.DocValuesRewriteMethod
-
- DocValuesStats<T> - Class in org.apache.lucene.search
-
Holds statistics for a DocValues field.
- DocValuesStats(String, T, T) - Constructor for class org.apache.lucene.search.DocValuesStats
-
- DocValuesStats.DoubleDocValuesStats - Class in org.apache.lucene.search
-
Holds DocValues statistics for a numeric field storing double
values.
- DocValuesStats.LongDocValuesStats - Class in org.apache.lucene.search
-
Holds DocValues statistics for a numeric field storing long
values.
- DocValuesStats.NumericDocValuesStats<T extends java.lang.Number> - Class in org.apache.lucene.search
-
Holds statistics for a numeric DocValues field.
- DocValuesStats.SortedDocValuesStats - Class in org.apache.lucene.search
-
Holds statistics for a sorted DocValues field.
- DocValuesStats.SortedDoubleDocValuesStats - Class in org.apache.lucene.search
-
Holds DocValues statistics for a sorted-numeric field storing double
values.
- DocValuesStats.SortedLongDocValuesStats - Class in org.apache.lucene.search
-
Holds DocValues statistics for a sorted-numeric field storing long
values.
- DocValuesStats.SortedNumericDocValuesStats<T extends java.lang.Number> - Class in org.apache.lucene.search
-
Holds statistics for a sorted-numeric DocValues field.
- DocValuesStats.SortedSetDocValuesStats - Class in org.apache.lucene.search
-
Holds statistics for a sorted-set DocValues field.
- DocValuesStatsCollector - Class in org.apache.lucene.search
-
A
Collector
which computes statistics for a DocValues field.
- DocValuesStatsCollector(DocValuesStats<?>) - Constructor for class org.apache.lucene.search.DocValuesStatsCollector
-
Creates a collector to compute statistics for a DocValues field using the given stats
.
- docValuesStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status for testing of DocValues (null if DocValues could not be tested).
- DocValuesTermsQuery - Class in org.apache.lucene.search
-
A
Query
that only accepts documents whose
term value in the specified field is contained in the
provided set of allowed terms.
- DocValuesTermsQuery(String, Collection<BytesRef>) - Constructor for class org.apache.lucene.search.DocValuesTermsQuery
-
- DocValuesTermsQuery(String, BytesRef...) - Constructor for class org.apache.lucene.search.DocValuesTermsQuery
-
- DocValuesTermsQuery(String, String...) - Constructor for class org.apache.lucene.search.DocValuesTermsQuery
-
- docValuesType(String) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextFieldInfosFormat
-
- docValuesType() - Method in class org.apache.lucene.document.FieldType
-
DocValues
DocValuesType
: how the field's value will be indexed
into docValues.
- DocValuesType - Enum in org.apache.lucene.index
-
DocValues types.
- docValuesType() - Method in interface org.apache.lucene.index.IndexableFieldType
-
DocValues
DocValuesType
: how the field's value will be indexed
into docValues.
- doFail - Variable in class org.apache.lucene.store.MockDirectoryWrapper.Failure
-
- doInform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilterFactory
-
- doInform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddFacetedDocTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddIndexesTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.AnalyzerFactoryTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ClearStatsTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CloseIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CloseReaderTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CloseTaxonomyIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CloseTaxonomyReaderTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CommitIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CommitTaxonomyIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ConsumeContentSourceTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.CreateTaxonomyIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ForceMergeTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.NearRealtimeReaderTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewAnalyzerTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewLocaleTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewRoundTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenReaderTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenTaxonomyIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenTaxonomyReaderTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Perform the task once (ignoring repetitions specification)
Return number of work items done by this task.
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.PrintReaderTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTokensTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReopenReaderTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.RepAllTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSelectByPrefTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByNameRoundTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByNameTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefRoundTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ResetInputsTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ResetSystemEraseTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.ResetSystemSoftTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.RollbackIndexTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.SetPropTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.UpdateDocTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.WaitTask
-
- doLogic() - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
- doMerge(IndexWriter, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- DOMUtils - Class in org.apache.lucene.queryparser.xml
-
Helper methods for parsing XML
- DOMUtils() - Constructor for class org.apache.lucene.queryparser.xml.DOMUtils
-
- DONE - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
-
Indicates the end of iteration
- Done() - Method in interface org.apache.lucene.queryparser.classic.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.classic.FastCharStream
-
- Done() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.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.flexible.standard.parser.FastCharStream
-
- Done() - Method in interface org.apache.lucene.queryparser.surround.parser.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.surround.parser.FastCharStream
-
- DONTNEED - Static variable in class org.apache.lucene.store.NativePosixUtil
-
- doOpenIfChanged() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- doOpenIfChanged() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Implements the actual opening of a new
TaxonomyReader
instance if
the taxonomy has changed.
- doOpenIfChanged() - Method in class org.apache.lucene.index.DirectoryReader
-
- doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.DirectoryReader
-
- doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.DirectoryReader
-
- doOpenIfChanged() - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- doOpenIfChanged() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- doOpenIfChanged(IndexCommit) - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- doOpenIfChanged(IndexWriter, boolean) - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- doPagingSearch(BufferedReader, IndexSearcher, Query, int, boolean, boolean) - Static method in class org.apache.lucene.demo.SearchFiles
-
This demonstrates a typical paging search scenario, where the search engine presents
pages of size n to the user.
- 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.
- doSearching(ExecutorService, long) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.facet.FacetsCollector
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.CheckHits.MatchesAsserter
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.CheckHits.SetCollector
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.NumericComparator
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.AllGroupsCollector
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleCollector
-
This method is called before collecting context
.
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleFieldComparator
-
This method is called before collecting context
.
- doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
- doSkipDuplicates() - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
Returns true if duplicates are filtered out
- doStall() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- doStartCurrentDoc() - Method in class org.apache.lucene.search.spans.Spans
-
Called before the current doc's frequency is calculated
- doTest(boolean) - Method in class org.apache.lucene.util.fst.FSTTester
-
- doTestBinaryVariableLengthVsStoredFields(double) - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- doTestSimulateAppendOnly(MergePolicy, int, int) - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Simulate an append-only use-case, ie.
- doTestSimulateUpdates(MergePolicy, int, int) - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Simulate an update use-case where documents are uniformly updated across segments.
- doTestSortedSetEnumAdvanceIndependently(SortedSetDocValues) - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- doTestSortedSetVsStoredFields(int, int, int, int, int) - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- doTestSortedVsStoredFields(int, double, Supplier<byte[]>) - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- doTestSortedVsStoredFields(int, double, int, int) - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- DOTLESS_YEH - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- dotProduct(Vector) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Do a dot product.
- dotProduct(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Do a dot product.
- DOUBLE_TYPE - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
when we emit a bigram, it's then marked as this type
- DoubleComparator(int, String, Double) - Constructor for class org.apache.lucene.search.FieldComparator.DoubleComparator
-
Creates a new comparator based on Double.compare(double, double)
for numHits
.
- DoubleConstValueSource - Class in org.apache.lucene.queries.function.valuesource
-
Function that returns a constant double value for every document.
- DoubleConstValueSource(double) - Constructor for class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- DoubleDocValues - Class in org.apache.lucene.queries.function.docvalues
-
Abstract
FunctionValues
implementation which supports retrieving double values.
- DoubleDocValues(ValueSource) - Constructor for class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- DoubleDocValuesField - Class in org.apache.lucene.document
-
Syntactic sugar for encoding doubles as NumericDocValues
via Double.doubleToRawLongBits(double)
.
- DoubleDocValuesField(String, double) - Constructor for class org.apache.lucene.document.DoubleDocValuesField
-
Creates a new DocValues field with the specified 64-bit double value
- DoubleDocValuesStats(String) - Constructor for class org.apache.lucene.search.DocValuesStats.DoubleDocValuesStats
-
- doubleField(FieldInfo, double) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- doubleField(FieldInfo, double) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
- doubleField(FieldInfo, double) - Method in class org.apache.lucene.index.StoredFieldVisitor
-
Process a double numeric field.
- DoubleFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- DoubleFieldSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.DoubleFieldSource
-
- DoubleMetaphoneFilter - Class in org.apache.lucene.analysis.phonetic
-
Filter for DoubleMetaphone (supporting secondary codes)
- DoubleMetaphoneFilter(TokenStream, int, boolean) - Constructor for class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilter
-
Creates a DoubleMetaphoneFilter with the specified maximum code length,
and either adding encoded forms as synonyms (inject=true
) or
replacing them.
- DoubleMetaphoneFilterFactory - Class in org.apache.lucene.analysis.phonetic
-
- DoubleMetaphoneFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilterFactory
-
Creates a new DoubleMetaphoneFilterFactory
- DoublePoint - Class in org.apache.lucene.document
-
An indexed double
field for fast range filters.
- DoublePoint(String, double...) - Constructor for class org.apache.lucene.document.DoublePoint
-
Creates a new DoublePoint, indexing the
provided N-dimensional double point.
- DoubleRange - Class in org.apache.lucene.document
-
An indexed Double Range field.
- DoubleRange(String, double[], double[]) - Constructor for class org.apache.lucene.document.DoubleRange
-
Create a new DoubleRange type, from min/max parallel arrays
- DoubleRange - Class in org.apache.lucene.facet.range
-
Represents a range over double values.
- DoubleRange(String, double, boolean, double, boolean) - Constructor for class org.apache.lucene.facet.range.DoubleRange
-
Create a DoubleRange.
- DoubleRangeFacetCounts - Class in org.apache.lucene.facet.range
-
- DoubleRangeFacetCounts(String, FacetsCollector, DoubleRange...) - Constructor for class org.apache.lucene.facet.range.DoubleRangeFacetCounts
-
Create
RangeFacetCounts
, using
DoubleValues
from the specified field.
- DoubleRangeFacetCounts(String, DoubleValuesSource, FacetsCollector, DoubleRange...) - Constructor for class org.apache.lucene.facet.range.DoubleRangeFacetCounts
-
- DoubleRangeFacetCounts(String, DoubleValuesSource, FacetsCollector, Query, DoubleRange...) - Constructor for class org.apache.lucene.facet.range.DoubleRangeFacetCounts
-
Create
RangeFacetCounts
, using the provided
DoubleValuesSource
, and using the provided Query as
a fastmatch: only documents matching the query are
checked for the matching ranges.
- 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.queries.function.docvalues.BoolDocValues
-
- doubleVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- doubleVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- doubleVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- doubleVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- doubleVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- doubleVal(int, double[]) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- doubleValue() - Method in class org.apache.lucene.search.DoubleValues
-
Get the double value for the current document
- DoubleValues - Class in org.apache.lucene.search
-
Per-segment, per-document double values, which can be calculated at search-time
- DoubleValues() - Constructor for class org.apache.lucene.search.DoubleValues
-
- DoubleValuesSource - Class in org.apache.lucene.search
-
- DoubleValuesSource() - Constructor for class org.apache.lucene.search.DoubleValuesSource
-
- downsize(FieldInfo, FuzzySet) - Method in class org.apache.lucene.codecs.bloom.BloomFilterFactory
-
Called when downsizing bitsets for serialization
- downsize(float) - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.AssertingDirectoryReader
-
- doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.ExitableDirectoryReader
-
- doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.FilterDirectoryReader
-
Called by the doOpenIfChanged() methods to return a new wrapped DirectoryReader.
- doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.MismatchedDirectoryReader
-
- doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.SoftDeletesDirectoryReaderWrapper
-
- drillDown(DoubleRange) - Method in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
User drills down on the specified range.
- drillDown(LongRange) - Method in class org.apache.lucene.demo.facet.RangeFacetsExample
-
User drills down on the specified range.
- DrillDownQuery - Class in org.apache.lucene.facet
-
A
Query
for drill-down over facet categories.
- DrillDownQuery(FacetsConfig) - Constructor for class org.apache.lucene.facet.DrillDownQuery
-
Creates a new
DrillDownQuery
without a base query,
to perform a pure browsing query (equivalent to using
MatchAllDocsQuery
as base).
- DrillDownQuery(FacetsConfig, Query) - Constructor for class org.apache.lucene.facet.DrillDownQuery
-
Creates a new DrillDownQuery
over the given base query.
- drillSideways(LongRange) - Method in class org.apache.lucene.demo.facet.RangeFacetsExample
-
User drills down on the specified range, and also computes drill sideways counts.
- DrillSideways - Class in org.apache.lucene.facet
-
Computes drill down and sideways counts for the provided
DrillDownQuery
.
- DrillSideways(IndexSearcher, FacetsConfig, TaxonomyReader) - Constructor for class org.apache.lucene.facet.DrillSideways
-
Create a new DrillSideways
instance.
- DrillSideways(IndexSearcher, FacetsConfig, SortedSetDocValuesReaderState) - Constructor for class org.apache.lucene.facet.DrillSideways
-
- DrillSideways(IndexSearcher, FacetsConfig, TaxonomyReader, SortedSetDocValuesReaderState) - Constructor for class org.apache.lucene.facet.DrillSideways
-
- DrillSideways(IndexSearcher, FacetsConfig, TaxonomyReader, SortedSetDocValuesReaderState, ExecutorService) - Constructor for class org.apache.lucene.facet.DrillSideways
-
- DrillSideways.ConcurrentDrillSidewaysResult<R> - Class in org.apache.lucene.facet
-
Result of a concurrent drill sideways search, including the
Facets
and
TopDocs
.
- DrillSideways.DrillSidewaysResult - Class in org.apache.lucene.facet
-
Result of a drill sideways search, including the
Facets
and
TopDocs
.
- DrillSidewaysResult(Facets, TopDocs) - Constructor for class org.apache.lucene.facet.DrillSideways.DrillSidewaysResult
-
Sole constructor.
- DualFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
Abstract
ValueSource
implementation which wraps two ValueSources
and applies an extendible float function to their values.
- DualFloatFunction(ValueSource, ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- DUMMY - Static variable in class org.apache.lucene.codecs.compressing.dummy.DummyCompressingCodec
-
- DummyCompressingCodec - Class in org.apache.lucene.codecs.compressing.dummy
-
CompressionCodec that does not compress data, useful for testing.
- DummyCompressingCodec(int, int, boolean, int) - Constructor for class org.apache.lucene.codecs.compressing.dummy.DummyCompressingCodec
-
Constructor that allows to configure the chunk size.
- DummyCompressingCodec() - Constructor for class org.apache.lucene.codecs.compressing.dummy.DummyCompressingCodec
-
Default constructor.
- DummyQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
This builder does nothing.
- DummyQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.DummyQueryNodeBuilder
-
- dump() - Method in class org.apache.lucene.analysis.ValidatingTokenFilter
-
- dumpArray(String, Object[], PrintStream) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Convenience method for logging an array.
- dumpIterator(String, Iterator<?>, PrintStream) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Convenience method for logging an iterator.
- dumpValidatingTokenFilters(TokenStream, PrintStream) - Static method in class org.apache.lucene.analysis.ValidatingTokenFilter
-
Prints details about consumed tokens stored in any ValidatingTokenFilters in the input chain
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValue
-
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueBool
-
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueDate
-
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueInt
-
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueLong
-
- duplicate() - Method in class org.apache.lucene.util.mutable.MutableValueStr
-
- DutchAnalyzer - Class in org.apache.lucene.analysis.nl
-
- DutchAnalyzer() - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
- DutchAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
- DutchAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
- DutchAnalyzer(CharArraySet, CharArraySet, CharArrayMap<String>) - Constructor for class org.apache.lucene.analysis.nl.DutchAnalyzer
-
- DutchStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- DutchStemmer() - Constructor for class org.tartarus.snowball.ext.DutchStemmer
-
- dvFormatNames - Variable in class org.apache.lucene.index.RandomCodec
-
unique set of docvalues format names this codec knows about
- F_WORD - Static variable in class org.apache.lucene.search.spell.SpellChecker
-
Field name for each word in the ngram index.
- FacetEntry(BytesRef, int) - Constructor for class org.apache.lucene.search.grouping.GroupFacetCollector.FacetEntry
-
- FacetField - Class in org.apache.lucene.facet
-
Add an instance of this to your
Document
for every facet label.
- FacetField(String, String...) - Constructor for class org.apache.lucene.facet.FacetField
-
Creates the this from dim
and
path
.
- facetField - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- FacetLabel - Class in org.apache.lucene.facet.taxonomy
-
Holds a sequence of string components, specifying the hierarchical name of a
category.
- FacetLabel(String...) - Constructor for class org.apache.lucene.facet.taxonomy.FacetLabel
-
Construct from the given path components.
- FacetLabel(String, String[]) - Constructor for class org.apache.lucene.facet.taxonomy.FacetLabel
-
Construct from the dimension plus the given path components.
- FacetParentVal() - Constructor for class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets.FacetParentVal
-
- facetPrefix - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- FacetQuery - Class in org.apache.lucene.facet
-
- FacetQuery(FacetsConfig, String, String...) - Constructor for class org.apache.lucene.facet.FacetQuery
-
Creates a new FacetQuery
filtering the query on the given dimension.
- FacetQuery(String, String...) - Constructor for class org.apache.lucene.facet.FacetQuery
-
Creates a new FacetQuery
filtering the query on the given dimension.
- FacetResult - Class in org.apache.lucene.facet
-
Counts or aggregates for a single dimension.
- FacetResult(String, String[], Number, LabelAndValue[], int) - Constructor for class org.apache.lucene.facet.FacetResult
-
Sole constructor.
- facets - Variable in class org.apache.lucene.facet.DrillSideways.DrillSidewaysResult
-
Combined drill down and sideways results.
- Facets - Class in org.apache.lucene.facet
-
Common base class for all facets implementations.
- Facets() - Constructor for class org.apache.lucene.facet.Facets
-
Default constructor.
- Facets(int) - Constructor for class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets
-
- FacetsCollector - Class in org.apache.lucene.facet
-
Collects hits for subsequent faceting.
- FacetsCollector() - Constructor for class org.apache.lucene.facet.FacetsCollector
-
Default constructor
- FacetsCollector(boolean) - Constructor for class org.apache.lucene.facet.FacetsCollector
-
Create this; if keepScores
is true then a
float[] is allocated to hold score of all hits.
- FacetsCollector.MatchingDocs - Class in org.apache.lucene.facet
-
- FacetsCollectorManager - Class in org.apache.lucene.facet
-
A
CollectorManager
implementation which produces FacetsCollector and produces a merged FacetsCollector.
- FacetsCollectorManager() - Constructor for class org.apache.lucene.facet.FacetsCollectorManager
-
Sole constructor.
- FacetsConfig - Class in org.apache.lucene.facet
-
Records per-dimension configuration.
- FacetsConfig() - Constructor for class org.apache.lucene.facet.FacetsConfig
-
Default constructor.
- FacetsConfig.DimConfig - Class in org.apache.lucene.facet
-
Holds the configuration for one dimension
- FacetSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Source items for facets.
- FacetSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.FacetSource
-
- FacetVisitor() - Constructor for class org.apache.lucene.spatial.prefix.PrefixTreeFacetCounter.FacetVisitor
-
- Factory() - Constructor for class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree.Factory
-
- Factory() - Constructor for class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.Factory
-
- Factory() - Constructor for class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.Factory
-
- failed - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- failNoMatch() - Method in class org.apache.lucene.facet.range.Range
-
Invoke this for a useless range.
- failOn(MockDirectoryWrapper.Failure) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
add a Failure object to the list of objects to be evaluated
at every potential failure point
- FailOnNonBulkMergesInfoStream - Class in org.apache.lucene.util
-
Hackidy-Häck-Hack to cause a test to fail on non-bulk merges
- FailOnNonBulkMergesInfoStream() - Constructor for class org.apache.lucene.util.FailOnNonBulkMergesInfoStream
-
- Failure() - Constructor for class org.apache.lucene.store.MockDirectoryWrapper.Failure
-
- FailureMarker - Class in org.apache.lucene.util
-
A RunListener
that detects suite/ test failures.
- FailureMarker() - Constructor for class org.apache.lucene.util.FailureMarker
-
- FakeIOException() - Constructor for exception org.apache.lucene.store.MockDirectoryWrapper.FakeIOException
-
- FARSI_YEH - Static variable in class org.apache.lucene.analysis.fa.PersianNormalizer
-
- FAST - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
-
A compression mode that trades compression ratio for speed.
- FAST - Static variable in class org.apache.lucene.util.packed.PackedInts
-
At most 50% memory overhead, always select a reasonably fast implementation.
- FAST_DECOMPRESSION - Static variable in class org.apache.lucene.codecs.compressing.CompressionMode
-
This compression mode is similar to
CompressionMode.FAST
but it spends more time
compressing in order to improve the compression ratio.
- FastCharStream - Class in org.apache.lucene.queryparser.classic
-
An efficient implementation of JavaCC's CharStream interface.
- FastCharStream(Reader) - Constructor for class org.apache.lucene.queryparser.classic.FastCharStream
-
Constructs from a Reader.
- FastCharStream - Class in org.apache.lucene.queryparser.flexible.standard.parser
-
An efficient implementation of JavaCC's CharStream interface.
- FastCharStream(Reader) - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.FastCharStream
-
Constructs from a Reader.
- FastCharStream - Class in org.apache.lucene.queryparser.surround.parser
-
An efficient implementation of JavaCC's CharStream interface.
- FastCharStream(Reader) - Constructor for class org.apache.lucene.queryparser.surround.parser.FastCharStream
-
Constructs from a Reader.
- FastCompressingCodec - Class in org.apache.lucene.codecs.compressing
-
- FastCompressingCodec(int, int, boolean, int) - Constructor for class org.apache.lucene.codecs.compressing.FastCompressingCodec
-
Constructor that allows to configure the chunk size.
- FastCompressingCodec() - Constructor for class org.apache.lucene.codecs.compressing.FastCompressingCodec
-
Default constructor.
- FastDecompressionCompressingCodec - Class in org.apache.lucene.codecs.compressing
-
- FastDecompressionCompressingCodec(int, int, boolean, int) - Constructor for class org.apache.lucene.codecs.compressing.FastDecompressionCompressingCodec
-
Constructor that allows to configure the chunk size.
- FastDecompressionCompressingCodec() - Constructor for class org.apache.lucene.codecs.compressing.FastDecompressionCompressingCodec
-
Default constructor.
- FASTEST - Static variable in class org.apache.lucene.util.packed.PackedInts
-
At most 700% memory overhead, always select a direct implementation.
- fastestFormatAndBits(int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Try to find the
PackedInts.Format
and number of bits per value that would
restore from disk the fastest reader whose overhead is less than
acceptableOverheadRatio
.
- FastTaxonomyFacetCounts - Class in org.apache.lucene.facet.taxonomy
-
Computes facets counts, assuming the default encoding
into DocValues was used.
- FastTaxonomyFacetCounts(TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.FastTaxonomyFacetCounts
-
Create FastTaxonomyFacetCounts
, which also
counts all facet labels.
- FastTaxonomyFacetCounts(String, TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.FastTaxonomyFacetCounts
-
Create FastTaxonomyFacetCounts
, using the
specified indexFieldName
for ordinals.
- FastTaxonomyFacetCounts(String, IndexReader, TaxonomyReader, FacetsConfig) - Constructor for class org.apache.lucene.facet.taxonomy.FastTaxonomyFacetCounts
-
Create FastTaxonomyFacetCounts
, using the
specified indexFieldName
for ordinals, and
counting all non-deleted documents in the index.
- FastVectorHighlighter - Class in org.apache.lucene.search.vectorhighlight
-
Another highlighter implementation.
- FastVectorHighlighter() - Constructor for class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
the default constructor.
- FastVectorHighlighter(boolean, boolean) - Constructor for class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
a constructor.
- FastVectorHighlighter(boolean, boolean, FragListBuilder, FragmentsBuilder) - Constructor for class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
a constructor.
- FATHA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- FATHATAN - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- FeatureField - Class in org.apache.lucene.document
-
Field
that can be used to store static scoring factors into
documents.
- FeatureField(String, String, float) - Constructor for class org.apache.lucene.document.FeatureField
-
Create a feature.
- featureRequested(int, short) - Static method in class org.apache.lucene.index.PostingsEnum
-
Returns true if the given feature is requested in the flags, false otherwise.
- FEH - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- field - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Field name.
- Field - Class in org.apache.lucene.document
-
Expert: directly create a field for a document.
- Field(String, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
-
Expert: creates a field with no initial value.
- Field(String, Reader, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
-
Create field with Reader value.
- Field(String, TokenStream, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
-
Create field with TokenStream value.
- Field(String, byte[], IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
-
Create field with binary value.
- Field(String, byte[], int, int, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
-
Create field with binary value.
- Field(String, BytesRef, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
-
Create field with binary value.
- Field(String, CharSequence, IndexableFieldType) - Constructor for class org.apache.lucene.document.Field
-
Create field with String value.
- field() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
-
- field() - Method in class org.apache.lucene.index.Term
-
Returns the field of this term.
- field - Variable in class org.apache.lucene.misc.TermStats
-
- field - Variable in class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- field - Variable in class org.apache.lucene.queries.function.valuesource.FieldCacheSource
-
- field - Variable in class org.apache.lucene.queries.function.valuesource.NormValueSource
-
- field - Variable in class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- field - Variable in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- field - Variable in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
The term's field
- FIELD - Static variable in class org.apache.lucene.search.BaseExplanationTestCase
-
- field() - Method in class org.apache.lucene.search.CollectionStatistics
-
returns the field name
- field - Variable in class org.apache.lucene.search.DocValuesStats
-
- field() - Method in class org.apache.lucene.search.DocValuesStats
-
The field for which these stats were computed.
- field - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
-
- field - Variable in class org.apache.lucene.search.MultiTermQuery
-
- field - Variable in class org.apache.lucene.search.spans.SpanNearQuery
-
- field - Variable in class org.apache.lucene.search.spans.SpanWeight
-
- field - Variable in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- Field.Store - Enum in org.apache.lucene.document
-
Specifies whether and how a field should be stored.
- field2analyzer - Variable in class org.apache.lucene.classification.document.KNearestNeighborDocumentClassifier
-
map of per field analyzers
- field2analyzer - Variable in class org.apache.lucene.classification.document.SimpleNaiveBayesDocumentClassifier
-
Analyzer
to be used for tokenizing document fields
- FIELD_BOOST_MAP - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set a field to boost map that is used to set the boost for each field
- FIELD_DATE_RESOLUTION_MAP - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set a field to
DateTools.Resolution
map that is used
to normalize each date field value.
- FIELD_DOC - Static variable in class org.apache.lucene.search.SortField
-
Represents sorting by document number (index order).
- FIELD_NAME - Static variable in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- FIELD_SCORE - Static variable in class org.apache.lucene.search.SortField
-
Represents sorting by document score (relevance).
- FIELD_TYPE - Static variable in class org.apache.lucene.search.suggest.document.SuggestField
-
Default field type for suggest field
- FIELD_TYPE - Static variable in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- FieldableNode - Interface in org.apache.lucene.queryparser.flexible.core.nodes
-
A query node implements
FieldableNode
interface to indicate that its
children and itself are associated to a specific field.
- FieldAndTerm(String, BytesRef, long) - Constructor for class org.apache.lucene.index.RandomPostingsTester.FieldAndTerm
-
- FieldBoostMapFCListener - Class in org.apache.lucene.queryparser.flexible.standard.config
-
- FieldBoostMapFCListener(QueryConfigHandler) - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.FieldBoostMapFCListener
-
- FieldCacheSource - Class in org.apache.lucene.queries.function.valuesource
-
A base class for ValueSource implementations that retrieve values for
a single field from DocValues.
- FieldCacheSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.FieldCacheSource
-
- FieldComparator<T> - Class in org.apache.lucene.search
-
Expert: a FieldComparator compares hits so as to determine their
sort order when collecting the top results with
TopFieldCollector
.
- FieldComparator() - Constructor for class org.apache.lucene.search.FieldComparator
-
- FieldComparator.DocComparator - Class in org.apache.lucene.search
-
Sorts by ascending docID
- FieldComparator.DoubleComparator - Class in org.apache.lucene.search
-
- FieldComparator.FloatComparator - Class in org.apache.lucene.search
-
- FieldComparator.IntComparator - Class in org.apache.lucene.search
-
- FieldComparator.LongComparator - Class in org.apache.lucene.search
-
- FieldComparator.NumericComparator<T extends java.lang.Number> - Class in org.apache.lucene.search
-
Base FieldComparator class for numeric types
- FieldComparator.RelevanceComparator - Class in org.apache.lucene.search
-
Sorts by descending relevance.
- FieldComparator.TermOrdValComparator - Class in org.apache.lucene.search
-
Sorts by field's natural Term sort order, using
ordinals.
- FieldComparator.TermValComparator - Class in org.apache.lucene.search
-
Sorts by field's natural Term sort order.
- FieldComparatorSource - Class in org.apache.lucene.search
-
- FieldComparatorSource() - Constructor for class org.apache.lucene.search.FieldComparatorSource
-
- FieldConfig - Class in org.apache.lucene.queryparser.flexible.core.config
-
This class represents a field configuration.
- FieldConfig(String) - Constructor for class org.apache.lucene.queryparser.flexible.core.config.FieldConfig
-
- FieldConfigListener - Interface in org.apache.lucene.queryparser.flexible.core.config
-
This interface should be implemented by classes that wants to listen for
field configuration requests.
- FieldDateResolutionFCListener - Class in org.apache.lucene.queryparser.flexible.standard.config
-
- FieldDateResolutionFCListener(QueryConfigHandler) - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.FieldDateResolutionFCListener
-
- 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.
- FieldFilterLeafReader - Class in org.apache.lucene.index
-
A
FilterLeafReader
that exposes only a subset
of fields from the underlying wrapped reader.
- FieldFilterLeafReader(LeafReader, Set<String>, boolean) - Constructor for class org.apache.lucene.index.FieldFilterLeafReader
-
- FieldFragList - Class in org.apache.lucene.search.vectorhighlight
-
FieldFragList has a list of "frag info" that is used by FragmentsBuilder class
to create fragments (snippets).
- FieldFragList(int) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldFragList
-
a constructor.
- FieldFragList.WeightedFragInfo - Class in org.apache.lucene.search.vectorhighlight
-
List of term offsets + weight for a frag info
- FieldFragList.WeightedFragInfo.SubInfo - Class in org.apache.lucene.search.vectorhighlight
-
Represents the list of term offsets for some text
- FieldHighlighter - Class in org.apache.lucene.search.uhighlight
-
Internal highlighter abstraction that operates on a per field basis.
- FieldHighlighter(String, FieldOffsetStrategy, BreakIterator, PassageScorer, int, int, PassageFormatter) - Constructor for class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- FieldIndexEnum() - Constructor for class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase.FieldIndexEnum
-
- fieldInfo - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
-
- FieldInfo - Class in org.apache.lucene.index
-
Access to the Field Info file that describes document fields and whether or
not they are indexed.
- FieldInfo(String, int, boolean, boolean, boolean, IndexOptions, DocValuesType, long, Map<String, String>, int, int, int, boolean) - Constructor for class org.apache.lucene.index.FieldInfo
-
Sole constructor.
- fieldInfo(String) - Method in class org.apache.lucene.index.FieldInfos
-
Return the fieldinfo object referenced by the field name
- fieldInfo(int) - Method in class org.apache.lucene.index.FieldInfos
-
Return the fieldinfo object referenced by the fieldNumber.
- FieldInfos - Class in org.apache.lucene.index
-
Collection of
FieldInfo
s (accessible by number or by name).
- FieldInfos(FieldInfo[]) - Constructor for class org.apache.lucene.index.FieldInfos
-
Constructs a new FieldInfos from an array of FieldInfo objects
- fieldInfos - Variable in class org.apache.lucene.index.MergeState
-
FieldInfos being merged
- fieldInfos - Variable in class org.apache.lucene.index.SegmentReadState
-
- fieldInfos - Variable in class org.apache.lucene.index.SegmentWriteState
-
- fieldInfos - Variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes field infos file
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- FieldInfosFormat - Class in org.apache.lucene.codecs
-
- FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.FieldInfosFormat
-
Sole constructor.
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- fieldInfosFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- fieldInfoStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status for testing of field infos
- FieldInvertState - Class in org.apache.lucene.index
-
This class tracks the number and position / offset parameters of terms
being added to the index.
- FieldInvertState(int, String) - Constructor for class org.apache.lucene.index.FieldInvertState
-
Creates {code FieldInvertState} for the specified
field name.
- FieldInvertState(int, String, int, int, int, int) - Constructor for class org.apache.lucene.index.FieldInvertState
-
Creates {code FieldInvertState} for the specified
field name and values for all fields.
- FieldMaskingSpanQuery - Class in org.apache.lucene.search.spans
-
Wrapper to allow
SpanQuery
objects participate in composite
single-field SpanQueries by 'lying' about their search field.
- FieldMaskingSpanQuery(SpanQuery, String) - Constructor for class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-
- fieldName - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery
-
- fieldNameComparator(String) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Necessary to implement matches for queries against defaultField
- fieldNamesToString(StringBuilder) - Method in class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- 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).
- fieldOffsetStrategy - Variable in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- FieldOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
Ultimately returns an
OffsetsEnum
yielding potentially highlightable words in the text.
- FieldOffsetStrategy(UHComponents) - Constructor for class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- FieldPhraseList - Class in org.apache.lucene.search.vectorhighlight
-
FieldPhraseList has a list of WeightedPhraseInfo that is used by FragListBuilder
to create a FieldFragList object.
- FieldPhraseList(FieldTermStack, FieldQuery) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldPhraseList
-
create a FieldPhraseList that has no limit on the number of phrases to analyze
- FieldPhraseList(FieldTermStack, FieldQuery, int) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldPhraseList
-
a constructor.
- FieldPhraseList(FieldPhraseList[]) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldPhraseList
-
Merging constructor.
- FieldPhraseList.WeightedPhraseInfo - Class in org.apache.lucene.search.vectorhighlight
-
Represents the list of term offsets and boost for some text
- FieldPhraseList.WeightedPhraseInfo.Toffs - Class in org.apache.lucene.search.vectorhighlight
-
Term offsets (start + end)
- FieldQuery - Class in org.apache.lucene.search.vectorhighlight
-
FieldQuery breaks down query object into terms/phrases and keeps
them in a QueryPhraseMap structure.
- FieldQuery.QueryPhraseMap - Class in org.apache.lucene.search.vectorhighlight
-
Internal structure of a query for highlighting: represents
a nested query structure
- FieldQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
- FieldQueryNode(CharSequence, CharSequence, int, int) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- FieldQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- FieldQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.FieldQueryNodeBuilder
-
- FieldReader - Class in org.apache.lucene.codecs.blocktree
-
BlockTree's implementation of
Terms
.
- Fields - Class in org.apache.lucene.index
-
Provides a
Terms
index for fields that have it, and lists which fields do.
- Fields() - Constructor for class org.apache.lucene.index.Fields
-
Sole constructor.
- fields - Variable in class org.apache.lucene.queryparser.classic.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 - Variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter.LimitedStoredFieldVisitor
-
- FIELDS_EXTENSION - Static variable in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
Extension of stored fields file
- FIELDS_HEADER_INDICATOR - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
- FIELDS_INDEX_EXTENSION - Static variable in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
Extension of stored fields index file
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.asserting.AssertingDocValuesFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.asserting.AssertingPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.blockterms.LuceneFixedGap
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.blockterms.LuceneVarGapDocFreqInterval
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.blockterms.LuceneVarGapFixedInterval
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.blocktreeords.BlockTreeOrdsPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.bloom.BloomFilteringPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.bloom.TestBloomFilteredLucenePostings
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.DocValuesFormat
-
- FieldsConsumer - Class in org.apache.lucene.codecs
-
Abstract API that consumes terms, doc, freq, prox, offset and
payloads postings.
- FieldsConsumer() - Constructor for class org.apache.lucene.codecs.FieldsConsumer
-
Sole constructor.
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene54.Lucene54DocValuesFormat
-
Deprecated.
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene70.Lucene70DocValuesFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.memory.DirectDocValuesFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.memory.DirectPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.memory.FSTOrdPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.memory.FSTPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.memory.MemoryDocValuesFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.memory.MemoryPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.mockrandom.MockRandomPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.PostingsFormat
-
Writes a new segment
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.ramonly.RAMOnlyPostingsFormat
-
- fieldsConsumer(SegmentWriteState) - Method in class org.apache.lucene.search.suggest.document.CompletionPostingsFormat
-
- fieldsData - Variable in class org.apache.lucene.document.Field
-
Field's value
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.asserting.AssertingDocValuesFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.asserting.AssertingPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.blockterms.LuceneFixedGap
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.blockterms.LuceneVarGapDocFreqInterval
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.blockterms.LuceneVarGapFixedInterval
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.blocktreeords.BlockTreeOrdsPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.bloom.BloomFilteringPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.bloom.TestBloomFilteredLucenePostings
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.DocValuesFormat
-
- FieldsProducer - Class in org.apache.lucene.codecs
-
Abstract API that produces terms, doc, freq, prox, offset and
payloads postings.
- FieldsProducer() - Constructor for class org.apache.lucene.codecs.FieldsProducer
-
Sole constructor.
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene54.Lucene54DocValuesFormat
-
Deprecated.
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene70.Lucene70DocValuesFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.memory.DirectDocValuesFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.memory.DirectPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.memory.FSTOrdPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.memory.FSTPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.memory.MemoryDocValuesFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.memory.MemoryPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.mockrandom.MockRandomPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.PostingsFormat
-
Reads a segment.
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.ramonly.RAMOnlyPostingsFormat
-
- fieldsProducer(SegmentReadState) - Method in class org.apache.lucene.search.suggest.document.CompletionPostingsFormat
-
- fieldsProducers - Variable in class org.apache.lucene.index.MergeState
-
Postings to merge
- FieldsQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- FieldsQuery - Class in org.apache.lucene.queryparser.surround.query
-
Forms an OR query of the provided query across multiple fields.
- FieldsQuery(SrndQuery, List<String>, char) - Constructor for class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- FieldsQuery(SrndQuery, String, char) - Constructor for class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- FieldsQueryList() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.asserting.AssertingPointsFormat
-
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.asserting.AssertingStoredFieldsFormat
-
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
-
- fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsFormat
-
- fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.PointsFormat
-
Reads a segment.
- fieldsReader(SegmentReadState) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextPointsFormat
-
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsFormat
-
- fieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
-
- fieldsToLoad - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetLoadFieldSelectorTask
-
- fieldSupportsHugeBinaryDocValues(String) - Static method in class org.apache.lucene.util.TestUtil
-
- fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.asserting.AssertingPointsFormat
-
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.asserting.AssertingStoredFieldsFormat
-
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
-
- fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsFormat
-
- fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.PointsFormat
-
Writes a new segment
- fieldsWriter(SegmentWriteState) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextPointsFormat
-
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsFormat
-
- fieldsWriter(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.StoredFieldsFormat
-
- FieldTermStack - Class in org.apache.lucene.search.vectorhighlight
-
FieldTermStack
is a stack that keeps query terms in the specified field
of the document to be highlighted.
- FieldTermStack(IndexReader, int, String, FieldQuery) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldTermStack
-
a constructor.
- FieldTermStack.TermInfo - Class in org.apache.lucene.search.vectorhighlight
-
Single term with its position/offsets in the document and IDF weight.
- fieldType() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- fieldType() - Method in class org.apache.lucene.document.Field
-
- FieldType - Class in org.apache.lucene.document
-
Describes the properties of a field.
- FieldType(IndexableFieldType) - Constructor for class org.apache.lucene.document.FieldType
-
Create a new mutable FieldType with all of the properties from ref
- FieldType() - Constructor for class org.apache.lucene.document.FieldType
-
Create a new FieldType with default properties.
- fieldType() - Method in class org.apache.lucene.document.LazyDocument.LazyField
-
- fieldType(BaseTermVectorsFormatTestCase.Options) - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- fieldType() - Method in interface org.apache.lucene.index.IndexableField
-
- 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
-
- FieldValuePairQueryNode<T> - Interface in org.apache.lucene.queryparser.flexible.core.nodes
-
This interface should be implemented by
QueryNode
that holds a field
and an arbitrary value.
- FieldWriter() - Constructor for class org.apache.lucene.codecs.blockterms.TermsIndexWriterBase.FieldWriter
-
- FileBasedQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
Create queries from a FileReader.
- FileBasedQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.FileBasedQueryMaker
-
- FileDictionary - Class in org.apache.lucene.search.suggest
-
Dictionary represented by a text file.
- FileDictionary(InputStream) - Constructor for class org.apache.lucene.search.suggest.FileDictionary
-
Creates a dictionary based on an inputstream.
- FileDictionary(Reader) - Constructor for class org.apache.lucene.search.suggest.FileDictionary
-
Creates a dictionary based on a reader.
- FileDictionary(Reader, String) - Constructor for class org.apache.lucene.search.suggest.FileDictionary
-
Creates a dictionary based on a reader.
- FileDictionary(InputStream, String) - Constructor for class org.apache.lucene.search.suggest.FileDictionary
-
Creates a dictionary based on an inputstream.
- fileLength(String) - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- fileLength(String) - Method in class org.apache.lucene.store.Directory
-
Returns the byte length of a file in the directory.
- fileLength(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- fileLength(String) - Method in class org.apache.lucene.store.FilterDirectory
-
- fileLength(String) - Method in class org.apache.lucene.store.FSDirectory
-
- fileLength(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- fileLength(String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- fileLength(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
Returns the length in bytes of a file in the directory.
- fileMap - Variable in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- FileMetaData - Class in org.apache.lucene.replicator.nrt
-
Holds metadata details about a single file that we use to confirm two files (one remote, one local) are in fact "identical".
- FileMetaData(byte[], byte[], long, long) - Constructor for class org.apache.lucene.replicator.nrt.FileMetaData
-
- fileName - Variable in class org.apache.lucene.replicator.RevisionFile
-
The name of the file.
- FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.ConnectionCosts
-
- FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ko.dict.ConnectionCosts
-
- fileNameExists(String) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- fileNameFromGeneration(String, String, long) - Static method in class org.apache.lucene.index.IndexFileNames
-
Computes the full file name from base, extension and generation.
- files(SegmentCommitInfo, Collection<String>) - Method in class org.apache.lucene.codecs.asserting.AssertingLiveDocsFormat
-
- files(SegmentCommitInfo, Collection<String>) - Method in class org.apache.lucene.codecs.LiveDocsFormat
-
- files(SegmentCommitInfo, Collection<String>) - Method in class org.apache.lucene.codecs.lucene50.Lucene50LiveDocsFormat
-
- files(SegmentCommitInfo, Collection<String>) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextLiveDocsFormat
-
- files() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns all files in use by this segment.
- files() - Method in class org.apache.lucene.index.SegmentInfo
-
Return all files referenced by this SegmentInfo.
- files(boolean) - Method in class org.apache.lucene.index.SegmentInfos
-
Returns all file names referenced by SegmentInfo.
- files - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- files - Variable in class org.apache.lucene.replicator.nrt.CopyState
-
- 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
-
- fileSystem - Variable in class org.apache.lucene.mockfile.FilterDirectoryStream
-
The underlying FileSystem
instance.
- fileSystem - Variable in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
The underlying FileSystem
instance.
- fileSystem - Variable in class org.apache.lucene.mockfile.FilterPath
-
The parent FileSystem
for this path.
- FilesystemResourceLoader - Class in org.apache.lucene.analysis.util
-
Simple
ResourceLoader
that opens resource files
from the local file system, optionally resolving against
a base directory.
- FilesystemResourceLoader(Path) - Constructor for class org.apache.lucene.analysis.util.FilesystemResourceLoader
-
- FilesystemResourceLoader(Path, ClassLoader) - Constructor for class org.apache.lucene.analysis.util.FilesystemResourceLoader
-
Creates a resource loader that resolves resources against the given
base directory (may be null
to refer to CWD).
- FilesystemResourceLoader(Path, ResourceLoader) - Constructor for class org.apache.lucene.analysis.util.FilesystemResourceLoader
-
Creates a resource loader that resolves resources against the given
base directory (may be null
to refer to CWD).
- fill(CharacterUtils.CharacterBuffer, Reader, int) - Static method in class org.apache.lucene.analysis.CharacterUtils
-
- fill(CharacterUtils.CharacterBuffer, Reader) - Static method in class org.apache.lucene.analysis.CharacterUtils
-
Convenience method which calls fill(buffer, reader, buffer.buffer.length)
.
- fill(int, int, long) - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- fill(int, int, long) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
-
Fill the mutable from fromIndex
(inclusive) to
toIndex
(exclusive) with val
.
- fill(BytesRef, long) - Method in class org.apache.lucene.util.PagedBytes.Reader
-
Reads length as 1 or 2 byte vInt prefix, starting at start.
- fillBasicStats(BasicStats, CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.LMSimilarity
-
Computes the collection probability of the current term in addition to the
usual statistics.
- fillBasicStats(BasicStats, CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
Fills all member fields defined in BasicStats
in stats
.
- fillChildrenBufferAndApplyModifiery(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- fillPages() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- fillSlice(BytesRef, long, int) - Method in class org.apache.lucene.util.PagedBytes.Reader
-
Gets a slice out of
PagedBytes
starting at
start with a
given length.
- fillValue(int) - Method in class org.apache.lucene.queries.function.FunctionValues.ValueFiller
-
MutableValue will be reused across calls.
- filter(SegToken) - Method in class org.apache.lucene.analysis.cn.smart.hhmm.SegTokenFilter
-
- FILTER_ARG_SEPARATOR - Static variable in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- FILTER_NAME_ID_SEPARATOR - Static variable in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- FilterAsynchronousFileChannel - Class in org.apache.lucene.mockfile
-
A FilterAsynchronousFileChannel
contains another
AsynchronousFileChannel
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterAsynchronousFileChannel(AsynchronousFileChannel) - Constructor for class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
Construct a FilterAsynchronousFileChannel
based on
the specified base channel.
- FilterBinaryDocValues - Class in org.apache.lucene.index
-
- FilterBinaryDocValues(BinaryDocValues) - Constructor for class org.apache.lucene.index.FilterBinaryDocValues
-
Sole constructor
- FilterCodec - Class in org.apache.lucene.codecs
-
A codec that forwards all its method calls to another codec.
- FilterCodec(String, Codec) - Constructor for class org.apache.lucene.codecs.FilterCodec
-
Sole constructor.
- FilterCodecReader - Class in org.apache.lucene.index
-
A FilterCodecReader
contains another CodecReader, which it
uses as its basic source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterCodecReader(CodecReader) - Constructor for class org.apache.lucene.index.FilterCodecReader
-
Creates a new FilterCodecReader.
- FilterCollector - Class in org.apache.lucene.search
-
- FilterCollector(Collector) - Constructor for class org.apache.lucene.search.FilterCollector
-
Sole constructor.
- FilterDirectory - Class in org.apache.lucene.store
-
Directory implementation that delegates calls to another directory.
- FilterDirectory(Directory) - Constructor for class org.apache.lucene.store.FilterDirectory
-
Sole constructor, typically called from sub-classes.
- FilterDirectoryReader - Class in org.apache.lucene.index
-
A FilterDirectoryReader wraps another DirectoryReader, allowing implementations
to transform or extend it.
- FilterDirectoryReader(DirectoryReader, FilterDirectoryReader.SubReaderWrapper) - Constructor for class org.apache.lucene.index.FilterDirectoryReader
-
Create a new FilterDirectoryReader that filters a passed in DirectoryReader,
using the supplied SubReaderWrapper to wrap its subreader.
- FilterDirectoryReader.SubReaderWrapper - Class in org.apache.lucene.index
-
Factory class passed to FilterDirectoryReader constructor that allows
subclasses to wrap the filtered DirectoryReader's subreaders.
- FilterDirectoryStream - Class in org.apache.lucene.mockfile
-
A FilterDirectoryStream
contains another
DirectoryStream
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterDirectoryStream(DirectoryStream<Path>, FileSystem) - Constructor for class org.apache.lucene.mockfile.FilterDirectoryStream
-
Construct a FilterDirectoryStream
based on
the specified base stream.
- 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(Query, Query) - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- FilteredTermsEnum - Class in org.apache.lucene.index
-
Abstract class for enumerating a subset of all terms.
- FilteredTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
-
Creates a filtered
TermsEnum
on a terms enum.
- FilteredTermsEnum(TermsEnum, boolean) - Constructor for class org.apache.lucene.index.FilteredTermsEnum
-
Creates a filtered
TermsEnum
on a terms enum.
- FilteredTermsEnum.AcceptStatus - Enum in org.apache.lucene.index
-
Return value, if term should be accepted or the iteration should
END
.
- filterExtractedTerms(Predicate<String>, Set<Term>) - Static method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- FilterFields(Fields) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterFields
-
Creates a new FilterFields.
- FilterFileChannel - Class in org.apache.lucene.mockfile
-
A FilterFileChannel
contains another
FileChannel
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterFileChannel(FileChannel) - Constructor for class org.apache.lucene.mockfile.FilterFileChannel
-
Construct a FilterFileChannel
based on
the specified base channel.
- FilterFileStore - Class in org.apache.lucene.mockfile
-
A FilterFileStore
contains another
FileStore
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterFileStore(FileStore, String) - Constructor for class org.apache.lucene.mockfile.FilterFileStore
-
Construct a FilterFileStore
based on
the specified base store.
- FilterFileSystem - Class in org.apache.lucene.mockfile
-
A FilterFileSystem
contains another
FileSystem
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterFileSystem(FilterFileSystemProvider, FileSystem) - Constructor for class org.apache.lucene.mockfile.FilterFileSystem
-
Construct a FilterFileSystem
based on
the specified base filesystem.
- FilterFileSystemProvider - Class in org.apache.lucene.mockfile
-
A FilterFileSystemProvider
contains another
FileSystemProvider
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterFileSystemProvider(String, FileSystem) - Constructor for class org.apache.lucene.mockfile.FilterFileSystemProvider
-
Construct a FilterFileSystemProvider
indicated by
the specified scheme
and wrapping functionality of the
provider of the specified base filesystem.
- FilterFileSystemProvider(String, FileSystemProvider) - Constructor for class org.apache.lucene.mockfile.FilterFileSystemProvider
-
Construct a FilterFileSystemProvider
indicated by
the specified scheme
and wrapping functionality of the
provider.
- FilteringTokenFilter - Class in org.apache.lucene.analysis
-
Abstract base class for TokenFilters that may remove tokens.
- FilteringTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.FilteringTokenFilter
-
- FilterInputStream2 - Class in org.apache.lucene.mockfile
-
A FilterInputStream2
contains another
InputStream
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterInputStream2(InputStream) - Constructor for class org.apache.lucene.mockfile.FilterInputStream2
-
Construct a FilterInputStream2
based on
the specified base stream.
- FilterIterator<T,InnerT extends T> - Class in org.apache.lucene.util
-
An Iterator
implementation that filters elements with a boolean predicate.
- FilterIterator(Iterator<InnerT>) - Constructor for class org.apache.lucene.util.FilterIterator
-
- FilterLeafCollector - Class in org.apache.lucene.search
-
- FilterLeafCollector(LeafCollector) - Constructor for class org.apache.lucene.search.FilterLeafCollector
-
Sole constructor.
- FilterLeafReader - Class in org.apache.lucene.index
-
A FilterLeafReader
contains another LeafReader, which it
uses as its basic source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterLeafReader(LeafReader) - Constructor for class org.apache.lucene.index.FilterLeafReader
-
Construct a FilterLeafReader based on the specified base reader.
- FilterLeafReader.FilterFields - Class in org.apache.lucene.index
-
Base class for filtering
Fields
implementations.
- FilterLeafReader.FilterPostingsEnum - Class in org.apache.lucene.index
-
- FilterLeafReader.FilterTerms - Class in org.apache.lucene.index
-
Base class for filtering
Terms
implementations.
- FilterLeafReader.FilterTermsEnum - Class in org.apache.lucene.index
-
Base class for filtering
TermsEnum
implementations.
- FilterMatchesIterator - Class in org.apache.lucene.search
-
A MatchesIterator that delegates all calls to another MatchesIterator
- FilterMatchesIterator(MatchesIterator) - Constructor for class org.apache.lucene.search.FilterMatchesIterator
-
Create a new FilterMatchesIterator
- FilterMergePolicy - Class in org.apache.lucene.index
-
- FilterMergePolicy(MergePolicy) - Constructor for class org.apache.lucene.index.FilterMergePolicy
-
Creates a new filter merge policy instance wrapping another.
- FilterNumericDocValues - Class in org.apache.lucene.index
-
- FilterNumericDocValues(NumericDocValues) - Constructor for class org.apache.lucene.index.FilterNumericDocValues
-
Sole constructor
- FilterOutputStream2 - Class in org.apache.lucene.mockfile
-
A FilterOutputStream2
contains another
OutputStream
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterOutputStream2(OutputStream) - Constructor for class org.apache.lucene.mockfile.FilterOutputStream2
-
Construct a FilterOutputStream2
based on
the specified base stream.
- FilterPath - Class in org.apache.lucene.mockfile
-
A FilterPath
contains another
Path
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterPath(Path, FileSystem) - Constructor for class org.apache.lucene.mockfile.FilterPath
-
Construct a FilterPath
with parent
fileSystem
, based on the specified base path.
- FilterPostingsEnum(PostingsEnum) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
Create a new FilterPostingsEnum
- FilterScorer - Class in org.apache.lucene.search
-
A FilterScorer
contains another Scorer
, which it
uses as its basic source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterScorer(Scorer) - Constructor for class org.apache.lucene.search.FilterScorer
-
Create a new FilterScorer
- FilterScorer(Scorer, Weight) - Constructor for class org.apache.lucene.search.FilterScorer
-
Create a new FilterScorer with a specific weight
- FilterSeekableByteChannel - Class in org.apache.lucene.mockfile
-
A FilterSeekableByteChannel
contains another
SeekableByteChannel
, which it uses as its basic
source of data, possibly transforming the data along the
way or providing additional functionality.
- FilterSeekableByteChannel(SeekableByteChannel) - Constructor for class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
Construct a FilterSeekableByteChannel
based on
the specified base channel.
- FilterSpans - Class in org.apache.lucene.search.spans
-
- FilterSpans(Spans) - Constructor for class org.apache.lucene.search.spans.FilterSpans
-
- FilterSpans.AcceptStatus - Enum in org.apache.lucene.search.spans
-
Status returned from
FilterSpans.accept(Spans)
that indicates
whether a candidate match should be accepted, rejected, or rejected
and move on to the next document.
- FilterTerms(Terms) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
Creates a new FilterTerms
- FilterTermsEnum(TermsEnum) - Constructor for class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
Creates a new FilterTermsEnum
- FilterWeight - Class in org.apache.lucene.search
-
A FilterWeight
contains another Weight
and implements
all abstract methods by calling the contained weight's method.
- FilterWeight(Weight) - Constructor for class org.apache.lucene.search.FilterWeight
-
Default constructor.
- FilterWeight(Query, Weight) - Constructor for class org.apache.lucene.search.FilterWeight
-
Alternative constructor.
- find(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- find(char[], int) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- find(BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
-
- find(int) - Method in class org.apache.lucene.util.SentinelIntSet
-
(internal) Returns the slot for this key, or -slot-1 if not found
- find_among(Among[], int) - Method in class org.tartarus.snowball.SnowballProgram
-
- find_among_b(Among[], int) - Method in class org.tartarus.snowball.SnowballProgram
-
- findArcDistancePoints(PlanetModel, double, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Locate a point that is within the specified bounds and on the specified plane, that has an arcDistance as
specified from the startPoint.
- findCategory(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Look up the given category in the cache and/or the on-disk storage,
returning the category's ordinal, or a negative number in case the
category does not yet exist in the taxonomy.
- findClass(String, Class<T>) - Method in class org.apache.lucene.analysis.util.ClasspathResourceLoader
-
- findClass(String, Class<T>) - Method in class org.apache.lucene.analysis.util.FilesystemResourceLoader
-
- findClass(String, Class<T>) - Method in interface org.apache.lucene.analysis.util.ResourceLoader
-
Finds class of the name and expected type
- findCrossings(PlanetModel, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Find the points between two planes, where one plane crosses the other, given a set of bounds.
- findCrossings(PlanetModel, Plane, Membership[], Membership[]) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Find the points between two planes, where one plane crosses the other, given a set of bounds.
- findDistancePoints(PlanetModel, double, GeoPoint, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.ArcDistance
-
- findDistancePoints(PlanetModel, double, GeoPoint, Plane, Membership...) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Find a GeoPoint, at a specified distance from a starting point, within the
specified bounds.
- findDistancePoints(PlanetModel, double, GeoPoint, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LinearDistance
-
- findDistancePoints(PlanetModel, double, GeoPoint, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- findDistancePoints(PlanetModel, double, GeoPoint, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.NormalDistance
-
- findDistancePoints(PlanetModel, double, GeoPoint, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- findEndOffset(StringBuilder, int) - Method in interface org.apache.lucene.search.vectorhighlight.BoundaryScanner
-
Scan forward to find start offset.
- findEndOffset(StringBuilder, int) - Method in class org.apache.lucene.search.vectorhighlight.BreakIteratorBoundaryScanner
-
- findEndOffset(StringBuilder, int) - Method in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
-
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
-
Finds merges necessary to force-merge all deletes from the
index.
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
-
Determine what set of merge operations is necessary in order to expunge all
deletes from the index.
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MockRandomMergePolicy
-
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
-
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.OneMergeWrappingMergePolicy
-
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.TieredMergePolicy
-
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
-
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns the merges necessary to merge the index down
to a specified number of segments.
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
-
Determine what set of merge operations is necessary in
order to merge to <=
the specified segment count.
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MockRandomMergePolicy
-
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
-
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.OneMergeWrappingMergePolicy
-
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.TieredMergePolicy
-
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-
- findIndexCommit(Directory, String) - Static method in class org.apache.lucene.benchmark.byTask.tasks.OpenReaderTask
-
- findIntersectionBounds(PlanetModel, Bounds, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Record intersection points for planes with error bounds.
- findIntersections(PlanetModel, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Find the intersection points between two planes, given a set of bounds.
- findIntersections(PlanetModel, Plane, Membership[], Membership[]) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Find the intersection points between two planes, given a set of bounds.
- findMaximumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.ArcDistance
-
- findMaximumArcDistance(PlanetModel, double) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Given a distance metric, find the maximum arc distance represented by the distance metric.
- findMaximumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.LinearDistance
-
- findMaximumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- findMaximumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.NormalDistance
-
- findMaximumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.ForceMergePolicy
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
-
Determine what set of merge operations are now necessary on the index.
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MockRandomMergePolicy
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.OneMergeWrappingMergePolicy
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.TieredMergePolicy
-
- findMerges(MergeTrigger, SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-
- findMinimumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.ArcDistance
-
- findMinimumArcDistance(PlanetModel, double) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Given a distance metric, find the minimum arc distance represented by that distance metric.
- findMinimumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.LinearDistance
-
- findMinimumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- findMinimumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.NormalDistance
-
- findMinimumArcDistance(PlanetModel, double) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- findPattern(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
- FindSegmentsFile(Directory) - Constructor for class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
-
Sole constructor.
- findStartOffset(StringBuilder, int) - Method in interface org.apache.lucene.search.vectorhighlight.BoundaryScanner
-
Scan backward to find end offset.
- findStartOffset(StringBuilder, int) - Method in class org.apache.lucene.search.vectorhighlight.BreakIteratorBoundaryScanner
-
- findStartOffset(StringBuilder, int) - Method in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- findSubCellsToVisit(Cell) - Method in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery.VisitorTemplate
-
Called when doing a divide and conquer to find the next intersecting cells
of the query shape that are beneath cell
.
- findTargetArc(int, FST.Arc<Long>, FST.Arc<Long>, boolean, FST.BytesReader) - Method in class org.apache.lucene.analysis.ja.dict.TokenInfoFST
-
- findTargetArc(int, FST.Arc<Long>, FST.Arc<Long>, boolean, FST.BytesReader) - Method in class org.apache.lucene.analysis.ko.dict.TokenInfoFST
-
- 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.
- FingerprintFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Filter outputs a single token which is a concatenation of the sorted and
de-duplicated set of input tokens.
- FingerprintFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.FingerprintFilter
-
Create a new FingerprintFilter with default settings
- FingerprintFilter(TokenStream, int, char) - Constructor for class org.apache.lucene.analysis.miscellaneous.FingerprintFilter
-
Create a new FingerprintFilter with control over all settings
- FingerprintFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- FingerprintFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.FingerprintFilterFactory
-
Creates a new FingerprintFilterFactory
- finish() - Method in class org.apache.lucene.analysis.ja.GraphvizFormatter
-
- finish() - Method in class org.apache.lucene.analysis.ko.GraphvizFormatter
-
- finish(long) - Method in class org.apache.lucene.codecs.blockterms.TermsIndexWriterBase.FieldWriter
-
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- finish() - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsWriter
-
- finish() - Method in class org.apache.lucene.codecs.PointsWriter
-
Called once at the end before close
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsWriter
-
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsWriter
-
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
-
- finish(FieldInfos, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
- finish() - Method in class org.apache.lucene.geo.EarthDebugger
-
- finish() - Method in class org.apache.lucene.index.PrefixCodedTerms.Builder
-
return finalized form
- finish() - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
Renames all copied (tmp) files to their true file names
- finish() - Method in class org.apache.lucene.search.ShardSearchingTestBase
-
- finish() - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Call this once you are done adding states/transitions.
- finish(int) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Call this once you are done adding states/transitions.
- finish() - Method in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery.VisitorTemplate
-
Called last to return the result.
- finish() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Compiles all added states and transitions into a new Automaton
and returns it.
- finish(IndexOutput) - Method in class org.apache.lucene.util.bkd.BKDWriter
-
Writes the BKD tree to the provided
IndexOutput
and returns the file offset where index was written.
- finish() - Method in class org.apache.lucene.util.fst.Builder
-
Returns final FST.
- finish() - Method in class org.apache.lucene.util.packed.DirectMonotonicWriter
-
This must be called exactly once after all values have been
added
.
- finish() - Method in class org.apache.lucene.util.packed.DirectWriter
-
finishes writing
- finish() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
-
Perform end-of-stream operations.
- finishCopyFile(String) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- finishDoc() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- finishDoc() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
-
Called when we are done adding positions and payloads
for each doc.
- finishDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
- finishDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- finishDocument() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
-
Called when a document and all its fields have been added.
- finishDocument() - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Called after a doc and all its fields have been added.
- finishField() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- finishField() - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Called after a field and all its terms have been added.
- finishNRTCopy(CopyJob, long) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- finishQuery(BooleanQuery.Builder, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Subclass can override this to tweak the Query before
searching.
- finishState() - Method in class org.apache.lucene.util.automaton.Automaton
-
Finishes the current state; call this once you are done adding
transitions for a state.
- finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
Called when we are done adding docs to this term
- finishTerm(BlockTermState) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
-
Finishes the current term.
- finishTerm() - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Called after a term and all its positions have been added.
- finite - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-
Indicates if the automaton accepts a finite set of strings.
- FiniteStringsIterator - Class in org.apache.lucene.util.automaton
-
Iterates all accepted strings.
- FiniteStringsIterator(Automaton) - Constructor for class org.apache.lucene.util.automaton.FiniteStringsIterator
-
Constructor.
- FiniteStringsIterator(Automaton, int, int) - Constructor for class org.apache.lucene.util.automaton.FiniteStringsIterator
-
Constructor.
- FinnishAnalyzer - Class in org.apache.lucene.analysis.fi
-
- FinnishAnalyzer() - Constructor for class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
- FinnishAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
Builds an analyzer with the given stop words.
- FinnishAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
Builds an analyzer with the given stop words.
- FinnishLightStemFilter - Class in org.apache.lucene.analysis.fi
-
- FinnishLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fi.FinnishLightStemFilter
-
- FinnishLightStemFilterFactory - Class in org.apache.lucene.analysis.fi
-
- FinnishLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.fi.FinnishLightStemFilterFactory
-
Creates a new FinnishLightStemFilterFactory
- FinnishLightStemmer - Class in org.apache.lucene.analysis.fi
-
Light Stemmer for Finnish.
- FinnishLightStemmer() - Constructor for class org.apache.lucene.analysis.fi.FinnishLightStemmer
-
- FinnishStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- FinnishStemmer() - Constructor for class org.tartarus.snowball.ext.FinnishStemmer
-
- first() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- first() - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- first() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- first() - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- first() - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- first - Variable in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
-
- FIRST_LEVEL_SIZE - Static variable in class org.apache.lucene.util.ByteBlockPool
-
The first level size for new slices
- FirstPassGroupingCollector<T> - Class in org.apache.lucene.search.grouping
-
FirstPassGroupingCollector is the first of two passes necessary
to collect grouped hits.
- FirstPassGroupingCollector(GroupSelector<T>, Sort, int) - Constructor for class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
Create the first pass collector.
- firstRangeBeginningOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
-
- firstRangeEndOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
-
- FixBrokenOffsets - Class in org.apache.lucene.index
-
Command-line tool that reads from a source index and
writes to a dest index, correcting any broken offsets
in the process.
- FixBrokenOffsets() - Constructor for class org.apache.lucene.index.FixBrokenOffsets
-
- FixBrokenOffsetsFilter - Class in org.apache.lucene.analysis.miscellaneous
-
- FixBrokenOffsetsFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.FixBrokenOffsetsFilter
-
Deprecated.
- FixBrokenOffsetsFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- FixBrokenOffsetsFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.FixBrokenOffsetsFilterFactory
-
Sole constructor
- FixedBitSet - Class in org.apache.lucene.util
-
- FixedBitSet(int) - Constructor for class org.apache.lucene.util.FixedBitSet
-
Creates a new LongBitSet.
- FixedBitSet(long[], int) - Constructor for class org.apache.lucene.util.FixedBitSet
-
Creates a new LongBitSet using the provided long[] array as backing store.
- FixedGapTermsIndexReader - Class in org.apache.lucene.codecs.blockterms
-
TermsIndexReader for simple every Nth terms indexes.
- FixedGapTermsIndexReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexReader
-
- FixedGapTermsIndexWriter - Class in org.apache.lucene.codecs.blockterms
-
Selects every Nth term as and index term, and hold term
bytes (mostly) fully expanded in memory.
- FixedGapTermsIndexWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexWriter
-
- FixedGapTermsIndexWriter(SegmentWriteState, int) - Constructor for class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexWriter
-
- FixedShingleFilter - Class in org.apache.lucene.analysis.shingle
-
A FixedShingleFilter constructs shingles (token n-grams) from a token stream.
- FixedShingleFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.shingle.FixedShingleFilter
-
Creates a FixedShingleFilter over an input token stream
- FixedShingleFilter(TokenStream, int, String, String) - Constructor for class org.apache.lucene.analysis.shingle.FixedShingleFilter
-
Creates a FixedShingleFilter over an input token stream
- FixedShingleFilterFactory - Class in org.apache.lucene.analysis.shingle
-
Factory for
FixedShingleFilter
Parameters are:
shingleSize - how many tokens should be combined into each shingle (default: 2)
tokenSeparator - how tokens should be joined together in the shingle (default: space)
fillerToken - what should be added in place of stop words (default: _ )
- FixedShingleFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.shingle.FixedShingleFilterFactory
-
- flags - Variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
flags to the parser (to turn features on/off)
- FlagsAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
This attribute can be used to pass different flags down the
Tokenizer
chain,
e.g.
- FlagsAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- FlagsAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-
Initialize this attribute with no bits set
- flagsToString(int) - Static method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Returns string representation of configuration flags
- FlattenGraphFilter - Class in org.apache.lucene.analysis.core
-
Converts an incoming graph token stream, such as one from
SynonymGraphFilter
, into a flat form so that
all nodes form a single linear chain with no side paths.
- FlattenGraphFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.core.FlattenGraphFilter
-
- FlattenGraphFilterFactory - Class in org.apache.lucene.analysis.core
-
- FlattenGraphFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.core.FlattenGraphFilterFactory
-
Creates a new FlattenGraphFilterFactory
- flattening - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The flattening value
- flip(int, int) - Method in class org.apache.lucene.util.FixedBitSet
-
Flips a range of bits
- flip(int) - Method in class org.apache.lucene.util.FixedBitSet
-
Flip the bit at the provided index.
- flip(long, long) - Method in class org.apache.lucene.util.LongBitSet
-
Flips a range of bits
- flip(long) - Method in class org.apache.lucene.util.LongBitSet
-
Flip the bit at the provided index.
- flipFlop(long) - Static method in class org.apache.lucene.util.BitUtil
-
flip flops odd with even bits
- FLOAT_DECODER - Static variable in interface org.apache.lucene.queries.payloads.PayloadDecoder
-
- FloatAssociationFacetField - Class in org.apache.lucene.facet.taxonomy
-
Add an instance of this to your
Document
to add
a facet label associated with a float.
- FloatAssociationFacetField(float, String, String...) - Constructor for class org.apache.lucene.facet.taxonomy.FloatAssociationFacetField
-
Creates this from dim
and path
and a
float association
- FloatComparator(int, String, Float) - Constructor for class org.apache.lucene.search.FieldComparator.FloatComparator
-
Creates a new comparator based on Float.compare(float, float)
for numHits
.
- FloatDocValues - Class in org.apache.lucene.queries.function.docvalues
-
Abstract
FunctionValues
implementation which supports retrieving float values.
- FloatDocValues(ValueSource) - Constructor for class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- FloatDocValuesField - Class in org.apache.lucene.document
-
Syntactic sugar for encoding floats as NumericDocValues
via Float.floatToRawIntBits(float)
.
- FloatDocValuesField(String, float) - Constructor for class org.apache.lucene.document.FloatDocValuesField
-
Creates a new DocValues field with the specified 32-bit float value
- FloatEncoder - Class in org.apache.lucene.analysis.payloads
-
Encode a character array Float as a
BytesRef
.
- FloatEncoder() - Constructor for class org.apache.lucene.analysis.payloads.FloatEncoder
-
- floatField(FieldInfo, float) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- floatField(FieldInfo, float) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
- floatField(FieldInfo, float) - Method in class org.apache.lucene.index.StoredFieldVisitor
-
Process a float numeric field.
- FloatFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- FloatFieldSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.FloatFieldSource
-
- FloatPoint - Class in org.apache.lucene.document
-
An indexed float
field for fast range filters.
- FloatPoint(String, float...) - Constructor for class org.apache.lucene.document.FloatPoint
-
Creates a new FloatPoint, indexing the
provided N-dimensional float point.
- FloatPointNearestNeighbor - Class in org.apache.lucene.document
-
KNN search on top of N dimensional indexed float points.
- FloatPointNearestNeighbor() - Constructor for class org.apache.lucene.document.FloatPointNearestNeighbor
-
- FloatRange - Class in org.apache.lucene.document
-
An indexed Float Range field.
- FloatRange(String, float[], float[]) - Constructor for class org.apache.lucene.document.FloatRange
-
Create a new FloatRange type, from min/max parallel arrays
- FloatTaxonomyFacets - Class in org.apache.lucene.facet.taxonomy
-
Base class for all taxonomy-based facets that aggregate
to a per-ords float[].
- FloatTaxonomyFacets(String, TaxonomyReader, FacetsConfig) - Constructor for class org.apache.lucene.facet.taxonomy.FloatTaxonomyFacets
-
Sole constructor.
- 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
- floatToBytesRef(float) - Static method in class org.apache.lucene.facet.taxonomy.FloatAssociationFacetField
-
- floatToEdits(float, int) - Static method in class org.apache.lucene.search.FuzzyQuery
-
- 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.queries.function.docvalues.BoolDocValues
-
- floatVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- floatVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- floatVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- floatVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- floatVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- floatVal(int, float[]) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- floor(BytesRef, BytesRefBuilder) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
-
Finds largest term accepted by this Automaton, that's
<= the provided input term.
- floorBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
The number of floor blocks (meta-blocks larger than the
allowed maxItemsPerBlock
) in the terms file.
- floorSubBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
The number of sub-blocks within the floor blocks.
- flush() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- flush() - Method in class org.apache.lucene.benchmark.quality.utils.SubmissionReport
-
- flush() - Method in class org.apache.lucene.index.IndexWriter
-
- flush() - Method in class org.apache.lucene.index.RandomIndexWriter
-
Writes all in-memory segments to the
Directory
.
- flush() - Method in class org.apache.lucene.mockfile.FilterOutputStream2
-
- flush() - Method in class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
Forces any buffered output to be written.
- flush() - Method in class org.apache.lucene.util.packed.BlockPackedWriter
-
- flush() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
-
- flush() - Method in class org.apache.lucene.util.packed.PackedDataOutput
-
- flushAndRefresh() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
Flush all index operations to disk and opens a new near-real-time reader.
- flushBuffer(IndexOutput, long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
Flushes the in-memory buffer to the given output, copying at most
numBytes
.
- FlushInfo - Class in org.apache.lucene.store
-
A FlushInfo provides information required for a FLUSH context.
- FlushInfo(int, long) - Constructor for class org.apache.lucene.store.FlushInfo
-
- flushInfo - Variable in class org.apache.lucene.store.IOContext
-
- flushNextBuffer() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: Flushes the next pending writer per thread buffer if available or the largest active
non-pending writer per thread buffer in the calling thread.
- flushPolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
FlushPolicy
to control when segments are
flushed.
- fname - Variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
- foldToASCII(char[], int) - Method in class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilter
-
Converts characters above ASCII to their ASCII equivalents.
- foldToASCII(char[], int, char[], int, int) - Static method in class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilter
-
Converts characters above ASCII to their ASCII equivalents.
- following(int) - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- following(int) - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- following(int) - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- following(int) - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- follows(TextFragment) - Method in class org.apache.lucene.search.highlight.TextFragment
-
- footer - Variable in class org.apache.lucene.replicator.nrt.FileMetaData
-
- FOOTER_MAGIC - Static variable in class org.apache.lucene.codecs.CodecUtil
-
Constant to identify the start of a codec footer.
- footerLength() - Static method in class org.apache.lucene.codecs.CodecUtil
-
Computes the length of a codec footer.
- force(boolean) - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- force(boolean) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- FORCE_FIRST_LETTER - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
- forceMerge(int) - Method in class org.apache.lucene.index.IndexWriter
-
Forces merge policy to merge segments until there are
<= maxNumSegments
.
- forceMerge(int, boolean) - Method in class org.apache.lucene.index.IndexWriter
-
- forceMerge(int) - Method in class org.apache.lucene.index.RandomIndexWriter
-
Forces a forceMerge.
- forceMergeDeletes(boolean) - Method in class org.apache.lucene.index.IndexWriter
-
- forceMergeDeletes() - Method in class org.apache.lucene.index.IndexWriter
-
Forces merging of all segments that have deleted
documents.
- forceMergeDeletes(boolean) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- forceMergeDeletes() - Method in class org.apache.lucene.index.RandomIndexWriter
-
- ForceMergePolicy - Class in org.apache.lucene.index
-
- ForceMergePolicy(MergePolicy) - Constructor for class org.apache.lucene.index.ForceMergePolicy
-
Create a new ForceMergePolicy
around the given MergePolicy
- ForceMergeTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Runs forceMerge on the index.
- ForceMergeTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ForceMergeTask
-
- forever - Variable in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
- forField(String, IOSupplier<MatchesIterator>) - Static method in class org.apache.lucene.search.MatchesUtils
-
Create a Matches for a single field
- Format - Class in org.apache.lucene.benchmark.byTask.utils
-
Formatting utilities (for reports).
- Format() - Constructor for class org.apache.lucene.benchmark.byTask.utils.Format
-
- format(int, float, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Padd a number from left.
- format(int, double, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
- format(int, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a number from left.
- format(String, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a string from right.
- format(double, StringBuffer, FieldPosition) - Method in class org.apache.lucene.queryparser.flexible.standard.config.NumberDateFormat
-
- format(long, StringBuffer, FieldPosition) - Method in class org.apache.lucene.queryparser.flexible.standard.config.NumberDateFormat
-
- format(Object, StringBuffer, FieldPosition) - Method in class org.apache.lucene.queryparser.flexible.standard.config.NumberDateFormat
-
- format(Passage[], String) - Method in class org.apache.lucene.search.uhighlight.DefaultPassageFormatter
-
- format(Passage[], String) - Method in class org.apache.lucene.search.uhighlight.PassageFormatter
-
Formats the top passages
from content
into a human-readable text snippet.
- format - Variable in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
-
- FORMAT_SNOWBALL - Static variable in class org.apache.lucene.analysis.core.StopFilterFactory
-
- FORMAT_SNOWBALL - Static variable in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilterFactory
-
multiple words may be specified on each line, trailing comments start with "|"
- FORMAT_WORDSET - Static variable in class org.apache.lucene.analysis.core.StopFilterFactory
-
- FORMAT_WORDSET - Static variable in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilterFactory
-
the default format, one word per line, whole line comments start with "#"
- FormatAndBits(PackedInts.Format, int) - Constructor for class org.apache.lucene.util.packed.PackedInts.FormatAndBits
-
- formatNames - Variable in class org.apache.lucene.index.RandomCodec
-
unique set of format names this codec knows about
- formatPaddLeft(String, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a string from left.
- formatPaddRight(int, float, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
Pad a number from right.
- formatPaddRight(int, double, String) - Static method in class org.apache.lucene.benchmark.byTask.utils.Format
-
- Formatter - Interface in org.apache.lucene.search.highlight
-
Processes terms found in the original text, typically by applying some form
of mark-up to highlight terms in HTML search results pages.
- forName(String, Map<String, String>) - Static method in class org.apache.lucene.analysis.util.CharFilterFactory
-
looks up a charfilter by name from context classpath
- forName(String, Map<String, String>) - Static method in class org.apache.lucene.analysis.util.TokenFilterFactory
-
looks up a tokenfilter by name from context classpath
- forName(String, Map<String, String>) - Static method in class org.apache.lucene.analysis.util.TokenizerFactory
-
looks up a tokenizer by name from context classpath
- forName(String) - Static method in class org.apache.lucene.codecs.Codec
-
looks up a codec by name
- forName(String) - Static method in class org.apache.lucene.codecs.DocValuesFormat
-
looks up a format by name
- forName(String) - Static method in class org.apache.lucene.codecs.PostingsFormat
-
looks up a format by name
- forName(String) - Static method in enum org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
-
- FragListBuilder - Interface in org.apache.lucene.search.vectorhighlight
-
FragListBuilder is an interface for FieldFragList builder classes.
- Fragmenter - Interface in org.apache.lucene.search.highlight
-
Implements the policy for breaking text into multiple fragments for
consideration by the
Highlighter
class.
- FragmentsBuilder - Interface in org.apache.lucene.search.vectorhighlight
-
- FREE_BSD - Static variable in class org.apache.lucene.util.Constants
-
True iff running on FreeBSD
- freeBefore(int) - Method in class org.apache.lucene.analysis.util.RollingCharBuffer
-
Call this to notify us that no chars before this
absolute position are needed anymore.
- freeBefore(int) - Method in class org.apache.lucene.util.RollingBuffer
-
- freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
Removes the given number of byte blocks from the buffer if possible.
- freeBlocks(int) - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-
Removes the given number of int blocks from the buffer if possible.
- freenode - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- FreeTextSuggester - Class in org.apache.lucene.search.suggest.analyzing
-
- FreeTextSuggester(Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Instantiate, using the provided analyzer for both
indexing and lookup, using bigram model by default.
- FreeTextSuggester(Analyzer, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Instantiate, using the provided indexing and lookup
analyzers, using bigram model by default.
- FreeTextSuggester(Analyzer, Analyzer, int) - Constructor for class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Instantiate, using the provided indexing and lookup
analyzers, with the specified model (2
= bigram, 3 = trigram, etc.).
- FreeTextSuggester(Analyzer, Analyzer, int, byte) - Constructor for class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Instantiate, using the provided indexing and lookup
analyzers, and specified model (2 = bigram, 3 =
trigram ,etc.).
- freeze() - Method in class org.apache.lucene.document.FieldType
-
Prevents future changes.
- freeze() - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Prepares the MemoryIndex for querying in a non-lazy way.
- freeze(boolean) - Method in class org.apache.lucene.util.PagedBytes
-
Commits final byte[], trimming it if necessary and if trim=true
- FrenchAnalyzer - Class in org.apache.lucene.analysis.fr
-
- FrenchAnalyzer() - Constructor for class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
- FrenchAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Builds an analyzer with the given stop words
- FrenchAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Builds an analyzer with the given stop words
- FrenchLightStemFilter - Class in org.apache.lucene.analysis.fr
-
- FrenchLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fr.FrenchLightStemFilter
-
- FrenchLightStemFilterFactory - Class in org.apache.lucene.analysis.fr
-
- FrenchLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.fr.FrenchLightStemFilterFactory
-
Creates a new FrenchLightStemFilterFactory
- FrenchLightStemmer - Class in org.apache.lucene.analysis.fr
-
Light Stemmer for French.
- FrenchLightStemmer() - Constructor for class org.apache.lucene.analysis.fr.FrenchLightStemmer
-
- FrenchMinimalStemFilter - Class in org.apache.lucene.analysis.fr
-
- FrenchMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fr.FrenchMinimalStemFilter
-
- FrenchMinimalStemFilterFactory - Class in org.apache.lucene.analysis.fr
-
- FrenchMinimalStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.fr.FrenchMinimalStemFilterFactory
-
Creates a new FrenchMinimalStemFilterFactory
- FrenchMinimalStemmer - Class in org.apache.lucene.analysis.fr
-
Light Stemmer for French.
- FrenchMinimalStemmer() - Constructor for class org.apache.lucene.analysis.fr.FrenchMinimalStemmer
-
- FrenchStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- FrenchStemmer() - Constructor for class org.tartarus.snowball.ext.FrenchStemmer
-
- freq() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- freq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- freq() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- freq() - Method in class org.apache.lucene.index.PostingsEnum
-
Returns term frequency in the current document, or 1 if the field was
indexed with
IndexOptions.DOCS
.
- freq() - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- freq - Variable in class org.apache.lucene.search.spans.TermSpans
-
- freq - Variable in class org.apache.lucene.search.spell.SuggestWord
-
The freq of the word
- freq() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum
-
An estimate of the number of occurrences of this term/OffsetsEnum.
- freq() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.MultiOffsetsEnum
-
- freq() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIterator
-
- freq() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIteratorWithSubs
-
- freq() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfPostings
-
- FREQS - Static variable in class org.apache.lucene.index.PostingsEnum
-
- freqs - Variable in class org.apache.lucene.search.suggest.BufferedInputIterator
-
- frequency(int) - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
-
Returns the frequency of the provided key in the ring buffer.
- FrequencyTrackingRingBuffer - Class in org.apache.lucene.util
-
A ring buffer that tracks the frequency of the integers that it contains.
- FrequencyTrackingRingBuffer(int, int) - Constructor for class org.apache.lucene.util.FrequencyTrackingRingBuffer
-
Create a new ring buffer that will contain at most maxSize
items.
- fromAggregationForm(double) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Convert an aggregation form distance value back to an actual distance.
- fromAggregationForm(double) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- fromAggregationForm(double) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- fromBits(int, int, int) - Static method in class org.apache.lucene.util.Version
-
Returns a new version based on raw numbers
- fromDocument(Iterable<? extends IndexableField>, Analyzer) - Static method in class org.apache.lucene.index.memory.MemoryIndex
-
Builds a MemoryIndex from a lucene
Document
using an analyzer
- fromDocument(Iterable<? extends IndexableField>, Analyzer, boolean, boolean) - Static method in class org.apache.lucene.index.memory.MemoryIndex
-
Builds a MemoryIndex from a lucene
Document
using an analyzer
- fromDocument(Iterable<? extends IndexableField>, Analyzer, boolean, boolean, long) - Static method in class org.apache.lucene.index.memory.MemoryIndex
-
Builds a MemoryIndex from a lucene
Document
using an analyzer
- fromDoubleField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Creates a DoubleValuesSource that wraps a double-valued field
- fromDoubleValuesSource(DoubleValuesSource) - Static method in class org.apache.lucene.queries.function.ValueSource
-
- fromField(String, LongToDoubleFunction) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Creates a DoubleValuesSource that wraps a generic NumericDocValues field
- fromFloatField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Creates a DoubleValuesSource that wraps a float-valued field
- fromGeoJSON(String) - Static method in class org.apache.lucene.geo.Polygon
-
Parses a standard GeoJSON polygon string.
- fromIntField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Creates a DoubleValuesSource that wraps an int-valued field
- fromIntField(String) - Static method in class org.apache.lucene.search.LongValuesSource
-
Creates a LongValuesSource that wraps an int-valued field
- fromLongField(String) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Creates a DoubleValuesSource that wraps a long-valued field
- fromLongField(String) - Static method in class org.apache.lucene.search.LongValuesSource
-
Creates a LongValuesSource that wraps a long-valued field
- fromPointDistance(double, double, double) - Static method in class org.apache.lucene.geo.Rectangle
-
Compute Bounding Box for a circle using WGS-84 parameters
- fromPolygon(Polygon[]) - Static method in class org.apache.lucene.geo.Rectangle
-
Returns the bounding box over an array of polygons
- fromQuery(Query) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Create a DoubleValuesSource that returns the score of a particular query
- fromScorer(Scorer) - Static method in class org.apache.lucene.search.DoubleValuesSource
-
Returns a DoubleValues instance that wraps scores returned by a Scorer
- fromSeparatorCharPredicate(IntPredicate) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
Creates a new instance of CharTokenizer using a custom predicate, supplied as method reference or lambda expression.
- fromSeparatorCharPredicate(AttributeFactory, IntPredicate) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
Creates a new instance of CharTokenizer with the supplied attribute factory using a custom predicate, supplied as method reference or lambda expression.
- fromSeparatorCharPredicate(IntPredicate, IntUnaryOperator) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
- fromSeparatorCharPredicate(AttributeFactory, IntPredicate, IntUnaryOperator) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
- fromSign(int) - Static method in enum org.apache.lucene.geo.GeoUtils.WindingOrder
-
- fromSubMatches(List<Matches>) - Static method in class org.apache.lucene.search.MatchesUtils
-
Amalgamate a collection of
Matches
into a single object
- fromTokenCharPredicate(IntPredicate) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
Creates a new instance of CharTokenizer using a custom predicate, supplied as method reference or lambda expression.
- fromTokenCharPredicate(AttributeFactory, IntPredicate) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
Creates a new instance of CharTokenizer with the supplied attribute factory using a custom predicate, supplied as method reference or lambda expression.
- fromTokenCharPredicate(IntPredicate, IntUnaryOperator) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
- fromTokenCharPredicate(AttributeFactory, IntPredicate, IntUnaryOperator) - Static method in class org.apache.lucene.analysis.util.CharTokenizer
-
- FSDirectory - Class in org.apache.lucene.store
-
Base class for Directory implementations that store index
files in the file system.
- FSDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.FSDirectory
-
Create a new FSDirectory for the named location (ctor for subclasses).
- FSLockFactory - Class in org.apache.lucene.store
-
Base class for file system based locking implementation.
- FSLockFactory() - Constructor for class org.apache.lucene.store.FSLockFactory
-
- fst - Variable in class org.apache.lucene.analysis.synonym.SynonymMap
-
map<input word, list<ord>>
- FST<T> - Class in org.apache.lucene.util.fst
-
Represents an finite state machine (FST), using a
compact byte[] format.
- FST(DataInput, Outputs<T>) - Constructor for class org.apache.lucene.util.fst.FST
-
Load a previously saved FST.
- FST(DataInput, Outputs<T>, int) - Constructor for class org.apache.lucene.util.fst.FST
-
Load a previously saved FST; maxBlockBits allows you to
control the size of the byte[] pages used to hold the FST bytes.
- FST.Arc<T> - Class in org.apache.lucene.util.fst
-
Represents a single arc.
- FST.BytesReader - Class in org.apache.lucene.util.fst
-
Reads bytes stored in an FST.
- FST.INPUT_TYPE - Enum in org.apache.lucene.util.fst
-
Specifies allowed range of each int input label for
this FST.
- FST_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.TokenInfoDictionary
-
- FST_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ko.dict.TokenInfoDictionary
-
- FSTCompletion - Class in org.apache.lucene.search.suggest.fst
-
Finite state automata based implementation of "autocomplete" functionality.
- FSTCompletion(FST<Object>, boolean, boolean) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Constructs an FSTCompletion, specifying higherWeightsFirst and exactFirst.
- FSTCompletion(FST<Object>) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Defaults to higher weights first and exact first.
- FSTCompletion.Completion - Class in org.apache.lucene.search.suggest.fst
-
A single completion for a given key.
- FSTCompletionBuilder - Class in org.apache.lucene.search.suggest.fst
-
Finite state automata based implementation of "autocomplete" functionality.
- FSTCompletionBuilder() - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
-
Creates an
FSTCompletion
with default options: 10 buckets, exact match
promoted to first position and
InMemorySorter
with a comparator obtained from
Comparator.naturalOrder()
.
- FSTCompletionBuilder(int, BytesRefSorter, int) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionBuilder
-
Creates an FSTCompletion with the specified options.
- FSTCompletionLookup - Class in org.apache.lucene.search.suggest.fst
-
- FSTCompletionLookup() - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
This constructor should only be used to read a previously saved suggester.
- FSTCompletionLookup(Directory, String) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- FSTCompletionLookup(Directory, String, int, boolean) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- FSTCompletionLookup(Directory, String, FSTCompletion, boolean) - Constructor for class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
This constructor takes a pre-built automaton.
- fstNode - Variable in class org.apache.lucene.search.suggest.analyzing.FSTUtil.Path
-
Node in the FST where path ends:
- FSTOrdPostingsFormat - Class in org.apache.lucene.codecs.memory
-
FSTOrd term dict + Lucene50PBF
- FSTOrdPostingsFormat() - Constructor for class org.apache.lucene.codecs.memory.FSTOrdPostingsFormat
-
- FSTOrdTermsReader - Class in org.apache.lucene.codecs.memory
-
FST-based terms dictionary reader.
- FSTOrdTermsReader(SegmentReadState, PostingsReaderBase) - Constructor for class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- FSTOrdTermsWriter - Class in org.apache.lucene.codecs.memory
-
FST-based term dict, using ord as FST output.
- FSTOrdTermsWriter(SegmentWriteState, PostingsWriterBase) - Constructor for class org.apache.lucene.codecs.memory.FSTOrdTermsWriter
-
- FSTPath(T, FST.Arc<T>, IntsRefBuilder) - Constructor for class org.apache.lucene.util.fst.Util.FSTPath
-
Sole constructor
- FSTPath(T, FST.Arc<T>, IntsRefBuilder, float, CharSequence, int) - Constructor for class org.apache.lucene.util.fst.Util.FSTPath
-
- FSTPostingsFormat - Class in org.apache.lucene.codecs.memory
-
FST term dict + Lucene50PBF
- FSTPostingsFormat() - Constructor for class org.apache.lucene.codecs.memory.FSTPostingsFormat
-
- fstRamBytesUsed() - Method in class org.apache.lucene.util.fst.Builder
-
- FSTTermsReader - Class in org.apache.lucene.codecs.memory
-
FST-based terms dictionary reader.
- FSTTermsReader(SegmentReadState, PostingsReaderBase) - Constructor for class org.apache.lucene.codecs.memory.FSTTermsReader
-
- FSTTermsWriter - Class in org.apache.lucene.codecs.memory
-
FST-based term dict, using metadata as FST output.
- FSTTermsWriter(SegmentWriteState, PostingsWriterBase) - Constructor for class org.apache.lucene.codecs.memory.FSTTermsWriter
-
- FSTTester<T> - Class in org.apache.lucene.util.fst
-
Helper class to test FSTs.
- FSTTester(Random, Directory, int, List<FSTTester.InputOutput<T>>, Outputs<T>, boolean) - Constructor for class org.apache.lucene.util.fst.FSTTester
-
- FSTTester.InputOutput<T> - Class in org.apache.lucene.util.fst
-
Holds one input/output pair.
- FSTUtil - Class in org.apache.lucene.search.suggest.analyzing
-
Exposes a utility method to enumerate all paths
intersecting an
Automaton
with an
FST
.
- FSTUtil.Path<T> - Class in org.apache.lucene.search.suggest.analyzing
-
Holds a pair (automaton, fst) of states and accumulated output in the intersected machine.
- fsync(String) - Method in class org.apache.lucene.store.FSDirectory
-
- fsync(Path, boolean) - Static method in class org.apache.lucene.util.IOUtils
-
Ensure that any writes to the given file is written to the storage device that contains it.
- FULLWIDTH_DIGIT - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Full-Width alphanumeric characters
- FULLWIDTH_LETTER - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Full-Width letters
- FULLWIDTH_NUMBER - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
Full-Width Alphanumeric
- FULLWIDTH_STRING - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
Full-Width String
- func(int, FunctionValues, FunctionValues) - Method in class org.apache.lucene.queries.function.valuesource.DivFloatFunction
-
- func(int, FunctionValues, FunctionValues) - Method in class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- func(int, FunctionValues[]) - Method in class org.apache.lucene.queries.function.valuesource.MaxFloatFunction
-
- func(int, FunctionValues[]) - Method in class org.apache.lucene.queries.function.valuesource.MinFloatFunction
-
- func(int, FunctionValues[]) - Method in class org.apache.lucene.queries.function.valuesource.MultiBoolFunction
-
- func(int, FunctionValues[]) - Method in class org.apache.lucene.queries.function.valuesource.MultiFloatFunction
-
- func(int, FunctionValues, FunctionValues) - Method in class org.apache.lucene.queries.function.valuesource.PowFloatFunction
-
- func(int, FunctionValues[]) - Method in class org.apache.lucene.queries.function.valuesource.ProductFloatFunction
-
- func(int, FunctionValues) - Method in class org.apache.lucene.queries.function.valuesource.SimpleBoolFunction
-
- func(int, FunctionValues) - Method in class org.apache.lucene.queries.function.valuesource.SimpleFloatFunction
-
- func(int, FunctionValues[]) - Method in class org.apache.lucene.queries.function.valuesource.SumFloatFunction
-
- FunctionMatchQuery - Class in org.apache.lucene.queries.function
-
A query that retrieves all documents with a
DoubleValues
value matching a predicate
This query works by a linear scan of the index, and is best used in
conjunction with other queries that can restrict the number of
documents visited
- FunctionMatchQuery(DoubleValuesSource, DoublePredicate) - Constructor for class org.apache.lucene.queries.function.FunctionMatchQuery
-
Create a FunctionMatchQuery
- FunctionQuery - Class in org.apache.lucene.queries.function
-
Returns a score for each document based on a ValueSource,
often some function of the value of a field.
- FunctionQuery(ValueSource) - Constructor for class org.apache.lucene.queries.function.FunctionQuery
-
- FunctionQuery.AllScorer - Class in org.apache.lucene.queries.function
-
- FunctionQuery.FunctionWeight - Class in org.apache.lucene.queries.function
-
- FunctionRangeQuery - Class in org.apache.lucene.queries.function
-
A Query wrapping a
ValueSource
that matches docs in which the values in the value source match a configured
range.
- FunctionRangeQuery(ValueSource, Number, Number, boolean, boolean) - Constructor for class org.apache.lucene.queries.function.FunctionRangeQuery
-
- FunctionRangeQuery(ValueSource, String, String, boolean, boolean) - Constructor for class org.apache.lucene.queries.function.FunctionRangeQuery
-
- FunctionScoreQuery - Class in org.apache.lucene.queries.function
-
A query that wraps another query, and uses a DoubleValuesSource to
replace or modify the wrapped query's score
If the DoubleValuesSource doesn't return a value for a particular document,
then that document will be given a score of 0.
- FunctionScoreQuery(Query, DoubleValuesSource) - Constructor for class org.apache.lucene.queries.function.FunctionScoreQuery
-
Create a new FunctionScoreQuery
- FunctionValues - Class in org.apache.lucene.queries.function
-
Represents field values as different types.
- FunctionValues() - Constructor for class org.apache.lucene.queries.function.FunctionValues
-
- FunctionValues.ValueFiller - Class in org.apache.lucene.queries.function
-
Abstraction of the logic required to fill the value of a specified doc into
a reusable
MutableValue
.
- FunctionWeight(IndexSearcher, float) - Constructor for class org.apache.lucene.queries.function.FunctionQuery.FunctionWeight
-
- FutureArrays - Class in org.apache.lucene.util
-
- FutureObjects - Class in org.apache.lucene.util
-
- FUZZY_CONFIG - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the
FuzzyConfig
used to create fuzzy queries.
- FUZZY_OPERATOR - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables FUZZY
operators: (~) on single terms
- FUZZY_SLOP - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- FUZZY_SLOP - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- FuzzyCompletionQuery - Class in org.apache.lucene.search.suggest.document
-
A
CompletionQuery
that match documents containing terms
within an edit distance of the specified prefix.
- FuzzyCompletionQuery(Analyzer, Term) - Constructor for class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
- FuzzyCompletionQuery(Analyzer, Term, BitsProducer) - Constructor for class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Calls
FuzzyCompletionQuery.FuzzyCompletionQuery(Analyzer, Term, BitsProducer,
int, boolean, int, int, boolean, int)
with defaults for
maxEdits
,
transpositions
,
nonFuzzyPrefix
,
minFuzzyLength
,
unicodeAware
and
maxDeterminizedStates
See
FuzzyCompletionQuery.DEFAULT_MAX_EDITS
,
FuzzyCompletionQuery.DEFAULT_TRANSPOSITIONS
,
FuzzyCompletionQuery.DEFAULT_NON_FUZZY_PREFIX
,
FuzzyCompletionQuery.DEFAULT_MIN_FUZZY_LENGTH
,
FuzzyCompletionQuery.DEFAULT_UNICODE_AWARE
and
Operations.DEFAULT_MAX_DETERMINIZED_STATES
for defaults
- FuzzyCompletionQuery(Analyzer, Term, BitsProducer, int, boolean, int, int, boolean, int) - Constructor for class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Constructs an analyzed fuzzy prefix completion query
- FuzzyConfig - Class in org.apache.lucene.queryparser.flexible.standard.config
-
- FuzzyConfig() - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.FuzzyConfig
-
- FuzzyLikeThisQuery - Class in org.apache.lucene.sandbox.queries
-
Fuzzifies ALL terms provided as strings and then picks the best n differentiating terms.
- FuzzyLikeThisQuery(int, Analyzer) - Constructor for class org.apache.lucene.sandbox.queries.FuzzyLikeThisQuery
-
- FuzzyLikeThisQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- FuzzyLikeThisQueryBuilder(Analyzer) - Constructor for class org.apache.lucene.queryparser.xml.builders.FuzzyLikeThisQueryBuilder
-
- FuzzyQuery - Class in org.apache.lucene.search
-
Implements the fuzzy search query.
- FuzzyQuery(Term, int, int, int, boolean) - Constructor for class org.apache.lucene.search.FuzzyQuery
-
Create a new FuzzyQuery that will match terms with an edit distance
of at most maxEdits
to term
.
- FuzzyQuery(Term, int, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
-
- FuzzyQuery(Term, int) - Constructor for class org.apache.lucene.search.FuzzyQuery
-
- FuzzyQuery(Term) - Constructor for class org.apache.lucene.search.FuzzyQuery
-
- FuzzyQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
FuzzyQueryNode
represents a element that contains
field/text/similarity tuple
- FuzzyQueryNode(CharSequence, CharSequence, float, int, int) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- FuzzyQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- FuzzyQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.FuzzyQueryNodeBuilder
-
- FuzzyQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- FuzzyQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.FuzzyQueryNodeProcessor
-
- FuzzySet - Class in org.apache.lucene.codecs.bloom
-
A class used to represent a set of many, potentially large, values (e.g.
- FuzzySet.ContainsResult - Enum in org.apache.lucene.codecs.bloom
-
- FuzzySuggester - Class in org.apache.lucene.search.suggest.analyzing
-
- FuzzySuggester(Directory, String, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
- FuzzySuggester(Directory, String, Analyzer, Analyzer) - Constructor for class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
Creates a
FuzzySuggester
instance with an index and query analyzer initialized with default values.
- FuzzySuggester(Directory, String, Analyzer, Analyzer, int, int, int, boolean, int, boolean, int, int, boolean) - Constructor for class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
- FuzzyTermsEnum - Class in org.apache.lucene.search
-
Subclass of TermsEnum for enumerating all terms that are similar
to the specified filter term.
- FuzzyTermsEnum(Terms, AttributeSource, Term, int, int, boolean) - Constructor for class org.apache.lucene.search.FuzzyTermsEnum
-
Constructor for enumeration of all terms from specified reader
which share a prefix of
length prefixLength
with term
and which have at most maxEdits
edits.
- FuzzyTermsEnum.LevenshteinAutomataAttribute - Interface in org.apache.lucene.search
-
reuses compiled automata across different segments,
because they are independent of the index
- FuzzyTermsEnum.LevenshteinAutomataAttributeImpl - Class in org.apache.lucene.search
-
Stores compiled automata as a list (indexed by edit distance)
- GalicianAnalyzer - Class in org.apache.lucene.analysis.gl
-
- GalicianAnalyzer() - Constructor for class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
- GalicianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
Builds an analyzer with the given stop words.
- GalicianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
Builds an analyzer with the given stop words.
- GalicianMinimalStemFilter - Class in org.apache.lucene.analysis.gl
-
- GalicianMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.gl.GalicianMinimalStemFilter
-
- GalicianMinimalStemFilterFactory - Class in org.apache.lucene.analysis.gl
-
- GalicianMinimalStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.gl.GalicianMinimalStemFilterFactory
-
Creates a new GalicianMinimalStemFilterFactory
- GalicianMinimalStemmer - Class in org.apache.lucene.analysis.gl
-
Minimal Stemmer for Galician
- GalicianMinimalStemmer() - Constructor for class org.apache.lucene.analysis.gl.GalicianMinimalStemmer
-
- GalicianStemFilter - Class in org.apache.lucene.analysis.gl
-
- GalicianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.gl.GalicianStemFilter
-
- GalicianStemFilterFactory - Class in org.apache.lucene.analysis.gl
-
- GalicianStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.gl.GalicianStemFilterFactory
-
Creates a new GalicianStemFilterFactory
- GalicianStemmer - Class in org.apache.lucene.analysis.gl
-
Galician stemmer implementing "Regras do lematizador para o galego".
- GalicianStemmer() - Constructor for class org.apache.lucene.analysis.gl.GalicianStemmer
-
- gamma(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Axiomatic
-
compute the gamma component (only for F3EXp and F3LOG)
- gamma(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
compute the gamma component
- gamma(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
compute the gamma component
- gamma(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
compute the gamma component
- gamma(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
compute the gamma component
- gamma(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
compute the gamma component
- gamma(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
-
compute the gamma component
- GB - Static variable in class org.apache.lucene.util.OfflineSorter
-
Convenience constant for gigabytes
- gcd(long, long) - Static method in class org.apache.lucene.util.MathUtil
-
Return the greatest common divisor of a
and b
,
consistently with BigInteger.gcd(BigInteger)
.
- gen - Variable in class org.apache.lucene.replicator.nrt.CopyState
-
- Gener - Class in org.egothor.stemmer
-
The Gener object helps in the discarding of nodes which break the reduction
effort and defend the structure against large reductions.
- Gener() - Constructor for class org.egothor.stemmer.Gener
-
Constructor for the Gener object.
- GENERATE_NUMBER_PARTS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
Causes number subwords to be generated:
- GENERATE_NUMBER_PARTS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes number subwords to be generated:
- GENERATE_WORD_PARTS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
Causes parts of words to be generated:
- GENERATE_WORD_PARTS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes parts of words to be generated:
- generateParseException() - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
Generate ParseException.
- generateParseException() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Generate ParseException.
- generateParseException() - Method in class org.apache.lucene.queryparser.surround.parser.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.
- genPartialReport(int, LinkedHashMap<String, TaskStats>, int) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- Geo3dBinaryCodec - Class in org.apache.lucene.spatial.spatial4j
-
Geo3d implementation of BinaryCodec
- Geo3dBinaryCodec(SpatialContext, SpatialContextFactory) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dBinaryCodec
-
- Geo3dCircleShape - Class in org.apache.lucene.spatial.spatial4j
-
Specialization of a
Geo3dShape
which represents a
Circle
.
- Geo3dCircleShape(GeoCircle, SpatialContext) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dCircleShape
-
- Geo3dDistanceCalculator - Class in org.apache.lucene.spatial.spatial4j
-
Geo3d implementation of DistanceCalculator
- Geo3dDistanceCalculator(PlanetModel) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- Geo3DDocValuesField - Class in org.apache.lucene.spatial3d
-
An per-document 3D location field.
- Geo3DDocValuesField(String, GeoPoint) - Constructor for class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a new Geo3DDocValuesField with the specified x, y, and z
- Geo3DDocValuesField(String, double, double, double) - Constructor for class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a new Geo3DDocValuesField with the specified x, y, and z
- Geo3DPoint - Class in org.apache.lucene.spatial3d
-
Add this to a document to index lat/lon or x/y/z point, indexed as a 3D point.
- Geo3DPoint(String, double, double) - Constructor for class org.apache.lucene.spatial3d.Geo3DPoint
-
Creates a new Geo3DPoint field with the specified latitude, longitude (in degrees).
- Geo3DPoint(String, double, double, double) - Constructor for class org.apache.lucene.spatial3d.Geo3DPoint
-
Creates a new Geo3DPoint field with the specified x,y,z.
- Geo3dPointShape - Class in org.apache.lucene.spatial.spatial4j
-
Specialization of a
Geo3dShape
which represents a
Point
.
- Geo3dPointShape(GeoPointShape, SpatialContext) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dPointShape
-
- Geo3dRectangleShape - Class in org.apache.lucene.spatial.spatial4j
-
Specialization of a
Geo3dShape
which represents a
Rectangle
.
- Geo3dRectangleShape(GeoBBox, SpatialContext, double, double, double, double) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- Geo3dRectangleShape(GeoBBox, SpatialContext) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- Geo3dShape<T extends GeoAreaShape> - Class in org.apache.lucene.spatial.spatial4j
-
A Spatial4j Shape wrapping a
GeoAreaShape
("Geo3D") -- a 3D planar geometry
based Spatial4j Shape implementation.
- Geo3dShape(T, SpatialContext) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- Geo3dShapeFactory - Class in org.apache.lucene.spatial.spatial4j
-
Geo3d implementation of ShapeFactory
- Geo3dShapeFactory(SpatialContext, SpatialContextFactory) - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- Geo3dSpatialContextFactory - Class in org.apache.lucene.spatial.spatial4j
-
Geo3d implementation of SpatialContextFactory
- Geo3dSpatialContextFactory() - Constructor for class org.apache.lucene.spatial.spatial4j.Geo3dSpatialContextFactory
-
Empty Constructor.
- GeoArea - Interface in org.apache.lucene.spatial3d.geom
-
A GeoArea represents a standard 2-D breakdown of a part of sphere.
- GeoAreaFactory - Class in org.apache.lucene.spatial3d.geom
-
- GeoAreaShape - Interface in org.apache.lucene.spatial3d.geom
-
Shape that implements GeoArea.
- GeoBaseCompositeShape<T extends GeoShape> - Class in org.apache.lucene.spatial3d.geom
-
Base class to create a composite of GeoShapes.
- GeoBaseCompositeShape(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
Constructor.
- GeoBaseCompositeShape(PlanetModel, InputStream, Class<T>) - Constructor for class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
Constructor for deserialization.
- GeoBaseDistanceShape - Class in org.apache.lucene.spatial3d.geom
-
Distance shapes have capabilities of both geohashing and distance
computation (which also includes point membership determination).
- GeoBaseDistanceShape(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
Constructor.
- GeoBaseMembershipShape - Class in org.apache.lucene.spatial3d.geom
-
Membership shapes have capabilities of both geohashing and membership
determination.
- GeoBaseMembershipShape(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.GeoBaseMembershipShape
-
Constructor.
- GeoBaseShape - Class in org.apache.lucene.spatial3d.geom
-
Base extended shape object.
- GeoBaseShape(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.GeoBaseShape
-
Constructor.
- GeoBBox - Interface in org.apache.lucene.spatial3d.geom
-
All bounding box shapes have this interface in common.
- GeoBBoxFactory - Class in org.apache.lucene.spatial3d.geom
-
- GeoCircle - Interface in org.apache.lucene.spatial3d.geom
-
Interface describing circular area with a center and radius.
- GeoCircleFactory - Class in org.apache.lucene.spatial3d.geom
-
Class which constructs a GeoCircle representing an arbitrary circle.
- GeoCompositeAreaShape - Class in org.apache.lucene.spatial3d.geom
-
GeoCompositeAreaShape is a set of GeoAreaShape's, treated as a unit.
- GeoCompositeAreaShape(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.GeoCompositeAreaShape
-
Constructor.
- GeoCompositeAreaShape(PlanetModel, InputStream) - Constructor for class org.apache.lucene.spatial3d.geom.GeoCompositeAreaShape
-
Constructor for deserialization.
- GeoCompositeMembershipShape - Class in org.apache.lucene.spatial3d.geom
-
GeoCompositeMembershipShape is a set of GeoMembershipShape's, treated as a unit.
- GeoCompositeMembershipShape(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.GeoCompositeMembershipShape
-
Constructor.
- GeoCompositeMembershipShape(PlanetModel, InputStream) - Constructor for class org.apache.lucene.spatial3d.geom.GeoCompositeMembershipShape
-
Constructor for deserialization.
- GeoCompositePolygon - Class in org.apache.lucene.spatial3d.geom
-
GeoCompositePolygon is a specific implementation of GeoCompositeAreaShape, which implements GeoPolygon explicitly.
- GeoCompositePolygon(PlanetModel) - Constructor for class org.apache.lucene.spatial3d.geom.GeoCompositePolygon
-
Constructor.
- GeoCompositePolygon(PlanetModel, InputStream) - Constructor for class org.apache.lucene.spatial3d.geom.GeoCompositePolygon
-
Constructor for deserialization.
- GeoDegenerateVerticalLine - Class in org.apache.lucene.spatial3d.geom
-
Degenerate bounding box limited on two sides (top lat, bottom lat).
- GeoDegenerateVerticalLine(PlanetModel, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Accepts only values in the following ranges: lat: -PI/2 -> PI/2
, longitude: -PI -> PI
- GeoDegenerateVerticalLine(PlanetModel, InputStream) - Constructor for class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Constructor for deserialization.
- GeoDistance - Interface in org.apache.lucene.spatial3d.geom
-
An implementer of this interface is capable of computing the described "distance" values,
which are meant to provide both actual distance values, as well as
distance estimates that can be computed more cheaply.
- GeoDistanceShape - Interface in org.apache.lucene.spatial3d.geom
-
Distance shapes have capabilities of both geohashing and distance
computation (which also includes point membership determination).
- GeoEncodingUtils - Class in org.apache.lucene.geo
-
reusable geopoint encoding methods
- GeoEncodingUtils.DistancePredicate - Class in org.apache.lucene.geo
-
A predicate that checks whether a given point is within a distance of another point.
- GeoEncodingUtils.PolygonPredicate - Class in org.apache.lucene.geo
-
A predicate that checks whether a given point is within a polygon.
- GeohashPrefixTree - Class in org.apache.lucene.spatial.prefix.tree
-
- GeohashPrefixTree(SpatialContext, int) - Constructor for class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree
-
- GeohashPrefixTree.Factory - Class in org.apache.lucene.spatial.prefix.tree
-
- GeoMembershipShape - Interface in org.apache.lucene.spatial3d.geom
-
Membership shapes have capabilities of both geohashing and membership
determination.
- GeonamesLineParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
A line parser for Geonames.org data.
- GeonamesLineParser(String[]) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.GeonamesLineParser
-
This header will be ignored; the geonames format is fixed and doesn't have a header line.
- GeoOutsideDistance - Interface in org.apache.lucene.spatial3d.geom
-
Implemented by Geo3D shapes that can compute the distance from a point to the closest outside edge.
- GeoPath - Interface in org.apache.lucene.spatial3d.geom
-
Interface describing a path.
- GeoPathFactory - Class in org.apache.lucene.spatial3d.geom
-
Class which constructs a GeoPath representing an arbitrary path.
- GeoPoint - Class in org.apache.lucene.spatial3d.geom
-
This class represents a point on the surface of a sphere or ellipsoid.
- GeoPoint(PlanetModel, double, double, double, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPoint
-
Construct a GeoPoint from the trig functions of a lat and lon pair.
- GeoPoint(PlanetModel, double, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPoint
-
Construct a GeoPoint from the trig functions of a lat and lon pair.
- GeoPoint(PlanetModel, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPoint
-
Construct a GeoPoint from a latitude/longitude pair.
- GeoPoint(PlanetModel, InputStream) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPoint
-
Construct a GeoPoint from a planet model and an input stream.
- GeoPoint(double, double, double, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPoint
-
Construct a GeoPoint from a unit (x,y,z) vector and a magnitude.
- GeoPoint(double, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPoint
-
Construct a GeoPoint from a unit (x,y,z) vector and a magnitude.
- GeoPoint(double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPoint
-
Construct a GeoPoint from an (x,y,z) value.
- GeoPointShape - Interface in org.apache.lucene.spatial3d.geom
-
Interface describing a GeoPointShape shape.It may represents a degenerated
bounding box or a degenerated circle, hence it extends such interfaces.
- GeoPointShapeFactory - Class in org.apache.lucene.spatial3d.geom
-
Class which constructs a GeoPointShape.
- GeoPolygon - Interface in org.apache.lucene.spatial3d.geom
-
GeoPolygon interface description.
- GeoPolygonFactory - Class in org.apache.lucene.spatial3d.geom
-
Class which constructs a GeoMembershipShape representing an arbitrary polygon.
- GeoPolygonFactory.PolygonDescription - Class in org.apache.lucene.spatial3d.geom
-
Use this class to specify a polygon with associated holes.
- GeoRelationUtils - Class in org.apache.lucene.spatial.util
-
Reusable geo-relation utility methods
- GeoShape - Interface in org.apache.lucene.spatial3d.geom
-
Generic shape.
- GeoSizeable - Interface in org.apache.lucene.spatial3d.geom
-
Some shapes can compute radii of a geocircle in which they are inscribed.
- geoTermToString(long) - Static method in class org.apache.lucene.spatial.util.MortonEncoder
-
Converts a long value into a full 64 bit string (useful for debugging)
- GeoTestUtil - Class in org.apache.lucene.geo
-
static methods for testing geo
- GeoTestUtil() - Constructor for class org.apache.lucene.geo.GeoTestUtil
-
- GeoUtils - Class in org.apache.lucene.geo
-
Basic reusable geo-spatial utility methods
- GeoUtils.WindingOrder - Enum in org.apache.lucene.geo
-
used to define the orientation of 3 points
-1 = Clockwise
0 = Colinear
1 = Counter-clockwise
- German2Stemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- German2Stemmer() - Constructor for class org.tartarus.snowball.ext.German2Stemmer
-
- GermanAnalyzer - Class in org.apache.lucene.analysis.de
-
- GermanAnalyzer() - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
- GermanAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
Builds an analyzer with the given stop words
- GermanAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.de.GermanAnalyzer
-
Builds an analyzer with the given stop words
- GermanLightStemFilter - Class in org.apache.lucene.analysis.de
-
- GermanLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanLightStemFilter
-
- GermanLightStemFilterFactory - Class in org.apache.lucene.analysis.de
-
- GermanLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.de.GermanLightStemFilterFactory
-
Creates a new GermanLightStemFilterFactory
- GermanLightStemmer - Class in org.apache.lucene.analysis.de
-
Light Stemmer for German.
- GermanLightStemmer() - Constructor for class org.apache.lucene.analysis.de.GermanLightStemmer
-
- GermanMinimalStemFilter - Class in org.apache.lucene.analysis.de
-
- GermanMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanMinimalStemFilter
-
- GermanMinimalStemFilterFactory - Class in org.apache.lucene.analysis.de
-
- GermanMinimalStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.de.GermanMinimalStemFilterFactory
-
Creates a new GermanMinimalStemFilterFactory
- GermanMinimalStemmer - Class in org.apache.lucene.analysis.de
-
Minimal Stemmer for German.
- GermanMinimalStemmer() - Constructor for class org.apache.lucene.analysis.de.GermanMinimalStemmer
-
- GermanNormalizationFilter - Class in org.apache.lucene.analysis.de
-
- GermanNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanNormalizationFilter
-
- GermanNormalizationFilterFactory - Class in org.apache.lucene.analysis.de
-
- GermanNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.de.GermanNormalizationFilterFactory
-
Creates a new GermanNormalizationFilterFactory
- GermanStemFilter - Class in org.apache.lucene.analysis.de
-
- GermanStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.de.GermanStemFilter
-
- GermanStemFilterFactory - Class in org.apache.lucene.analysis.de
-
- GermanStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.de.GermanStemFilterFactory
-
Creates a new GermanStemFilterFactory
- GermanStemmer - Class in org.apache.lucene.analysis.de
-
A stemmer for German words.
- GermanStemmer() - Constructor for class org.apache.lucene.analysis.de.GermanStemmer
-
- GermanStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- GermanStemmer() - Constructor for class org.tartarus.snowball.ext.GermanStemmer
-
- 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(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- get(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- get(int, int) - Method in class org.apache.lucene.analysis.ja.dict.ConnectionCosts
-
- get(int, int) - Method in class org.apache.lucene.analysis.ko.dict.ConnectionCosts
-
- get(char[], int, FST.Arc<BytesRef>, FST.BytesReader) - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter.StemmerOverrideMap
-
Returns the value mapped to the given key or null
if the key is not in the FST dictionary.
- get(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- get(Map<String, String>, String, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- get(Map<String, String>, String, Collection<String>) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- get(Map<String, String>, String, Collection<String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- get(Map<String, String>, String, Collection<String>, String, boolean) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- get(int) - Method in class org.apache.lucene.analysis.util.RollingCharBuffer
-
- get(int, int) - Method in class org.apache.lucene.analysis.util.RollingCharBuffer
-
- get(String, String) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return a string property.
- get(String, int) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return an int property.
- get(String, double) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return a double property.
- get(String, boolean) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Return a boolean property.
- get(int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
- get(int) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsReader
-
- get(int) - Method in class org.apache.lucene.codecs.TermVectorsReader
-
Returns term vectors for this document, or null if
term vectors were not indexed.
- get(String) - Method in class org.apache.lucene.document.Document
-
Returns the string value of the field with the given name if any exist in
this document, or null.
- get(int, IntsRef) - Method in class org.apache.lucene.facet.taxonomy.OrdinalsReader.OrdinalsSegmentReader
-
Get the ordinals for this document.
- get(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
- get(FacetLabel) - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
Lookup a category in the cache, returning its ordinal, or a negative
number if the category is not in the cache.
- get(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.writercache.UTF8TaxonomyWriterCache
-
- get(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBits
-
- get(int) - Method in class org.apache.lucene.index.LegacyBinaryDocValues
-
Deprecated.
Lookup the value for document.
- get(int) - Method in class org.apache.lucene.index.LegacyNumericDocValues
-
Deprecated.
Returns the numeric value for the specified document ID.
- get(int) - Method in class org.apache.lucene.index.LegacySortedDocValues
-
Deprecated.
- get(int) - Method in class org.apache.lucene.index.MergeState.DocMap
-
Return the mapped docID or -1 if the given doc is not mapped.
- get(int) - Method in class org.apache.lucene.index.TermContext
-
Returns the
TermState
for an leaf ordinal or
null
if no
TermState
for the ordinal was registered.
- get() - Static method in class org.apache.lucene.LucenePackage
-
Return Lucene's package, including version information.
- get(ConfigurationKey<T>) - Method in class org.apache.lucene.queryparser.flexible.core.config.AbstractQueryConfig
-
Returns the value held by the given key.
- get(int) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- get(String) - Method in class org.apache.lucene.search.LiveFieldValues
-
Returns the current value for this id, or null if the
id isn't in the index or was deleted.
- get(long) - Method in class org.apache.lucene.search.ScorerSupplier
-
- get(String) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-
- get(String) - Method in class org.apache.lucene.search.similarities.RandomSimilarity
-
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
Returns the weight associated with an input string,
or null if it does not exist.
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Returns the weight associated with an input string,
or null if it does not exist.
- get() - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
Returns the bucket (weight) as a Long for the provided key if it exists,
otherwise null if it does not.
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
Returns the weight associated with an input string,
or null if it does not exist.
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
Returns the value for the specified key, or null
if the key does not exist.
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Retrieve the object indexed by a key.
- get(CharSequence) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
Returns the value for the specified key, or null
if the key does not exist.
- get(String) - Static method in class org.apache.lucene.spatial.query.SpatialOperation
-
- get(int) - Method in interface org.apache.lucene.util.Bits
-
Returns the value of the bit with the specified index
.
- get(int) - Method in class org.apache.lucene.util.Bits.MatchAllBits
-
- get(int) - Method in class org.apache.lucene.util.Bits.MatchNoBits
-
- get(BytesRefBuilder, int) - Method in class org.apache.lucene.util.BytesRefArray
-
- get() - Method in class org.apache.lucene.util.BytesRefBuilder
-
Return a
BytesRef
that points to the internal content of this
builder.
- get(int, BytesRef) - Method in class org.apache.lucene.util.BytesRefHash
-
Populates and returns a
BytesRef
with the bytes for the given
bytesID.
- get() - Method in class org.apache.lucene.util.CharsRefBuilder
-
Return a
CharsRef
that points to the internal content of this
builder.
- get() - Method in class org.apache.lucene.util.CloseableThreadLocal
-
- get() - Method in class org.apache.lucene.util.Counter
-
Returns the counters current value
- get(int) - Method in class org.apache.lucene.util.FixedBitSet
-
- get(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() - Method in class org.apache.lucene.util.IntsRefBuilder
-
Return a
IntsRef
that points to the internal content of this
builder.
- get() - Method in interface org.apache.lucene.util.IOSupplier
-
Gets the result.
- get(long) - Method in class org.apache.lucene.util.LongBitSet
-
- get(long) - Method in class org.apache.lucene.util.LongValues
-
Get value at index
.
- get(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- get(long) - Method in class org.apache.lucene.util.packed.BlockPackedReader
-
- get(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- get(long) - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
-
- get(int) - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-
- get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-
- get(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.Reader
-
Bulk get: read at least one and at most len
longs starting
from index
into arr[off:off+len]
and return
the actual number of values that have been read.
- get(long) - Method in class org.apache.lucene.util.packed.PackedLongValues
-
- get() - Method in class org.apache.lucene.util.RefCount
-
- get(int) - Method in class org.apache.lucene.util.RollingBuffer
-
Get T instance for this absolute position;
this is allowed to be arbitrarily far "in the
future" but cannot be before the last freeBefore.
- get() - Method in class org.apache.lucene.util.SetOnce
-
- get(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- get(Class<S>) - Static method in class org.apache.lucene.util.SPIClassIterator
-
Creates a new SPI iterator to lookup services of type clazz
using
the same ClassLoader
as the argument.
- get(Class<S>, ClassLoader) - Static method in class org.apache.lucene.util.SPIClassIterator
-
Creates a new SPI iterator to lookup services of type clazz
using the given classloader.
- get(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
-
Returns the value to which the specified key is mapped.
- getAccuracy() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
Calculate accuracy on this confusion matrix using the formula:
accuracy = correctly-classified / (correctly-classified + wrongly-classified)
- getAccuracy() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the minimal accuracy from the StringDistance for a match
- getAccuracy() - Method in class org.apache.lucene.search.spell.SpellChecker
-
- getAfterEffect() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-
Returns the first normalization
- getAlgLineNum() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getAlgorithm() - Method in class org.apache.lucene.benchmark.byTask.Benchmark
-
- getAlgorithmText() - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
- getAll(CharSequence) - Method in class org.egothor.stemmer.Trie
-
Gets the all attribute of the Trie object
- getAllChildrenSortByValue() - Method in class org.apache.lucene.facet.LongValueFacetCounts
-
Returns all unique values seen, sorted by value.
- getAllDims(int) - Method in class org.apache.lucene.facet.Facets
-
Returns topN labels for any dimension that had hits,
sorted by the number of hits that dimension matched;
this is used for "sparse" faceting, where many
different dimensions were indexed, for example
depending on the type of document.
- getAllDims(int) - Method in class org.apache.lucene.facet.LongValueFacetCounts
-
- getAllDims(int) - Method in class org.apache.lucene.facet.MultiFacets
-
- getAllDims(int) - Method in class org.apache.lucene.facet.sortedset.ConcurrentSortedSetDocValuesFacetCounts
-
- getAllDims(int) - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetCounts
-
- getAllDims(int) - Method in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
- getAllGroupHeads() - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
- getAllMatchingGroups() - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
- getAllowLeadingWildcard() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getAllowLeadingWildcard() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- getAllowLeadingWildcard() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getAllPositionInsensitiveTerms() - Method in class org.apache.lucene.search.uhighlight.PhraseHelper
-
Returns the terms that are position-insensitive (sorted).
- getAnalyzer() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getAnalyzer() - Method in class org.apache.lucene.index.IndexWriter
-
Returns the analyzer used by this index.
- getAnalyzer() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getAnalyzer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the default analyzer to use for indexing documents.
- getAnalyzer() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns an analyzer that will be used to parse source doc with.
- getAnalyzer() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getAnalyzer() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- getAnalyzer() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getAnalyzer() - Method in class org.apache.lucene.search.suggest.document.PrefixCompletionQuery
-
Gets the analyzer used to analyze the prefix.
- getAnalyzer() - Method in class org.apache.lucene.util.QueryBuilder
-
Returns the analyzer.
- getAnalyzerFactories() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getAndClear(int) - Method in class org.apache.lucene.util.FixedBitSet
-
- getAndClear(long) - Method in class org.apache.lucene.util.LongBitSet
-
- getAndIncrement(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Retrieve the Float
indexed by key, increment it by one unit
and store the new Float
.
- getAndQuery(List<SrndQuery>, boolean, Token) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getAndResetClearCalled() - Method in interface org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttribute
-
- getAndResetClearCalled() - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
-
- getAndSet(int) - Method in class org.apache.lucene.util.FixedBitSet
-
- getAndSet(long) - Method in class org.apache.lucene.util.LongBitSet
-
- getAnyTokenStream(IndexReader, int, String, Document, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getAnyTokenStream(IndexReader, int, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getArcCount() - Method in class org.apache.lucene.util.fst.Builder
-
- getArea(SpatialContext) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getArea(SpatialContext) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- getArea(SpatialContext) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- getArguments() - Method in interface org.apache.lucene.queryparser.flexible.messages.Message
-
- getArguments() - Method in class org.apache.lucene.queryparser.flexible.messages.MessageImpl
-
- getArray() - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- getArray() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- getArray() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- getAssertNoDeleteOpenFile() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- getAssignedClass() - Method in class org.apache.lucene.classification.ClassificationResult
-
retrieve the result class
- getAttribute(String) - Method in class org.apache.lucene.index.FieldInfo
-
Get a codec attribute value, or null if it does not exist
- getAttribute(String) - Method in class org.apache.lucene.index.SegmentInfo
-
Get a codec attribute value, or null if it does not exist
- getAttribute(String) - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- getAttribute(Element, String, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getAttribute(Element, String, float) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getAttribute(Element, String, int) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getAttribute(Element, String, boolean) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getAttribute(Class<T>) - Method in class org.apache.lucene.util.AttributeSource
-
Returns the instance of the passed in Attribute contained in this AttributeSource
- getAttributeClassesIterator() - Method in class org.apache.lucene.util.AttributeSource
-
Returns a new iterator that iterates the attribute classes
in the same order they were added in.
- getAttributeFactory() - Method in class org.apache.lucene.util.AttributeSource
-
returns the used AttributeFactory.
- getAttributeImplsIterator() - Method in class org.apache.lucene.util.AttributeSource
-
Returns a new iterator that iterates all unique Attribute implementations.
- getAttributeOrFail(Element, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getAttributes() - Method in class org.apache.lucene.document.FieldType
-
- getAttributes() - Method in interface org.apache.lucene.index.IndexableFieldType
-
Attributes for the field type.
- getAttributes() - Method in class org.apache.lucene.index.SegmentInfo
-
Returns the internal codec attributes map.
- getAttributeSource() - Method in class org.apache.lucene.index.FieldInvertState
-
- getAttributeWithInheritance(Element, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
Returns an attribute value from this node, or first parent node with this attribute defined
- getAttributeWithInheritanceOrFail(Element, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getAutoGenerateMultiTermSynonymsPhraseQuery() - Method in class org.apache.lucene.util.QueryBuilder
-
Returns true if phrase query should be automatically generated for multi terms synonyms.
- getAutoGeneratePhraseQueries() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getAutoIOThrottle() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Returns true if auto IO throttling is currently enabled.
- getAutomata() - Method in class org.apache.lucene.search.uhighlight.UHComponents
-
- getAutomata(String, Query, Set<UnifiedHighlighter.HighlightFlag>) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getAutomaton() - Method in class org.apache.lucene.search.AutomatonQuery
-
Returns the automaton used to create this query
- getAutomaton() - Method in class org.apache.lucene.search.suggest.document.CompletionWeight
-
- getAutomaton(String) - Method in interface org.apache.lucene.util.automaton.AutomatonProvider
-
Returns automaton of the given name.
- getAutomaton() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
-
Returns the automaton that caused this exception, if any.
- getAvgClassificationTime() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
get the average classification time in milliseconds
- getAvgFieldLength() - Method in class org.apache.lucene.search.similarities.BasicStats
-
Returns the average field length.
- getAvp() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Return the average precision at recall points.
- getB() - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Returns the b
parameter
- getBackgroundColorString(float) - Method in class org.apache.lucene.search.highlight.GradientFormatter
-
- getBackgroundDeltaPriority() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getBaseForm(int, char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getBaseForm(int, char[], int, int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get base form of word
- getBaseForm(int, char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getBaseForm() - Method in class org.apache.lucene.analysis.ja.Token
-
- getBaseForm() - Method in interface org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttribute
-
- getBaseForm() - Method in class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
-
- getBaseTempDirForTestClass() - Static method in class org.apache.lucene.util.LuceneTestCase
-
Deprecated.
- getBasicModel() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-
Returns the basic model of information content
- getBasicQueryFactory() - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- getBegin() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getBegin() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode.QueryText
-
- getBeginColumn() - Method in interface org.apache.lucene.queryparser.classic.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.classic.FastCharStream
-
- getBeginColumn() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
For EndOfLine and EndOfFile ("<EOF>") parsing problems the last char in the
string is returned For the case where the parser is not able to figure out
the line and column number -1 will be returned
- getBeginColumn() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.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.flexible.standard.parser.FastCharStream
-
- getBeginColumn() - Method in interface org.apache.lucene.queryparser.surround.parser.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.surround.parser.FastCharStream
-
- getBeginIndex() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- getBeginLine() - Method in interface org.apache.lucene.queryparser.classic.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.classic.FastCharStream
-
- getBeginLine() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
For EndOfLine and EndOfFile ("<EOF>") parsing problems the last char in the
string is returned For the case where the parser is not able to figure out
the line and column number -1 will be returned
- getBeginLine() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.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.flexible.standard.parser.FastCharStream
-
- getBeginLine() - Method in interface org.apache.lucene.queryparser.surround.parser.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.surround.parser.FastCharStream
-
- getBestFragment(Analyzer, String, String) - Method in class org.apache.lucene.search.highlight.Highlighter
-
Highlights chosen terms in a text, extracting the most relevant section.
- getBestFragment(TokenStream, String) - Method in class org.apache.lucene.search.highlight.Highlighter
-
Highlights chosen terms in a text, extracting the most relevant section.
- getBestFragment(FieldQuery, IndexReader, int, String, int) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
return the best fragment.
- getBestFragment(FieldQuery, IndexReader, int, String, int, FragListBuilder, FragmentsBuilder, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
return the best fragment.
- getBestFragments(Analyzer, String, String, int) - Method in class org.apache.lucene.search.highlight.Highlighter
-
Highlights chosen terms in a text, extracting the most relevant sections.
- getBestFragments(TokenStream, String, int) - Method in class org.apache.lucene.search.highlight.Highlighter
-
Highlights chosen terms in a text, extracting the most relevant sections.
- getBestFragments(TokenStream, String, int, String) - Method in class org.apache.lucene.search.highlight.Highlighter
-
Highlights terms in the text , extracting the most relevant sections
and concatenating the chosen fragments with a separator (typically "...").
- getBestFragments(FieldQuery, IndexReader, int, String, int, int) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
return the best fragments.
- getBestFragments(FieldQuery, IndexReader, int, String, int, int, FragListBuilder, FragmentsBuilder, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
return the best fragments.
- getBestFragments(FieldQuery, IndexReader, int, String, Set<String>, int, int, FragListBuilder, FragmentsBuilder, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
Return the best fragments.
- getBestTextFragments(TokenStream, String, boolean, int) - Method in class org.apache.lucene.search.highlight.Highlighter
-
Low level api to get the most relevant (formatted) sections of the document.
- getBinary(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
-
- getBinary(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
-
- getBinary(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
- getBinaryDocValues(String) - Method in class org.apache.lucene.facet.taxonomy.OrdinalMappingLeafReader
-
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.CodecReader
-
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.LeafReader
-
Returns
BinaryDocValues
for this field, or
null if no binary doc values were indexed for
this field.
- getBinaryDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getBinaryDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
Retrieves the BinaryDocValues for the field in this segment
- getBinaryDocValues(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getBinaryValue(String) - Method in class org.apache.lucene.document.Document
-
Returns an array of bytes for the first (or only) field that has the name
specified as the method parameter.
- getBinaryValues(String) - Method in class org.apache.lucene.document.Document
-
Returns an array of byte arrays for of the fields that have the name specified
as the method parameter.
- getBinaryValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
-
Returns a BinaryDocValues for a reader's docvalues (potentially merging on-the-fly)
- getBits(LeafReaderContext) - Method in class org.apache.lucene.search.suggest.BitsProducer
-
Return
Bits
for the given leaf.
- getBits() - Method in class org.apache.lucene.util.FixedBitSet
-
Expert.
- getBits() - Method in class org.apache.lucene.util.LongBitSet
-
Expert.
- getBitSet(LeafReaderContext) - Method in interface org.apache.lucene.search.join.BitSetProducer
-
Produce a
BitSet
matching the expected documents on the given
segment.
- getBitSet(LeafReaderContext) - Method in class org.apache.lucene.search.join.QueryBitSetProducer
-
- getBitSet() - Method in class org.apache.lucene.util.BitSetIterator
-
- getBitsPerValue() - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- getBitsPerValue() - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
-
- getBitsPerValue() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
-
Returns number of bits per value
- getBody() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- getBool() - Method in class org.apache.lucene.queries.function.valuesource.ConstNumberSource
-
- getBool() - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- getBool() - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- getBoolean(Map<String, String>, String, boolean) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getBooleanQuery(List<BooleanClause>) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Factory method for generating query, given a set of clauses.
- getBoost() - Method in class org.apache.lucene.queries.BoostingQuery
-
Deprecated.
- getBoost() - Method in interface org.apache.lucene.search.BoostAttribute
-
Retrieves the boost, default is 1.0f
.
- getBoost() - Method in class org.apache.lucene.search.BoostAttributeImpl
-
- getBoost() - Method in class org.apache.lucene.search.BoostQuery
-
Return the applied boost.
- getBoost() - Method in class org.apache.lucene.search.similarities.BasicStats
-
Returns the total boost.
- getBoost() - Method in class org.apache.lucene.search.spans.SpanBoostQuery
-
Return the applied boost.
- getBoost() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
-
- getBoost() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- getBoost() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
-
- getBoostFactor() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the boost factor used when boosting terms
- getBoundingBox() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getBoundingBox() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- getBoundingBox() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dPointShape
-
- getBoundingBox() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getBoundingBox() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- getBoundingBoxQuery(double, double, double) - Static method in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
Given a latitude and longitude (in degrees) and the
maximum great circle (surface of the earth) distance,
returns a simple Filter bounding box to "fast match"
candidates.
- getBounds(Bounds) - Method in interface org.apache.lucene.spatial3d.geom.Bounded
-
Compute bounds for the shape.
- getBounds(Bounds) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
- getBounds(Bounds) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseShape
-
- getBounds(Bounds) - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- getBracketClose() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- getBracketOpen() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- getBreakIterator(int) - Method in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
- getBreakIterator(int) - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizerConfig
-
Return a breakiterator capable of processing a given script.
- getBreakIterator(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Returns the BreakIterator
to use for
dividing text into passages.
- getBucket(CharSequence) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Returns the bucket assigned to a given key (if found) or -1
if
no exact match exists.
- getBucketCount() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Returns the bucket count (discretization thresholds).
- getBuffer() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
-
Returns the internal buffer
- getBuffer(int) - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
- getBuffered(double, SpatialContext) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getBuffered(double, SpatialContext) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- getBuffered(double, SpatialContext) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dPointShape
-
- getBuffered(double, SpatialContext) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getBuffered(double, SpatialContext) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- getBufferSize() - Method in class org.apache.lucene.store.BufferedIndexInput
-
Returns buffer size.
- getBufferSize() - Method in class org.apache.lucene.util.RollingBuffer
-
Returns how many active positions are in the buffer.
- getByOutput(FST<Long>, long) - Static method in class org.apache.lucene.util.fst.Util
-
Reverse lookup (lookup by output instead of by input),
in the special case when your FSTs outputs are
strictly ascending.
- getByOutput(FST<Long>, long, FST.BytesReader, FST.Arc<Long>, FST.Arc<Long>, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
-
- getByteAt(int, int) - Method in class org.apache.lucene.codecs.MutablePointValues
-
Get the k-th byte of the i-th value.
- getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
-
- getByteBlock() - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-
- getByteBlock() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- getBytes() - Method in class org.apache.lucene.store.GrowableByteArrayDataOutput
-
- getBytesComparator() - Method in class org.apache.lucene.search.SortField
-
- getBytesCopied() - Method in class org.apache.lucene.replicator.nrt.CopyOneFile
-
- getBytesCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Returns the number of bytes generated since last reset.
- getBytesPerDim() - Method in class org.apache.lucene.search.PointInSetQuery
-
- getBytesPerDim() - Method in class org.apache.lucene.search.PointRangeQuery
-
- getBytesPerDimension() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- getBytesPerDimension() - Method in class org.apache.lucene.index.PointValues
-
Returns the number of bytes per dimension
- getBytesPerDimension() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- getBytesReader() - Method in class org.apache.lucene.analysis.ja.dict.TokenInfoFST
-
- getBytesReader() - Method in class org.apache.lucene.analysis.ko.dict.TokenInfoFST
-
- getBytesReader() - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter.StemmerOverrideMap
-
- getBytesReader() - Method in class org.apache.lucene.util.fst.FST
-
- getBytesRef() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
- getBytesRef() - Method in class org.apache.lucene.analysis.MockUTF16TermAttributeImpl
-
- getBytesRef() - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
-
- getBytesRef() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- getBytesRef() - Method in interface org.apache.lucene.analysis.tokenattributes.TermToBytesRefAttribute
-
Retrieve this attribute's BytesRef.
- getBytesRef() - Method in class org.apache.lucene.collation.tokenattributes.CollatedTermAttributeImpl
-
- getBytesRef() - Method in class org.apache.lucene.collation.tokenattributes.ICUCollatedTermAttributeImpl
-
- getC() - Method in class org.apache.lucene.search.similarities.NormalizationH1
-
Returns the c
parameter.
- getC() - Method in class org.apache.lucene.search.similarities.NormalizationH2
-
Returns the c
parameter.
- getCache() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- getCache(LeafReader) - Method in class org.apache.lucene.spatial.util.ShapeFieldCacheProvider
-
- getCacheCount() - Method in class org.apache.lucene.search.LRUQueryCache
-
Return the total number of cache entries that have been generated and put
in the cache.
- getCacheFieldValCharsThreshold() - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Limits the amount of field value pre-fetching until this threshold is passed.
- getCacheSize() - Method in class org.apache.lucene.search.LRUQueryCache
-
Return the total number of
DocIdSet
s which are currently stored
in the cache.
- getCalibrateSizeByDeletes() - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns true if the segment size should be calibrated
by the number of deletes when choosing segments for merge.
- getCalPrecisionField(Calendar) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Calendar utility method:
Gets the Calendar field code of the last field that is set prior to an unset field.
- getCell(Point, int) - Method in class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree
-
- getCell(Point, int) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- getCell(Point, int) - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- getCells() - Method in class org.egothor.stemmer.Row
-
Return the number of cells in use.
- getCells() - Method in class org.egothor.stemmer.Trie
-
Return the number of cells in this Trie object.
- getCellsPnt() - Method in class org.egothor.stemmer.Row
-
Return the number of references (how many transitions) to other rows.
- getCellsPnt() - Method in class org.egothor.stemmer.Trie
-
Gets the cellsPnt attribute of the Trie object
- getCellsVal() - Method in class org.egothor.stemmer.Row
-
Return the number of patch commands saved in this Row.
- getCellsVal() - Method in class org.egothor.stemmer.Trie
-
Gets the cellsVal attribute of the Trie object
- getCenter() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getCenter() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- getCenter() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dCircleShape
-
- getCenter() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getCenter() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- getCenter() - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- getCenter() - Method in interface org.apache.lucene.spatial3d.geom.GeoSizeable
-
Returns the center of a circle into which the area will be inscribed.
- getChar(Map<String, String>, String, char) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getCharacterClass(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- getCharacterClass(char) - Method in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- getCharacterDefinition() - Method in class org.apache.lucene.analysis.ja.dict.UnknownDictionary
-
- getCharacterDefinition() - Method in class org.apache.lucene.analysis.ko.dict.UnknownDictionary
-
- getCharFilterFactories() - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
Returns the list of char filters that are used in this analyzer.
- getCharIntervals() - Method in class org.apache.lucene.util.automaton.RunAutomaton
-
Returns array of codepoint class interval start points.
- getCharSequenceValue() - Method in class org.apache.lucene.document.Field
-
- getCharSequenceValue() - Method in interface org.apache.lucene.index.IndexableField
-
Non-null if this field has a string value
- getCharType(char) - Static method in class org.apache.lucene.analysis.cn.smart.Utility
-
Return the internal
CharType
constant of a given character.
- getCheckIndexOnClose() - Method in class org.apache.lucene.store.BaseDirectoryWrapper
-
- getChecksum() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- getChecksum() - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
-
- getChecksum() - Method in class org.apache.lucene.store.ChecksumIndexInput
-
Returns the current checksum value
- getChecksum() - Method in class org.apache.lucene.store.CorruptingIndexOutput
-
- getChecksum() - Method in class org.apache.lucene.store.IndexOutput
-
Returns the current checksum of bytes written so far
- getChecksum() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
-
- getChecksum() - Method in class org.apache.lucene.store.OutputStreamIndexOutput
-
- getChecksum() - Method in class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
- getChecksum() - Method in class org.apache.lucene.store.RateLimitedIndexOutput
-
- getChecksum() - Method in class org.apache.lucene.util.ThrottledIndexOutput
-
- getChecksumsOnly() - Method in class org.apache.lucene.index.CheckIndex
-
- getChild() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BoostQueryNode
-
Returns the single child which this node boosts.
- getChild() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.GroupQueryNode
-
- getChild() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode
-
- getChild() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- getChild() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- getChildByTagName(Element, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getChildByTagOrFail(Element, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getChildQuery() - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
-
Return our child query.
- getChildren() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
Returns int[] mapping each ordinal to its first child; this is a large array and
is computed (and then saved) the first time this method is invoked.
- getChildren(int) - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Returns an iterator over the children of the given ordinal.
- getChildren() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
get Children nodes
- getChildren() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- getChildren() - Method in class org.apache.lucene.search.AssertingScorer
-
- getChildren() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-
- getChildren() - Method in class org.apache.lucene.search.Scorer
-
Returns child sub-scorers positioned on the current document
Note that this method should not be called on Scorers passed to
LeafCollector.setScorer(Scorer)
,
as these may be synthetic Scorers produced by
BulkScorer
which will throw an Exception.
- getChildResources() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- getChildResources() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsProducer
-
- getChildResources() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
Returns nested resources of this class.
- getChildResources() - Method in class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader
-
- getChildResources() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- getChildResources() - Method in class org.apache.lucene.index.CodecReader
-
- getChildResources() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getChildResources() - Method in class org.apache.lucene.index.OrdinalMap
-
- getChildResources() - Method in class org.apache.lucene.search.LRUQueryCache
-
- getChildResources() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- getChildResources() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- getChildResources() - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
- getChildResources() - Method in class org.apache.lucene.search.suggest.document.CompletionsTermsReader
-
- getChildResources() - Method in class org.apache.lucene.search.suggest.document.NRTSuggester
-
- getChildResources() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- getChildResources() - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
- getChildResources() - Method in class org.apache.lucene.search.TermInSetQuery
-
- getChildResources() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- getChildResources() - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- getChildResources() - Method in class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
- getChildResources() - Method in interface org.apache.lucene.util.Accountable
-
Returns nested resources of this class.
- getChildTextByTagName(Element, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getClassArg() - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getClasses(String) - Method in class org.apache.lucene.classification.BM25NBClassifier
-
- getClasses(String, int) - Method in class org.apache.lucene.classification.BM25NBClassifier
-
- getClasses(String) - Method in class org.apache.lucene.classification.BooleanPerceptronClassifier
-
- getClasses(String, int) - Method in class org.apache.lucene.classification.BooleanPerceptronClassifier
-
- getClasses(String) - Method in interface org.apache.lucene.classification.Classifier
-
Get all the classes (sorted by score, descending) assigned to the given text String.
- getClasses(String, int) - Method in interface org.apache.lucene.classification.Classifier
-
Get the first max
classes (sorted by score, descending) assigned to the given text String.
- getClasses(Document) - Method in interface org.apache.lucene.classification.document.DocumentClassifier
-
Get all the classes (sorted by score, descending) assigned to the given
Document
.
- getClasses(Document, int) - Method in interface org.apache.lucene.classification.document.DocumentClassifier
-
Get the first max
classes (sorted by score, descending) assigned to the given text String.
- getClasses(Document) - Method in class org.apache.lucene.classification.document.KNearestNeighborDocumentClassifier
-
- getClasses(Document, int) - Method in class org.apache.lucene.classification.document.KNearestNeighborDocumentClassifier
-
- getClasses(Document) - Method in class org.apache.lucene.classification.document.SimpleNaiveBayesDocumentClassifier
-
- getClasses(Document, int) - Method in class org.apache.lucene.classification.document.SimpleNaiveBayesDocumentClassifier
-
- getClasses(String) - Method in class org.apache.lucene.classification.KNearestFuzzyClassifier
-
- getClasses(String, int) - Method in class org.apache.lucene.classification.KNearestFuzzyClassifier
-
- getClasses(String) - Method in class org.apache.lucene.classification.KNearestNeighborClassifier
-
- getClasses(String, int) - Method in class org.apache.lucene.classification.KNearestNeighborClassifier
-
- getClasses(String) - Method in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
- getClasses(String, int) - Method in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
- getClassResource(Class<?>, String) - Static method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getClassResource(Class<?>, String) - Static method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- 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.
- getCmd(Character) - Method in class org.egothor.stemmer.Row
-
Return the command in the Cell associated with the given Character.
- getCnt(Character) - Method in class org.egothor.stemmer.Row
-
Return the number of patch commands were in the Cell associated with the
given Character before the Trie containing this Row was reduced.
- getCode() - Method in interface org.apache.lucene.analysis.icu.tokenattributes.ScriptAttribute
-
Get the numeric code for this script value.
- getCode() - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
- getCodec() - Method in class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
Returns the codec to run tests against
- getCodec() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getCodec() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the current
Codec
.
- getCodec() - Method in class org.apache.lucene.index.SegmentInfo
-
Return
Codec
that wrote this segment.
- getCollectedGroupHeads() - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
Returns the collected group heads.
- getCollectionProbability() - Method in class org.apache.lucene.search.similarities.LMSimilarity.LMStats
-
Returns the probability that the current term is generated by the
collection.
- getCollector(T) - Method in class org.apache.lucene.search.grouping.GroupReducer
-
Get the Collector for a given group
- getColsNamesForValsByRound() - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
- getColsValuesForValsByRound(int) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
- getColumn() - Method in interface org.apache.lucene.queryparser.classic.CharStream
-
Deprecated.
- getColumn() - Method in class org.apache.lucene.queryparser.classic.FastCharStream
-
- getColumn() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.CharStream
-
Deprecated.
- getColumn() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.FastCharStream
-
- getColumn() - Method in interface org.apache.lucene.queryparser.surround.parser.CharStream
-
Deprecated.
- getColumn() - Method in class org.apache.lucene.queryparser.surround.parser.FastCharStream
-
- getCommitLuceneVersion() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns which Lucene
Version
wrote this commit, or null if the
version this index was written with did not directly record the version.
- getCommitOnClose() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getCommitUserData() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- getCommitUserData() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Retrieve user committed data.
- getCommonPrefix(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns the longest string that is a prefix of all accepted strings and
visits each state at most once.
- getCommonPrefixBytesRef(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns the longest BytesRef that is a prefix of all accepted strings and
visits each state at most once.
- getCommonSuffixBytesRef(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns the longest BytesRef that is a suffix of all accepted strings.
- getCommonWords() - Method in class org.apache.lucene.analysis.commongrams.CommonGramsFilterFactory
-
- getComparator(int, int) - Method in class org.apache.lucene.search.join.ToParentBlockJoinSortField
-
- getComparator(int, int) - Method in class org.apache.lucene.search.SortedNumericSortField
-
- getComparator(int, int) - Method in class org.apache.lucene.search.SortedSetSortField
-
- getComparator(int, int) - Method in class org.apache.lucene.search.SortField
-
- getComparator() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the current comparator in use.
- getComparator() - Method in class org.apache.lucene.search.spell.SpellChecker
-
Gets the comparator in use for ranking suggestions.
- getComparator() - Method in interface org.apache.lucene.search.suggest.fst.BytesRefSorter
-
Comparator used to determine the sort order of entries.
- getComparator() - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
-
- getComparator() - Method in class org.apache.lucene.search.suggest.InMemorySorter
-
- getComparator() - Method in class org.apache.lucene.util.OfflineSorter
-
Returns the comparator in use to sort entries
- getComparators() - Method in class org.apache.lucene.search.FieldValueHitQueue
-
- getComparators(LeafReaderContext) - Method in class org.apache.lucene.search.FieldValueHitQueue
-
- getComparatorSource() - Method in class org.apache.lucene.search.SortField
-
- getCompetitiveTerm() - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
-
This is the term or null
of the term that triggered the boost change.
- getCompetitiveTerm() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- getCompoundReader(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.CompoundFormat
-
Returns a Directory view (read-only) for the compound files in this segment
- getCompoundReader(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50CompoundFormat
-
- getCompoundReader(Directory, SegmentInfo, IOContext) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCompoundFormat
-
- getConfig() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
- getConfig() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getConfig() - Method in class org.apache.lucene.index.IndexWriter
-
Returns a
LiveIndexWriterConfig
, which can be used to query the IndexWriter
current settings, as well as modify "live" ones.
- getConfusionMatrix(IndexReader, Classifier<T>, String, String, long) - Static method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator
-
- getContentSource() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Returns the ContentSource.
- getContext() - Method in class org.apache.lucene.index.CompositeReader
-
- getContext() - Method in class org.apache.lucene.index.IndexReader
-
- getContext() - Method in class org.apache.lucene.index.LeafReader
-
- getContext() - Method in class org.apache.lucene.queries.BoostingQuery
-
Deprecated.
- getContext() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getContext() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- getContext() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- getCopyState() - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
- getCopyState() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
IncRef the current CopyState and return it
- getCopyStateVersion() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
- getCoreCacheHelper() - Method in class org.apache.lucene.facet.taxonomy.OrdinalMappingLeafReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.index.AllDeletedFilterReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.index.LeafReader
-
Optional method: Return a
IndexReader.CacheHelper
that can be used to cache
based on the content of this leaf regardless of deletions.
- getCoreCacheHelper() - Method in class org.apache.lucene.index.MismatchedLeafReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.index.SegmentReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getCoreCacheHelper() - Method in class org.apache.lucene.search.uhighlight.OverlaySingleDocTermsLeafReader
-
- getCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
-
- getCount() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getCount() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.FacetEntry
-
- getCount() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- getCount() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- getCount() - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
- getCount() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- getCount() - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
- getCount() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
- getCount() - Method in class org.apache.lucene.search.suggest.Lookup
-
Get the number of entries the lookup was built with
- getCount() - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
- getCount(int, int) - Method in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter.Heatmap
-
- getCountsByTime() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getCountsByTimeStepMSec() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getCountToCollect() - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
Returns the number of results to be collected
- getCreatedFiles() - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-
NOTE: returns a copy of the created files.
- getCreatedVersionMajor() - Method in class org.apache.lucene.index.LeafMetaData
-
Get the Lucene version that created this index.
- getCrossCheckTermVectors() - Method in class org.apache.lucene.index.CheckIndex
-
- getCrossCheckTermVectorsOnClose() - Method in class org.apache.lucene.store.BaseDirectoryWrapper
-
- getCrossesDateLine() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getCurrent() - Method in class org.tartarus.snowball.SnowballProgram
-
Get the current string.
- getCurrentBuffer() - Method in class org.tartarus.snowball.SnowballProgram
-
Get the current buffer containing the stem.
- getCurrentBufferLength() - Method in class org.tartarus.snowball.SnowballProgram
-
- getCurrentLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
- getCurrentLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
- getCurrentOffset() - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
-
Returns the offset of the currently written slice.
- getCurrentSearcher() - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- getCurrentSearchingVersion() - Method in class org.apache.lucene.replicator.nrt.Node
-
- getCurrentStats() - Method in class org.apache.lucene.benchmark.byTask.stats.Points
-
- getCustomScoreProvider(LeafReaderContext) - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
- getDataFormat(String) - Method in class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilterFactory
-
- getDataInput() - Method in class org.apache.lucene.util.PagedBytes
-
Returns a DataInput to read values from this
PagedBytes instance.
- getDataInputStream(String) - Method in class org.apache.lucene.util.LuceneTestCase
-
Gets a resource from the test's classpath as InputStream
.
- getDataOutput() - Method in class org.apache.lucene.util.PagedBytes
-
Returns a DataOutput that you may use to write into
this PagedBytes instance.
- getDataPath(String) - Method in class org.apache.lucene.util.LuceneTestCase
-
Gets a resource from the test's classpath as Path
.
- getDate() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- getDateResolution(String) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Returns the date resolution that is used by RangeQueries for the given field.
- getDateResolution() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getDateResolutionMap() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getDecoder(PackedInts.Format, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
- getDecodingReader(InputStream, Charset) - Static method in class org.apache.lucene.util.IOUtils
-
Wrapping the given InputStream
in a reader using a CharsetDecoder
.
- getDecodingReader(Class<?>, String, Charset) - Static method in class org.apache.lucene.util.IOUtils
-
Opens a Reader for the given resource using a CharsetDecoder
.
- getDefault() - Static method in class org.apache.lucene.codecs.Codec
-
- getDefault() - Static method in class org.apache.lucene.store.FSLockFactory
-
Returns the default locking implementation for this platform.
- getDefault() - Static method in class org.apache.lucene.util.InfoStream
-
The default InfoStream
used by a newly instantiated classes.
- getDefaultCodec() - Static method in class org.apache.lucene.util.TestUtil
-
Returns the actual default codec (e.g.
- getDefaultDimConfig() - Method in class org.apache.lucene.facet.FacetsConfig
-
Get the default configuration for new dimensions.
- getDefaultDocValuesFormat() - Static method in class org.apache.lucene.util.TestUtil
-
Returns the actual default docvalues format (e.g.
- getDefaultOperator() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Gets implicit operator setting, which will be either AND_OPERATOR
or OR_OPERATOR.
- getDefaultOperator() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getDefaultOperator() - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Returns the implicit operator setting, which will be
either SHOULD
or MUST
.
- getDefaultPostingsFormat() - Static method in class org.apache.lucene.util.TestUtil
-
Returns the actual default postings format (e.g.
- getDefaultPostingsFormat(int, int) - Static method in class org.apache.lucene.util.TestUtil
-
Returns the actual default postings format (e.g.
- getDefaultQueryCache() - Static method in class org.apache.lucene.search.IndexSearcher
-
Expert: Get the default
QueryCache
or
null
if the cache is disabled.
- getDefaultQueryCachingPolicy() - Static method in class org.apache.lucene.search.IndexSearcher
-
- getDefaultSimilarity() - Static method in class org.apache.lucene.search.IndexSearcher
-
Expert: returns a default Similarity instance.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.bn.BengaliAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.ckb.SoraniAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.cz.CzechAnalyzer
-
Returns a set of default Czech-stopwords
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.da.DanishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.de.GermanAnalyzer
-
Returns a set of default German-stopwords
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.el.GreekAnalyzer
-
Returns a set of default Greek-stopwords
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.en.EnglishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.es.SpanishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.ga.IrishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.hi.HindiAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.it.ItalianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.ja.JapaneseAnalyzer
-
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.lt.LithuanianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Returns an unmodifiable instance of the default stop-words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.th.ThaiAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopSet() - Static method in class org.apache.lucene.analysis.uk.UkrainianMorfologikAnalyzer
-
Returns an unmodifiable instance of the default stop words set.
- getDefaultStopTags() - Static method in class org.apache.lucene.analysis.ja.JapaneseAnalyzer
-
- getDefaultTable() - Static method in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
Returns an unmodifiable instance of the default stemmer table.
- getDefaultValue() - Method in class org.apache.lucene.queries.function.valuesource.QueryValueSource
-
- getDelay(boolean) - Method in class org.apache.lucene.util.ThrottledIndexOutput
-
- getDelCount() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the number of deleted docs in the segment.
- getDelegate() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getDelegate() - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- getDelegate() - Method in class org.apache.lucene.index.FilterLeafReader
-
- getDelegate() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
Returns the FileSystem
we wrap.
- getDelegate() - Method in class org.apache.lucene.mockfile.FilterPath
-
Get the underlying wrapped path.
- getDelegate() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-
- getDelegate() - Method in class org.apache.lucene.store.FilterDirectory
-
- getDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
-
Returns the current deletesPctAllowed setting.
- getDeletionPolicy() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter
-
- getDelGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns generation number of the live docs file
or -1 if there are no deletes yet.
- getDepth() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getDescription() - Method in class org.apache.lucene.search.Explanation
-
A description of this explanation node.
- getDetails() - Method in class org.apache.lucene.search.Explanation
-
The sub-nodes of this explanation node.
- getDiagnostics() - Method in class org.apache.lucene.index.SegmentInfo
-
Returns diagnostics saved into the segment when it was
written.
- getDimConfig(String) - Method in class org.apache.lucene.facet.FacetsConfig
-
Get the current configuration for a dimension.
- getDimConfigs() - Method in class org.apache.lucene.facet.FacetsConfig
-
- getDirectory() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getDirectory() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Returns the
Directory
of this taxonomy writer.
- getDirectory() - Method in class org.apache.lucene.index.IndexCommit
-
- getDirectory() - Method in class org.apache.lucene.index.IndexWriter
-
Returns the Directory used by this index.
- getDirectory() - Method in exception org.apache.lucene.index.MergePolicy.MergeException
-
Returns the
Directory
of the index that hit
the exception.
- getDirectory(Directory) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- getDirectory() - Method in class org.apache.lucene.replicator.nrt.Node
-
Returns the
Directory
this node is writing to
- getDirectory(String, String) - Method in class org.apache.lucene.replicator.PerSessionDirectoryFactory
-
- getDirectory(String, String) - Method in interface org.apache.lucene.replicator.ReplicationClient.SourceDirectoryFactory
-
Returns the
Directory
to use for the given session and source.
- getDirectory(Path) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Subclass can override to choose a specific
Directory
implementation.
- getDirectory(Path) - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
A subclass returns the Directory to be tested; if it's
an FS-based directory it should point to the specified
path, else it can ignore it.
- getDirectory(Path) - Method in class org.apache.lucene.store.BaseLockFactoryTestCase
-
Subclass returns the Directory to be tested; if it's
an FS-based directory it should point to the specified
path, else it can ignore it.
- getDirectory() - Method in class org.apache.lucene.store.FSDirectory
-
- getDirectory() - Method in class org.apache.lucene.util.OfflineSorter
-
Returns the
Directory
we use to create temp files.
- getDirectReader(IndexInput) - Static method in class org.apache.lucene.util.packed.PackedInts
-
- getDirectReaderNoHeader(IndexInput, PackedInts.Format, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Expert: Construct a direct
PackedInts.Reader
from a stream without reading
metadata at the beginning of the stream.
- getDirImpl() - Method in class org.apache.lucene.index.CheckIndex.Options
-
Get the name of the FSDirectory implementation class to use.
- getDiscountOverlaps() - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Returns true if overlap tokens are discounted from the document's length.
- getDiscountOverlaps() - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
Returns true if overlap tokens are discounted from the document's length.
- getDiscountOverlaps() - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Returns true if overlap tokens are discounted from the document's length.
- getDisjuncts() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
- getDistance() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- getDistance() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the string distance metric in use.
- getDistance(String, String) - Method in class org.apache.lucene.search.spell.JaroWinklerDistance
-
- getDistance(String, String) - Method in class org.apache.lucene.search.spell.LevenshteinDistance
-
- getDistance(String, String) - Method in class org.apache.lucene.search.spell.LuceneLevenshteinDistance
-
- getDistance(String, String) - Method in class org.apache.lucene.search.spell.NGramDistance
-
- getDistance(String, String) - Method in interface org.apache.lucene.search.spell.StringDistance
-
Returns a float between 0 and 1 based on how similar the specified strings are to one another.
- getDistanceBounds(Bounds, DistanceStyle, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
- getDistanceBounds(Bounds, DistanceStyle, double) - Method in interface org.apache.lucene.spatial3d.geom.GeoDistanceShape
-
Compute a bound based on a provided distance measure.
- getDistanceForLevel(int) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- getDistanceForLevel(int) - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
Given a cell having the specified level, returns the distance from opposite
corners.
- getDistanceQuery(List<SrndQuery>, boolean, Token, boolean) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getDistErr() - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
The acceptable error of the shape.
- getDistErrPct() - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- getDistErrPct() - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
A measure of acceptable error of the shape as a fraction.
- getDistribution() - Method in class org.apache.lucene.search.similarities.IBSimilarity
-
Returns the distribution
- getDoc() - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
- getDocCount() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- getDocCount() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- getDocCount(String) - Method in class org.apache.lucene.index.BaseCompositeReader
-
- getDocCount() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
- getDocCount(String) - Method in class org.apache.lucene.index.IndexReader
-
Returns the number of documents that have at least one term for this field,
or -1 if this measure isn't stored by the codec.
- getDocCount(String) - Method in class org.apache.lucene.index.LeafReader
-
- getDocCount() - Method in class org.apache.lucene.index.MultiTerms
-
- getDocCount(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
-
Return the cumulated number of docs that have points across all leaves
of the given
IndexReader
.
- getDocCount() - Method in class org.apache.lucene.index.PointValues
-
Returns the total number of documents that have indexed at least one point.
- getDocCount() - Method in class org.apache.lucene.index.Terms
-
Returns the number of documents that have at least one
term for this field, or -1 if this measure isn't
stored by the codec.
- getDocCount() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- getDocCountSeen() - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
-
Returns total number of unique docIDs in this BKD tree
- getDocFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
-
Returns the document frequency.
- getDocID(int) - Method in class org.apache.lucene.codecs.MutablePointValues
-
Return the doc ID of the i-th value.
- getDocIdSet(LeafReaderContext) - Method in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery
-
- getDocIdSet() - Method in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery.VisitorTemplate
-
- getDocIdSet(LeafReaderContext) - Method in class org.apache.lucene.spatial.prefix.ContainsPrefixTreeQuery
-
- getDocIdSet(LeafReaderContext) - Method in class org.apache.lucene.spatial.prefix.IntersectsPrefixTreeQuery
-
- getDocIdSet(LeafReaderContext) - Method in class org.apache.lucene.spatial.prefix.WithinPrefixTreeQuery
-
- getDocMaker() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Returns the DocMaker.
- getDocNamesExtractTime() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the time it took to extract doc names for judging the measured query, in milliseconds.
- getDocState() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- getDocStats() - Method in class org.apache.lucene.index.IndexWriter
-
- getDocStats() - Method in class org.apache.lucene.index.RandomIndexWriter
-
- getDocument() - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
Retrieve the visited document.
- getDocValues() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
Return top-level doc values.
- getDocValues() - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState
-
Return top-level doc values.
- getDocValuesDocIdSetIterator(String, LeafReader) - Static method in class org.apache.lucene.search.DocValuesFieldExistsQuery
-
Returns a
DocIdSetIterator
from the given field or null if the field doesn't exist
in the reader or if the reader has no doc values for the field.
- getDocValuesFormat(String) - Static method in class org.apache.lucene.util.TestUtil
-
- getDocValuesFormat(Codec, String) - Static method in class org.apache.lucene.util.TestUtil
-
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
Returns the docvalues format that should be used for writing
new segments of field
.
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
Returns the docvalues format that should be used for writing
new segments of field
.
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
Returns the docvalues format that should be used for writing
new segments of field
.
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
Returns the docvalues format that should be used for writing
new segments of field
.
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-
Returns the doc values format that should be used for writing
new segments of field
.
- getDocValuesFormatForField(String) - Method in class org.apache.lucene.index.RandomCodec
-
- getDocValuesGen() - Method in class org.apache.lucene.index.FieldInfo
-
Returns the docValues generation of this field, or -1 if no docValues
updates exist for it.
- getDocValuesGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the generation number of the DocValues file or -1 if there are no
doc-values updates yet.
- getDocValuesReader() - Method in class org.apache.lucene.index.CodecReader
-
Expert: retrieve underlying DocValuesProducer
- getDocValuesReader() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getDocValuesReader() - Method in class org.apache.lucene.index.SegmentReader
-
- getDocValuesType() - Method in class org.apache.lucene.index.FieldInfo
-
Returns
DocValuesType
of the docValues; this is
DocValuesType.NONE
if the field has no docvalues.
- getDocValuesTypes() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
- getDocValuesUpdatesFiles() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the per-field DocValues updates files.
- getDouble() - Method in class org.apache.lucene.queries.function.valuesource.ConstNumberSource
-
- getDouble() - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- getDouble() - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- getDoubleValuesSource(String) - Method in class org.apache.lucene.expressions.Bindings
-
Returns a DoubleValuesSource bound to the variable name
- getDoubleValuesSource(Bindings) - Method in class org.apache.lucene.expressions.Expression
-
Get a DoubleValuesSource which can compute the value of this expression in the context of the given bindings.
- getDoubleValuesSource(String) - Method in class org.apache.lucene.expressions.SimpleBindings
-
- getEdgePoints() - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
- getEdgePoints() - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- getEdgePoints() - Method in interface org.apache.lucene.spatial3d.geom.GeoShape
-
Return a sample point that is on the outside edge/boundary of the shape.
- getElapsed() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getEmptyOutput() - Method in class org.apache.lucene.util.fst.FST
-
- getEnableGraphQueries() - Method in class org.apache.lucene.util.QueryBuilder
-
Returns true if graph TokenStream processing is enabled (default).
- getEnablePositionIncrements() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- getEnablePositionIncrements() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getEnablePositionIncrements() - Method in class org.apache.lucene.util.QueryBuilder
-
Returns true if position increments are enabled.
- getEncodedX(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
-
get quantized x value for the given vertex
- getEncodedY(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
-
get quantized y value for the given vertex
- getEncoder() - Method in class org.apache.lucene.analysis.phonetic.PhoneticFilterFactory
-
Must be thread-safe.
- getEncoder() - Method in class org.apache.lucene.search.highlight.Highlighter
-
- getEncoder(PackedInts.Format, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
- getEnd() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getEnd() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode.QueryText
-
- getEnd() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-
- getEndColumn() - Method in interface org.apache.lucene.queryparser.classic.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.classic.FastCharStream
-
- getEndColumn() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.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.flexible.standard.parser.FastCharStream
-
- getEndColumn() - Method in interface org.apache.lucene.queryparser.surround.parser.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.surround.parser.FastCharStream
-
- getEndIndex() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- getEndLine() - Method in interface org.apache.lucene.queryparser.classic.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.classic.FastCharStream
-
- getEndLine() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.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.flexible.standard.parser.FastCharStream
-
- getEndLine() - Method in interface org.apache.lucene.queryparser.surround.parser.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.surround.parser.FastCharStream
-
- getEndOffset() - Method in class org.apache.lucene.analysis.ko.Token
-
Get the end offset of the term in the analyzed text.
- getEndOffset() - Method in class org.apache.lucene.search.highlight.TokenGroup
-
- getEndOffset() - Method in class org.apache.lucene.search.uhighlight.Passage
-
End offset of this passage.
- getEndOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
-
- getEndOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- getEndOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
-
- getEndOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
- getEndOffsets() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- getEntityResolver() - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
Returns a SAX EntityResolver
to be used by DocumentBuilder
.
- getEntryIterator() - Method in interface org.apache.lucene.search.spell.Dictionary
-
Returns an iterator over all the entries
- getEntryIterator() - Method in class org.apache.lucene.search.spell.HighFrequencyDictionary
-
- getEntryIterator() - Method in class org.apache.lucene.search.spell.LuceneDictionary
-
- getEntryIterator() - Method in class org.apache.lucene.search.spell.PlainTextDictionary
-
- getEntryIterator() - Method in class org.apache.lucene.search.suggest.DocumentDictionary
-
- getEntryIterator() - Method in class org.apache.lucene.search.suggest.DocumentValueSourceDictionary
-
- getEntryIterator() - Method in class org.apache.lucene.search.suggest.FileDictionary
-
- getErrorHandler() - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
Subclass and override to return a SAX ErrorHandler
to be used by DocumentBuilder
.
- getErrorToken() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
- getEstimatedNumberUniqueValuesAllowingForCollisions(int, int) - Static method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- getEstimatedUniqueValues() - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- getEvictionCount() - Method in class org.apache.lucene.search.LRUQueryCache
-
Return the number of cache entries that have been removed from the cache
either in order to stay under the maximum configured size/ram usage, or
because a segment has been closed.
- getExceptionWord(ArrayList<?>) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- getExclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
-
Return the SpanQuery whose matches must not overlap those returned.
- getExpandMultiTermQuery() - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- getExpirationThreshold() - Method in class org.apache.lucene.replicator.LocalReplicator
-
Returns the expiration threshold.
- getExtension(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Return the extension (anything after the first '.'),
or null if there is no '.' in the file name.
- getExtension(String) - Method in class org.apache.lucene.queryparser.ext.Extensions
-
Returns the
ParserExtension
instance for the given key or
null
if no extension can be found for the key.
- getExtension(String) - Static method in class org.apache.lucene.store.FileSwitchDirectory
-
Utility method to return a file's extension.
- getExtensionFieldDelimiter() - Method in class org.apache.lucene.queryparser.ext.ExtendableQueryParser
-
Returns the extension field delimiter character.
- getExtensionFieldDelimiter() - Method in class org.apache.lucene.queryparser.ext.Extensions
-
Returns the extension field delimiter
- getF1Measure(String) - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
get the F-1 measure of the given class
- getF1Measure() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
get the F-1 measure on this confusion matrix
- getFacetEntries(int, int) - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.GroupedFacetResult
-
Returns a list of facet entries to be rendered based on the specified offset and limit.
- getFacetSource() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Returns the facet source.
- getFailed() - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
- getFailFast() - Method in class org.apache.lucene.index.CheckIndex
-
- getFallbackSelector(int) - Method in class org.apache.lucene.util.RadixSelector
-
Get a fall-back selector which may assume that the first d
bytes
of all compared strings are equal.
- getFallbackSorter(int) - Method in class org.apache.lucene.util.MSBRadixSorter
-
Get a fall-back sorter which may assume that the first k bytes of all compared strings are equal.
- getField(String) - Method in class org.apache.lucene.document.Document
-
Returns a field with the given name if any exist in this document, or
null.
- getField(FieldInfo) - Method in class org.apache.lucene.document.LazyDocument
-
Creates a StorableField whose value will be lazy loaded if and
when it is used.
- getField() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
Indexed field we are reading.
- getField() - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState
-
Indexed field we are reading.
- getField() - Method in class org.apache.lucene.queries.function.valuesource.FieldCacheSource
-
- getField() - Method in class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
- getField() - Method in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery
-
- getField() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getField() - Method in class org.apache.lucene.queryparser.ext.ExtensionQuery
-
Returns the query field
- getField() - Method in class org.apache.lucene.queryparser.flexible.core.config.FieldConfig
-
Returns the field name this configuration represents.
- getField() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
returns null if the field was not specified
- getField() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.FieldableNode
-
Returns the field associated to the node and every node under it.
- getField() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getField() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- getField() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
returns null if the field was not specified in the query string
- getField() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- getField() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.TokenizedPhraseQueryNode
-
- getField() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
Returns the field associated with this node.
- getField() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.MultiPhraseQueryNode
-
- getField() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
Returns the field associated with this node.
- getField() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- getField() - Method in class org.apache.lucene.search.DocValuesFieldExistsQuery
-
- getField() - Method in class org.apache.lucene.search.DocValuesNumbersQuery
-
- getField() - Method in class org.apache.lucene.search.intervals.IntervalQuery
-
- getField() - Method in class org.apache.lucene.search.MultiTermQuery
-
Returns the field name for this query
- getField() - Method in class org.apache.lucene.search.NormsFieldExistsQuery
-
- getField() - Method in class org.apache.lucene.search.PointInSetQuery
-
- getField() - Method in class org.apache.lucene.search.PointRangeQuery
-
- getField() - Method in class org.apache.lucene.search.SortField
-
Returns the name of the field.
- getField() - Method in class org.apache.lucene.search.spans.AssertingSpanQuery
-
- getField() - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-
- getField() - Method in class org.apache.lucene.search.spans.SpanBoostQuery
-
- 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.suggest.document.CompletionQuery
-
Returns the field name this query should
be run against
- getField() - Method in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- getField() - Method in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- getField() - Method in class org.apache.lucene.search.uhighlight.UHComponents
-
- getFieldAsString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
returns - null if the field was not specified
- getFieldAsString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
returns null if the field was not specified in the query string
- getFieldAsString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
returns null if the field was not specified in the query string
- getFieldAsString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- getFieldConfig(String) - Method in class org.apache.lucene.queryparser.flexible.core.config.QueryConfigHandler
-
Returns an implementation of
FieldConfig
for a specific field name.
- getFieldEnum(FieldInfo) - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexReader
-
- getFieldEnum(FieldInfo) - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase
-
- getFieldEnum(FieldInfo) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexReader
-
- getFieldHighlighter(String, Query, Set<Term>, int) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getFieldInfo(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getFieldInfos() - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getFieldInfos() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getFieldInfos() - Method in class org.apache.lucene.index.FilterLeafReader
-
- getFieldInfos() - Method in class org.apache.lucene.index.LeafReader
-
Get the
FieldInfos
describing all fields in
this reader.
- getFieldInfos() - Method in class org.apache.lucene.index.MismatchedLeafReader
-
- getFieldInfos() - Method in class org.apache.lucene.index.ParallelLeafReader
-
Get the
FieldInfos
describing all fields in
this reader.
- getFieldInfos() - Method in class org.apache.lucene.index.SegmentReader
-
- getFieldInfos() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getFieldInfosFiles() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the FieldInfos file names.
- getFieldInfosGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the generation number of the field infos file or -1 if there are no
field updates yet.
- getFieldMatcher() - Method in class org.apache.lucene.search.uhighlight.UHComponents
-
- getFieldMatcher(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Returns the predicate to use for extracting the query part that must be highlighted.
- getFieldName() - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- getFieldName() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
-
- getFieldName() - Method in class org.apache.lucene.spatial.SpatialStrategy
-
The name of the field or the prefix of them if there are multiple
fields needed internally.
- getFieldNames() - Method in class org.apache.lucene.index.IndexWriter
-
Return an unmodifiable set of all field names as visible
from this IndexWriter, across all segments of the index.
- getFieldNames() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the field names that will be used when generating the 'More Like This' query.
- getFieldNames() - Method in class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- getFieldOperator() - Method in class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- getFieldOperator() - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getFieldQuery(String, String, int) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- getFieldQuery(String, String, boolean) - Method in class org.apache.lucene.queryparser.ext.ExtendableQueryParser
-
- getFieldQuery(Query) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
- getFieldQuery(Query, IndexReader) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
- getFields(String) - Method in class org.apache.lucene.document.Document
-
- getFields() - Method in class org.apache.lucene.document.Document
-
Returns a List of all the fields in a document.
- getFields(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
-
Returns a single
Fields
instance for this
reader, merging fields/terms/docs/positions on the
fly.
- getFields(IndexReader, int, String) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getFieldsBoost() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Returns the field to boost map used to set boost for each field.
- getFieldsQuery(SrndQuery, ArrayList<String>) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getFieldsReader() - Method in class org.apache.lucene.index.CodecReader
-
Expert: retrieve thread-private StoredFieldsReader
- getFieldsReader() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getFieldsReader() - Method in class org.apache.lucene.index.SegmentReader
-
- getFieldTermMap(String, String) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery
-
- getFieldType() - Method in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
Returns a field type representing the set of field options.
- getFileAttributeView(Path, Class<V>, LinkOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- getFileHandleCount() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
returns current open file handle count
- getFileName() - Method in class org.apache.lucene.mockfile.FilterPath
-
- 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.replicator.nrt.CopyJob
-
Returns all file names referenced in this copy job
- getFileNamesToCopy() - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
- getFilePointer() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- getFilePointer() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- getFilePointer() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- getFilePointer() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- getFilePointer() - Method in class org.apache.lucene.store.ByteBuffersIndexOutput
-
- getFilePointer() - Method in class org.apache.lucene.store.CorruptingIndexOutput
-
- 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.MockIndexInputWrapper
-
- getFilePointer() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
-
- getFilePointer() - Method in class org.apache.lucene.store.OutputStreamIndexOutput
-
- getFilePointer() - Method in class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- getFilePointer() - Method in class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
- getFilePointer() - Method in class org.apache.lucene.store.RateLimitedIndexOutput
-
- getFilePointer() - Method in class org.apache.lucene.util.ThrottledIndexOutput
-
- getFilesToCopy(Map<String, FileMetaData>) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Compares incoming per-file identity (id, checksum, header, footer) versus what we have locally and returns the subset of the incoming
files that need copying
- getFileStore(Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- getFileStoreAttributeView(Class<V>) - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- getFileStores() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- getFileSystem(URI) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- getFileSystem() - Method in class org.apache.lucene.mockfile.FilterPath
-
- getFillerToken() - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- getFilter() - Method in class org.apache.lucene.search.suggest.document.CompletionQuery
-
- getFinalSearcher() - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- getFiniteStrings() - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
-
Get all finite strings from the automaton.
- getFiniteStrings(int, int) - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
-
Get all finite strings that start at startState
and end at endState
.
- getFiniteStringsRecursive(Automaton, int) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Simple, original implementation of getFiniteStrings.
- getFirstArc(FST.Arc<Long>) - Method in class org.apache.lucene.analysis.ja.dict.TokenInfoFST
-
- getFirstArc(FST.Arc<Long>) - Method in class org.apache.lucene.analysis.ko.dict.TokenInfoFST
-
- 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
- getFirstChildElement(Element) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getFirstChildOrFail(Element) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getFirstPathElement() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
Returns the CharSequence value of a specific QueryText element
- getFirstSegmentNumber(long) - Method in class org.apache.lucene.index.OrdinalMap
-
Given a global ordinal, returns the index of the first
segment that contains this term.
- getFirstSegmentOrd(long) - Method in class org.apache.lucene.index.OrdinalMap
-
- getFixedBitSetOrNull(DocIdSetIterator) - Static method in class org.apache.lucene.util.BitSetIterator
-
If the provided iterator wraps a
FixedBitSet
, returns it, otherwise returns null.
- getFlags() - Method in class org.apache.lucene.analysis.Token
-
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
-
- getFlags() - Method in class org.apache.lucene.search.suggest.document.RegexCompletionQuery
-
Get the regex flags
- getFlags(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getFloat(Map<String, String>, String, float) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getFloat() - Method in class org.apache.lucene.queries.function.valuesource.ConstNumberSource
-
- getFloat() - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- getFloat() - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- getFloorSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
-
Returns the current floorSegmentMB.
- getFlushingBytes() - Method in class org.apache.lucene.index.IndexWriter
-
Returns the number of bytes currently being flushed
- getForceMergeDeletesPctAllowed() - Method in class org.apache.lucene.index.TieredMergePolicy
-
Returns the current forceMergeDeletesPctAllowed setting.
- getForceMergeMBPerSec() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Get the per-merge IO throttle rate for forced merges.
- getForegroundColorString(float) - Method in class org.apache.lucene.search.highlight.GradientFormatter
-
- getFormat() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
-
The format used to serialize values.
- getFormatter(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Returns the
PassageFormatter
to use for
formatting passages into highlighted snippets.
- getFragInfos() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList
-
return the list of WeightedFragInfos.
- getFragmentScore() - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- getFragmentScore() - Method in class org.apache.lucene.search.highlight.QueryTermScorer
-
- getFragmentScore() - Method in interface org.apache.lucene.search.highlight.Scorer
-
Called when the
Highlighter
has no more tokens for the current fragment -
the Scorer returns the weighting it has derived for the most recent
fragment, typically based on the results of
Scorer.getTokenScore()
.
- getFragmentScorer() - Method in class org.apache.lucene.search.highlight.Highlighter
-
- getFragmentSize() - Method in class org.apache.lucene.search.highlight.SimpleFragmenter
-
- getFragmentSource(StringBuilder, int[], Field[], int, int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getFragmentSourceMSO(StringBuilder, int[], Field[], int, int, int[]) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getFragNum() - Method in class org.apache.lucene.search.highlight.TextFragment
-
- getFST() - Method in class org.apache.lucene.analysis.ja.dict.TokenInfoDictionary
-
- getFST() - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getFST() - Method in class org.apache.lucene.analysis.ko.dict.TokenInfoDictionary
-
- getFST() - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getFST() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Returns the internal automaton.
- getFullPrefixPaths(List<FSTUtil.Path<PairOutputs.Pair<Long, BytesRef>>>, Automaton, FST<PairOutputs.Pair<Long, BytesRef>>) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
Returns all prefix paths to initialize the search.
- getFullPrefixPaths(List<FSTUtil.Path<PairOutputs.Pair<Long, BytesRef>>>, Automaton, FST<PairOutputs.Pair<Long, BytesRef>>) - Method in class org.apache.lucene.search.suggest.analyzing.FuzzySuggester
-
- getFullSliceDescription(String) - Method in class org.apache.lucene.store.IndexInput
-
Subclasses call this to get the String for resourceDescription of a slice of this IndexInput
.
- getFully(CharSequence) - Method in class org.egothor.stemmer.MultiTrie
-
Return the element that is stored in a cell associated with the given key.
- getFully(CharSequence) - Method in class org.egothor.stemmer.MultiTrie2
-
Return the element that is stored in a cell associated with the given key.
- getFully(CharSequence) - Method in class org.egothor.stemmer.Trie
-
Return the element that is stored in a cell associated with the given key.
- getFuzzyMinSim() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Get the minimal similarity for fuzzy queries.
- getFuzzyMinSim() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Get the minimal similarity for fuzzy queries.
- getFuzzyMinSim() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Get the minimal similarity for fuzzy queries.
- getFuzzyPrefixLength() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Get the prefix length for fuzzy queries.
- getFuzzyPrefixLength() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Get the prefix length for fuzzy queries.
- getFuzzyPrefixLength() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Get the prefix length for fuzzy queries.
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getFuzzyQuery(String, String, float) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- getGeneration() - Method in class org.apache.lucene.index.IndexCommit
-
Returns the generation (the _N in segments_N) for this
IndexCommit
- getGeneration() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns current generation.
- getGeometryStrategy() - Method in class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
- getGlobalCounter() - Static method in class org.apache.lucene.search.TimeLimitingCollector
-
Returns the global TimerThreads
Counter
- getGlobalOrds(int) - Method in class org.apache.lucene.index.OrdinalMap
-
Given a segment number, return a
LongValues
instance that maps
segment ordinals to global ordinals.
- getGlobalTimerThread() - Static method in class org.apache.lucene.search.TimeLimitingCollector
-
- getGraphStrings(Analyzer, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Returns all paths accepted by the token stream graph produced by analyzing text with the provided analyzer.
- getGraphStrings(TokenStream) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Returns all paths accepted by the token stream graph produced by the already initialized
TokenStream
.
- getGrid() - Method in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy
-
- getGrid() - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- getGrid() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- getGrid() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- getGroupCount() - Method in class org.apache.lucene.search.grouping.AllGroupsCollector
-
Returns the total number of groups for the executed search.
- getGroups() - Method in class org.apache.lucene.search.grouping.AllGroupsCollector
-
Returns the group values
- getGroups() - Method in class org.apache.lucene.search.grouping.DistinctValuesCollector
-
Returns all unique values for each top N group.
- getGroupSelector() - Method in class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
- getGroupSelector() - Method in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- getHardLiveDocs() - Method in class org.apache.lucene.index.SegmentReader
-
Returns the live docs that are not hard-deleted.
- getHeapArray() - Method in class org.apache.lucene.util.PriorityQueue
-
This method returns the internal heap array as Object[].
- getHeight() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getHighFreqBoost() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Gets the boost used for high frequency terms.
- getHighFreqMinimumNumberShouldMatch() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Gets the minimum number of the optional high frequent BooleanClauses which must be
satisfied.
- getHighFreqOccur() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- getHighFreqTerms(IndexReader, int, String, Comparator<TermStats>) - Static method in class org.apache.lucene.misc.HighFreqTerms
-
Returns TermStats[] ordered by the specified comparator
- getHighlightFlags() - Method in class org.apache.lucene.search.uhighlight.UHComponents
-
- getHitCount() - Method in class org.apache.lucene.search.LRUQueryCache
-
Over the
total
number of times that a query has
been looked up, return how many times a cached
DocIdSet
has been
found and returned.
- getHoles() - Method in class org.apache.lucene.geo.Polygon
-
Returns a copy of the internal holes array
- getHyphenationPoints() - Method in class org.apache.lucene.analysis.compound.hyphenation.Hyphenation
-
- getHyphenationTree(String) - Static method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Create a hyphenator tree
- getHyphenationTree(InputSource) - Static method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilter
-
Create a hyphenator tree
- getID() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- getId() - Method in class org.apache.lucene.index.SegmentInfo
-
Return the id that uniquely identifies this segment.
- getId() - Method in class org.apache.lucene.index.SegmentInfos
-
Since Lucene 5.0, every commit (segments_N) writes a unique id.
- getId() - Method in enum org.apache.lucene.util.packed.PackedInts.Format
-
Returns the ID of the format.
- getIdentifiers() - Method in class org.apache.lucene.util.automaton.RegExp
-
Returns set of automaton identifiers that occur in this regular expression.
- getIdfWeightedTerms(Query, IndexReader, String) - Static method in class org.apache.lucene.search.highlight.QueryTermExtractor
-
Extracts all terms texts of a given Query into an array of WeightedTerms
- getIgnoreCase() - Method in class org.apache.lucene.analysis.hunspell.Dictionary
-
Returns true if this dictionary was constructed with the ignoreCase
option
- GetImage() - Method in interface org.apache.lucene.queryparser.classic.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.classic.FastCharStream
-
- GetImage() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.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.flexible.standard.parser.FastCharStream
-
- GetImage() - Method in interface org.apache.lucene.queryparser.surround.parser.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.surround.parser.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
.
- getIn() - Method in class org.apache.lucene.search.AssertingQuery
-
- getIn() - Method in class org.apache.lucene.search.AssertingScorer
-
- getInclude() - Method in class org.apache.lucene.search.spans.SpanNotQuery
-
Return the SpanQuery whose matches are filtered.
- getIndependence() - Method in class org.apache.lucene.search.similarities.DFISimilarity
-
Returns the measure of independence
- getIndex() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- getIndexAnalyzer() - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
...
- getIndexCommit() - Method in class org.apache.lucene.index.DirectoryReader
-
Expert: return the IndexCommit that this reader has opened.
- getIndexCommit() - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- getIndexCommit() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getIndexCommit() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getIndexCommit(long) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Retrieve an
IndexCommit
from its generation;
returns null if this IndexCommit is not currently
snapshotted
- getIndexCommit() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- getIndexCreatedVersionMajor() - Method in class org.apache.lucene.index.FieldInvertState
-
Return the version that was used to create the index, or 6 if it was created before 7.0.
- getIndexCreatedVersionMajor() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Return the compatibility version to use for this index.
- getIndexCreatedVersionMajor() - Method in class org.apache.lucene.index.SegmentInfos
-
Return the version major that was used to initially create the index.
- getIndexDeletionPolicy(Config) - Static method in class org.apache.lucene.benchmark.byTask.tasks.CreateIndexTask
-
- getIndexDeletionPolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getIndexDeletionPolicy() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getIndexedFields(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
-
Call this to get the (merged) FieldInfos representing the
set of indexed fields only for a composite reader.
- getIndexFieldName() - Method in class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader
-
- getIndexFieldName() - Method in class org.apache.lucene.facet.taxonomy.DocValuesOrdinalsReader
-
- getIndexFieldName() - Method in class org.apache.lucene.facet.taxonomy.OrdinalsReader
-
Returns the indexed field name this OrdinalsReader
is reading from.
- getIndexOptions() - Method in class org.apache.lucene.index.FieldInfo
-
Returns IndexOptions for the field, or IndexOptions.NONE if the field is not indexed
- getIndexPath() - Method in class org.apache.lucene.index.CheckIndex.Options
-
Get the directory containing the index.
- getIndexQuery() - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
-
Return the wrapped query that may be costly to initialize but has a good
iterator.
- getIndexReader() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getIndexReader() - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- getIndexReader() - Method in class org.apache.lucene.search.IndexSearcher
-
- getIndexSearcher() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getIndexSearcher() - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
...
- getIndexSort() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Get the index-time
Sort
order, applied to all (flushed and merged) segments.
- getIndexSort() - Method in class org.apache.lucene.index.SegmentInfo
-
Return the sort order of this segment, or null if the index has no sort.
- getIndexSortFields() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the field names involved in the index sort
- getIndexStrategy() - Method in class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
- getIndexWriter() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getIndexWriter() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter
-
- getIndexWriterConfig(Analyzer, IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Override this to customize index settings, e.g.
- getInflectedFormTranslation(String) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
-
Get the english form of inflected form
- getInflectionForm(int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getInflectionForm(int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get inflection form of tokens
- getInflectionForm(int) - Method in class org.apache.lucene.analysis.ja.dict.UnknownDictionary
-
- getInflectionForm(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getInflectionForm() - Method in class org.apache.lucene.analysis.ja.Token
-
- getInflectionForm() - Method in interface org.apache.lucene.analysis.ja.tokenattributes.InflectionAttribute
-
- getInflectionForm() - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
-
- getInflectionType(int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getInflectionType(int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get inflection type of tokens
- getInflectionType(int) - Method in class org.apache.lucene.analysis.ja.dict.UnknownDictionary
-
- getInflectionType(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getInflectionType() - Method in class org.apache.lucene.analysis.ja.Token
-
- getInflectionType() - Method in interface org.apache.lucene.analysis.ja.tokenattributes.InflectionAttribute
-
- getInflectionType() - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
-
- getInflectionTypeTranslation(String) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
-
Get the english form of inflection type
- getInfoStream() - Method in class org.apache.lucene.index.BaseMergePolicyTestCase.MockMergeContext
-
- getInfoStream() - Method in class org.apache.lucene.index.IndexWriter
-
- getInfoStream() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getInfoStream() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getInfoStream() - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
-
Returns the info stream that can be used to log messages
- getInfoStream() - Static method in class org.apache.lucene.index.SegmentInfos
-
Returns infoStream
.
- getInputCloneCount() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- getInputType() - Method in class org.apache.lucene.util.fst.FST
-
- getInstance() - Static method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- getInstance() - Static method in class org.apache.lucene.analysis.ja.dict.ConnectionCosts
-
- getInstance() - Static method in class org.apache.lucene.analysis.ja.dict.TokenInfoDictionary
-
- getInstance() - Static method in class org.apache.lucene.analysis.ja.dict.UnknownDictionary
-
- getInstance() - Static method in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- getInstance() - Static method in class org.apache.lucene.analysis.ko.dict.ConnectionCosts
-
- getInstance() - Static method in class org.apache.lucene.analysis.ko.dict.TokenInfoDictionary
-
- getInstance() - Static method in class org.apache.lucene.analysis.ko.dict.UnknownDictionary
-
- getInstance(DirectMonotonicReader.Meta, RandomAccessInput) - Static method in class org.apache.lucene.util.packed.DirectMonotonicReader
-
Retrieves an instance from the specified slice.
- getInstance(IndexOutput, IndexOutput, long, int) - Static method in class org.apache.lucene.util.packed.DirectMonotonicWriter
-
Returns an instance suitable for encoding numValues
into monotonic
blocks of 2blockShift
values.
- getInstance(RandomAccessInput, int) - Static method in class org.apache.lucene.util.packed.DirectReader
-
Retrieves an instance from the specified slice written decoding
bitsPerValue
for each value
- getInstance(RandomAccessInput, int, long) - Static method in class org.apache.lucene.util.packed.DirectReader
-
Retrieves an instance from the specified offset
of the given slice
decoding bitsPerValue
for each value
- getInstance(DataOutput, long, int) - Static method in class org.apache.lucene.util.packed.DirectWriter
-
Returns an instance suitable for encoding numValues
using bitsPerValue
- getInt(Map<String, String>, String, int) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getInt() - Method in class org.apache.lucene.queries.function.valuesource.ConstNumberSource
-
- getInt() - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- getInt() - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- getIntBlock() - Method in class org.apache.lucene.util.IntBlockPool.Allocator
-
- getIntBlock() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- getInterletterValues(String) - Static method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- getIntersectState(PointValues.IntersectVisitor) - Method in class org.apache.lucene.util.bkd.BKDReader
-
- getIORateLimitMBPerSec() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- getItemsCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Returns the number of generated items since last reset.
- getK1() - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Returns the k1
parameter
- getKeepScores() - Method in class org.apache.lucene.facet.FacetsCollector
-
True if scores were saved.
- getKey() - Method in interface org.apache.lucene.index.IndexReader.CacheHelper
-
Get a key that the resource can be cached on.
- getKey() - Method in interface org.apache.lucene.queryparser.flexible.messages.Message
-
- getKey() - Method in class org.apache.lucene.queryparser.flexible.messages.MessageImpl
-
- getKey() - Method in class org.apache.lucene.search.DiversifiedTopDocsCollector.ScoreDocKey
-
- getKey(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the key that indexes the node argument.
- getKeys(LeafReaderContext) - Method in class org.apache.lucene.search.DiversifiedTopDocsCollector
-
Get a source of values used for grouping keys
- getLambda() - Method in class org.apache.lucene.search.similarities.IBSimilarity
-
Returns the distribution's lambda parameter
- getLambda() - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-
Returns the λ parameter.
- getLastCommit(Directory) - Static method in class org.apache.lucene.replicator.IndexReplicationHandler
-
- 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.
- getLastCommitVersion() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
- getLastCumulativeDiff() - Method in class org.apache.lucene.analysis.charfilter.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
-
Returns last succesfully read or written generation.
- getLastOnPath(CharSequence) - Method in class org.egothor.stemmer.MultiTrie
-
Return the element that is stored as last on a path belonging to the given
key.
- getLastOnPath(CharSequence) - Method in class org.egothor.stemmer.MultiTrie2
-
Return the element that is stored as last on a path belonging to the given
key.
- getLastOnPath(CharSequence) - Method in class org.egothor.stemmer.Trie
-
Return the element that is stored as last on a path associated with the
given key.
- getLastOutput(int) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- getLastSaveFile() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Returns the file name the snapshots are currently
saved to, or null if no snapshots have been saved.
- getLastTokenQuery(String) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
This is called if the last token isn't ended
(e.g.
- getLat(int) - Method in class org.apache.lucene.geo.Line
-
Returns latitude value at given index
- getLat() - Method in class org.apache.lucene.geo.Tessellator.Node
-
get the latitude value
- getLat(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
-
get latitude value for the given vertex
- getLatitude() - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Compute the latitude for the point.
- getLats() - Method in class org.apache.lucene.geo.Line
-
Returns a copy of the internal latitude array
- getLeafBlockFP() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
Only valid after pushLeft or pushRight, not pop!
- getLeafCollector(LeafReaderContext) - Method in interface org.apache.lucene.search.Collector
-
Create a new
collector
to collect the given context.
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.DiversifiedTopDocsCollector
-
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.DocValuesStatsCollector
-
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.EarlyTerminatingSortingCollector
-
Deprecated.
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.FilterCollector
-
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.MultiCollector
-
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.MultiCollectorManager.Collectors
-
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.PositiveScoresOnlyCollector
-
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleCollector
-
- getLeafCollector(LeafReaderContext) - Method in class org.apache.lucene.search.TimeLimitingCollector
-
- getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator
-
- getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- getLeafComparator(LeafReaderContext) - Method in class org.apache.lucene.search.SimpleFieldComparator
-
- getLeafContext() - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- getLeftId(int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getLeftId(int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get left id of specified word
- getLeftId(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getLeftId(int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getLeftId(int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get left id of specified word
- getLeftId(int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getLeftLongitude() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Get left longitude, if any.
- getLeftPOS() - Method in class org.apache.lucene.analysis.ko.DecompoundToken
-
- getLeftPOS(int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getLeftPOS(int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get the left
POS.Tag
of specfied word.
- getLeftPOS(int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getLeftPOS() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
- getLeftPOS() - Method in class org.apache.lucene.analysis.ko.Token
-
Get the left part of speech of the token.
- getLeftPOS() - Method in interface org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttribute
-
Get the left part of speech of the token.
- getLeftPOS() - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- getLength() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
-
- getLength() - Method in class org.apache.lucene.analysis.ja.Token
-
- getLength() - Method in class org.apache.lucene.analysis.ko.Token
-
- getLength() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- getLength() - Method in class org.apache.lucene.index.FieldInvertState
-
Get total number of terms in this field.
- getLength() - Method in class org.apache.lucene.search.uhighlight.Passage
-
- getLength() - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
- getLevel() - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Level 0 is the world (and has no parent), from then on a higher level means a smaller
cell than the level before it.
- getLevel() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- getLevel() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getLevel() - Method in interface org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.UnitNRShape
-
Get the prefix tree level, the higher the more precise.
- getLevel() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- getLevelForDistance(double) - Method in class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree.Factory
-
- getLevelForDistance(double) - Method in class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree
-
- getLevelForDistance(double) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- getLevelForDistance(double) - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.Factory
-
- getLevelForDistance(double) - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- getLevelForDistance(double) - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
Returns the level of the largest grid in which its longest side is less
than or equal to the provided distance (in degrees).
- getLevelForDistance(double) - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- getLikeText() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getLine() - Method in interface org.apache.lucene.queryparser.classic.CharStream
-
Deprecated.
- getLine() - Method in class org.apache.lucene.queryparser.classic.FastCharStream
-
- getLine() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.CharStream
-
Deprecated.
- getLine() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.FastCharStream
-
- getLine() - Method in interface org.apache.lucene.queryparser.surround.parser.CharStream
-
Deprecated.
- getLine() - Method in class org.apache.lucene.queryparser.surround.parser.FastCharStream
-
- getLinearizedMatrix() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
get the linearized confusion matrix as a Map
- getLines(ResourceLoader, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
Returns the resource's lines (with content treated as UTF-8)
- getLines(InputStream, Charset) - Static method in class org.apache.lucene.analysis.WordlistLoader
-
Accesses a resource by name and returns the (non comment) lines containing
data using the given character encoding.
- getLiveCommitData() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- getLiveCommitData() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyWriter
-
- getLiveCommitData() - Method in class org.apache.lucene.index.IndexWriter
-
- getLiveDocs() - Method in class org.apache.lucene.index.AllDeletedFilterReader
-
- getLiveDocs() - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getLiveDocs() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getLiveDocs() - Method in class org.apache.lucene.index.FilterLeafReader
-
- getLiveDocs() - Method in class org.apache.lucene.index.LeafReader
-
Returns the
Bits
representing live (not
deleted) docs.
- getLiveDocs(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
-
Returns a single
Bits
instance for this
reader, merging live Documents on the
fly.
- getLiveDocs() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getLiveDocs() - Method in class org.apache.lucene.index.SegmentReader
-
- getLiveDocs() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getLocale() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getLocale() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Returns current locale, allowing access by subclasses.
- getLocale() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Returns current locale, allowing access by subclasses.
- getLocale() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Returns current locale, allowing access by subclasses.
- getLocalizedMessage() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeException
-
- getLocalizedMessage(Locale) - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeException
-
- getLocalizedMessage() - Method in interface org.apache.lucene.queryparser.flexible.messages.Message
-
- getLocalizedMessage(Locale) - Method in interface org.apache.lucene.queryparser.flexible.messages.Message
-
- getLocalizedMessage() - Method in class org.apache.lucene.queryparser.flexible.messages.MessageImpl
-
- getLocalizedMessage(Locale) - Method in class org.apache.lucene.queryparser.flexible.messages.MessageImpl
-
- getLocalizedMessage(String) - Static method in class org.apache.lucene.queryparser.flexible.messages.NLS
-
- getLocalizedMessage(String, Locale) - Static method in class org.apache.lucene.queryparser.flexible.messages.NLS
-
- getLocalizedMessage(String, Locale, Object...) - Static method in class org.apache.lucene.queryparser.flexible.messages.NLS
-
- getLocalizedMessage(String, Object...) - Static method in class org.apache.lucene.queryparser.flexible.messages.NLS
-
- getLogMessage(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
- getLogMessage(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.AddFacetedDocTask
-
- getLogMessage(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.ConsumeContentSourceTask
-
- getLogMessage(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getLogMessage(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTokensTask
-
- getLogMessage(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.UpdateDocTask
-
- getLogMessage(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
- getLon(int) - Method in class org.apache.lucene.geo.Line
-
Returns longitude value at given index
- getLon() - Method in class org.apache.lucene.geo.Tessellator.Node
-
get the longitude value
- getLon(int) - Method in class org.apache.lucene.geo.Tessellator.Triangle
-
get longitude value for the given vertex
- getLong() - Method in class org.apache.lucene.queries.function.valuesource.ConstNumberSource
-
- getLong() - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- getLong() - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- getLongitude() - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Compute the longitude for the point.
- getLons() - Method in class org.apache.lucene.geo.Line
-
Returns a copy of the internal longitude array
- getLowerBound() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.RangeQueryNode
-
- getLowerBound() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
Returns the lower bound node.
- getLowerCaseTerms() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
true if the spellchecker should lowercase terms
- getLowerPoint() - Method in class org.apache.lucene.search.PointRangeQuery
-
- getLowerTerm() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns the lower value of this range query
- getLowerVal() - Method in class org.apache.lucene.queries.function.FunctionRangeQuery
-
- getLowFreqBoost() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Gets the boost used for low frequency terms.
- getLowFreqMinimumNumberShouldMatch() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Gets the minimum number of the optional low frequent BooleanClauses which must be
satisfied.
- getLowFreqOccur() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- getLuceneMatchVersion() - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getLucenePrefixTerm(String) - Method in class org.apache.lucene.queryparser.surround.query.SrndPrefixQuery
-
- getLuceneTerm(String) - Method in class org.apache.lucene.queryparser.surround.query.SrndTermQuery
-
- getMap() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
-
- getMap() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
-
- getMap() - Method in interface org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.OrdinalMap
-
Return the map from the taxonomy's original (consecutive) ordinals
to the new taxonomy's ordinals.
- 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.queries.BoostingQuery
-
Deprecated.
- getMatch() - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-
- getMatchArray() - Method in class org.apache.lucene.index.MultiTermsEnum
-
Returns sub-reader slices positioned to the current term.
- getMatchCount() - Method in class org.apache.lucene.index.MultiTermsEnum
-
Returns how many sub-reader slices contain the current
term.
- getMatchEnds() - Method in class org.apache.lucene.search.uhighlight.Passage
-
- getMatches(String) - Method in interface org.apache.lucene.search.Matches
-
Returns a
MatchesIterator
over the matches for a single field,
or
null
if there are no matches in that field.
- getMatchingDocs() - Method in class org.apache.lucene.facet.FacetsCollector
-
- getMatchingDocs() - Method in class org.apache.lucene.facet.RandomSamplingFacetsCollector
-
Returns the sampled list of the matching documents.
- getMatchStarts() - Method in class org.apache.lucene.search.uhighlight.Passage
-
Start offsets of the term matches, in increasing order.
- getMatchTermFreqsInDoc() - Method in class org.apache.lucene.search.uhighlight.Passage
-
- getMatchTerms() - Method in class org.apache.lucene.search.uhighlight.Passage
-
- getMax() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- getMax(int) - Method in class org.apache.lucene.document.DoubleRange
-
Get the max value for the given dimension
- getMax(int) - Method in class org.apache.lucene.document.FloatRange
-
Get the max value for the given dimension
- getMax(int) - Method in class org.apache.lucene.document.IntRange
-
Get the max value for the given dimension
- getMax(int) - Method in class org.apache.lucene.document.LongRange
-
Get the max value for the given dimension
- getMax() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingTerms
-
- getMax() - Method in class org.apache.lucene.index.MultiTerms
-
- getMax() - Method in class org.apache.lucene.index.Terms
-
Returns the largest term (in lexicographic order) in the field.
- getMax(int) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- getMaxBasicQueries() - Method in class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- getMaxBufferedDocs() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getMaxBufferedDocs() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the number of buffered added documents that will trigger a flush if
enabled.
- getMaxCFSSegmentSizeMB() - Method in class org.apache.lucene.index.FilterMergePolicy
-
- getMaxCFSSegmentSizeMB() - Method in class org.apache.lucene.index.MergePolicy
-
Returns the largest size allowed for a compound file segment
- getMaxCFSSegmentSizeMB() - Method in class org.apache.lucene.index.NoMergePolicy
-
- getMaxChanges() - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Returns the maximum number of changes to perform on the input
- 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.
- getMaxCombineWordLength() - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Returns the maximum length of a combined suggestion
- getMaxCompletedSequenceNumber() - Method in class org.apache.lucene.index.IndexWriter
-
Returns the highest
sequence number across
all completed operations, or 0 if no operations have finished yet.
- getMaxDeterminizedStates() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getMaxDeterminizedStates() - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Get the maximum number of determinized states permitted
- getMaxDeterminizedStates() - Method in class org.apache.lucene.search.suggest.document.RegexCompletionQuery
-
Get the maximum number of states permitted in the determinized automaton
- getMaxDeterminizedStates() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
-
Get the maximum number of allowed determinized states.
- getMaxDocCharsToAnalyze() - Method in class org.apache.lucene.search.highlight.Highlighter
-
- getMaxDocFreq() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the maximum frequency in which words may still appear.
- getMaxEdits() - Method in class org.apache.lucene.search.FuzzyQuery
-
- getMaxEdits() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the maximum number of Levenshtein edit-distances to draw
candidate terms from.
- getMaxEdits() - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Get the maximum edit distance for fuzzy matches
- getMaxEvaluations() - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Returns the maximum number of word combinations to evaluate.
- getMaxGoodPoints() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the maximal number of good points.
- getMaximumMagnitude() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the maximum magnitude of all points on the ellipsoid.
- getMaximumX() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return the maximum X value.
- getMaximumXValue() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the maximum x value.
- getMaximumY() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return the maximum Y value.
- getMaximumYValue() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the maximum y value.
- getMaximumZ() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return the maximum Z value.
- getMaximumZValue() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the maximum z value.
- getMaxInspections() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the maximum number of top-N inspections per suggestion
- getMaxLatitude() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Get maximum latitude, if any.
- getMaxLength() - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
The maximum content size to process.
- getMaxLevels() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- getMaxLevels() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- getMaxLevels() - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
- getMaxLevelsPossible() - Static method in class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree
-
Any more than this and there's no point (double lat and lon are the same).
- getMaxLookaheadUsed() - Method in class org.apache.lucene.analysis.core.FlattenGraphFilter
-
For testing
- getMaxMergeAtOnce() - Method in class org.apache.lucene.index.TieredMergePolicy
-
Returns the current maxMergeAtOnce setting.
- getMaxMergeAtOnceExplicit() - Method in class org.apache.lucene.index.TieredMergePolicy
-
Returns the current maxMergeAtOnceExplicit setting.
- getMaxMergeCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- getMaxMergeDocs() - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns the largest segment (measured by document
count) that may be merged with other segments.
- getMaxMergedSegmentMB() - Method in class org.apache.lucene.index.TieredMergePolicy
-
Returns the current maxMergedSegmentMB setting.
- getMaxMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Returns the largest segment (measured by total byte
size of the segment's files, in MB) that may be merged
with other segments.
- getMaxMergeMBForForcedMerge() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Returns the largest segment (measured by total byte
size of the segment's files, in MB) that may be merged
with other segments during forceMerge.
- getMaxNoHighlightPassages(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Returns the number of leading passages (as delineated by the BreakIterator
) when no
highlights could be found.
- getMaxNonCompetitiveBoost() - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
-
This is the maximum boost that would not be competitive.
- getMaxNonCompetitiveBoost() - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- getMaxNumTokensParsed() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
- getMaxOrdinal() - Method in class org.apache.lucene.facet.taxonomy.writercache.LabelToOrdinal
-
return the maximal Ordinal assigned so far
- getMaxPackedValue() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- getMaxPackedValue(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
-
Return the maximum packed values across all leaves of the given
IndexReader
.
- getMaxPackedValue() - Method in class org.apache.lucene.index.PointValues
-
- getMaxPackedValue() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- getMaxPos() - Method in class org.apache.lucene.util.RollingBuffer
-
Returns the maximum position looked up, or -1 if no
position has been looked up since reset/init.
- getMaxQueries() - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
- getMaxQueryFrequency() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the maximum threshold of documents a query term can appear in order
to provide suggestions.
- getMaxQueryTerms() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the maximum number of query terms that will be included in any generated query.
- getMaxQueryTerms() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getMaxResults() - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
- getMaxScore() - Method in class org.apache.lucene.search.TopDocs
-
Returns the maximum score value encountered.
- getMaxShingleSize() - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
The max shingle (token ngram) size
- getMaxSize() - Method in class org.apache.lucene.facet.taxonomy.LRUHashMap
-
Return the max size
- getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
-
- getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-
- getMaxSize() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
-
- getMaxSize() - Method in class org.apache.lucene.search.TopTermsRewrite
-
return the maximum size of the priority queue (for boolean rewrites this is BooleanQuery#getMaxClauseCount).
- getMaxSizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- getMaxTermFrequency() - Method in class org.apache.lucene.index.FieldInvertState
-
Get the maximum term-frequency encountered for any term in the field.
- getMaxTermFrequency() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Gets the maximum threshold of a terms document frequency to be considered a
low frequency term.
- getMaxTermWeight() - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- getMaxTermWeight() - Method in class org.apache.lucene.search.highlight.QueryTermScorer
-
- getMaxThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Returns maxThreadCount
.
- 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
-
Returns the current maximum token length
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Returns the current maximum token length
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
- getMaxTokenLength() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
- getMaxTotMem() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getMaxUnit() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- getMaxUsedMem() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getMaxUsedSizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Returns the peek actual storage used (bytes) in this
directory.
- getMaxVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
-
Returns the maximum version accepted
- getMaxVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
-
Returns the maximum version accepted.
- getMaxWeight() - Method in class org.apache.lucene.search.suggest.document.CompletionTerms
-
Returns the maximum weight of all entries in the weighted FST
- getMaxWordLen() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the maximum word length above which words will be ignored.
- getMaxX() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getMaxY() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getMBPerSec() - Method in class org.apache.lucene.index.MergeRateLimiter
-
- getMBPerSec() - Method in class org.apache.lucene.store.RateLimiter
-
The current MB per second rate limit.
- getMBPerSec() - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
-
The current mb per second rate limit.
- getMergedFieldInfos(IndexReader) - Static method in class org.apache.lucene.index.MultiFields
-
Call this to get the (merged) FieldInfos for a
composite reader.
- getMergedSegmentWarmer() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getMergedSegmentWarmer() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the current merged segment warmer.
- getMergeFactor() - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns the number of segments that are merged at
once and also controls the total number of segments
allowed to accumulate in the index.
- getMergeInfo() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Returns the
SegmentCommitInfo
for the merged segment,
or null if it hasn't been set yet.
- getMergeInstance() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
- getMergeInstance() - Method in class org.apache.lucene.codecs.DocValuesProducer
-
Returns an instance optimized for merging.
- getMergeInstance() - Method in class org.apache.lucene.codecs.FieldsProducer
-
Returns an instance optimized for merging.
- getMergeInstance() - Method in class org.apache.lucene.codecs.NormsProducer
-
Returns an instance optimized for merging.
- getMergeInstance() - Method in class org.apache.lucene.codecs.PointsReader
-
Returns an instance optimized for merging.
- getMergeInstance() - Method in class org.apache.lucene.codecs.StoredFieldsReader
-
Returns an instance optimized for merging.
- getMergeInstance() - Method in class org.apache.lucene.codecs.TermVectorsReader
-
Returns an instance optimized for merging.
- getMergePolicy() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getMergePolicy() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the current MergePolicy in use by this writer.
- getMergeProgress() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
- getMergeScheduler() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getMergeScheduler() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getMergeThread(IndexWriter, MergePolicy.OneMerge) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Create and return a new MergeThread
- getMergingSegments() - Method in class org.apache.lucene.index.BaseMergePolicyTestCase.MockMergeContext
-
- getMergingSegments() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: to be used by a
MergePolicy
to avoid
selecting merges for segments already being merged.
- getMergingSegments() - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
-
Returns an unmodifiable set of segments that are currently merging.
- getMessage() - Method in error org.apache.lucene.queryparser.classic.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMessage() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeException
-
- getMessage() - Method in error org.apache.lucene.queryparser.flexible.standard.parser.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMessage() - Method in error org.apache.lucene.queryparser.surround.parser.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMessageObject() - Method in error org.apache.lucene.queryparser.flexible.core.QueryNodeError
-
- getMessageObject() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeException
-
- getMessageObject() - Method in interface org.apache.lucene.queryparser.flexible.messages.NLSException
-
- getMetaData() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getMetaData() - Method in class org.apache.lucene.index.FilterLeafReader
-
- getMetaData() - Method in class org.apache.lucene.index.LeafReader
-
Return metadata about this leaf.
- getMetaData() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getMetaData() - Method in class org.apache.lucene.index.SegmentReader
-
- getMetaData() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getMilliseconds() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
Get the timer value in milliseconds.
- getMin() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- getMin(int) - Method in class org.apache.lucene.document.DoubleRange
-
Get the min value for the given dimension
- getMin(int) - Method in class org.apache.lucene.document.FloatRange
-
Get the min value for the given dimension
- getMin(int) - Method in class org.apache.lucene.document.IntRange
-
Get the min value for the given dimension
- getMin(int) - Method in class org.apache.lucene.document.LongRange
-
Get the min value for the given dimension
- getMin() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingTerms
-
- getMin() - Method in class org.apache.lucene.index.MultiTerms
-
- getMin() - Method in class org.apache.lucene.index.Terms
-
Returns the smallest term (in lexicographic order) in the field.
- getMin(int) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- getMinBreakWordLength() - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Returns the minimum size of a broken word
- getMinDocFreq() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the frequency at which words will be ignored which do not occur in at least this
many docs.
- getMinDocFreq() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getMinFuzzyLength() - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Get the minimum length of a term considered for matching
- getMinimumMagnitude() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the minimum magnitude of all points on the ellipsoid.
- getMinimumMatchingElements() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
- getMinimumNumberShouldMatch() - Method in class org.apache.lucene.search.BooleanQuery
-
Gets the minimum number of the optional BooleanClauses
which must be satisfied.
- getMinimumX() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return the minimum X value.
- getMinimumXValue() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the minimum x value.
- getMinimumY() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return the minimum Y value.
- getMinimumYValue() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the minimum y value.
- getMinimumZ() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return the minimum Z value.
- getMinimumZValue() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Find the minimum z value.
- getMinLatitude() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Get minimum latitude, if any.
- getMinMergeDocs() - Method in class org.apache.lucene.index.LogDocMergePolicy
-
Get the minimum size for a segment to remain
un-merged.
- getMinMergeMB() - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Get the minimum size for a segment to remain
un-merged.
- getMinPackedValue() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- getMinPackedValue(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
-
Return the minimum packed values across all leaves of the given
IndexReader
.
- getMinPackedValue() - Method in class org.apache.lucene.index.PointValues
-
- getMinPackedValue() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- getMinPauseCheckBytes() - Method in class org.apache.lucene.index.MergeRateLimiter
-
- getMinPauseCheckBytes() - Method in class org.apache.lucene.store.RateLimiter
-
- getMinPauseCheckBytes() - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
-
- getMinPrefix() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the minimal number of characters that must match exactly
- getMinQueryLength() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the minimum length of a query term needed to return suggestions
- getMinSegmentLuceneVersion() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns the version of the oldest segment, or null if there are no segments.
- getMinShingleSize() - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
The min shingle (token ngram) size
- getMinSimilarity() - Method in class org.apache.lucene.queryparser.flexible.standard.config.FuzzyConfig
-
- getMinSuggestionFrequency() - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Returns the minimum frequency a term must have
to be part of a suggestion.
- getMinTermFreq() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the frequency below which terms will be ignored in the source doc.
- getMinTermFrequency() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getMinUnit() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- getMinVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
-
Returns the minimum version accepted
- getMinVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
-
- getMinVersion() - Method in class org.apache.lucene.index.LeafMetaData
-
Return the minimum Lucene version that contributed documents to this index,
or null
if this information is not available.
- getMinVersion() - Method in class org.apache.lucene.index.SegmentInfo
-
Return the minimum Lucene version that contributed documents to this
segment, or null
if it is unknown.
- getMinWeight() - Method in class org.apache.lucene.search.suggest.document.CompletionTerms
-
Returns the minimum weight of all entries in the weighted FST
- getMinWordLen() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns the minimum word length below which words will be ignored.
- getMinX() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getMinY() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getMissCount() - Method in class org.apache.lucene.search.LRUQueryCache
-
Over the
total
number of times that a query has
been looked up, return how many times this query was not contained in the
cache.
- getMissingValue() - Method in class org.apache.lucene.search.SortField
-
Return the value to use for documents that don't have a value.
- getModifier() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode
-
- getMoreLikeFields() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getMorphemes() - Method in class org.apache.lucene.analysis.ko.DecompoundToken
-
- getMorphemes(int, char[], int, int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getMorphemes(int, char[], int, int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get the morphemes of specified word (e.g.
- getMorphemes(int, char[], int, int) - Method in class org.apache.lucene.analysis.ko.dict.UnknownDictionary
-
- getMorphemes(int, char[], int, int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getMorphemes() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
- getMorphemes() - Method in class org.apache.lucene.analysis.ko.Token
-
- getMorphemes() - Method in interface org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttribute
-
- getMorphemes() - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- getMRR() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the Mean reciprocal rank over the queries or RR for a single query.
- getMu() - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
-
Returns the μ parameter.
- getMu() - Method in class org.apache.lucene.search.similarities.NormalizationH3
-
Returns the parameter μ
- getMultiFieldQuery(List<Query>) - Method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
Creates a multifield query
- getMultiFields() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Returns the fields used to expand the query when the field for a
certain query is null
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.ar.ArabicNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.bn.BengaliNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.cjk.CJKWidthFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.ckb.SoraniNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.core.DecimalDigitFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.core.LowerCaseFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.core.LowerCaseTokenizerFactory
-
Deprecated.
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.core.UpperCaseFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.de.GermanNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.el.GreekLowerCaseFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.fa.PersianCharFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.fa.PersianNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.ga.IrishLowerCaseFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.hi.HindiNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.icu.ICUFoldingFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.icu.ICUNormalizer2CharFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.icu.ICUNormalizer2FilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.icu.ICUTransformFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.in.IndicNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.ja.JapaneseIterationMarkCharFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.miscellaneous.ScandinavianFoldingFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.miscellaneous.ScandinavianNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.miscellaneous.TrimFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.pattern.PatternReplaceCharFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.sr.SerbianNormalizationFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.tr.TurkishLowerCaseFilterFactory
-
- getMultiTermComponent() - Method in class org.apache.lucene.analysis.util.ElisionFilterFactory
-
- getMultiTermComponent() - Method in interface org.apache.lucene.analysis.util.MultiTermAwareComponent
-
Returns an analysis component to handle analysis if multi-term queries.
- getMultiTermRewriteMethod() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getMultiTermRewriteMethod() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- getMultiTermRewriteMethod() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getMultiValuedSeparator() - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getMutable() - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- getMutable(int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Create a packed integer array with the given amount of values initialized
to 0.
- getMutable(int, int, PackedInts.Format) - Static method in class org.apache.lucene.util.packed.PackedInts
-
- getN() - Method in class org.apache.lucene.search.NGramPhraseQuery
-
Return the n in n-gram
- getName() - Method in interface org.apache.lucene.analysis.icu.tokenattributes.ScriptAttribute
-
Get the full name.
- getName() - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
- getName() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- getName() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getName() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- getName() - Method in class org.apache.lucene.codecs.Codec
-
Returns this codec's name
- getName() - Method in class org.apache.lucene.codecs.DocValuesFormat
-
- getName() - Method in class org.apache.lucene.codecs.PostingsFormat
-
Returns this posting format's name
- getName() - Method in class org.apache.lucene.index.FieldInvertState
-
Return the field's name
- getName(int) - Method in class org.apache.lucene.mockfile.FilterPath
-
- getName() - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
-
- getName() - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-
- getName() - Method in interface org.apache.lucene.search.similarities.LMSimilarity.CollectionModel
-
The name of the collection model strategy.
- getName() - Method in class org.apache.lucene.search.similarities.LMSimilarity.DefaultCollectionModel
-
- getName() - Method in class org.apache.lucene.search.similarities.LMSimilarity
-
Returns the name of the LM method.
- getName() - Method in class org.apache.lucene.spatial.query.SpatialOperation
-
- getName() - Method in class org.apache.lucene.store.CorruptingIndexOutput
-
- getName() - Method in class org.apache.lucene.store.IndexOutput
-
Returns the name used to create this IndexOutput
.
- getName() - Method in interface org.apache.lucene.util.NamedSPILoader.NamedSPI
-
- getNameCount() - Method in class org.apache.lucene.mockfile.FilterPath
-
- getNames() - Method in class org.apache.lucene.benchmark.quality.QualityQuery
-
Return all the names of name-value-pairs in this QualityQuery.
- getNearestSetSize(int) - Static method in class org.apache.lucene.codecs.bloom.FuzzySet
-
Rounds down required maxNumberOfBits to the nearest number that is made up
of all ones as a binary number.
- getNearestSetSize(int, float) - Static method in class org.apache.lucene.codecs.bloom.FuzzySet
-
Use this method to choose a set size where accuracy (low content saturation) is more important
than deciding how much memory to throw at the problem.
- getNext() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
Returns the next TermInfo at this same position.
- getNextDelGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the next available generation number
of the live docs file.
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentSource
-
Returns the next
DocData
from the content source.
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource
-
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.EnwikiContentSource
-
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource
-
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishContentSource
-
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.ReutersContentSource
-
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.SingleDocSource
-
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.SortableSingleDocSource
-
- getNextDocData(DocData) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- getNextDocValuesGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the next available generation number of the DocValues files.
- getNextFacets(List<FacetField>) - Method in class org.apache.lucene.benchmark.byTask.feeds.FacetSource
-
Fills the next facets content items in the given list.
- getNextFacets(List<FacetField>) - Method in class org.apache.lucene.benchmark.byTask.feeds.RandomFacetSource
-
- getNextFieldInfosGen() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the next available generation number of the FieldInfos files.
- getNextLevelCells(Shape) - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Gets the cells at the next grid cell level underneath this one, optionally filtered by
shapeFilter
.
- getNextLevelCells(Shape) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- getNextLevelCells(Shape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getNextMerge() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: the
MergeScheduler
calls this method to retrieve the next
merge requested by the MergePolicy
- getNextOrdinal() - Method in class org.apache.lucene.facet.taxonomy.writercache.LabelToOrdinal
-
Returns the next unassigned ordinal.
- 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 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.classic.QueryParser
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryparser.classic.QueryParserTokenManager
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
Get the next Token.
- getNextToken() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParserTokenManager
-
Get the next Token.
- getNextTransition(Transition) - Method in class org.apache.lucene.util.automaton.Automaton
-
Iterate to the next transition after the provided one
- getNoCFSRatio() - Method in class org.apache.lucene.index.FilterMergePolicy
-
- getNoCFSRatio() - Method in class org.apache.lucene.index.MergePolicy
-
Returns current noCFSRatio
.
- getNoCFSRatio() - Method in class org.apache.lucene.index.NoMergePolicy
-
- getNode(CharSequence) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the node indexed by key, or null
if that node doesn't
exist.
- getNode(CharSequence, JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the node indexed by key, or null
if that node doesn't
exist.
- getNodeCount() - Method in class org.apache.lucene.util.fst.Builder
-
- getNodeID() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- getNonBlankTextOrFail(Element) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getNonFuzzyPrefix() - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Get the length of a prefix where no edits are permitted
- getNoOutput() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- getNoOutput() - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- getNoOutput() - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- getNoOutput() - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- 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
-
- getNormalization() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-
Returns the second normalization
- getNormalization() - Method in class org.apache.lucene.search.similarities.IBSimilarity
-
Returns the term frequency normalization
- getNorms(FieldInfo) - Method in class org.apache.lucene.codecs.NormsProducer
-
- getNorms(FieldInfo) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsProducer
-
- getNormsReader() - Method in class org.apache.lucene.index.CodecReader
-
Expert: retrieve underlying NormsProducer
- getNormsReader() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getNormsReader() - Method in class org.apache.lucene.index.SegmentReader
-
- getNormValues(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getNormValues(String) - Method in class org.apache.lucene.index.CodecReader
-
- getNormValues(String) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getNormValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getNormValues(String) - Method in class org.apache.lucene.index.LeafReader
-
- getNormValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
-
Returns a NumericDocValues for a reader's norms (potentially merging on-the-fly).
- getNormValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getNormValues(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getNotQuery(List<SrndQuery>, Token) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getNrQueriesMade() - Method in class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- getNrSubQueries() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- getNumber() - Method in class org.apache.lucene.queries.function.valuesource.ConstNumberSource
-
- getNumber() - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- getNumber() - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- getNumberFormat() - Method in class org.apache.lucene.queryparser.flexible.standard.config.PointsConfig
-
Returns the NumberFormat
used to parse a String
to
Number
- getNumberFormat() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
Returns the NumberFormat
used to convert the value to String
.
- getNumberOfDocuments() - Method in class org.apache.lucene.search.similarities.BasicStats
-
Returns the number of documents.
- getNumberOfEvaluatedDocs() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
get the no.
- getNumberOfFieldTokens() - Method in class org.apache.lucene.search.similarities.BasicStats
-
Returns the total number of tokens in the field.
- getNumbers() - Method in class org.apache.lucene.search.DocValuesNumbersQuery
-
- getNumDataDimensions() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- getNumDataDimensions() - Method in class org.apache.lucene.index.PointValues
-
Returns how many data dimensions are represented in the values
- getNumDataDimensions() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- getNumDims() - Method in class org.apache.lucene.search.PointInSetQuery
-
- getNumDims() - Method in class org.apache.lucene.search.PointRangeQuery
-
- getNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
-
- getNumeric(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
-
- getNumeric(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
- getNumericDocValues(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getNumericDocValues(String) - Method in class org.apache.lucene.index.CodecReader
-
- getNumericDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getNumericDocValues(String) - Method in class org.apache.lucene.index.LeafReader
-
Returns
NumericDocValues
for this field, or
null if no numeric doc values were indexed for
this field.
- getNumericDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.DoubleFieldSource
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.FloatFieldSource
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.IntFieldSource
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedDoubleFieldSource
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedFloatFieldSource
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedIntFieldSource
-
- getNumericDocValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedLongFieldSource
-
- getNumericDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.NumericComparator
-
Retrieves the NumericDocValues for the field in this segment
- getNumericDocValues(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getNumericType() - Method in class org.apache.lucene.search.SortedNumericSortField
-
Returns the numeric type in use for this sort
- getNumericValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
-
Returns a NumericDocValues for a reader's docvalues (potentially merging on-the-fly)
- getNumGoodPoints() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the number of good points (only relevant points).
- getNumIndexDimensions() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- getNumIndexDimensions() - Method in class org.apache.lucene.index.PointValues
-
Returns how many dimensions are used for the index
- getNumIndexDimensions() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- getNumLeaves() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
Return the number of leaves below the current node.
- getNumMatches() - Method in class org.apache.lucene.search.uhighlight.Passage
-
- getNumOverlap() - Method in class org.apache.lucene.index.FieldInvertState
-
Get the number of terms with positionIncrement == 0
.
- getNumParallelTasks() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getNumPoints() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the number of points (both relevant and irrelevant points).
- getNumRuns() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getNumStates() - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
How many states this automaton has.
- getNumStates() - Method in class org.apache.lucene.util.automaton.Automaton
-
How many states this automaton has.
- getNumSubCells(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
- getNumSubCells(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
Returns the number of sub-cells beneath the given UnitNRShape.
- getNumSubs() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
How many sub-readers we are merging.
- getNumTokens() - Method in class org.apache.lucene.search.highlight.TokenGroup
-
- getNumTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
-
How many transitions this automaton has.
- getNumTransitions(int) - Method in class org.apache.lucene.util.automaton.Automaton
-
How many transitions this state has.
- getOccur() - Method in class org.apache.lucene.search.BooleanClause
-
- getOffset() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
-
Returns the data offset in the internal buffer.
- getOffset() - Method in class org.apache.lucene.analysis.ja.Token
-
- getOffset() - Method in class org.apache.lucene.analysis.ko.Token
-
- getOffset() - Method in class org.apache.lucene.index.FieldInvertState
-
Get end offset of the last processed term.
- getOffsetGap(String) - Method in class org.apache.lucene.analysis.Analyzer
-
- getOffsetGap(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
- getOffsetGap(String) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
- getOffsetGap(String) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
Get the offset gap between tokens in fields if several fields with the same name were added.
- getOffsetsEnum(LeafReader, int, String) - Method in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
The primary method -- return offsets for highlightable words in the specified document.
- getOffsetsEnum(LeafReader, int, String) - Method in class org.apache.lucene.search.uhighlight.MemoryIndexOffsetStrategy
-
- getOffsetsEnum(LeafReader, int, String) - Method in class org.apache.lucene.search.uhighlight.NoOpOffsetStrategy
-
- getOffsetsEnum(LeafReader, int, String) - Method in class org.apache.lucene.search.uhighlight.PostingsOffsetStrategy
-
- getOffsetsEnum(LeafReader, int, String) - Method in class org.apache.lucene.search.uhighlight.PostingsWithTermVectorsOffsetStrategy
-
- getOffsetsEnum(LeafReader, int, String) - Method in class org.apache.lucene.search.uhighlight.TermVectorOffsetStrategy
-
- getOffsetsEnum(LeafReader, int, String) - Method in class org.apache.lucene.search.uhighlight.TokenStreamOffsetStrategy
-
- getOffsetSource() - Method in class org.apache.lucene.search.uhighlight.AnalysisOffsetStrategy
-
- getOffsetSource() - Method in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- getOffsetSource() - Method in class org.apache.lucene.search.uhighlight.FieldOffsetStrategy
-
- getOffsetSource() - Method in class org.apache.lucene.search.uhighlight.NoOpOffsetStrategy
-
- getOffsetSource() - Method in class org.apache.lucene.search.uhighlight.PostingsOffsetStrategy
-
- getOffsetSource() - Method in class org.apache.lucene.search.uhighlight.PostingsWithTermVectorsOffsetStrategy
-
- getOffsetSource() - Method in class org.apache.lucene.search.uhighlight.TermVectorOffsetStrategy
-
- getOffsetSource(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Determine the offset source for the specified field.
- getOffsetStrategy(UnifiedHighlighter.OffsetSource, UHComponents) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getOnlyLeafReader(IndexReader) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Some tests expect the directory to contain a single segment, and want to
do tests on that segment's reader.
- getOpDistance(String) - Static method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getOpDistance() - Method in class org.apache.lucene.queryparser.surround.query.DistanceQuery
-
- getOpenDeletedFiles() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- getOpenMode() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getOpenMode() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getOperation() - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
- getOperatorName() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- getOptimizedOffsetSource(String, BytesRef[], PhraseHelper, CharacterRunAutomaton[]) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getOrCreateNode(CharSequence) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the node indexed by key, creating that node if it doesn't exist,
and creating any required intermediate nodes if they don't exist.
- getOrd(int) - Method in class org.apache.lucene.index.LegacySortedDocValues
-
Deprecated.
Returns the ordinal for the specified docID.
- getOrdForDoc(int) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- getOrdinal(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- getOrdinal(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Returns the ordinal of the category given as a path.
- getOrdinal(String, String[]) - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Returns ordinal for the dim + path.
- getOrdinal(FacetLabel) - Method in class org.apache.lucene.facet.taxonomy.writercache.LabelToOrdinal
-
- getOrdinalsReader(String) - Method in class org.apache.lucene.facet.taxonomy.OrdinalMappingLeafReader
-
Expert: override in case you used custom encoding for the categories under
this field.
- getOrdRange(String) - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
- getOrdRange(String) - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState
-
- getOriginalArgs() - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getOriginalMatchingDocs() - Method in class org.apache.lucene.facet.RandomSamplingFacetsCollector
-
Returns the original matching documents.
- getOriginalMessage() - Method in exception org.apache.lucene.index.CorruptIndexException
-
Returns the original exception message without the corrupted file description.
- getOriginalString() - Method in class org.apache.lucene.util.automaton.RegExp
-
The string that was used to construct the regex.
- getOrQuery(List<SrndQuery>, boolean, Token) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getOutOf() - Method in class org.apache.lucene.benchmark.byTask.stats.Report
-
Returns total number of stats points when this report was created.
- getPackedPoints() - Method in class org.apache.lucene.search.PointInSetQuery
-
- getPackedValueSlice(int, BytesRef) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
Returns a reference, in result
, to the byte[] slice holding this value
- getParallelReaders() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getParallelTaxonomyArrays() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- getParallelTaxonomyArrays() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
- getParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getParent() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- getParent(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- getParent(int) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyWriter
-
getParent() returns the ordinal of the parent category of the category
with the given ordinal.
- getParent() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
Returns the FilterFileSystemProvider
sent to this on init.
- getParent() - Method in class org.apache.lucene.mockfile.FilterPath
-
- getParent() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
- getParent() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- getParentQuery() - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
-
Return our parent query.
- getPartOfSpeech(int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getPartOfSpeech(int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get Part-Of-Speech of tokens
- getPartOfSpeech(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getPartOfSpeech() - Method in class org.apache.lucene.analysis.ja.Token
-
- getPartOfSpeech() - Method in interface org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttribute
-
- getPartOfSpeech() - Method in class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
-
- getPath(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- getPath(int) - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Returns the path name of the category with the given ordinal.
- getPath(String, String...) - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- getPath(URI) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- getPathElement(int) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
Returns the a specific QueryText element
- getPathElements() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
Returns the a List with all QueryText elements
- getPathElements(int) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
Returns a List QueryText element from position startIndex
- getPathMatcher(String) - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- getPattern(String) - Static method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- getPattern(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
Compiles a pattern for the value of the specified argument key name
- getPauseTimes() - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
-
Returns pause reasons and associated times in nanoseconds.
- getPayload() - Method in class org.apache.lucene.analysis.Token
-
Returns this Token's payload.
- getPayload() - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
-
Returns this Token's payload.
- getPayload() - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
- getPayload() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- getPayload() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- getPayload() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- getPayload() - Method in class org.apache.lucene.index.PostingsEnum
-
Returns the payload at this position, or null if no
payload was indexed.
- getPayload() - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- getPayloads() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- getPayloads() - Method in class org.apache.lucene.payloads.PayloadSpanCollector
-
- getPayloadsForQuery(Query) - Method in class org.apache.lucene.payloads.PayloadSpanUtil
-
Query should be rewritten for wild/fuzzy support.
- getPendingDeletions() - Method in class org.apache.lucene.store.Directory
-
Returns a set of files currently pending deletion in this directory.
- getPendingDeletions() - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- getPendingDeletions() - Method in class org.apache.lucene.store.FilterDirectory
-
- getPendingDeletions() - Method in class org.apache.lucene.store.FSDirectory
-
- getPercentTermsToMatch() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getPerfObject(String) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getPhraseHelper() - Method in class org.apache.lucene.search.uhighlight.UHComponents
-
- getPhraseHelper(String, Query, Set<UnifiedHighlighter.HighlightFlag>) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getPhraseLimit() - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
- getPhraseList() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList
-
return the list of WeightedPhraseInfo.
- getPhraseSlop() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Gets the default slop for phrases.
- getPhraseSlop() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Gets the default slop for phrases.
- getPhraseSlop() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Gets the default slop for phrases.
- getPlanetModel() - Method in class org.apache.lucene.spatial3d.geom.BasePlanetObject
-
- getPlanetModel() - Method in interface org.apache.lucene.spatial3d.geom.PlanetObject
-
Returns the
PlanetModel
provided when this shape was created.
- getPointCount() - Method in class org.apache.lucene.util.bkd.BKDWriter
-
How many points have been added so far
- getPointCountSeen() - Method in class org.apache.lucene.index.CheckIndex.VerifyPointsVisitor
-
Returns total number of points in this BKD tree
- getPointDataDimensionCount() - Method in class org.apache.lucene.index.FieldInfo
-
Return point data dimension count
- getPointer() - Method in class org.apache.lucene.util.PagedBytes
-
- getPointIndexDimensionCount() - Method in class org.apache.lucene.index.FieldInfo
-
Return point data dimension count
- getPointNumBytes() - Method in class org.apache.lucene.index.FieldInfo
-
Return number of bytes per dimension
- getPoints() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getPointsConfig() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointRangeQueryNode
-
Returns the
PointsConfig
associated with the lower and upper bounds.
- getPointsConfigMap() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getPointsReader() - Method in class org.apache.lucene.index.CodecReader
-
Expert: retrieve underlying PointsReader
- getPointsReader() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getPointsReader() - Method in class org.apache.lucene.index.SegmentReader
-
- getPointValues(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getPointValues(String) - Method in class org.apache.lucene.index.CodecReader
-
- getPointValues(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
-
- getPointValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getPointValues(String) - Method in class org.apache.lucene.index.LeafReader
-
Returns the
PointValues
used for numeric or
spatial searches for the given field, or null if there
are no point fields.
- getPointValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getPointValues(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getPolyLat(int) - Method in class org.apache.lucene.geo.Polygon
-
Returns latitude value at given index
- getPolyLats() - Method in class org.apache.lucene.geo.Polygon
-
Returns a copy of the internal latitude array
- getPolyLon(int) - Method in class org.apache.lucene.geo.Polygon
-
Returns longitude value at given index
- getPolyLons() - Method in class org.apache.lucene.geo.Polygon
-
Returns a copy of the internal longitude array
- getPosition() - Method in class org.apache.lucene.analysis.ja.Token
-
Get index of this token in input text
- getPosition() - Method in class org.apache.lucene.index.FieldInvertState
-
Get the last processed term position.
- getPosition() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
- 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.store.GrowableByteArrayDataOutput
-
- getPosition() - Method in class org.apache.lucene.util.fst.FST.BytesReader
-
Get current read position.
- getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-
Returns the current byte position.
- getPosition() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
-
Return the current byte position.
- getPositionIncrement() - Method in class org.apache.lucene.analysis.ko.Token
-
- getPositionIncrement() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Returns the position increment of this Token.
- getPositionIncrement() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
-
Returns the position increment of this Token.
- getPositionIncrement() - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-
- getPositionIncrement() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.Analyzer
-
Invoked before indexing a IndexableField instance if
terms have already been added to that field.
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
- getPositionIncrementGap(String) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
- getPositionLength() - Method in class org.apache.lucene.analysis.ja.Token
-
Get the length (in tokens) of this token.
- getPositionLength() - Method in class org.apache.lucene.analysis.ko.Token
-
- getPositionLength() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Returns the position length of this Token.
- getPositionLength() - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
-
Returns the position length of this Token.
- getPositionLength() - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-
- getPositions() - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Returns the relative positions of terms in this phrase.
- getPositions() - Method in class org.apache.lucene.search.NGramPhraseQuery
-
Return the list of relative positions that each term should appear at.
- getPositions() - Method in class org.apache.lucene.search.PhraseQuery
-
Returns the relative positions of terms in this phrase.
- getPositionsIncrements() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- getPositionSpans() - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
-
- getPostings() - Method in class org.apache.lucene.search.spans.TermSpans
-
- getPostingsEnum() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfPostings
-
- getPostingsFormat(String) - Static method in class org.apache.lucene.util.TestUtil
-
- getPostingsFormat(Codec, String) - Static method in class org.apache.lucene.util.TestUtil
-
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
Returns the postings format that should be used for writing
new segments of field
.
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
Returns the postings format that should be used for writing
new segments of field
.
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
Returns the postings format that should be used for writing
new segments of field
.
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
Returns the postings format that should be used for writing
new segments of field
.
- getPostingsFormatForField(String) - Method in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-
Returns the postings format that should be used for writing
new segments of field
.
- getPostingsFormatForField(String) - Method in class org.apache.lucene.index.RandomCodec
-
- getPostingsFormatWithOrds(Random) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a random postings format that supports term ordinals
- getPostingsReader() - Method in class org.apache.lucene.index.CodecReader
-
Expert: retrieve underlying FieldsProducer
- getPostingsReader() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getPostingsReader() - Method in class org.apache.lucene.index.SegmentReader
-
- getPOSTranslation(String) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
-
Get the english form of a POS tag
- getPostTag(int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getPostTag(String[], int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getPOSType() - Method in class org.apache.lucene.analysis.ko.DecompoundToken
-
- getPOSType(int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getPOSType(int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get the
POS.Type
of specified word (morpheme, compound, inflect or pre-analysis)
- getPOSType(int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getPOSType() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
- getPOSType() - Method in class org.apache.lucene.analysis.ko.Token
-
- getPOSType() - Method in interface org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttribute
-
- getPOSType() - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- getPrecision(String) - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
calculate precision on the given class
- getPrecision() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
- getPrecisionAt(int) - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Return the precision at rank n:
|{relevant hits within first n
hits}| / n
.
- getPrefix() - Method in class org.apache.lucene.queryparser.surround.query.SrndPrefixQuery
-
- getPrefix() - Method in class org.apache.lucene.search.PrefixQuery
-
Returns the prefix of this query.
- getPrefixGridScanLevel() - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- getPrefixLength() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- getPrefixLength() - Method in class org.apache.lucene.queryparser.flexible.standard.config.FuzzyConfig
-
- 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.classic.MultiFieldQueryParser
-
- getPrefixQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getPrefixQuery(String, boolean) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getPrefixSeparator() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- getPrefixToOrdRange() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
- getPrefixToOrdRange() - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState
-
- getPreload() - Method in class org.apache.lucene.store.MMapDirectory
-
Returns true
if mapped pages should be loaded.
- getPreTag(int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getPreTag(String[], int) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getPrimaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
-
Return the primary directory
- getPrimaryGen() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
Returns the current primary generation, which is incremented each time a new primary is started for this index
- getPronunciation(int, char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getPronunciation(int, char[], int, int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get pronunciation of tokens
- getPronunciation(int, char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getPronunciation() - Method in class org.apache.lucene.analysis.ja.Token
-
- getPronunciation() - Method in interface org.apache.lucene.analysis.ja.tokenattributes.ReadingAttribute
-
- getPronunciation() - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
-
- getProps() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- getProtectedTerms() - Method in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- getProximityType() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- getQuery(Query, DoubleValuesSource) - Method in class org.apache.lucene.facet.range.DoubleRange
-
Create a Query that matches documents in this range
The query will check all documents that match the provided match query,
or every document in the index if the match query is null.
- getQuery(Query, LongValuesSource) - Method in class org.apache.lucene.facet.range.LongRange
-
Create a Query that matches documents in this range
The query will check all documents that match the provided match query,
or every document in the index if the match query is null.
- getQuery() - Method in class org.apache.lucene.queries.function.BoostedQuery
-
Deprecated.
- getQuery() - Method in class org.apache.lucene.queries.function.valuesource.QueryValueSource
-
- getQuery() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.BooleanQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.BoostingQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.ConstantScoreQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.DisjunctionMaxQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.FuzzyLikeThisQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.LikeThisQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.MatchAllDocsQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.PointRangeQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.RangeQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanBuilderBase
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanQueryBuilderFactory
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.TermQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.TermsQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.UserInputQueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
- getQuery(Element) - Method in interface org.apache.lucene.queryparser.xml.QueryBuilder
-
- getQuery(Element) - Method in class org.apache.lucene.queryparser.xml.QueryBuilderFactory
-
- getQuery() - Method in class org.apache.lucene.search.BooleanClause
-
- getQuery() - Method in class org.apache.lucene.search.BoostQuery
-
Return the wrapped
Query
.
- getQuery() - Method in class org.apache.lucene.search.ConstantScoreQuery
-
Returns the encapsulated query.
- getQuery() - Method in class org.apache.lucene.search.FilterMatchesIterator
-
- getQuery() - Method in class org.apache.lucene.search.join.QueryBitSetProducer
-
Gets the contained query.
- getQuery() - Method in interface org.apache.lucene.search.MatchesIterator
-
- getQuery() - Method in class org.apache.lucene.search.spans.SpanBoostQuery
-
- getQuery() - Method in class org.apache.lucene.search.uhighlight.UHComponents
-
- getQuery() - Method in class org.apache.lucene.search.Weight
-
The query that this concerns.
- getQueryBuilder() - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
Returns the query builder used to build a object from the query node tree.
- getQueryBuilder(String) - Method in class org.apache.lucene.queryparser.xml.QueryBuilderFactory
-
- getQueryCache() - Method in class org.apache.lucene.search.IndexSearcher
-
- getQueryCachingPolicy() - Method in class org.apache.lucene.search.IndexSearcher
-
- getQueryConfigHandler() - Method in interface org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessor
-
Returns the
QueryConfigHandler
associated to the query tree if any,
otherwise it returns
null
- getQueryConfigHandler() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorImpl
-
- getQueryConfigHandler() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- getQueryConfigHandler() - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
Returns the query configuration handler, which is used during the query
node tree processing.
- getQueryConfigHandler() - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- getQueryID() - Method in class org.apache.lucene.benchmark.quality.QualityQuery
-
Return the ID of this query.
- getQueryMaker(ReadTask) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getQueryMaker() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Return query maker used for this task.
- getQueryMaker() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTask
-
- getQueryMaker() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
-
- getQueryMaker() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
-
- getQueryMaker() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
-
- getQueryMaker() - Method in class org.apache.lucene.benchmark.byTask.tasks.WarmTask
-
- getQueryNodeProcessor() - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
Returns the processor object used to process the query node tree, it
returns null
if no processor is used.
- getQuote() - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- getRadius() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dCircleShape
-
- getRadius() - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- getRadius() - Method in interface org.apache.lucene.spatial3d.geom.GeoSizeable
-
Returns the radius of a circle into which the GeoSizeable area can
be inscribed.
- getRAMBufferSizeMB() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getRAMBufferSizeMB() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getRAMPerThreadHardLimitMB() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getRAMPerThreadHardLimitMB() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the max amount of memory each DocumentsWriterPerThread
can
consume until forcefully flushed.
- getRandom() - Method in class org.apache.lucene.search.AssertingQuery
-
- getRandomAcceptedString(Random) - Method in class org.apache.lucene.util.automaton.AutomatonTestUtil.RandomAcceptedStrings
-
- getRandomAccessQuery() - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
-
Return the wrapped query that may be slow at identifying all matching
documents, but which is cheap to initialize and can efficiently
verify that some documents match.
- getRandomIOExceptionRate() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- getRandomIOExceptionRateOnOpen() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- getRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
- getRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- getRangeScorer(LeafReaderContext, String, String, boolean, boolean) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- getRangeScorer(LeafReaderContext, String, String, boolean, boolean) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- getRangeScorer(LeafReaderContext, String, String, boolean, boolean) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- getRangeScorer(LeafReaderContext, String, String, boolean, boolean) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- getRangeScorer(LeafReaderContext, String, String, boolean, boolean) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- getRank() - Method in class org.apache.lucene.benchmark.quality.QualityStats.RecallPoint
-
Returns the rank: where on the list of returned docs this relevant doc appeared.
- getRate() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
Returns the rate per minute: how many operations should be performed in a minute.
- getRawQueryString() - Method in class org.apache.lucene.queryparser.ext.ExtensionQuery
-
Returns the raw extension query string
- getReader() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
- getReader() - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState
-
Returns top-level index reader.
- getReader(LeafReaderContext) - Method in class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader
-
- getReader(LeafReaderContext) - Method in class org.apache.lucene.facet.taxonomy.DocValuesOrdinalsReader
-
- getReader(LeafReaderContext) - Method in class org.apache.lucene.facet.taxonomy.OrdinalsReader
-
Set current atomic reader.
- getReader() - Method in class org.apache.lucene.index.RandomIndexWriter
-
- getReader(boolean, boolean) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- getReader(long, long) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- getReader(long, long) - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- getReader(long, long) - Method in interface org.apache.lucene.util.bkd.PointWriter
-
Returns a
PointReader
iterator to step through all previously added points
- getReader(ChecksumIndexInput, String) - Method in class org.apache.lucene.util.OfflineSorter
-
Subclasses can override to change how byte sequences are read from disk.
- getReader(DataInput) - Static method in class org.apache.lucene.util.packed.PackedInts
-
- getReaderCacheHelper() - Method in class org.apache.lucene.facet.taxonomy.OrdinalMappingLeafReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.AllDeletedFilterReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.AssertingDirectoryReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.ExitableDirectoryReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.IndexReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.MismatchedDirectoryReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.MismatchedLeafReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.MultiReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.OwnCacheKeyMultiReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.ParallelCompositeReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.SegmentReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.SoftDeletesDirectoryReaderWrapper
-
- getReaderCacheHelper() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getReaderCacheHelper() - Method in class org.apache.lucene.search.uhighlight.OverlaySingleDocTermsLeafReader
-
- getReaderIterator(DataInput, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
- getReaderIteratorNoHeader(DataInput, PackedInts.Format, int, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
- getReaderNoHeader(DataInput, PackedInts.Format, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Expert: Restore a
PackedInts.Reader
from a stream without reading metadata at
the beginning of the stream.
- getReaderPooling() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getReaderPooling() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getReading(int, char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getReading(int, char[], int, int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get reading of tokens
- getReading(int, char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.UnknownDictionary
-
- getReading(int, char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getReading() - Method in class org.apache.lucene.analysis.ja.Token
-
- getReading() - Method in interface org.apache.lucene.analysis.ja.tokenattributes.ReadingAttribute
-
- getReading() - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
-
- getReading() - Method in class org.apache.lucene.analysis.ko.DecompoundToken
-
- getReading(int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getReading(int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get the reading of specified word (mainly used for Hanja to Hangul conversion).
- getReading(int) - Method in class org.apache.lucene.analysis.ko.dict.UnknownDictionary
-
- getReading(int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getReading() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
- getReading() - Method in class org.apache.lucene.analysis.ko.Token
-
Get the reading of the token.
- getReading() - Method in interface org.apache.lucene.analysis.ko.tokenattributes.ReadingAttribute
-
Get the reading of the token.
- getReading() - Method in class org.apache.lucene.analysis.ko.tokenattributes.ReadingAttributeImpl
-
- getReason() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
-
Returns an optional reason for this exception if the version information was not available.
- getRecall() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Return the recall: |{relevant hits found}| / |{relevant hits existing}|.
- getRecall() - Method in class org.apache.lucene.benchmark.quality.QualityStats.RecallPoint
-
Returns the recall: how many relevant docs were returned up to this point, inclusive.
- getRecall(String) - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
calculate recall on the given class
- getRecall() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
- getRecallPoints() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the recallPoints.
- getRecomputedActualSizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Like getRecomputedSizeInBytes(), but, uses actual file
lengths rather than buffer allocations (which are
quantized up to nearest
RAMOutputStream.BUFFER_SIZE (now 1024) bytes.
- getRecomputedSizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Provided for testing purposes.
- getRef(Character) - Method in class org.egothor.stemmer.Row
-
Return the reference to the next Row in the Cell associated with the given
Character.
- getRefCount(SearcherTaxonomyManager.SearcherAndTaxonomy) - Method in class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
- getRefCount() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Returns the current refCount for this taxonomy reader.
- getRefCount() - Method in class org.apache.lucene.index.IndexReader
-
Expert: returns the current refCount for this reader
- getRefCount(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-
- getRefCount(G) - Method in class org.apache.lucene.search.ReferenceManager
-
Returns the current reference count of the given reference.
- getRefCount(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
-
- getRefCount() - Method in class org.apache.lucene.util.RefCount
-
Returns the current reference count.
- getRegexp() - Method in class org.apache.lucene.search.RegexpQuery
-
Returns the regexp of this query wrapped in a Term.
- getRegExp() - Method in exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
-
Return the RegExp that caused this exception if any.
- getRegexpQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
- getRegexpQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Factory method for generating a query.
- getRelationship(GeoShape) - Method in interface org.apache.lucene.spatial3d.geom.GeoArea
-
Find the spatial relationship between a shape and the current geo area.
- getRelationship(GeoShape) - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- getRepetitions() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- getReported() - Method in class org.apache.lucene.benchmark.byTask.stats.Report
-
Returns number of stats points represented in this report.
- getRequiredPostings() - Method in enum org.apache.lucene.search.spans.SpanWeight.Postings
-
- getRescorer(Bindings) - Method in class org.apache.lucene.expressions.Expression
-
Get a
Rescorer
, to rescore first-pass hits
using this expression.
- getResolution() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
Return the timer resolution.
- getResource(String) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getResource(String) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getResourceDescription() - Method in exception org.apache.lucene.index.CorruptIndexException
-
Returns a description of the file that was corrupted
- getResourceDescription() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
-
Returns a description of the file that was too new
- getResourceDescription() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
-
Returns a description of the file that was too old
- getResults() - Method in class org.apache.lucene.search.suggest.Lookup.LookupPriorityQueue
-
Returns the top N results in descending order.
- getReusableComponents(Analyzer, String) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
-
Gets the reusable TokenStreamComponents for the field with the given name.
- getReuseStrategy() - Method in class org.apache.lucene.analysis.Analyzer
-
- getReverse() - Method in class org.apache.lucene.search.SortField
-
Returns whether the sort should be reversed.
- getReverseMul() - Method in class org.apache.lucene.search.FieldValueHitQueue
-
- getRewriteMethod() - Method in class org.apache.lucene.search.MultiTermQuery
-
- getRewriteMethod() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
Expert: returns the rewriteMethod
- getRightId(int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getRightId(int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get right id of specified word
- getRightId(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getRightId(int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getRightId(int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get right id of specified word
- getRightId(int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getRightLongitude() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Get right longitude, if any.
- getRightPOS() - Method in class org.apache.lucene.analysis.ko.DecompoundToken
-
- getRightPOS(int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getRightPOS(int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get the right
POS.Tag
of specfied word.
- getRightPOS(int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getRightPOS() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
- getRightPOS() - Method in class org.apache.lucene.analysis.ko.Token
-
Get the right part of speech of the token.
- getRightPOS() - Method in interface org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttribute
-
Get the right part of speech of the token.
- getRightPOS() - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- getRomanization(String) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
-
Romanize katakana with modified hepburn
- getRomanization(Appendable, CharSequence) - Static method in class org.apache.lucene.analysis.ja.util.ToStringUtil
-
Romanize katakana with modified hepburn
- getRoot() - Method in class org.apache.lucene.mockfile.FilterPath
-
- getRootDirectories() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- getRound() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getRoundNumber() - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
- getRunData() - Method in class org.apache.lucene.benchmark.byTask.Benchmark
-
- getRunData() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getRunInBackground() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- getSampleIntersectionPoint(PlanetModel, Plane) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Find a sample point on the intersection between two planes and the world.
- getSamplingRate() - Method in class org.apache.lucene.facet.RandomSamplingFacetsCollector
-
Returns the sampling rate that was used.
- getSaturation() - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- getSchema() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.OpaqueQueryNode
-
- getScheme() - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- getScore() - Method in class org.apache.lucene.classification.ClassificationResult
-
retrieve the result score
- getScore() - Method in class org.apache.lucene.search.highlight.TextFragment
-
- getScore(int) - Method in class org.apache.lucene.search.highlight.TokenGroup
-
- getScore() - Method in class org.apache.lucene.search.uhighlight.Passage
-
Passage's score.
- getScorer(LeafReaderContext) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- getScorer(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- getScoringQueries() - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
The scoring queries that only affect the score of CustomScoreQuery.
- getSearcher(SearcherFactory, IndexReader, IndexReader) - Static method in class org.apache.lucene.search.SearcherManager
-
- getSearcherManager() - Method in class org.apache.lucene.replicator.nrt.Node
-
- getSearchingGen() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
-
Returns which generation
the current searcher is guaranteed to include.
- getSearchTime() - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Returns the search time in milliseconds for the measured query.
- getSecondaryDir() - Method in class org.apache.lucene.store.FileSwitchDirectory
-
Return the secondary directory
- getSeedPostings(String, long, IndexOptions, boolean) - Static method in class org.apache.lucene.index.RandomPostingsTester
-
- getSegmentCount() - Method in class org.apache.lucene.index.IndexCommit
-
Returns number of segments referenced by this commit.
- getSegmentInfo() - Method in class org.apache.lucene.index.SegmentReader
-
Return the SegmentInfoPerCommit of the segment this reader is reading.
- getSegmentInfos() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- getSegmentName() - Method in class org.apache.lucene.index.SegmentReader
-
Return the name of the segment this reader is reading.
- getSegmentsFile(List<String>, boolean) - Static method in class org.apache.lucene.replicator.IndexReplicationHandler
-
Verifies that the last file is segments_N and fails otherwise.
- getSegmentsFileName() - Method in class org.apache.lucene.index.IndexCommit
-
Get the segments file (segments_N
) associated
with this commit point.
- getSegmentsFileName() - Method in class org.apache.lucene.index.SegmentInfos
-
Get the segments_N filename in use by this segment infos.
- getSegmentsPerTier() - Method in class org.apache.lucene.index.TieredMergePolicy
-
Returns the current segmentsPerTier setting.
- getSelector() - Method in class org.apache.lucene.search.SortedNumericSortField
-
Returns the selector in use for this sort
- getSelector() - Method in class org.apache.lucene.search.SortedSetSortField
-
Returns the selector in use for this sort
- getSeparator() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- getSeqnum() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
-
- getSeqnum() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- getSequentialSubReaders() - Method in class org.apache.lucene.index.BaseCompositeReader
-
- getSequentialSubReaders() - Method in class org.apache.lucene.index.CompositeReader
-
Expert: returns the sequential sub readers that this
reader is logically composed of.
- getSet(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
Returns whitespace- and/or comma-separated set of values, or null if none are found
- getSetForField(SegmentWriteState, FieldInfo) - Method in class org.apache.lucene.codecs.bloom.BloomFilterFactory
-
- getSetForField(SegmentWriteState, FieldInfo) - Method in class org.apache.lucene.codecs.bloom.DefaultBloomFilterFactory
-
- getShape() - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Gets the shape for this cell; typically a Rectangle.
- getShape() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getShape() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- getShape() - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
- getShape(int) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
Get shape at index
- getShapeAtLevel(int) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getShapeAtLevel(int) - Method in interface org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.UnitNRShape
-
Gets an ancestor at the specified level.
- getShapeRel() - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Gets the relationship this cell has with the shape from which it was filtered from, assuming it came from a
CellIterator
.
- getShapeRel() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- getShapeRel() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getShapes(int) - Method in class org.apache.lucene.spatial.util.ShapeFieldCache
-
- getSharedReader(long, long, List<Closeable>) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- getSharedReader(long, long, List<Closeable>) - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- getSharedReader(long, long, List<Closeable>) - Method in interface org.apache.lucene.util.bkd.PointWriter
-
Returns the single shared reader, used at multiple times during the recursion, to read previously added points
- getShortName() - Method in interface org.apache.lucene.analysis.icu.tokenattributes.ScriptAttribute
-
Get the abbreviated name.
- getShortName() - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
- getSiblings() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
Returns int[] mapping each ordinal to its next sibling; this is a large array and
is computed (and then saved) the first time this method is invoked.
- getSimilarity() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- getSimilarity() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- getSimilarity() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
- getSimilarity() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- getSimilarity(boolean) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Get the
Similarity
to use to compute scores.
- getSimScorer(LeafReaderContext) - Method in class org.apache.lucene.search.spans.AssertingSpanWeight
-
- getSimScorer(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanWeight
-
Return a SimScorer for this context
- getSingleton(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
If this automaton accepts a single input, return it.
- getSingleton() - Static method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- getSingleton() - Static method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- getSingleton() - Static method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- getSingleton() - Static method in class org.apache.lucene.util.fst.NoOutputs
-
- getSingleton() - Static method in class org.apache.lucene.util.fst.PositiveIntOutputs
-
- getSingleton(boolean) - Static method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
-
- getSize() - Method in class org.apache.lucene.benchmark.byTask.stats.Report
-
Returns number of lines in the report.
- getSize() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
Number of unique labels.
- getSize() - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState
-
Number of unique labels.
- getSize() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- getSize() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- getSize() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Returns the number of categories in the taxonomy.
- getSize() - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyWriter
-
getSize() returns the number of categories in the taxonomy.
- getSize() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
-
return the maximum priority queue size
- getSize() - Method in class org.apache.lucene.search.TopTermsRewrite
-
return the maximum priority queue size
- getSize() - Method in class org.apache.lucene.util.automaton.RunAutomaton
-
Returns number of states in automaton.
- getSlices() - Method in class org.apache.lucene.search.IndexSearcher
-
Returns the leaf slices used for concurrent searching, or null if no ExecutorService
was
passed to the constructor.
- 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
-
- getSlop() - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
Return the maximum number of intervening unmatched positions permitted.
- getSlop() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
-
- getSlot(int) - Method in class org.apache.lucene.util.SentinelIntSet
-
(internal) Returns the slot for this key
- getSnapshotCount() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Returns the total number of snapshots currently held.
- getSnapshots() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Returns all IndexCommits held by at least one snapshot.
- getSnowballWordSet(ResourceLoader, String, boolean) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- getSnowballWordSet(Reader, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
-
Reads stopwords from a stopword list in Snowball format.
- getSnowballWordSet(Reader) - Static method in class org.apache.lucene.analysis.WordlistLoader
-
Reads stopwords from a stopword list in Snowball format.
- getSoftDelCount() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns the number of only soft-deleted docs.
- getSoftDeletesField() - Method in class org.apache.lucene.index.FieldInfos
-
Returns the soft-deletes field name if exists; otherwise returns null
- getSoftDeletesField() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns the soft deletes field or null
if soft-deletes are disabled.
- getSort() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
- getSort() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
-
- getSort() - Method in class org.apache.lucene.index.LeafMetaData
-
Return the order in which documents from this index are sorted, or
null
if documents are in no particular order.
- getSort() - Method in class org.apache.lucene.search.Sort
-
Representation of the sort criteria.
- getSorted(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
-
- getSorted(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
-
- getSorted(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
- getSortedDocValues(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getSortedDocValues(String) - Method in class org.apache.lucene.index.CodecReader
-
- getSortedDocValues(String) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getSortedDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getSortedDocValues(String) - Method in class org.apache.lucene.index.LeafReader
-
- getSortedDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getSortedDocValues(LeafReaderContext, String) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
Retrieves the SortedDocValues for the field in this segment
- getSortedDocValues(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getSortedNumeric(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
-
- getSortedNumeric(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
-
- getSortedNumeric(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
- getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.CodecReader
-
- getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.LeafReader
-
- getSortedNumericDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getSortedNumericDocValues(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getSortedNumericValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
-
Returns a SortedNumericDocValues for a reader's docvalues (potentially merging on-the-fly)
- getSortedSet(FieldInfo) - Method in class org.apache.lucene.codecs.DocValuesProducer
-
- getSortedSet(LeafReader, String) - Static method in class org.apache.lucene.index.DocValues
-
- getSortedSet(FieldInfo) - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.CodecReader
-
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.LeafReader
-
- getSortedSetDocValues(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getSortedSetDocValues(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getSortedSetValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
-
Returns a SortedSetDocValues for a reader's docvalues (potentially doing extremely slow things).
- getSortedTransitions() - Method in class org.apache.lucene.util.automaton.Automaton
-
Sugar to get all transitions for all states.
- getSortedValues(IndexReader, String) - Static method in class org.apache.lucene.index.MultiDocValues
-
Returns a SortedDocValues for a reader's docvalues (potentially doing extremely slow things).
- getSortField(Bindings, boolean) - Method in class org.apache.lucene.expressions.Expression
-
Get a sort field which can be used to rank documents by this expression.
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.DoubleFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.FloatFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.ValueSource
-
EXPERIMENTAL: This method is subject to change.
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.IntFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedDoubleFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedFloatFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedIntFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.MultiValuedLongFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.queries.function.valuesource.SortedSetFieldSource
-
- getSortField(boolean) - Method in class org.apache.lucene.search.DoubleValuesSource
-
Create a sort field based on the value of this producer
- getSortField(boolean) - Method in class org.apache.lucene.search.LongValuesSource
-
Create a sort field based on the value of this producer
- getSourceFiles() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- getSourceFiles() - Method in class org.apache.lucene.replicator.IndexRevision
-
- getSourceFiles() - Method in interface org.apache.lucene.replicator.Revision
-
Returns the files that comprise this revision, as a mapping from a source
to a list of files.
- getSources() - Method in class org.apache.lucene.queries.function.valuesource.VectorValueSource
-
- getSpanNearQuery(IndexReader, String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.DistanceQuery
-
- getSpanQueries() - Method in class org.apache.lucene.search.uhighlight.PhraseHelper
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.BoostingTermBuilder
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanFirstBuilder
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanNearBuilder
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanNotBuilder
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanOrBuilder
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanOrTermsBuilder
-
- getSpanQuery(Element) - Method in interface org.apache.lucene.queryparser.xml.builders.SpanQueryBuilder
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanQueryBuilderFactory
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.builders.SpanTermBuilder
-
- getSpanQuery(Element) - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
-
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.AssertingSpanWeight
-
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanContainingQuery.SpanContainingWeight
-
Return spans from big
that contain at least one spans from little
.
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanNearQuery.SpanNearWeight
-
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanNotQuery.SpanNotWeight
-
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanOrQuery.SpanOrWeight
-
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.SpanPositionCheckWeight
-
- getSpans() - Method in class org.apache.lucene.search.spans.SpanScorer
-
return the Spans for this Scorer
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanTermQuery.SpanTermWeight
-
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanWeight
-
Expert: Return a Spans object iterating over matches from this Weight
- getSpans(LeafReaderContext, SpanWeight.Postings) - Method in class org.apache.lucene.search.spans.SpanWithinQuery.SpanWithinWeight
-
Return spans from little
that are contained in a spans from big
.
- getSparseFixedBitSetOrNull(DocIdSetIterator) - Static method in class org.apache.lucene.util.BitSetIterator
-
If the provided iterator wraps a
SparseFixedBitSet
, returns it, otherwise returns null.
- getSpatialContext() - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
- getSpatialContext() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- getSpatialContext() - Method in class org.apache.lucene.spatial.SpatialStrategy
-
- getSpatialStrategy(int) - Static method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- getSpecificValue(String, String...) - Method in class org.apache.lucene.facet.Facets
-
Return the count or value
for a specific path.
- getSpecificValue(String, String...) - Method in class org.apache.lucene.facet.LongValueFacetCounts
-
- getSpecificValue(String, String...) - Method in class org.apache.lucene.facet.MultiFacets
-
- getSpecificValue(String, String...) - Method in class org.apache.lucene.facet.sortedset.ConcurrentSortedSetDocValuesFacetCounts
-
- getSpecificValue(String, String...) - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetCounts
-
- getSpecificValue(String, String...) - Method in class org.apache.lucene.facet.taxonomy.FloatTaxonomyFacets
-
- getSpecificValue(String, String...) - Method in class org.apache.lucene.facet.taxonomy.IntTaxonomyFacets
-
- getSplitDim() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
Only valid after pushLeft or pushRight, not pop!
- getSplitDimValue() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
Only valid after pushLeft or pushRight, not pop!
- getSplitOnWhitespace() - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
- getSplitPackedValue() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- getStart() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- getStart() - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-
- getStartOffset() - Method in class org.apache.lucene.analysis.ko.Token
-
Get the start offset of the term in the analyzed text.
- getStartOffset() - Method in class org.apache.lucene.search.highlight.TokenGroup
-
- getStartOffset() - Method in class org.apache.lucene.search.uhighlight.Passage
-
Start offset of this passage.
- getStartOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
-
- getStartOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- getStartOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
-
- getStartOffset() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
- getStartOffsets() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- getStartTimeMillis() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getStaticImplementation(AttributeFactory, Class<A>) - Static method in class org.apache.lucene.util.AttributeFactory
-
Returns an AttributeFactory returning an instance of the given clazz
for the
attributes it implements.
- getStats() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
For debugging -- used by CheckIndex too
- getStats() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
- getStats() - Method in class org.apache.lucene.index.Terms
-
Expert: returns additional information about this Terms instance
for debugging purposes.
- getStemDict(Reader, CharArrayMap<String>) - Static method in class org.apache.lucene.analysis.WordlistLoader
-
Reads a stem dictionary.
- getStopTypes() - Method in class org.apache.lucene.analysis.core.TypeTokenFilterFactory
-
- getStopWords() - Method in class org.apache.lucene.analysis.core.StopFilterFactory
-
- getStopWords(String) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Provides information on which stop words have been identified for a field
- getStopWords() - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
Provides information on which stop words have been identified for all fields
- getStopWords() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Get the current stop words being used.
- getStopWords() - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- getStopWords() - Method in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilterFactory
-
Returns the configured stopword set
- getStopwordSet() - Method in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Returns the analyzer's stopword set or an empty set if the analyzer has no
stopwords
- getStoredValue(Analyzer) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
-
Returns the currently stored value.
- getStoreMergeInfo() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
- getStringDistance() - Method in class org.apache.lucene.search.spell.SpellChecker
-
- getSubCell(Point) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
Performant implementations are expected to implement this efficiently by
considering the current cell's boundary.
- getSubCell(Point) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- getSubCell(Point) - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- getSubCells() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
Gets the cells at the next grid cell level that covers this cell.
- getSubCells() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- getSubCells() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- getSubCellsSize() - Method in interface org.apache.lucene.spatial.prefix.tree.CellCanPrune
-
Returns the number of children for this cell.
- getSubCellsSize() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- getSubInfos() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
-
- getSubMatches() - Method in class org.apache.lucene.search.FilterMatchesIterator
-
- getSubMatches() - Method in interface org.apache.lucene.search.MatchesIterator
-
Returns a MatchesIterator that iterates over the positions and offsets of individual
terms within the current match
Returns
null
if there are no submatches (ie the current iterator is at the
leaf level)
Should only be called after
MatchesIterator.next()
has returned
true
- getSubQueriesIterator() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- getSubQuery() - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
The sub-query that CustomScoreQuery wraps, affecting both the score and which documents match.
- getSubQuery(int) - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- getSubs() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
Returns sub-readers we are merging.
- getSubSlices() - Method in class org.apache.lucene.index.MultiTerms
-
Expert: returns pointers to the sub-readers corresponding to the Terms being merged.
- getSubTerms() - Method in class org.apache.lucene.index.MultiTerms
-
Expert: returns the Terms being merged.
- GetSuffix(int) - Method in interface org.apache.lucene.queryparser.classic.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.classic.FastCharStream
-
- GetSuffix(int) - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.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.flexible.standard.parser.FastCharStream
-
- GetSuffix(int) - Method in interface org.apache.lucene.queryparser.surround.parser.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.surround.parser.FastCharStream
-
- getSuffixOperator() - Method in class org.apache.lucene.queryparser.surround.query.SrndPrefixQuery
-
- getSumDocFreq() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- getSumDocFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
-
- getSumDocFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
- getSumDocFreq(String) - Method in class org.apache.lucene.index.IndexReader
-
Returns the sum of
TermsEnum.docFreq()
for all terms in this field,
or -1 if this measure isn't stored by the codec.
- getSumDocFreq(String) - Method in class org.apache.lucene.index.LeafReader
-
- getSumDocFreq() - Method in class org.apache.lucene.index.MultiTerms
-
- getSumDocFreq() - Method in class org.apache.lucene.index.Terms
-
Returns the sum of
TermsEnum.docFreq()
for
all terms in this field, or -1 if this measure isn't
stored by the codec.
- getSummaryPassagesNoHighlight(int) - Method in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
Called to summarize a document when no highlights were found.
- getSumTotalTermFreq() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.BaseCompositeReader
-
- getSumTotalTermFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
- getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.IndexReader
-
Returns the sum of
TermsEnum.totalTermFreq()
for all terms in this
field, or -1 if this measure isn't stored by the codec (or if this fields
omits term freq and positions).
- getSumTotalTermFreq(String) - Method in class org.apache.lucene.index.LeafReader
-
- getSumTotalTermFreq() - Method in class org.apache.lucene.index.MultiTerms
-
- getSumTotalTermFreq() - Method in class org.apache.lucene.index.Terms
-
Returns the sum of
TermsEnum.totalTermFreq()
for
all terms in this field, or -1 if this measure isn't
stored by the codec (or if this fields omits term freq
and positions).
- getSurfaceForm() - Method in class org.apache.lucene.analysis.ja.Token
-
- getSurfaceForm() - Method in class org.apache.lucene.analysis.ko.Token
-
- getSurfaceFormString() - Method in class org.apache.lucene.analysis.ja.Token
-
- getSurfaceFormString() - Method in class org.apache.lucene.analysis.ko.Token
-
- getSyntaxParser() - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
Returns the text parser used to build a query node tree from a query
string.
- getTag(String) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
Returns object stored under that tag name
- getTag(String) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- getTagMap() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
Returns a map containing all tags attached to this query node.
- getTagMap() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
Returns a map containing all tags attached to this query node.
- getTags() - Method in interface org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttribute
-
Returns the POS tag of the term.
- getTags() - Method in class org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttributeImpl
-
Returns the POS tag of the term.
- getTargetLabel() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
- getTargetLabel() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
- getTask() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getTaskRunNum() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- getTasks() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- getTaxonomyDir() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getTaxonomyEpoch() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Expert: returns current index epoch, if this is a
near-real-time reader.
- getTaxonomyReader() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getTaxonomyWriter() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- getTempFileNamePrefix() - Method in class org.apache.lucene.util.OfflineSorter
-
- getTerm() - Method in class org.apache.lucene.search.FuzzyQuery
-
Returns the pattern term.
- getTerm() - Method in class org.apache.lucene.search.highlight.WeightedTerm
-
- 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.suggest.document.CompletionQuery
-
Returns the term to be queried against
- getTerm() - Method in class org.apache.lucene.search.TermQuery
-
Returns the term of this query.
- getTerm() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum
-
The term at this position.
- getTerm() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.MultiOffsetsEnum
-
- getTerm() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIterator
-
- getTerm() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIteratorWithSubs
-
- getTerm() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfPostings
-
- getTerm() - Method in class org.apache.lucene.search.WildcardQuery
-
Returns the pattern term.
- getTermArrays() - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Returns the arrays of arrays of terms in the multi-phrase.
- getTermBytes() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- getTermContext() - Method in class org.apache.lucene.search.spans.SpanTermQuery
-
Returns the
TermContext
passed to the constructor, or null if it was not passed.
- getTermContext() - Method in class org.apache.lucene.search.TermQuery
-
Returns the
TermContext
passed to the constructor, or null if it was not passed.
- getTermContexts(SpanWeight...) - Static method in class org.apache.lucene.search.spans.SpanQuery
-
Build a map of terms to termcontexts, for use in constructing SpanWeights
- getTermContexts(Collection<SpanWeight>) - Static method in class org.apache.lucene.search.spans.SpanQuery
-
Build a map of terms to termcontexts, for use in constructing SpanWeights
- getTermCount() - Method in class org.apache.lucene.util.fst.Builder
-
- getTermData() - Method in class org.apache.lucene.search.TermInSetQuery
-
Returns the terms wrapped in a PrefixCodedTerms.
- getTermDocsEnum(IndexReader, String, BytesRef) - Static method in class org.apache.lucene.index.MultiFields
-
- getTermDocsEnum(IndexReader, String, BytesRef, int) - Static method in class org.apache.lucene.index.MultiFields
-
Returns
PostingsEnum
for the specified field and
term, with control over whether freqs are required.
- getTermEscaped(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getTermEscaped(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
This method is used to get the value converted to
String
and
escaped using the given
EscapeQuerySyntax
.
- getTermEscapeQuoted(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getTermFrequency() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
- getTermFrequency() - Method in interface org.apache.lucene.analysis.tokenattributes.TermFrequencyAttribute
-
Returns the custom term frequencey.
- getTermFrequency() - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
-
- GetTermInfo - Class in org.apache.lucene.misc
-
Utility to get document frequency and total number of occurrences (sum of the tf for each doc) of a term.
- GetTermInfo() - Constructor for class org.apache.lucene.misc.GetTermInfo
-
- getTermInfo(Directory, Term) - Static method in class org.apache.lucene.misc.GetTermInfo
-
- getTermMap(String) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
-
- getTermOrPhraseNumber() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
-
- getTermPositionsEnum(IndexReader, String, BytesRef) - Static method in class org.apache.lucene.index.MultiFields
-
- getTermPositionsEnum(IndexReader, String, BytesRef, int) - Static method in class org.apache.lucene.index.MultiFields
-
Returns
PostingsEnum
for the specified
field and term, with control over whether offsets and payloads are
required.
- getTermQuery(String, boolean) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getTerms() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- getTerms(IndexReader, String) - Static method in class org.apache.lucene.index.MultiFields
-
This method may return null if the field does not exist or if it has no terms.
- getTerms() - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Gets the list of terms.
- getTerms(Query) - Static method in class org.apache.lucene.search.highlight.QueryTermExtractor
-
Extracts all terms texts of a given Query into an array of WeightedTerms
- getTerms(Query, boolean, String) - Static method in class org.apache.lucene.search.highlight.QueryTermExtractor
-
Extracts all terms texts of a given Query into an array of WeightedTerms
- getTerms(Query, boolean) - Static method in class org.apache.lucene.search.highlight.QueryTermExtractor
-
Extracts all terms texts of a given Query into an array of WeightedTerms
- getTerms() - Method in class org.apache.lucene.search.NGramPhraseQuery
-
Return the list of terms.
- getTerms() - Method in class org.apache.lucene.search.PhraseQuery
-
Returns the list of terms in this phrase.
- getTerms() - Method in class org.apache.lucene.search.SynonymQuery
-
- getTerms() - Method in class org.apache.lucene.search.uhighlight.UHComponents
-
- getTerms(String, int) - Method in class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
-
Returns the list of terms that start at the provided state
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.AutomatonQuery
-
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.FuzzyQuery
-
- getTermsEnum(Terms, AttributeSource) - Method in class org.apache.lucene.search.MultiTermQuery
-
Construct the enumeration to be used, expanding the
pattern term.
- getTermsEnum(Terms) - Method in class org.apache.lucene.search.MultiTermQuery
-
Convenience method, if no attributes are needed:
This simply passes empty attributes and is equal to:
getTermsEnum(terms, new AttributeSource())
- getTermsEnum(MultiTermQuery, Terms, AttributeSource) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
-
- getTermsEnum(Terms) - Method in class org.apache.lucene.util.automaton.CompiledAutomaton
-
Return a
TermsEnum
intersecting the provided
Terms
with the terms accepted by this automaton.
- getTermsInfos() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- getTermsOffsets() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
-
- getTermsOffsets() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- getTermText() - Method in class org.apache.lucene.queryparser.surround.query.SrndTermQuery
-
- getTermVector(int, String) - Method in class org.apache.lucene.index.IndexReader
-
Retrieve term vector for this document and field, or
null if term vectors were not indexed.
- getTermVectors(int) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- getTermVectors(int) - Method in class org.apache.lucene.index.BaseCompositeReader
-
- getTermVectors(int) - Method in class org.apache.lucene.index.CodecReader
-
- getTermVectors(int) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- getTermVectors(int) - Method in class org.apache.lucene.index.FilterLeafReader
-
- getTermVectors(int) - Method in class org.apache.lucene.index.IndexReader
-
Retrieve term vectors for this document, or null if
term vectors were not indexed.
- getTermVectors(int) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- getTermVectors(int) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- getTermVectorsReader() - Method in class org.apache.lucene.index.CodecReader
-
Expert: retrieve thread-private TermVectorsReader
- getTermVectorsReader() - Method in class org.apache.lucene.index.FilterCodecReader
-
- getTermVectorsReader() - Method in class org.apache.lucene.index.SegmentReader
-
- getTermVectorTerms() - Method in class org.apache.lucene.search.highlight.TokenStreamFromTermVector
-
- getTermVectorTokenStreamOrNull(String, Fields, int) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Get a token stream by un-inverting the term vector.
- getTestClass() - Static method in class org.apache.lucene.util.LuceneTestCase
-
Return the current class being tested.
- getTestClass() - Method in class org.apache.lucene.util.TestRuleStoreClassName
-
Returns the test class currently executing in this rule.
- getTestMethods(Class<?>, ClassModel) - Method in class org.apache.lucene.util.LuceneJUnit3MethodProvider
-
- getTestName() - Method in class org.apache.lucene.util.LuceneTestCase
-
Return the name of the currently executing test case.
- getText(CharTermAttribute) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
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.
- getText() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- getText() - Method in class org.apache.lucene.benchmark.byTask.stats.Report
-
Returns the report text.
- getText() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
Returns the term.
- getText() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.TextableQueryNode
-
- getText() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- getText(Node) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- getText() - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- getText() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- getText() - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- getText() - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- getText() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
-
- getText() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
Text of the match, calculated on the fly.
- getText() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
- getTextAsString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getTextFieldType() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Subclass can override this method to change the field type of the text field
e.g.
- getTextFieldType() - Method in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
- getTextFragmenter() - Method in class org.apache.lucene.search.highlight.Highlighter
-
- getThreshold() - Method in class org.apache.lucene.search.spell.JaroWinklerDistance
-
Returns the current value of the threshold used for adding the Winkler bonus.
- getThresholdFrequency() - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Get the minimal threshold of documents a term must appear for a match
- getTieBreakerMultiplier() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
- getTimeAllowed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
-
Returns allowed time (milliseconds).
- getTimeElapsed() - Method in exception org.apache.lucene.search.TimeLimitingCollector.TimeExceededException
-
Returns elapsed time (milliseconds).
- getTimeoutAt() - Method in class org.apache.lucene.index.QueryTimeoutImpl
-
Returns time at which to time out, in nanoseconds relative to the (JVM-specific)
epoch for System.nanoTime()
, to compare with the value returned by
nanoTime()
.
- getTimestamp() - Method in class org.apache.lucene.util.PrintStreamInfoStream
-
Returns the current time as string for insertion into log messages.
- getTimeZone() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- getTimeZone() - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- getTimeZone() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- getTitle() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- getToken(int) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
Get the specific Token.
- getToken(int) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Get the specific Token.
- getToken(int) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
Get the specific Token.
- getTokenArray(TokenStream) - Method in class org.apache.lucene.classification.document.SimpleNaiveBayesDocumentClassifier
-
- getTokenBytesNoLeaf(BytesRef) - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Returns the bytes for this cell, without a leaf set.
- getTokenBytesNoLeaf(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- getTokenBytesNoLeaf(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getTokenBytesNoLeaf(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- getTokenBytesWithLeaf(BytesRef) - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Returns the bytes for this cell, with a leaf byte if this is a leaf cell.
- getTokenBytesWithLeaf(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- getTokenBytesWithLeaf(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getTokenBytesWithLeaf(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- getTokenFilterFactories() - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
Returns the list of token filters that are used in this analyzer.
- getTokenizer() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
-
- getTokenizerFactory() - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
Returns the tokenizer that is used in this analyzer.
- getTokenScore() - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- getTokenScore() - Method in class org.apache.lucene.search.highlight.QueryTermScorer
-
- getTokenScore() - Method in interface org.apache.lucene.search.highlight.Scorer
-
Called for each token in the current fragment.
- getTokenSeparator() - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- getTokenStream() - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
-
- getTokenStream(String, Fields, String, Analyzer, int) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Get a token stream from either un-inverting a term vector if possible, or by analyzing the text.
- getTokenStream(Terms, boolean) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getTokenStream(Terms) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getTokenStream(IndexReader, int, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getTokenStream(Document, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getTokenStream(String, String, Analyzer) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getTokenStream() - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Returns the tokenStream which may have been wrapped in a CachingTokenFilter.
- getTokenStreamWithOffsets(IndexReader, int, String) - Static method in class org.apache.lucene.search.highlight.TokenSources
-
Deprecated.
- getTopChildren(int, String, String...) - Method in class org.apache.lucene.facet.Facets
-
Returns the topN child labels under the specified
path.
- getTopChildren(int, String, String...) - Method in class org.apache.lucene.facet.LongValueFacetCounts
-
- getTopChildren(int, String, String...) - Method in class org.apache.lucene.facet.MultiFacets
-
- getTopChildren(int, String, String...) - Method in class org.apache.lucene.facet.sortedset.ConcurrentSortedSetDocValuesFacetCounts
-
- getTopChildren(int, String, String...) - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetCounts
-
- getTopChildren(int, String, String...) - Method in class org.apache.lucene.facet.taxonomy.FloatTaxonomyFacets
-
- getTopChildren(int, String, String...) - Method in class org.apache.lucene.facet.taxonomy.IntTaxonomyFacets
-
- getTopChildrenSortByCount(int) - Method in class org.apache.lucene.facet.LongValueFacetCounts
-
Returns the specified top number of facets, sorted by count.
- getTopGroups(Sort, int, int, int, boolean) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
-
Returns the grouped results.
- getTopGroups(int, boolean) - Method in class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
Returns top groups, starting from offset.
- getTopGroups(int) - Method in class org.apache.lucene.search.grouping.TopGroupsCollector
-
Get the TopGroups recorded by this collector
- getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
-
- getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-
- getTopLevelBuilder() - Method in class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
-
- getTopLevelContext(IndexReaderContext) - Static method in class org.apache.lucene.index.ReaderUtil
-
Walks up the reader tree and return the given context's top level reader
context, or in other words the reader tree's root context.
- getTopLevelParser() - Method in class org.apache.lucene.queryparser.ext.ExtensionQuery
-
- getTopReaderContext() - Method in class org.apache.lucene.search.IndexSearcher
-
- getTotalBoost() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
-
- getTotalBytesCopied() - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
- getTotalBytesCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Returns the total number of bytes that were generated by this source.
- getTotalBytesWritten() - Method in class org.apache.lucene.index.MergeRateLimiter
-
Returns total bytes written by this merge.
- getTotalCount() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.GroupedFacetResult
-
Returns the sum of all facet entries counts.
- getTotalCount() - Method in class org.apache.lucene.search.LRUQueryCache
-
Return the total number of times that a
Query
has been looked up
in this
QueryCache
.
- getTotalHits() - Method in class org.apache.lucene.search.TopDocsCollector
-
The total number of documents that matched this query.
- getTotalHits() - Method in class org.apache.lucene.search.TotalHitCountCollector
-
Returns how many hits matched the search.
- getTotalItemsCount() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Returns the total number of generated items.
- getTotalMissingCount() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.GroupedFacetResult
-
Returns the number of groups that didn't have a facet value.
- getTotalPausedNS() - Method in class org.apache.lucene.index.MergeRateLimiter
-
Total NS merge was paused to rate limit IO.
- getTotalScore() - Method in class org.apache.lucene.search.highlight.TokenGroup
-
- getTotalSpace() - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- getTotalStoppedNS() - Method in class org.apache.lucene.index.MergeRateLimiter
-
Total NS merge was stopped.
- getTotalTermFreq() - Method in class org.apache.lucene.search.similarities.BasicStats
-
Returns the total number of occurrences of this term across all documents.
- getTragicException() - Method in class org.apache.lucene.index.IndexWriter
-
If this IndexWriter
was closed as a side-effect of a tragic exception,
e.g.
- getTransition(int, int, Transition) - Method in class org.apache.lucene.util.automaton.Automaton
-
Fill the provided
Transition
with the index'th
transition leaving the specified state.
- getTranspositions() - Method in class org.apache.lucene.search.FuzzyQuery
-
Returns true if transpositions should be treated as a primitive edit operation.
- getTreeCellIterator(Shape, int) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- getTreeCellIterator(Shape, int) - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
Gets the intersecting cells for the specified shape, without exceeding
detail level.
- getTreeLevelForCalendarField(int) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Calendar utility method:
Returns the spatial prefix tree level for the corresponding Calendar
field, such as
Calendar.YEAR
.
- getTruncated() - Method in class org.apache.lucene.queryparser.surround.query.SrndTruncQuery
-
- getTruncQuery(String) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- getType(int, int) - Method in class org.apache.lucene.analysis.icu.segmentation.DefaultICUTokenizerConfig
-
- getType(int, int) - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizerConfig
-
Return a token type value for a given script and BreakIterator
rule status.
- getType() - Method in class org.apache.lucene.analysis.ja.Token
-
Returns the type of this token
- getType() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
Returns the type of this token
- getType(int) - Static method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterIterator
-
Computes the type of the given character
- getType() - Method in class org.apache.lucene.queryparser.flexible.standard.config.PointsConfig
-
Returns the numeric type used to index the numeric values
- getType() - Method in class org.apache.lucene.search.SortField
-
Returns the type of contents in the field.
- getType() - Method in class org.apache.lucene.search.suggest.document.CompletionTerms
-
- getUnallocatedSpace() - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- getUniqueTermCount() - Method in class org.apache.lucene.index.FieldInvertState
-
Return the number of unique terms encountered in this field.
- getUpperBound() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.RangeQueryNode
-
- getUpperBound() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
Returns the upper bound node.
- getUpperPoint() - Method in class org.apache.lucene.search.PointRangeQuery
-
- getUpperTerm() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns the upper value of this range query
- getUpperVal() - Method in class org.apache.lucene.queries.function.FunctionRangeQuery
-
- getUsableSpace() - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- getUseCompoundFile() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Returns
true
iff the
IndexWriter
packs
newly written segments in a compound file.
- getUseCompoundFile() - Method in class org.apache.lucene.index.SegmentInfo
-
Returns true if this segment is stored as a compound
file; else, false.
- getUserData() - Method in class org.apache.lucene.index.IndexCommit
-
- getUserData() - Method in class org.apache.lucene.index.SegmentInfos
-
Return userData
saved with this commit.
- getUserPrincipalLookupService() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- 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
-
- getValAtLevel(int) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- getValAtLevel(int) - Method in interface org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.UnitNRShape
-
Gets the value at the specified level of this unit.
- getValue() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
-
- getValue(String) - Method in class org.apache.lucene.benchmark.quality.QualityQuery
-
Return the value of a certain name-value pair.
- getValue(int, BytesRef) - Method in class org.apache.lucene.codecs.MutablePointValues
-
Set packedValue
with a reference to the packed bytes of the i-th value.
- getValue() - Method in class org.apache.lucene.queries.function.FunctionValues.ValueFiller
-
MutableValue will be reused across calls
- getValue() - Method in class org.apache.lucene.queries.function.valuesource.LiteralValueSource
-
returns the literal value
- getValue() - Method in class org.apache.lucene.queryparser.classic.Token
-
An optional attribute value of the Token.
- getValue() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BoostQueryNode
-
Returns the boost value.
- getValue() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- getValue() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.OpaqueQueryNode
-
- getValue() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode.QueryText
-
- getValue() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- getValue() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- getValue() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.ValueQueryNode
-
- getValue() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
Returns the numeric value as Number
.
- getValue() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
An optional attribute value of the Token.
- getValue() - Method in class org.apache.lucene.queryparser.surround.parser.Token
-
An optional attribute value of the Token.
- getValue() - Method in class org.apache.lucene.search.Explanation
-
The value assigned to this explanation node.
- getValue() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.FacetEntry
-
- getValue() - Method in class org.apache.lucene.store.BufferedChecksum
-
- getValueCount() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- getValueCount() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- getValueCount() - Method in class org.apache.lucene.index.LegacySortedDocValues
-
Deprecated.
Returns the number of unique values.
- getValueCount() - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- getValueCount() - Method in class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
Returns the number of unique values.
- getValueCount() - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- getValueCount() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- getValueCount() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- getValueCount() - Method in class org.apache.lucene.index.OrdinalMap
-
Returns the total number of unique terms in global ord space.
- getValueCount() - Method in class org.apache.lucene.index.SortedDocValues
-
Returns the number of unique values.
- getValueCount() - Method in class org.apache.lucene.index.SortedSetDocValues
-
Returns the number of unique values.
- getValueFiller() - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.docvalues.StrDocValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.FunctionValues
-
- getValueFiller() - Method in class org.apache.lucene.queries.function.valuesource.MultiFunction.Values
-
- getValues(int) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
- getValues(String) - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsReader
-
- getValues(String) - Method in class org.apache.lucene.codecs.PointsReader
-
- getValues(String) - Method in class org.apache.lucene.document.Document
-
Returns an array of values of the field specified as the method parameter.
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.BytesRefFieldSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.ComparisonBoolFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.ConstValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.DefFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.DoubleConstValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.DoubleFieldSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.EnumFieldSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.FloatFieldSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.ValueSource
-
Gets the values for this reader and the context that was previously
passed to createWeight().
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.IDFValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.IfFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.IntFieldSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.JoinDocFreqValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.LinearFloatFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.LiteralValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.MaxDocValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.MultiBoolFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.MultiFloatFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.NormValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.NumDocsValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.QueryValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.ScaleFloatFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.SimpleBoolFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.SimpleFloatFunction
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.SortedSetFieldSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.SumTotalTermFreqValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.TermFreqValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.TFValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- getValues(Map, LeafReaderContext) - Method in class org.apache.lucene.queries.function.valuesource.VectorValueSource
-
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.search.DoubleValuesSource
-
Returns a
DoubleValues
instance for the passed-in LeafReaderContext and scores
If scores are not needed to calculate the values (ie
returns false
, callers
may safely pass
null
for the
scores
parameter.
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.search.LongValuesSource
-
Returns a
LongValues
instance for the passed-in LeafReaderContext and scores
If scores are not needed to calculate the values (ie
returns false
, callers
may safely pass
null
for the
scores
parameter.
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
- getValues(LeafReaderContext) - Method in class org.apache.lucene.spatial.ShapeValuesSource
-
Get a
ShapeValues
instance for the given leaf reader context
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.spatial.util.CachingDoubleValueSource
-
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.spatial.util.DistanceToShapeValueSource
-
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.spatial.util.ReciprocalDoubleValuesSource
-
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.spatial.util.ShapeAreaValueSource
-
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.spatial.util.ShapeFieldCacheDistanceValueSource
-
- getValues(LeafReaderContext, DoubleValues) - Method in class org.apache.lucene.spatial.vector.DistanceValueSource
-
Returns the FunctionValues used by the function query.
- getValueSource() - Method in class org.apache.lucene.queries.function.BoostedQuery
-
Deprecated.
- getValueSource() - Method in class org.apache.lucene.queries.function.FunctionQuery
-
- getValueSource() - Method in class org.apache.lucene.queries.function.FunctionRangeQuery
-
- getVersion() - Method in class org.apache.lucene.analysis.Analyzer
-
Return the version of Lucene this analyzer will mimic the behavior of for analysis.
- getVersion() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
Get the version of the currently seek'd term; only valid if we are
positioned.
- getVersion() - Method in class org.apache.lucene.index.DirectoryReader
-
Version number when this IndexReader was opened.
- getVersion() - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- getVersion() - Method in exception org.apache.lucene.index.IndexFormatTooNewException
-
Returns the version of the file that was too new
- getVersion() - Method in exception org.apache.lucene.index.IndexFormatTooOldException
-
Returns the version of the file that was too old.
- getVersion() - Method in class org.apache.lucene.index.SegmentInfo
-
Returns the version of the code which wrote the segment.
- getVersion() - Method in class org.apache.lucene.index.SegmentInfos
-
version number when this SegmentInfos was generated.
- getVersion() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- getVersion() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- getVersion() - Method in class org.apache.lucene.replicator.IndexRevision
-
- getVersion() - Method in interface org.apache.lucene.replicator.Revision
-
Returns a string representation of the version of this revision.
- getVersions() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Returns the versions this SI should test
- getWeight() - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- getWeight() - Method in class org.apache.lucene.search.highlight.WeightedTerm
-
- getWeight() - Method in class org.apache.lucene.search.Scorer
-
returns parent Weight
- getWeight(Document, int) - Method in class org.apache.lucene.search.suggest.DocumentDictionary.DocumentInputIterator
-
Returns the value of the weightField
for the current document.
- getWeight() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
- getWeightedFragInfoList(List<FieldFragList.WeightedFragInfo>) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- getWeightedFragInfoList(List<FieldFragList.WeightedFragInfo>) - Method in class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder
-
Sort by score the list of WeightedFragInfo
- getWeightedFragInfoList(List<FieldFragList.WeightedFragInfo>) - Method in class org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
-
do nothing.
- getWeightedSpanTerm(String) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- getWeightedSpanTerms(Query, float, TokenStream) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Creates a Map of WeightedSpanTerms
from the given Query
and TokenStream
.
- getWeightedSpanTerms(Query, float, TokenStream, String) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Creates a Map of WeightedSpanTerms
from the given Query
and TokenStream
.
- getWeightedSpanTermsWithScores(Query, float, TokenStream, String, IndexReader) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
Creates a Map of WeightedSpanTerms
from the given Query
and TokenStream
.
- getWeightOperator() - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- getWeightString() - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- getWidth() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Factory method for generating a query.
- getWildcardQuery(String, String) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- getWindingOrder() - Method in class org.apache.lucene.geo.Polygon
-
Returns the winding order (CW, COLINEAR, CCW) for the polygon shell
- getWordCost(int) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- getWordCost(int) - Method in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
Get word cost of specified word
- getWordCost(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- getWordCost(int) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- getWordCost(int) - Method in interface org.apache.lucene.analysis.ko.dict.Dictionary
-
Get word cost of specified word
- getWordCost(int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- getWords() - Method in class org.apache.lucene.analysis.miscellaneous.KeepWordFilterFactory
-
- getWordSet(ResourceLoader, String, boolean) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
Returns as
CharArraySet
from wordFiles, which
can be a comma-separated list of filenames
- 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) - Static method in class org.apache.lucene.analysis.WordlistLoader
-
Reads lines from a Reader and adds every line as an entry to a CharArraySet (omitting
leading and trailing whitespace).
- getWordSet(Reader, String) - Static method in class org.apache.lucene.analysis.WordlistLoader
-
Reads lines from a Reader and adds every non-comment line as an entry to a CharArraySet (omitting
leading and trailing whitespace).
- getWordSet(Reader, String, CharArraySet) - Static method in class org.apache.lucene.analysis.WordlistLoader
-
Reads lines from a Reader and adds every non-comment line as an entry to a CharArraySet (omitting
leading and trailing whitespace).
- getWorldCell() - Method in class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree
-
- getWorldCell() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- getWorldCell() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- getWorldCell() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- getWorldCell() - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
Returns the level 0 cell which encompasses all spatial data.
- getWrapped() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- getWrappedAnalyzer(String) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
Retrieves the wrapped Analyzer appropriate for analyzing the field with
the given name
- getWrappedAnalyzer(String) - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenCountAnalyzer
-
- getWrappedAnalyzer(String) - Method in class org.apache.lucene.analysis.miscellaneous.PerFieldAnalyzerWrapper
-
- getWrappedAnalyzer(String) - Method in class org.apache.lucene.analysis.query.QueryAutoStopWordAnalyzer
-
- getWrappedAnalyzer(String) - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- getWrappedAnalyzer(String) - Method in class org.apache.lucene.search.suggest.document.CompletionAnalyzer
-
- getWrappedQuery() - Method in class org.apache.lucene.queries.function.FunctionScoreQuery
-
- getWrappedQuery() - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
Returns the wrapped query
- getWriter(IndexOutput, long) - Method in class org.apache.lucene.util.OfflineSorter
-
Subclasses can override to change how byte sequences are written to disk.
- getWriter(DataOutput, int, int, float) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Create a packed integer array writer for the given output, format, value
count, and number of bits per value.
- getWriterNoHeader(DataOutput, PackedInts.Format, int, int, int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Expert: Create a packed integer array writer for the given output, format,
value count, and number of bits per value.
- getX() - Method in class org.apache.lucene.geo.Tessellator.Node
-
get the x value
- getX() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dPointShape
-
- getY() - Method in class org.apache.lucene.geo.Tessellator.Node
-
get the y value
- getY() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dPointShape
-
- getZ() - Method in class org.apache.lucene.search.similarities.NormalizationZ
-
Returns the parameter z
- GLOBAL_REUSE_STRATEGY - Static variable in class org.apache.lucene.analysis.Analyzer
-
- globalStartNS - Static variable in class org.apache.lucene.replicator.nrt.Node
-
Startup time of original test, carefully propogated to all nodes to produce consistent "seconds since start time" in messages
- GOOD_FAST_HASH_SEED - Static variable in class org.apache.lucene.util.StringHelper
-
- GradientFormatter - Class in org.apache.lucene.search.highlight
-
Formats text with different color intensity depending on the score of the
term.
- GradientFormatter(float, String, String, String, String) - Constructor for class org.apache.lucene.search.highlight.GradientFormatter
-
Sets the color range for the IDF scores
- GRAM_TYPE - Static variable in class org.apache.lucene.analysis.commongrams.CommonGramsFilter
-
- GraphTokenStreamFiniteStrings - Class in org.apache.lucene.util.graph
-
- GraphTokenStreamFiniteStrings(TokenStream) - Constructor for class org.apache.lucene.util.graph.GraphTokenStreamFiniteStrings
-
- GraphvizFormatter - Class in org.apache.lucene.analysis.ja
-
Outputs the dot (graphviz) string for the viterbi lattice.
- GraphvizFormatter(ConnectionCosts) - Constructor for class org.apache.lucene.analysis.ja.GraphvizFormatter
-
- GraphvizFormatter - Class in org.apache.lucene.analysis.ko
-
Outputs the dot (graphviz) string for the viterbi lattice.
- GraphvizFormatter(ConnectionCosts) - Constructor for class org.apache.lucene.analysis.ko.GraphvizFormatter
-
- GREEK - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- GREEK - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- GreekAnalyzer - Class in org.apache.lucene.analysis.el
-
- GreekAnalyzer() - Constructor for class org.apache.lucene.analysis.el.GreekAnalyzer
-
Builds an analyzer with the default stop words.
- GreekAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.el.GreekAnalyzer
-
Builds an analyzer with the given stop words.
- GreekLowerCaseFilter - Class in org.apache.lucene.analysis.el
-
Normalizes token text to lower case, removes some Greek diacritics,
and standardizes final sigma to sigma.
- GreekLowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.el.GreekLowerCaseFilter
-
Create a GreekLowerCaseFilter that normalizes Greek token text.
- GreekLowerCaseFilterFactory - Class in org.apache.lucene.analysis.el
-
- GreekLowerCaseFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.el.GreekLowerCaseFilterFactory
-
Creates a new GreekLowerCaseFilterFactory
- GreekStemFilter - Class in org.apache.lucene.analysis.el
-
- GreekStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.el.GreekStemFilter
-
- GreekStemFilterFactory - Class in org.apache.lucene.analysis.el
-
- GreekStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.el.GreekStemFilterFactory
-
Creates a new GreekStemFilterFactory
- GreekStemmer - Class in org.apache.lucene.analysis.el
-
A stemmer for Greek words, according to: Development of a Stemmer for the
Greek Language. Georgios Ntais
- GreekStemmer() - Constructor for class org.apache.lucene.analysis.el.GreekStemmer
-
- grid - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery
-
- grid - Variable in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- gridH - Variable in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- gridW - Variable in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- GROUP - Static variable in class org.apache.lucene.analysis.pattern.PatternTokenizerFactory
-
- group - Variable in class org.apache.lucene.analysis.pattern.PatternTokenizerFactory
-
- groupByDocBlock(IndexSearcher, Query, int, int) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
- groupByFieldOrFunction(IndexSearcher, Query, int, int) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
- GroupCount(T, Set<R>) - Constructor for class org.apache.lucene.search.grouping.DistinctValuesCollector.GroupCount
-
- GroupDocs<T> - Class in org.apache.lucene.search.grouping
-
Represents one group in the results.
- GroupDocs(float, float, long, ScoreDoc[], T, Object[]) - Constructor for class org.apache.lucene.search.grouping.GroupDocs
-
- GroupedFacetResult(int, int, boolean, int, int) - Constructor for class org.apache.lucene.search.grouping.GroupFacetCollector.GroupedFacetResult
-
- GroupFacetCollector - Class in org.apache.lucene.search.grouping
-
Base class for computing grouped facets.
- GroupFacetCollector(String, String, BytesRef) - Constructor for class org.apache.lucene.search.grouping.GroupFacetCollector
-
- GroupFacetCollector.FacetEntry - Class in org.apache.lucene.search.grouping
-
Represents a facet entry with a value and a count.
- GroupFacetCollector.GroupedFacetResult - Class in org.apache.lucene.search.grouping
-
The grouped facet result.
- GroupFacetCollector.SegmentResult - Class in org.apache.lucene.search.grouping
-
Contains the local grouped segment counts for a particular segment.
- groupField - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- GroupHead(T, int, int) - Constructor for class org.apache.lucene.search.grouping.AllGroupHeadsCollector.GroupHead
-
Create a new GroupHead for the given value
- groupHeadsSize() - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- GroupingSearch - Class in org.apache.lucene.search.grouping
-
Convenience class to perform grouping in a non distributed environment.
- GroupingSearch(String) - Constructor for class org.apache.lucene.search.grouping.GroupingSearch
-
Constructs a GroupingSearch
instance that groups documents by index terms using DocValues.
- GroupingSearch(ValueSource, Map<?, ?>) - Constructor for class org.apache.lucene.search.grouping.GroupingSearch
-
Constructs a
GroupingSearch
instance that groups documents by function using a
ValueSource
instance.
- GroupingSearch(Query) - Constructor for class org.apache.lucene.search.grouping.GroupingSearch
-
Constructor for grouping documents by doc block.
- GroupQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
GroupQueryNode
represents a location where the original user typed
real parenthesis on the query string.
- GroupQueryNode(QueryNode) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.GroupQueryNode
-
This QueryNode is used to identify parenthesis on the original query string
- GroupQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- GroupQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.GroupQueryNodeBuilder
-
- GroupReducer<T,C extends Collector> - Class in org.apache.lucene.search.grouping
-
Concrete implementations of this class define what to collect for individual
groups during the second-pass of a grouping search.
- GroupReducer() - Constructor for class org.apache.lucene.search.grouping.GroupReducer
-
- groupReducer - Variable in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- groups - Variable in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- groups - Variable in class org.apache.lucene.search.grouping.TopGroups
-
Group results in groupSort order
- GroupSelector<T> - Class in org.apache.lucene.search.grouping
-
Defines a group, for use by grouping collectors
A GroupSelector acts as an iterator over documents.
- GroupSelector() - Constructor for class org.apache.lucene.search.grouping.GroupSelector
-
- groupSelector - Variable in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- GroupSelector.State - Enum in org.apache.lucene.search.grouping
-
What to do with the current value
- groupSort - Variable in class org.apache.lucene.search.grouping.TopGroups
-
How groups are sorted against each other
- groupSortValues - Variable in class org.apache.lucene.search.grouping.GroupDocs
-
- groupValue - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector.GroupHead
-
- groupValue - Variable in class org.apache.lucene.search.grouping.DistinctValuesCollector.GroupCount
-
- groupValue - Variable in class org.apache.lucene.search.grouping.GroupDocs
-
The groupField value for all docs in this group; this
may be null if hits did not have the groupField.
- groupValue - Variable in class org.apache.lucene.search.grouping.SearchGroup
-
The value that defines this group
- grow(int) - Method in interface org.apache.lucene.index.PointValues.IntersectVisitor
-
Notifies the caller that this many documents are about to be visited
- grow(T[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(short[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a larger array, generally over-allocating exponentially
- grow(float[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(float[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a larger array, generally over-allocating exponentially
- grow(double[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(double[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a larger array, generally over-allocating exponentially
- grow(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(int[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a larger array, generally over-allocating exponentially
- grow(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(long[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a larger array, generally over-allocating exponentially
- grow(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(byte[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a larger array, generally over-allocating exponentially
- grow(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array whose size is at least minSize
, generally over-allocating exponentially
- grow(char[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a larger array, generally over-allocating exponentially
- grow(int) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Ensure that this builder can hold at least capacity
bytes
without resizing.
- grow() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
- grow() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-
- grow(int) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Used to grow the reference array.
- grow(int) - Method in class org.apache.lucene.util.DocIdSetBuilder
-
- grow() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
- grow() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
- grow(int) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Used to grow the reference array.
- grow(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- grow() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- GrowableByteArrayDataOutput - Class in org.apache.lucene.store
-
- GrowableByteArrayDataOutput(int) - Constructor for class org.apache.lucene.store.GrowableByteArrayDataOutput
-
- GrowableWriter - Class in org.apache.lucene.util.packed
-
Implements
PackedInts.Mutable
, but grows the
bit count of the underlying packed ints on-demand.
- GrowableWriter(int, int, float) - Constructor for class org.apache.lucene.util.packed.GrowableWriter
-
- growExact(T[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- growExact(short[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- growExact(float[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- growExact(double[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- growExact(int[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- growExact(long[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- growExact(byte[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- growExact(char[], int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns a new array whose size is exact the specified newLength
without over-allocating
- IBSimilarity - Class in org.apache.lucene.search.similarities
-
Provides a framework for the family of information-based models, as described
in Stéphane Clinchant and Eric Gaussier.
- IBSimilarity(Distribution, Lambda, Normalization) - Constructor for class org.apache.lucene.search.similarities.IBSimilarity
-
Creates IBSimilarity from the three components.
- ICUCollatedTermAttributeImpl - Class in org.apache.lucene.collation.tokenattributes
-
Extension of
CharTermAttributeImpl
that encodes the term
text as a binary Unicode collation key instead of as UTF-8 bytes.
- ICUCollatedTermAttributeImpl(Collator) - Constructor for class org.apache.lucene.collation.tokenattributes.ICUCollatedTermAttributeImpl
-
Create a new ICUCollatedTermAttributeImpl
- ICUCollationAttributeFactory - Class in org.apache.lucene.collation
-
Converts each token into its CollationKey
, and
then encodes bytes as an index term.
- ICUCollationAttributeFactory(Collator) - Constructor for class org.apache.lucene.collation.ICUCollationAttributeFactory
-
- ICUCollationAttributeFactory(AttributeFactory, Collator) - Constructor for class org.apache.lucene.collation.ICUCollationAttributeFactory
-
Create an ICUCollationAttributeFactory, using the supplied Attribute
Factory as the factory for all other attributes.
- ICUCollationDocValuesField - Class in org.apache.lucene.collation
-
- ICUCollationDocValuesField(String, Collator) - Constructor for class org.apache.lucene.collation.ICUCollationDocValuesField
-
Create a new ICUCollationDocValuesField.
- ICUCollationKeyAnalyzer - Class in org.apache.lucene.collation
-
- ICUCollationKeyAnalyzer(Collator) - Constructor for class org.apache.lucene.collation.ICUCollationKeyAnalyzer
-
Create a new ICUCollationKeyAnalyzer, using the specified collator.
- ICUFoldingFilter - Class in org.apache.lucene.analysis.icu
-
A TokenFilter that applies search term folding to Unicode text,
applying foldings from UTR#30 Character Foldings.
- ICUFoldingFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.icu.ICUFoldingFilter
-
Create a new ICUFoldingFilter on the specified input
- ICUFoldingFilter(TokenStream, Normalizer2) - Constructor for class org.apache.lucene.analysis.icu.ICUFoldingFilter
-
Create a new ICUFoldingFilter on the specified input with the specified
normalizer
- ICUFoldingFilterFactory - Class in org.apache.lucene.analysis.icu
-
- ICUFoldingFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.icu.ICUFoldingFilterFactory
-
Creates a new ICUFoldingFilterFactory
- ICUNormalizer2CharFilter - Class in org.apache.lucene.analysis.icu
-
Normalize token text with ICU's Normalizer2
.
- ICUNormalizer2CharFilter(Reader) - Constructor for class org.apache.lucene.analysis.icu.ICUNormalizer2CharFilter
-
Create a new Normalizer2CharFilter that combines NFKC normalization, Case
Folding, and removes Default Ignorables (NFKC_Casefold)
- ICUNormalizer2CharFilter(Reader, Normalizer2) - Constructor for class org.apache.lucene.analysis.icu.ICUNormalizer2CharFilter
-
Create a new Normalizer2CharFilter with the specified Normalizer2
- ICUNormalizer2CharFilterFactory - Class in org.apache.lucene.analysis.icu
-
- ICUNormalizer2CharFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.icu.ICUNormalizer2CharFilterFactory
-
Creates a new ICUNormalizer2CharFilterFactory
- ICUNormalizer2Filter - Class in org.apache.lucene.analysis.icu
-
Normalize token text with ICU's Normalizer2
- ICUNormalizer2Filter(TokenStream) - Constructor for class org.apache.lucene.analysis.icu.ICUNormalizer2Filter
-
Create a new Normalizer2Filter that combines NFKC normalization, Case
Folding, and removes Default Ignorables (NFKC_Casefold)
- ICUNormalizer2Filter(TokenStream, Normalizer2) - Constructor for class org.apache.lucene.analysis.icu.ICUNormalizer2Filter
-
Create a new Normalizer2Filter with the specified Normalizer2
- ICUNormalizer2FilterFactory - Class in org.apache.lucene.analysis.icu
-
- ICUNormalizer2FilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.icu.ICUNormalizer2FilterFactory
-
Creates a new ICUNormalizer2FilterFactory
- ICUTokenizer - Class in org.apache.lucene.analysis.icu.segmentation
-
Breaks text into words according to UAX #29: Unicode Text Segmentation
(http://www.unicode.org/reports/tr29/)
- ICUTokenizer() - Constructor for class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
-
Construct a new ICUTokenizer that breaks text into words from the given
Reader.
- ICUTokenizer(ICUTokenizerConfig) - Constructor for class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
-
Construct a new ICUTokenizer that breaks text into words from the given
Reader, using a tailored BreakIterator configuration.
- ICUTokenizer(AttributeFactory, ICUTokenizerConfig) - Constructor for class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
-
Construct a new ICUTokenizer that breaks text into words from the given
Reader, using a tailored BreakIterator configuration.
- ICUTokenizerConfig - Class in org.apache.lucene.analysis.icu.segmentation
-
Class that allows for tailored Unicode Text Segmentation on
a per-writing system basis.
- ICUTokenizerConfig() - Constructor for class org.apache.lucene.analysis.icu.segmentation.ICUTokenizerConfig
-
Sole constructor.
- ICUTokenizerFactory - Class in org.apache.lucene.analysis.icu.segmentation
-
- ICUTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.icu.segmentation.ICUTokenizerFactory
-
Creates a new ICUTokenizerFactory
- ICUTransformFilter - Class in org.apache.lucene.analysis.icu
-
- ICUTransformFilter(TokenStream, Transliterator) - Constructor for class org.apache.lucene.analysis.icu.ICUTransformFilter
-
Create a new ICUTransformFilter that transforms text on the given stream.
- ICUTransformFilterFactory - Class in org.apache.lucene.analysis.icu
-
- ICUTransformFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.icu.ICUTransformFilterFactory
-
Creates a new ICUTransformFilterFactory
- id() - Method in class org.apache.lucene.index.IndexReaderContext
-
Expert: Return an Object
that uniquely identifies this context.
- id - Variable in class org.apache.lucene.replicator.nrt.Node
-
Compact ordinal for this node
- id - Variable in class org.apache.lucene.replicator.SessionToken
-
ID of this session.
- id - Variable in enum org.apache.lucene.util.packed.PackedInts.Format
-
- ID_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- ID_LENGTH - Static variable in class org.apache.lucene.util.StringHelper
-
length in bytes of an ID
- IDENTITY - Static variable in class org.apache.lucene.util.LongValues
-
An instance that returns the provided value.
- IdentityEncoder - Class in org.apache.lucene.analysis.payloads
-
Does nothing other than convert the char array to a byte array using the specified encoding.
- IdentityEncoder() - Constructor for class org.apache.lucene.analysis.payloads.IdentityEncoder
-
- IdentityEncoder(Charset) - Constructor for class org.apache.lucene.analysis.payloads.IdentityEncoder
-
- IDEOGRAPHIC - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Ideographic token type
- IDEOGRAPHIC - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Ideographic token type
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Ideographic token type
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Ideographic token type
- idf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Axiomatic
-
compute the inverted document frequency component
- idf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
compute the inverted document frequency component
- idf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
compute the inverted document frequency component
- idf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
compute the inverted document frequency component
- idf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
compute the inverted document frequency component
- idf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
compute the inverted document frequency component
- idf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
-
compute the inverted document frequency component
- idf(long, long) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Implemented as log(1 + (docCount - docFreq + 0.5)/(docFreq + 0.5))
.
- idf(long, long) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
-
Implemented as log((docCount+1)/(docFreq+1)) + 1
.
- idf(long, long) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Computes a score factor based on a term's document frequency (the number
of documents which contain the term).
- idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Computes a score factor for a simple term and returns an explanation
for that score factor.
- idfExplain(CollectionStatistics, TermStatistics[]) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Computes a score factor for a phrase.
- idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
-
- idfExplain(CollectionStatistics, TermStatistics) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Computes a score factor for a simple term and returns an explanation
for that score factor.
- idfExplain(CollectionStatistics, TermStatistics[]) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Computes a score factor for a phrase.
- IDFValueSource - Class in org.apache.lucene.queries.function.valuesource
-
- IDFValueSource(String, String, String, BytesRef) - Constructor for class org.apache.lucene.queries.function.valuesource.IDFValueSource
-
- idToString(byte[]) - Static method in class org.apache.lucene.util.StringHelper
-
Helper method to render an ID as a string, for debugging
- IDVersionPostingsFormat - Class in org.apache.lucene.codecs.idversion
-
- IDVersionPostingsFormat() - Constructor for class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
- IDVersionPostingsFormat(int, int) - Constructor for class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
- IDVersionSegmentTermsEnum - Class in org.apache.lucene.codecs.idversion
-
- IfFunction - Class in org.apache.lucene.queries.function.valuesource
-
Depending on the boolean value of the ifSource
function,
returns the value of the trueSource
or falseSource
function.
- IfFunction(ValueSource, ValueSource, ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.IfFunction
-
- IGNORE_KEYWORDS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- IGNORE_KEYWORDS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
- image - Variable in class org.apache.lucene.queryparser.classic.Token
-
The string image of the token.
- image - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
The string image of the token.
- image - Variable in class org.apache.lucene.queryparser.surround.parser.Token
-
The string image of the token.
- implCloseChannel() - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- in - Variable in class org.apache.lucene.index.FilterBinaryDocValues
-
Wrapped values
- in - Variable in class org.apache.lucene.index.FilterCodecReader
-
The underlying CodecReader instance.
- in - Variable in class org.apache.lucene.index.FilterDirectoryReader
-
The filtered DirectoryReader
- in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterFields
-
The underlying Fields instance.
- in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
The underlying PostingsEnum instance.
- in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
The underlying Terms instance.
- in - Variable in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
The underlying TermsEnum instance.
- in - Variable in class org.apache.lucene.index.FilterLeafReader
-
The underlying LeafReader.
- in - Variable in class org.apache.lucene.index.FilterMergePolicy
-
- in - Variable in class org.apache.lucene.index.FilterNumericDocValues
-
Wrapped values
- in - Variable in class org.apache.lucene.search.FilterCollector
-
- in - Variable in class org.apache.lucene.search.FilterLeafCollector
-
- in - Variable in class org.apache.lucene.search.FilterMatchesIterator
-
The delegate
- in - Variable in class org.apache.lucene.search.FilterScorer
-
- in - Variable in class org.apache.lucene.search.FilterWeight
-
- in - Variable in class org.apache.lucene.search.intervals.IntervalFilter
-
- in - Variable in class org.apache.lucene.search.spans.FilterSpans
-
The wrapped spans instance.
- in - Variable in class org.apache.lucene.store.FilterDirectory
-
- in - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
-
- in_grouping(char[], int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- in_grouping_b(char[], int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- in_range(int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- in_range_b(int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- includesLower() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns true
if the lower endpoint is inclusive
- includesUpper() - Method in class org.apache.lucene.search.TermRangeQuery
-
Returns true
if the upper endpoint is inclusive
- incRef() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Expert: increments the refCount of this TaxonomyReader instance.
- incRef() - Method in class org.apache.lucene.index.IndexReader
-
Expert: increments the refCount of this IndexReader
instance.
- incRef(IndexCommit) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
- incRef() - Method in class org.apache.lucene.util.RefCount
-
Increments the reference count.
- incRefDeleter(SegmentInfos) - Method in class org.apache.lucene.index.IndexWriter
-
Record that the files referenced by this
SegmentInfos
are still in use.
- increment(int) - Method in class org.apache.lucene.facet.taxonomy.IntTaxonomyFacets
-
Increment the count for this ordinal by 1.
- increment(int, int) - Method in class org.apache.lucene.facet.taxonomy.IntTaxonomyFacets
-
Increment the count for this ordinal by amount
..
- incrementToken() - Method in class org.apache.lucene.analysis.ar.ArabicNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ar.ArabicStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.bg.BulgarianStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.bn.BengaliNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.bn.BengaliStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.br.BrazilianStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.CachingTokenFilter
-
The first time called, it'll read and cache all tokens from the input.
- incrementToken() - Method in class org.apache.lucene.analysis.CannedBinaryTokenStream
-
- incrementToken() - Method in class org.apache.lucene.analysis.CannedTokenStream
-
- incrementToken() - Method in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.cjk.CJKWidthFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ckb.SoraniNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ckb.SoraniStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.commongrams.CommonGramsFilter
-
Inserts bigrams for common words into a token stream.
- incrementToken() - Method in class org.apache.lucene.analysis.commongrams.CommonGramsQueryFilter
-
Output bigrams whenever possible to optimize queries.
- incrementToken() - Method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- incrementToken() - Method in class org.apache.lucene.analysis.core.DecimalDigitFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.core.FlattenGraphFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.core.KeywordTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.core.UpperCaseFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.CrankyTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.cz.CzechStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.de.GermanLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.de.GermanMinimalStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.de.GermanNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.de.GermanStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.el.GreekLowerCaseFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.el.GreekStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.en.EnglishMinimalStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.en.EnglishPossessiveFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.en.KStemFilter
-
Returns the next, stemmed, input Token.
- incrementToken() - Method in class org.apache.lucene.analysis.en.PorterStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.es.SpanishLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.fa.PersianNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.fi.FinnishLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.fr.FrenchLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.fr.FrenchMinimalStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ga.IrishLowerCaseFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.gl.GalicianMinimalStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.gl.GalicianStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.hi.HindiNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.hi.HindiStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.hu.HungarianLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.icu.ICUNormalizer2Filter
-
- incrementToken() - Method in class org.apache.lucene.analysis.icu.ICUTransformFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.id.IndonesianStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.in.IndicNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.it.ItalianLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ja.JapaneseBaseFormFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ja.JapaneseKatakanaStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ja.JapaneseReadingFormFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.ko.KoreanReadingFormFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ko.KoreanTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.LowerCaseFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.lv.LatvianStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.minhash.MinHashFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenatingTokenStream
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.DelimitedTermFrequencyTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.EmptyTokenStream
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.FingerprintFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.FixBrokenOffsetsFilter
-
Deprecated.
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.HyphenatedWordsFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.KeywordMarkerFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.KeywordRepeatFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenOffsetFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.RemoveDuplicatesTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.ScandinavianFoldingFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.ScandinavianNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.TrimFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.TruncateTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.TypeAsSynonymFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- incrementToken() - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockFixedLengthPayloadFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockGraphTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockHoleInjectingTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockLowerCaseFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockRandomLookaheadTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockSynonymFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.MockVariableLengthPayloadFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.morfologik.MorfologikFilter
-
Retrieves the next token (possibly from the list of lemmas).
- incrementToken() - Method in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ngram.NGramTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.no.NorwegianLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.no.NorwegianMinimalStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.pattern.PatternCaptureGroupTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.pattern.PatternReplaceFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.pattern.PatternTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.pattern.SimplePatternTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.payloads.NumericPayloadTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.payloads.TokenOffsetPayloadTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.payloads.TypeAsPayloadTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.phonetic.BeiderMorseFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.phonetic.DaitchMokotoffSoundexFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.phonetic.PhoneticFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.pt.PortugueseLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.pt.PortugueseMinimalStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.pt.PortugueseStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.ru.RussianLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.shingle.FixedShingleFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.SimplePayloadFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.sinks.TeeSinkTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.sinks.TeeSinkTokenFilter.SinkTokenStream
-
- incrementToken() - Method in class org.apache.lucene.analysis.snowball.SnowballFilter
-
Returns the next input Token, after being stemmed
- incrementToken() - Method in class org.apache.lucene.analysis.sr.SerbianNormalizationFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.sr.SerbianNormalizationRegularFilter
-
- 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
-
Deprecated.
- 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.stempel.StempelFilter
-
Returns the next input Token, after being stemmed
- incrementToken() - Method in class org.apache.lucene.analysis.sv.SwedishLightStemFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.synonym.SynonymFilter
-
Deprecated.
- incrementToken() - Method in class org.apache.lucene.analysis.synonym.SynonymGraphFilter
-
- 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.analysis.tr.ApostropheFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.tr.TurkishLowerCaseFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.util.CharTokenizer
-
- incrementToken() - Method in class org.apache.lucene.analysis.util.ElisionFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
- incrementToken() - Method in class org.apache.lucene.analysis.ValidatingTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- incrementToken() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- incrementToken() - Method in class org.apache.lucene.search.highlight.OffsetLimitTokenFilter
-
- incrementToken() - Method in class org.apache.lucene.search.highlight.TokenStreamFromTermVector
-
- incrementToken() - Method in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilter
-
- incrementToken() - Method in class org.apache.lucene.search.suggest.document.CompletionTokenStream
-
- incrementWord() - Method in class org.apache.lucene.analysis.cn.smart.HMMChineseTokenizer
-
- incrementWord() - Method in class org.apache.lucene.analysis.th.ThaiTokenizer
-
- incrementWord() - Method in class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
Returns true if another word is available
- Independence - Class in org.apache.lucene.search.similarities
-
Computes the measure of divergence from independence for DFI
scoring functions.
- Independence() - Constructor for class org.apache.lucene.search.similarities.Independence
-
Sole constructor.
- IndependenceChiSquared - Class in org.apache.lucene.search.similarities
-
Normalized chi-squared measure of distance from independence
- IndependenceChiSquared() - Constructor for class org.apache.lucene.search.similarities.IndependenceChiSquared
-
Sole constructor.
- IndependenceSaturated - Class in org.apache.lucene.search.similarities
-
Saturated measure of distance from independence
- IndependenceSaturated() - Constructor for class org.apache.lucene.search.similarities.IndependenceSaturated
-
Sole constructor.
- IndependenceStandardized - Class in org.apache.lucene.search.similarities
-
Standardized measure of distance from independence
- IndependenceStandardized() - Constructor for class org.apache.lucene.search.similarities.IndependenceStandardized
-
Sole constructor.
- index - Variable in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
-
during segmentation, this is used to store the index of the token in the token list table
- index() - Method in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
Build the example index.
- index() - Method in class org.apache.lucene.demo.facet.RangeFacetsExample
-
Build the example index.
- index - Variable in class org.apache.lucene.util.bkd.BKDReader.IntersectState
-
- INDEX_EPOCH - Static variable in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Property name of user commit data that contains the index epoch.
- INDEX_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene60.Lucene60PointsFormat
-
Filename extension for the index per field
- INDEX_SOURCE - Static variable in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- IndexableField - Interface in org.apache.lucene.index
-
Represents a single field for indexing.
- IndexableFieldType - Interface in org.apache.lucene.index
-
Describes the properties of a field.
- indexAnalyzer - Variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Analyzer used at index time
- indexAnalyzer - Variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- IndexAndTaxonomyReplicationHandler - Class in org.apache.lucene.replicator
-
- IndexAndTaxonomyReplicationHandler(Directory, Directory, Callable<Boolean>) - Constructor for class org.apache.lucene.replicator.IndexAndTaxonomyReplicationHandler
-
Constructor with the given index directory and callback to notify when the
indexes were updated.
- IndexAndTaxonomyRevision - Class in org.apache.lucene.replicator
-
A
Revision
of a single index and taxonomy index files which comprises
the list of files from both indexes.
- IndexAndTaxonomyRevision(IndexWriter, IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter) - Constructor for class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter - Class in org.apache.lucene.replicator
-
- IndexCommit - Class in org.apache.lucene.index
-
- IndexCommit() - Constructor for class org.apache.lucene.index.IndexCommit
-
Sole constructor.
- indexCommits - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Used to map gen to IndexCommit.
- IndexDeletionPolicy - Class in org.apache.lucene.index
-
- IndexDeletionPolicy() - Constructor for class org.apache.lucene.index.IndexDeletionPolicy
-
Sole constructor, typically called by sub-classes constructors.
- indexDictionary(Dictionary, IndexWriterConfig, boolean) - Method in class org.apache.lucene.search.spell.SpellChecker
-
- indexedBytes - Variable in class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- indexedBytes - Variable in class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- indexedField - Variable in class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- indexedField - Variable in class org.apache.lucene.queries.function.valuesource.SumTotalTermFreqValueSource
-
- indexedField - Variable in class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- indexedTermPrefixLength(BytesRef, BytesRef) - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexWriter
-
NOTE: if your codec does not sort in unicode code
point order, you must override this method, to simply
return indexedTerm.length.
- indexedTermPrefixLength(BytesRef, BytesRef) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter
-
NOTE: if your codec does not sort in unicode code
point order, you must override this method, to simply
return indexedTerm.length.
- indexerThreadPool - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
DocumentsWriterPerThreadPool
to control how
threads are allocated to DocumentsWriterPerThread
.
- indexExists(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
-
Returns true
if an index likely exists at
the specified directory.
- indexFieldName - Variable in class org.apache.lucene.facet.FacetsConfig.DimConfig
-
Actual field where this dimension's facet labels
should be indexed
- indexFieldName - Variable in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
Index field name provided to the constructor.
- 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
).
- IndexFiles - Class in org.apache.lucene.demo
-
Index all text files under a directory.
- IndexFormatTooNewException - Exception in org.apache.lucene.index
-
This exception is thrown when Lucene detects
an index that is newer than this Lucene version.
- IndexFormatTooNewException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
-
Creates an IndexFormatTooNewException
- IndexFormatTooNewException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooNewException
-
Creates an IndexFormatTooNewException
- IndexFormatTooOldException - Exception in org.apache.lucene.index
-
This exception is thrown when Lucene detects
an index that is too old for this Lucene version
- IndexFormatTooOldException(String, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
-
Creates an IndexFormatTooOldException
.
- IndexFormatTooOldException(DataInput, String) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
-
Creates an IndexFormatTooOldException
.
- IndexFormatTooOldException(String, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
-
Creates an IndexFormatTooOldException
.
- IndexFormatTooOldException(DataInput, int, int, int) - Constructor for exception org.apache.lucene.index.IndexFormatTooOldException
-
Creates an IndexFormatTooOldException
.
- indexFPs - Variable in class org.apache.lucene.codecs.lucene60.Lucene60PointsWriter
-
Maps field name to file pointer in the data file where the BKD index is located.
- indexHeaderLength(String, String) - Static method in class org.apache.lucene.codecs.CodecUtil
-
Computes the length of an index header.
- indexingChain - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
DocumentsWriterPerThread.IndexingChain
that determines how documents are
indexed.
- IndexInput - Class in org.apache.lucene.store
-
Abstract base class for input from a file in a
Directory
.
- IndexInput(String) - Constructor for class org.apache.lucene.store.IndexInput
-
resourceDescription should be a non-null, opaque string
describing this resource; it's returned from
IndexInput.toString()
.
- IndexInputInputStream - Class in org.apache.lucene.replicator
-
- IndexInputInputStream(IndexInput) - Constructor for class org.apache.lucene.replicator.IndexInputInputStream
-
- IndexMergeTool - Class in org.apache.lucene.misc
-
Merges indices specified on the command line into the index
specified as the first command line argument.
- IndexMergeTool() - Constructor for class org.apache.lucene.misc.IndexMergeTool
-
- IndexNotFoundException - Exception in org.apache.lucene.index
-
Signals that no index was found in the Directory.
- IndexNotFoundException(String) - Constructor for exception org.apache.lucene.index.IndexNotFoundException
-
Creates IndexFileNotFoundException with the
description message.
- indexNumBytes - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Byte size of the index.
- indexOf(Object) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- indexOptions - Variable in class org.apache.lucene.codecs.PushPostingsWriterBase
-
- indexOptions() - Method in class org.apache.lucene.document.FieldType
-
IndexOptions
, describing what should be
recorded into the inverted index
- indexOptions() - Method in interface org.apache.lucene.index.IndexableFieldType
-
IndexOptions
, describing what should be
recorded into the inverted index
- IndexOptions - Enum in org.apache.lucene.index
-
Controls how much information is stored in the postings lists.
- INDEXORDER - Static variable in class org.apache.lucene.search.Sort
-
Represents sorting by index order.
- IndexOrDocValuesQuery - Class in org.apache.lucene.search
-
A query that uses either an index structure (points or terms) or doc values
in order to run a query, depending which one is more efficient.
- IndexOrDocValuesQuery(Query, Query) - Constructor for class org.apache.lucene.search.IndexOrDocValuesQuery
-
- IndexOutput - Class in org.apache.lucene.store
-
- IndexOutput(String, String) - Constructor for class org.apache.lucene.store.IndexOutput
-
Sole constructor.
- indexProperties - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- indexReader - Variable in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
- IndexReader - Class in org.apache.lucene.index
-
IndexReader is an abstract class, providing an interface for accessing a
point-in-time view of an index.
- IndexReader.CacheHelper - Interface in org.apache.lucene.index
-
A utility class that gives hooks in order to help build a cache based on
the data that is contained in this index.
- IndexReader.CacheKey - Class in org.apache.lucene.index
-
A cache key identifying a resource that is being cached on.
- IndexReader.ClosedListener - Interface in org.apache.lucene.index
-
A listener that is called when a resource gets closed.
- IndexReaderContext - Class in org.apache.lucene.index
-
A struct like class that represents a hierarchical relationship between
IndexReader
instances.
- IndexReaderFunctions - Class in org.apache.lucene.queries.function
-
Class exposing static helper methods for generating DoubleValuesSource instances
over some IndexReader statistics
- IndexReplicationHandler - Class in org.apache.lucene.replicator
-
- IndexReplicationHandler(Directory, Callable<Boolean>) - Constructor for class org.apache.lucene.replicator.IndexReplicationHandler
-
Constructor with the given index directory and callback to notify when the
indexes were updated.
- IndexRevision - Class in org.apache.lucene.replicator
-
A
Revision
of a single index files which comprises the list of files
that are part of the current
IndexCommit
.
- IndexRevision(IndexWriter) - Constructor for class org.apache.lucene.replicator.IndexRevision
-
- indexSearcher - Variable in class org.apache.lucene.classification.KNearestNeighborClassifier
-
- indexSearcher - Variable in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
IndexSearcher
to run searches on the index for retrieving frequencies
- IndexSearcher - Class in org.apache.lucene.search
-
Implements search over a single IndexReader.
- IndexSearcher(IndexReader) - Constructor for class org.apache.lucene.search.IndexSearcher
-
Creates a searcher searching the provided index.
- IndexSearcher(IndexReader, ExecutorService) - Constructor for class org.apache.lucene.search.IndexSearcher
-
Runs searches for each segment separately, using the
provided ExecutorService.
- IndexSearcher(IndexReaderContext, ExecutorService) - Constructor for class org.apache.lucene.search.IndexSearcher
-
- IndexSearcher(IndexReaderContext) - Constructor for class org.apache.lucene.search.IndexSearcher
-
- IndexSearcher.LeafSlice - Class in org.apache.lucene.search
-
A class holding a subset of the
IndexSearcher
s leaf contexts to be
executed within a single thread.
- indexSort - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
The sort order to use to write merged segments.
- indexSortFields - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
The field names involved in the index sort
- indexSortStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status of index sort
- IndexSplitter - Class in org.apache.lucene.index
-
Command-line tool that enables listing segments in an
index, copying specific segments to another index, and
deleting segments from an index.
- IndexSplitter(Path) - Constructor for class org.apache.lucene.index.IndexSplitter
-
- IndexTermSelector() - Constructor for class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter.IndexTermSelector
-
- IndexTree() - Constructor for class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- IndexUpgrader - Class in org.apache.lucene.index
-
This is an easy-to-use tool that upgrades all segments of an index from previous Lucene versions
to the current segment file format.
- IndexUpgrader(Directory) - Constructor for class org.apache.lucene.index.IndexUpgrader
-
Creates index upgrader on the given directory, using an
IndexWriter
using the given
matchVersion
.
- IndexUpgrader(Directory, InfoStream, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
-
Creates index upgrader on the given directory, using an
IndexWriter
using the given
matchVersion
.
- IndexUpgrader(Directory, IndexWriterConfig, boolean) - Constructor for class org.apache.lucene.index.IndexUpgrader
-
Creates index upgrader on the given directory, using an
IndexWriter
using the given
config.
- IndexWriter - Class in org.apache.lucene.index
-
An IndexWriter
creates and maintains an index.
- IndexWriter(Directory, IndexWriterConfig) - Constructor for class org.apache.lucene.index.IndexWriter
-
Constructs a new IndexWriter per the settings given in conf
.
- IndexWriter.DocStats - Class in org.apache.lucene.index
-
DocStats for this index
- IndexWriter.IndexReaderWarmer - Interface in org.apache.lucene.index
-
If
DirectoryReader.open(IndexWriter)
has
been called (ie, this writer is in near real-time
mode), then after a merge completes, this class can be
invoked to warm the reader on the newly merged
segment, before the merge commits.
- IndexWriterConfig - Class in org.apache.lucene.index
-
Holds all the configuration that is used to create an
IndexWriter
.
- IndexWriterConfig() - Constructor for class org.apache.lucene.index.IndexWriterConfig
-
- IndexWriterConfig(Analyzer) - Constructor for class org.apache.lucene.index.IndexWriterConfig
-
Creates a new config that with the provided
Analyzer
.
- IndexWriterConfig.OpenMode - Enum in org.apache.lucene.index
-
- IndexWriterMaxDocsChanger - Class in org.apache.lucene.index
-
Accessor to make some package protected methods in
IndexWriter
available for testing.
- IndicNormalizationFilter - Class in org.apache.lucene.analysis.in
-
- IndicNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.in.IndicNormalizationFilter
-
- IndicNormalizationFilterFactory - Class in org.apache.lucene.analysis.in
-
- IndicNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.in.IndicNormalizationFilterFactory
-
Creates a new IndicNormalizationFilterFactory
- IndicNormalizer - Class in org.apache.lucene.analysis.in
-
Normalizes the Unicode representation of text in Indian languages.
- IndicNormalizer() - Constructor for class org.apache.lucene.analysis.in.IndicNormalizer
-
- IndonesianAnalyzer - Class in org.apache.lucene.analysis.id
-
Analyzer for Indonesian (Bahasa)
- IndonesianAnalyzer() - Constructor for class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
- IndonesianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
Builds an analyzer with the given stop words
- IndonesianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
Builds an analyzer with the given stop word.
- IndonesianStemFilter - Class in org.apache.lucene.analysis.id
-
- IndonesianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.id.IndonesianStemFilter
-
- IndonesianStemFilter(TokenStream, boolean) - Constructor for class org.apache.lucene.analysis.id.IndonesianStemFilter
-
Create a new IndonesianStemFilter.
- IndonesianStemFilterFactory - Class in org.apache.lucene.analysis.id
-
- IndonesianStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.id.IndonesianStemFilterFactory
-
Creates a new IndonesianStemFilterFactory
- IndonesianStemmer - Class in org.apache.lucene.analysis.id
-
Stemmer for Indonesian.
- IndonesianStemmer() - Constructor for class org.apache.lucene.analysis.id.IndonesianStemmer
-
- InetAddressPoint - Class in org.apache.lucene.document
-
An indexed 128-bit InetAddress
field.
- InetAddressPoint(String, InetAddress) - Constructor for class org.apache.lucene.document.InetAddressPoint
-
Creates a new InetAddressPoint, indexing the
provided address.
- InetAddressRange - Class in org.apache.lucene.document
-
An indexed InetAddress Range Field
- InetAddressRange(String, InetAddress, InetAddress) - Constructor for class org.apache.lucene.document.InetAddressRange
-
Create a new InetAddressRange from min/max value
- infixToString(StringBuilder) - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- InflectionAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
-
Attribute for Kuromoji inflection data.
- InflectionAttributeImpl - Class in org.apache.lucene.analysis.ja.tokenattributes
-
Attribute for Kuromoji inflection data.
- InflectionAttributeImpl() - Constructor for class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
-
- info - Variable in class org.apache.lucene.index.SegmentCommitInfo
-
- info(int) - Method in class org.apache.lucene.index.SegmentInfos
-
- INFO_STREAM_COMPONENT - Static variable in class org.apache.lucene.replicator.IndexAndTaxonomyReplicationHandler
-
- INFO_STREAM_COMPONENT - Static variable in class org.apache.lucene.replicator.IndexReplicationHandler
-
- INFO_STREAM_COMPONENT - Static variable in class org.apache.lucene.replicator.ReplicationClient
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.commongrams.CommonGramsFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.compound.DictionaryCompoundWordTokenFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.compound.HyphenationCompoundWordTokenFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.core.StopFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.core.TypeTokenFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.hunspell.HunspellStemFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizerFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.ja.JapanesePartOfSpeechStopFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizerFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.ko.KoreanTokenizerFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.KeepWordFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.KeywordMarkerFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilterFactory
-
Deprecated.
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.morfologik.MorfologikFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.payloads.DelimitedPayloadTokenFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.phonetic.PhoneticFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.snowball.SnowballPorterFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.synonym.SynonymFilterFactory
-
Deprecated.
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.synonym.SynonymGraphFilterFactory
-
- inform(ResourceLoader) - Method in class org.apache.lucene.analysis.util.ElisionFilterFactory
-
- inform(ResourceLoader) - Method in interface org.apache.lucene.analysis.util.ResourceLoaderAware
-
Initializes this component with the provided ResourceLoader
(used for loading classes, files, etc).
- inform(ResourceLoader) - Method in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilterFactory
-
- INFORMATION_SEPARATOR_MARKER - Static variable in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Example marker character: U+001F (INFORMATION SEPARATOR ONE)
- infos - Variable in class org.apache.lucene.index.FixBrokenOffsets
-
- infos - Variable in class org.apache.lucene.index.IndexSplitter
-
- infos - Variable in class org.apache.lucene.replicator.nrt.CopyState
-
- infosBytes - Variable in class org.apache.lucene.replicator.nrt.CopyState
-
- infoStream - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- infoStream - Variable in class org.apache.lucene.index.MergeScheduler
-
For messages about merge scheduling
- infoStream - Variable in class org.apache.lucene.index.MergeState
-
InfoStream for debugging messages.
- infoStream - Variable in class org.apache.lucene.index.SegmentWriteState
-
- InfoStream - Class in org.apache.lucene.util
-
- InfoStream() - Constructor for class org.apache.lucene.util.InfoStream
-
- INFOSTREAM - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Enables or disables dumping of
InfoStream
messages.
- init() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- init(IndexInput, SegmentReadState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- init(IndexOutput, SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- init(long, int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Initializes the reader, for reuse on a new term.
- init() - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
-
Allocates internal skip buffers.
- init(IndexInput, SegmentReadState) - Method in class org.apache.lucene.codecs.PostingsReaderBase
-
Performs any initialization, such as reading and
verifying the header from the provided terms
dictionary
IndexInput
.
- init(IndexOutput, SegmentWriteState) - Method in class org.apache.lucene.codecs.PostingsWriterBase
-
Called once after startup, before any terms have been
added.
- init(String, Analyzer) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Initializes a query parser.
- init(LeafReaderContext) - Method in class org.apache.lucene.search.DocValuesStats
-
Initializes this object with the given reader context.
- init(LeafReaderContext) - Method in class org.apache.lucene.search.DocValuesStats.NumericDocValuesStats
-
- init(LeafReaderContext) - Method in class org.apache.lucene.search.DocValuesStats.SortedDocValuesStats
-
- init(LeafReaderContext) - Method in class org.apache.lucene.search.DocValuesStats.SortedNumericDocValuesStats
-
- init(LeafReaderContext) - Method in class org.apache.lucene.search.DocValuesStats.SortedSetDocValuesStats
-
- init(TokenStream) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- init(TokenStream) - Method in class org.apache.lucene.search.highlight.QueryTermScorer
-
- init(TokenStream) - Method in interface org.apache.lucene.search.highlight.Scorer
-
- init(Map<String, String>, SpatialContext) - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- init(Map<String, String>, ClassLoader) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dSpatialContextFactory
-
- init() - Method in class org.apache.lucene.util.BytesRefHash.BytesStartArray
-
Initializes the BytesStartArray.
- init() - Method in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-
- initCalculator() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dSpatialContextFactory
-
- initializeMessages(String, Class<? extends NLS>) - Static method in class org.apache.lucene.queryparser.flexible.messages.NLS
-
Initialize a given class with the message bundle Keys Should be called from
a class that extends NLS in a static block at class load time.
- initialValue() - Method in class org.apache.lucene.util.CloseableThreadLocal
-
- initMaxLevels() - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- initPlanetModel(Map<String, String>) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dSpatialContextFactory
-
- initReader(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
-
Override this if you want to add a CharFilter chain.
- initReader(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
- initReader(String, Reader) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
- initReader(String, Reader) - Method in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
- initReader(String, Reader) - Method in class org.apache.lucene.analysis.uk.UkrainianMorfologikAnalyzer
-
- initReaderForNormalization(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
-
Wrap the given
Reader
with
CharFilter
s that make sense
for normalization.
- initReaderForNormalization(String, Reader) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
- initReaderForNormalization(String, Reader) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
- initSearcher(long[]) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- initSize - Variable in class org.apache.lucene.util.BytesRefHash.DirectBytesStartArray
-
- initTransition(int, Transition) - Method in class org.apache.lucene.util.automaton.Automaton
-
Initialize the provided Transition to iterate through all transitions
leaving the specified state.
- inject - Variable in class org.apache.lucene.analysis.phonetic.DaitchMokotoffSoundexFilter
-
true if encoded tokens should be added as synonyms
- INJECT - Static variable in class org.apache.lucene.analysis.phonetic.DaitchMokotoffSoundexFilterFactory
-
parameter name: true if encoded tokens should be added as synonyms
- INJECT - Static variable in class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilterFactory
-
parameter name: true if encoded tokens should be added as synonyms
- inject - Variable in class org.apache.lucene.analysis.phonetic.PhoneticFilter
-
true if encoded tokens should be added as synonyms
- INJECT - Static variable in class org.apache.lucene.analysis.phonetic.PhoneticFilterFactory
-
parameter name: true if encoded tokens should be added as synonyms
- InMemorySorter - Class in org.apache.lucene.search.suggest
-
- InMemorySorter(Comparator<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.InMemorySorter
-
Creates an InMemorySorter, sorting entries by the
provided comparator.
- innerQuery - Variable in class org.apache.lucene.search.suggest.document.ContextQuery
-
Inner completion query
- inOrder - Variable in class org.apache.lucene.search.spans.SpanNearQuery
-
- InPlaceMergeSorter - Class in org.apache.lucene.util
-
Sorter
implementation based on the merge-sort algorithm that merges
in place (no extra memory will be allocated).
- InPlaceMergeSorter() - Constructor for class org.apache.lucene.util.InPlaceMergeSorter
-
- input - Variable in class org.apache.lucene.analysis.CharFilter
-
The underlying character-input stream.
- input - Variable in class org.apache.lucene.analysis.TokenFilter
-
The source of tokens for this filter.
- input - Variable in class org.apache.lucene.analysis.Tokenizer
-
The text source for this Tokenizer.
- input - Variable in class org.apache.lucene.search.suggest.analyzing.FSTUtil.Path
-
Input of the path so far:
- input - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
-
- input - Variable in class org.apache.lucene.util.fst.FSTTester.InputOutput
-
- input - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
-
- input - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-
- input - Variable in class org.apache.lucene.util.fst.Util.Result
-
- input_stream - Variable in class org.apache.lucene.queryparser.classic.QueryParserTokenManager
-
- input_stream - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
- input_stream - Variable in class org.apache.lucene.queryparser.surround.parser.QueryParserTokenManager
-
- inputCount - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- InputIterator - Interface in org.apache.lucene.search.suggest
-
- InputIterator.InputIteratorWrapper - Class in org.apache.lucene.search.suggest
-
Wraps a BytesRefIterator as a suggester InputIterator, with all weights
set to 1
and carries no payload
- InputIteratorWrapper(BytesRefIterator) - Constructor for class org.apache.lucene.search.suggest.InputIterator.InputIteratorWrapper
-
Creates a new wrapper, wrapping the specified iterator and
specifying a weight value of 1
for all terms
and nullifies associated payloads.
- InputOutput() - Constructor for class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
-
- InputOutput(IntsRef, T) - Constructor for class org.apache.lucene.util.fst.FSTTester.InputOutput
-
- InputOutput() - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
-
- inputPos - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- inputStream(Path) - Static method in class org.apache.lucene.benchmark.byTask.utils.StreamUtils
-
Returns an InputStream
over the requested file.
- InputStreamDataInput - Class in org.apache.lucene.store
-
- InputStreamDataInput(InputStream) - Constructor for class org.apache.lucene.store.InputStreamDataInput
-
- inputTokens - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
-
- inputType - Variable in class org.apache.lucene.util.fst.FST
-
- insert(String, char) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Branches are initially compressed, needing one node per key plus the size
of the string key.
- insert(char[], int, char) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- insert(DiversifiedTopDocsCollector.ScoreDocKey, int, NumericDocValues) - Method in class org.apache.lucene.search.DiversifiedTopDocsCollector
-
- insert(TernaryTreeNode, CharSequence, Object, int) - Method in class org.apache.lucene.search.suggest.tst.TSTAutocomplete
-
Inserts a key in TST creating a series of Binary Search Trees at each node.
- insert(int, int, CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
-
- insertBalanced(String[], char[], int, int) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Recursively insert the median first and then the median of the lower and
upper halves, and so on in order to get a balanced tree.
- insertChild(Element, String, String) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
- insertEmptyValue(Iterable<BytesRef>) - Static method in class org.apache.lucene.codecs.MissingOrdRemapper
-
insert an empty byte[] to the front of this iterable
- insertToken() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
-
Call this only from within afterPosition, to insert a new
token.
- insertWithOverflow(T) - Method in class org.apache.lucene.util.PriorityQueue
-
Adds an Object to a PriorityQueue in log(size) time.
- INSTANCE - Static variable in class org.apache.lucene.codecs.bloom.MurmurHash2
-
- INSTANCE - Static variable in class org.apache.lucene.index.NoDeletionPolicy
-
The single instance of this class.
- INSTANCE - Static variable in class org.apache.lucene.index.NoMergePolicy
-
Singleton instance.
- INSTANCE - Static variable in class org.apache.lucene.index.NoMergeScheduler
-
- INSTANCE - Static variable in class org.apache.lucene.search.uhighlight.NoOpOffsetStrategy
-
- INSTANCE - Static variable in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Deprecated.
- INSTANCE - Static variable in class org.apache.lucene.spatial3d.geom.ArcDistance
-
An instance of the ArcDistance DistanceStyle.
- INSTANCE - Static variable in class org.apache.lucene.spatial3d.geom.LinearDistance
-
A convenient instance
- INSTANCE - Static variable in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
A convenient instance
- INSTANCE - Static variable in class org.apache.lucene.spatial3d.geom.NormalDistance
-
A convenient instance
- INSTANCE - Static variable in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
A convenient instance
- INSTANCE - Static variable in class org.apache.lucene.store.NativeFSLockFactory
-
Singleton instance
- INSTANCE - Static variable in class org.apache.lucene.store.NoLockFactory
-
The singleton
- INSTANCE - Static variable in class org.apache.lucene.store.SimpleFSLockFactory
-
Singleton instance
- int4ToLong(int) - Static method in class org.apache.lucene.util.SmallFloat
-
- INT_BLOCK_MASK - Static variable in class org.apache.lucene.util.IntBlockPool
-
- INT_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.IntBlockPool
-
- INT_BLOCK_SIZE - Static variable in class org.apache.lucene.util.IntBlockPool
-
- IntAssociationFacetField - Class in org.apache.lucene.facet.taxonomy
-
Add an instance of this to your
Document
to add
a facet label associated with an int.
- IntAssociationFacetField(int, String, String...) - Constructor for class org.apache.lucene.facet.taxonomy.IntAssociationFacetField
-
Creates this from dim
and path
and an
int association
- intAt(int) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Return the int at the given offset.
- IntBlockPool - Class in org.apache.lucene.util
-
- IntBlockPool() - Constructor for class org.apache.lucene.util.IntBlockPool
-
- IntBlockPool(IntBlockPool.Allocator) - Constructor for class org.apache.lucene.util.IntBlockPool
-
- IntBlockPool.Allocator - Class in org.apache.lucene.util
-
Abstract class for allocating and freeing int
blocks.
- IntBlockPool.DirectAllocator - Class in org.apache.lucene.util
-
- IntBlockPool.SliceReader - Class in org.apache.lucene.util
-
- IntBlockPool.SliceWriter - Class in org.apache.lucene.util
-
- IntComparator(int, String, Integer) - Constructor for class org.apache.lucene.search.FieldComparator.IntComparator
-
Creates a new comparator based on Integer.compare(int, int)
for numHits
.
- IntDocValues - Class in org.apache.lucene.queries.function.docvalues
-
Abstract
FunctionValues
implementation which supports retrieving int values.
- IntDocValues(ValueSource) - Constructor for class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- integer - Variable in class org.apache.lucene.expressions.js.VariableContext
-
The integer value for this piece of the variable.
- IntegerEncoder - Class in org.apache.lucene.analysis.payloads
-
Encode a character array Integer as a
BytesRef
.
- IntegerEncoder() - Constructor for class org.apache.lucene.analysis.payloads.IntegerEncoder
-
- intercept - Variable in class org.apache.lucene.queries.function.valuesource.LinearFloatFunction
-
- interleave(int, int) - Static method in class org.apache.lucene.util.BitUtil
-
Interleaves the first 32 bits of each long value
Adapted from: http://graphics.stanford.edu/~seander/bithacks.html#InterleaveBMN
- INTERNAL_LEVENSHTEIN - Static variable in class org.apache.lucene.search.spell.DirectSpellChecker
-
The default StringDistance, Damerau-Levenshtein distance implemented internally
via
LevenshteinAutomata
.
- INTERNAL_LINK - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- INTERNAL_LINK_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- INTERNAL_SEPARATOR - Static variable in interface org.apache.lucene.analysis.ja.dict.Dictionary
-
- internalComponentRelate(double, double, double, double) - Method in class org.apache.lucene.geo.EdgeTree
-
Returns relation to the provided rectangle for this component
- interpolate(PlanetModel, GeoPoint, GeoPoint, double[]) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Find points on the boundary of the intersection of a plane and the unit sphere,
given a starting point, and ending point, and a list of proportions of the arc (e.g.
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- intersect(PointValues.IntersectVisitor) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingTerms
-
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
-
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.MultiTerms
-
- intersect(PointValues.IntersectVisitor) - Method in class org.apache.lucene.index.PointValues
-
Finds all documents and points matching the provided visitor.
- intersect(CompiledAutomaton) - Method in class org.apache.lucene.index.SortedDocValues
-
- intersect(CompiledAutomaton) - Method in class org.apache.lucene.index.SortedSetDocValues
-
- intersect(CompiledAutomaton, BytesRef) - Method in class org.apache.lucene.index.Terms
-
Returns a TermsEnum that iterates over all terms and
documents that are accepted by the provided
CompiledAutomaton
.
- intersect(PointValues.IntersectVisitor) - Method in class org.apache.lucene.util.bkd.BKDReader
-
- intersection(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton that accepts the intersection of the languages of the
given automata.
- INTERSECTION - Static variable in class org.apache.lucene.util.automaton.RegExp
-
Syntax flag, enables intersection (&).
- intersectionCount(FixedBitSet, FixedBitSet) - Static method in class org.apache.lucene.util.FixedBitSet
-
Returns the popcount or cardinality of the intersection of the two sets.
- intersectIterators(List<DocIdSetIterator>) - Static method in class org.apache.lucene.search.ConjunctionDISI
-
Create a conjunction over the provided DocIdSetIterators.
- intersectPrefixPaths(Automaton, FST<T>) - Static method in class org.apache.lucene.search.suggest.analyzing.FSTUtil
-
Enumerates all minimal prefix paths in the automaton that also intersect the FST,
accumulating the FST end node and output for each path.
- Intersects - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
Meets the "Intersects" OGC definition.
- intersects(GeoShape) - Method in interface org.apache.lucene.spatial3d.geom.GeoAreaShape
-
Assess whether a shape intersects with any of the edges of this shape.
- intersects(Plane, GeoPoint[], Membership...) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
- intersects(Plane, GeoPoint[], Membership...) - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- intersects(GeoShape) - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- intersects(Plane, GeoPoint[], Membership...) - Method in interface org.apache.lucene.spatial3d.geom.GeoShape
-
Assess whether a plane, within the provided bounds, intersects
with the shape's edges.
- intersects(PlanetModel, Plane, GeoPoint[], GeoPoint[], Membership[], Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Determine whether the plane intersects another plane within the
bounds provided.
- intersects(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
-
returns true if the sets have any elements in common
- intersects(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
-
returns true if the sets have any elements in common
- intersectScorers(Collection<Scorer>) - Static method in class org.apache.lucene.search.ConjunctionDISI
-
Create a conjunction over the provided
Scorer
s.
- intersectSpans(List<Spans>) - Static method in class org.apache.lucene.search.ConjunctionDISI
-
Create a conjunction over the provided
Spans
.
- IntersectsPrefixTreeQuery - Class in org.apache.lucene.spatial.prefix
-
A Query matching documents that have an SpatialRelation.INTERSECTS
(i.e.
- IntersectsPrefixTreeQuery(Shape, String, SpatialPrefixTree, int, int) - Constructor for class org.apache.lucene.spatial.prefix.IntersectsPrefixTreeQuery
-
- IntersectsRPTVerifyQuery - Class in org.apache.lucene.spatial.composite
-
A spatial Intersects predicate that distinguishes an approximated match from an exact match based on which cells
are within the query shape.
- IntersectsRPTVerifyQuery(Shape, String, SpatialPrefixTree, int, int, ShapeValuesPredicate) - Constructor for class org.apache.lucene.spatial.composite.IntersectsRPTVerifyQuery
-
- IntersectState(IndexInput, int, int, int, int, PointValues.IntersectVisitor, BKDReader.IndexTree) - Constructor for class org.apache.lucene.util.bkd.BKDReader.IntersectState
-
- intersectsTriangle(int, int, int, int, int, int) - Method in class org.apache.lucene.geo.Rectangle2D
-
Checks if the rectangle intersects the provided triangle
- INTERVAL - Static variable in class org.apache.lucene.util.automaton.RegExp
-
Syntax flag, enables numerical intervals (
<n-m>).
- IntervalFilter - Class in org.apache.lucene.search.intervals
-
- IntervalFilter(IntervalIterator) - Constructor for class org.apache.lucene.search.intervals.IntervalFilter
-
Create a new filter
- IntervalIterator - Class in org.apache.lucene.search.intervals
-
A
DocIdSetIterator
that also allows iteration over matching
intervals in a document.
- IntervalIterator() - Constructor for class org.apache.lucene.search.intervals.IntervalIterator
-
- IntervalQuery - Class in org.apache.lucene.search.intervals
-
A query that retrieves documents containing intervals returned from an
IntervalsSource
Static constructor functions for various different sources can be found in the
Intervals
class
- IntervalQuery(String, IntervalsSource) - Constructor for class org.apache.lucene.search.intervals.IntervalQuery
-
Create a new IntervalQuery
- Intervals - Class in org.apache.lucene.search.intervals
-
- intervals(String, LeafReaderContext) - Method in class org.apache.lucene.search.intervals.IntervalsSource
-
Create an
IntervalIterator
exposing the minimum intervals defined by this
IntervalsSource
Returns
null
if no intervals for this field exist in this segment
- IntervalsSource - Class in org.apache.lucene.search.intervals
-
A helper class for
IntervalQuery
that provides an
IntervalIterator
for a given field and segment
Static constructor functions for various different sources can be found in the
Intervals
class
- IntervalsSource() - Constructor for class org.apache.lucene.search.intervals.IntervalsSource
-
- intField(FieldInfo, int) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- intField(FieldInfo, int) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
- intField(FieldInfo, int) - Method in class org.apache.lucene.index.StoredFieldVisitor
-
Process a int numeric field.
- IntFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- IntFieldSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.IntFieldSource
-
- intOffset - Variable in class org.apache.lucene.util.IntBlockPool
-
Current head offset
- IntPoint - Class in org.apache.lucene.document
-
An indexed int
field for fast range filters.
- IntPoint(String, int...) - Constructor for class org.apache.lucene.document.IntPoint
-
Creates a new IntPoint, indexing the
provided N-dimensional int point.
- IntRange - Class in org.apache.lucene.document
-
An indexed Integer Range field.
- IntRange(String, int[], int[]) - Constructor for class org.apache.lucene.document.IntRange
-
Create a new IntRange type, from min/max parallel arrays
- IntroSelector - Class in org.apache.lucene.util
-
Implementation of the quick select algorithm.
- IntroSelector() - Constructor for class org.apache.lucene.util.IntroSelector
-
- introSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice using the Comparator
.
- introSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array using the Comparator
.
- introSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice in natural order.
- introSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array in natural order.
- introSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access List
using the Comparator
.
- introSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access List
in natural order.
- IntroSorter - Class in org.apache.lucene.util
-
Sorter
implementation based on a variant of the quicksort algorithm
called
introsort: when
the recursion level exceeds the log of the length of the array to sort, it
falls back to heapsort.
- IntroSorter() - Constructor for class org.apache.lucene.util.IntroSorter
-
- ints - Variable in class org.apache.lucene.util.IntsRef
-
The contents of the IntsRef.
- ints() - Method in class org.apache.lucene.util.IntsRefBuilder
-
Return a reference to the ints of this builder.
- intsEquals(IntsRef) - Method in class org.apache.lucene.util.IntsRef
-
- IntSequenceOutputs - Class in org.apache.lucene.util.fst
-
An FST
Outputs
implementation where each output
is a sequence of ints.
- IntsRef - Class in org.apache.lucene.util
-
Represents int[], as a slice (offset + length) into an
existing int[].
- IntsRef() - Constructor for class org.apache.lucene.util.IntsRef
-
- IntsRef(int) - Constructor for class org.apache.lucene.util.IntsRef
-
Create a IntsRef pointing to a new array of size capacity
.
- IntsRef(int[], int, int) - Constructor for class org.apache.lucene.util.IntsRef
-
This instance will directly reference ints w/o making a copy.
- IntsRefBuilder - Class in org.apache.lucene.util
-
- IntsRefBuilder() - Constructor for class org.apache.lucene.util.IntsRefBuilder
-
Sole constructor.
- IntsRefFSTEnum<T> - Class in org.apache.lucene.util.fst
-
Enumerates all input (IntsRef) + output pairs in an
FST.
- IntsRefFSTEnum(FST<T>) - Constructor for class org.apache.lucene.util.fst.IntsRefFSTEnum
-
doFloor controls the behavior of advance: if it's true
doFloor is true, advance positions to the biggest
term before target.
- IntsRefFSTEnum.InputOutput<T> - Class in org.apache.lucene.util.fst
-
Holds a single input (IntsRef) + output pair.
- intsRefToBytesRef(IntsRef) - Static method in class org.apache.lucene.util.StringHelper
-
Just converts each int in the incoming
IntsRef
to each byte
in the returned
BytesRef
, throwing
IllegalArgumentException
if any int value is out of bounds for a byte.
- IntTaxonomyFacets - Class in org.apache.lucene.facet.taxonomy
-
Base class for all taxonomy-based facets that aggregate
to a per-ords int[].
- IntTaxonomyFacets(String, TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.IntTaxonomyFacets
-
Sole constructor.
- intToByte4(int) - Static method in class org.apache.lucene.util.SmallFloat
-
Encode an integer to a byte.
- intToBytesRef(int) - Static method in class org.apache.lucene.facet.taxonomy.IntAssociationFacetField
-
Encodes an
int
as a 4-byte
BytesRef
,
big-endian.
- intToEnglish(int) - Static method in class org.apache.lucene.util.English
-
- intToEnglish(int, StringBuilder) - Static method in class org.apache.lucene.util.English
-
- intToSortableBytes(int, byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
-
Encodes an integer value
such that unsigned byte order comparison
is consistent with Integer.compare(int, int)
- intUpto - Variable in class org.apache.lucene.util.IntBlockPool
-
Pointer to the current position in head buffer
- intVal(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- intVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- intVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- intVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- intVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- intVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- intVal(int, int[]) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- INVALID_ORDINAL - Static variable in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Ordinals are always non-negative, so a negative ordinal can be used to
signify an error.
- INVALID_ORDINAL - Static variable in class org.apache.lucene.facet.taxonomy.writercache.LabelToOrdinal
-
- INVALID_SYNTAX - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- INVALID_SYNTAX_CANNOT_PARSE - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- INVALID_SYNTAX_ESCAPE_CHARACTER - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- INVALID_SYNTAX_ESCAPE_NONE_HEX_UNICODE - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- INVALID_SYNTAX_ESCAPE_UNICODE_TRUNCATION - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- INVALID_SYNTAX_FUZZY_EDITS - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- INVALID_SYNTAX_FUZZY_LIMITS - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- InvalidTokenOffsetsException - Exception in org.apache.lucene.search.highlight
-
Exception thrown if TokenStream Tokens are incompatible with provided text
- InvalidTokenOffsetsException(String) - Constructor for exception org.apache.lucene.search.highlight.InvalidTokenOffsetsException
-
- inverseAb - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The inverse of ab
- inverseAbSquared - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The square of the inverse of ab
- inverseC - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The inverse of c
- inverseCSquared - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The square of the inverse of c
- inverseScale - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The inverse of scale
- IOContext - Class in org.apache.lucene.store
-
IOContext holds additional details on the merge/search context.
- IOContext() - Constructor for class org.apache.lucene.store.IOContext
-
- IOContext(FlushInfo) - Constructor for class org.apache.lucene.store.IOContext
-
- IOContext(IOContext.Context) - Constructor for class org.apache.lucene.store.IOContext
-
- IOContext(MergeInfo) - Constructor for class org.apache.lucene.store.IOContext
-
- IOContext(IOContext, boolean) - Constructor for class org.apache.lucene.store.IOContext
-
This constructor is used to initialize a
IOContext
instance with a new value for the readOnce variable.
- IOContext.Context - Enum in org.apache.lucene.store
-
Context is a enumerator which specifies the context in which the Directory
is being used for.
- IOStats() - Constructor for class org.apache.lucene.index.BaseMergePolicyTestCase.IOStats
-
- IOSupplier<T> - Interface in org.apache.lucene.util
-
This is a result supplier that is allowed to throw an IOException.
- IOUtils - Class in org.apache.lucene.util
-
This class emulates the new Java 7 "Try-With-Resources" statement.
- IOUtils.IOConsumer<T> - Interface in org.apache.lucene.util
-
An IO operation with a single input.
- IrishAnalyzer - Class in org.apache.lucene.analysis.ga
-
- IrishAnalyzer() - Constructor for class org.apache.lucene.analysis.ga.IrishAnalyzer
-
- IrishAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.ga.IrishAnalyzer
-
Builds an analyzer with the given stop words.
- IrishAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.ga.IrishAnalyzer
-
Builds an analyzer with the given stop words.
- IrishLowerCaseFilter - Class in org.apache.lucene.analysis.ga
-
Normalises token text to lower case, handling t-prothesis
and n-eclipsis (i.e., that 'nAthair' should become 'n-athair')
- IrishLowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ga.IrishLowerCaseFilter
-
Create an IrishLowerCaseFilter that normalises Irish token text.
- IrishLowerCaseFilterFactory - Class in org.apache.lucene.analysis.ga
-
- IrishLowerCaseFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ga.IrishLowerCaseFilterFactory
-
Creates a new IrishLowerCaseFilterFactory
- IrishStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- IrishStemmer() - Constructor for class org.tartarus.snowball.ext.IrishStemmer
-
- is(SpatialOperation, SpatialOperation...) - Static method in class org.apache.lucene.spatial.query.SpatialOperation
-
- isAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Returns true if this merge was or should be aborted.
- isAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
-
Return the aborted state of this merge.
- isAbsolute() - Method in class org.apache.lucene.mockfile.FilterPath
-
- isAccept(int) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Returns true if this state is an accept state.
- isAccept(int) - Method in class org.apache.lucene.util.automaton.Automaton
-
Returns true if this state is an accept state.
- isAccept(int) - Method in class org.apache.lucene.util.automaton.RunAutomaton
-
Returns acceptance status for given state.
- isArabicNumeral(char) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Arabic numeral predicate.
- isAssumption(Throwable) - Static method in class org.apache.lucene.util.TestRuleMarkFailure
-
Is a given exception (or a MultipleFailureException) an
AssumptionViolatedException
?
- isAutomatonBinary() - Method in class org.apache.lucene.search.AutomatonQuery
-
Is this a binary (byte) oriented automaton.
- isBoost() - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Returns whether to boost terms in query based on "score" or not.
- isBoundary(int) - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- isCacheable(LeafReaderContext, String...) - Static method in class org.apache.lucene.index.DocValues
-
Returns true
if the specified docvalues fields have not been updated
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.queries.function.FunctionQuery.FunctionWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.FilterWeight
-
- isCacheable(LeafReaderContext) - Method in interface org.apache.lucene.search.SegmentCacheable
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.AssertingSpanWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanContainingQuery.SpanContainingWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanNearQuery.SpanNearWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanNotQuery.SpanNotWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanOrQuery.SpanOrWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery.SpanPositionCheckWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanTermQuery.SpanTermWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanWithinQuery.SpanWithinWeight
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.search.suggest.document.CompletionWeight
-
This object can be cached
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.util.CachingDoubleValueSource
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.util.DistanceToShapeValueSource
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.util.ReciprocalDoubleValuesSource
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.util.ShapeAreaValueSource
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.util.ShapeFieldCacheDistanceValueSource
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.util.ShapeValuesPredicate
-
- isCacheable(LeafReaderContext) - Method in class org.apache.lucene.spatial.vector.DistanceValueSource
-
- isCached() - Method in class org.apache.lucene.analysis.CachingTokenFilter
-
If the underlying token stream was consumed and cached.
- isCached() - Method in class org.apache.lucene.search.CachingCollector
-
Return true is this collector is able to replay collection.
- isCachedTokenStream() - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- isCheckPendingFlushOnUpdate() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Expert: Returns if indexing threads check for pending flushes on update in order
to help our flushing indexing buffers to disk
- isClosed() - Method in class org.apache.lucene.replicator.http.HttpClientBase
-
Returns true iff this instance was
closed
, otherwise
returns false.
- isClosed() - Method in class org.apache.lucene.replicator.nrt.Node
-
- isClosed() - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
- isClosed() - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- isCollapsable() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
Return true if can be collapsed in case it is outermost sequence
- isCompiled() - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- isComplete - Variable in class org.apache.lucene.util.fst.Util.TopResults
-
true
iff this is a complete result ie.
- isCopying() - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- isCurrent() - Method in class org.apache.lucene.index.DirectoryReader
-
Check whether any new changes have occurred to the
index since this reader was opened.
- isCurrent() - Method in class org.apache.lucene.index.FilterDirectoryReader
-
- isCurrent() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- isDefaultBooleanQueryNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- isDefaultField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
This method is use toQueryString to detect if fld is the default field
- isDeleted() - Method in class org.apache.lucene.index.IndexCommit
-
- isDeterministic() - Method in class org.apache.lucene.util.automaton.Automaton
-
Returns true if this automaton is deterministic (for ever state
there is only one transition for each label).
- isDeterministicSlow(Automaton) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Returns true if the automaton is deterministic.
- isDisableCounting() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Return true if counting is disabled for this task.
- isDiscreteMultiValueHighlighting() - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- isDisjoint(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- IsDisjointTo - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
Meets the "Disjoint" OGC definition.
- isEarlyTerminated() - Method in class org.apache.lucene.search.TopFieldCollector
-
Return whether collection terminated early.
- isEmpty() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- isEmpty() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
-
to know whether the stack is empty
- isEmpty() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- isEmpty() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- isEmpty() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- isEmpty(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if the given automaton accepts no strings.
- isEmpty() - Method in class org.apache.lucene.util.WeakIdentityMap
-
Returns true
if this map contains no key-value mappings.
- isEnabled() - Method in class org.apache.lucene.mockfile.VirusCheckingFS
-
- isEnabled(String) - Method in class org.apache.lucene.util.FailOnNonBulkMergesInfoStream
-
- isEnabled(String) - Method in class org.apache.lucene.util.InfoStream
-
- isEnabled(String) - Method in class org.apache.lucene.util.NullInfoStream
-
- isEnabled(String) - Method in class org.apache.lucene.util.PrintStreamInfoStream
-
- isEnableTestPoints() - Method in class org.apache.lucene.index.IndexWriter
-
Tests should override this to enable test points.
- isEnd(int, int) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- isEnforced() - Method in class org.apache.lucene.util.TestRuleLimitSysouts
-
- isEqual(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- IsEqualTo - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
Meets the "Equals" OGC definition.
- isExpandMultiTermQuery() - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- isExplicitLuceneMatchVersion() - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- isExternal - Variable in class org.apache.lucene.store.MergeInfo
-
- isExtra(String) - Static method in class org.apache.lucene.mockfile.ExtrasFS
-
- isFieldMatch() - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
return whether fieldMatch or not.
- isFieldsSubQueryAcceptable() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- isFieldsSubQueryAcceptable() - Method in class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- isFieldsSubQueryAcceptable() - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- isFinal - Variable in class org.apache.lucene.util.fst.Builder.Arc
-
- isFinal - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- isFinal() - Method in class org.apache.lucene.util.fst.FST.Arc
-
- isFinite(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if the language of this automaton is finite.
- isFiniteSlow(Automaton) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Returns true if the language of this automaton is finite.
- isFull() - Method in class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
- isFull() - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
- isFull() - Method in class org.apache.lucene.facet.taxonomy.writercache.UTF8TaxonomyWriterCache
-
- isFunctionallyIdentical(Plane) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Returns true if this plane and the other plane are functionally identical within the margin of error.
- isGramType() - Method in class org.apache.lucene.analysis.commongrams.CommonGramsQueryFilter
-
Convenience method to check if the current type is a gram type
- isGreedy() - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Checks if this time limited collector is greedy in collecting the last hit.
- isGridAlignedShape(Shape) - Method in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy
-
- isGridAlignedShape(Shape) - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
A quick check of the shape to see if it is perfectly aligned to a grid.
- isGroup(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- isGroup(char) - Method in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- isHangul(char) - Method in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- isHanja(char) - Method in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- isHidden(Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- isIdentical(GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Compute whether point matches another.
- isIdentical(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Compute whether point matches another.
- isIgnoreCase() - Method in class org.apache.lucene.analysis.commongrams.CommonGramsFilterFactory
-
- isIgnoreCase() - Method in class org.apache.lucene.analysis.core.StopFilterFactory
-
- isIgnoreCase() - Method in class org.apache.lucene.analysis.miscellaneous.KeepWordFilterFactory
-
- isIgnoreCase() - Method in class org.apache.lucene.analysis.miscellaneous.KeywordMarkerFilterFactory
-
- isIgnoreCase() - Method in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- isIgnoreCase() - Method in class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilterFactory
-
- isIgnoreCase() - Method in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilterFactory
-
Whether or not to ignore case
- isIgnoreTF() - Method in class org.apache.lucene.sandbox.queries.FuzzyLikeThisQuery
-
- isIncludeLower() - Method in class org.apache.lucene.queries.function.FunctionRangeQuery
-
- isIncludeUpper() - Method in class org.apache.lucene.queries.function.FunctionRangeQuery
-
- isIndexTerm(BytesRef, TermStats) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter.EveryNOrDocFreqTermSelector
-
- isIndexTerm(BytesRef, TermStats) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter.EveryNTermSelector
-
- isIndexTerm(BytesRef, TermStats) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter.IndexTermSelector
-
Called sequentially on every term being written,
returning true if this term should be indexed
- isInOrder() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- isInOrder() - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
Return true if matches are required to be in-order.
- isInternalPrefix(PackedQuadPrefixTree.PackedQuadCell) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- isInvoke(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- isInvoke(char) - Method in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- isKanji(char) - Method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- isKeyword() - Method in class org.apache.lucene.analysis.miscellaneous.KeywordMarkerFilter
-
- isKeyword() - Method in class org.apache.lucene.analysis.miscellaneous.PatternKeywordMarkerFilter
-
- isKeyword() - Method in class org.apache.lucene.analysis.miscellaneous.SetKeywordMarkerFilter
-
- isKeyword() - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
-
Returns true
if the current token is a keyword, otherwise
false
- isKeyword() - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-
- isKnown() - Method in class org.apache.lucene.analysis.ja.Token
-
Returns true if this token is known word
- isKnown() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
Returns true if this token is known word
- isLargestMaxX(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return true if maxX is as large as the planet model allows.
- isLargestMaxY(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return true if maxY is as large as the planet model allows.
- isLargestMaxZ(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return true if maxZ is as large as the planet model allows.
- isLast() - Method in class org.apache.lucene.util.fst.FST.Arc
-
- isLeaf() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
verify if a node is a Leaf node
- isLeaf() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- isLeaf() - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Some cells are flagged as leaves, which are indexed as such.
- isLeaf - Variable in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- isLeaf() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- isLeaf() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- isLeafNode() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- isLeafNode(int) - Method in class org.apache.lucene.util.bkd.BKDReader
-
- isLowerInclusive() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.RangeQueryNode
-
- isLowerInclusive() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
Returns whether the lower bound is inclusive or exclusive.
- isMatch() - Method in class org.apache.lucene.search.Explanation
-
Indicates whether or not this Explanation models a match.
- isMerged(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
-
Returns true if the number of segments eligible for
merging is less than or equal to the specified maxNumSegments
.
- isMerged(SegmentInfos, SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
-
Returns true if this single info is already fully merged (has no
pending deletes, is in the same dir as the
writer, and matches the current compound file setting
- isMissing - Variable in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- isMultiOverlappingIndexedShapes() - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- isMyEvilException(Throwable) - Static method in class org.apache.lucene.analysis.MockReaderWrapper
-
- isNewFragment() - Method in interface org.apache.lucene.search.highlight.Fragmenter
-
Test to see if this token from the stream should be held in a new
TextFragment.
- isNewFragment() - Method in class org.apache.lucene.search.highlight.NullFragmenter
-
- isNewFragment() - Method in class org.apache.lucene.search.highlight.SimpleFragmenter
-
- isNewFragment() - Method in class org.apache.lucene.search.highlight.SimpleSpanFragmenter
-
- isNormWrapLongitude() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- isNumeral(String) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Numeral predicate
- isNumeral(char) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Numeral predicate
- isNumeralPunctuation(String) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Numeral punctuation predicate
- isNumeralPunctuation(char) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Numeral punctuation predicate
- isNumericallyIdentical(Plane) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Returns true if this plane and the other plane are identical within the margin of error.
- isNumericallyIdentical(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute whether two vectors are numerically identical.
- isNumericallyIdentical(Vector) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute whether two vectors are numerically identical.
- isOffsetOverlap(FieldPhraseList.WeightedPhraseInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- isOK(Throwable) - Method in class org.apache.lucene.index.SuppressingConcurrentMergeScheduler
-
- isOpen() - Method in class org.apache.lucene.index.IndexWriter
-
Returns true
if this IndexWriter
is still open.
- isOpen() - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- isOpen() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- isOpen() - Method in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
- isOpen - Variable in class org.apache.lucene.store.BaseDirectory
-
- isOpen - Variable in class org.apache.lucene.store.BaseDirectoryWrapper
-
- isOpen() - Method in class org.apache.lucene.store.BaseDirectoryWrapper
-
- isOperatorInfix() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- isOptimizePredicates() - Method in class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
- isOutputUnigrams() - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- isOutputUnigramsIfNoShingles() - Method in class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- isOverriddenAsOf(Class<? extends C>) - Method in class org.apache.lucene.util.VirtualMethod
-
Returns, if this method is overridden/implemented in the inheritance path between
baseClass
and the given subclass subclazz
.
- isParallel() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- isParallel(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute whether two vectors are parallel.
- isParallel(Vector) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute whether two vectors are numerically identical.
- isParentClassLoader(ClassLoader, ClassLoader) - Static method in class org.apache.lucene.util.SPIClassIterator
-
Utility method to check if some class loader is a (grand-)parent of or the same as another one.
- isPhraseHighlight() - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
return whether phraseHighlight or not.
- isPointShape(Shape) - Method in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy
-
- isPointShape(Shape) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
Returns true if the shape
is a Point
.
- isPointsOnly() - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- isPositionSensitive() - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
-
- isPostingsEnumReuseImplemented() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- isPrefixOf(Cell) - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Returns if the target term is within/underneath this cell; not necessarily a direct
descendant.
- isPrefixOf(Cell) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- isPrefixOf(Cell) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- isPrefixOf(Cell) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- isPreserveOriginal() - Method in class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilter
-
Does the filter preserve the original tokens?
- isProhibited() - Method in class org.apache.lucene.search.BooleanClause
-
- isPruneLeafyBranches() - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- isPruneLeafyBranches() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- isQueryUnsupported(Class<? extends Query>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- isReadOnly() - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- isReadOnly() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- isRelevant(String, QualityQuery) - Method in interface org.apache.lucene.benchmark.quality.Judge
-
Judge if document docName
is relevant for the given quality query.
- isRelevant(String, QualityQuery) - Method in class org.apache.lucene.benchmark.quality.trec.TrecJudge
-
- isRequired() - Method in class org.apache.lucene.search.BooleanClause
-
- isRoot() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- isRunningNested() - Static method in class org.apache.lucene.util.TestRuleIgnoreTestSuites
-
Check if a suite class is running as a nested test.
- isSafeEnd(char) - Method in class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
For sentence tokenization, these are the unambiguous break positions.
- isSameFile(Path, Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- isSaturated(FuzzySet, FieldInfo) - Method in class org.apache.lucene.codecs.bloom.BloomFilterFactory
-
Used to determine if the given filter has reached saturation and should be retired i.e.
- isSaturated(FuzzySet, FieldInfo) - Method in class org.apache.lucene.codecs.bloom.DefaultBloomFilterFactory
-
- isScoring() - Method in class org.apache.lucene.search.BooleanClause
-
- isSearcherCurrent() - Method in class org.apache.lucene.search.SearcherManager
-
Returns true
if no changes have occured since this searcher
ie.
- isShutdown() - Method in class org.apache.lucene.util.SameThreadExecutorService
-
- isSingleValued(Iterable<Number>) - Static method in class org.apache.lucene.codecs.DocValuesConsumer
-
Helper: returns true if the given docToValue count contains only at most one value
- isSmallestMinX(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return true if minX is as small as the planet model allows.
- isSmallestMinY(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return true if minY is as small as the planet model allows.
- isSmallestMinZ(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
Return true if minZ is as small as the planet model allows.
- isSoftDeletesField() - Method in class org.apache.lucene.index.FieldInfo
-
Returns true if this field is configured and used as the soft-deletes field.
- isSphere() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Does this planet model describe a sphere?
- isSupported(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
-
Tests whether the provided number of bits per value is supported by the
format.
- isSystemStream() - Method in class org.apache.lucene.util.PrintStreamInfoStream
-
- isTerminal() - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
-
- isTerminated() - Method in class org.apache.lucene.util.SameThreadExecutorService
-
- isTestThread() - Method in class org.apache.lucene.util.LuceneTestCase
-
Returns true if and only if the calling thread is the primary thread
executing the test case.
- isTimeoutEnabled() - Method in interface org.apache.lucene.index.QueryTimeout
-
Returns true if timeouts are enabled for this query (i.e.
- isTokenChar(int) - Method in class org.apache.lucene.analysis.core.LetterTokenizer
-
Collects only characters which satisfy
Character.isLetter(int)
.
- isTokenChar(int) - Method in class org.apache.lucene.analysis.core.UnicodeWhitespaceTokenizer
-
Collects only characters which do not satisfy Unicode's WHITESPACE property.
- isTokenChar(int) - Method in class org.apache.lucene.analysis.core.WhitespaceTokenizer
-
Collects only characters which do not satisfy
Character.isWhitespace(int)
.
- isTokenChar(int) - Method in class org.apache.lucene.analysis.MockTokenizer
-
- isTokenChar(int) - Method in class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Only collect characters which satisfy this condition.
- isTokenChar(int) - Method in class org.apache.lucene.analysis.util.CharTokenizer
-
Returns true iff a codepoint should be included in a token.
- isTopLevel - Variable in class org.apache.lucene.index.IndexReaderContext
-
true
if this context struct represents the top level reader within the hierarchical context
- isTotal(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if the given automaton accepts all strings.
- isTotal(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if the given automaton accepts all strings for the specified min/max
range of the alphabet.
- isTranspositions() - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Return whether transpositions count as a single edit
- isUnicodeAware() - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
Return true if lengths are measured in unicode code-points rather than bytes
- isUnknown() - Method in class org.apache.lucene.analysis.ja.Token
-
Returns true if this token is unknown word
- isUnknown() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
Returns true if this token is unknown word
- isUpdateThreadAlive() - Method in class org.apache.lucene.replicator.ReplicationClient
-
Returns true if the update thread is alive.
- isUpperInclusive() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.RangeQueryNode
-
- isUpperInclusive() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
Returns whether the upper bound is inclusive or exclusive.
- isUsePayloads() - Method in class org.apache.lucene.search.highlight.QueryScorer
-
Whether or not we should capture payloads in
MemoryIndex
at each position so that queries can access them.
- isUsePayloads() - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- isUser() - Method in class org.apache.lucene.analysis.ja.Token
-
Returns true if this token is defined in user dictionary
- isUser() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
Returns true if this token is defined in user dictionary
- isValid() - Method in class org.apache.lucene.util.BytesRef
-
Performs internal consistency checks.
- isValid() - Method in class org.apache.lucene.util.CharsRef
-
Performs internal consistency checks.
- isValid() - Method in class org.apache.lucene.util.IntsRef
-
Performs internal consistency checks.
- isValid() - Method in class org.apache.lucene.util.LongsRef
-
Performs internal consistency checks.
- isValidTermOrPhrase(List<FieldTermStack.TermInfo>) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
-
- isWeighted() - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- isWide() - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Signal that the shape exceeds Math.PI in longitude.
- isWide() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- isWide() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- isWithin(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- IsWithin - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
Meets the "CoveredBy" OGC definition (boundary-neutral).
- isWithin(Vector) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
- isWithin(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
- isWithin(Vector) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseDistanceShape
-
- isWithin(Vector) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseMembershipShape
-
- isWithin(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- isWithin(Vector) - Method in interface org.apache.lucene.spatial3d.geom.Membership
-
Check if a point is within this shape.
- isWithin(double, double, double) - Method in interface org.apache.lucene.spatial3d.geom.Membership
-
Check if a point is within this shape.
- isWithin(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.SidedPlane
-
- isWithin(Membership[], Membership...) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Determine if this vector, taken from the origin,
describes a point within a set of planes.
- ItalianAnalyzer - Class in org.apache.lucene.analysis.it
-
- ItalianAnalyzer() - Constructor for class org.apache.lucene.analysis.it.ItalianAnalyzer
-
- ItalianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.it.ItalianAnalyzer
-
Builds an analyzer with the given stop words.
- ItalianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.it.ItalianAnalyzer
-
Builds an analyzer with the given stop words.
- ItalianLightStemFilter - Class in org.apache.lucene.analysis.it
-
- ItalianLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.it.ItalianLightStemFilter
-
- ItalianLightStemFilterFactory - Class in org.apache.lucene.analysis.it
-
- ItalianLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.it.ItalianLightStemFilterFactory
-
Creates a new ItalianLightStemFilterFactory
- ItalianLightStemmer - Class in org.apache.lucene.analysis.it
-
Light Stemmer for Italian.
- ItalianLightStemmer() - Constructor for class org.apache.lucene.analysis.it.ItalianLightStemmer
-
- ItalianStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- ItalianStemmer() - Constructor for class org.tartarus.snowball.ext.ItalianStemmer
-
- ITALICS - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- ITALICS_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- iterator() - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
-
- iterator() - Method in class org.apache.lucene.analysis.CharArraySet
-
Returns an Iterator
for char[]
instances in this set.
- Iterator() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
-
- Iterator(Path) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
-
- iterator() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- iterator() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- iterator() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- iterator() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- iterator() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- iterator() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- iterator() - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- iterator() - Method in class org.apache.lucene.document.Document
-
- iterator() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingFields
-
- iterator() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingTerms
-
- iterator() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTerms
-
- iterator() - Method in class org.apache.lucene.index.FieldInfos
-
Returns an iterator over all the fieldinfo objects present,
ordered by ascending field number
- iterator() - Method in class org.apache.lucene.index.Fields
-
Returns an iterator that will step through all fields
names.
- iterator() - Method in class org.apache.lucene.index.FilterLeafReader.FilterFields
-
- iterator() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
- iterator() - Method in class org.apache.lucene.index.MultiFields
-
- iterator() - Method in class org.apache.lucene.index.MultiTerms
-
- iterator() - Method in class org.apache.lucene.index.PrefixCodedTerms
-
- iterator() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns an unmodifiable Iterator
of contained segments in order.
- iterator() - Method in class org.apache.lucene.index.Terms
-
Returns an iterator that will step through all
terms.
- iterator() - Method in class org.apache.lucene.mockfile.FilterDirectoryStream
-
- iterator() - Method in class org.apache.lucene.mockfile.FilterPath
-
- iterator() - Method in class org.apache.lucene.queries.function.FunctionQuery.AllScorer
-
- iterator() - Method in class org.apache.lucene.queries.function.ValueSourceScorer
-
- iterator() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- iterator() - Method in class org.apache.lucene.search.AssertingScorer
-
- iterator() - Method in class org.apache.lucene.search.BooleanQuery
-
Returns an iterator on the clauses in this query.
- iterator() - Method in class org.apache.lucene.search.BulkScorerWrapperScorer
-
- iterator() - Method in class org.apache.lucene.search.ConstantScoreScorer
-
- iterator() - Method in class org.apache.lucene.search.DisiPriorityQueue
-
- iterator - Variable in class org.apache.lucene.search.DisiWrapper
-
- iterator() - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
- iterator() - Method in class org.apache.lucene.search.DocIdSet
-
- iterator() - Method in class org.apache.lucene.search.FilterScorer
-
- iterator() - Method in class org.apache.lucene.search.Scorer
-
- iterator() - Method in class org.apache.lucene.search.spans.SpanScorer
-
- iterator() - Method in interface org.apache.lucene.search.suggest.fst.BytesRefSorter
-
- iterator() - Method in class org.apache.lucene.search.suggest.fst.ExternalRefSorter
-
- iterator() - Method in class org.apache.lucene.search.suggest.InMemorySorter
-
- iterator(LeafReaderContext, DocIdSetIterator) - Method in class org.apache.lucene.spatial.util.ShapeValuesPredicate
-
- iterator() - Method in class org.apache.lucene.util.BitDocIdSet
-
- iterator() - Method in class org.apache.lucene.util.BytesRefArray
-
- iterator(Comparator<BytesRef>) - Method in class org.apache.lucene.util.BytesRefArray
-
- iterator() - Method in class org.apache.lucene.util.fst.Util.TopResults
-
- iterator() - Method in class org.apache.lucene.util.NamedSPILoader
-
- iterator() - Method in class org.apache.lucene.util.NotDocIdSet
-
- iterator() - Method in class org.apache.lucene.util.packed.PackedLongValues
-
Return an iterator over the values of this array.
- iterator() - Method in class org.apache.lucene.util.PriorityQueue
-
- iterator() - Method in class org.apache.lucene.util.RoaringDocIdSet
-
- label - Variable in class org.apache.lucene.facet.LabelAndValue
-
Facet's label.
- label - Variable in class org.apache.lucene.facet.range.Range
-
Label that identifies this range.
- label - Variable in class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetField
-
Label.
- label - Variable in class org.apache.lucene.util.fst.Builder.Arc
-
- label - Variable in class org.apache.lucene.util.fst.FST.Arc
-
- LabelAndValue - Class in org.apache.lucene.facet
-
Single label and its value, usually contained in a
FacetResult
.
- LabelAndValue(String, Number) - Constructor for class org.apache.lucene.facet.LabelAndValue
-
Sole constructor.
- LabelToOrdinal - Class in org.apache.lucene.facet.taxonomy.writercache
-
Abstract class for storing Label->Ordinal mappings in a taxonomy.
- LabelToOrdinal() - Constructor for class org.apache.lucene.facet.taxonomy.writercache.LabelToOrdinal
-
Default constructor.
- labelValues - Variable in class org.apache.lucene.facet.FacetResult
-
Child counts.
- LAM - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- lambda - Variable in class org.apache.lucene.search.similarities.IBSimilarity
-
The lambda (λw) parameter.
- Lambda - Class in org.apache.lucene.search.similarities
-
The lambda (λw) parameter in information-based
models.
- Lambda() - Constructor for class org.apache.lucene.search.similarities.Lambda
-
Sole constructor.
- lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.Lambda
-
Computes the lambda parameter.
- lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaDF
-
- lambda(BasicStats) - Method in class org.apache.lucene.search.similarities.LambdaTTF
-
- LambdaDF - Class in org.apache.lucene.search.similarities
-
Computes lambda as docFreq+1 / numberOfDocuments+1
.
- LambdaDF() - Constructor for class org.apache.lucene.search.similarities.LambdaDF
-
Sole constructor: parameter-free
- LambdaTTF - Class in org.apache.lucene.search.similarities
-
Computes lambda as totalTermFreq+1 / numberOfDocuments+1
.
- LambdaTTF() - Constructor for class org.apache.lucene.search.similarities.LambdaTTF
-
Sole constructor: parameter-free
- last() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- last() - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- last() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- last() - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- last() - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- lastApproxMatchDoc - Variable in class org.apache.lucene.search.DisiWrapper
-
- lastApproxNonMatchDoc - Variable in class org.apache.lucene.search.DisiWrapper
-
- lastCommit - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
-
- lastFileMetaData - Variable in class org.apache.lucene.replicator.nrt.Node
-
File metadata for last sync that succeeded; we use this as a cache
- lastIndexOf(Object) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- lastNRTFiles - Variable in class org.apache.lucene.replicator.nrt.ReplicaNode
-
IncRef'd files in the current NRT point:
- lastPrimaryGen - Variable in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Primary gen last time we successfully replicated:
- LATEST - Static variable in class org.apache.lucene.util.Version
-
WARNING: if you use this setting, and then
upgrade to a newer release of Lucene, sizable changes
may happen.
- latitude - Variable in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Lazily-evaluated latitude.
- LatLonBoundingBox - Class in org.apache.lucene.document
-
An indexed 2-Dimension Bounding Box field for the Geospatial Lat/Lon Coordinate system
- LatLonBoundingBox(String, double, double, double, double) - Constructor for class org.apache.lucene.document.LatLonBoundingBox
-
Create a new 2D GeoBoundingBoxField representing a 2 dimensional geospatial bounding box
- LatLonBounds - Class in org.apache.lucene.spatial3d.geom
-
An object for accumulating latitude/longitude bounds information.
- LatLonBounds() - Constructor for class org.apache.lucene.spatial3d.geom.LatLonBounds
-
Construct an empty bounds object
- LatLonDocValuesField - Class in org.apache.lucene.document
-
An per-document location field.
- LatLonDocValuesField(String, double, double) - Constructor for class org.apache.lucene.document.LatLonDocValuesField
-
Creates a new LatLonDocValuesField with the specified latitude and longitude
- LatLonPoint - Class in org.apache.lucene.document
-
An indexed location field.
- LatLonPoint(String, double, double) - Constructor for class org.apache.lucene.document.LatLonPoint
-
Creates a new LatLonPoint with the specified latitude and longitude
- LatLonPointPrototypeQueries - Class in org.apache.lucene.search
-
Holder class for prototype sandboxed queries
When the query graduates from sandbox, these static calls should be
placed in
LatLonPoint
- LatLonShape - Class in org.apache.lucene.document
-
An indexed shape utility class.
- LatLonShape.QueryRelation - Enum in org.apache.lucene.document
-
Query Relation Types
- LatvianAnalyzer - Class in org.apache.lucene.analysis.lv
-
- LatvianAnalyzer() - Constructor for class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
- LatvianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
Builds an analyzer with the given stop words.
- LatvianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
Builds an analyzer with the given stop words.
- LatvianStemFilter - Class in org.apache.lucene.analysis.lv
-
- LatvianStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.lv.LatvianStemFilter
-
- LatvianStemFilterFactory - Class in org.apache.lucene.analysis.lv
-
- LatvianStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.lv.LatvianStemFilterFactory
-
Creates a new LatvianStemFilterFactory
- LatvianStemmer - Class in org.apache.lucene.analysis.lv
-
Light stemmer for Latvian.
- LatvianStemmer() - Constructor for class org.apache.lucene.analysis.lv.LatvianStemmer
-
- launch(CopyJob) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Runs this job async'd
- launchPreCopyMerge(AtomicBoolean, long, Map<String, FileMetaData>) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- LazyDocument - Class in org.apache.lucene.document
-
Defers actually loading a field's value until you ask
for it.
- LazyDocument(IndexReader, int) - Constructor for class org.apache.lucene.document.LazyDocument
-
- LazyDocument.LazyField - Class in org.apache.lucene.document
-
- LEADING_WILDCARD_NOT_ALLOWED - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- LeafCollector - Interface in org.apache.lucene.search
-
Collector decouples the score from the collected doc:
the score computation is skipped entirely if it's not
needed.
- leafContexts - Variable in class org.apache.lucene.search.IndexSearcher
-
- LeafFieldComparator - Interface in org.apache.lucene.search
-
Expert: comparator that gets instantiated on each leaf
from a top-level
FieldComparator
instance.
- LeafMetaData - Class in org.apache.lucene.index
-
Provides read-only metadata about a leaf.
- LeafMetaData(int, Version, Sort) - Constructor for class org.apache.lucene.index.LeafMetaData
-
Expert: Sole constructor.
- LeafReader - Class in org.apache.lucene.index
-
LeafReader
is an abstract class, providing an interface for accessing an
index.
- LeafReader() - Constructor for class org.apache.lucene.index.LeafReader
-
Sole constructor.
- LeafReaderContext - Class in org.apache.lucene.index
-
- LeafSlice(LeafReaderContext...) - Constructor for class org.apache.lucene.search.IndexSearcher.LeafSlice
-
- leafyPrune - Variable in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- LeakFS - Class in org.apache.lucene.mockfile
-
FileSystem that tracks open handles.
- LeakFS(FileSystem) - Constructor for class org.apache.lucene.mockfile.LeakFS
-
Create a new instance, tracking file handle leaks for the
specified delegate filesystem.
- LEAVE_TEMPORARY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Leave temporary files on disk, even on successful runs.
- leaves() - Method in class org.apache.lucene.index.CompositeReaderContext
-
- leaves() - Method in class org.apache.lucene.index.IndexReader
-
Returns the reader's leaves, or itself if this reader is atomic.
- leaves() - Method in class org.apache.lucene.index.IndexReaderContext
-
Returns the context's leaves if this context is a top-level context.
- leaves() - Method in class org.apache.lucene.index.LeafReaderContext
-
- leaves - Variable in class org.apache.lucene.search.IndexSearcher.LeafSlice
-
The leaves that make up this slice.
- left - Variable in class org.apache.lucene.geo.EdgeTree
-
- LEFT_ID - Static variable in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- LEFT_ID - Static variable in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- LegacyBinaryDocValues - Class in org.apache.lucene.index
-
- LegacyBinaryDocValues() - Constructor for class org.apache.lucene.index.LegacyBinaryDocValues
-
Deprecated.
Sole constructor.
- LegacyBinaryDocValuesWrapper - Class in org.apache.lucene.index
-
- LegacyBinaryDocValuesWrapper(Bits, LegacyBinaryDocValues) - Constructor for class org.apache.lucene.index.LegacyBinaryDocValuesWrapper
-
Deprecated.
- LegacyCell - Class in org.apache.lucene.spatial.prefix.tree
-
The base for the original two SPT's: Geohash and Quad.
- LegacyCell(byte[], int, int) - Constructor for class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
Warning: Refers to the same bytes (no copy).
- LegacyDocValuesIterables - Class in org.apache.lucene.codecs
-
Bridge helper methods for legacy codecs to map sorted doc values to iterables.
- LegacyNumericDocValues - Class in org.apache.lucene.index
-
- LegacyNumericDocValues() - Constructor for class org.apache.lucene.index.LegacyNumericDocValues
-
Deprecated.
Sole constructor.
- LegacyNumericDocValuesWrapper - Class in org.apache.lucene.index
-
- LegacyNumericDocValuesWrapper(Bits, LegacyNumericDocValues) - Constructor for class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- LegacySortedDocValues - Class in org.apache.lucene.index
-
- LegacySortedDocValues() - Constructor for class org.apache.lucene.index.LegacySortedDocValues
-
Deprecated.
Sole constructor.
- LegacySortedDocValuesWrapper - Class in org.apache.lucene.index
-
- LegacySortedDocValuesWrapper(LegacySortedDocValues, int) - Constructor for class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- LegacySortedNumericDocValues - Class in org.apache.lucene.index
-
- LegacySortedNumericDocValues() - Constructor for class org.apache.lucene.index.LegacySortedNumericDocValues
-
Deprecated.
Sole constructor.
- LegacySortedNumericDocValuesWrapper - Class in org.apache.lucene.index
-
- LegacySortedNumericDocValuesWrapper(LegacySortedNumericDocValues, int) - Constructor for class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- LegacySortedSetDocValues - Class in org.apache.lucene.index
-
- LegacySortedSetDocValues() - Constructor for class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
Sole constructor.
- LegacySortedSetDocValuesWrapper - Class in org.apache.lucene.index
-
- LegacySortedSetDocValuesWrapper(LegacySortedSetDocValues, int) - Constructor for class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- len - Variable in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- length() - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
return number of items in array
- length() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
return number of items in array
- length() - Method in class org.apache.lucene.analysis.compound.hyphenation.Hyphenation
-
- length - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- length() - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter.NumberBuffer
-
- length() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- length() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- length - Variable in class org.apache.lucene.facet.taxonomy.FacetLabel
-
- length() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBits
-
- length - Variable in class org.apache.lucene.index.ReaderSlice
-
Number of documents in this slice.
- length() - Method in class org.apache.lucene.queryparser.flexible.core.util.UnescapedCharSequence
-
- length - Variable in class org.apache.lucene.replicator.nrt.FileMetaData
-
- length() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- length() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- length() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- length() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- length() - Method in class org.apache.lucene.store.IndexInput
-
The number of bytes in the file.
- length() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- length() - Method in class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- length() - Method in interface org.apache.lucene.util.Bits
-
Returns the number of bits in this set
- length() - Method in class org.apache.lucene.util.Bits.MatchAllBits
-
- length() - Method in class org.apache.lucene.util.Bits.MatchNoBits
-
- length - Variable in class org.apache.lucene.util.BytesRef
-
Length of used bytes.
- length() - Method in class org.apache.lucene.util.BytesRefBuilder
-
Return the number of bytes in this buffer.
- length - Variable in class org.apache.lucene.util.CharsRef
-
Length of used characters.
- length() - Method in class org.apache.lucene.util.CharsRef
-
- length() - Method in class org.apache.lucene.util.CharsRefBuilder
-
Return the number of chars in this buffer.
- length() - Method in class org.apache.lucene.util.FixedBitSet
-
- length - Variable in class org.apache.lucene.util.IntsRef
-
Length of used ints.
- length() - Method in class org.apache.lucene.util.IntsRefBuilder
-
Return the number of ints in this buffer.
- length() - Method in class org.apache.lucene.util.LongBitSet
-
Returns the number of bits stored in this bitset.
- length - Variable in class org.apache.lucene.util.LongsRef
-
Length of used longs.
- length() - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- LengthFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Removes words that are too long or too short from the stream.
- LengthFilter(TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.LengthFilter
-
- LengthFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- LengthFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.LengthFilterFactory
-
Creates a new LengthFilterFactory
- LengthGoalBreakIterator - Class in org.apache.lucene.search.uhighlight
-
Wraps another BreakIterator
to skip past breaks that would result in passages that are too
short.
- lengthNorm(int) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Implemented as:
1/sqrt( steepness * (abs(x-min) + abs(x-max) - (max-min)) + 1 )
.
- lengthNorm(int) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
-
Implemented as
1/sqrt(length)
.
- lengthNorm(int) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Compute an index-time normalization value for this field instance.
- lessThan(TopOrdAndFloatQueue.OrdAndValue, TopOrdAndFloatQueue.OrdAndValue) - Method in class org.apache.lucene.facet.TopOrdAndFloatQueue
-
- lessThan(TopOrdAndIntQueue.OrdAndValue, TopOrdAndIntQueue.OrdAndValue) - Method in class org.apache.lucene.facet.TopOrdAndIntQueue
-
- lessThan(FieldValueHitQueue.Entry, FieldValueHitQueue.Entry) - Method in class org.apache.lucene.search.FieldValueHitQueue
-
- lessThan(SuggestWord, SuggestWord) - Method in class org.apache.lucene.search.spell.SuggestWordQueue
-
- lessThan(Lookup.LookupResult, Lookup.LookupResult) - Method in class org.apache.lucene.search.suggest.Lookup.LookupPriorityQueue
-
- lessThan(T, T) - Method in class org.apache.lucene.util.PriorityQueue
-
Determines the ordering of objects in this priority queue.
- LETTER - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Letters
- LetterTokenizer - Class in org.apache.lucene.analysis.core
-
A LetterTokenizer is a tokenizer that divides text at non-letters.
- LetterTokenizer() - Constructor for class org.apache.lucene.analysis.core.LetterTokenizer
-
Construct a new LetterTokenizer.
- LetterTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.core.LetterTokenizer
-
- LetterTokenizer(AttributeFactory, int) - Constructor for class org.apache.lucene.analysis.core.LetterTokenizer
-
- LetterTokenizerFactory - Class in org.apache.lucene.analysis.core
-
- LetterTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.core.LetterTokenizerFactory
-
Creates a new LetterTokenizerFactory
- level - Variable in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- LEVEL_LOG_SPAN - Static variable in class org.apache.lucene.index.LogMergePolicy
-
Defines the allowed range of log(size) for each
level.
- LEVEL_SIZE_ARRAY - Static variable in class org.apache.lucene.util.ByteBlockPool
-
An array holding the level sizes for byte slices.
- levelByTermLen - Variable in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- LevenshteinAutomata - Class in org.apache.lucene.util.automaton
-
Class to construct DFAs that match a word within some edit distance.
- LevenshteinAutomata(String, boolean) - Constructor for class org.apache.lucene.util.automaton.LevenshteinAutomata
-
Create a new LevenshteinAutomata for some input String.
- LevenshteinAutomata(int[], int, boolean) - Constructor for class org.apache.lucene.util.automaton.LevenshteinAutomata
-
Expert: specify a custom maximum possible symbol
(alphaMax); default is Character.MAX_CODE_POINT.
- LevenshteinAutomataAttributeImpl() - Constructor for class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-
- LevenshteinDistance - Class in org.apache.lucene.search.spell
-
Levenshtein edit distance class.
- LevenshteinDistance() - Constructor for class org.apache.lucene.search.spell.LevenshteinDistance
-
Optimized to run a bit faster than the static getDistance().
- LevensteinDistance - Class in org.apache.lucene.search.spell
-
- LevensteinDistance() - Constructor for class org.apache.lucene.search.spell.LevensteinDistance
-
Deprecated.
Sole constructor.
- LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.lucene.queryparser.classic.TokenMgrError
-
Returns a detailed message for the Error when it is thrown by the
token manager to indicate a lexical error.
- LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.lucene.queryparser.flexible.standard.parser.TokenMgrError
-
Returns a detailed message for the Error when it is thrown by the
token manager to indicate a lexical error.
- LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.lucene.queryparser.surround.parser.TokenMgrError
-
Returns a detailed message for the Error when it is thrown by the
token manager to indicate a lexical error.
- lexStateNames - Static variable in class org.apache.lucene.queryparser.classic.QueryParserTokenManager
-
Lexer state names.
- lexStateNames - Static variable in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
Lexer state names.
- lexStateNames - Static variable in class org.apache.lucene.queryparser.surround.parser.QueryParserTokenManager
-
Lexer state names.
- LHC - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Point at the lower end of the vertical line
- Lift - Class in org.egothor.stemmer
-
The Lift class is a data structure that is a variation of a Patricia trie.
- Lift(boolean) - Constructor for class org.egothor.stemmer.Lift
-
Constructor for the Lift object.
- liftUp(Row, List<Row>) - Method in class org.egothor.stemmer.Lift
-
Reduce the trie using Lift-Up reduction.
- like(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Return a query that will return docs like the passed lucene document ID.
- like(Map<String, Collection<Object>>) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
- like(String, Reader...) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Return a query that will return docs like the passed Readers.
- LikeThisQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- LikeThisQueryBuilder(Analyzer, String[]) - Constructor for class org.apache.lucene.queryparser.xml.builders.LikeThisQueryBuilder
-
- limit - Variable in class org.tartarus.snowball.SnowballProgram
-
- limit_backward - Variable in class org.tartarus.snowball.SnowballProgram
-
- LimitedFiniteStringsIterator - Class in org.apache.lucene.util.automaton
-
- LimitedFiniteStringsIterator(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
-
Constructor.
- LimitedStoredFieldVisitor(String[], char, int) - Constructor for class org.apache.lucene.search.uhighlight.UnifiedHighlighter.LimitedStoredFieldVisitor
-
- LimitTokenCountAnalyzer - Class in org.apache.lucene.analysis.miscellaneous
-
This Analyzer limits the number of tokens while indexing.
- LimitTokenCountAnalyzer(Analyzer, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenCountAnalyzer
-
Build an analyzer that limits the maximum number of tokens per field.
- LimitTokenCountAnalyzer(Analyzer, int, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenCountAnalyzer
-
Build an analyzer that limits the maximum number of tokens per field.
- LimitTokenCountFilter - Class in org.apache.lucene.analysis.miscellaneous
-
This TokenFilter limits the number of tokens while indexing.
- LimitTokenCountFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilter
-
Build a filter that only accepts tokens up to a maximum number.
- LimitTokenCountFilter(TokenStream, int, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilter
-
Build an filter that limits the maximum number of tokens per field.
- LimitTokenCountFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- LimitTokenCountFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilterFactory
-
Creates a new LimitTokenCountFilterFactory
- LimitTokenOffsetFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Lets all tokens pass through until it sees one with a start offset <= a
configured limit, which won't pass and ends the stream.
- LimitTokenOffsetFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenOffsetFilter
-
Lets all tokens pass through until it sees one with a start offset <= maxStartOffset
which won't pass and ends the stream.
- LimitTokenOffsetFilter(TokenStream, int, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenOffsetFilter
-
- LimitTokenOffsetFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- LimitTokenOffsetFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenOffsetFilterFactory
-
- LimitTokenPositionFilter - Class in org.apache.lucene.analysis.miscellaneous
-
This TokenFilter limits its emitted tokens to those with positions that
are not greater than the configured limit.
- LimitTokenPositionFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilter
-
Build a filter that only accepts tokens up to and including the given maximum position.
- LimitTokenPositionFilter(TokenStream, int, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilter
-
Build a filter that limits the maximum position of tokens to emit.
- LimitTokenPositionFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- LimitTokenPositionFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilterFactory
-
Creates a new LimitTokenPositionFilterFactory
- Line - Class in org.apache.lucene.geo
-
Represents a line on the earth's surface.
- Line(double[], double[]) - Constructor for class org.apache.lucene.geo.Line
-
Creates a new Line from the supplied latitude/longitude array.
- Line2D - Class in org.apache.lucene.geo
-
2D line implementation represented as a balanced interval tree of edges.
- LINEAR - Static variable in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Linear distance calculator
- LINEAR_COEF - Static variable in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
Coefficient used for linear blending
- LINEAR_SQUARED - Static variable in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Linear distance squared calculator
- LinearDistance - Class in org.apache.lucene.spatial3d.geom
-
Linear distance computation style.
- LinearDistance() - Constructor for class org.apache.lucene.spatial3d.geom.LinearDistance
-
Constructor.
- linearDistance(PlanetModel, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute linear distance from plane to a vector.
- linearDistance(PlanetModel, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute linear distance from plane to a vector.
- linearDistance(Vector) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the straight-line distance to a point described by the
vector taken from the origin.
- linearDistance(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the straight-line distance to a point described by the
vector taken from the origin.
- linearDistanceSquared(PlanetModel, GeoPoint, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute linear distance squared from plane to a vector.
- linearDistanceSquared(PlanetModel, double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute linear distance squared from plane to a vector.
- linearDistanceSquared(Vector) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the square of a straight-line distance to a point described by the
vector taken from the origin.
- linearDistanceSquared(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the square of a straight-line distance to a point described by the
vector taken from the origin.
- LinearFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
LinearFloatFunction
implements a linear function over
another
ValueSource
.
- LinearFloatFunction(ValueSource, float, float) - Constructor for class org.apache.lucene.queries.function.valuesource.LinearFloatFunction
-
- LinearSquaredDistance - Class in org.apache.lucene.spatial3d.geom
-
Linear squared distance computation style.
- LinearSquaredDistance() - Constructor for class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
Constructor.
- lineCount - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
number of lines of data read
- LineDocSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
- LineDocSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LineDocSource
-
- LineDocSource.HeaderLineParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
- LineDocSource.LineParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Reader of a single input line into
DocData
.
- LineDocSource.SimpleLineParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
- LineFileDocs - Class in org.apache.lucene.util
-
Minimal port of benchmark's LneDocSource +
DocMaker, so tests can enum docs from a line file created
by benchmark's WriteLineDoc task
- LineFileDocs(Random, String) - Constructor for class org.apache.lucene.util.LineFileDocs
-
If forever is true, we rewind the file at EOF (repeat
the docs over and over)
- LineFileDocs(Random) - Constructor for class org.apache.lucene.util.LineFileDocs
-
- lineFileOut(Document) - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteEnwikiLineDocTask
-
- lineFileOut(Document) - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
Selects output line file by written doc.
- lineno(StreamTokenizer) - Method in class org.apache.lucene.benchmark.byTask.tasks.AnalyzerFactoryTask
-
Returns the current line in the algorithm file
- LineParser(String[]) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.LineParser
-
Construct with the header
- lineRelateLine(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
-
uses orient method to compute relation between two line segments
note the following return values:
CELL_CROSSES_QUERY - if the two line segments fully cross
CELL_INSIDE_QUERY - if the one line segment terminates on the other
CELL_OUTSIDE_QUERY - if the two segments do not cross
- linesIntersect(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.Tessellator
-
Determines whether two line segments intersect.
- lineString(List<Point>, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- lineString() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- LINUX - Static variable in class org.apache.lucene.util.Constants
-
True iff running on Linux.
- listAll() - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- listAll() - Method in class org.apache.lucene.store.Directory
-
Returns names of all files stored in this directory.
- listAll() - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- listAll() - Method in class org.apache.lucene.store.FilterDirectory
-
- listAll(Path) - Static method in class org.apache.lucene.store.FSDirectory
-
Lists all files (including subdirectories) in the directory.
- listAll() - Method in class org.apache.lucene.store.FSDirectory
-
- listAll() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- listAll() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- listAll() - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- listCachedFiles() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- listCommits(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
-
Returns all commit points that exist in the Directory.
- listIterator() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- listIterator(int) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- ListOfOutputs<T> - Class in org.apache.lucene.util.fst
-
Wraps another Outputs implementation and encodes one or
more of its output values.
- ListOfOutputs(Outputs<T>) - Constructor for class org.apache.lucene.util.fst.ListOfOutputs
-
- listSegments() - Method in class org.apache.lucene.index.IndexSplitter
-
- LiteralValueSource - Class in org.apache.lucene.queries.function.valuesource
-
Pass a the field value through as a String, no matter the type // Q: doesn't this mean it's a "string"?
- LiteralValueSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.LiteralValueSource
-
- LithuanianAnalyzer - Class in org.apache.lucene.analysis.lt
-
- LithuanianAnalyzer() - Constructor for class org.apache.lucene.analysis.lt.LithuanianAnalyzer
-
- LithuanianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.lt.LithuanianAnalyzer
-
Builds an analyzer with the given stop words.
- LithuanianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.lt.LithuanianAnalyzer
-
Builds an analyzer with the given stop words.
- LithuanianStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- LithuanianStemmer() - Constructor for class org.tartarus.snowball.ext.LithuanianStemmer
-
- liveDocs - Variable in class org.apache.lucene.index.MergeState
-
Live docs for each reader
- liveDocs - Variable in class org.apache.lucene.index.PerThreadPKLookup
-
- liveDocs - Variable in class org.apache.lucene.index.SegmentWriteState
-
FixedBitSet
recording live documents; this is
only set if there is one or more deleted documents.
- liveDocsFormat() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- liveDocsFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes live docs
- liveDocsFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- liveDocsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- LiveDocsFormat - Class in org.apache.lucene.codecs
-
Format for live/deleted documents
- LiveDocsFormat() - Constructor for class org.apache.lucene.codecs.LiveDocsFormat
-
Sole constructor.
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- liveDocsFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- liveDocsFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- liveDocStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status for testing of livedocs
- LiveFieldValues<S,T> - Class in org.apache.lucene.search
-
Tracks live field values across NRT reader reopens.
- LiveFieldValues(ReferenceManager<S>, T) - Constructor for class org.apache.lucene.search.LiveFieldValues
-
The missingValue must be non-null.
- LiveIndexWriterConfig - Class in org.apache.lucene.index
-
Holds all the configuration used by
IndexWriter
with few setters for
settings that can be changed on an
IndexWriter
instance "live".
- LMDirichletSimilarity - Class in org.apache.lucene.search.similarities
-
Bayesian smoothing using Dirichlet priors.
- LMDirichletSimilarity(LMSimilarity.CollectionModel, float) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
-
Instantiates the similarity with the provided μ parameter.
- LMDirichletSimilarity(float) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
-
Instantiates the similarity with the provided μ parameter.
- LMDirichletSimilarity(LMSimilarity.CollectionModel) - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
-
Instantiates the similarity with the default μ value of 2000.
- LMDirichletSimilarity() - Constructor for class org.apache.lucene.search.similarities.LMDirichletSimilarity
-
Instantiates the similarity with the default μ value of 2000.
- LMJelinekMercerSimilarity - Class in org.apache.lucene.search.similarities
-
Language model based on the Jelinek-Mercer smoothing method.
- LMJelinekMercerSimilarity(LMSimilarity.CollectionModel, float) - Constructor for class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-
Instantiates with the specified collectionModel and λ parameter.
- LMJelinekMercerSimilarity(float) - Constructor for class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-
Instantiates with the specified λ parameter.
- LMSimilarity - Class in org.apache.lucene.search.similarities
-
Abstract superclass for language modeling Similarities.
- LMSimilarity(LMSimilarity.CollectionModel) - Constructor for class org.apache.lucene.search.similarities.LMSimilarity
-
Creates a new instance with the specified collection language model.
- LMSimilarity() - Constructor for class org.apache.lucene.search.similarities.LMSimilarity
-
Creates a new instance with the default collection language model.
- LMSimilarity.CollectionModel - Interface in org.apache.lucene.search.similarities
-
A strategy for computing the collection language model.
- LMSimilarity.DefaultCollectionModel - Class in org.apache.lucene.search.similarities
-
Models p(w|C)
as the number of occurrences of the term in the
collection, divided by the total number of tokens + 1
.
- LMSimilarity.LMStats - Class in org.apache.lucene.search.similarities
-
Stores the collection distribution of the current term.
- LMStats(String, float) - Constructor for class org.apache.lucene.search.similarities.LMSimilarity.LMStats
-
Creates LMStats for the provided field and query-time boost
- ln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Axiomatic
-
compute the document length component
- ln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
compute the document length component
- ln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
compute the document length component
- ln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
compute the document length component
- ln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
compute the document length component
- ln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
compute the document length component
- ln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
-
compute the document length component
- lo - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Pointer to low branch and to rest of the key when it is stored directly in
this node, we don't have unions in java!
- load(InputStream) - Static method in class org.apache.lucene.analysis.stempel.StempelStemmer
-
Load a stemmer table from an inputstream.
- load(DataInput) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- load(DataInput) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- load(DataInput) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
- load(IndexInput) - Static method in class org.apache.lucene.search.suggest.document.NRTSuggester
-
- load(DataInput) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- load(DataInput) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
- load(DataInput) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
- load(InputStream) - Method in class org.apache.lucene.search.suggest.Lookup
-
- load(DataInput) - Method in class org.apache.lucene.search.suggest.Lookup
-
Discard current lookup data and load it from a previously saved copy.
- load(DataInput) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
- loadDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Loads a specific Directory implementation
- loadFieldValues(String[], DocIdSetIterator, int) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Loads the String values for each docId by field to be highlighted.
- loadFSDirectoryClass(String) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Loads a specific FSDirectory implementation
- loadMeta(IndexInput, long, int) - Static method in class org.apache.lucene.util.packed.DirectMonotonicReader
-
- loadPatterns(InputSource) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Read hyphenation patterns from an XML file.
- loadStopwordSet(boolean, Class<? extends Analyzer>, String, String) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a CharArraySet from a file resource associated with a class.
- loadStopwordSet(Path) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a CharArraySet from a path.
- loadStopwordSet(Reader) - Static method in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a CharArraySet from a file.
- loadSynonyms(ResourceLoader, String, boolean, Analyzer) - Method in class org.apache.lucene.analysis.synonym.SynonymFilterFactory
-
Deprecated.
- loadSynonyms(ResourceLoader, String, boolean, Analyzer) - Method in class org.apache.lucene.analysis.synonym.SynonymGraphFilterFactory
-
- loadXML(Reader) - Static method in class org.apache.lucene.queryparser.xml.DOMUtils
-
Helper method to parse an XML file into a DOM tree, given a reader.
- LOCALE - Static variable in class org.apache.lucene.analysis.miscellaneous.DateRecognizerFilterFactory
-
- LOCALE - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the Locale
used when parsing the query
- localeForLanguageTag(String) - Static method in class org.apache.lucene.util.LuceneTestCase
-
return a Locale object equivalent to its programmatic name
- LocalReplicator - Class in org.apache.lucene.replicator
-
- LocalReplicator() - Constructor for class org.apache.lucene.replicator.LocalReplicator
-
- localSearch(Query, int) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- localSearch(Query, int, Sort) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- localSearchAfter(ScoreDoc, Query, int) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- localStartNS - Static variable in class org.apache.lucene.replicator.nrt.Node
-
When this node was started
- lock(long, long, boolean, A, CompletionHandler<FileLock, ? super A>) - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- lock(long, long, boolean) - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- lock(long, long, boolean) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- Lock - Class in org.apache.lucene.store
-
An interprocess mutex lock.
- Lock() - Constructor for class org.apache.lucene.store.Lock
-
- LOCK_OBTAIN_WAIT_FOREVER - Static variable in class org.apache.lucene.store.SleepingLockWrapper
-
Pass this lockWaitTimeout to try forever to obtain the lock.
- lockFactory - Variable in class org.apache.lucene.store.BaseDirectory
-
Holds the LockFactory instance (implements locking for
this Directory instance).
- LockFactory - Class in org.apache.lucene.store
-
Base class for Locking implementation.
- LockFactory() - Constructor for class org.apache.lucene.store.LockFactory
-
- LockObtainFailedException - Exception in org.apache.lucene.store
-
This exception is thrown when the write.lock
could not be acquired.
- LockObtainFailedException(String) - Constructor for exception org.apache.lucene.store.LockObtainFailedException
-
- LockObtainFailedException(String, Throwable) - Constructor for exception org.apache.lucene.store.LockObtainFailedException
-
- LockReleaseFailedException - Exception in org.apache.lucene.store
-
This exception is thrown when the write.lock
could not be released.
- LockReleaseFailedException(String) - Constructor for exception org.apache.lucene.store.LockReleaseFailedException
-
- LockReleaseFailedException(String, Throwable) - Constructor for exception org.apache.lucene.store.LockReleaseFailedException
-
- LockStressTest - Class in org.apache.lucene.store
-
Simple standalone tool that forever acquires and releases a
lock using a specific LockFactory.
- LockStressTest() - Constructor for class org.apache.lucene.store.LockStressTest
-
- LockValidatingDirectoryWrapper - Class in org.apache.lucene.store
-
This class makes a best-effort check that a provided
Lock
is valid before any destructive filesystem operation.
- LockValidatingDirectoryWrapper(Directory, Lock) - Constructor for class org.apache.lucene.store.LockValidatingDirectoryWrapper
-
- LockVerifyServer - Class in org.apache.lucene.store
-
- LockVerifyServer() - Constructor for class org.apache.lucene.store.LockVerifyServer
-
- log() - Method in class org.apache.lucene.analysis.br.BrazilianStemmer
-
For log and debug purpose
- log(String, int, PrintWriter, String) - Method in class org.apache.lucene.benchmark.quality.QualityStats
-
Log information on this QualityStats object.
- log(long, int) - Static method in class org.apache.lucene.util.MathUtil
-
Returns x <= 0 ? 0 : Math.floor(Math.log(x) / Math.log(base))
- log(double, double) - Static method in class org.apache.lucene.util.MathUtil
-
Calculates logarithm in a given base with doubles.
- log2(double) - Static method in class org.apache.lucene.search.similarities.SimilarityBase
-
Returns the base two logarithm of x
.
- LOG2_E - Static variable in class org.apache.lucene.search.similarities.BasicModelP
-
log2(Math.E)
, precomputed.
- LogByteSizeMergePolicy - Class in org.apache.lucene.index
-
This is a
LogMergePolicy
that measures size of a
segment as the total byte size of the segment's files.
- LogByteSizeMergePolicy() - Constructor for class org.apache.lucene.index.LogByteSizeMergePolicy
-
Sole constructor, setting all settings to their
defaults.
- LogDocMergePolicy - Class in org.apache.lucene.index
-
This is a
LogMergePolicy
that measures size of a
segment as the number of documents (not taking deletions
into account).
- LogDocMergePolicy() - Constructor for class org.apache.lucene.index.LogDocMergePolicy
-
Sole constructor, setting all settings to their
defaults.
- logicalAnd(QueryNode, QueryNode) - Static method in class org.apache.lucene.queryparser.flexible.core.util.QueryNodeOperation
-
perform a logical and of 2 QueryNode trees.
- LogMergePolicy - Class in org.apache.lucene.index
-
This class implements a
MergePolicy
that tries
to merge segments into levels of exponentially
increasing size, where each level has fewer segments than
the value of the merge factor.
- LogMergePolicy() - Constructor for class org.apache.lucene.index.LogMergePolicy
-
Sole constructor.
- logStep - Variable in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
- logStep - Variable in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- LOKID - Static variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Deprecated.
Index values for accessing relatives array.
- LongBitSet - Class in org.apache.lucene.util
-
BitSet of fixed length (numBits), backed by accessible (
LongBitSet.getBits()
)
long[], accessed with a long index.
- LongBitSet(long) - Constructor for class org.apache.lucene.util.LongBitSet
-
Creates a new LongBitSet.
- LongBitSet(long[], long) - Constructor for class org.apache.lucene.util.LongBitSet
-
Creates a new LongBitSet using the provided long[] array as backing store.
- longBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
The minimum number of long blocks to encode in a single iteration, when
using long encoding.
- longBlockCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
-
The minimum number of long blocks to encode in a single iteration, when
using long encoding.
- LongComparator(int, String, Long) - Constructor for class org.apache.lucene.search.FieldComparator.LongComparator
-
Creates a new comparator based on Long.compare(long, long)
for numHits
.
- longCount(int, int, int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
-
Computes how many long blocks are needed to store values
values of size bitsPerValue
.
- LongDocValues - Class in org.apache.lucene.queries.function.docvalues
-
Abstract
FunctionValues
implementation which supports retrieving long values.
- LongDocValues(ValueSource) - Constructor for class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- LongDocValuesStats(String) - Constructor for class org.apache.lucene.search.DocValuesStats.LongDocValuesStats
-
- longestOp(Iterable<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
find the longest op name out of completed tasks.
- longField(FieldInfo, long) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- longField(FieldInfo, long) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
- longField(FieldInfo, long) - Method in class org.apache.lucene.index.StoredFieldVisitor
-
Process a long numeric field.
- LongFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- LongFieldSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- longHashCode() - Method in class org.apache.lucene.facet.taxonomy.FacetLabel
-
Calculate a 64-bit hash function for this path.
- longHex(long) - Static method in class org.apache.lucene.util.ToStringUtils
-
- longitude - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Longitude of the vertical line
- longitude - Variable in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Lazily-evaluated longitude.
- longOrds - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
true if we have so many values that we must write ords using long (8 bytes) instead of int (4 bytes)
- LongPoint - Class in org.apache.lucene.document
-
An indexed long
field for fast range filters.
- LongPoint(String, long...) - Constructor for class org.apache.lucene.document.LongPoint
-
Creates a new LongPoint, indexing the
provided N-dimensional long point.
- LongRange - Class in org.apache.lucene.document
-
An indexed Long Range field.
- LongRange(String, long[], long[]) - Constructor for class org.apache.lucene.document.LongRange
-
Create a new LongRange type, from min/max parallel arrays
- LongRange - Class in org.apache.lucene.facet.range
-
Represents a range over long values.
- LongRange(String, long, boolean, long, boolean) - Constructor for class org.apache.lucene.facet.range.LongRange
-
Create a LongRange.
- LongRangeFacetCounts - Class in org.apache.lucene.facet.range
-
- LongRangeFacetCounts(String, FacetsCollector, LongRange...) - Constructor for class org.apache.lucene.facet.range.LongRangeFacetCounts
-
- LongRangeFacetCounts(String, LongValuesSource, FacetsCollector, LongRange...) - Constructor for class org.apache.lucene.facet.range.LongRangeFacetCounts
-
- LongRangeFacetCounts(String, LongValuesSource, FacetsCollector, Query, LongRange...) - Constructor for class org.apache.lucene.facet.range.LongRangeFacetCounts
-
Create
LongRangeFacetCounts
, using the provided
LongValuesSource
, and using the provided Filter as
a fastmatch: only documents passing the filter are
checked for the matching ranges, which is helpful when
the provided
LongValuesSource
is costly per-document,
such as a geo distance.
- longs - Variable in class org.apache.lucene.util.LongsRef
-
The contents of the LongsRef.
- longsEquals(LongsRef) - Method in class org.apache.lucene.util.LongsRef
-
- LongsRef - Class in org.apache.lucene.util
-
Represents long[], as a slice (offset + length) into an
existing long[].
- LongsRef() - Constructor for class org.apache.lucene.util.LongsRef
-
- LongsRef(int) - Constructor for class org.apache.lucene.util.LongsRef
-
Create a LongsRef pointing to a new array of size capacity
.
- LongsRef(long[], int, int) - Constructor for class org.apache.lucene.util.LongsRef
-
This instance will directly reference longs w/o making a copy.
- longToBytes(long, BytesRef) - Static method in class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
- longToEnglish(long) - Static method in class org.apache.lucene.util.English
-
- longToEnglish(long, StringBuilder) - Static method in class org.apache.lucene.util.English
-
- LongToEnglishContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Creates documents whose content is a long
number starting from
Long.MIN_VALUE
+ 10
.
- LongToEnglishContentSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishContentSource
-
- LongToEnglishQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
Creates queries whose content is a spelled-out long
number
starting from Long.MIN_VALUE
+ 10
.
- LongToEnglishQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
-
- longToInt4(long) - Static method in class org.apache.lucene.util.SmallFloat
-
Float-like encoding for positive longs that preserves ordering and 4 significant bits.
- longToObject(long) - Method in class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- longToSortableBytes(long, byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
-
Encodes an long value
such that unsigned byte order comparison
is consistent with Long.compare(long, long)
- longToString(long) - Method in class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- longVal(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- longVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- longVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- longVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- longVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- longVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- longVal(int, long[]) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- longValue() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- longValue() - Method in class org.apache.lucene.index.FilterNumericDocValues
-
- longValue() - Method in class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- longValue() - Method in class org.apache.lucene.index.NumericDocValues
-
Returns the numeric value for the current document ID.
- longValue() - Method in class org.apache.lucene.search.LongValues
-
Get the long value for the current document
- longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Decoder
-
- longValueCount() - Method in interface org.apache.lucene.util.packed.PackedInts.Encoder
-
- LongValueFacetCounts - Class in org.apache.lucene.facet
-
Facets
implementation that computes counts for
all uniqute long values, more efficiently counting small values (0-1023) using an int array,
and switching to a
HashMap
for values above 1023.
- LongValueFacetCounts(String, FacetsCollector, boolean) - Constructor for class org.apache.lucene.facet.LongValueFacetCounts
-
- LongValueFacetCounts(String, LongValuesSource, FacetsCollector) - Constructor for class org.apache.lucene.facet.LongValueFacetCounts
-
- LongValueFacetCounts(String, LongValuesSource, FacetsCollector, boolean) - Constructor for class org.apache.lucene.facet.LongValueFacetCounts
-
- LongValueFacetCounts(String, IndexReader, boolean) - Constructor for class org.apache.lucene.facet.LongValueFacetCounts
-
Counts all facet values for this reader.
- LongValueFacetCounts(String, LongValuesSource, IndexReader) - Constructor for class org.apache.lucene.facet.LongValueFacetCounts
-
- LongValues - Class in org.apache.lucene.search
-
Per-segment, per-document long values, which can be calculated at search-time
- LongValues() - Constructor for class org.apache.lucene.search.LongValues
-
- LongValues - Class in org.apache.lucene.util
-
Abstraction over an array of longs.
- LongValues() - Constructor for class org.apache.lucene.util.LongValues
-
- LongValuesSource - Class in org.apache.lucene.search
-
- LongValuesSource() - Constructor for class org.apache.lucene.search.LongValuesSource
-
- LookaheadTokenFilter<T extends LookaheadTokenFilter.Position> - Class in org.apache.lucene.analysis
-
An abstract TokenFilter to make it easier to build graph
token filters requiring some lookahead.
- LookaheadTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.LookaheadTokenFilter
-
- LookaheadTokenFilter.Position - Class in org.apache.lucene.analysis
-
Holds all state for a single position; subclass this
to record other state at each position.
- lookup(char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.UnknownDictionary
-
- lookup(char[], int, int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
Lookup words in text
- lookup(char[], int, int) - Method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
Lookup words in text
- lookup(BytesRef) - Method in class org.apache.lucene.index.PerThreadPKLookup
-
Returns docID if found, else -1.
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- lookup(CharSequence, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Lookup, without any context.
- lookup(CharSequence, Set<BytesRef>, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Lookup, with context but without booleans.
- lookup(CharSequence, Map<BytesRef, BooleanClause.Occur>, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Retrieve suggestions, specifying whether all terms
must match (allTermsRequired
) and whether the hits
should be highlighted (doHighlight
).
- lookup(CharSequence, BooleanQuery, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
This is an advanced method providing the capability to send down to the suggester any
arbitrary lucene query to be used to filter the result of the suggester
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
- lookup(CharSequence, Set<BytesRef>, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
- lookup(CharSequence, Map<BytesRef, BooleanClause.Occur>, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
- lookup(CharSequence, BooleanQuery, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.analyzing.BlendedInfixSuggester
-
- lookup(CharSequence, boolean, int) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
- lookup(CharSequence, int) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Lookup, without any context.
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
- lookup(CharSequence, Set<BytesRef>, int) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Retrieve suggestions.
- lookup(CompletionScorer, Bits, TopSuggestDocsCollector) - Method in class org.apache.lucene.search.suggest.document.NRTSuggester
-
- lookup(CharSequence, int) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion
-
Lookup suggestions to key
.
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
- Lookup - Class in org.apache.lucene.search.suggest
-
Simple Lookup interface for CharSequence
suggestions.
- Lookup() - Constructor for class org.apache.lucene.search.suggest.Lookup
-
Sole constructor.
- lookup(CharSequence, boolean, int) - Method in class org.apache.lucene.search.suggest.Lookup
-
Look up a key and return possible completion for this key.
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.Lookup
-
Look up a key and return possible completion for this key.
- lookup(CharSequence, BooleanQuery, int, boolean, boolean) - Method in class org.apache.lucene.search.suggest.Lookup
-
Look up a key and return possible completion for this key.
- lookup(CharSequence, Set<BytesRef>, boolean, int) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
- lookup(String) - Method in class org.apache.lucene.util.NamedSPILoader
-
- Lookup.LookupPriorityQueue - Class in org.apache.lucene.search.suggest
-
- Lookup.LookupResult - Class in org.apache.lucene.search.suggest
-
Result of a lookup.
- lookupAnalysisClass(String, Class<T>) - Method in class org.apache.lucene.benchmark.byTask.tasks.AnalyzerFactoryTask
-
This method looks up a class with its fully qualified name (FQN), or a short-name
class-simplename, or with a package suffix, assuming "org.apache.lucene.analysis."
as the package prefix (e.g.
- lookupCharacterClass(String) - Static method in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- lookupCharacterClass(String) - Static method in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- lookupClass(String) - Method in class org.apache.lucene.analysis.util.AnalysisSPILoader
-
- lookupClass(String) - Static method in class org.apache.lucene.analysis.util.CharFilterFactory
-
looks up a charfilter class by name from context classpath
- lookupClass(String) - Static method in class org.apache.lucene.analysis.util.TokenFilterFactory
-
looks up a tokenfilter class by name from context classpath
- lookupClass(String) - Static method in class org.apache.lucene.analysis.util.TokenizerFactory
-
looks up a tokenizer class by name from context classpath
- lookupFromSearcher(S, String) - Method in class org.apache.lucene.search.LiveFieldValues
-
This is called when the id/value was already flushed and opened
in an NRT IndexSearcher.
- lookupOrd(int) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- lookupOrd(long) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- lookupOrd(int) - Method in class org.apache.lucene.index.LegacySortedDocValues
-
Deprecated.
Retrieves the value for the specified ordinal.
- lookupOrd(int) - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- lookupOrd(long) - Method in class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
Retrieves the value for the specified ordinal.
- lookupOrd(long) - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- lookupOrd(int) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- lookupOrd(long) - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- lookupOrd(int) - Method in class org.apache.lucene.index.SortedDocValues
-
Retrieves the value for the specified ordinal.
- lookupOrd(long) - Method in class org.apache.lucene.index.SortedSetDocValues
-
Retrieves the value for the specified ordinal.
- LookupPriorityQueue(int) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupPriorityQueue
-
Creates a new priority queue of the specified size.
- LookupResult(CharSequence, long) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupResult
-
Create a new result from a key+weight pair.
- LookupResult(CharSequence, long, BytesRef) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupResult
-
Create a new result from a key+weight+payload triple.
- LookupResult(CharSequence, Object, long, BytesRef) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupResult
-
Create a new result from a key+highlightKey+weight+payload triple.
- LookupResult(CharSequence, long, BytesRef, Set<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupResult
-
Create a new result from a key+weight+payload+contexts triple.
- LookupResult(CharSequence, long, Set<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupResult
-
Create a new result from a key+weight+contexts triple.
- LookupResult(CharSequence, Object, long, BytesRef, Set<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.Lookup.LookupResult
-
Create a new result from a key+highlightKey+weight+payload+contexts triple.
- lookupSegmentation(int) - Method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.LegacySortedDocValues
-
Deprecated.
If key
exists, returns its ordinal, else
returns -insertionPoint-1
, like Arrays.binarySearch
.
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
If key
exists, returns its ordinal, else
returns -insertionPoint-1
, like Arrays.binarySearch
.
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedDocValues
-
If key
exists, returns its ordinal, else
returns -insertionPoint-1
, like Arrays.binarySearch
.
- lookupTerm(BytesRef) - Method in class org.apache.lucene.index.SortedSetDocValues
-
If key
exists, returns its ordinal, else
returns -insertionPoint-1
, like Arrays.binarySearch
.
- lookupWordIds(int, IntsRef) - Method in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- lookupWordIds(int, IntsRef) - Method in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- LovinsStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- LovinsStemmer() - Constructor for class org.tartarus.snowball.ext.LovinsStemmer
-
- LOWER - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- LowerCaseFilter - Class in org.apache.lucene.analysis.core
-
Normalizes token text to lower case.
- LowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.core.LowerCaseFilter
-
Create a new LowerCaseFilter, that normalizes token text to lower case.
- LowerCaseFilter - Class in org.apache.lucene.analysis
-
Normalizes token text to lower case.
- LowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.LowerCaseFilter
-
Create a new LowerCaseFilter, that normalizes token text to lower case.
- LowerCaseFilterFactory - Class in org.apache.lucene.analysis.core
-
- LowerCaseFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.core.LowerCaseFilterFactory
-
Creates a new LowerCaseFilterFactory
- LowerCaseTokenizer - Class in org.apache.lucene.analysis.core
-
- LowerCaseTokenizer() - Constructor for class org.apache.lucene.analysis.core.LowerCaseTokenizer
-
Deprecated.
Construct a new LowerCaseTokenizer.
- LowerCaseTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.core.LowerCaseTokenizer
-
Deprecated.
- LowerCaseTokenizer(AttributeFactory, int) - Constructor for class org.apache.lucene.analysis.core.LowerCaseTokenizer
-
Deprecated.
- LowerCaseTokenizerFactory - Class in org.apache.lucene.analysis.core
-
- LowerCaseTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.core.LowerCaseTokenizerFactory
-
Deprecated.
Creates a new LowerCaseTokenizerFactory
- lowFreqBoost - Variable in class org.apache.lucene.queries.CommonTermsQuery
-
- lowFreqMinNrShouldMatch - Variable in class org.apache.lucene.queries.CommonTermsQuery
-
- lowFreqOccur - Variable in class org.apache.lucene.queries.CommonTermsQuery
-
- LPAREN - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
-
- LPAREN - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- LPAREN - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- LPAREN - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- LRUHashMap<K,V> - Class in org.apache.lucene.facet.taxonomy
-
LRUHashMap is an extension of Java's HashMap, which has a bounded size();
When it reaches that size, each time a new element is added, the least
recently used (LRU) entry is removed.
- LRUHashMap(int) - Constructor for class org.apache.lucene.facet.taxonomy.LRUHashMap
-
Create a new hash map with a bounded size and with least recently
used entries removed.
- LRUQueryCache - Class in org.apache.lucene.search
-
A
QueryCache
that evicts queries using a LRU (least-recently-used)
eviction policy in order to remain under a given maximum size and number of
bytes used.
- LRUQueryCache(int, long, Predicate<LeafReaderContext>) - Constructor for class org.apache.lucene.search.LRUQueryCache
-
Expert: Create a new instance that will cache at most maxSize
queries with at most maxRamBytesUsed
bytes of memory, only on
leaves that satisfy leavesToCache
;
- LRUQueryCache(int, long) - Constructor for class org.apache.lucene.search.LRUQueryCache
-
Create a new instance that will cache at most maxSize
queries
with at most maxRamBytesUsed
bytes of memory.
- LruTaxonomyWriterCache - Class in org.apache.lucene.facet.taxonomy.writercache
-
- LruTaxonomyWriterCache(int) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
- LruTaxonomyWriterCache(int, LruTaxonomyWriterCache.LRUType) - Constructor for class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
Creates this with the specified method.
- LruTaxonomyWriterCache.LRUType - Enum in org.apache.lucene.facet.taxonomy.writercache
-
Determines cache type.
- LSBRadixSorter - Class in org.apache.lucene.util
-
A LSB Radix sorter for unsigned int values.
- LSBRadixSorter() - Constructor for class org.apache.lucene.util.LSBRadixSorter
-
- Lucene50CompoundFormat - Class in org.apache.lucene.codecs.lucene50
-
Lucene 5.0 compound file format
- Lucene50CompoundFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50CompoundFormat
-
Sole constructor.
- Lucene50FieldInfosFormat - Class in org.apache.lucene.codecs.lucene50
-
Lucene 5.0 Field Infos format.
- Lucene50FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50FieldInfosFormat
-
Sole constructor.
- Lucene50LiveDocsFormat - Class in org.apache.lucene.codecs.lucene50
-
Lucene 5.0 live docs format
- Lucene50LiveDocsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50LiveDocsFormat
-
Sole constructor.
- Lucene50PostingsFormat - Class in org.apache.lucene.codecs.lucene50
-
Lucene 5.0 postings format, which encodes postings in packed integer blocks
for fast decode.
- Lucene50PostingsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
Creates Lucene50PostingsFormat
with default
settings.
- Lucene50PostingsFormat(int, int) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
Creates Lucene50PostingsFormat
with custom
values for minBlockSize
and maxBlockSize
passed to block terms dictionary.
- Lucene50PostingsReader - Class in org.apache.lucene.codecs.lucene50
-
Concrete class that reads docId(maybe frq,pos,offset,payloads) list
with postings format.
- Lucene50PostingsReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
Sole constructor.
- Lucene50PostingsWriter - Class in org.apache.lucene.codecs.lucene50
-
Concrete class that writes docId(maybe frq,pos,offset,payloads) list
with postings format.
- Lucene50PostingsWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
Creates a postings writer
- Lucene50SegmentInfoFormat - Class in org.apache.lucene.codecs.lucene50
-
- Lucene50SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50SegmentInfoFormat
-
Deprecated.
Sole constructor.
- Lucene50StoredFieldsFormat - Class in org.apache.lucene.codecs.lucene50
-
Lucene 5.0 stored fields format.
- Lucene50StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
-
Stored fields format with default options
- Lucene50StoredFieldsFormat(Lucene50StoredFieldsFormat.Mode) - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
-
Stored fields format with specified mode
- Lucene50StoredFieldsFormat.Mode - Enum in org.apache.lucene.codecs.lucene50
-
Configuration option for stored fields.
- Lucene50TermVectorsFormat - Class in org.apache.lucene.codecs.lucene50
-
- Lucene50TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.lucene50.Lucene50TermVectorsFormat
-
Sole constructor.
- Lucene53NormsFormat - Class in org.apache.lucene.codecs.lucene53
-
Lucene 5.3 Score normalization format.
- Lucene53NormsFormat() - Constructor for class org.apache.lucene.codecs.lucene53.Lucene53NormsFormat
-
Sole Constructor
- Lucene54DocValuesFormat - Class in org.apache.lucene.codecs.lucene54
-
- Lucene54DocValuesFormat() - Constructor for class org.apache.lucene.codecs.lucene54.Lucene54DocValuesFormat
-
Deprecated.
Sole Constructor
- Lucene60Codec - Class in org.apache.lucene.codecs.lucene60
-
- Lucene60Codec() - Constructor for class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
Instantiates a new codec.
- Lucene60Codec(Lucene50StoredFieldsFormat.Mode) - Constructor for class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
Instantiates a new codec, specifying the stored fields compression
mode to use.
- Lucene60FieldInfosFormat - Class in org.apache.lucene.codecs.lucene60
-
Lucene 6.0 Field Infos format.
- Lucene60FieldInfosFormat() - Constructor for class org.apache.lucene.codecs.lucene60.Lucene60FieldInfosFormat
-
Sole constructor.
- Lucene60PointsFormat - Class in org.apache.lucene.codecs.lucene60
-
Lucene 6.0 point format, which encodes dimensional values in a block KD-tree structure
for fast 1D range and N dimesional shape intersection filtering.
- Lucene60PointsFormat() - Constructor for class org.apache.lucene.codecs.lucene60.Lucene60PointsFormat
-
Sole constructor
- Lucene60PointsReader - Class in org.apache.lucene.codecs.lucene60
-
- Lucene60PointsReader(SegmentReadState) - Constructor for class org.apache.lucene.codecs.lucene60.Lucene60PointsReader
-
Sole constructor
- Lucene60PointsWriter - Class in org.apache.lucene.codecs.lucene60
-
Writes dimensional values
- Lucene60PointsWriter(SegmentWriteState, int, double) - Constructor for class org.apache.lucene.codecs.lucene60.Lucene60PointsWriter
-
Full constructor
- Lucene60PointsWriter(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.lucene60.Lucene60PointsWriter
-
Uses the defaults values for maxPointsInLeafNode
(1024) and maxMBSortInHeap
(16.0)
- Lucene62Codec - Class in org.apache.lucene.codecs.lucene62
-
Implements the Lucene 6.2 index format, with configurable per-field postings
and docvalues formats.
- Lucene62Codec() - Constructor for class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
Instantiates a new codec.
- Lucene62Codec(Lucene50StoredFieldsFormat.Mode) - Constructor for class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
Instantiates a new codec, specifying the stored fields compression
mode to use.
- Lucene62SegmentInfoFormat - Class in org.apache.lucene.codecs.lucene62
-
Lucene 6.2 Segment info format.
- Lucene62SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene62.Lucene62SegmentInfoFormat
-
Sole constructor.
- Lucene70Codec - Class in org.apache.lucene.codecs.lucene70
-
Implements the Lucene 7.0 index format, with configurable per-field postings
and docvalues formats.
- Lucene70Codec() - Constructor for class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
Instantiates a new codec.
- Lucene70Codec(Lucene50StoredFieldsFormat.Mode) - Constructor for class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
Instantiates a new codec, specifying the stored fields compression
mode to use.
- Lucene70DocValuesFormat - Class in org.apache.lucene.codecs.lucene70
-
Lucene 7.0 DocValues format.
- Lucene70DocValuesFormat() - Constructor for class org.apache.lucene.codecs.lucene70.Lucene70DocValuesFormat
-
Sole Constructor
- Lucene70NormsFormat - Class in org.apache.lucene.codecs.lucene70
-
Lucene 7.0 Score normalization format.
- Lucene70NormsFormat() - Constructor for class org.apache.lucene.codecs.lucene70.Lucene70NormsFormat
-
Sole Constructor
- Lucene70SegmentInfoFormat - Class in org.apache.lucene.codecs.lucene70
-
Lucene 7.0 Segment info format.
- Lucene70SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.lucene70.Lucene70SegmentInfoFormat
-
Sole constructor.
- LUCENE_6_0_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_0_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_1_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_2_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_2_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_3_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_4_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_4_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_4_2 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_5_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_5_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_6_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_6_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_6_2 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_6_3 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_6_4 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_6_6_5 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_0_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_0_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_1_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_2_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_2_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_3_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_3_1 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_4_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_5_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_6_0 - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_7_7_0 - Static variable in class org.apache.lucene.util.Version
-
Match settings and bugs in Lucene's 7.7.0 release.
- LUCENE_CURRENT - Static variable in class org.apache.lucene.util.Version
-
- LUCENE_MAIN_VERSION - Static variable in class org.apache.lucene.util.Constants
-
- LUCENE_MATCH_VERSION_PARAM - Static variable in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- LUCENE_QUERY_CONVERSION_ERROR - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- LUCENE_VERSION - Static variable in class org.apache.lucene.util.Constants
-
- LuceneDictionary - Class in org.apache.lucene.search.spell
-
Lucene Dictionary: terms taken from the given field
of a Lucene index.
- LuceneDictionary(IndexReader, String) - Constructor for class org.apache.lucene.search.spell.LuceneDictionary
-
Creates a new Dictionary, pulling source terms from
the specified field
in the provided reader
- LuceneFixedGap - Class in org.apache.lucene.codecs.blockterms
-
- LuceneFixedGap() - Constructor for class org.apache.lucene.codecs.blockterms.LuceneFixedGap
-
- LuceneFixedGap(int) - Constructor for class org.apache.lucene.codecs.blockterms.LuceneFixedGap
-
- LuceneJUnit3MethodProvider - Class in org.apache.lucene.util
-
Backwards compatible test* method provider (public, non-static).
- LuceneJUnit3MethodProvider() - Constructor for class org.apache.lucene.util.LuceneJUnit3MethodProvider
-
- LuceneLevenshteinDistance - Class in org.apache.lucene.search.spell
-
Damerau-Levenshtein (optimal string alignment) implemented in a consistent
way as Lucene's FuzzyTermsEnum with the transpositions option enabled.
- LuceneLevenshteinDistance() - Constructor for class org.apache.lucene.search.spell.LuceneLevenshteinDistance
-
Creates a new comparator, mimicing the behavior of Lucene's internal
edit distance.
- luceneMatchVersion - Variable in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
the luceneVersion arg
- LucenePackage - Class in org.apache.lucene
-
Lucene's package information, including version.
- LuceneTestCase - Class in org.apache.lucene.util
-
Base class for all Lucene unit tests, Junit3 or Junit4 variant.
- LuceneTestCase() - Constructor for class org.apache.lucene.util.LuceneTestCase
-
- LuceneTestCase.AwaitsFix - Annotation Type in org.apache.lucene.util
-
Annotation for tests which exhibit a known issue and are temporarily disabled.
- LuceneTestCase.BadApple - Annotation Type in org.apache.lucene.util
-
Annotation for tests that fail frequently and are not executed in Jenkins builds
to not spam mailing lists with false reports.
- LuceneTestCase.Monster - Annotation Type in org.apache.lucene.util
-
Annotation for monster tests that require special setup (e.g.
- LuceneTestCase.Nightly - Annotation Type in org.apache.lucene.util
-
Annotation for tests that should only be run during nightly builds.
- LuceneTestCase.Slow - Annotation Type in org.apache.lucene.util
-
Annotation for tests that are slow.
- LuceneTestCase.SuppressCodecs - Annotation Type in org.apache.lucene.util
-
Annotation for test classes that should avoid certain codec types
(because they are expensive, for example).
- LuceneTestCase.SuppressFileSystems - Annotation Type in org.apache.lucene.util
-
Annotation for test classes that should avoid mock filesystem types
(because they test a bug that only happens on linux, for example).
- LuceneTestCase.SuppressFsync - Annotation Type in org.apache.lucene.util
-
Annotation for test classes that should avoid always omit
actual fsync calls from reaching the filesystem.
- LuceneTestCase.SuppressReproduceLine - Annotation Type in org.apache.lucene.util
-
Suppress the default reproduce with: ant test...
Your own listener can be added as needed for your build.
- LuceneTestCase.SuppressSysoutChecks - Annotation Type in org.apache.lucene.util
-
Ignore
TestRuleLimitSysouts
for any suite which is known to print
over the default limit of bytes to
System.out
or
System.err
.
- LuceneTestCase.SuppressTempFileChecks - Annotation Type in org.apache.lucene.util
-
Marks any suites which are known not to close all the temporary
files.
- LuceneTestCase.ThrowingRunnable - Interface in org.apache.lucene.util
-
A runnable that can throw any checked exception.
- LuceneTestCase.Weekly - Annotation Type in org.apache.lucene.util
-
Annotation for tests that should only be run during weekly builds
- LuceneVarGapDocFreqInterval - Class in org.apache.lucene.codecs.blockterms
-
- LuceneVarGapDocFreqInterval() - Constructor for class org.apache.lucene.codecs.blockterms.LuceneVarGapDocFreqInterval
-
- LuceneVarGapDocFreqInterval(int, int) - Constructor for class org.apache.lucene.codecs.blockterms.LuceneVarGapDocFreqInterval
-
- LuceneVarGapFixedInterval - Class in org.apache.lucene.codecs.blockterms
-
- LuceneVarGapFixedInterval() - Constructor for class org.apache.lucene.codecs.blockterms.LuceneVarGapFixedInterval
-
- LuceneVarGapFixedInterval(int) - Constructor for class org.apache.lucene.codecs.blockterms.LuceneVarGapFixedInterval
-
- m - Variable in class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
- MAC_OS_X - Static variable in class org.apache.lucene.util.Constants
-
True iff running on Mac OS X
- madvise(ByteBuffer, int) - Static method in class org.apache.lucene.store.NativePosixUtil
-
- magnitude - Variable in class org.apache.lucene.spatial3d.geom.GeoPoint
-
This is the lazily-evaluated magnitude.
- magnitude() - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
Compute the linear magnitude of the point.
- magnitude(double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute a magnitude of an x,y,z value.
- magnitude() - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the magnitude of this vector.
- main(String[]) - Static method in class org.apache.lucene.benchmark.byTask.Benchmark
-
Run the benchmark algorithm.
- main(String[]) - Static method in class org.apache.lucene.benchmark.byTask.programmatic.Sample
-
- main(String[]) - Static method in class org.apache.lucene.benchmark.quality.trec.QueryDriver
-
- main(String[]) - Static method in class org.apache.lucene.benchmark.quality.utils.QualityQueriesFinder
-
- main(String[]) - Static method in class org.apache.lucene.benchmark.utils.ExtractReuters
-
- main(String[]) - Static method in class org.apache.lucene.benchmark.utils.ExtractWikipedia
-
- main(String[]) - Static method in class org.apache.lucene.demo.facet.AssociationsFacetsExample
-
Runs the sum int/float associations examples and prints the results.
- main(String[]) - Static method in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
Runs the search and drill-down examples and prints the results.
- main(String[]) - Static method in class org.apache.lucene.demo.facet.ExpressionAggregationFacetsExample
-
Runs the search and drill-down examples and prints the results.
- main(String[]) - Static method in class org.apache.lucene.demo.facet.MultiCategoryListsFacetsExample
-
Runs the search example and prints the results.
- main(String[]) - Static method in class org.apache.lucene.demo.facet.RangeFacetsExample
-
Runs the search and drill-down examples and prints the results.
- main(String[]) - Static method in class org.apache.lucene.demo.facet.SimpleFacetsExample
-
Runs the search and drill-down examples and prints the results.
- main(String[]) - Static method in class org.apache.lucene.demo.facet.SimpleSortedSetFacetsExample
-
Runs the search and drill-down examples and prints the results.
- main(String[]) - Static method in class org.apache.lucene.demo.IndexFiles
-
Index all text files under a directory.
- main(String[]) - Static method in class org.apache.lucene.demo.SearchFiles
-
Simple command-line based search demo.
- main(String[]) - Static method in class org.apache.lucene.facet.taxonomy.PrintTaxonomyStats
-
Command-line tool.
- main(String[]) - Static method in class org.apache.lucene.index.CheckIndex
-
Command-line interface to check and exorcise corrupt segments from an index.
- main(String[]) - Static method in class org.apache.lucene.index.FixBrokenOffsets
-
- main(String[]) - Static method in class org.apache.lucene.index.IndexSplitter
-
- main(String[]) - Static method in class org.apache.lucene.index.IndexUpgrader
-
Main method to run {code IndexUpgrader} from the
command-line.
- main(String[]) - Static method in class org.apache.lucene.index.MultiPassIndexSplitter
-
- main(String[]) - Static method in class org.apache.lucene.misc.GetTermInfo
-
- main(String[]) - Static method in class org.apache.lucene.misc.HighFreqTerms
-
- main(String[]) - Static method in class org.apache.lucene.misc.IndexMergeTool
-
- main(String[]) - Static method in class org.apache.lucene.store.LockStressTest
-
- main(String[]) - Static method in class org.apache.lucene.store.LockVerifyServer
-
- main(String[]) - Static method in class org.egothor.stemmer.Compile
-
Entry point to the Compile application.
- main(String[]) - Static method in class org.egothor.stemmer.DiffIt
-
Entry point to the DiffIt application.
- major - Variable in class org.apache.lucene.util.Version
-
Major version, the difference between stable and trunk
- makeAnyBinary() - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts all binary terms.
- makeAnyChar() - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts any single codepoint.
- makeAnyString() - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts all strings.
- makeBinary(BytesRef) - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts the single given
binary term.
- makeBinaryInterval(BytesRef, boolean, BytesRef, boolean) - Static method in class org.apache.lucene.util.automaton.Automata
-
Creates a new deterministic, minimal automaton accepting
all binary terms in the specified interval.
- makeChar(int) - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts a single codepoint of
the given value.
- makeCharRange(int, int) - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts a single codepoint whose
value is in the given interval (including both end points).
- makeCompositeStrategy(Config, Map<String, String>, SpatialContext) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- makeDecimalInterval(int, int, int) - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new automaton that accepts strings representing decimal (base 10)
non-negative integers in the given interval.
- makeDistanceValueSource(Point, double) - Method in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- makeDistanceValueSource(Point, double) - Method in class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
- makeDistanceValueSource(Point, double) - Method in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy
-
Unsupported.
- makeDistanceValueSource(Point, double) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- makeDistanceValueSource(Point, double) - Method in class org.apache.lucene.spatial.serialized.SerializedDVStrategy
-
- makeDistanceValueSource(Point) - Method in class org.apache.lucene.spatial.SpatialStrategy
-
- makeDistanceValueSource(Point, double) - Method in class org.apache.lucene.spatial.SpatialStrategy
-
Make a ValueSource returning the distance between the center of the
indexed shape and queryPoint
.
- makeDistanceValueSource(Point, double) - Method in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
- makeDocument() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
Creates a
Document
object ready for indexing.
- makeDocument(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- makeDocument() - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- makeDocument(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- makeEmpty() - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton with the empty language.
- makeEmptyString() - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts only the empty string.
- makeExactGeoCircle(PlanetModel, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoCircleFactory
-
Create an GeoCircle from a center, a radius and a desired accuracy.
- makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- makeGeoArea(PlanetModel, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoAreaFactory
-
Create a GeoArea of the right kind given the specified bounds.
- makeGeoArea(PlanetModel, double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoAreaFactory
-
Create a GeoArea of the right kind given (x,y,z) bounds.
- makeGeoBBox(PlanetModel, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoBBoxFactory
-
Create a geobbox of the right kind given the specified bounds.
- makeGeoBBox(PlanetModel, LatLonBounds) - Static method in class org.apache.lucene.spatial3d.geom.GeoBBoxFactory
-
Create a geobbox of the right kind given the specified
LatLonBounds
.
- makeGeoCircle(PlanetModel, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoCircleFactory
-
Create a GeoCircle from a center and a cutoff angle.
- makeGeoConcavePolygon(PlanetModel, List<GeoPoint>) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoConcavePolygon using the specified points.
- makeGeoConcavePolygon(PlanetModel, List<GeoPoint>, List<GeoPolygon>) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoConcavePolygon using the specified points and holes.
- makeGeoConvexPolygon(PlanetModel, List<GeoPoint>) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoConvexPolygon using the specified points.
- makeGeoConvexPolygon(PlanetModel, List<GeoPoint>, List<GeoPolygon>) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoConvexPolygon using the specified points and holes.
- makeGeoPath(PlanetModel, double, GeoPoint[]) - Static method in class org.apache.lucene.spatial3d.geom.GeoPathFactory
-
Create a GeoPath of the right kind given the specified information.
- makeGeoPointShape(PlanetModel, double, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoPointShapeFactory
-
Create a GeoPointShape with the provided information.
- makeGeoPolygon(PlanetModel, GeoPolygonFactory.PolygonDescription) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoPolygon using the specified points and holes, using order to determine
siding of the polygon.
- makeGeoPolygon(PlanetModel, GeoPolygonFactory.PolygonDescription, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoPolygon using the specified points and holes, using order to determine
siding of the polygon.
- makeGeoPolygon(PlanetModel, List<GeoPoint>) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoPolygon using the specified points and holes, using order to determine
siding of the polygon.
- makeGeoPolygon(PlanetModel, List<GeoPoint>, List<GeoPolygon>) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoPolygon using the specified points and holes, using order to determine
siding of the polygon.
- makeGeoPolygon(PlanetModel, List<GeoPoint>, List<GeoPolygon>, double) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a GeoPolygon using the specified points and holes, using order to determine
siding of the polygon.
- makeGridShapeIntersectsQuery(Shape) - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- makeLargeGeoPolygon(PlanetModel, List<GeoPolygonFactory.PolygonDescription>) - Static method in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory
-
Create a large GeoPolygon.
- makeLuceneQueryField(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- makeLuceneQueryFieldNoBoost(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.AndQuery
-
- makeLuceneQueryFieldNoBoost(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.DistanceQuery
-
- makeLuceneQueryFieldNoBoost(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- makeLuceneQueryFieldNoBoost(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.NotQuery
-
- makeLuceneQueryFieldNoBoost(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.OrQuery
-
- makeLuceneQueryFieldNoBoost(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- makeLuceneQueryFieldNoBoost(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- makeLuceneQueryNoBoost(BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- makeLuceneSubQueriesField(String, BasicQueryFactory) - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- makeOverlapRatioValueSource(Rectangle, double) - Method in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- makeQuery() - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- makeQuery(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- makeQuery(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
-
- makeQuery() - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
-
- makeQuery(int) - Method in interface org.apache.lucene.benchmark.byTask.feeds.QueryMaker
-
Create the next query, of the given size.
- makeQuery() - Method in interface org.apache.lucene.benchmark.byTask.feeds.QueryMaker
-
Create the next query
- makeQuery(SpatialArgs) - Method in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- makeQuery(SpatialArgs) - Method in class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
- makeQuery(SpatialArgs) - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- makeQuery(SpatialArgs) - Method in class org.apache.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
-
- makeQuery(SpatialArgs) - Method in class org.apache.lucene.spatial.serialized.SerializedDVStrategy
-
Returns a Query that should be used in a random-access fashion.
- makeQuery(SpatialArgs) - Method in class org.apache.lucene.spatial.SpatialStrategy
-
Make a Query based principally on
SpatialOperation
and
Shape
from the supplied
args
.
- makeQuery(SpatialArgs) - Method in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
- makeQueryFromShape(Shape) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- makeRecipDistanceValueSource(Shape) - Method in class org.apache.lucene.spatial.SpatialStrategy
-
- makeRPTStrategy(String, Config, Map<String, String>, SpatialContext) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- makeSegmentCommitInfo(String, int, int, double, String) - Static method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Make a new
SegmentCommitInfo
with the given
maxDoc
,
numDeletedDocs
and
sizeInBytes
, which are usually the
numbers that merge policies care about.
- makeSerializedDVStrategy(String, Config, Map<String, String>, SpatialContext) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- makeShape() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
Constructs a bounding box shape out of the encoded cell
- makeShape() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.QuadCell
-
- makeShapeConverter(SpatialStrategy, Config, String) - Static method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
Optionally converts points to circles, and optionally bbox'es result.
- makeShapeFromString(SpatialStrategy, String, String) - Static method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- makeShapeValueSource() - Method in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- makeShapeValueSource() - Method in class org.apache.lucene.spatial.serialized.SerializedDVStrategy
-
Provides access to each shape per document
- makeSpanClause() - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- makeSpatialStrategy(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
Builds a SpatialStrategy from configuration options.
- makeSpatialStrategy(Config, Map<String, String>, SpatialContext) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- makeSPT(Map<String, String>, ClassLoader, SpatialContext) - Static method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
The factory is looked up via "prefixTree" in args, expecting "geohash" or "quad".
- makeStopSet(String...) - Static method in class org.apache.lucene.analysis.StopFilter
-
Builds a Set from an array of stop words,
appropriate for passing into the StopFilter constructor.
- makeStopSet(List<?>) - Static method in class org.apache.lucene.analysis.StopFilter
-
Builds a Set from an array of stop words,
appropriate for passing into the StopFilter constructor.
- makeStopSet(String[], boolean) - Static method in class org.apache.lucene.analysis.StopFilter
-
Creates a stopword set from the given stopword array.
- makeStopSet(List<?>, boolean) - Static method in class org.apache.lucene.analysis.StopFilter
-
Creates a stopword set from the given stopword list.
- makeString(String) - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts the single given
string.
- makeString(int[], int, int) - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic) automaton that accepts the single given
string from the specified unicode code points.
- makeStringUnion(Collection<BytesRef>) - Static method in class org.apache.lucene.util.automaton.Automata
-
Returns a new (deterministic and minimal) automaton that accepts the union
of the given collection of
BytesRef
s representing UTF-8 encoded
strings.
- makeXYZSolid(PlanetModel, double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.XYZSolidFactory
-
Create a XYZSolid of the right kind given (x,y,z) bounds.
- makeXYZSolid(PlanetModel, XYZBounds) - Static method in class org.apache.lucene.spatial3d.geom.XYZSolidFactory
-
Create a XYZSolid of the right kind given (x,y,z) bounds.
- map(FileChannel.MapMode, long, long) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- mapAllOrds(Iterable<Number>) - Static method in class org.apache.lucene.codecs.MissingOrdRemapper
-
remaps every ord+1 on this iterable
- mapMissingToOrd0(Iterable<Number>) - Static method in class org.apache.lucene.codecs.MissingOrdRemapper
-
remaps ord -1 to ord 0 on this iterable.
- MapOfSets<K,V> - Class in org.apache.lucene.util
-
Helper class for keeping Lists of Objects associated with keys.
- MapOfSets(Map<K, Set<V>>) - Constructor for class org.apache.lucene.util.MapOfSets
-
- mappedDocID - Variable in class org.apache.lucene.index.DocIDMerger.Sub
-
Mapped doc ID
- MappedMultiFields - Class in org.apache.lucene.index
-
A
Fields
implementation that merges multiple
Fields into one, and maps around deleted documents.
- MappedMultiFields(MergeState, MultiFields) - Constructor for class org.apache.lucene.index.MappedMultiFields
-
Create a new MappedMultiFields for merging, based on the supplied
mergestate and merged view of terms.
- mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
ordinal map mapping ords from values
to global ord space
- mapping - Variable in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
ordinal map mapping ords from values
to global ord space
- MappingCharFilter - Class in org.apache.lucene.analysis.charfilter
-
Simplistic
CharFilter
that applies the mappings
contained in a
NormalizeCharMap
to the character
stream, and correcting the resulting changes to the
offsets.
- MappingCharFilter(NormalizeCharMap, Reader) - Constructor for class org.apache.lucene.analysis.charfilter.MappingCharFilter
-
Default constructor that takes a Reader
.
- MappingCharFilterFactory - Class in org.apache.lucene.analysis.charfilter
-
- MappingCharFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.charfilter.MappingCharFilterFactory
-
Creates a new MappingCharFilterFactory
- MARGIN_DEFAULT - Static variable in class org.apache.lucene.search.vectorhighlight.BaseFragListBuilder
-
- mark(int) - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- markFailed() - Method in class org.apache.lucene.util.TestRuleMarkFailure
-
Taints this object and any chained as having failures.
- markOrds(long, LongBitSet) - Method in class org.apache.lucene.util.bkd.OfflinePointReader
-
- markOrds(long, LongBitSet) - Method in class org.apache.lucene.util.bkd.PointReader
-
Iterates through the next count
ords, marking them in the provided ordBitSet
.
- markSupported() - Method in class org.apache.lucene.analysis.MockReaderWrapper
-
- markSupported() - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- markTaskEnd(TaskStats, int) - Method in class org.apache.lucene.benchmark.byTask.stats.Points
-
mark the end of a task
- markTaskStart(PerfTask, int) - Method in class org.apache.lucene.benchmark.byTask.stats.Points
-
Mark that a task is starting.
- match - Variable in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery
-
- match(float, String, Collection<Explanation>) - Static method in class org.apache.lucene.search.Explanation
-
Create a new explanation for a match.
- match(float, String, Explanation...) - Static method in class org.apache.lucene.search.Explanation
-
Create a new explanation for a match.
- match(int) - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-
Validation method to determine whether a docid should be in the result set.
- match - Variable in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-
- MATCH_WITH_NO_TERMS - Static variable in class org.apache.lucene.search.MatchesUtils
-
Indicates a match with no term positions, for example on a Point or DocValues field,
or a field indexed as docs and freqs only
- MatchAllBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchAllBits
-
- MatchAllDocsQuery - Class in org.apache.lucene.search
-
A query that matches all documents.
- MatchAllDocsQuery() - Constructor for class org.apache.lucene.search.MatchAllDocsQuery
-
- MatchAllDocsQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- MatchAllDocsQueryBuilder() - Constructor for class org.apache.lucene.queryparser.xml.builders.MatchAllDocsQueryBuilder
-
- MatchAllDocsQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
MatchAllDocsQueryNode
indicates that a query node tree or subtree
will match all documents if executed in the index.
- MatchAllDocsQueryNode() - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.MatchAllDocsQueryNode
-
- MatchAllDocsQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- MatchAllDocsQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.MatchAllDocsQueryNodeBuilder
-
- MatchAllDocsQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- MatchAllDocsQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.MatchAllDocsQueryNodeProcessor
-
- matchAlmost(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns a List
of keys that almost match the argument key.
- matchAlmost(CharSequence, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns a List
of keys that almost match the argument key.
- matchCost - Variable in class org.apache.lucene.search.DisiWrapper
-
- matchCost() - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- matchCost() - Method in class org.apache.lucene.search.intervals.IntervalIterator
-
An indication of the average cost of iterating over all intervals in a document
- matchCost() - Method in class org.apache.lucene.search.TwoPhaseIterator
-
- matchEnd - Variable in class org.apache.lucene.search.spans.NearSpansOrdered
-
- matches(char[], int) - Method in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
-
- matches(char[], int) - Method in class org.apache.lucene.analysis.pt.RSLPStemmerBase.RuleWithSetExceptions
-
- matches(char[], int) - Method in class org.apache.lucene.analysis.pt.RSLPStemmerBase.RuleWithSuffixExceptions
-
- matches(int) - Method in class org.apache.lucene.queries.function.ValueSourceScorer
-
Override to decide if this document matches.
- matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
- matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.FilterWeight
-
- matches(String, LeafReaderContext, int) - Method in class org.apache.lucene.search.intervals.IntervalsSource
-
Return a
MatchesIterator
over the intervals defined by this
IntervalsSource
for a
given document and field
Returns
null
if no intervals exist in the given document and field
- Matches - Interface in org.apache.lucene.search
-
- matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.spans.SpanWeight
-
- matches() - Method in class org.apache.lucene.search.TwoPhaseIterator
-
- matches(LeafReaderContext, int) - Method in class org.apache.lucene.search.Weight
-
Returns
Matches
for a specific document, or
null
if the document
does not match the parent query
A query match that contains no position information (for example, a Point or
DocValues query) will return
MatchesUtils.MATCH_WITH_NO_TERMS
- MatchesAsserter(Query, IndexSearcher) - Constructor for class org.apache.lucene.search.CheckHits.MatchesAsserter
-
- matchesExtension(String, String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Returns true if the given filename ends with the given extension.
- MatchesIterator - Interface in org.apache.lucene.search
-
An iterator over match positions (and optionally offsets) for a single document and field
To iterate over the matches, call
MatchesIterator.next()
until it returns
false
, retrieving
positions and/or offsets after each call.
- MatchesUtils - Class in org.apache.lucene.search
-
- matchingChar(char) - Method in class org.apache.lucene.queryparser.surround.query.SrndTruncQuery
-
- MatchingDocs(LeafReaderContext, DocIdSet, int, float[]) - Constructor for class org.apache.lucene.facet.FacetsCollector.MatchingDocs
-
Sole constructor.
- MatchNoBits(int) - Constructor for class org.apache.lucene.util.Bits.MatchNoBits
-
- MatchNoDocsQuery - Class in org.apache.lucene.search
-
A query that matches no documents.
- MatchNoDocsQuery() - Constructor for class org.apache.lucene.search.MatchNoDocsQuery
-
Default constructor
- MatchNoDocsQuery(String) - Constructor for class org.apache.lucene.search.MatchNoDocsQuery
-
Provides a reason explaining why this query was used
- MatchNoDocsQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
MatchNoDocsQueryNode
indicates that a query node tree or subtree
will not match any documents if executed in the index.
- MatchNoDocsQueryNode() - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.MatchNoDocsQueryNode
-
- MatchNoDocsQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- MatchNoDocsQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.MatchNoDocsQueryNodeBuilder
-
- matchPrefix(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns an alphabetical List
of all keys in the trie that
begin with a given prefix.
- matchPrefix(CharSequence, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns an alphabetical List
of all keys in the trie that
begin with a given prefix.
- matchStart - Variable in class org.apache.lucene.search.spans.NearSpansOrdered
-
- matchTheseItems(int[]) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
Convenience subclass of TermsQuery
- matchWidth - Variable in class org.apache.lucene.search.spans.NearSpansOrdered
-
- MathUtil - Class in org.apache.lucene.util
-
Math static utility methods.
- max - Variable in class org.apache.lucene.facet.range.DoubleRange
-
Maximum (inclusive.
- max - Variable in class org.apache.lucene.facet.range.LongRange
-
Maximum (inclusive).
- max - Variable in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- max - Variable in class org.apache.lucene.queries.function.valuesource.ScaleFloatFunction
-
- max - Variable in class org.apache.lucene.search.DocValuesStats
-
- max() - Method in class org.apache.lucene.search.DocValuesStats
-
The maximum value of the field.
- max - Variable in class org.apache.lucene.util.automaton.Transition
-
Maximum accepted label (inclusive).
- MAX_ARRAY_LENGTH - Static variable in class org.apache.lucene.util.ArrayUtil
-
Maximum length for an array (Integer.MAX_VALUE - RamUsageEstimator.NUM_BYTES_ARRAY_HEADER).
- MAX_BINARY_FIELD_LENGTH - Static variable in class org.apache.lucene.codecs.memory.MemoryDocValuesFormat
-
Maximum length for each binary doc values field.
- MAX_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.packed.DirectMonotonicWriter
-
- MAX_CATEGORY_PATH_LENGTH - Static variable in class org.apache.lucene.facet.taxonomy.FacetLabel
-
The maximum number of characters a
FacetLabel
can have.
- MAX_CODE_LENGTH - Static variable in class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilterFactory
-
parameter name: restricts the length of the phonetic code
- MAX_CODE_LENGTH - Static variable in class org.apache.lucene.analysis.phonetic.PhoneticFilterFactory
-
parameter name: restricts the length of the phonetic code
- MAX_DIMENSIONS - Static variable in class org.apache.lucene.index.PointValues
-
Maximum number of dimensions
- MAX_DIMS - Static variable in class org.apache.lucene.util.bkd.BKDWriter
-
Maximum number of dimensions
- MAX_DIST_ERR - Static variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- MAX_DOCS - Static variable in class org.apache.lucene.index.IndexWriter
-
Hard limit on maximum number of documents that may be added to the
index.
- MAX_FREQUENCE - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
Maximum bigram frequency (used in the smoothing function).
- MAX_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.CodepointCountFilterFactory
-
- MAX_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.LengthFilterFactory
-
- MAX_LAT_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
-
Maximum latitude value.
- MAX_LAT_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
-
max latitude value in radians
- MAX_LEVELS - Static variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- MAX_LEVELS_POSSIBLE - Static variable in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- MAX_LEVELS_POSSIBLE - Static variable in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- MAX_LON_ENCODED - Static variable in class org.apache.lucene.geo.GeoEncodingUtils
-
- MAX_LON_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
-
Maximum longitude value.
- MAX_LON_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
-
max longitude value in radians
- MAX_NUM_BITS - Static variable in class org.apache.lucene.util.LongBitSet
-
The maximum numBits
supported.
- MAX_NUM_BYTES - Static variable in class org.apache.lucene.index.PointValues
-
Maximum number of bytes for each dimension
- MAX_OUTPUT_TOKEN_SIZE_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.FingerprintFilterFactory
-
- MAX_POINTS - Static variable in class org.apache.lucene.benchmark.quality.QualityStats
-
Number of points for which precision is computed.
- MAX_POSITION - Static variable in class org.apache.lucene.index.IndexWriter
-
Maximum value of the token position in an indexed field.
- MAX_RECURSION_LEVEL - Static variable in class org.apache.lucene.util.automaton.Operations
-
Maximum level of recursion allowed in recursive operations.
- MAX_ROWS_OR_COLUMNS - Static variable in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter
-
Maximum number of supported rows (or columns).
- MAX_SORTED_SET_ORDS - Static variable in class org.apache.lucene.codecs.memory.DirectDocValuesFormat
-
The sum of the number of values across all documents
in a sorted set field cannot exceed this.
- MAX_START_OFFSET - Static variable in class org.apache.lucene.analysis.miscellaneous.LimitTokenOffsetFilterFactory
-
- MAX_STORED_STRING_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
-
Maximum length string for a stored field.
- MAX_TEMPFILES - Static variable in class org.apache.lucene.util.OfflineSorter
-
Maximum number of temporary files before doing an intermediate merge.
- MAX_TERM_LENGTH - Static variable in class org.apache.lucene.index.IndexWriter
-
Absolute hard maximum length for a term, in bytes once
encoded as UTF8.
- MAX_TOKEN_COUNT_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilterFactory
-
- MAX_TOKEN_LENGTH - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
- MAX_TOKEN_LENGTH_LIMIT - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Absolute maximum sized token
- MAX_TOKEN_LENGTH_LIMIT - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Absolute maximum sized token
- MAX_TOKEN_POSITION_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilterFactory
-
- MAX_TOTAL_BYTES_LENGTH - Static variable in class org.apache.lucene.codecs.memory.DirectDocValuesFormat
-
The sum of all byte lengths for binary field, or for
the unique values in sorted or sorted set fields, cannot
exceed this.
- MAX_UTF8_BYTES_PER_CHAR - Static variable in class org.apache.lucene.util.UnicodeUtil
-
Maximum number of UTF8 bytes per UTF16 character.
- MAX_VALUE - Static variable in class org.apache.lucene.document.BigIntegerPoint
-
A constant holding the maximum value a BigIntegerPoint can have, 2127-1.
- MAX_VALUE - Static variable in class org.apache.lucene.document.InetAddressPoint
-
The maximum value that an ip address can hold.
- MAX_VERSION - Static variable in class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
version must be <= this, because we encode with ZigZag.
- MAX_WORD_COUNT - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
- MAX_X_POLE - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Max X pole
- MAX_Y_POLE - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Max Y pole
- maxBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- maxBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- maxCFSSegmentSize - Variable in class org.apache.lucene.index.MergePolicy
-
If the size of the merged segment exceeds
this value then it will not use compound file format.
- maxDoc() - Method in class org.apache.lucene.index.BaseCompositeReader
-
- maxDoc - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Document count (does not take deletions into account).
- maxDoc() - Method in class org.apache.lucene.index.FilterCodecReader
-
- maxDoc() - Method in class org.apache.lucene.index.FilterLeafReader
-
- maxDoc() - Method in class org.apache.lucene.index.IndexReader
-
Returns one greater than the largest possible document number.
- maxDoc - Variable in class org.apache.lucene.index.IndexWriter.DocStats
-
The total number of docs in this index, including
docs not yet flushed (still in the RAM buffer),
not counting deletions.
- maxDoc() - Method in class org.apache.lucene.index.IndexWriter
-
- maxDoc() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- maxDoc() - Method in class org.apache.lucene.index.SegmentInfo
-
Returns number of documents in this segment (deletions
are not taken into account).
- maxDoc() - Method in class org.apache.lucene.index.SegmentReader
-
- maxDoc() - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the index's maxDoc
- maxDoc() - Method in class org.apache.lucene.search.CollectionStatistics
-
returns the total number of documents, regardless of
whether they all contain values for this field.
- maxDoc() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- maxDoc - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- maxDocs - Variable in class org.apache.lucene.index.MergeState
-
Max docs per reader
- MaxDocValueSource - Class in org.apache.lucene.queries.function.valuesource
-
- MaxDocValueSource() - Constructor for class org.apache.lucene.queries.function.valuesource.MaxDocValueSource
-
- MaxFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
MaxFloatFunction
returns the max of its components.
- MaxFloatFunction(ValueSource[]) - Constructor for class org.apache.lucene.queries.function.valuesource.MaxFloatFunction
-
- maxHorizontalContext - Variable in class org.apache.lucene.analysis.synonym.SynonymMap
-
maxHorizontalContext: maximum context we need on the tokenstream
- MAXIMUM_SUPPORTED_DISTANCE - Static variable in class org.apache.lucene.util.automaton.LevenshteinAutomata
-
Maximum edit distance this class can generate an automaton for.
- maxLat - Variable in class org.apache.lucene.geo.EdgeTree
-
maximum latitude of this geometry's bounding box area
- maxLat - Variable in class org.apache.lucene.geo.Line
-
maximum latitude of this line's bounding box
- maxLat - Variable in class org.apache.lucene.geo.Polygon
-
maximum latitude of this polygon's bounding box area
- maxLat - Variable in class org.apache.lucene.geo.Rectangle
-
maximum latitude value (in degrees)
- maxLength - Variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter.LimitedStoredFieldVisitor
-
- maxLevels - Variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
- maxLevels - Variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- maxLon - Variable in class org.apache.lucene.geo.EdgeTree
-
maximum longitude of this geometry's bounding box area
- maxLon - Variable in class org.apache.lucene.geo.Line
-
maximum longitude of this line's bounding box
- maxLon - Variable in class org.apache.lucene.geo.Polygon
-
maximum longitude of this polygon's bounding box area
- maxLon - Variable in class org.apache.lucene.geo.Rectangle
-
minimum latitude value (in degrees)
- maxMergeDocs - Variable in class org.apache.lucene.index.LogMergePolicy
-
If a segment has more than this many documents then it
will never be merged.
- maxMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
-
If the size of a segment exceeds this value then it
will never be merged.
- maxMergeSizeForForcedMerge - Variable in class org.apache.lucene.index.LogMergePolicy
-
- maxNoHighlightPassages - Variable in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- MaxNonCompetitiveBoostAttribute - Interface in org.apache.lucene.search
-
- MaxNonCompetitiveBoostAttributeImpl - Class in org.apache.lucene.search
-
- MaxNonCompetitiveBoostAttributeImpl() - Constructor for class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- maxNumberOfSkipLevels - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
the maximum number of skip levels possible for this index
- maxNumPerKey - Variable in class org.apache.lucene.search.DiversifiedTopDocsCollector
-
- maxPackedValue - Variable in class org.apache.lucene.index.PointsStackTracker.Cell
-
- maxPackedValue - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
Maximum per-dim values, packed
- maxPassages - Variable in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- MaxPayloadFunction - Class in org.apache.lucene.queries.payloads
-
Returns the maximum payload score seen, else 1 if there are no payloads on the doc.
- MaxPayloadFunction() - Constructor for class org.apache.lucene.queries.payloads.MaxPayloadFunction
-
- maxPointsInLeafNode - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
- maxRecall(QualityQuery) - Method in interface org.apache.lucene.benchmark.quality.Judge
-
Return the maximal recall for the input quality query.
- maxRecall(QualityQuery) - Method in class org.apache.lucene.benchmark.quality.trec.TrecJudge
-
- maxScan - Variable in class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- maxScore - Variable in class org.apache.lucene.search.grouping.GroupDocs
-
Max score in this group
- maxScore - Variable in class org.apache.lucene.search.grouping.TopGroups
-
Highest score across all hits, or
Float.NaN
if scores were not computed.
- maxSegmentName - Variable in class org.apache.lucene.index.CheckIndex.Status
-
The greatest segment name.
- maxSubCellsByLevel - Variable in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- maxSubwordSize - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- maxTermFrequency - Variable in class org.apache.lucene.queries.CommonTermsQuery
-
- maxTermLen - Variable in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- maxTermPos - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
- maxUTF8Length(int) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Returns the maximum number of utf8 bytes required to encode a utf16 (e.g., java char[], String)
- maxValue(int) - Static method in class org.apache.lucene.util.packed.PackedInts
-
Calculates the maximum unsigned long that can be expressed with the given
number of bits.
- maxWeight - Variable in class org.apache.lucene.search.suggest.document.CompletionsTermsReader
-
Maximum entry weight for the suggester
- maxwidth(int, IntervalsSource) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Create an
IntervalsSource
that filters a sub-source by the width of its intervals
- maxX - Variable in class org.apache.lucene.geo.EdgeTree
-
maximum longitude of this component or any of its children
- maxY - Variable in class org.apache.lucene.geo.EdgeTree
-
maximum latitude of this component or any of its children
- MAYBE_CACHE_POLICY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- maybeChangeLiveIndexWriterConfig(Random, LiveIndexWriterConfig) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- maybeMerge() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: asks the mergePolicy whether any merges are
necessary now and if so, runs the requested merges and
then iterate (test again if merges are needed) until no
more merges are returned by the mergePolicy.
- maybeNewPrimary(long) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Called when the primary changed
- maybeRefresh() - Method in class org.apache.lucene.search.ReferenceManager
-
- maybeRefreshBlocking() - Method in class org.apache.lucene.search.ReferenceManager
-
- maybeStall(IndexWriter) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- maybeWrapReader(IndexReader) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Sometimes wrap the IndexReader as slow, parallel or filter reader (or
combinations of that)
- MB - Static variable in class org.apache.lucene.util.OfflineSorter
-
Convenience constant for megabytes
- mBitsToBytes(int) - Static method in class org.apache.lucene.util.ThrottledIndexOutput
-
- mean - Variable in class org.apache.lucene.search.DocValuesStats.NumericDocValuesStats
-
- mean() - Method in class org.apache.lucene.search.DocValuesStats.NumericDocValuesStats
-
The mean of all values of the field.
- mean - Variable in class org.apache.lucene.search.DocValuesStats.SortedNumericDocValuesStats
-
- mean() - Method in class org.apache.lucene.search.DocValuesStats.SortedNumericDocValuesStats
-
The mean of all values of the field.
- megabytes(long) - Static method in class org.apache.lucene.util.OfflineSorter.BufferSize
-
- Membership - Interface in org.apache.lucene.spatial3d.geom
-
Implemented by Geo3D shapes that can calculate if a point is within it or not.
- MemoryDocValuesFormat - Class in org.apache.lucene.codecs.memory
-
In-memory docvalues format
- MemoryDocValuesFormat() - Constructor for class org.apache.lucene.codecs.memory.MemoryDocValuesFormat
-
- MemoryDocValuesFormat(float) - Constructor for class org.apache.lucene.codecs.memory.MemoryDocValuesFormat
-
Creates a new MemoryDocValuesFormat with the specified
acceptableOverheadRatio
for NumericDocValues.
- MemoryIndex - Class in org.apache.lucene.index.memory
-
High-performance single-document main memory Apache Lucene fulltext search index.
- MemoryIndex() - Constructor for class org.apache.lucene.index.memory.MemoryIndex
-
Constructs an empty instance that will not store offsets or payloads.
- MemoryIndex(boolean) - Constructor for class org.apache.lucene.index.memory.MemoryIndex
-
Constructs an empty instance that can optionally store the start and end
character offset of each token term in the text.
- MemoryIndex(boolean, boolean) - Constructor for class org.apache.lucene.index.memory.MemoryIndex
-
Constructs an empty instance with the option of storing offsets and payloads.
- MemoryIndexOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
- MemoryIndexOffsetStrategy(UHComponents, Analyzer, Function<Query, Collection<Query>>) - Constructor for class org.apache.lucene.search.uhighlight.MemoryIndexOffsetStrategy
-
- MemoryOrdinalMap() - Constructor for class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
-
Sole constructor.
- MemoryPostingsFormat - Class in org.apache.lucene.codecs.memory
-
Stores terms and postings (docs, positions, payloads) in
RAM, using an FST.
- MemoryPostingsFormat() - Constructor for class org.apache.lucene.codecs.memory.MemoryPostingsFormat
-
- MemoryPostingsFormat(boolean, float) - Constructor for class org.apache.lucene.codecs.memory.MemoryPostingsFormat
-
Create MemoryPostingsFormat, specifying advanced FST options.
- merge(MergeState) - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
- merge(MergeState) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- merge(MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Merges in the fields from the readers in
mergeState
.
- merge(MergeState) - Method in class org.apache.lucene.codecs.FieldsConsumer
-
Merges in the fields from the readers in
mergeState
.
- merge(MergeState) - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsWriter
-
- merge(MergeState) - Method in class org.apache.lucene.codecs.NormsConsumer
-
Merges in the fields from the readers in
mergeState
.
- merge(MergeState) - Method in class org.apache.lucene.codecs.PointsWriter
-
Default merge implementation to merge incoming points readers by visiting all their points and
adding to this writer
- merge(MergeState) - Method in class org.apache.lucene.codecs.StoredFieldsWriter
-
Merges in the stored fields from the readers in
mergeState
.
- merge(MergeState) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Merges in the term vectors from the readers in
mergeState
.
- merge(Directory, Directory, DirectoryTaxonomyWriter.OrdinalMap, IndexWriter, DirectoryTaxonomyWriter, FacetsConfig) - Static method in class org.apache.lucene.facet.taxonomy.TaxonomyMergeUtils
-
Merges the given taxonomy and index directories and commits the changes to
the given writers.
- merge(IndexWriter, MergeTrigger, boolean) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- merge(MergePolicy.OneMerge) - Method in class org.apache.lucene.index.IndexWriter
-
Merges the indicated segments, replacing them in the stack with a
single segment.
- merge(IndexWriter, MergeTrigger, boolean) - Method in class org.apache.lucene.index.MergeScheduler
-
- merge(IndexWriter, MergeTrigger, boolean) - Method in class org.apache.lucene.index.NoMergeScheduler
-
- merge(IndexWriter, MergeTrigger, boolean) - Method in class org.apache.lucene.index.SerialMergeScheduler
-
Just do the merges in sequence.
- merge(List<Collection<SearchGroup<T>>>, int, int, Sort) - Static method in class org.apache.lucene.search.grouping.SearchGroup
-
Merges multiple collections of top groups, for example
obtained from separate index shards.
- merge(TopGroups<T>[], Sort, Sort, int, int, TopGroups.ScoreMergeMode) - Static method in class org.apache.lucene.search.grouping.TopGroups
-
Merges an array of TopGroups, for example obtained
from the second-pass collector across multiple
shards.
- merge(TextFragment) - Method in class org.apache.lucene.search.highlight.TextFragment
-
- merge(int, TopSuggestDocs[]) - Static method in class org.apache.lucene.search.suggest.document.TopSuggestDocs
-
Returns a new TopSuggestDocs, containing topN results across
the provided TopSuggestDocs, sorting by score.
- merge(int, TopDocs[]) - Static method in class org.apache.lucene.search.TopDocs
-
Returns a new TopDocs, containing topN results across
the provided TopDocs, sorting by score.
- merge(int, int, TopDocs[], boolean) - Static method in class org.apache.lucene.search.TopDocs
-
- merge(Sort, int, TopFieldDocs[]) - Static method in class org.apache.lucene.search.TopDocs
-
Returns a new TopFieldDocs, containing topN results across
the provided TopFieldDocs, sorting by the specified
Sort
.
- merge(Sort, int, int, TopFieldDocs[], boolean) - Static method in class org.apache.lucene.search.TopDocs
-
- merge(IndexOutput, List<MergeState.DocMap>, List<BKDReader>) - Method in class org.apache.lucene.util.bkd.BKDWriter
-
More efficient bulk-add for incoming
BKDReader
s.
- merge(Object, Object) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- merge(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
-
- merge(T, T) - Method in class org.apache.lucene.util.fst.Outputs
-
- merge(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
-
- merge(Row, Row) - Method in class org.egothor.stemmer.Optimizer
-
Merge the given rows and return the resulting Row.
- merge(Cell, Cell) - Method in class org.egothor.stemmer.Optimizer
-
Merge the given Cells and return the resulting Cell.
- merge(Cell, Cell) - Method in class org.egothor.stemmer.Optimizer2
-
Merge the given Cells and return the resulting Cell.
- MERGE_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
-
A buffer size for merges set to 4096.
- MergeAbortedException() - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
-
- MergeAbortedException(String) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeAbortedException
-
- mergeBinaryField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Merges the binary docvalues from MergeState
.
- mergeCopyJobs - Variable in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Currently running merge pre-copy jobs
- MergedIterator<T extends java.lang.Comparable<T>> - Class in org.apache.lucene.util
-
Provides a merged sorted view from several sorted iterators.
- MergedIterator(Iterator<T>...) - Constructor for class org.apache.lucene.util.MergedIterator
-
- MergedIterator(boolean, Iterator<T>...) - Constructor for class org.apache.lucene.util.MergedIterator
-
- MergeException(String, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
-
Create a MergeException
.
- MergeException(Throwable, Directory) - Constructor for exception org.apache.lucene.index.MergePolicy.MergeException
-
Create a MergeException
.
- mergeFactor - Variable in class org.apache.lucene.index.LogMergePolicy
-
How many segments to merge at a time.
- mergeFieldInfos - Variable in class org.apache.lucene.index.MergeState
-
- mergeFinished() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Called by
IndexWriter
after the merge is done and all readers have been closed.
- mergeInfo - Variable in class org.apache.lucene.store.IOContext
-
- MergeInfo - Class in org.apache.lucene.store
-
A MergeInfo provides information required for a MERGE context.
- MergeInfo(int, long, boolean, int) - Constructor for class org.apache.lucene.store.MergeInfo
-
- mergeInit() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Called by
IndexWriter
after the merge started and from the
thread that will be executing the merge.
- mergeIsStable() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- mergeMaxNumSegments - Variable in class org.apache.lucene.store.MergeInfo
-
- mergeNormsField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.NormsConsumer
-
Merges the norms from toMerge
.
- mergeNumericField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Merges the numeric docvalues from MergeState
.
- mergeOneField(MergeState, FieldInfo) - Method in class org.apache.lucene.codecs.PointsWriter
-
Default naive merge implementation for one field: it just re-indexes all the values
from the incoming segment.
- mergePolicy() - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
- mergePolicy - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- MergePolicy - Class in org.apache.lucene.index
-
Expert: a MergePolicy determines the sequence of
primitive merge operations.
- MergePolicy() - Constructor for class org.apache.lucene.index.MergePolicy
-
Creates a new merge policy instance.
- MergePolicy(double, long) - Constructor for class org.apache.lucene.index.MergePolicy
-
Creates a new merge policy instance with default settings for noCFSRatio
and maxCFSSegmentSize.
- MergePolicy.MergeAbortedException - Exception in org.apache.lucene.index
-
- MergePolicy.MergeContext - Interface in org.apache.lucene.index
-
This interface represents the current context of the merge selection process.
- MergePolicy.MergeException - Exception in org.apache.lucene.index
-
Exception thrown if there are any problems while executing a merge.
- MergePolicy.MergeSpecification - Class in org.apache.lucene.index
-
A MergeSpecification instance provides the information
necessary to perform multiple merges.
- MergePolicy.OneMerge - Class in org.apache.lucene.index
-
OneMerge provides the information necessary to perform
an individual primitive merge operation, resulting in
a single new segment.
- MergePolicy.OneMergeProgress - Class in org.apache.lucene.index
-
Progress and state for an executing merge.
- MergePolicy.OneMergeProgress.PauseReason - Enum in org.apache.lucene.index
-
Reason for pausing the merge thread.
- MergePolicyWrapper - Class in org.apache.lucene.index
-
- MergePolicyWrapper(MergePolicy) - Constructor for class org.apache.lucene.index.MergePolicyWrapper
-
Deprecated.
Creates a new merge policy instance wrapping another.
- mergePos - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
- MergeRateLimiter - Class in org.apache.lucene.index
-
- MergeRateLimiter(MergePolicy.OneMergeProgress) - Constructor for class org.apache.lucene.index.MergeRateLimiter
-
Sole constructor.
- mergeRounds - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
number of partition merges
- merges - Variable in class org.apache.lucene.index.MergePolicy.MergeSpecification
-
The subset of segments to be included in the primitive merge.
- mergeScheduler - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- MergeScheduler - Class in org.apache.lucene.index
-
Expert:
IndexWriter
uses an instance
implementing this interface to execute the merges
selected by a
MergePolicy
.
- MergeScheduler() - Constructor for class org.apache.lucene.index.MergeScheduler
-
Sole constructor.
- MergeScore() - Constructor for class org.apache.lucene.index.TieredMergePolicy.MergeScore
-
Sole constructor.
- mergeSegmentResults(int, int, boolean) - Method in class org.apache.lucene.search.grouping.GroupFacetCollector
-
Returns grouped facet results that were computed over zero or more segments.
- mergeSortedField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Merges the sorted docvalues from toMerge
.
- mergeSortedNumericField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Merges the sorted docvalues from toMerge
.
- mergeSortedSetField(FieldInfo, MergeState) - Method in class org.apache.lucene.codecs.DocValuesConsumer
-
Merges the sortedset docvalues from toMerge
.
- MergeSpecification() - Constructor for class org.apache.lucene.index.MergePolicy.MergeSpecification
-
Sole constructor.
- MergeState - Class in org.apache.lucene.index
-
Holds common state used during segment merging.
- MergeState.DocMap - Class in org.apache.lucene.index
-
A map of doc IDs.
- mergeTerm - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
- MergeThread(IndexWriter, MergePolicy.OneMerge) - Constructor for class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
-
Sole constructor.
- mergeThreadCount - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- mergeThreadCount() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Returns the number of merge threads that are alive, ignoring the calling thread
if it is a merge thread.
- mergeThreads - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- mergeTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
time spent merging sorted partitions (in milliseconds)
- MergeTrigger - Enum in org.apache.lucene.index
-
- MergeVisitor(MergeState, int) - Constructor for class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
Create new merge visitor.
- message(String, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
-
- message(String) - Method in class org.apache.lucene.index.MergeScheduler
-
- message - Variable in exception org.apache.lucene.queryparser.flexible.core.QueryNodeException
-
- Message - Interface in org.apache.lucene.queryparser.flexible.messages
-
Message Interface for a lazy loading.
- message(String) - Method in class org.apache.lucene.replicator.nrt.Node
-
- message(String, String) - Method in class org.apache.lucene.util.FailOnNonBulkMergesInfoStream
-
- message(String, String) - Method in class org.apache.lucene.util.InfoStream
-
prints a message
- message(String, String) - Method in class org.apache.lucene.util.NullInfoStream
-
- message(String, String) - Method in class org.apache.lucene.util.PrintStreamInfoStream
-
- messageID - Variable in class org.apache.lucene.util.PrintStreamInfoStream
-
- MessageImpl - Class in org.apache.lucene.queryparser.flexible.messages
-
Default implementation of Message interface.
- MessageImpl(String) - Constructor for class org.apache.lucene.queryparser.flexible.messages.MessageImpl
-
- MessageImpl(String, Object...) - Constructor for class org.apache.lucene.queryparser.flexible.messages.MessageImpl
-
- metaData - Variable in class org.apache.lucene.replicator.nrt.CopyOneFile
-
- metaTags - Variable in class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser.Parser
-
- mgr - Variable in class org.apache.lucene.replicator.nrt.Node
-
- mgr - Variable in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- min - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
-
- min - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
-
- min - Variable in class org.apache.lucene.facet.range.DoubleRange
-
Minimum (inclusive).
- min - Variable in class org.apache.lucene.facet.range.LongRange
-
Minimum (inclusive).
- min - Variable in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- min - Variable in class org.apache.lucene.queries.function.valuesource.ScaleFloatFunction
-
- min - Variable in class org.apache.lucene.search.DocValuesStats
-
- min() - Method in class org.apache.lucene.search.DocValuesStats
-
The minimum value of the field.
- min - Variable in class org.apache.lucene.util.automaton.Transition
-
Minimum accepted label (inclusive).
- MIN_BLOCK_SHIFT - Static variable in class org.apache.lucene.util.packed.DirectMonotonicWriter
-
- MIN_BUFFER_SIZE - Static variable in class org.apache.lucene.store.BufferedIndexInput
-
Minimum buffer size allowed
- MIN_BUFFER_SIZE_MB - Static variable in class org.apache.lucene.util.OfflineSorter
-
Minimum recommended buffer size for sorting.
- MIN_FRAG_CHAR_SIZE_FACTOR - Static variable in class org.apache.lucene.search.vectorhighlight.BaseFragListBuilder
-
- MIN_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.CodepointCountFilterFactory
-
- MIN_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.LengthFilterFactory
-
- MIN_LAT_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
-
Minimum latitude value.
- MIN_LAT_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
-
min latitude value in radians
- MIN_LON_ENCODED - Static variable in class org.apache.lucene.geo.GeoEncodingUtils
-
- MIN_LON_INCL - Static variable in class org.apache.lucene.geo.GeoUtils
-
Minimum longitude value.
- MIN_LON_RADIANS - Static variable in class org.apache.lucene.geo.GeoUtils
-
min longitude value in radians
- MIN_VALUE - Static variable in class org.apache.lucene.document.BigIntegerPoint
-
A constant holding the minimum value a BigIntegerPoint can have, -2127.
- MIN_VALUE - Static variable in class org.apache.lucene.document.InetAddressPoint
-
The minimum value that an ip address can hold.
- MIN_VERSION - Static variable in class org.apache.lucene.codecs.idversion.IDVersionPostingsFormat
-
version must be >= this.
- MIN_WORD_LENGTH - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
- MIN_X_POLE - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Min X pole
- MIN_Y_POLE - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Min Y pole
- MinFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
MinFloatFunction
returns the min of its components.
- MinFloatFunction(ValueSource[]) - Constructor for class org.apache.lucene.queries.function.valuesource.MinFloatFunction
-
- minFrequencyToCache(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
-
For a given filter, return how many times it should appear in the history
before being cached.
- MinHashFilter - Class in org.apache.lucene.analysis.minhash
-
Generate min hash tokens from an incoming stream of tokens.
- MinHashFilter(TokenStream, int, int, int, boolean) - Constructor for class org.apache.lucene.analysis.minhash.MinHashFilter
-
create a MinHash filter
- MinHashFilterFactory - Class in org.apache.lucene.analysis.minhash
-
- MinHashFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.minhash.MinHashFilterFactory
-
- MinimizationOperations - Class in org.apache.lucene.util.automaton
-
Operations for minimizing automata.
- minimize(Automaton, int) - Static method in class org.apache.lucene.util.automaton.MinimizationOperations
-
Minimizes (and determinizes if not already deterministic) the given
automaton using Hopcroft's algorighm.
- minimizeSimple(Automaton) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Simple, original brics implementation of Brzozowski minimize()
- MINIMUM_ANGULAR_RESOLUTION - Static variable in class org.apache.lucene.spatial3d.geom.Vector
-
Angular version of minimum resolution.
- MINIMUM_RESOLUTION - Static variable in class org.apache.lucene.spatial3d.geom.Vector
-
Values that are all considered to be essentially zero have a magnitude
less than this.
- MINIMUM_RESOLUTION_CUBED - Static variable in class org.apache.lucene.spatial3d.geom.Vector
-
For cubed quantities, cube the bound.
- MINIMUM_RESOLUTION_SQUARED - Static variable in class org.apache.lucene.spatial3d.geom.Vector
-
For squared quantities, the bound is squared too.
- minimumPoleDistance - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Minimum surface distance between poles
- minLat - Variable in class org.apache.lucene.geo.EdgeTree
-
minimum latitude of this geometry's bounding box area
- minLat - Variable in class org.apache.lucene.geo.Line
-
minimum latitude of this line's bounding box
- minLat - Variable in class org.apache.lucene.geo.Polygon
-
minimum latitude of this polygon's bounding box area
- minLat - Variable in class org.apache.lucene.geo.Rectangle
-
maximum longitude value (in degrees)
- minLon - Variable in class org.apache.lucene.geo.EdgeTree
-
minimum longitude of this geometry's bounding box area
- minLon - Variable in class org.apache.lucene.geo.Line
-
minimum longitude of this line's bounding box
- minLon - Variable in class org.apache.lucene.geo.Polygon
-
minimum longitude of this polygon's bounding box area
- minLon - Variable in class org.apache.lucene.geo.Rectangle
-
minimum longitude value (in degrees)
- minMergeSize - Variable in class org.apache.lucene.index.LogMergePolicy
-
Any segments whose size is smaller than this value
will be rounded up to this value.
- minor - Variable in class org.apache.lucene.util.Version
-
Minor version, incremented within the stable branch
- minPackedValue - Variable in class org.apache.lucene.index.PointsStackTracker.Cell
-
- minPackedValue - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
Minimum per-dim values, packed
- MinPayloadFunction - Class in org.apache.lucene.queries.payloads
-
Calculates the minimum payload seen
- MinPayloadFunction() - Constructor for class org.apache.lucene.queries.payloads.MinPayloadFunction
-
- minSubwordSize - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- MINUS - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- MINUS - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- minus(Automaton, Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns a (deterministic) automaton that accepts the intersection of the
language of a1
and the complement of the language of
a2
.
- MINUTE - Static variable in class org.apache.lucene.util.TimeUnits
-
1 minute in milliseconds
- minWeight - Variable in class org.apache.lucene.search.suggest.document.CompletionsTermsReader
-
Minimum entry weight for the suggester
- minWordSize - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- mismatch(byte[], int, int, byte[], int, int) - Static method in class org.apache.lucene.util.FutureArrays
-
Behaves like Java 9's Arrays.mismatch
- mismatch(char[], int, int, char[], int, int) - Static method in class org.apache.lucene.util.FutureArrays
-
Behaves like Java 9's Arrays.mismatch
- MismatchedDirectoryReader - Class in org.apache.lucene.index
-
- MismatchedDirectoryReader(DirectoryReader, Random) - Constructor for class org.apache.lucene.index.MismatchedDirectoryReader
-
- MismatchedLeafReader - Class in org.apache.lucene.index
-
Shuffles field numbers around to try to trip bugs where field numbers
are assumed to always be consistent across segments.
- MismatchedLeafReader(LeafReader, Random) - Constructor for class org.apache.lucene.index.MismatchedLeafReader
-
Creates a new reader which will renumber fields in in
- missing() - Method in class org.apache.lucene.search.DocValuesStats
-
The number of documents which do not have a value of the field.
- missing - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
- MissingOrdRemapper - Class in org.apache.lucene.codecs
-
a utility class to write missing values for SORTED as if they were the empty string
(to simulate pre-Lucene4.5 dv behavior for testing old codecs)
- MissingOrdRemapper() - Constructor for class org.apache.lucene.codecs.MissingOrdRemapper
-
- missingSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
-
True if we were unable to locate and load the segments_N file.
- missingValue - Variable in class org.apache.lucene.search.FieldComparator.NumericComparator
-
- missingValue - Variable in class org.apache.lucene.search.SortField
-
- mixedBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
The number of "internal" blocks (that have both
terms and sub-blocks).
- mlt - Variable in class org.apache.lucene.classification.KNearestNeighborClassifier
-
- MMapDirectory - Class in org.apache.lucene.store
-
File-based
Directory
implementation that uses
mmap for reading, and
FSDirectory.FSIndexOutput
for writing.
- MMapDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.MMapDirectory
-
Create a new MMapDirectory for the named location.
- MMapDirectory(Path) - Constructor for class org.apache.lucene.store.MMapDirectory
-
- MMapDirectory(Path, int) - Constructor for class org.apache.lucene.store.MMapDirectory
-
- MMapDirectory(Path, LockFactory, int) - Constructor for class org.apache.lucene.store.MMapDirectory
-
Create a new MMapDirectory for the named location, specifying the
maximum chunk size used for memory mapping.
- MockAnalyzer - Class in org.apache.lucene.analysis
-
Analyzer for testing
- MockAnalyzer(Random, CharacterRunAutomaton, boolean, CharacterRunAutomaton) - Constructor for class org.apache.lucene.analysis.MockAnalyzer
-
Creates a new MockAnalyzer.
- MockAnalyzer(Random, CharacterRunAutomaton, boolean) - Constructor for class org.apache.lucene.analysis.MockAnalyzer
-
- MockAnalyzer(Random) - Constructor for class org.apache.lucene.analysis.MockAnalyzer
-
Create a Whitespace-lowercasing analyzer with no stopwords removal.
- MockBytesAnalyzer - Class in org.apache.lucene.analysis
-
Analyzer for testing that encodes terms as UTF-16 bytes.
- MockBytesAnalyzer() - Constructor for class org.apache.lucene.analysis.MockBytesAnalyzer
-
- MockCharFilter - Class in org.apache.lucene.analysis
-
the purpose of this charfilter is to send offsets out of bounds
if the analyzer doesn't use correctOffset or does incorrect offset math.
- MockCharFilter(Reader, int) - Constructor for class org.apache.lucene.analysis.MockCharFilter
-
- MockCharFilter(Reader) - Constructor for class org.apache.lucene.analysis.MockCharFilter
-
- MockDirectoryWrapper - Class in org.apache.lucene.store
-
This is a Directory Wrapper that adds methods
intended to be used only by unit tests.
- MockDirectoryWrapper(Random, Directory) - Constructor for class org.apache.lucene.store.MockDirectoryWrapper
-
- MockDirectoryWrapper.Failure - Class in org.apache.lucene.store
-
Objects that represent fail-able conditions.
- MockDirectoryWrapper.FakeIOException - Exception in org.apache.lucene.store
-
Use this when throwing fake IOException
,
e.g.
- MockDirectoryWrapper.Throttling - Enum in org.apache.lucene.store
-
Enum for controlling hard disk throttling.
- MockFileSystemTestCase - Class in org.apache.lucene.mockfile
-
Base class for testing mockfilesystems.
- MockFileSystemTestCase() - Constructor for class org.apache.lucene.mockfile.MockFileSystemTestCase
-
- MockFixedLengthPayloadFilter - Class in org.apache.lucene.analysis
-
TokenFilter that adds random fixed-length payloads.
- MockFixedLengthPayloadFilter(Random, TokenStream, int) - Constructor for class org.apache.lucene.analysis.MockFixedLengthPayloadFilter
-
- MockGraphTokenFilter - Class in org.apache.lucene.analysis
-
Randomly inserts overlapped (posInc=0) tokens with
posLength sometimes > 1.
- MockGraphTokenFilter(Random, TokenStream) - Constructor for class org.apache.lucene.analysis.MockGraphTokenFilter
-
- MockHoleInjectingTokenFilter - Class in org.apache.lucene.analysis
-
Randomly injects holes (similar to what a stopfilter would do)
- MockHoleInjectingTokenFilter(Random, TokenStream) - Constructor for class org.apache.lucene.analysis.MockHoleInjectingTokenFilter
-
- MockIndexInputWrapper - Class in org.apache.lucene.store
-
Used by MockDirectoryWrapper to create an input stream that
keeps track of when it's been closed.
- MockIndexInputWrapper(MockDirectoryWrapper, String, IndexInput, MockIndexInputWrapper) - Constructor for class org.apache.lucene.store.MockIndexInputWrapper
-
Sole constructor
- MockIndexOutputWrapper - Class in org.apache.lucene.store
-
Used by MockRAMDirectory to create an output stream that
will throw an IOException on fake disk full, track max
disk space actually used, and maybe throw random
IOExceptions.
- MockIndexOutputWrapper(MockDirectoryWrapper, IndexOutput, String) - Constructor for class org.apache.lucene.store.MockIndexOutputWrapper
-
Construct an empty output buffer.
- mockIndexWriter(Directory, IndexWriterConfig, Random) - Static method in class org.apache.lucene.index.RandomIndexWriter
-
Returns an indexwriter that randomly mixes up thread scheduling (by yielding at test points)
- mockIndexWriter(Random, Directory, IndexWriterConfig, RandomIndexWriter.TestPoint) - Static method in class org.apache.lucene.index.RandomIndexWriter
-
Returns an indexwriter that enables the specified test point
- MockLowerCaseFilter - Class in org.apache.lucene.analysis
-
- MockLowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.MockLowerCaseFilter
-
Sole constructor.
- MockMergeContext(ToIntFunction<SegmentCommitInfo>) - Constructor for class org.apache.lucene.index.BaseMergePolicyTestCase.MockMergeContext
-
- MockPayloadAnalyzer - Class in org.apache.lucene.analysis
-
Wraps a whitespace tokenizer with a filter that sets
the first token, and odd tokens to posinc=1, and all others
to 0, encoding the position as pos: XXX in the payload.
- MockPayloadAnalyzer() - Constructor for class org.apache.lucene.analysis.MockPayloadAnalyzer
-
- MockRandomLookaheadTokenFilter - Class in org.apache.lucene.analysis
-
- MockRandomLookaheadTokenFilter(Random, TokenStream) - Constructor for class org.apache.lucene.analysis.MockRandomLookaheadTokenFilter
-
- MockRandomMergePolicy - Class in org.apache.lucene.index
-
MergePolicy that makes random decisions for testing.
- MockRandomMergePolicy(Random) - Constructor for class org.apache.lucene.index.MockRandomMergePolicy
-
- MockRandomPostingsFormat - Class in org.apache.lucene.codecs.mockrandom
-
Randomly combines terms index impl w/ postings impls.
- MockRandomPostingsFormat() - Constructor for class org.apache.lucene.codecs.mockrandom.MockRandomPostingsFormat
-
- MockRandomPostingsFormat(Random) - Constructor for class org.apache.lucene.codecs.mockrandom.MockRandomPostingsFormat
-
- MockReaderWrapper - Class in org.apache.lucene.analysis
-
Wraps a Reader, and can throw random or fixed
exceptions, and spoon feed read chars.
- MockReaderWrapper(Random, Reader) - Constructor for class org.apache.lucene.analysis.MockReaderWrapper
-
- MockSynonymAnalyzer - Class in org.apache.lucene.analysis
-
adds synonym of "dog" for "dogs", and synonym of "cavy" for "guinea pig".
- MockSynonymAnalyzer() - Constructor for class org.apache.lucene.analysis.MockSynonymAnalyzer
-
- MockSynonymFilter - Class in org.apache.lucene.analysis
-
adds synonym of "dog" for "dogs", and synonym of "cavy" for "guinea pig".
- MockSynonymFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.MockSynonymFilter
-
- MockTokenFilter - Class in org.apache.lucene.analysis
-
A tokenfilter for testing that removes terms accepted by a DFA.
- MockTokenFilter(TokenStream, CharacterRunAutomaton) - Constructor for class org.apache.lucene.analysis.MockTokenFilter
-
Create a new MockTokenFilter.
- MockTokenizer - Class in org.apache.lucene.analysis
-
Tokenizer for testing.
- MockTokenizer(AttributeFactory, CharacterRunAutomaton, boolean, int) - Constructor for class org.apache.lucene.analysis.MockTokenizer
-
- MockTokenizer(CharacterRunAutomaton, boolean, int) - Constructor for class org.apache.lucene.analysis.MockTokenizer
-
- MockTokenizer(CharacterRunAutomaton, boolean) - Constructor for class org.apache.lucene.analysis.MockTokenizer
-
- MockTokenizer() - Constructor for class org.apache.lucene.analysis.MockTokenizer
-
- MockTokenizer(AttributeFactory, CharacterRunAutomaton, boolean) - Constructor for class org.apache.lucene.analysis.MockTokenizer
-
- MockTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.MockTokenizer
-
- MockUTF16TermAttributeImpl - Class in org.apache.lucene.analysis
-
- MockUTF16TermAttributeImpl() - Constructor for class org.apache.lucene.analysis.MockUTF16TermAttributeImpl
-
- MockVariableLengthPayloadFilter - Class in org.apache.lucene.analysis
-
TokenFilter that adds random variable-length payloads.
- MockVariableLengthPayloadFilter(Random, TokenStream) - Constructor for class org.apache.lucene.analysis.MockVariableLengthPayloadFilter
-
- ModClause(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- MODE_KEY - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50StoredFieldsFormat
-
Attribute key for compression mode.
- ModifierQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
ModifierQueryNode
indicates the modifier value (+,-,?,NONE) for
each term on the query string.
- ModifierQueryNode(QueryNode, ModifierQueryNode.Modifier) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode
-
Used to store the modifier value on the original query string
- ModifierQueryNode.Modifier - Enum in org.apache.lucene.queryparser.flexible.core.nodes
-
Modifier type: such as required (REQ), prohibited (NOT)
- ModifierQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- ModifierQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.ModifierQueryNodeBuilder
-
- Modifiers() - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
- Modifiers() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- modify(GeoPoint, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Modify a point to produce a vector in translated/rotated space.
- MonotonicBlockPackedReader - Class in org.apache.lucene.util.packed
-
- MonotonicBlockPackedWriter - Class in org.apache.lucene.util.packed
-
A writer for large monotonically increasing sequences of positive longs.
- MonotonicBlockPackedWriter(DataOutput, int) - Constructor for class org.apache.lucene.util.packed.MonotonicBlockPackedWriter
-
Sole constructor.
- monotonicBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
-
Return a new
PackedLongValues.Builder
that will compress efficiently integers that
would be a monotonic function of their index.
- monotonicBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
-
- MoreLikeThis - Class in org.apache.lucene.queries.mlt
-
Generate "more like this" similarity queries.
- MoreLikeThis(IndexReader) - Constructor for class org.apache.lucene.queries.mlt.MoreLikeThis
-
Constructor requiring an IndexReader.
- MoreLikeThis(IndexReader, TFIDFSimilarity) - Constructor for class org.apache.lucene.queries.mlt.MoreLikeThis
-
- MoreLikeThisQuery - Class in org.apache.lucene.queries.mlt
-
A simple wrapper for MoreLikeThis for use in scenarios where a Query object is required eg
in custom QueryParser extensions.
- MoreLikeThisQuery(String, String[], Analyzer, String) - Constructor for class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- MorfologikAnalyzer - Class in org.apache.lucene.analysis.morfologik
-
- MorfologikAnalyzer(Dictionary) - Constructor for class org.apache.lucene.analysis.morfologik.MorfologikAnalyzer
-
Builds an analyzer with an explicit Dictionary
resource.
- MorfologikAnalyzer() - Constructor for class org.apache.lucene.analysis.morfologik.MorfologikAnalyzer
-
Builds an analyzer with the default Morfologik's Polish dictionary.
- MorfologikFilter - Class in org.apache.lucene.analysis.morfologik
-
TokenFilter
using Morfologik library to transform input tokens into lemma and
morphosyntactic (POS) tokens.
- MorfologikFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.morfologik.MorfologikFilter
-
Creates a filter with the default (Polish) dictionary.
- MorfologikFilter(TokenStream, Dictionary) - Constructor for class org.apache.lucene.analysis.morfologik.MorfologikFilter
-
Creates a filter with a given dictionary.
- MorfologikFilterFactory - Class in org.apache.lucene.analysis.morfologik
-
- MorfologikFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.morfologik.MorfologikFilterFactory
-
Creates a new MorfologikFilterFactory
- Morpheme(POS.Tag, String) - Constructor for class org.apache.lucene.analysis.ko.dict.Dictionary.Morpheme
-
- MorphosyntacticTagsAttribute - Interface in org.apache.lucene.analysis.morfologik
-
Morfologik provides morphosyntactic annotations for
surface forms.
- MorphosyntacticTagsAttributeImpl - Class in org.apache.lucene.analysis.morfologik
-
Morphosyntactic annotations for surface forms.
- MorphosyntacticTagsAttributeImpl() - Constructor for class org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttributeImpl
-
Initializes this attribute with no tags
- MortonEncoder - Class in org.apache.lucene.spatial.util
-
Quantizes lat/lon points and bit interleaves them into a binary morton code
in the range of 0x00000000...
- move(Path, Path, CopyOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- move(Path, Path, CopyOption...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- move(Path, Path, CopyOption...) - Method in class org.apache.lucene.mockfile.WindowsFS
-
- MSBRadixSorter - Class in org.apache.lucene.util
-
Radix sorter for variable-length strings.
- MSBRadixSorter(int) - Constructor for class org.apache.lucene.util.MSBRadixSorter
-
Sole constructor.
- MULTI_FIELDS - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the fields a query should be expanded to when the field
is null
- MULTI_TERM_REWRITE_METHOD - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
- MultiBoolFunction - Class in org.apache.lucene.queries.function.valuesource
-
Abstract
ValueSource
implementation which wraps multiple ValueSources
and applies an extendible boolean function to their values.
- MultiBoolFunction(List<ValueSource>) - Constructor for class org.apache.lucene.queries.function.valuesource.MultiBoolFunction
-
- MultiCategoryListsFacetsExample - Class in org.apache.lucene.demo.facet
-
Demonstrates indexing categories into different indexed fields.
- MultiCategoryListsFacetsExample() - Constructor for class org.apache.lucene.demo.facet.MultiCategoryListsFacetsExample
-
Creates a new instance and populates the category list params mapping.
- MultiCollector - Class in org.apache.lucene.search
-
- MultiCollectorManager - Class in org.apache.lucene.search
-
- MultiCollectorManager(CollectorManager<? extends Collector, ?>...) - Constructor for class org.apache.lucene.search.MultiCollectorManager
-
- MultiCollectorManager.Collectors - Class in org.apache.lucene.search
-
- MultiCollectorManager.Collectors.LeafCollectors - Class in org.apache.lucene.search
-
- MultiDocValues - Class in org.apache.lucene.index
-
A wrapper for CompositeIndexReader providing access to DocValues.
- MultiDocValues.MultiSortedDocValues - Class in org.apache.lucene.index
-
Implements SortedDocValues over n subs, using an OrdinalMap
- MultiDocValues.MultiSortedSetDocValues - Class in org.apache.lucene.index
-
Implements MultiSortedSetDocValues over n subs, using an OrdinalMap
- MultiFacetQuery - Class in org.apache.lucene.facet
-
- MultiFacetQuery(FacetsConfig, String, String[]...) - Constructor for class org.apache.lucene.facet.MultiFacetQuery
-
Creates a new MultiFacetQuery
filtering the query on the given dimension.
- MultiFacetQuery(String, String[]...) - Constructor for class org.apache.lucene.facet.MultiFacetQuery
-
Creates a new MultiFacetQuery
filtering the query on the given dimension.
- MultiFacets - Class in org.apache.lucene.facet
-
Maps specified dims to provided Facets impls; else, uses
the default Facets impl.
- MultiFacets(Map<String, Facets>) - Constructor for class org.apache.lucene.facet.MultiFacets
-
Create this, with no default
Facets
.
- MultiFacets(Map<String, Facets>, Facets) - Constructor for class org.apache.lucene.facet.MultiFacets
-
Create this, with the specified default
Facets
for fields not included in
dimToFacets
.
- MultiFieldQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
This processor is used to expand terms so the query looks for the same term
in different fields.
- MultiFieldQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.MultiFieldQueryNodeProcessor
-
- MultiFieldQueryParser - Class in org.apache.lucene.queryparser.classic
-
A QueryParser which constructs queries to search multiple fields.
- MultiFieldQueryParser(String[], Analyzer, Map<String, Float>) - Constructor for class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
Creates a MultiFieldQueryParser.
- MultiFieldQueryParser(String[], Analyzer) - Constructor for class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
Creates a MultiFieldQueryParser.
- MultiFields - Class in org.apache.lucene.index
-
- MultiFields(Fields[], ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiFields
-
Expert: construct a new MultiFields instance directly.
- MultiFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
Abstract
ValueSource
implementation which wraps multiple ValueSources
and applies an extendible float function to their values.
- MultiFloatFunction(ValueSource[]) - Constructor for class org.apache.lucene.queries.function.valuesource.MultiFloatFunction
-
- MultiFunction - Class in org.apache.lucene.queries.function.valuesource
-
Abstract parent class for
ValueSource
implementations that wrap multiple
ValueSources and apply their own logic.
- MultiFunction(List<ValueSource>) - Constructor for class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- MultiFunction.Values - Class in org.apache.lucene.queries.function.valuesource
-
- MultiLevelSkipListReader - Class in org.apache.lucene.codecs
-
This abstract class reads skip lists with multiple levels.
- MultiLevelSkipListReader(IndexInput, int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Creates a MultiLevelSkipListReader
.
- MultiLevelSkipListReader(IndexInput, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Creates a MultiLevelSkipListReader
, where
skipInterval
and skipMultiplier
are
the same.
- MultiLevelSkipListWriter - Class in org.apache.lucene.codecs
-
This abstract class writes skip lists with multiple levels.
- MultiLevelSkipListWriter(int, int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListWriter
-
Creates a MultiLevelSkipListWriter
.
- MultiLevelSkipListWriter(int, int, int) - Constructor for class org.apache.lucene.codecs.MultiLevelSkipListWriter
-
Creates a MultiLevelSkipListWriter
, where
skipInterval
and skipMultiplier
are
the same.
- multiLineString() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- MultiOffsetsEnum(List<OffsetsEnum>) - Constructor for class org.apache.lucene.search.uhighlight.OffsetsEnum.MultiOffsetsEnum
-
- multiOverlappingIndexedShapes - Variable in class org.apache.lucene.spatial.prefix.ContainsPrefixTreeQuery
-
If the spatial data for a document is comprised of multiple overlapping or adjacent parts,
it might fail to match a query shape when doing the CONTAINS predicate when the sum of
those shapes contain the query shape but none do individually.
- multiOverlappingIndexedShapes - Variable in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- MultiPassIndexSplitter - Class in org.apache.lucene.index
-
This tool splits input index into multiple equal parts.
- MultiPassIndexSplitter() - Constructor for class org.apache.lucene.index.MultiPassIndexSplitter
-
- MultiPhraseQuery - Class in org.apache.lucene.search
-
A generalized version of
PhraseQuery
, with the possibility of
adding more than one term at the same position that are treated as a disjunction (OR).
- MultiPhraseQuery.Builder - Class in org.apache.lucene.search
-
A builder for multi-phrase queries
- MultiPhraseQueryNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
- MultiPhraseQueryNode() - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.MultiPhraseQueryNode
-
- MultiPhraseQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- MultiPhraseQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.MultiPhraseQueryNodeBuilder
-
- multiPoint() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- multiPolygon() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- MultiPostingsEnum - Class in org.apache.lucene.index
-
- MultiPostingsEnum(MultiTermsEnum, int) - Constructor for class org.apache.lucene.index.MultiPostingsEnum
-
Sole constructor.
- MultiPostingsEnum.EnumWithSlice - Class in org.apache.lucene.index
-
- MultiReader - Class in org.apache.lucene.index
-
- MultiReader(IndexReader...) - Constructor for class org.apache.lucene.index.MultiReader
-
Construct a MultiReader aggregating the named set of (sub)readers.
- MultiReader(IndexReader[], boolean) - Constructor for class org.apache.lucene.index.MultiReader
-
Construct a MultiReader aggregating the named set of (sub)readers.
- multiShape(List<S>) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- multiShape(Class<T>) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- MultiSimilarity - Class in org.apache.lucene.search.similarities
-
Implements the CombSUM method for combining evidence from multiple
similarity values described in: Joseph A.
- MultiSimilarity(Similarity[]) - Constructor for class org.apache.lucene.search.similarities.MultiSimilarity
-
Creates a MultiSimilarity which will sum the scores
of the provided sims
.
- MultiSortedDocValues(SortedDocValues[], int[], OrdinalMap, long) - Constructor for class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
Creates a new MultiSortedDocValues over values
- MultiSortedSetDocValues(SortedSetDocValues[], int[], OrdinalMap, long) - Constructor for class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
Creates a new MultiSortedSetDocValues over values
- MultiTerm(String, List<BooleanClause>) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
Returns the first query if splitOnWhitespace=true or otherwise the entire produced query
- MultiTermAwareComponent - Interface in org.apache.lucene.analysis.util
-
Add to any analysis factory component to allow returning an
analysis component factory for use with partial terms in prefix queries,
wildcard queries, range query endpoints, regex queries, etc.
- MultiTermQuery - Class in org.apache.lucene.search
-
An abstract
Query
that matches documents
containing a subset of terms provided by a
FilteredTermsEnum
enumeration.
- MultiTermQuery(String) - Constructor for class org.apache.lucene.search.MultiTermQuery
-
Constructs a query matching terms that cannot be represented with a single
Term.
- MultiTermQuery.RewriteMethod - Class in org.apache.lucene.search
-
Abstract class that defines how the query is rewritten.
- MultiTermQuery.TopTermsBlendedFreqScoringRewrite - Class in org.apache.lucene.search
-
A rewrite method that first translates each term into
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, but adjusts
the frequencies used for scoring to be blended across the terms, otherwise
the rarest term typically ranks highest (often not useful eg in the set of
expanded terms in a FuzzyQuery).
- MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite - Class in org.apache.lucene.search
-
A rewrite method that first translates each term into
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, but the scores
are only computed as the boost.
- MultiTermQuery.TopTermsScoringBooleanQueryRewrite - Class in org.apache.lucene.search
-
A rewrite method that first translates each term into
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, and keeps the
scores as computed by the query.
- MultiTermRewriteMethodProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- MultiTermRewriteMethodProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.MultiTermRewriteMethodProcessor
-
- MultiTerms - Class in org.apache.lucene.index
-
Exposes flex API, merged from flex API of
sub-segments.
- MultiTerms(Terms[], ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiTerms
-
Sole constructor.
- MultiTermsEnum - Class in org.apache.lucene.index
-
- MultiTermsEnum(ReaderSlice[]) - Constructor for class org.apache.lucene.index.MultiTermsEnum
-
Sole constructor.
- MultiTrie - Class in org.egothor.stemmer
-
The MultiTrie is a Trie of Tries.
- MultiTrie(DataInput) - Constructor for class org.egothor.stemmer.MultiTrie
-
Constructor for the MultiTrie object.
- MultiTrie(boolean) - Constructor for class org.egothor.stemmer.MultiTrie
-
Constructor for the MultiTrie object
- MultiTrie2 - Class in org.egothor.stemmer
-
The MultiTrie is a Trie of Tries.
- MultiTrie2(DataInput) - Constructor for class org.egothor.stemmer.MultiTrie2
-
Constructor for the MultiTrie object.
- MultiTrie2(boolean) - Constructor for class org.egothor.stemmer.MultiTrie2
-
Constructor for the MultiTrie2 object
- MULTIVAL_SEP_CHAR - Static variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- multiValued - Variable in class org.apache.lucene.facet.FacetsConfig.DimConfig
-
True if this dimension is multi-valued.
- MultiValuedDoubleFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- MultiValuedDoubleFieldSource(String, SortedNumericSelector.Type) - Constructor for class org.apache.lucene.queries.function.valuesource.MultiValuedDoubleFieldSource
-
- MultiValuedFloatFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- MultiValuedFloatFieldSource(String, SortedNumericSelector.Type) - Constructor for class org.apache.lucene.queries.function.valuesource.MultiValuedFloatFieldSource
-
- MultiValuedIntFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- MultiValuedIntFieldSource(String, SortedNumericSelector.Type) - Constructor for class org.apache.lucene.queries.function.valuesource.MultiValuedIntFieldSource
-
- MultiValuedLongFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
- MultiValuedLongFieldSource(String, SortedNumericSelector.Type) - Constructor for class org.apache.lucene.queries.function.valuesource.MultiValuedLongFieldSource
-
- MultiValueSource - Class in org.apache.lucene.queries.function.valuesource
-
- MultiValueSource() - Constructor for class org.apache.lucene.queries.function.valuesource.MultiValueSource
-
- MurmurHash2 - Class in org.apache.lucene.codecs.bloom
-
This is a very fast, non-cryptographic hash suitable for general hash-based
lookup.
- murmurhash3_x86_32(byte[], int, int, int) - Static method in class org.apache.lucene.util.StringHelper
-
Returns the MurmurHash3_x86_32 hash.
- murmurhash3_x86_32(BytesRef, int) - Static method in class org.apache.lucene.util.StringHelper
-
- mustRewriteQuery(SpanQuery) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- Mutable() - Constructor for class org.apache.lucene.util.packed.PackedInts.Mutable
-
- MutablePointsReaderUtils - Class in org.apache.lucene.util.bkd
-
Utility APIs for sorting and partitioning buffered points.
- MutablePointValues - Class in org.apache.lucene.codecs
-
- MutablePointValues() - Constructor for class org.apache.lucene.codecs.MutablePointValues
-
Sole constructor.
- MutableValue - Class in org.apache.lucene.util.mutable
-
Base class for all mutable values.
- MutableValue() - Constructor for class org.apache.lucene.util.mutable.MutableValue
-
- MutableValueBool - Class in org.apache.lucene.util.mutable
-
- MutableValueBool() - Constructor for class org.apache.lucene.util.mutable.MutableValueBool
-
- MutableValueDate - Class in org.apache.lucene.util.mutable
-
- MutableValueDate() - Constructor for class org.apache.lucene.util.mutable.MutableValueDate
-
- MutableValueDouble - Class in org.apache.lucene.util.mutable
-
- MutableValueDouble() - Constructor for class org.apache.lucene.util.mutable.MutableValueDouble
-
- MutableValueFloat - Class in org.apache.lucene.util.mutable
-
- MutableValueFloat() - Constructor for class org.apache.lucene.util.mutable.MutableValueFloat
-
- MutableValueInt - Class in org.apache.lucene.util.mutable
-
- MutableValueInt() - Constructor for class org.apache.lucene.util.mutable.MutableValueInt
-
- MutableValueLong - Class in org.apache.lucene.util.mutable
-
- MutableValueLong() - Constructor for class org.apache.lucene.util.mutable.MutableValueLong
-
- MutableValueStr - Class in org.apache.lucene.util.mutable
-
- MutableValueStr() - Constructor for class org.apache.lucene.util.mutable.MutableValueStr
-
- myNodeID - Variable in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- myNodeID - Variable in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- N - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- name - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
-
- name() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- name() - Method in class org.apache.lucene.collation.CollationDocValuesField
-
- name() - Method in class org.apache.lucene.collation.ICUCollationDocValuesField
-
- name - Variable in class org.apache.lucene.document.Field
-
Field's name
- name() - Method in class org.apache.lucene.document.Field
-
- name() - Method in class org.apache.lucene.document.LazyDocument.LazyField
-
- name - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Name of the segment.
- name - Variable in class org.apache.lucene.index.FieldInfo
-
Field's name
- name() - Method in interface org.apache.lucene.index.IndexableField
-
Field name
- name - Variable in class org.apache.lucene.index.SegmentInfo
-
Unique segment name in the directory.
- name() - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- name() - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
- name() - Method in class org.apache.lucene.queries.function.valuesource.ComparisonBoolFunction
-
Uniquely identify the operation (ie "gt", "lt" "gte", etc)
- name() - Method in class org.apache.lucene.queries.function.valuesource.DefFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.DivFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.DocFreqValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.DualFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.IDFValueSource
-
- NAME - Static variable in class org.apache.lucene.queries.function.valuesource.JoinDocFreqValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.MaxDocValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.MaxFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.MinFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.MultiBoolFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.MultiFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.NormValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.NumDocsValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.PowFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.ProductFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.SimpleBoolFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.SingleFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.SumFloatFunction
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.SumTotalTermFreqValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.TermFreqValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.TFValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- name() - Method in class org.apache.lucene.queries.function.valuesource.VectorValueSource
-
- name - Variable in class org.apache.lucene.replicator.nrt.CopyOneFile
-
- name() - Method in class org.apache.lucene.replicator.nrt.Node
-
- name - Variable in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- name - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
-
- NAME_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- namedAccountable(String, Accountable) - Static method in class org.apache.lucene.util.Accountables
-
Augments an existing accountable with the provided description.
- namedAccountable(String, long) - Static method in class org.apache.lucene.util.Accountables
-
Returns an accountable with the provided description and bytes.
- namedAccountable(String, Collection<Accountable>, long) - Static method in class org.apache.lucene.util.Accountables
-
Returns an accountable with the provided description, children and bytes.
- namedAccountables(String, Map<?, ? extends Accountable>) - Static method in class org.apache.lucene.util.Accountables
-
Converts a map of resources to a collection.
- NamedSPILoader<S extends NamedSPILoader.NamedSPI> - Class in org.apache.lucene.util
-
Helper class for loading named SPIs from classpath (e.g.
- NamedSPILoader(Class<S>) - Constructor for class org.apache.lucene.util.NamedSPILoader
-
- NamedSPILoader(Class<S>, ClassLoader) - Constructor for class org.apache.lucene.util.NamedSPILoader
-
- NamedSPILoader.NamedSPI - Interface in org.apache.lucene.util
-
- NamedThreadFactory - Class in org.apache.lucene.util
-
A default ThreadFactory
implementation that accepts the name prefix
of the created threads as a constructor argument.
- NamedThreadFactory(String) - Constructor for class org.apache.lucene.util.NamedThreadFactory
-
- NameHashIntCacheLRU - Class in org.apache.lucene.facet.taxonomy.writercache
-
An an LRU cache of mapping from name to int.
- NAN - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
-
- NativeFSLockFactory - Class in org.apache.lucene.store
-
- NativePosixUtil - Class in org.apache.lucene.store
-
- NativePosixUtil() - Constructor for class org.apache.lucene.store.NativePosixUtil
-
- NativeUnixDirectory - Class in org.apache.lucene.store
-
A
Directory
implementation for all Unixes that uses
DIRECT I/O to bypass OS level IO caching during
merging.
- NativeUnixDirectory(Path, int, long, LockFactory, Directory) - Constructor for class org.apache.lucene.store.NativeUnixDirectory
-
Create a new NIOFSDirectory for the named location.
- NativeUnixDirectory(Path, LockFactory, Directory) - Constructor for class org.apache.lucene.store.NativeUnixDirectory
-
Create a new NIOFSDirectory for the named location.
- NativeUnixDirectory(Path, Directory) - Constructor for class org.apache.lucene.store.NativeUnixDirectory
-
- ndv - Variable in class org.apache.lucene.search.DocValuesStats.NumericDocValuesStats
-
- NEAR_OPERATOR - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables NEAR
operators: (~) on phrases
- nearest(IndexSearcher, String, int, float...) - Static method in class org.apache.lucene.document.FloatPointNearestNeighbor
-
- nearest(IndexSearcher, String, double, double, int) - Static method in class org.apache.lucene.search.LatLonPointPrototypeQueries
-
Finds the n
nearest indexed points to the provided point, according to Haversine distance.
- NearestFuzzyQuery - Class in org.apache.lucene.classification.utils
-
Simplification of FuzzyLikeThisQuery, to be used in the context of KNN classification.
- NearestFuzzyQuery(Analyzer) - Constructor for class org.apache.lucene.classification.utils.NearestFuzzyQuery
-
Default constructor
- NearRealtimeReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Spawns a BG thread that periodically (defaults to 3.0
seconds, but accepts param in seconds) wakes up and asks
IndexWriter for a near real-time reader.
- NearRealtimeReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.NearRealtimeReaderTask
-
- NearSpansOrdered - Class in org.apache.lucene.search.spans
-
A Spans that is formed from the ordered subspans of a SpanNearQuery
where the subspans do not overlap and have a maximum slop between them.
- NearSpansOrdered(int, List<Spans>) - Constructor for class org.apache.lucene.search.spans.NearSpansOrdered
-
- NearSpansUnordered - Class in org.apache.lucene.search.spans
-
- NearSpansUnordered(int, List<Spans>) - Constructor for class org.apache.lucene.search.spans.NearSpansUnordered
-
- needsField(FieldInfo) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- needsField(FieldInfo) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
- needsField(FieldInfo) - Method in class org.apache.lucene.index.StoredFieldVisitor
-
Hook before processing a field.
- needsField(FieldInfo) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter.LimitedStoredFieldVisitor
-
- needsIndexSort - Variable in class org.apache.lucene.index.MergeState
-
Indicates if the index needs to be sorted
- needsScores() - Method in class org.apache.lucene.facet.FacetsCollector
-
- needsScores() - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
-
- needsScores() - Method in class org.apache.lucene.search.CheckHits.MatchesAsserter
-
- needsScores() - Method in class org.apache.lucene.search.CheckHits.SetCollector
-
- needsScores() - Method in interface org.apache.lucene.search.Collector
-
Indicates if document scores are needed by this collector.
- needsScores() - Method in class org.apache.lucene.search.DiversifiedTopDocsCollector
-
- needsScores() - Method in class org.apache.lucene.search.DocValuesStatsCollector
-
- needsScores() - Method in class org.apache.lucene.search.DoubleValuesSource
-
Return true if document scores are needed to calculate values
- needsScores() - Method in class org.apache.lucene.search.FilterCollector
-
- needsScores() - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- needsScores() - Method in class org.apache.lucene.search.grouping.AllGroupsCollector
-
- needsScores() - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
-
- needsScores() - Method in class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
- needsScores() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- needsScores() - Method in class org.apache.lucene.search.grouping.GroupReducer
-
Whether or not this reducer requires collected documents to be scored
- needsScores() - Method in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- needsScores() - Method in class org.apache.lucene.search.LongValuesSource
-
Return true if document scores are needed to calculate values
- needsScores() - Method in class org.apache.lucene.search.MultiCollector
-
- needsScores() - Method in class org.apache.lucene.search.MultiCollectorManager.Collectors
-
- needsScores() - Method in class org.apache.lucene.search.Sort
-
Returns true if the relevance score is needed to sort documents.
- needsScores() - Method in class org.apache.lucene.search.SortField
-
Whether the relevance score is needed to sort documents.
- needsScores() - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
Ignored
- needsScores() - Method in class org.apache.lucene.search.TimeLimitingCollector
-
- needsScores() - Method in class org.apache.lucene.search.TopFieldCollector
-
- needsScores() - Method in class org.apache.lucene.search.TopScoreDocCollector
-
- needsScores() - Method in class org.apache.lucene.search.TotalHitCountCollector
-
- needsScores() - Method in class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
- needsScores() - Method in class org.apache.lucene.spatial.util.CachingDoubleValueSource
-
- needsScores() - Method in class org.apache.lucene.spatial.util.DistanceToShapeValueSource
-
- needsScores() - Method in class org.apache.lucene.spatial.util.ReciprocalDoubleValuesSource
-
- needsScores() - Method in class org.apache.lucene.spatial.util.ShapeAreaValueSource
-
- needsScores() - Method in class org.apache.lucene.spatial.util.ShapeFieldCacheDistanceValueSource
-
- needsScores() - Method in class org.apache.lucene.spatial.vector.DistanceValueSource
-
- NEW_LINE - Static variable in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
separator between lines in the byffer
- NEW_LINE - Static variable in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- newAlcoholicMergePolicy() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newAlcoholicMergePolicy(Random, TimeZone) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- NewAnalyzerTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Create a new
Analyzer
and set it it in the getRunData() for use by all future tasks.
- NewAnalyzerTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.NewAnalyzerTask
-
- newAsynchronousFileChannel(Path, Set<? extends OpenOption>, ExecutorService, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.DisableFsyncFS
-
- newAsynchronousFileChannel(Path, Set<? extends OpenOption>, ExecutorService, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newAsynchronousFileChannel(Path, Set<? extends OpenOption>, ExecutorService, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
- newAsynchronousFileChannel(Path, Set<? extends OpenOption>, ExecutorService, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- newAttributeFactory(Random) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Returns a random AttributeFactory impl
- newAttributeFactory() - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Returns a random AttributeFactory impl
- newBooleanClause(Query, BooleanClause.Occur) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Builds a new BooleanClause instance
- newBooleanQuery() - Method in class org.apache.lucene.util.QueryBuilder
-
Builds a new BooleanQuery instance.
- newBoxQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonPoint
-
Create a query for matching a bounding box.
- newBoxQuery(String, LatLonShape.QueryRelation, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonShape
-
create a query to find all polygons that intersect a defined bounding box
- newBoxQuery(String, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.Geo3DPoint
-
Create a query for matching a box.
- newBuffer(byte[]) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- newBuffer(int) - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
Expert: allocate a new buffer.
- newByteChannel(Path, Set<? extends OpenOption>, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newByteChannel(Path, Set<? extends OpenOption>, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
- newByteChannel(Path, Set<? extends OpenOption>, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- newCal() - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Calendar utility method:
Returns a clone of the Calendar
passed to the constructor with all fields cleared.
- newCellStack(int) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- newCellToBytesRefIterator() - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- newCellToBytesRefIterator() - Method in class org.apache.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
-
- newCharacterBuffer(int) - Static method in class org.apache.lucene.analysis.CharacterUtils
-
- NewCollationAnalyzerTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Task to support benchmarking collation.
- NewCollationAnalyzerTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask
-
- NewCollationAnalyzerTask.Implementation - Enum in org.apache.lucene.benchmark.byTask.tasks
-
Different Collation implementations: currently
limited to what is provided in the JDK and ICU.
- newCollector() - Method in class org.apache.lucene.facet.FacetsCollectorManager
-
- newCollector() - Method in interface org.apache.lucene.search.CollectorManager
-
- newCollector(GroupSelector<T>, Sort) - Static method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
Create a new AllGroupHeadsCollector based on the type of within-group Sort required
- newCollector() - Method in class org.apache.lucene.search.grouping.GroupReducer
-
Creates a new Collector for each group
- newCollector() - Method in class org.apache.lucene.search.MultiCollectorManager
-
- newComparator(String, int, int, boolean) - Method in class org.apache.lucene.search.FieldComparatorSource
-
Creates a comparator for the field in the given index.
- newCompressor() - Method in class org.apache.lucene.codecs.compressing.CompressionMode
-
- newConcurrentHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
-
Creates a new WeakIdentityMap
based on a ConcurrentHashMap
.
- newConcurrentHashMap(boolean) - Static method in class org.apache.lucene.util.WeakIdentityMap
-
Creates a new WeakIdentityMap
based on a ConcurrentHashMap
.
- newContainsQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
-
Create a query for matching indexed ranges that contain the defined range.
- newContainsQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
-
Create a query for matching indexed float ranges that contain the defined range.
- newContainsQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
-
Create a query for matching indexed ip ranges that CONTAINS
the defined range.
- newContainsQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
-
Create a query for matching indexed ranges that contain the defined range.
- newContainsQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonBoundingBox
-
Create a new 2d query that finds all indexed 2d GeoBoundingBoxField values that contain the defined
2d bounding box
- newContainsQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
-
Create a query for matching indexed ranges that contain the defined range.
- newContainsQuery(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- newContext(IndexSearcher) - Static method in class org.apache.lucene.queries.function.ValueSource
-
Returns a new non-threadsafe context map.
- newCopyJob(String, Map<String, FileMetaData>, Map<String, FileMetaData>, boolean, CopyJob.OnceDone) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Start a background copying job, to copy the specified files from the current primary node.
- newCopyOneFile(CopyOneFile) - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
- newCounter() - Static method in class org.apache.lucene.util.Counter
-
Returns a new counter.
- newCounter(boolean) - Static method in class org.apache.lucene.util.Counter
-
Returns a new counter.
- newCrossesQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
-
Create a query for matching indexed ranges that cross the defined range.
- newCrossesQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
-
Create a query for matching indexed ranges that cross the defined range.
- newCrossesQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
-
Create a query for matching indexed ip ranges that CROSS
the defined range.
- newCrossesQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
-
Create a query for matching indexed ranges that cross the defined range.
- newCrossesQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonBoundingBox
-
Create a new 2d query that finds all indexed 2d GeoBoundingBoxField values that cross the defined
3d bounding box
- newCrossesQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
-
Create a query for matching indexed ranges that cross the defined range.
- newCrossesQuery(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- newDecompressor() - Method in class org.apache.lucene.codecs.compressing.CompressionMode
-
- newDefaultQuery(String) - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Factory method to generate a standard query (no phrase or prefix operators).
- newDirectory() - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new Directory instance.
- newDirectory(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new Directory instance, using the specified random.
- newDirectory(Random, LockFactory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new Directory instance, using the specified random.
- newDirectory(Directory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new Directory instance, with contents copied from the
provided directory.
- newDirectory(Random, Directory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new Directory instance, using the specified random
with contents copied from the provided directory.
- newDirectoryStream(Path, DirectoryStream.Filter<? super Path>) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newDirectoryStream(Path, DirectoryStream.Filter<? super Path>) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
- newDirectoryStream(Path, DirectoryStream.Filter<? super Path>) - Method in class org.apache.lucene.mockfile.ShuffleFS
-
- newDistanceQuery(String, double, double, double) - Static method in class org.apache.lucene.document.LatLonPoint
-
Create a query for matching points within the specified distance of the supplied location.
- newDistanceQuery(String, double, double, double) - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- newDistanceQuery(String, double, double, double) - Static method in class org.apache.lucene.spatial3d.Geo3DPoint
-
Create a query for matching points within the specified distance of the supplied location.
- newDistanceSort(String, double, double) - Static method in class org.apache.lucene.document.LatLonDocValuesField
-
Creates a SortField for sorting by distance from a location.
- newDistanceSort(String, double, double, double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a SortField for sorting by distance within a circle.
- newDocument(int, int, BaseTermVectorsFormatTestCase.Options) - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomDocumentFactory
-
- newExactQuery(String, BigInteger) - Static method in class org.apache.lucene.document.BigIntegerPoint
-
Create a query for matching an exact big integer value.
- newExactQuery(String, byte[]) - Static method in class org.apache.lucene.document.BinaryPoint
-
Create a query for matching an exact binary value.
- newExactQuery(String, double) - Static method in class org.apache.lucene.document.DoublePoint
-
Create a query for matching an exact double value.
- newExactQuery(String, float) - Static method in class org.apache.lucene.document.FloatPoint
-
Create a query for matching an exact float value.
- newExactQuery(String, float) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Create a query for matching an exact half-float value.
- newExactQuery(String, InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
-
Create a query for matching a network address.
- newExactQuery(String, int) - Static method in class org.apache.lucene.document.IntPoint
-
Create a query for matching an exact integer value.
- newExactQuery(String, long) - Static method in class org.apache.lucene.document.LongPoint
-
Create a query for matching an exact long value.
- newFactoryClassInstance(Class<T>, Map<String, String>) - Static method in class org.apache.lucene.analysis.util.AnalysisSPILoader
-
Creates a new instance of the given
AbstractAnalysisFactory
by invoking the constructor, passing the given argument map.
- newField(FieldInfo) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter.EveryNOrDocFreqTermSelector
-
- newField(FieldInfo) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter.EveryNTermSelector
-
- newField(FieldInfo) - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter.IndexTermSelector
-
Called when a new field is started.
- newField(String, String, FieldType) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newField(Random, String, Object, FieldType) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newFieldQuery(Analyzer, String, String, boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- newFileChannel(Path, Set<? extends OpenOption>, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.DisableFsyncFS
-
- newFileChannel(Path, Set<? extends OpenOption>, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newFileChannel(Path, Set<? extends OpenOption>, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
- newFileChannel(Path, Set<? extends OpenOption>, FileAttribute<?>...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- newFileSystem(URI, Map<String, ?>) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newFileSystem(Path, Map<String, ?>) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newFromDelegate(IndexOutput) - Method in class org.apache.lucene.util.ThrottledIndexOutput
-
- newFSDirectory(String, Path) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Creates a specific FSDirectory instance starting from its class name, using the default lock factory
- newFSDirectory(String, Path, LockFactory) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Creates a specific FSDirectory instance starting from its class name
- newFSDirectory(Class<? extends FSDirectory>, Path) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Creates a new specific FSDirectory instance
- newFSDirectory(Class<? extends FSDirectory>, Path, LockFactory) - Static method in class org.apache.lucene.util.CommandLineUtil
-
Creates a new specific FSDirectory instance
- newFSDirectory(Path) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new FSDirectory instance over the given file, which must be a folder.
- newFSDirectory(Path, LockFactory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns a new FSDirectory instance over the given file, which must be a folder.
- newFuzzyQuery(Term, float, int) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Builds a new FuzzyQuery instance
- newFuzzyQuery(String, int) - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Factory method to generate a fuzzy query.
- newGraphSynonymQuery(Iterator<Query>) - Method in class org.apache.lucene.util.QueryBuilder
-
Builds a new GraphQuery for multi-terms synonyms.
- newGroupHead(int, T, LeafReaderContext, Scorer) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
Create a new GroupHead for the given group value, initialized with a doc, context and scorer
- newHashMap() - Static method in class org.apache.lucene.util.WeakIdentityMap
-
Creates a new WeakIdentityMap
based on a non-synchronized HashMap
.
- newHashMap(boolean) - Static method in class org.apache.lucene.util.WeakIdentityMap
-
Creates a new WeakIdentityMap
based on a non-synchronized HashMap
.
- newIndexWriterConfig() - Static method in class org.apache.lucene.util.LuceneTestCase
-
create a new index writer config with random defaults
- newIndexWriterConfig(Analyzer) - Static method in class org.apache.lucene.util.LuceneTestCase
-
create a new index writer config with random defaults
- newIndexWriterConfig(Random, Analyzer) - Static method in class org.apache.lucene.util.LuceneTestCase
-
create a new index writer config with random defaults using the specified random
- newInputStream(Path, OpenOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newInputStream(Path, OpenOption...) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
- newInstance(String, Map<String, String>) - Method in class org.apache.lucene.analysis.util.AnalysisSPILoader
-
- newInstance(String, Class<T>) - Method in class org.apache.lucene.analysis.util.ClasspathResourceLoader
-
- newInstance(String, Class<T>) - Method in class org.apache.lucene.analysis.util.FilesystemResourceLoader
-
- newInstance(String, Class<T>) - Method in interface org.apache.lucene.analysis.util.ResourceLoader
-
Creates an instance of the name and expected type
- newInstance() - Static method in class org.apache.lucene.queryparser.flexible.core.config.ConfigurationKey
-
Creates a new instance.
- newInstance(SpatialContext, String) - Static method in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- newInstance(SpatialContext, String) - Static method in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
- newInstance() - Method in class org.apache.lucene.util.RollingBuffer
-
- newIntersectsQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
-
Create a query for matching indexed ranges that intersect the defined range.
- newIntersectsQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
-
Create a query for matching indexed ranges that intersect the defined range.
- newIntersectsQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
-
Create a query for matching indexed ip ranges that INTERSECT
the defined range.
- newIntersectsQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
-
Create a query for matching indexed ranges that intersect the defined range.
- newIntersectsQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonBoundingBox
-
Create a new 2d query that finds all indexed 2d GeoBoundingBoxField values that intersect the defined
3d bounding ranges
- newIntersectsQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
-
Create a query for matching indexed ranges that intersect the defined range.
- newIntersectsQuery(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- newIOContext(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
TODO: javadoc
- newIOContext(Random, IOContext) - Static method in class org.apache.lucene.util.LuceneTestCase
-
TODO: javadoc
- newLargePolygonQuery(String, Polygon...) - Static method in class org.apache.lucene.spatial3d.Geo3DPoint
-
Create a query for matching a large polygon.
- newLimitedStoredFieldsVisitor(String[]) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- newline - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- newLineQuery(String, LatLonShape.QueryRelation, Line...) - Static method in class org.apache.lucene.document.LatLonShape
-
create a query to find all polygons that intersect a provided linestring (or array of linestrings)
note: does not support dateline crossing
- NewLocaleTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Set a Locale
for use in benchmarking.
- NewLocaleTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.NewLocaleTask
-
Create a new Locale
and set it it in the getRunData() for
use by all future tasks.
- newLogMergePolicy() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newLogMergePolicy(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newLogMergePolicy(boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newLogMergePolicy(boolean, int) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newLogMergePolicy(int) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newLogQuery(String, String, float, float) - Static method in class org.apache.lucene.document.FeatureField
-
Return a new
Query
that will score documents as
weight * Math.log(scalingFactor + S)
where S is the value of the static feature.
- newMatchAllDocsQuery() - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Builds a new MatchAllDocsQuery instance
- newMaybeVirusCheckingDirectory() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMaybeVirusCheckingFSDirectory(Path) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMergePolicy(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMergePolicy(Random, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMergePolicy() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMockDirectory() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMockDirectory(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMockDirectory(Random, LockFactory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMockFSDirectory(Path) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMockFSDirectory(Path, LockFactory) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newMultiPhraseQueryBuilder() - Method in class org.apache.lucene.util.QueryBuilder
-
Builds a new MultiPhraseQuery instance.
- newMutable(int, int) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- newMutable(int, int) - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
-
- newMutable(int, int) - Method in class org.apache.lucene.util.packed.PagedMutable
-
- newMutableValueLong() - Method in class org.apache.lucene.queries.function.valuesource.LongFieldSource
-
- newNRTPoint(long, long) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Call this to notify this replica node that a new NRT infos is available on the primary.
- newOrderedNearQuery(String) - Static method in class org.apache.lucene.search.spans.SpanNearQuery
-
- newOutputStream(Path, OpenOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- newOutputStream(Path, OpenOption...) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
- newOutputStream(Path, OpenOption...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- newOutsideBoxSort(String, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a SortField for sorting by outside distance from a box.
- newOutsideDistanceSort(String, double, double, double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a SortField for sorting by outside distance from a circle.
- newOutsideLargePolygonSort(String, Polygon...) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a SortField for sorting by outside distance from a large polygon.
- newOutsidePathSort(String, double[], double[], double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a SortField for sorting by outside distance from a path.
- newOutsidePolygonSort(String, Polygon...) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a SortField for sorting by outside distance from a polygon.
- newPair(A, B) - Method in class org.apache.lucene.util.fst.PairOutputs
-
Create a new Pair
- newPath(T, IntsRefBuilder) - Method in class org.apache.lucene.util.fst.Util.FSTPath
-
- newPathQuery(String, double[], double[], double) - Static method in class org.apache.lucene.spatial3d.Geo3DPoint
-
Create a query for matching a path.
- newPathSort(String, double[], double[], double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Creates a SortField for sorting by distance along a path.
- newPhraseQuery(String, int) - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Factory method to generate a phrase query with slop.
- newPolygonQuery(String, Polygon...) - Static method in class org.apache.lucene.document.LatLonPoint
-
Create a query for matching one or more polygons.
- newPolygonQuery(String, LatLonShape.QueryRelation, Polygon...) - Static method in class org.apache.lucene.document.LatLonShape
-
create a query to find all polygons that intersect a provided polygon (or array of polygons)
note: does not support dateline crossing
- newPolygonQuery(String, Polygon...) - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- newPolygonQuery(String, Polygon...) - Static method in class org.apache.lucene.spatial3d.Geo3DPoint
-
Create a query for matching a polygon.
- newPosition() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- newPosition() - Method in class org.apache.lucene.analysis.MockGraphTokenFilter
-
- newPosition() - Method in class org.apache.lucene.analysis.MockRandomLookaheadTokenFilter
-
- newPrefixQuery(String, InetAddress, int) - Static method in class org.apache.lucene.document.InetAddressPoint
-
Create a prefix query for matching a CIDR network range.
- newPrefixQuery(Term) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Builds a new PrefixQuery instance
- newPrefixQuery(String) - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Factory method to generate a prefix query.
- newRAMFile() - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
Returns a new
RAMFile
for storing data.
- newRangeField(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- newRangeQuery(String, BigInteger, BigInteger) - Static method in class org.apache.lucene.document.BigIntegerPoint
-
Create a range query for big integer values.
- newRangeQuery(String, BigInteger[], BigInteger[]) - Static method in class org.apache.lucene.document.BigIntegerPoint
-
Create a range query for n-dimensional big integer values.
- newRangeQuery(String, byte[], byte[]) - Static method in class org.apache.lucene.document.BinaryPoint
-
Create a range query for binary values.
- newRangeQuery(String, byte[][], byte[][]) - Static method in class org.apache.lucene.document.BinaryPoint
-
Create a range query for n-dimensional binary values.
- newRangeQuery(String, double, double) - Static method in class org.apache.lucene.document.DoublePoint
-
Create a range query for double values.
- newRangeQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoublePoint
-
Create a range query for n-dimensional double values.
- newRangeQuery(String, float, float) - Static method in class org.apache.lucene.document.FloatPoint
-
Create a range query for float values.
- newRangeQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatPoint
-
Create a range query for n-dimensional float values.
- newRangeQuery(String, float, float) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Create a range query for half-float values.
- newRangeQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Create a range query for n-dimensional half-float values.
- newRangeQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
-
Create a range query for network addresses.
- newRangeQuery(String, int, int) - Static method in class org.apache.lucene.document.IntPoint
-
Create a range query for integer values.
- newRangeQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntPoint
-
Create a range query for n-dimensional integer values.
- newRangeQuery(String, long, long) - Static method in class org.apache.lucene.document.LongPoint
-
Create a range query for long values.
- newRangeQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongPoint
-
Create a range query for n-dimensional long values.
- newRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- newRangeQuery(String, String, String, boolean, boolean) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- newRectQuery(String, double, double, double, double) - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- newRegexpQuery(Term) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Builds a new RegexpQuery instance
- newResettableInstance() - Static method in class org.apache.lucene.store.ByteBuffersDataOutput
-
- newRound() - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Increment the round number, for config values that are extracted by round number.
- NewRoundTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Increment the counter for properties maintained by Round Number.
- NewRoundTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.NewRoundTask
-
- newSaturationQuery(String, String, float, float) - Static method in class org.apache.lucene.document.FeatureField
-
Return a new
Query
that will score documents as
weight * S / (S + pivot)
where S is the value of the static feature.
- newSaturationQuery(String, String) - Static method in class org.apache.lucene.document.FeatureField
-
- newSearcher(IndexReader, IndexReader) - Method in class org.apache.lucene.search.SearcherFactory
-
Returns a new IndexSearcher over the given reader.
- newSearcher(IndexReader) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Create a new searcher over the reader.
- newSearcher(IndexReader, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Create a new searcher over the reader.
- newSearcher(IndexReader, boolean, boolean) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Create a new searcher over the reader.
- newSegmentInfo(Directory, String) - Static method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
Returns a new fake segment
- newSegmentInfo(Directory, String) - Static method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Returns a new fake segment
- newSentenceInstance() - Static method in class org.apache.lucene.analysis.util.CharArrayIterator
-
Create a new CharArrayIterator that works around JRE bugs
in a manner suitable for BreakIterator.getSentenceInstance()
- newSetQuery(String, BigInteger...) - Static method in class org.apache.lucene.document.BigIntegerPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, byte[]...) - Static method in class org.apache.lucene.document.BinaryPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, double...) - Static method in class org.apache.lucene.document.DoublePoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, Collection<Double>) - Static method in class org.apache.lucene.document.DoublePoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, float...) - Static method in class org.apache.lucene.document.FloatPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, Collection<Float>) - Static method in class org.apache.lucene.document.FloatPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, float...) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, Collection<Float>) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, InetAddress...) - Static method in class org.apache.lucene.document.InetAddressPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, int...) - Static method in class org.apache.lucene.document.IntPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, Collection<Integer>) - Static method in class org.apache.lucene.document.IntPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, long...) - Static method in class org.apache.lucene.document.LongPoint
-
Create a query matching any of the specified 1D values.
- newSetQuery(String, Collection<Long>) - Static method in class org.apache.lucene.document.LongPoint
-
Create a query matching any of the specified 1D values.
- newShapeQuery(String, GeoShape) - Static method in class org.apache.lucene.spatial3d.Geo3DPoint
-
Returns a query matching all points inside the provided shape.
- newSigmoidQuery(String, String, float, float, float) - Static method in class org.apache.lucene.document.FeatureField
-
Return a new
Query
that will score documents as
weight * S^a / (S^a + pivot^a)
where S is the value of the static feature.
- newSinkTokenStream() - Method in class org.apache.lucene.analysis.sinks.TeeSinkTokenFilter
-
- newSlice(int) - Method in class org.apache.lucene.util.ByteBlockPool
-
Allocates a new slice with the given size.
- newSlowBoxQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonDocValuesField
-
Create a query for matching a bounding box using doc values.
- newSlowDistanceQuery(String, double, double, double) - Static method in class org.apache.lucene.document.LatLonDocValuesField
-
Create a query for matching points within the specified distance of the supplied location.
- newSlowExactQuery(String, long) - Static method in class org.apache.lucene.document.NumericDocValuesField
-
Create a query for matching an exact long value.
- newSlowExactQuery(String, BytesRef) - Static method in class org.apache.lucene.document.SortedDocValuesField
-
Create a query for matching an exact
BytesRef
value.
- newSlowExactQuery(String, long) - Static method in class org.apache.lucene.document.SortedNumericDocValuesField
-
Create a query for matching an exact long value.
- newSlowExactQuery(String, BytesRef) - Static method in class org.apache.lucene.document.SortedSetDocValuesField
-
Create a query for matching an exact
BytesRef
value.
- newSlowRangeQuery(String, long, long) - Static method in class org.apache.lucene.document.NumericDocValuesField
-
Create a range query that matches all documents whose value is between
lowerValue
and upperValue
included.
- newSlowRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.document.SortedDocValuesField
-
Create a range query that matches all documents whose value is between
lowerValue
and upperValue
included.
- newSlowRangeQuery(String, long, long) - Static method in class org.apache.lucene.document.SortedNumericDocValuesField
-
Create a range query that matches all documents whose value is between
lowerValue
and upperValue
included.
- newSlowRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.document.SortedSetDocValuesField
-
Create a range query that matches all documents whose value is between
lowerValue
and upperValue
.
- newSpanTermQuery(Term) - Method in class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- newSpatialArgs(SpatialOperation, Shape) - Method in class org.apache.lucene.spatial.query.SpatialArgsParser
-
- newSpatialContext() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dSpatialContextFactory
-
- newSPT() - Method in class org.apache.lucene.spatial.prefix.tree.GeohashPrefixTree.Factory
-
- newSPT() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.Factory
-
- newSPT() - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree.Factory
-
- newSPT() - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- newStats(String, float) - Method in class org.apache.lucene.search.similarities.LMSimilarity
-
- newStats(String, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
Factory method to return a custom stats object
- newString(int[], int, int) - Static method in class org.apache.lucene.util.UnicodeUtil
-
Cover JDK 1.5 API.
- newStringField(String, String, Field.Store) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newStringField(String, BytesRef, Field.Store) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newStringField(Random, String, String, Field.Store) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newStringField(Random, String, BytesRef, Field.Store) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newStringRange(String, String, String, boolean, boolean) - Static method in class org.apache.lucene.search.TermRangeQuery
-
Factory that creates a new TermRangeQuery using Strings for term text.
- newSynonymQuery(Term[]) - Method in class org.apache.lucene.util.QueryBuilder
-
Builds a new SynonymQuery instance.
- newTermExtractor(String) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- newTermQuery(Term, TermContext) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Builds a new TermQuery instance.
- newTermQuery(Term) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- newTermQuery(Term) - Method in class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- newTermQuery(Term) - Method in class org.apache.lucene.util.QueryBuilder
-
Builds a new TermQuery instance.
- newTermState() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- newTermState() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- newTermState() - Method in class org.apache.lucene.codecs.PostingsReaderBase
-
Return a newly created empty TermState
- newTermState() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
-
Return a newly created empty TermState
- newTextField(String, String, Field.Store) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newTextField(Random, String, String, Field.Store) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newThread(Runnable) - Method in class org.apache.lucene.util.NamedThreadFactory
-
Creates a new Thread
- newTieredMergePolicy() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newTieredMergePolicy(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- newToken(int, String) - Static method in class org.apache.lucene.queryparser.classic.Token
-
Returns a new Token object, by default.
- newToken(int) - Static method in class org.apache.lucene.queryparser.classic.Token
-
- newToken(int, String) - Static method in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
Returns a new Token object, by default.
- newToken(int) - Static method in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
- newToken(int, String) - Static method in class org.apache.lucene.queryparser.surround.parser.Token
-
Returns a new Token object, by default.
- newToken(int) - Static method in class org.apache.lucene.queryparser.surround.parser.Token
-
- newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.DiversifiedTopDocsCollector
-
- newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopDocsCollector
-
Returns a
TopDocs
instance containing the given results.
- newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopFieldCollector
-
- newTopDocs(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopScoreDocCollector
-
- newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.PagedGrowableWriter
-
- newUnfilledCopy(long) - Method in class org.apache.lucene.util.packed.PagedMutable
-
- newUnorderedNearQuery(String) - Static method in class org.apache.lucene.search.spans.SpanNearQuery
-
- newWatchService() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- newWildcardQuery(Term) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Builds a new WildcardQuery instance
- newWithinQuery(String, double[], double[]) - Static method in class org.apache.lucene.document.DoubleRange
-
Create a query for matching indexed ranges that are within the defined range.
- newWithinQuery(String, float[], float[]) - Static method in class org.apache.lucene.document.FloatRange
-
Create a query for matching indexed ranges that are within the defined range.
- newWithinQuery(String, InetAddress, InetAddress) - Static method in class org.apache.lucene.document.InetAddressRange
-
Create a query for matching indexed ip ranges that are WITHIN
the defined range.
- newWithinQuery(String, int[], int[]) - Static method in class org.apache.lucene.document.IntRange
-
Create a query for matching indexed ranges that are within the defined range.
- newWithinQuery(String, double, double, double, double) - Static method in class org.apache.lucene.document.LatLonBoundingBox
-
Create a new 2d query that finds all indexed 2d GeoBoundingBoxField values that are within the defined
2d bounding box
- newWithinQuery(String, long[], long[]) - Static method in class org.apache.lucene.document.LongRange
-
Create a query for matching indexed ranges that are within the defined range.
- newWithinQuery(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- newWordInstance() - Static method in class org.apache.lucene.analysis.util.CharArrayIterator
-
Create a new CharArrayIterator that works around JRE bugs
in a manner suitable for BreakIterator.getWordInstance()
- next() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
-
use nextCharArray() + currentValue() for better efficiency.
- next() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- next() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
-
- next() - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase.FieldIndexEnum
-
Returns -1 at end
- next() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- next() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- next() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader.ChildrenIterator
-
- next() - Method in class org.apache.lucene.index.DocIDMerger
-
Returns null when done.
- next() - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableTermsEnum
-
- next() - Method in class org.apache.lucene.index.FilteredTermsEnum
-
- next() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- next() - Method in class org.apache.lucene.index.MultiTermsEnum
-
- next() - Method in class org.apache.lucene.index.PrefixCodedTerms.TermIterator
-
- next - Variable in class org.apache.lucene.queryparser.classic.Token
-
A reference to the next regular (non-special) token from the input
stream.
- next - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
A reference to the next regular (non-special) token from the input
stream.
- next - Variable in class org.apache.lucene.queryparser.surround.parser.Token
-
A reference to the next regular (non-special) token from the input
stream.
- next - Variable in class org.apache.lucene.search.DisiWrapper
-
- next() - Method in class org.apache.lucene.search.FilterMatchesIterator
-
- next() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- next() - Method in interface org.apache.lucene.search.MatchesIterator
-
Advance the iterator to the next match position
- next() - Method in class org.apache.lucene.search.PointInSetQuery.Stream
-
- next() - Method in class org.apache.lucene.search.suggest.BufferedInputIterator
-
- next() - Method in class org.apache.lucene.search.suggest.DocumentDictionary.DocumentInputIterator
-
- next() - Method in class org.apache.lucene.search.suggest.InputIterator.InputIteratorWrapper
-
- next() - Method in class org.apache.lucene.search.suggest.SortedInputIterator
-
- next() - Method in class org.apache.lucene.search.suggest.UnsortedInputIterator
-
- next() - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- next(int) - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- next(int) - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- next() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- next() - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- next(int) - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- next() - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- next(int) - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- next() - Method in class org.apache.lucene.spatial.prefix.CellToBytesRefIterator
-
- next() - Method in class org.apache.lucene.spatial.prefix.tree.CellIterator
-
- next() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PrefixTreeIterator
-
- next() - Method in class org.apache.lucene.util.automaton.FiniteStringsIterator
-
Generate next finite string.
- next() - Method in class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
-
- next() - Method in class org.apache.lucene.util.bkd.HeapPointReader
-
- next() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
-
- next() - Method in class org.apache.lucene.util.bkd.PointReader
-
Returns false once iteration is done, else true.
- next() - Method in interface org.apache.lucene.util.BytesRefIterator
-
Increments the iteration to the next
BytesRef
in the iterator.
- next() - Method in class org.apache.lucene.util.FilterIterator
-
- next() - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
- next() - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
- next() - Method in class org.apache.lucene.util.MergedIterator
-
- next() - Method in class org.apache.lucene.util.OfflineSorter.ByteSequencesReader
-
Reads the next entry into the provided
BytesRef
.
- next() - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
-
Read the next value.
- next(int) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
-
Read between 1 and count
values.
- next() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
-
Returns next value
- next(int) - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
-
Returns at least 1 and at most count
next values,
the returned ref MUST NOT be modified
- next() - Method in class org.apache.lucene.util.packed.PackedLongValues.Iterator
-
Return the next long in the buffer.
- next() - Method in class org.apache.lucene.util.SPIClassIterator
-
- NEXT_LEVEL_ARRAY - Static variable in class org.apache.lucene.util.ByteBlockPool
-
- nextBigInteger(Random, int) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a randomish big integer with {@code 1 ..
- nextBox() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- nextBox() - Static method in class org.apache.lucene.geo.GeoTestUtil
-
returns next pseudorandom box: can cross the 180th meridian
- nextBoxNear(Polygon) - Static method in class org.apache.lucene.geo.GeoTestUtil
-
Returns next box for testing near a Polygon
- nextBoxNotCrossingDateline() - Static method in class org.apache.lucene.geo.GeoTestUtil
-
returns next pseudorandom box: does not cross the 180th meridian
- nextBuffer() - Method in class org.apache.lucene.util.ByteBlockPool
-
Advances the pool to its next buffer.
- nextBuffer() - Method in class org.apache.lucene.util.IntBlockPool
-
Advances the pool to its next buffer.
- nextCell - Variable in class org.apache.lucene.spatial.prefix.tree.CellIterator
-
- nextCell(boolean) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
Get the next cell in the tree without using recursion.
- nextDoc() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- nextDoc() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.DocIDMerger.Sub
-
- nextDoc() - Method in class org.apache.lucene.index.FilterBinaryDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- nextDoc() - Method in class org.apache.lucene.index.FilterNumericDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.LegacyBinaryDocValuesWrapper
-
Deprecated.
- nextDoc() - Method in class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- nextDoc() - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- nextDoc() - Method in class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- nextDoc() - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- nextDoc() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- nextDoc() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- nextDoc() - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- nextDoc() - Method in class org.apache.lucene.search.ConjunctionDISI
-
- nextDoc() - Method in class org.apache.lucene.search.DisjunctionDISIApproximation
-
- nextDoc() - Method in class org.apache.lucene.search.DocIdSetIterator
-
Advances to the next document in the set and returns the doc it is
currently on, or
DocIdSetIterator.NO_MORE_DOCS
if there are no more docs in the
set.
NOTE: after the iterator has exhausted you should not call this
method, as it may result in unpredicted behavior.
- nextDoc() - Method in class org.apache.lucene.search.FilteredDocIdSetIterator
-
- nextDoc() - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- nextDoc() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- nextDoc() - Method in class org.apache.lucene.search.spans.TermSpans
-
- nextDoc() - Method in class org.apache.lucene.util.BitSetIterator
-
- nextDoc() - Method in class org.apache.lucene.util.LineFileDocs
-
Note: Document instance is re-used per-thread
- nextDown(double) - Static method in class org.apache.lucene.document.DoublePoint
-
Return the greatest double that compares less than d
consistently
with Double.compare(double, double)
.
- nextDown(float) - Static method in class org.apache.lucene.document.FloatPoint
-
Return the greatest float that compares less than f
consistently
with Float.compare(float, float)
.
- nextDown(float) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Return the first half float which is immediately smaller than v
.
- nextDown(InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
-
Return the InetAddress
that compares immediately less than
address
.
- nextElement() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
-
- nextFinalOutput - Variable in class org.apache.lucene.util.fst.Builder.Arc
-
- nextFinalOutput - Variable in class org.apache.lucene.util.fst.FST.Arc
-
- nextFrom(Cell) - Method in class org.apache.lucene.spatial.prefix.tree.CellIterator
-
Gets the next cell that is >= fromCell
, compared using non-leaf bytes.
- nextHighestPowerOfTwo(int) - Static method in class org.apache.lucene.util.BitUtil
-
returns the next highest power of two, or the current value if it's already a power of two or zero
- nextHighestPowerOfTwo(long) - Static method in class org.apache.lucene.util.BitUtil
-
returns the next highest power of two, or the current value if it's already a power of two or zero
- nextInt(Random, int, int) - Static method in class org.apache.lucene.util.TestUtil
-
start and end are BOTH inclusive
- nextInterval() - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- nextInterval() - Method in class org.apache.lucene.search.intervals.IntervalIterator
-
Advance the iterator to the next interval
- nextKey() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
-
gets the next key...
- nextKeyString() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
-
gets the next key as a newly created String object
- nextLatitude() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- nextLatitude() - Static method in class org.apache.lucene.geo.GeoTestUtil
-
returns next pseudorandom latitude (anywhere)
- nextLong(Random, long, long) - Static method in class org.apache.lucene.util.TestUtil
-
start and end are BOTH inclusive
- nextLongitude() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- nextLongitude() - Static method in class org.apache.lucene.geo.GeoTestUtil
-
returns next pseudorandom longitude (anywhere)
- nextOrd() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedSetDocValues
-
- nextOrd() - Method in class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
- nextOrd() - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- nextOrd() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedSetDocValues
-
- nextOrd() - Method in class org.apache.lucene.index.SortedSetDocValues
-
Returns the next ordinal for the current document.
- nextPointNear(Rectangle) - Static method in class org.apache.lucene.geo.GeoTestUtil
-
Returns next point (lat/lon) for testing near a Box.
- nextPointNear(Polygon) - Static method in class org.apache.lucene.geo.GeoTestUtil
-
Returns next point (lat/lon) for testing near a Polygon
- nextPolygon() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- nextPolygon() - Static method in class org.apache.lucene.geo.GeoTestUtil
-
returns next pseudorandom polygon
- nextPosition() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- nextPosition() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- nextPosition() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- nextPosition() - Method in class org.apache.lucene.index.PostingsEnum
-
Returns the next position, or -1 if positions were not indexed.
- nextPosition() - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- nextPosition() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.MultiOffsetsEnum
-
- nextPosition() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum
-
Advances to the next position and returns true, or if can't then returns false.
- nextPosition() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIterator
-
- nextPosition() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIteratorWithSubs
-
- nextPosition() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfPostings
-
- nextQnum() - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- nextRange(int) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- nextRead - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
-
- nextSeekTerm(BytesRef) - Method in class org.apache.lucene.index.AutomatonTermsEnum
-
- nextSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
- nextSetBit(int) - Method in class org.apache.lucene.util.BitSet
-
Returns the index of the first set bit starting at the index specified.
- nextSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
-
- nextSetBit(long) - Method in class org.apache.lucene.util.LongBitSet
-
Returns the index of the first set bit starting at the index specified.
- nextSetBit(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- nextStartPosition() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- nextStartPosition() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-
- nextStartPosition() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-
- nextStartPosition() - Method in class org.apache.lucene.search.spans.Spans
-
Returns the next start position for the current doc.
- nextStartPosition() - Method in class org.apache.lucene.search.spans.TermSpans
-
- nextState() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
-
- nextTerm() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
Go to next term in this SegmentResult
in order to retrieve the grouped facet counts.
- nextToken() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
-
Call this when you are done looking ahead; it will set
the next token to return.
- nextUp(double) - Static method in class org.apache.lucene.document.DoublePoint
-
Return the least double that compares greater than d
consistently
with Double.compare(double, double)
.
- nextUp(float) - Static method in class org.apache.lucene.document.FloatPoint
-
Return the least float that compares greater than f
consistently
with Float.compare(float, float)
.
- nextUp(float) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Return the first half float which is immediately greater than v
.
- nextUp(InetAddress) - Static method in class org.apache.lucene.document.InetAddressPoint
-
Return the InetAddress
that compares immediately greater than
address
.
- nextValue() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedNumericDocValues
-
- nextValue() - Method in class org.apache.lucene.index.LegacySortedNumericDocValuesWrapper
-
Deprecated.
- nextValue() - Method in class org.apache.lucene.index.SortedNumericDocValues
-
Iterates to the next value in the current document.
- NGRAM - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- NGRAM - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- NGramDistance - Class in org.apache.lucene.search.spell
-
N-Gram version of edit distance based on paper by Grzegorz Kondrak,
"N-gram similarity and distance".
- NGramDistance(int) - Constructor for class org.apache.lucene.search.spell.NGramDistance
-
Creates an N-Gram distance measure using n-grams of the specified size.
- NGramDistance() - Constructor for class org.apache.lucene.search.spell.NGramDistance
-
Creates an N-Gram distance measure using n-grams of size 2.
- NGramFilterFactory - Class in org.apache.lucene.analysis.ngram
-
- NGramFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ngram.NGramFilterFactory
-
Creates a new NGramFilterFactory
- NGramPhraseQuery - Class in org.apache.lucene.search
-
This is a
PhraseQuery
which is optimized for n-gram phrase query.
- NGramPhraseQuery(int, PhraseQuery) - Constructor for class org.apache.lucene.search.NGramPhraseQuery
-
Constructor that takes gram size.
- NGramTokenFilter - Class in org.apache.lucene.analysis.ngram
-
Tokenizes the input into n-grams of the given size(s).
- NGramTokenFilter(TokenStream, int, int, boolean) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
Creates an NGramTokenFilter that, for a given input term, produces all
contained n-grams with lengths >= minGram and <= maxGram.
- NGramTokenFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
Creates an NGramTokenFilter that produces n-grams of the indicated size.
- NGramTokenFilter(TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
- NGramTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
- NGramTokenizer - Class in org.apache.lucene.analysis.ngram
-
Tokenizes the input into n-grams of the given size(s).
- NGramTokenizer(int, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Creates NGramTokenizer with given min and max n-grams.
- NGramTokenizer(AttributeFactory, int, int) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Creates NGramTokenizer with given min and max n-grams.
- NGramTokenizer() - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizer
-
Creates NGramTokenizer with default min and max n-grams.
- NGramTokenizerFactory - Class in org.apache.lucene.analysis.ngram
-
- NGramTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ngram.NGramTokenizerFactory
-
Creates a new NGramTokenizerFactory
- NIOFSDirectory - Class in org.apache.lucene.store
-
An
FSDirectory
implementation that uses java.nio's FileChannel's
positional read, which allows multiple threads to read from the same file
without synchronizing.
- NIOFSDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.NIOFSDirectory
-
Create a new NIOFSDirectory for the named location.
- NIOFSDirectory(Path) - Constructor for class org.apache.lucene.store.NIOFSDirectory
-
- NLS - Class in org.apache.lucene.queryparser.flexible.messages
-
MessageBundles classes extend this class, to implement a bundle.
- NLS() - Constructor for class org.apache.lucene.queryparser.flexible.messages.NLS
-
- NLSException - Interface in org.apache.lucene.queryparser.flexible.messages
-
Interface that exceptions should implement to support lazy loading of messages.
- NO - Static variable in class org.apache.lucene.index.SegmentInfo
-
Used by some member fields to mean not present (e.g.,
norms, deletions).
- NO_BOUNDS - Static variable in class org.apache.lucene.spatial3d.geom.Plane
-
An array with no bounds in it
- NO_MORE_DOCS - Static variable in class org.apache.lucene.search.DocIdSetIterator
-
- NO_MORE_INTERVALS - Static variable in class org.apache.lucene.search.intervals.IntervalIterator
-
- NO_MORE_ORDS - Static variable in class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
- NO_MORE_ORDS - Static variable in class org.apache.lucene.index.SortedSetDocValues
-
- NO_MORE_POSITIONS - Static variable in class org.apache.lucene.search.spans.Spans
-
- NO_OUTPUT - Variable in class org.apache.lucene.analysis.ja.dict.TokenInfoFST
-
- NO_OUTPUT - Variable in class org.apache.lucene.analysis.ko.dict.TokenInfoFST
-
- NO_OUTPUT - Static variable in class org.apache.lucene.util.InfoStream
-
Instance of InfoStream that does no logging at all.
- NO_POINTS - Static variable in class org.apache.lucene.spatial3d.geom.Plane
-
An array with no points in it
- NO_REUSE - Static variable in class org.apache.lucene.store.ByteBuffersDataOutput
-
A singleton instance of "no-reuse" buffer strategy.
- NoAfterEffect() - Constructor for class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
-
Sole constructor: parameter-free
- noBottomLatitudeBound() - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Signal that there is no bottom latitude bound.
- noBottomLatitudeBound() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- noBottomLatitudeBound() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- noBound(PlanetModel) - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Signal that there is no bound whatsoever.
- noBound(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- noBound(PlanetModel) - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- noBreak - Variable in class org.apache.lucene.analysis.compound.hyphenation.Hyphen
-
- noCFSRatio - Variable in class org.apache.lucene.index.MergePolicy
-
If the size of the merge segment exceeds this ratio of
the total index size then it will remain in
non-compound format
- NoChildOptimizationQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.core.processors
-
- NoChildOptimizationQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.core.processors.NoChildOptimizationQueryNodeProcessor
-
- Node(Polygon, int, int) - Constructor for class org.apache.lucene.geo.Tessellator.Node
-
- Node(Tessellator.Node) - Constructor for class org.apache.lucene.geo.Tessellator.Node
-
simple deep copy constructor
- Node - Class in org.apache.lucene.replicator.nrt
-
- Node(int, Directory, SearcherFactory, PrintStream) - Constructor for class org.apache.lucene.replicator.nrt.Node
-
- NODE_ACTION_NOT_SUPPORTED - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- NodeCommunicationException - Exception in org.apache.lucene.replicator.nrt
-
Should be thrown by subclasses of
PrimaryNode
and
ReplicaNode
if a non-fatal exception
occurred while communicating between nodes.
- NodeCommunicationException(String, Throwable) - Constructor for exception org.apache.lucene.replicator.nrt.NodeCommunicationException
-
- nodeExists() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- nodeID - Variable in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- NoDeletionPolicy - Class in org.apache.lucene.index
-
- nodeMessage(PrintStream, String) - Static method in class org.apache.lucene.replicator.nrt.Node
-
- nodeMessage(PrintStream, int, String) - Static method in class org.apache.lucene.replicator.nrt.Node
-
- nodes - Variable in class org.apache.lucene.search.ShardSearchingTestBase
-
- NodeState(Random, int, int) - Constructor for class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- nodeVersions - Variable in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- NoLockFactory - Class in org.apache.lucene.store
-
- noLongitudeBound() - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Signal that there is no longitude bound.
- noLongitudeBound() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- noLongitudeBound() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- noMatch(String, Collection<Explanation>) - Static method in class org.apache.lucene.search.Explanation
-
Create a new explanation for a document which does not match.
- noMatch(String, Explanation...) - Static method in class org.apache.lucene.search.Explanation
-
Create a new explanation for a document which does not match.
- NoMergePolicy - Class in org.apache.lucene.index
-
- NoMergeScheduler - Class in org.apache.lucene.index
-
- NoMoreDataException - Exception in org.apache.lucene.benchmark.byTask.feeds
-
Exception indicating there is no more data.
- NoMoreDataException() - Constructor for exception org.apache.lucene.benchmark.byTask.feeds.NoMoreDataException
-
- NONE - Static variable in class org.apache.lucene.index.PostingsEnum
-
- NONE - Static variable in class org.apache.lucene.search.uhighlight.PhraseHelper
-
- NONE - Static variable in class org.apache.lucene.util.automaton.RegExp
-
Syntax flag, enables no optional regexp syntax.
- nonFloorBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
The number of normal (non-floor) blocks in the terms file.
- NoNormalization() - Constructor for class org.apache.lucene.search.similarities.Normalization.NoNormalization
-
Sole constructor: parameter-free
- nonOverlapping(IntervalsSource, IntervalsSource) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Create a non-overlapping IntervalsSource
Returns intervals of the minuend that do not overlap with intervals from the subtrahend
- NOON - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- NoOpOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
Never returns offsets.
- NoOutputs - Class in org.apache.lucene.util.fst
-
A null FST
Outputs
implementation; use this if
you just want to build an FSA.
- NOREUSE - Static variable in class org.apache.lucene.store.NativePosixUtil
-
- norm(int) - Method in class org.apache.lucene.search.uhighlight.PassageScorer
-
Normalize a passage according to its position in the document.
- NORMAL - Static variable in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Normal distance calculator
- NORMAL - Static variable in class org.apache.lucene.store.NativePosixUtil
-
- NORMAL_SQUARED - Static variable in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Normal distance squared calculator
- NormalDistance - Class in org.apache.lucene.spatial3d.geom
-
Normal distance computation style.
- NormalDistance() - Constructor for class org.apache.lucene.spatial3d.geom.NormalDistance
-
Constructor.
- normalDistance(Vector, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute normal distance from plane to a vector.
- normalDistance(double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute normal distance from plane to a vector.
- normalDistance(Vector) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the normal (perpendicular) distance to a vector described by a
vector taken from the origin.
- normalDistance(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the normal (perpendicular) distance to a vector described by a
vector taken from the origin.
- normalDistanceSquared(Vector, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute normal distance squared from plane to a vector.
- normalDistanceSquared(double, double, double, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Compute normal distance squared from plane to a vector.
- normalDistanceSquared(Vector) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the square of the normal distance to a vector described by a
vector taken from the origin.
- normalDistanceSquared(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute the square of the normal distance to a vector described by a
vector taken from the origin.
- normalization - Variable in class org.apache.lucene.search.similarities.DFRSimilarity
-
The term frequency normalization.
- normalization - Variable in class org.apache.lucene.search.similarities.IBSimilarity
-
The term frequency normalization.
- Normalization - Class in org.apache.lucene.search.similarities
-
This class acts as the base class for the implementations of the term
frequency normalization methods in the DFR framework.
- Normalization() - Constructor for class org.apache.lucene.search.similarities.Normalization
-
Sole constructor.
- Normalization.NoNormalization - Class in org.apache.lucene.search.similarities
-
Implementation used when there is no normalization.
- NormalizationH1 - Class in org.apache.lucene.search.similarities
-
Normalization model that assumes a uniform distribution of the term frequency.
- NormalizationH1(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH1
-
Creates NormalizationH1 with the supplied parameter c
.
- NormalizationH1() - Constructor for class org.apache.lucene.search.similarities.NormalizationH1
-
- NormalizationH2 - Class in org.apache.lucene.search.similarities
-
Normalization model in which the term frequency is inversely related to the
length.
- NormalizationH2(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH2
-
Creates NormalizationH2 with the supplied parameter c
.
- NormalizationH2() - Constructor for class org.apache.lucene.search.similarities.NormalizationH2
-
- NormalizationH3 - Class in org.apache.lucene.search.similarities
-
Dirichlet Priors normalization
- NormalizationH3() - Constructor for class org.apache.lucene.search.similarities.NormalizationH3
-
- NormalizationH3(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationH3
-
Creates NormalizationH3 with the supplied parameter μ
.
- NormalizationZ - Class in org.apache.lucene.search.similarities
-
Pareto-Zipf Normalization
- NormalizationZ() - Constructor for class org.apache.lucene.search.similarities.NormalizationZ
-
- NormalizationZ(float) - Constructor for class org.apache.lucene.search.similarities.NormalizationZ
-
Creates NormalizationZ with the supplied parameter z
.
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.Analyzer
-
Wrap the given
TokenStream
in order to apply normalization filters.
- normalize(String, String) - Method in class org.apache.lucene.analysis.Analyzer
-
Normalize a string down to the representation that it would have in the
index.
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.AnalyzerWrapper
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ar.ArabicAnalyzer
-
- normalize(char[], int) - Method in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
Normalize an input buffer of Arabic text
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.bg.BulgarianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.bn.BengaliAnalyzer
-
- normalize(char[], int) - Method in class org.apache.lucene.analysis.bn.BengaliNormalizer
-
Normalize an input buffer of Bengali text
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.br.BrazilianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ca.CatalanAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.cjk.CJKAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ckb.SoraniAnalyzer
-
- normalize(char[], int) - Method in class org.apache.lucene.analysis.ckb.SoraniNormalizer
-
Normalize an input buffer of Sorani text
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
- normalize(int) - Method in class org.apache.lucene.analysis.core.LowerCaseTokenizer
-
Deprecated.
Converts char to lower case
Character.toLowerCase(int)
.
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.core.SimpleAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.core.StopAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.cz.CzechAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.da.DanishAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.de.GermanAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.el.GreekAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.en.EnglishAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.es.SpanishAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.eu.BasqueAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
- normalize(char[], int) - Method in class org.apache.lucene.analysis.fa.PersianNormalizer
-
Normalize an input buffer of Persian text
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.fi.FinnishAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.fr.FrenchAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ga.IrishAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.gl.GalicianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.hi.HindiAnalyzer
-
- normalize(char[], int) - Method in class org.apache.lucene.analysis.hi.HindiNormalizer
-
Normalize an input buffer of Hindi text
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.hu.HungarianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.hy.ArmenianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.id.IndonesianAnalyzer
-
- normalize(char[], int) - Method in class org.apache.lucene.analysis.in.IndicNormalizer
-
Normalizes input text, and returns the new length.
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.it.ItalianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ja.JapaneseAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ko.KoreanAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.lt.LithuanianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.lv.LatvianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
- normalize(int) - Method in class org.apache.lucene.analysis.MockTokenizer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.nl.DutchAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.pl.PolishAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.ru.RussianAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.th.ThaiAnalyzer
-
- normalize(String, TokenStream) - Method in class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
- normalize(int) - Method in class org.apache.lucene.analysis.util.CharTokenizer
-
- normalize() - Method in class org.apache.lucene.mockfile.FilterPath
-
- normalize() - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Build a normalized plane, so that the vector is normalized.
- normalize() - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Compute a normalized unit vector based on the current vector.
- NORMALIZE_KANA_DEFAULT - Static variable in class org.apache.lucene.analysis.ja.JapaneseIterationMarkCharFilter
-
Normalize kana iteration marks by default
- NORMALIZE_KANJI_DEFAULT - Static variable in class org.apache.lucene.analysis.ja.JapaneseIterationMarkCharFilter
-
Normalize kanji iteration marks by default
- NormalizeCharMap - Class in org.apache.lucene.analysis.charfilter
-
- NormalizeCharMap.Builder - Class in org.apache.lucene.analysis.charfilter
-
Builds an NormalizeCharMap.
- normalizeException(ArrayList<?>) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- normalizeNumber(String) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Normalizes a Japanese number
- NORMALIZER - Static variable in class org.apache.lucene.analysis.icu.ICUFoldingFilter
-
A normalizer for search term folding to Unicode text,
applying foldings from UTR#30 Character Foldings.
- NormalSquaredDistance - Class in org.apache.lucene.spatial3d.geom
-
Normal squared distance computation style.
- NormalSquaredDistance() - Constructor for class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
Constructor.
- normalXPlane - Static variable in class org.apache.lucene.spatial3d.geom.Plane
-
A vertical plane normal to the X axis
- normalYPlane - Static variable in class org.apache.lucene.spatial3d.geom.Plane
-
A vertical plane normal to the Y axis
- normalZPlane - Static variable in class org.apache.lucene.spatial3d.geom.Plane
-
A vertical plane normal to the Z axis
- normClassificationResults(List<ClassificationResult<BytesRef>>) - Method in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
Normalize the classification results based on the max score available
- normDist(double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- normMap - Variable in class org.apache.lucene.analysis.charfilter.MappingCharFilterFactory
-
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.asserting.AssertingNormsFormat
-
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene53.Lucene53NormsFormat
-
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.lucene70.Lucene70NormsFormat
-
- NormsConsumer - Class in org.apache.lucene.codecs
-
Abstract API that consumes normalization values.
- NormsConsumer() - Constructor for class org.apache.lucene.codecs.NormsConsumer
-
Sole constructor.
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.NormsFormat
-
- normsConsumer(SegmentWriteState) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat
-
- NormsFieldExistsQuery - Class in org.apache.lucene.search
-
A
Query
that matches documents that have a value for a given field
as reported by field norms.
- NormsFieldExistsQuery(String) - Constructor for class org.apache.lucene.search.NormsFieldExistsQuery
-
Create a query that will match that have a value for the given
field
.
- normsFormat() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- normsFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes document normalization values
- normsFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- normsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- normsFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- normsFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- normsFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- NormsFormat - Class in org.apache.lucene.codecs
-
Encodes/decodes per-document score normalization values.
- NormsFormat() - Constructor for class org.apache.lucene.codecs.NormsFormat
-
Sole constructor.
- normsFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- normsIterable(FieldInfo, NormsProducer, int) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.asserting.AssertingNormsFormat
-
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene53.Lucene53NormsFormat
-
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.lucene70.Lucene70NormsFormat
-
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.NormsFormat
-
- NormsProducer - Class in org.apache.lucene.codecs
-
Abstract API that produces field normalization values
- NormsProducer() - Constructor for class org.apache.lucene.codecs.NormsProducer
-
Sole constructor.
- normsProducer(SegmentReadState) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat
-
- normsProducers - Variable in class org.apache.lucene.index.MergeState
-
Norms producers being merged
- NormValueSource - Class in org.apache.lucene.queries.function.valuesource
-
Function that returns the decoded norm for every document.
- NormValueSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.NormValueSource
-
- normX(double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- normY(double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- normZ(double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- NORTH_POLE - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
North pole
- NorwegianAnalyzer - Class in org.apache.lucene.analysis.no
-
- NorwegianAnalyzer() - Constructor for class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
- NorwegianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
Builds an analyzer with the given stop words.
- NorwegianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.no.NorwegianAnalyzer
-
Builds an analyzer with the given stop words.
- NorwegianLightStemFilter - Class in org.apache.lucene.analysis.no
-
- NorwegianLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.no.NorwegianLightStemFilter
-
- NorwegianLightStemFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.no.NorwegianLightStemFilter
-
Creates a new NorwegianLightStemFilter
- NorwegianLightStemFilterFactory - Class in org.apache.lucene.analysis.no
-
- NorwegianLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.no.NorwegianLightStemFilterFactory
-
Creates a new NorwegianLightStemFilterFactory
- NorwegianLightStemmer - Class in org.apache.lucene.analysis.no
-
Light Stemmer for Norwegian.
- NorwegianLightStemmer(int) - Constructor for class org.apache.lucene.analysis.no.NorwegianLightStemmer
-
Creates a new NorwegianLightStemmer
- NorwegianMinimalStemFilter - Class in org.apache.lucene.analysis.no
-
- NorwegianMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.no.NorwegianMinimalStemFilter
-
- NorwegianMinimalStemFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.no.NorwegianMinimalStemFilter
-
Creates a new NorwegianLightStemFilter
- NorwegianMinimalStemFilterFactory - Class in org.apache.lucene.analysis.no
-
- NorwegianMinimalStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.no.NorwegianMinimalStemFilterFactory
-
Creates a new NorwegianMinimalStemFilterFactory
- NorwegianMinimalStemmer - Class in org.apache.lucene.analysis.no
-
Minimal Stemmer for Norwegian Bokmål (no-nb) and Nynorsk (no-nn)
- NorwegianMinimalStemmer(int) - Constructor for class org.apache.lucene.analysis.no.NorwegianMinimalStemmer
-
Creates a new NorwegianMinimalStemmer
- NorwegianStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- NorwegianStemmer() - Constructor for class org.tartarus.snowball.ext.NorwegianStemmer
-
- NOT - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- NOT - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- NOT - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- NOT_OPERATOR - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables NOT
operator (-)
- notContainedBy(IntervalsSource, IntervalsSource) - Static method in class org.apache.lucene.search.intervals.Intervals
-
- notContaining(IntervalsSource, IntervalsSource) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Create a not-containing
IntervalsSource
Returns intervals from the minuend that do not contain intervals of the subtrahend
- NotDocIdSet - Class in org.apache.lucene.util
-
- NotDocIdSet(int, DocIdSet) - Constructor for class org.apache.lucene.util.NotDocIdSet
-
Sole constructor.
- NoTokenFoundQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
NoTokenFoundQueryNode
is used if a term is convert into no tokens
by the tokenizer/lemmatizer/analyzer (null).
- NoTokenFoundQueryNode() - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.NoTokenFoundQueryNode
-
- noTopLatitudeBound() - Method in interface org.apache.lucene.spatial3d.geom.Bounds
-
Signal that there is no top latitude bound.
- noTopLatitudeBound() - Method in class org.apache.lucene.spatial3d.geom.LatLonBounds
-
- noTopLatitudeBound() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- NotQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- NotQuery - Class in org.apache.lucene.queryparser.surround.query
-
Factory for prohibited clauses
- NotQuery(List<SrndQuery>, String) - Constructor for class org.apache.lucene.queryparser.surround.query.NotQuery
-
- notWithin(IntervalsSource, int, IntervalsSource) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Create a not-within
IntervalsSource
Returns intervals of the minuend that do not appear within a set number of positions of
intervals from the subtrahend query
- NQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- NRTCachingDirectory - Class in org.apache.lucene.store
-
Wraps a
RAMDirectory
around any provided delegate directory, to
be used during NRT search.
- NRTCachingDirectory(Directory, double, double) - Constructor for class org.apache.lucene.store.NRTCachingDirectory
-
We will cache a newly created output if 1) it's a
flush or a merge and the estimated size of the merged segment is
<= maxMergeSizeMB
, and 2) the total cached bytes is
<= maxCachedMB
- NRTSuggester - Class in org.apache.lucene.search.suggest.document
-
NRTSuggester executes Top N search on a weighted FST specified by a
CompletionScorer
- NullFragmenter - Class in org.apache.lucene.search.highlight
-
Fragmenter
implementation which does not fragment the text.
- NullFragmenter() - Constructor for class org.apache.lucene.search.highlight.NullFragmenter
-
- NullInfoStream - Class in org.apache.lucene.util
-
Prints nothing.
- NullInfoStream() - Constructor for class org.apache.lucene.util.NullInfoStream
-
- NullReader(int) - Constructor for class org.apache.lucene.util.packed.PackedInts.NullReader
-
Sole constructor.
- NUM - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- NUM - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Numeric token type
- NUM - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Numeric token type
- NUM_BYTES_ARRAY_HEADER - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
Number of bytes to represent an array header (no content, but with alignments).
- NUM_BYTES_BOOLEAN - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_BYTES_BYTE - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_BYTES_CHAR - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_BYTES_DOUBLE - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_BYTES_FLOAT - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_BYTES_INT - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_BYTES_LONG - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_BYTES_OBJECT_ALIGNMENT - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
A constant specifying the object alignment boundary inside the JVM.
- NUM_BYTES_OBJECT_HEADER - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
Number of bytes to represent an object header (no fields, no alignments).
- NUM_BYTES_OBJECT_REF - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
Number of bytes this JVM uses to represent an object reference.
- NUM_BYTES_SHORT - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
- NUM_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- numArcs - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- numArcs - Variable in class org.apache.lucene.util.fst.FST.Arc
-
How many arcs in the array; only valid if bytesPerArc != 0.
- numBadSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
-
How many bad segments were found.
- NUMBER - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
ASCII Alphanumeric
- number - Variable in class org.apache.lucene.index.FieldInfo
-
Internal field number
- NUMBER - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- NUMBER - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- NUMBER - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- NUMBER_CHAR_ARRAY - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
- NUMBER_CLASS_NOT_SUPPORTED_BY_NUMERIC_RANGE_QUERY - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- NumberBuffer(String) - Constructor for class org.apache.lucene.analysis.ja.JapaneseNumberFilter.NumberBuffer
-
- NumberDateFormat - Class in org.apache.lucene.queryparser.flexible.standard.config
-
This Format
parses Long
into date strings and vice-versa.
- NumberDateFormat(DateFormat) - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.NumberDateFormat
-
- numberOfDocuments - Variable in class org.apache.lucene.search.similarities.BasicStats
-
The number of documents.
- numberOfFieldTokens - Variable in class org.apache.lucene.search.similarities.BasicStats
-
The total number of tokens in the field.
- numberOfSkipLevels - Variable in class org.apache.lucene.codecs.MultiLevelSkipListWriter
-
number of levels in this skip list
- NumberRangePrefixTree - Class in org.apache.lucene.spatial.prefix.tree
-
A SpatialPrefixTree for single-dimensional numbers and number ranges of fixed precision values (not floating point).
- NumberRangePrefixTree(int[]) - Constructor for class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- NumberRangePrefixTree.NRCell - Class in org.apache.lucene.spatial.prefix.tree
-
Most of the PrefixTree implementation is in this one class, which is both
the Cell, the CellIterator, and the Shape to reduce object allocation.
- NumberRangePrefixTree.NRShape - Interface in org.apache.lucene.spatial.prefix.tree
-
Base interface for Shape
s this prefix tree supports.
- NumberRangePrefixTree.SpanUnitsNRShape - Class in org.apache.lucene.spatial.prefix.tree
-
- NumberRangePrefixTree.UnitNRShape - Interface in org.apache.lucene.spatial.prefix.tree
-
A unit value Shape implemented as a stack of numbers, one for each level in the prefix tree.
- NumberRangePrefixTreeStrategy - Class in org.apache.lucene.spatial.prefix
-
A PrefixTree based on Number/Date ranges.
- NumberRangePrefixTreeStrategy(NumberRangePrefixTree, String) - Constructor for class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy
-
- NumberRangePrefixTreeStrategy.Facets - Class in org.apache.lucene.spatial.prefix
-
Facet response information
- NumberRangePrefixTreeStrategy.Facets.FacetParentVal - Class in org.apache.lucene.spatial.prefix
-
Holds a block of detailLevel counts aggregated to their parent level.
- numBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- numBufferedBlocks() - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- numBuffers() - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
- numDataDims - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
How many dimensions we are storing at the leaf (data) nodes
- numDataNodes() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the number of nodes in the trie that have non-null data.
- numDataNodes(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the number of nodes in the subtrie below and including the starting
node.
- numDeleted - Variable in class org.apache.lucene.index.CheckIndex.Status.LiveDocStatus
-
Number of deleted documents.
- numDeletedDocs(SegmentCommitInfo) - Method in class org.apache.lucene.index.BaseMergePolicyTestCase.MockMergeContext
-
- numDeletedDocs() - Method in class org.apache.lucene.index.IndexReader
-
Returns the number of deleted documents.
- numDeletedDocs(SegmentCommitInfo) - Method in class org.apache.lucene.index.IndexWriter
-
Obtain the number of deleted docs for a pooled reader.
- numDeletedDocs(SegmentCommitInfo) - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
-
Returns the number of deleted documents in the given segments.
- numDeletedDocs() - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the number of deleted docs in the index
- numDeletesToMerge(SegmentCommitInfo) - Method in class org.apache.lucene.index.BaseMergePolicyTestCase.MockMergeContext
-
- numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.FilterMergePolicy
-
- numDeletesToMerge(SegmentCommitInfo) - Method in class org.apache.lucene.index.IndexWriter
-
Returns the number of deletes a merge would claim back if the given segment is merged.
- numDeletesToMerge(SegmentCommitInfo) - Method in interface org.apache.lucene.index.MergePolicy.MergeContext
-
Returns the number of deletes a merge would claim back if the given segment is merged.
- numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.MergePolicy
-
Returns the number of deletes that a merge would claim on the given segment.
- numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.NoMergePolicy
-
- numDeletesToMerge(SegmentCommitInfo, int, IOSupplier<CodecReader>) - Method in class org.apache.lucene.index.SoftDeletesRetentionMergePolicy
-
- numDimensions() - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- numDocs() - Method in class org.apache.lucene.index.AllDeletedFilterReader
-
- numDocs() - Method in class org.apache.lucene.index.BaseCompositeReader
-
- numDocs() - Method in class org.apache.lucene.index.FilterCodecReader
-
- numDocs() - Method in class org.apache.lucene.index.FilterLeafReader
-
- numDocs() - Method in class org.apache.lucene.index.IndexReader
-
Returns the number of documents in this index.
- numDocs - Variable in class org.apache.lucene.index.IndexWriter.DocStats
-
The total number of docs in this index, including
docs not yet flushed (still in the RAM buffer), and
including deletions.
- numDocs() - Method in class org.apache.lucene.index.IndexWriter
-
- numDocs() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- numDocs() - Method in class org.apache.lucene.index.SegmentReader
-
- numDocs() - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the index's numDocs
- numDocs() - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- numDocs - Variable in class org.apache.lucene.store.FlushInfo
-
- numDocsToCollect - Variable in class org.apache.lucene.search.EarlyTerminatingSortingCollector
-
Deprecated.
Number of documents to collect in each segment
- NumDocsValueSource - Class in org.apache.lucene.queries.function.valuesource
-
- NumDocsValueSource() - Constructor for class org.apache.lucene.queries.function.valuesource.NumDocsValueSource
-
- NUMERIC - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- NUMERIC - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- NUMERIC_CANNOT_BE_EMPTY - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Numbers
- NUMERIC_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Numbers
- NumericComparator(String, T) - Constructor for class org.apache.lucene.search.FieldComparator.NumericComparator
-
- numericConfig - Variable in class org.apache.lucene.queryparser.flexible.standard.nodes.PointRangeQueryNode
-
- NumericDocValues - Class in org.apache.lucene.index
-
A per-document numeric value.
- NumericDocValues() - Constructor for class org.apache.lucene.index.NumericDocValues
-
Sole constructor.
- NumericDocValuesField - Class in org.apache.lucene.document
-
Field that stores a per-document long
value for scoring,
sorting or value retrieval.
- NumericDocValuesField(String, long) - Constructor for class org.apache.lucene.document.NumericDocValuesField
-
Creates a new DocValues field with the specified 64-bit long value
- NumericDocValuesField(String, Long) - Constructor for class org.apache.lucene.document.NumericDocValuesField
-
Creates a new DocValues field with the specified 64-bit long value
- NumericDocValuesStats(String, T, T) - Constructor for class org.apache.lucene.search.DocValuesStats.NumericDocValuesStats
-
- numericIterable(FieldInfo, DocValuesProducer, int) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- NumericPayloadTokenFilter - Class in org.apache.lucene.analysis.payloads
-
- NumericPayloadTokenFilter(TokenStream, float, String) - Constructor for class org.apache.lucene.analysis.payloads.NumericPayloadTokenFilter
-
- NumericPayloadTokenFilterFactory - Class in org.apache.lucene.analysis.payloads
-
- NumericPayloadTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.payloads.NumericPayloadTokenFilterFactory
-
Creates a new NumericPayloadTokenFilterFactory
- NumericUtils - Class in org.apache.lucene.util
-
Helper APIs to encode numeric values as sortable bytes and vice-versa.
- numericValue() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- numericValue() - Method in class org.apache.lucene.document.BigIntegerPoint
-
- numericValue() - Method in class org.apache.lucene.document.DoublePoint
-
- numericValue() - Method in class org.apache.lucene.document.Field
-
- numericValue() - Method in class org.apache.lucene.document.FloatPoint
-
- numericValue() - Method in class org.apache.lucene.document.HalfFloatPoint
-
- numericValue() - Method in class org.apache.lucene.document.IntPoint
-
- numericValue() - Method in class org.apache.lucene.document.LazyDocument.LazyField
-
- numericValue() - Method in class org.apache.lucene.document.LongPoint
-
- numericValue() - Method in interface org.apache.lucene.index.IndexableField
-
Non-null if this field has a numeric value
- numFiles - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Number of files referenced by this segment.
- numHits() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Specify the number of hits to retrieve.
- numHoles() - Method in class org.apache.lucene.geo.Polygon
-
returns the number of holes for the polygon
- numIndexDims - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
How many dimensions we are indexing in the internal nodes
- numNodes() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the total number of nodes in the trie.
- numNodes(JaspellTernarySearchTrie.TSTNode) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns the total number of nodes in the subtrie below and including the
starting Node.
- numOrd() - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- numOrd() - Method in class org.apache.lucene.queries.function.FunctionValues
-
- numPoints() - Method in class org.apache.lucene.geo.Line
-
returns the number of vertex points
- numPoints() - Method in class org.apache.lucene.geo.Polygon
-
returns the number of vertex points
- numRamDocs() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: Return the number of documents currently
buffered in RAM.
- numSegments - Variable in class org.apache.lucene.index.CheckIndex.Status
-
Number of segments in the index.
- numSegs - Variable in class org.apache.lucene.index.PerThreadPKLookup
-
- NYNORSK - Static variable in class org.apache.lucene.analysis.no.NorwegianLightStemmer
-
Constant to remove Nynorsk-specific endings
- object - Variable in class org.apache.lucene.util.RefCount
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.docvalues.StrDocValues
-
- objectVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
Native Java Object representation of the value
- obtainFile(String, String, String) - Method in class org.apache.lucene.replicator.http.HttpReplicator
-
- obtainFile(String, String, String) - Method in class org.apache.lucene.replicator.LocalReplicator
-
- obtainFile(String, String, String) - Method in interface org.apache.lucene.replicator.Replicator
-
Returns an
InputStream
for the requested file and source in the
context of the given
session
.
- obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.FSLockFactory
-
Implement this method to obtain a lock for a FSDirectory instance.
- obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.NativeFSLockFactory
-
- obtainFSLock(FSDirectory, String) - Method in class org.apache.lucene.store.SimpleFSLockFactory
-
- obtainLock(String) - Method in class org.apache.lucene.store.BaseDirectory
-
- obtainLock(String) - Method in class org.apache.lucene.store.Directory
-
Acquires and returns a
Lock
for a file with the given name.
- obtainLock(String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- obtainLock(String) - Method in class org.apache.lucene.store.FilterDirectory
-
- obtainLock(Directory, String) - Method in class org.apache.lucene.store.FSLockFactory
-
- obtainLock(Directory, String) - Method in class org.apache.lucene.store.LockFactory
-
Return a new obtained Lock instance identified by lockName.
- obtainLock(String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- obtainLock(Directory, String) - Method in class org.apache.lucene.store.NoLockFactory
-
- obtainLock(Directory, String) - Method in class org.apache.lucene.store.SingleInstanceLockFactory
-
- obtainLock(String) - Method in class org.apache.lucene.store.SleepingLockWrapper
-
- obtainLock(Directory, String) - Method in class org.apache.lucene.store.VerifyingLockFactory
-
- of(List<T>, int, boolean) - Static method in class org.apache.lucene.index.DocIDMerger
-
Construct this from the provided subs, specifying the maximum sub count
- of(List<T>, boolean) - Static method in class org.apache.lucene.index.DocIDMerger
-
Construct this from the provided subs
- of(DocIdSetIterator, int) - Static method in class org.apache.lucene.util.BitSet
-
- of(IndexInput, int, int, long, boolean) - Static method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
-
Sole constructor.
- OfflinePointReader - Class in org.apache.lucene.util.bkd
-
Reads points from disk in a fixed-with format, previously written with
OfflinePointWriter
.
- OfflinePointReader(Directory, String, int, long, long, boolean, boolean) - Constructor for class org.apache.lucene.util.bkd.OfflinePointReader
-
- OfflinePointWriter - Class in org.apache.lucene.util.bkd
-
Writes points to disk in a fixed-with format.
- OfflinePointWriter(Directory, String, int, boolean, String, long, boolean) - Constructor for class org.apache.lucene.util.bkd.OfflinePointWriter
-
Create a new writer with an unknown number of incoming points
- OfflinePointWriter(Directory, String, int, long, boolean, boolean) - Constructor for class org.apache.lucene.util.bkd.OfflinePointWriter
-
- OfflineSorter - Class in org.apache.lucene.util
-
On-disk sorting of byte arrays.
- OfflineSorter(Directory, String) - Constructor for class org.apache.lucene.util.OfflineSorter
-
Defaults constructor.
- OfflineSorter(Directory, String, Comparator<BytesRef>) - Constructor for class org.apache.lucene.util.OfflineSorter
-
Defaults constructor with a custom comparator.
- OfflineSorter(Directory, String, Comparator<BytesRef>, OfflineSorter.BufferSize, int, int, ExecutorService, int) - Constructor for class org.apache.lucene.util.OfflineSorter
-
All-details constructor.
- OfflineSorter.BufferSize - Class in org.apache.lucene.util
-
A bit more descriptive unit for constructors.
- OfflineSorter.ByteSequencesReader - Class in org.apache.lucene.util
-
Utility class to read length-prefixed byte[] entries from an input.
- OfflineSorter.ByteSequencesWriter - Class in org.apache.lucene.util
-
Utility class to emit length-prefixed byte[] entries to an output stream for sorting.
- OfflineSorter.SortInfo - Class in org.apache.lucene.util
-
Sort info (debugging mostly).
- offlineSorterBufferMB - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
How much heap OfflineSorter is allowed to use
- offlineSorterMaxTempFiles - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
How much heap OfflineSorter is allowed to use
- offset - Variable in class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
accumulated offset of previous buffers for this reader, for offsetAtt
- offset - Variable in class org.apache.lucene.util.BytesRef
-
Offset of first valid byte.
- offset - Variable in class org.apache.lucene.util.CharsRef
-
Offset of first valid character.
- offset - Variable in class org.apache.lucene.util.IntsRef
-
Offset of first valid integer.
- offset - Variable in class org.apache.lucene.util.LongsRef
-
Offset of first valid long.
- offsetAtt - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- offsetAtt - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- OffsetAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
The start and end character offset of a Token.
- OffsetAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- OffsetAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-
Initialize this attribute with startOffset and endOffset of 0.
- OffsetLimitTokenFilter - Class in org.apache.lucene.search.highlight
-
This TokenFilter limits the number of tokens while indexing by adding up the
current offset.
- OffsetLimitTokenFilter(TokenStream, int) - Constructor for class org.apache.lucene.search.highlight.OffsetLimitTokenFilter
-
- offsets - Variable in class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader.CachedOrds
-
- OFFSETS - Static variable in class org.apache.lucene.index.PostingsEnum
-
- OffsetsEnum - Class in org.apache.lucene.search.uhighlight
-
- OffsetsEnum() - Constructor for class org.apache.lucene.search.uhighlight.OffsetsEnum
-
- OffsetsEnum.MultiOffsetsEnum - Class in org.apache.lucene.search.uhighlight
-
A view over several OffsetsEnum instances, merging them in-place
- OffsetsEnum.OfMatchesIterator - Class in org.apache.lucene.search.uhighlight
-
- OffsetsEnum.OfMatchesIteratorWithSubs - Class in org.apache.lucene.search.uhighlight
-
- OffsetsEnum.OfPostings - Class in org.apache.lucene.search.uhighlight
-
- OfMatchesIterator(MatchesIterator, Supplier<BytesRef>) - Constructor for class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIterator
-
- OfMatchesIteratorWithSubs(MatchesIterator) - Constructor for class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIteratorWithSubs
-
- OfPostings(BytesRef, int, PostingsEnum) - Constructor for class org.apache.lucene.search.uhighlight.OffsetsEnum.OfPostings
-
- OfPostings(BytesRef, PostingsEnum) - Constructor for class org.apache.lucene.search.uhighlight.OffsetsEnum.OfPostings
-
- OK_PREFIX - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
- OLD_SEGMENTS_GEN - Static variable in class org.apache.lucene.index.IndexFileNames
-
Name of the generation reference file name
- omitNorms() - Method in class org.apache.lucene.document.FieldType
-
True if normalization values should be omitted for the field.
- omitNorms() - Method in interface org.apache.lucene.index.IndexableFieldType
-
True if normalization values should be omitted for the field.
- omitsNorms() - Method in class org.apache.lucene.index.FieldInfo
-
Returns true if norms are explicitly omitted for this field
- onceDone - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- onClear() - Method in class org.apache.lucene.search.LRUQueryCache
-
Expert: callback when the cache is completely cleared.
- onClose(IndexReader.CacheKey) - Method in interface org.apache.lucene.index.IndexReader.ClosedListener
-
Invoked when the resource (segment core, or index reader) that is
being cached on is closed.
- onClose() - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
Override to trigger some behavior when the filesystem is closed.
- onClose(Path, Object) - Method in class org.apache.lucene.mockfile.HandleLimitFS
-
- onClose(Path, Object) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
Called when path
is closed via stream
.
- onClose(Path, Object) - Method in class org.apache.lucene.mockfile.LeakFS
-
- onClose() - Method in class org.apache.lucene.mockfile.LeakFS
-
- onClose(Path, Object) - Method in class org.apache.lucene.mockfile.WindowsFS
-
- onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.IndexDeletionPolicy
-
This is called each time the writer completed a commit.
- onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
-
Deletes all commits except the most recent one.
- onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.NoDeletionPolicy
-
- onCommit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
- onCompare(byte[], byte[]) - Method in class org.apache.lucene.index.PointsStackTracker
-
- onDocIdSetCache(Object, long) - Method in class org.apache.lucene.search.LRUQueryCache
-
Expert: callback when a
DocIdSet
is added to this cache.
- onDocIdSetEviction(Object, int, long) - Method in class org.apache.lucene.search.LRUQueryCache
-
Expert: callback when one or more
DocIdSet
s are removed from this
cache.
- ONE_GB - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
One gigabyte bytes.
- ONE_KB - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
One kilobyte bytes.
- ONE_MB - Static variable in class org.apache.lucene.util.RamUsageEstimator
-
One megabyte bytes.
- OneMerge(List<SegmentCommitInfo>) - Constructor for class org.apache.lucene.index.MergePolicy.OneMerge
-
Sole constructor.
- OneMergeProgress() - Constructor for class org.apache.lucene.index.MergePolicy.OneMergeProgress
-
Creates a new merge progress info.
- OneMergeWrappingMergePolicy - Class in org.apache.lucene.index
-
A wrapping merge policy that wraps the
MergePolicy.OneMerge
objects returned by the wrapped merge policy.
- OneMergeWrappingMergePolicy(MergePolicy, UnaryOperator<MergePolicy.OneMerge>) - Constructor for class org.apache.lucene.index.OneMergeWrappingMergePolicy
-
Constructor
- onHit(Object, Query) - Method in class org.apache.lucene.search.LRUQueryCache
-
Expert: callback when there is a cache hit on a given query.
- onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.IndexDeletionPolicy
-
This is called once when a writer is first
instantiated to give the policy a chance to remove old
commit points.
- onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.KeepOnlyLastCommitDeletionPolicy
-
Deletes all commits except the most recent one.
- onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.NoDeletionPolicy
-
- onInit(List<? extends IndexCommit>) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
- ONLY_FIRST_WORD - Static variable in class org.apache.lucene.analysis.miscellaneous.CapitalizationFilterFactory
-
- onlyLongestMatch - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- onMiss(Object, Query) - Method in class org.apache.lucene.search.LRUQueryCache
-
Expert: callback when there is a cache miss on a given query.
- onOpen(Path, Object) - Method in class org.apache.lucene.mockfile.HandleLimitFS
-
- onOpen(Path, Object) - Method in class org.apache.lucene.mockfile.HandleTrackingFS
-
Called when path
is opened via stream
.
- onOpen(Path, Object) - Method in class org.apache.lucene.mockfile.LeakFS
-
- onOpen(Path, Object) - Method in class org.apache.lucene.mockfile.WindowsFS
-
- onOrAfter(Version) - Method in class org.apache.lucene.util.Version
-
Returns true if this version is the same or after the version from the argument.
- onQueryCache(Query, long) - Method in class org.apache.lucene.search.LRUQueryCache
-
Expert: callback when a query is added to this cache.
- onQueryEviction(Query, long) - Method in class org.apache.lucene.search.LRUQueryCache
-
Expert: callback when a query is evicted from this cache.
- onUse(Query) - Method in interface org.apache.lucene.search.QueryCachingPolicy
-
Callback that is called every time that a cached filter is used.
- onUse(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
-
- OP - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
Get a textual summary of the benchmark results, average from all test runs.
- OP_COLON - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OP_EQUAL - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OP_LESSTHAN - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OP_LESSTHANEQ - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OP_MORETHAN - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OP_MORETHANEQ - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OpaqueQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
OpaqueQueryNode
is used for specify values that are not supposed to
be parsed by the parser.
- OpaqueQueryNode(CharSequence, CharSequence) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.OpaqueQueryNode
-
- open(Reader) - Static method in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- open(Reader) - Static method in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- open(Directory) - Static method in class org.apache.lucene.index.DirectoryReader
-
Returns a IndexReader reading the index in the given
Directory
- open(IndexWriter) - Static method in class org.apache.lucene.index.DirectoryReader
-
Open a near real time IndexReader from the
IndexWriter
.
- open(IndexWriter, boolean, boolean) - Static method in class org.apache.lucene.index.DirectoryReader
-
Expert: open a near real time IndexReader from the
IndexWriter
,
controlling whether past deletions should be applied.
- open(IndexCommit) - Static method in class org.apache.lucene.index.DirectoryReader
-
Expert: returns an IndexReader reading the index in the given
IndexCommit
.
- open(Directory, SegmentInfos, List<? extends LeafReader>) - Static method in class org.apache.lucene.index.StandardDirectoryReader
-
- open(String, String) - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- open(String, String) - Method in class org.apache.lucene.replicator.IndexRevision
-
- open(String, String) - Method in interface org.apache.lucene.replicator.Revision
-
Returns an
IndexInput
for the given fileName and source.
- open(Path) - Static method in class org.apache.lucene.store.FSDirectory
-
Creates an FSDirectory instance, trying to pick the
best implementation given the current environment.
- open(Path, LockFactory) - Static method in class org.apache.lucene.store.FSDirectory
-
- open_direct(String, boolean) - Static method in class org.apache.lucene.store.NativePosixUtil
-
- OPEN_RANGE_TOKEN - Static variable in class org.apache.lucene.queryparser.flexible.standard.processors.OpenRangeQueryNodeProcessor
-
- openChecksumInput(String, IOContext) - Method in class org.apache.lucene.store.Directory
-
Opens a checksum-computing stream for reading an existing file.
- openChecksumInput(String, IOContext) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- openChecksumInput(String, IOContext) - Method in class org.apache.lucene.store.RawDirectoryWrapper
-
- openIfChanged(T) - Static method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
If the taxonomy has changed since the provided reader was opened, open and
return a new
TaxonomyReader
; else, return
null
.
- openIfChanged(DirectoryReader) - Static method in class org.apache.lucene.index.DirectoryReader
-
If the index has changed since the provided reader was
opened, open and return a new reader; else, return
null.
- openIfChanged(DirectoryReader, IndexCommit) - Static method in class org.apache.lucene.index.DirectoryReader
-
If the IndexCommit differs from what the
provided reader is searching, open and return a new
reader; else, return null.
- openIfChanged(DirectoryReader, IndexWriter) - Static method in class org.apache.lucene.index.DirectoryReader
-
Expert: If there changes (committed or not) in the
IndexWriter
versus what the provided reader is
searching, then open and return a new
IndexReader searching both committed and uncommitted
changes from the writer; else, return null (though, the
current implementation never returns null).
- openIfChanged(DirectoryReader, IndexWriter, boolean) - Static method in class org.apache.lucene.index.DirectoryReader
-
Expert: Opens a new reader, if there are any changes, controlling whether past deletions should be applied.
- openIndexReader(Directory) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- openIndexReader(IndexWriter) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- OpenIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Open an index writer.
- OpenIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
-
- openIndexWriter(Directory, IndexWriterConfig) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Open internal index writer, which contains the taxonomy data.
- openIndexWriter(Directory, IndexWriterConfig) - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.Directory
-
Opens a stream for reading an existing file.
- openInput(String, IOContext) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.FilterDirectory
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.MMapDirectory
-
Creates an IndexInput for the file with the given name.
- openInput(String, IOContext) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.NativeUnixDirectory
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.NIOFSDirectory
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- openInput(String, IOContext) - Method in class org.apache.lucene.store.RAFDirectory
-
Creates an IndexInput for the file with the given name.
- openInput(String, IOContext) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
Returns a stream reading an existing file.
- openInput(String, IOContext) - Method in class org.apache.lucene.store.SimpleFSDirectory
-
Creates an IndexInput for the file with the given name.
- openInput(String, IOContext) - Method in class org.apache.lucene.store.WindowsDirectory
-
- openInputStream() - Method in class org.apache.lucene.benchmark.byTask.feeds.EnwikiContentSource
-
Open the input stream.
- openMode - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- OpenRangeQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- OpenRangeQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.OpenRangeQueryNodeProcessor
-
- openReaderPassed - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
True if we were able to open a CodecReader on this
segment.
- OpenReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Open an index reader.
- OpenReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.OpenReaderTask
-
- openResource(String) - Method in class org.apache.lucene.analysis.util.ClasspathResourceLoader
-
- openResource(String) - Method in class org.apache.lucene.analysis.util.FilesystemResourceLoader
-
- openResource(String) - Method in interface org.apache.lucene.analysis.util.ResourceLoader
-
Opens a named resource
- OpenStringBuilder - Class in org.apache.lucene.analysis.util
-
A StringBuilder that allows one to access the array.
- OpenStringBuilder() - Constructor for class org.apache.lucene.analysis.util.OpenStringBuilder
-
- OpenStringBuilder(int) - Constructor for class org.apache.lucene.analysis.util.OpenStringBuilder
-
- OpenStringBuilder(char[], int) - Constructor for class org.apache.lucene.analysis.util.OpenStringBuilder
-
- OpenTaxonomyIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Open a taxonomy index.
- OpenTaxonomyIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.OpenTaxonomyIndexTask
-
- OpenTaxonomyReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Open a taxonomy index reader.
- OpenTaxonomyReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.OpenTaxonomyReaderTask
-
- operation - Variable in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- Operations - Class in org.apache.lucene.util.automaton
-
Automata operations.
- opName - Variable in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- optB(Query) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO: Wraps a Query in a BooleanQuery so that it is optional, along
with a second prohibited clause which will never match anything
- optimize(Trie) - Method in class org.egothor.stemmer.Gener
-
Return a Trie with infrequent values occurring in the given Trie removed.
- optimize(Trie) - Method in class org.egothor.stemmer.Lift
-
Optimize (eliminate rows with no content) the given Trie and return the
reduced Trie.
- optimize(Trie) - Method in class org.egothor.stemmer.Optimizer
-
Optimize (remove empty rows) from the given Trie and return the resulting
Trie.
- optimize(Trie) - Method in class org.egothor.stemmer.Reduce
-
Optimize (remove holes in the rows) the given Trie and return the
restructured Trie.
- Optimizer - Class in org.egothor.stemmer
-
The Optimizer class is a Trie that will be reduced (have empty rows removed).
- Optimizer() - Constructor for class org.egothor.stemmer.Optimizer
-
Constructor for the Optimizer object.
- Optimizer2 - Class in org.egothor.stemmer
-
The Optimizer class is a Trie that will be reduced (have empty rows removed).
- Optimizer2() - Constructor for class org.egothor.stemmer.Optimizer2
-
Constructor for the Optimizer2 object.
- optional(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton that accepts the union of the empty string and the
language of the given automaton.
- OptionalFields() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- OptionalWeights(SrndQuery) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- Options() - Constructor for class org.apache.lucene.index.CheckIndex.Options
-
Sole constructor.
- OR - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- OR - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- OR - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- or(IntervalsSource...) - Static method in class org.apache.lucene.search.intervals.Intervals
-
- or(DocIdSetIterator) - Method in class org.apache.lucene.util.BitSet
-
Does in-place OR of the bits provided by the iterator.
- or(DocIdSetIterator) - Method in class org.apache.lucene.util.FixedBitSet
-
- or(FixedBitSet) - Method in class org.apache.lucene.util.FixedBitSet
-
this = this OR other
- or(LongBitSet) - Method in class org.apache.lucene.util.LongBitSet
-
this = this OR other
- or(DocIdSetIterator) - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- OR_OPERATOR - Static variable in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Alternative form of QueryParser.Operator.OR
- OR_OPERATOR - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables OR
operator (|)
- ord() - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase.FieldIndexEnum
-
- ord() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- ord() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- ord - Variable in class org.apache.lucene.facet.TopOrdAndFloatQueue.OrdAndValue
-
Ordinal of the entry.
- ord - Variable in class org.apache.lucene.facet.TopOrdAndIntQueue.OrdAndValue
-
Ordinal of the entry.
- ord() - Method in class org.apache.lucene.index.FilteredTermsEnum
-
- ord() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- ord - Variable in class org.apache.lucene.index.LeafReaderContext
-
The reader's ord in the top-level's leaves array
- ord() - Method in class org.apache.lucene.index.MultiTermsEnum
-
- ord - Variable in class org.apache.lucene.index.OrdTermState
-
Term ordinal, i.e.
- ord() - Method in class org.apache.lucene.index.TermsEnum
-
Returns ordinal position for current term.
- ord - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- ord() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- ord() - Method in class org.apache.lucene.util.bkd.HeapPointReader
-
- ord() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
-
- ord() - Method in class org.apache.lucene.util.bkd.PointReader
-
Point ordinal
- ord() - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
-
Return the offset of the next value to read.
- ord() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
-
Returns the current position
- ord() - Method in class org.apache.lucene.util.packed.PackedInts.Writer
-
Returns the current ord in the stream (number of values that have been
written so far minus one).
- OrdAndValue() - Constructor for class org.apache.lucene.facet.TopOrdAndFloatQueue.OrdAndValue
-
Default constructor.
- OrdAndValue() - Constructor for class org.apache.lucene.facet.TopOrdAndIntQueue.OrdAndValue
-
Default constructor.
- ordered(IntervalsSource...) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Create an ordered
IntervalsSource
Returns intervals in which the subsources all appear in the given order
- orderedGroups - Variable in class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
- OrdinalMap - Class in org.apache.lucene.index
-
Maps per-segment ordinals to/from global ordinal space, using a compact packed-ints representation.
- OrdinalMappingLeafReader - Class in org.apache.lucene.facet.taxonomy
-
A
FilterLeafReader
for updating facets ordinal references,
based on an ordinal map.
- OrdinalMappingLeafReader(LeafReader, int[], FacetsConfig) - Constructor for class org.apache.lucene.facet.taxonomy.OrdinalMappingLeafReader
-
Wraps an LeafReader, mapping ordinals according to the ordinalMap, using
the provided
FacetsConfig
which was used to build the wrapped
reader.
- ordinals - Variable in class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader.CachedOrds
-
Holds ords for all docs.
- OrdinalsReader - Class in org.apache.lucene.facet.taxonomy
-
Provides per-document ordinals.
- OrdinalsReader() - Constructor for class org.apache.lucene.facet.taxonomy.OrdinalsReader
-
Default constructor.
- OrdinalsReader.OrdinalsSegmentReader - Class in org.apache.lucene.facet.taxonomy
-
Returns ordinals for documents in one segment.
- OrdinalsSegmentReader() - Constructor for class org.apache.lucene.facet.taxonomy.OrdinalsReader.OrdinalsSegmentReader
-
Default constructor.
- ordInParent - Variable in class org.apache.lucene.index.IndexReaderContext
-
the ord for this reader in the parent, 0 if parent is null
- OrdRange(int, int) - Constructor for class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState.OrdRange
-
Start and end are inclusive.
- ords - Variable in class org.apache.lucene.util.bkd.HeapPointWriter
-
- OrdsBlockTreeTermsReader - Class in org.apache.lucene.codecs.blocktreeords
-
- OrdsBlockTreeTermsReader(PostingsReaderBase, SegmentReadState) - Constructor for class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
Sole constructor.
- OrdsBlockTreeTermsWriter - Class in org.apache.lucene.codecs.blocktreeords
-
This is just like
BlockTreeTermsWriter
, except it also stores a version per term, and adds a method to its TermsEnum
implementation to seekExact only if the version is >= the specified version.
- OrdsBlockTreeTermsWriter(SegmentWriteState, PostingsWriterBase, int, int) - Constructor for class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsWriter
-
Create a new writer.
- ordsLong - Variable in class org.apache.lucene.util.bkd.HeapPointWriter
-
- OrdsSegmentTermsEnum - Class in org.apache.lucene.codecs.blocktreeords
-
Iterates through terms in this field.
- OrdTermState - Class in org.apache.lucene.index
-
- OrdTermState() - Constructor for class org.apache.lucene.index.OrdTermState
-
Sole constructor.
- ordVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- ordVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- ordValue() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingSortedDocValues
-
- ordValue() - Method in class org.apache.lucene.index.LegacySortedDocValuesWrapper
-
Deprecated.
- ordValue() - Method in class org.apache.lucene.index.MultiDocValues.MultiSortedDocValues
-
- ordValue() - Method in class org.apache.lucene.index.SortedDocValues
-
Returns the ordinal for the current docID.
- org.apache.lucene - package org.apache.lucene
-
Top-level package.
- org.apache.lucene.analysis - package org.apache.lucene.analysis
-
Text analysis.
- org.apache.lucene.analysis.ar - package org.apache.lucene.analysis.ar
-
Analyzer for Arabic.
- org.apache.lucene.analysis.bg - package org.apache.lucene.analysis.bg
-
Analyzer for Bulgarian.
- org.apache.lucene.analysis.bn - package org.apache.lucene.analysis.bn
-
Analyzer for Bengali Language.
- org.apache.lucene.analysis.br - package org.apache.lucene.analysis.br
-
Analyzer for Brazilian Portuguese.
- org.apache.lucene.analysis.ca - package org.apache.lucene.analysis.ca
-
Analyzer for Catalan.
- org.apache.lucene.analysis.charfilter - package org.apache.lucene.analysis.charfilter
-
Normalization of text before the tokenizer.
- org.apache.lucene.analysis.cjk - package org.apache.lucene.analysis.cjk
-
Analyzer for Chinese, Japanese, and Korean, which indexes bigrams.
- org.apache.lucene.analysis.ckb - package org.apache.lucene.analysis.ckb
-
Analyzer for Sorani Kurdish.
- org.apache.lucene.analysis.cn.smart - package org.apache.lucene.analysis.cn.smart
-
Analyzer for Simplified Chinese, which indexes words.
- org.apache.lucene.analysis.cn.smart.hhmm - package org.apache.lucene.analysis.cn.smart.hhmm
-
SmartChineseAnalyzer Hidden Markov Model package.
- org.apache.lucene.analysis.commongrams - package org.apache.lucene.analysis.commongrams
-
Construct n-grams for frequently occurring terms and phrases.
- org.apache.lucene.analysis.compound - package org.apache.lucene.analysis.compound
-
A filter that decomposes compound words you find in many Germanic
languages into the word parts.
- org.apache.lucene.analysis.compound.hyphenation - package org.apache.lucene.analysis.compound.hyphenation
-
Hyphenation code for the CompoundWordTokenFilter.
- org.apache.lucene.analysis.core - package org.apache.lucene.analysis.core
-
Basic, general-purpose analysis components.
- org.apache.lucene.analysis.custom - package org.apache.lucene.analysis.custom
-
A general-purpose Analyzer that can be created with a builder-style API.
- org.apache.lucene.analysis.cz - package org.apache.lucene.analysis.cz
-
Analyzer for Czech.
- org.apache.lucene.analysis.da - package org.apache.lucene.analysis.da
-
Analyzer for Danish.
- org.apache.lucene.analysis.de - package org.apache.lucene.analysis.de
-
Analyzer for German.
- org.apache.lucene.analysis.el - package org.apache.lucene.analysis.el
-
Analyzer for Greek.
- org.apache.lucene.analysis.en - package org.apache.lucene.analysis.en
-
Analyzer for English.
- org.apache.lucene.analysis.es - package org.apache.lucene.analysis.es
-
Analyzer for Spanish.
- org.apache.lucene.analysis.eu - package org.apache.lucene.analysis.eu
-
Analyzer for Basque.
- org.apache.lucene.analysis.fa - package org.apache.lucene.analysis.fa
-
Analyzer for Persian.
- org.apache.lucene.analysis.fi - package org.apache.lucene.analysis.fi
-
Analyzer for Finnish.
- org.apache.lucene.analysis.fr - package org.apache.lucene.analysis.fr
-
Analyzer for French.
- org.apache.lucene.analysis.ga - package org.apache.lucene.analysis.ga
-
Analyzer for Irish.
- org.apache.lucene.analysis.gl - package org.apache.lucene.analysis.gl
-
Analyzer for Galician.
- org.apache.lucene.analysis.hi - package org.apache.lucene.analysis.hi
-
Analyzer for Hindi.
- org.apache.lucene.analysis.hu - package org.apache.lucene.analysis.hu
-
Analyzer for Hungarian.
- org.apache.lucene.analysis.hunspell - package org.apache.lucene.analysis.hunspell
-
- org.apache.lucene.analysis.hy - package org.apache.lucene.analysis.hy
-
Analyzer for Armenian.
- org.apache.lucene.analysis.icu - package org.apache.lucene.analysis.icu
-
Analysis components based on ICU
- org.apache.lucene.analysis.icu.segmentation - package org.apache.lucene.analysis.icu.segmentation
-
Tokenizer that breaks text into words with the Unicode Text Segmentation algorithm.
- org.apache.lucene.analysis.icu.tokenattributes - package org.apache.lucene.analysis.icu.tokenattributes
-
Additional ICU-specific Attributes for text analysis.
- org.apache.lucene.analysis.id - package org.apache.lucene.analysis.id
-
Analyzer for Indonesian.
- org.apache.lucene.analysis.in - package org.apache.lucene.analysis.in
-
Analyzer for Indian languages.
- org.apache.lucene.analysis.it - package org.apache.lucene.analysis.it
-
Analyzer for Italian.
- org.apache.lucene.analysis.ja - package org.apache.lucene.analysis.ja
-
Analyzer for Japanese.
- org.apache.lucene.analysis.ja.dict - package org.apache.lucene.analysis.ja.dict
-
Kuromoji dictionary implementation.
- org.apache.lucene.analysis.ja.tokenattributes - package org.apache.lucene.analysis.ja.tokenattributes
-
Additional Kuromoji-specific Attributes for text analysis.
- org.apache.lucene.analysis.ja.util - package org.apache.lucene.analysis.ja.util
-
Kuromoji utility classes.
- org.apache.lucene.analysis.ko - package org.apache.lucene.analysis.ko
-
Analyzer for Korean.
- org.apache.lucene.analysis.ko.dict - package org.apache.lucene.analysis.ko.dict
-
Korean dictionary implementation.
- org.apache.lucene.analysis.ko.tokenattributes - package org.apache.lucene.analysis.ko.tokenattributes
-
Additional Korean-specific Attributes for text analysis.
- org.apache.lucene.analysis.ko.util - package org.apache.lucene.analysis.ko.util
-
Nori utility classes.
- org.apache.lucene.analysis.lt - package org.apache.lucene.analysis.lt
-
Analyzer for Lithuanian.
- org.apache.lucene.analysis.lv - package org.apache.lucene.analysis.lv
-
Analyzer for Latvian.
- org.apache.lucene.analysis.minhash - package org.apache.lucene.analysis.minhash
-
MinHash filtering (for LSH).
- org.apache.lucene.analysis.miscellaneous - package org.apache.lucene.analysis.miscellaneous
-
Miscellaneous Tokenstreams.
- org.apache.lucene.analysis.morfologik - package org.apache.lucene.analysis.morfologik
-
This package provides dictionary-driven lemmatization ("accurate stemming")
filter and analyzer for the Polish Language, driven by the
Morfologik library developed
by Dawid Weiss and Marcin Miłkowski.
- org.apache.lucene.analysis.ngram - package org.apache.lucene.analysis.ngram
-
Character n-gram tokenizers and filters.
- org.apache.lucene.analysis.nl - package org.apache.lucene.analysis.nl
-
Analyzer for Dutch.
- org.apache.lucene.analysis.no - package org.apache.lucene.analysis.no
-
Analyzer for Norwegian.
- org.apache.lucene.analysis.path - package org.apache.lucene.analysis.path
-
Analysis components for path-like strings such as filenames.
- org.apache.lucene.analysis.pattern - package org.apache.lucene.analysis.pattern
-
Set of components for pattern-based (regex) analysis.
- org.apache.lucene.analysis.payloads - package org.apache.lucene.analysis.payloads
-
Provides various convenience classes for creating payloads on Tokens.
- org.apache.lucene.analysis.phonetic - package org.apache.lucene.analysis.phonetic
-
Analysis components for phonetic search.
- org.apache.lucene.analysis.pl - package org.apache.lucene.analysis.pl
-
Analyzer for Polish.
- org.apache.lucene.analysis.pt - package org.apache.lucene.analysis.pt
-
Analyzer for Portuguese.
- org.apache.lucene.analysis.query - package org.apache.lucene.analysis.query
-
Automatically filter high-frequency stopwords.
- org.apache.lucene.analysis.reverse - package org.apache.lucene.analysis.reverse
-
Filter to reverse token text.
- org.apache.lucene.analysis.ro - package org.apache.lucene.analysis.ro
-
Analyzer for Romanian.
- org.apache.lucene.analysis.ru - package org.apache.lucene.analysis.ru
-
Analyzer for Russian.
- org.apache.lucene.analysis.shingle - package org.apache.lucene.analysis.shingle
-
Word n-gram filters.
- org.apache.lucene.analysis.sinks - package org.apache.lucene.analysis.sinks
-
- org.apache.lucene.analysis.snowball - package org.apache.lucene.analysis.snowball
-
- org.apache.lucene.analysis.sr - package org.apache.lucene.analysis.sr
-
Analyzer for Serbian.
- org.apache.lucene.analysis.standard - package org.apache.lucene.analysis.standard
-
- org.apache.lucene.analysis.stempel - package org.apache.lucene.analysis.stempel
-
Stempel: Algorithmic Stemmer
- org.apache.lucene.analysis.sv - package org.apache.lucene.analysis.sv
-
Analyzer for Swedish.
- org.apache.lucene.analysis.synonym - package org.apache.lucene.analysis.synonym
-
Analysis components for Synonyms.
- org.apache.lucene.analysis.th - package org.apache.lucene.analysis.th
-
Analyzer for Thai.
- org.apache.lucene.analysis.tokenattributes - package org.apache.lucene.analysis.tokenattributes
-
General-purpose attributes for text analysis.
- org.apache.lucene.analysis.tr - package org.apache.lucene.analysis.tr
-
Analyzer for Turkish.
- org.apache.lucene.analysis.uk - package org.apache.lucene.analysis.uk
-
Analyzer for Ukrainian.
- org.apache.lucene.analysis.util - package org.apache.lucene.analysis.util
-
Utility functions for text analysis.
- org.apache.lucene.analysis.wikipedia - package org.apache.lucene.analysis.wikipedia
-
Tokenizer that is aware of Wikipedia syntax.
- org.apache.lucene.benchmark - package org.apache.lucene.benchmark
-
Lucene Benchmarking Package
- org.apache.lucene.benchmark.byTask - package org.apache.lucene.benchmark.byTask
-
Benchmarking Lucene By Tasks
- org.apache.lucene.benchmark.byTask.feeds - package org.apache.lucene.benchmark.byTask.feeds
-
Sources for benchmark inputs: documents and queries.
- org.apache.lucene.benchmark.byTask.programmatic - package org.apache.lucene.benchmark.byTask.programmatic
-
Sample performance test written programmatically - no algorithm file is needed here.
- org.apache.lucene.benchmark.byTask.stats - package org.apache.lucene.benchmark.byTask.stats
-
Statistics maintained when running benchmark tasks.
- org.apache.lucene.benchmark.byTask.tasks - package org.apache.lucene.benchmark.byTask.tasks
-
Extendable benchmark tasks.
- org.apache.lucene.benchmark.byTask.utils - package org.apache.lucene.benchmark.byTask.utils
-
Utilities used for the benchmark, and for the reports.
- org.apache.lucene.benchmark.quality - package org.apache.lucene.benchmark.quality
-
Search Quality Benchmarking.
- org.apache.lucene.benchmark.quality.trec - package org.apache.lucene.benchmark.quality.trec
-
Utilities for Trec related quality benchmarking, feeding from Trec Topics and QRels inputs.
- org.apache.lucene.benchmark.quality.utils - package org.apache.lucene.benchmark.quality.utils
-
Miscellaneous utilities for search quality benchmarking: query parsing, submission reports.
- org.apache.lucene.benchmark.utils - package org.apache.lucene.benchmark.utils
-
Benchmark Utility functions.
- org.apache.lucene.classification - package org.apache.lucene.classification
-
Uses already seen data (the indexed documents) to classify an input ( can be simple text or a structured document).
- org.apache.lucene.classification.document - package org.apache.lucene.classification.document
-
Uses already seen data (the indexed documents) to classify new documents.
- org.apache.lucene.classification.utils - package org.apache.lucene.classification.utils
-
Utilities for evaluation, data preparation, etc.
- org.apache.lucene.codecs - package org.apache.lucene.codecs
-
Codecs API: API for customization of the encoding and structure of the index.
- org.apache.lucene.codecs.asserting - package org.apache.lucene.codecs.asserting
-
Codec for testing that asserts various contracts of the codec apis.
- org.apache.lucene.codecs.blockterms - package org.apache.lucene.codecs.blockterms
-
Pluggable term index / block terms dictionary implementations.
- org.apache.lucene.codecs.blocktree - package org.apache.lucene.codecs.blocktree
-
BlockTree terms dictionary.
- org.apache.lucene.codecs.blocktreeords - package org.apache.lucene.codecs.blocktreeords
-
Same postings format as Lucene50, except the terms dictionary also
supports ords, i.e.
- org.apache.lucene.codecs.bloom - package org.apache.lucene.codecs.bloom
-
Codec PostingsFormat for fast access to low-frequency terms
such as primary key fields.
- org.apache.lucene.codecs.cheapbastard - package org.apache.lucene.codecs.cheapbastard
-
Codec that unreasonably tries to use as little RAM as possible.
- org.apache.lucene.codecs.compressing - package org.apache.lucene.codecs.compressing
-
StoredFieldsFormat that allows cross-document and cross-field compression of stored fields.
- org.apache.lucene.codecs.compressing.dummy - package org.apache.lucene.codecs.compressing.dummy
-
Dummy CompressingCodec implementation used for testing.
- org.apache.lucene.codecs.cranky - package org.apache.lucene.codecs.cranky
-
Codec for testing that throws random IOExceptions
- org.apache.lucene.codecs.idversion - package org.apache.lucene.codecs.idversion
-
A primary-key postings format that associates a version (long) with each term and
can provide fail-fast lookups by ID and version.
- org.apache.lucene.codecs.lucene50 - package org.apache.lucene.codecs.lucene50
-
- org.apache.lucene.codecs.lucene53 - package org.apache.lucene.codecs.lucene53
-
- org.apache.lucene.codecs.lucene54 - package org.apache.lucene.codecs.lucene54
-
Lucene 5.4 file format.
- org.apache.lucene.codecs.lucene60 - package org.apache.lucene.codecs.lucene60
-
Components from the Lucene 6.0 index format.
- org.apache.lucene.codecs.lucene62 - package org.apache.lucene.codecs.lucene62
-
- org.apache.lucene.codecs.lucene70 - package org.apache.lucene.codecs.lucene70
-
Lucene 7.0 file format.
- org.apache.lucene.codecs.memory - package org.apache.lucene.codecs.memory
-
Term dictionary, DocValues or Postings formats that are read
entirely into memory.
- org.apache.lucene.codecs.mockrandom - package org.apache.lucene.codecs.mockrandom
-
Frankenstein codec for testing that pieces together random components.
- org.apache.lucene.codecs.perfield - package org.apache.lucene.codecs.perfield
-
Postings format that can delegate to different formats per-field.
- org.apache.lucene.codecs.ramonly - package org.apache.lucene.codecs.ramonly
-
Codec for testing that never writes to disk.
- org.apache.lucene.codecs.simpletext - package org.apache.lucene.codecs.simpletext
-
Simpletext Codec: writes human readable postings.
- org.apache.lucene.collation - package org.apache.lucene.collation
-
Unicode collation support.
- org.apache.lucene.collation.tokenattributes - package org.apache.lucene.collation.tokenattributes
-
- org.apache.lucene.demo - package org.apache.lucene.demo
-
Demo applications for indexing and searching.
- org.apache.lucene.demo.facet - package org.apache.lucene.demo.facet
-
Facets example code.
- org.apache.lucene.document - package org.apache.lucene.document
-
The logical representation of a
Document
for indexing and searching.
- org.apache.lucene.expressions - package org.apache.lucene.expressions
-
Expressions.
- org.apache.lucene.expressions.js - package org.apache.lucene.expressions.js
-
Javascript expressions.
- org.apache.lucene.facet - package org.apache.lucene.facet
-
Faceted search.
- org.apache.lucene.facet.range - package org.apache.lucene.facet.range
-
Provides range faceting capabilities.
- org.apache.lucene.facet.sortedset - package org.apache.lucene.facet.sortedset
-
- org.apache.lucene.facet.taxonomy - package org.apache.lucene.facet.taxonomy
-
Taxonomy of Categories.
- org.apache.lucene.facet.taxonomy.directory - package org.apache.lucene.facet.taxonomy.directory
-
Taxonomy index implementation using on top of a Directory.
- org.apache.lucene.facet.taxonomy.writercache - package org.apache.lucene.facet.taxonomy.writercache
-
Improves indexing time by caching a map of CategoryPath to their Ordinal.
- org.apache.lucene.geo - package org.apache.lucene.geo
-
Geospatial Utility Implementations for Lucene Core
- org.apache.lucene.index - package org.apache.lucene.index
-
Code to maintain and access indices.
- org.apache.lucene.index.memory - package org.apache.lucene.index.memory
-
High-performance single-document main memory Apache Lucene fulltext search index.
- org.apache.lucene.misc - package org.apache.lucene.misc
-
Miscellaneous index tools.
- org.apache.lucene.mockfile - package org.apache.lucene.mockfile
-
Support for testing/debugging with virtual filesystems
- org.apache.lucene.payloads - package org.apache.lucene.payloads
-
Experimental classes for interacting with payloads
- org.apache.lucene.queries - package org.apache.lucene.queries
-
Filters and Queries that add to core Lucene.
- org.apache.lucene.queries.function - package org.apache.lucene.queries.function
-
Queries that compute score based upon a function.
- org.apache.lucene.queries.function.docvalues - package org.apache.lucene.queries.function.docvalues
-
FunctionValues for different data types.
- org.apache.lucene.queries.function.valuesource - package org.apache.lucene.queries.function.valuesource
-
A variety of functions to use with FunctionQuery.
- org.apache.lucene.queries.mlt - package org.apache.lucene.queries.mlt
-
Document similarity query generators.
- org.apache.lucene.queries.payloads - package org.apache.lucene.queries.payloads
-
The payloads package provides Query mechanisms for finding and using payloads.
- org.apache.lucene.queryparser.classic - package org.apache.lucene.queryparser.classic
-
A simple query parser implemented with JavaCC.
- org.apache.lucene.queryparser.complexPhrase - package org.apache.lucene.queryparser.complexPhrase
-
QueryParser which permits complex phrase query syntax eg "(john jon jonathan~) peters*"
- org.apache.lucene.queryparser.ext - package org.apache.lucene.queryparser.ext
-
Extendable QueryParser provides a simple and flexible extension mechanism by overloading query field names.
- org.apache.lucene.queryparser.flexible.core - package org.apache.lucene.queryparser.flexible.core
-
Core classes of the flexible query parser framework.
- org.apache.lucene.queryparser.flexible.core.builders - package org.apache.lucene.queryparser.flexible.core.builders
-
Necessary classes to implement query builders.
- org.apache.lucene.queryparser.flexible.core.config - package org.apache.lucene.queryparser.flexible.core.config
-
Base classes used to configure the query processing.
- org.apache.lucene.queryparser.flexible.core.messages - package org.apache.lucene.queryparser.flexible.core.messages
-
Messages usually used by query parser implementations.
- org.apache.lucene.queryparser.flexible.core.nodes - package org.apache.lucene.queryparser.flexible.core.nodes
-
Query nodes commonly used by query parser implementations.
- org.apache.lucene.queryparser.flexible.core.parser - package org.apache.lucene.queryparser.flexible.core.parser
-
Necessary interfaces to implement text parsers.
- org.apache.lucene.queryparser.flexible.core.processors - package org.apache.lucene.queryparser.flexible.core.processors
-
Interfaces and implementations used by query node processors
- org.apache.lucene.queryparser.flexible.core.util - package org.apache.lucene.queryparser.flexible.core.util
-
Utility classes to used with the Query Parser.
- org.apache.lucene.queryparser.flexible.messages - package org.apache.lucene.queryparser.flexible.messages
-
For Native Language Support (NLS), system of software internationalization.
- org.apache.lucene.queryparser.flexible.precedence - package org.apache.lucene.queryparser.flexible.precedence
-
Precedence Query Parser Implementation
- org.apache.lucene.queryparser.flexible.precedence.processors - package org.apache.lucene.queryparser.flexible.precedence.processors
-
Processors used by Precedence Query Parser
- org.apache.lucene.queryparser.flexible.standard - package org.apache.lucene.queryparser.flexible.standard
-
- org.apache.lucene.queryparser.flexible.standard.builders - package org.apache.lucene.queryparser.flexible.standard.builders
-
Standard Lucene Query Node Builders.
- org.apache.lucene.queryparser.flexible.standard.config - package org.apache.lucene.queryparser.flexible.standard.config
-
Standard Lucene Query Configuration.
- org.apache.lucene.queryparser.flexible.standard.nodes - package org.apache.lucene.queryparser.flexible.standard.nodes
-
Standard Lucene Query Nodes.
- org.apache.lucene.queryparser.flexible.standard.parser - package org.apache.lucene.queryparser.flexible.standard.parser
-
Lucene Query Parser
- org.apache.lucene.queryparser.flexible.standard.processors - package org.apache.lucene.queryparser.flexible.standard.processors
-
Lucene Query Node Processors.
- org.apache.lucene.queryparser.simple - package org.apache.lucene.queryparser.simple
-
A simple query parser for human-entered queries.
- org.apache.lucene.queryparser.surround.parser - package org.apache.lucene.queryparser.surround.parser
-
This package contains the QueryParser.jj source file for the Surround parser.
- org.apache.lucene.queryparser.surround.query - package org.apache.lucene.queryparser.surround.query
-
This package contains SrndQuery and its subclasses.
- org.apache.lucene.queryparser.xml - package org.apache.lucene.queryparser.xml
-
Parser that produces Lucene Query objects from XML streams.
- org.apache.lucene.queryparser.xml.builders - package org.apache.lucene.queryparser.xml.builders
-
XML Parser factories for different Lucene Query/Filters.
- org.apache.lucene.replicator - package org.apache.lucene.replicator
-
Files replication framework
- org.apache.lucene.replicator.http - package org.apache.lucene.replicator.http
-
HTTP replication implementation
- org.apache.lucene.replicator.nrt - package org.apache.lucene.replicator.nrt
-
Near-real-time replication framework
- org.apache.lucene.sandbox.queries - package org.apache.lucene.sandbox.queries
-
Additional queries (some may have caveats or limitations)
- org.apache.lucene.search - package org.apache.lucene.search
-
Code to search indices.
- org.apache.lucene.search.grouping - package org.apache.lucene.search.grouping
-
Grouping.
- org.apache.lucene.search.highlight - package org.apache.lucene.search.highlight
-
Highlighting search terms.
- org.apache.lucene.search.intervals - package org.apache.lucene.search.intervals
-
Intervals queries
- org.apache.lucene.search.join - package org.apache.lucene.search.join
-
Support for index-time and query-time joins.
- org.apache.lucene.search.similarities - package org.apache.lucene.search.similarities
-
This package contains the various ranking models that can be used in Lucene.
- org.apache.lucene.search.spans - package org.apache.lucene.search.spans
-
The calculus of spans.
- org.apache.lucene.search.spell - package org.apache.lucene.search.spell
-
Suggest alternate spellings for words.
- org.apache.lucene.search.suggest - package org.apache.lucene.search.suggest
-
Support for Autocomplete/Autosuggest
- org.apache.lucene.search.suggest.analyzing - package org.apache.lucene.search.suggest.analyzing
-
Analyzer based autosuggest.
- org.apache.lucene.search.suggest.document - package org.apache.lucene.search.suggest.document
-
Support for document suggestion
- org.apache.lucene.search.suggest.fst - package org.apache.lucene.search.suggest.fst
-
Finite-state based autosuggest.
- org.apache.lucene.search.suggest.jaspell - package org.apache.lucene.search.suggest.jaspell
-
JaSpell-based autosuggest.
- org.apache.lucene.search.suggest.tst - package org.apache.lucene.search.suggest.tst
-
Ternary Search Tree based autosuggest.
- org.apache.lucene.search.uhighlight - package org.apache.lucene.search.uhighlight
-
The UnifiedHighlighter -- a flexible highlighter that can get offsets from postings, term vectors, or analysis.
- org.apache.lucene.search.vectorhighlight - package org.apache.lucene.search.vectorhighlight
-
Another highlighter implementation based on term vectors.
- org.apache.lucene.spatial - package org.apache.lucene.spatial
-
Lucene spatial search
- org.apache.lucene.spatial.bbox - package org.apache.lucene.spatial.bbox
-
Bounding Box Spatial Strategy
- org.apache.lucene.spatial.composite - package org.apache.lucene.spatial.composite
-
Composite strategies.
- org.apache.lucene.spatial.prefix - package org.apache.lucene.spatial.prefix
-
Prefix Tree Strategy.
- org.apache.lucene.spatial.prefix.tree - package org.apache.lucene.spatial.prefix.tree
-
This package is about SpatialPrefixTree and any supporting classes.
- org.apache.lucene.spatial.query - package org.apache.lucene.spatial.query
-
Spatial Query options useful for client side requests
- org.apache.lucene.spatial.serialized - package org.apache.lucene.spatial.serialized
-
Strategies that serialize the shape (non-indexed).
- org.apache.lucene.spatial.spatial4j - package org.apache.lucene.spatial.spatial4j
-
Spatial4j stuff that ideally belongs in Spatial4j (isn't related to Lucene).
- org.apache.lucene.spatial.util - package org.apache.lucene.spatial.util
-
Various spatial utilities.
- org.apache.lucene.spatial.vector - package org.apache.lucene.spatial.vector
-
Spatial strategy that uses two fields.
- org.apache.lucene.spatial3d - package org.apache.lucene.spatial3d
-
- org.apache.lucene.spatial3d.geom - package org.apache.lucene.spatial3d.geom
-
Shapes implemented using 3D planar geometry.
- org.apache.lucene.store - package org.apache.lucene.store
-
Binary i/o API, used for all index data.
- org.apache.lucene.util - package org.apache.lucene.util
-
Some utility classes.
- org.apache.lucene.util.automaton - package org.apache.lucene.util.automaton
-
Finite-state automaton for regular expressions.
- org.apache.lucene.util.bkd - package org.apache.lucene.util.bkd
-
Block KD-tree, implementing the generic spatial data structure described in
this paper.
- org.apache.lucene.util.fst - package org.apache.lucene.util.fst
-
Finite state transducers
- org.apache.lucene.util.graph - package org.apache.lucene.util.graph
-
Utility classes for working with token streams as graphs.
- org.apache.lucene.util.mutable - package org.apache.lucene.util.mutable
-
Comparable object wrappers
- org.apache.lucene.util.packed - package org.apache.lucene.util.packed
-
Packed integer arrays and streams.
- org.egothor.stemmer - package org.egothor.stemmer
-
Egothor stemmer API.
- org.tartarus.snowball - package org.tartarus.snowball
-
Snowball stemmer API
- org.tartarus.snowball.ext - package org.tartarus.snowball.ext
-
Autogenerated snowball stemmer implementations.
- orient(double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
-
Returns a positive value if points a, b, and c are arranged in counter-clockwise order,
negative value if clockwise, zero if collinear.
- ORIGIN_LATITUDE - Static variable in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
The "home" latitude.
- ORIGIN_LONGITUDE - Static variable in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
The "home" longitude.
- originalTermIndexes - Variable in class org.apache.lucene.search.spell.CombineSuggestion
-
The indexes from the passed-in array of terms used to make this word combination
- OrQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- OrQuery - Class in org.apache.lucene.queryparser.surround.query
-
Factory for disjunctions
- OrQuery(List<SrndQuery>, boolean, String) - Constructor for class org.apache.lucene.queryparser.surround.query.OrQuery
-
- OrQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
OrQueryNode
represents an OR boolean operation performed on a list
of nodes.
- OrQueryNode(List<QueryNode>) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.OrQueryNode
-
- OS_ARCH - Static variable in class org.apache.lucene.util.Constants
-
- OS_NAME - Static variable in class org.apache.lucene.util.Constants
-
The value of System.getProperty("os.name").
- OS_VERSION - Static variable in class org.apache.lucene.util.Constants
-
- OTHER - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Other (not fitting any of the other categories)
- out - Variable in class org.apache.lucene.analysis.TokenStreamToDot
-
- out - Variable in class org.apache.lucene.codecs.blockterms.BlockTermsWriter
-
- out - Variable in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexWriter
-
- out - Variable in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexWriter
-
- out - Variable in class org.apache.lucene.store.CorruptingIndexOutput
-
- out - Variable in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- out - Variable in class org.apache.lucene.util.OfflineSorter.ByteSequencesWriter
-
- out - Variable in class org.apache.lucene.util.packed.PackedInts.Writer
-
- out_grouping(char[], int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- out_grouping_b(char[], int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- out_range(int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- out_range_b(int, int) - Method in class org.tartarus.snowball.SnowballProgram
-
- output - Variable in class org.apache.lucene.search.suggest.analyzing.FSTUtil.Path
-
Output of the path so far:
- output - Variable in class org.apache.lucene.util.fst.Builder.Arc
-
- output - Variable in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- output - Variable in class org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput
-
- output - Variable in class org.apache.lucene.util.fst.FST.Arc
-
- output - Variable in class org.apache.lucene.util.fst.FSTTester.InputOutput
-
- output - Variable in class org.apache.lucene.util.fst.IntsRefFSTEnum.InputOutput
-
- output - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-
Holds cost plus any usage-specific output:
- output - Variable in class org.apache.lucene.util.fst.Util.Result
-
- output1 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
-
- output2 - Variable in class org.apache.lucene.util.fst.PairOutputs.Pair
-
- OUTPUT_AS_BYTE_ARRAY - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
-
- OUTPUT_AS_MANY_BUFFERS - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
-
- OUTPUT_AS_MANY_BUFFERS_LUCENE - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
-
- OUTPUT_AS_ONE_BUFFER - Static variable in class org.apache.lucene.store.ByteBuffersDirectory
-
- outputPos - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- outputs - Variable in class org.apache.lucene.util.fst.FST
-
- Outputs<T> - Class in org.apache.lucene.util.fst
-
Represents the outputs for an FST, providing the basic
algebra required for building and traversing the FST.
- Outputs() - Constructor for class org.apache.lucene.util.fst.Outputs
-
- outputsEqual(T, T) - Method in class org.apache.lucene.util.fst.FSTTester
-
- outputStream(Path) - Static method in class org.apache.lucene.benchmark.byTask.utils.StreamUtils
-
- OutputStreamDataOutput - Class in org.apache.lucene.store
-
- OutputStreamDataOutput(OutputStream) - Constructor for class org.apache.lucene.store.OutputStreamDataOutput
-
- OutputStreamIndexOutput - Class in org.apache.lucene.store
-
Implementation class for buffered
IndexOutput
that writes to an
OutputStream
.
- OutputStreamIndexOutput(String, String, OutputStream, int) - Constructor for class org.apache.lucene.store.OutputStreamIndexOutput
-
- outputToString(BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- outputToString(CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- outputToString(IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- outputToString(Object) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- outputToString(Object) - Method in class org.apache.lucene.util.fst.NoOutputs
-
- outputToString(T) - Method in class org.apache.lucene.util.fst.Outputs
-
- outputToString(PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
-
- outputToString(Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-
- outputToString(Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
-
- outsideDistance(DistanceStyle, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoBaseMembershipShape
-
Called by a computeOutsideDistance
method if X/Y/Z is not within this shape.
- outsideDistance(DistanceStyle, double, double, double) - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- overheadPerValue(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
-
Returns the overhead per value, in bits.
- overheadRatio(int) - Method in enum org.apache.lucene.util.packed.PackedInts.Format
-
Returns the overhead ratio (overhead per value / bits per value
).
- Overlaps - Static variable in class org.apache.lucene.spatial.query.SpatialOperation
-
Almost meets the "Overlaps" OGC definition, but boundary-neutral (boundary==interior).
- OVERLAPS - Static variable in interface org.apache.lucene.spatial3d.geom.GeoArea
-
The referenced shape OVERLAPS this area
- OverlaySingleDocTermsLeafReader - Class in org.apache.lucene.search.uhighlight
-
Overlays a 2nd LeafReader for the terms of one field, otherwise the primary reader is
consulted.
- OverlaySingleDocTermsLeafReader(LeafReader, LeafReader, String, int) - Constructor for class org.apache.lucene.search.uhighlight.OverlaySingleDocTermsLeafReader
-
- overrideDefaultQueryCache() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- overrideTestDefaultQueryCache() - Method in class org.apache.lucene.util.LuceneTestCase
-
- oversize(int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Returns an array size >= minTargetSize, generally
over-allocating exponentially to achieve amortized
linear-time cost as the array grows.
- OwnCacheKeyMultiReader - Class in org.apache.lucene.index
-
A
MultiReader
that has its own cache key, occasionally useful for
testing purposes.
- OwnCacheKeyMultiReader(IndexReader...) - Constructor for class org.apache.lucene.index.OwnCacheKeyMultiReader
-
Sole constructor.
- owner - Variable in class org.apache.lucene.index.OrdinalMap
-
Cache key of whoever asked for this awful thing
- packCount - Variable in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- packedBuilder(int, float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
-
- packedBuilder(float) - Static method in class org.apache.lucene.util.packed.PackedLongValues
-
- packedBytesLength - Variable in class org.apache.lucene.util.bkd.BKDReader
-
- packedBytesLength - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
numDataDims * bytesPerDim
- PackedDataInput - Class in org.apache.lucene.util.packed
-
A
DataInput
wrapper to read unaligned, variable-length packed
integers.
- PackedDataInput(DataInput) - Constructor for class org.apache.lucene.util.packed.PackedDataInput
-
Create a new instance that wraps in
.
- PackedDataOutput - Class in org.apache.lucene.util.packed
-
A
DataOutput
wrapper to write unaligned, variable-length packed
integers.
- PackedDataOutput(DataOutput) - Constructor for class org.apache.lucene.util.packed.PackedDataOutput
-
Create a new instance that wraps out
.
- packedIndexBytesLength - Variable in class org.apache.lucene.util.bkd.BKDReader
-
- packedIndexBytesLength - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
numIndexDims * bytesPerDim
- PackedInts - Class in org.apache.lucene.util.packed
-
Simplistic compression for array of unsigned long values.
- PackedInts() - Constructor for class org.apache.lucene.util.packed.PackedInts
-
- PackedInts.Decoder - Interface in org.apache.lucene.util.packed
-
A decoder for packed integers.
- PackedInts.Encoder - Interface in org.apache.lucene.util.packed
-
An encoder for packed integers.
- PackedInts.Format - Enum in org.apache.lucene.util.packed
-
A format to write packed ints.
- PackedInts.FormatAndBits - Class in org.apache.lucene.util.packed
-
Simple class that holds a format and a number of bits per value.
- PackedInts.Mutable - Class in org.apache.lucene.util.packed
-
A packed integer array that can be modified.
- PackedInts.NullReader - Class in org.apache.lucene.util.packed
-
- PackedInts.Reader - Class in org.apache.lucene.util.packed
-
A read-only random access array of positive integers.
- PackedInts.ReaderIterator - Interface in org.apache.lucene.util.packed
-
Run-once iterator interface, to decode previously saved PackedInts.
- PackedInts.Writer - Class in org.apache.lucene.util.packed
-
A write-once Writer.
- PackedLongValues - Class in org.apache.lucene.util.packed
-
Utility class to compress integers into a
LongValues
instance.
- PackedLongValues.Builder - Class in org.apache.lucene.util.packed
-
- PackedLongValues.Iterator - Class in org.apache.lucene.util.packed
-
An iterator over long values.
- PackedQuadPrefixTree - Class in org.apache.lucene.spatial.prefix.tree
-
Uses a compact binary representation of 8 bytes to encode a spatial quad trie.
- PackedQuadPrefixTree(SpatialContext, int) - Constructor for class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- PackedQuadPrefixTree.Factory - Class in org.apache.lucene.spatial.prefix.tree
-
- PackedQuadPrefixTree.PackedQuadCell - Class in org.apache.lucene.spatial.prefix.tree
-
- PackedQuadPrefixTree.PrefixTreeIterator - Class in org.apache.lucene.spatial.prefix.tree
-
This is a streamlined version of TreeCellIterator, with built-in support to prune at detailLevel
(but not recursively upwards).
- PackedTokenAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- PackedTokenAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Constructs the attribute implementation.
- packedValue() - Method in class org.apache.lucene.util.bkd.HeapPointReader
-
- packedValue() - Method in class org.apache.lucene.util.bkd.OfflinePointReader
-
- packedValue() - Method in class org.apache.lucene.util.bkd.PointReader
-
Returns the packed byte[] value
- packValues(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Packs the values by storing them in 4 bits, two values into a byte Values
range is from 0 to 9.
- PagedBytes - Class in org.apache.lucene.util
-
Represents a logical byte[] as a series of pages.
- PagedBytes(int) - Constructor for class org.apache.lucene.util.PagedBytes
-
1<<blockBits must be bigger than biggest single
BytesRef slice that will be pulled
- PagedBytes.PagedBytesDataInput - Class in org.apache.lucene.util
-
- PagedBytes.PagedBytesDataOutput - Class in org.apache.lucene.util
-
- PagedBytes.Reader - Class in org.apache.lucene.util
-
Provides methods to read BytesRefs from a frozen
PagedBytes.
- PagedBytesDataOutput() - Constructor for class org.apache.lucene.util.PagedBytes.PagedBytesDataOutput
-
- PagedGrowableWriter - Class in org.apache.lucene.util.packed
-
- PagedGrowableWriter(long, int, int, float) - Constructor for class org.apache.lucene.util.packed.PagedGrowableWriter
-
- PagedMutable - Class in org.apache.lucene.util.packed
-
- PagedMutable(long, int, int, float) - Constructor for class org.apache.lucene.util.packed.PagedMutable
-
- Pair(Cur, Cud) - Constructor for class org.apache.lucene.queryparser.ext.Extensions.Pair
-
Creates a new Pair
- PairOutputs<A,B> - Class in org.apache.lucene.util.fst
-
An FST
Outputs
implementation, holding two other outputs.
- PairOutputs(Outputs<A>, Outputs<B>) - Constructor for class org.apache.lucene.util.fst.PairOutputs
-
- PairOutputs.Pair<A,B> - Class in org.apache.lucene.util.fst
-
Holds a single pair of two outputs.
- ParallelCompositeReader - Class in org.apache.lucene.index
-
- ParallelCompositeReader(CompositeReader...) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
-
Create a ParallelCompositeReader based on the provided
readers; auto-closes the given readers on
IndexReader.close()
.
- ParallelCompositeReader(boolean, CompositeReader...) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
-
Create a ParallelCompositeReader based on the provided
readers.
- ParallelCompositeReader(boolean, CompositeReader[], CompositeReader[]) - Constructor for class org.apache.lucene.index.ParallelCompositeReader
-
Expert: create a ParallelCompositeReader based on the provided
readers and storedFieldReaders; when a document is
loaded, only storedFieldsReaders will be used.
- ParallelLeafReader - Class in org.apache.lucene.index
-
An
LeafReader
which reads multiple, parallel indexes.
- ParallelLeafReader(LeafReader...) - Constructor for class org.apache.lucene.index.ParallelLeafReader
-
Create a ParallelLeafReader based on the provided
readers; auto-closes the given readers on
IndexReader.close()
.
- ParallelLeafReader(boolean, LeafReader...) - Constructor for class org.apache.lucene.index.ParallelLeafReader
-
Create a ParallelLeafReader based on the provided
readers.
- ParallelLeafReader(boolean, LeafReader[], LeafReader[]) - Constructor for class org.apache.lucene.index.ParallelLeafReader
-
Expert: create a ParallelLeafReader based on the provided
readers and storedFieldReaders; when a document is
loaded, only storedFieldsReaders will be used.
- ParallelTaxonomyArrays - Class in org.apache.lucene.facet.taxonomy
-
Returns 3 arrays for traversing the taxonomy:
parents
: parents[i]
denotes the parent of category
ordinal i
.
children
: children[i]
denotes a child of category ordinal
i
.
siblings
: siblings[i]
denotes the sibling of category
ordinal i
.
To traverse the taxonomy tree, you typically start with children[0]
(ordinal 0 is reserved for ROOT), and then depends if you want to do DFS or
BFS, you call children[children[0]]
or siblings[children[0]]
and so forth, respectively.
- ParallelTaxonomyArrays() - Constructor for class org.apache.lucene.facet.taxonomy.ParallelTaxonomyArrays
-
Sole constructor.
- PARAMETER_VALUE_NOT_SUPPORTED - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- params - Variable in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- parent - Variable in class org.apache.lucene.index.IndexReaderContext
-
The reader context for this reader's immediate parent, or null if none
- parent - Variable in class org.apache.lucene.mockfile.FilterFileSystem
-
FileSystemProvider that created this FilterFileSystem
- PARENT - Static variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Deprecated.
Index values for accessing relatives array.
- ParentChildrenBlockJoinQuery - Class in org.apache.lucene.search.join
-
A query that returns all the matching child documents for a specific parent document
indexed together in the same block.
- ParentChildrenBlockJoinQuery(BitSetProducer, Query, int) - Constructor for class org.apache.lucene.search.join.ParentChildrenBlockJoinQuery
-
Creates a ParentChildrenBlockJoinQuery
instance
- parentLeaves - Variable in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets.FacetParentVal
-
The count of ranges that span all of the childCounts.
- parentQuery - Variable in class org.apache.lucene.search.Weight
-
- parents() - Method in class org.apache.lucene.facet.taxonomy.ParallelTaxonomyArrays
-
Returns the parents array, where parents[i]
denotes the parent of
category ordinal i
.
- parents - Variable in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
Maps an ordinal to its parent, or -1 if there is no
parent (root node).
- parents - Variable in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets
-
- parse(String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
Parses a hyphenation pattern file.
- parse(InputSource) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
Parses a hyphenation pattern file.
- parse(String) - Static method in class org.apache.lucene.analysis.ja.util.CSVUtil
-
Parse CSV line
- parse(String) - Static method in class org.apache.lucene.analysis.ko.util.CSVUtil
-
Parse CSV line
- parse(Class<? extends RSLPStemmerBase>, String) - Static method in class org.apache.lucene.analysis.pt.RSLPStemmerBase
-
Parse a resource file into an RSLP stemmer description.
- parse(Reader) - Method in class org.apache.lucene.analysis.synonym.SolrSynonymParser
-
- parse(Reader) - Method in class org.apache.lucene.analysis.synonym.SynonymMap.Parser
-
- parse(Reader) - Method in class org.apache.lucene.analysis.synonym.WordnetSynonymParser
-
- parse(DocData, String, Date, Reader, TrecContentSource) - Method in class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser
-
- parse(DocData, String, Date, InputSource, TrecContentSource) - Method in class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser
-
- parse(DocData, String, Date, Reader, TrecContentSource) - Method in interface org.apache.lucene.benchmark.byTask.feeds.HTMLParser
-
Parse the input Reader and return DocData.
- parse(DocData, String, TrecContentSource, StringBuilder, TrecDocParser.ParsePathType) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecDocParser
-
parse the text prepared in docBuf into a result DocData,
no synchronization is required.
- parse(DocData, String, TrecContentSource, StringBuilder, TrecDocParser.ParsePathType) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecFBISParser
-
- parse(DocData, String, TrecContentSource, StringBuilder, TrecDocParser.ParsePathType) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecFR94Parser
-
- parse(DocData, String, TrecContentSource, StringBuilder, TrecDocParser.ParsePathType) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecFTParser
-
- parse(DocData, String, TrecContentSource, StringBuilder, TrecDocParser.ParsePathType) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecGov2Parser
-
- parse(DocData, String, TrecContentSource, StringBuilder, TrecDocParser.ParsePathType) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecLATimesParser
-
- parse(DocData, String, TrecContentSource, StringBuilder, TrecDocParser.ParsePathType) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecParserByPath
-
- parse(QualityQuery) - Method in interface org.apache.lucene.benchmark.quality.QualityQueryParser
-
Parse a given QualityQuery into a Lucene query.
- parse(QualityQuery) - Method in class org.apache.lucene.benchmark.quality.utils.SimpleQQParser
-
- parse(String) - Static method in class org.apache.lucene.expressions.js.VariableContext
-
Parses a normalized javascript variable.
- parse(String) - Static method in class org.apache.lucene.geo.SimpleWKTShapeParser
-
- parse(String[], String[], Analyzer) - Static method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
Parses a query which searches on the fields specified.
- parse(String, String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
Parses a query, searching on the fields specified.
- parse(String[], String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryparser.classic.MultiFieldQueryParser
-
Parses a query, searching on the fields specified.
- parse(String) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Parses a query string, returning a
Query
.
- parse(String) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
- parse(ExtensionQuery) - Method in class org.apache.lucene.queryparser.ext.ParserExtension
-
- parse(CharSequence, CharSequence) - Method in interface org.apache.lucene.queryparser.flexible.core.parser.SyntaxParser
-
- parse(String, String) - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
- parse(String, ParsePosition) - Method in class org.apache.lucene.queryparser.flexible.standard.config.NumberDateFormat
-
- parse(CharSequence, CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Parses a query string, returning a
QueryNode
.
- parse(String[], String[], Analyzer) - Static method in class org.apache.lucene.queryparser.flexible.standard.QueryParserUtil
-
Parses a query which searches on the fields specified.
- parse(String, String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryparser.flexible.standard.QueryParserUtil
-
Parses a query, searching on the fields specified.
- parse(String[], String[], BooleanClause.Occur[], Analyzer) - Static method in class org.apache.lucene.queryparser.flexible.standard.QueryParserUtil
-
Parses a query, searching on the fields specified.
- parse(String, String) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- parse(String) - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Parses the query text and returns parsed query
- parse(String) - Static method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- parse(InputStream) - Method in class org.apache.lucene.queryparser.xml.CoreParser
-
Parses the given stream as XML file and returns a
Query
.
- parse(String, SpatialContext) - Method in class org.apache.lucene.spatial.query.SpatialArgsParser
-
Parses a string such as "Intersects(ENVELOPE(-10,-8,22,20)) distErrPct=0.025".
- parse(String) - Static method in class org.apache.lucene.util.Version
-
Parse a version number of the form "major.minor.bugfix.prerelease"
.
- parse2(String) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- parseCalendar(String) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
- parseDate(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- ParseException - Exception in org.apache.lucene.queryparser.classic
-
This exception is thrown when parse errors are encountered.
- ParseException(Token, int[][], String[]) - Constructor for exception org.apache.lucene.queryparser.classic.ParseException
-
This constructor is used by the method "generateParseException"
in the generated parser.
- ParseException() - Constructor for exception org.apache.lucene.queryparser.classic.ParseException
-
The following constructors are for use by you for whatever
purpose you can think of.
- ParseException(String) - Constructor for exception org.apache.lucene.queryparser.classic.ParseException
-
Constructor with message.
- ParseException - Exception in org.apache.lucene.queryparser.flexible.standard.parser
-
This exception is thrown when parse errors are encountered.
- ParseException(Token, int[][], String[]) - Constructor for exception org.apache.lucene.queryparser.flexible.standard.parser.ParseException
-
This constructor is used by the method "generateParseException"
in the generated parser.
- ParseException() - Constructor for exception org.apache.lucene.queryparser.flexible.standard.parser.ParseException
-
The following constructors are for use by you for whatever
purpose you can think of.
- ParseException(Message) - Constructor for exception org.apache.lucene.queryparser.flexible.standard.parser.ParseException
-
Constructor with message.
- ParseException - Exception in org.apache.lucene.queryparser.surround.parser
-
This exception is thrown when parse errors are encountered.
- ParseException(Token, int[][], String[]) - Constructor for exception org.apache.lucene.queryparser.surround.parser.ParseException
-
This constructor is used by the method "generateParseException"
in the generated parser.
- ParseException() - Constructor for exception org.apache.lucene.queryparser.surround.parser.ParseException
-
The following constructors are for use by you for whatever
purpose you can think of.
- ParseException(String) - Constructor for exception org.apache.lucene.queryparser.surround.parser.ParseException
-
Constructor with message.
- parseExpectedType(String, SimpleWKTShapeParser.ShapeType) - Static method in class org.apache.lucene.geo.SimpleWKTShapeParser
-
- parseGeneration(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Returns the generation from this file name, or 0 if there is no
generation.
- parseInt(char[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Parses a char array into an int.
- parseInt(char[], int, int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Parses the string argument as if it was an int value and returns the
result.
- parseLargeKanjiNumeral(JapaneseNumberFilter.NumberBuffer) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Parse large kanji numerals (ten thousands or larger)
- parseLeniently(String) - Static method in class org.apache.lucene.util.Version
-
Parse the given version number as a constant or dot based version.
- parseLine(DocData, String) - Method in class org.apache.lucene.benchmark.byTask.feeds.GeonamesLineParser
-
- parseLine(DocData, String) - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.HeaderLineParser
-
- parseLine(DocData, String) - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.LineParser
-
parse an input line and fill doc data appropriately
- parseLine(DocData, String) - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.SimpleLineParser
-
- parseMap(String) - Static method in class org.apache.lucene.spatial.query.SpatialArgsParser
-
Parses "a=b c=d f" (whitespace separated) into name-value pairs.
- parseMediumKanjiNumeral(JapaneseNumberFilter.NumberBuffer) - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
Parse medium kanji numerals (tens, hundreds or thousands)
- parseOptions(String[]) - Static method in class org.apache.lucene.index.CheckIndex
-
Parse command line args into fields
- Parser(boolean, Analyzer) - Constructor for class org.apache.lucene.analysis.synonym.SynonymMap.Parser
-
- Parser(Reader) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser.Parser
-
- Parser(InputSource) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser.Parser
-
- parser - Variable in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
-
- parser - Variable in class org.apache.lucene.queryparser.xml.CoreParser
-
- ParserException - Exception in org.apache.lucene.queryparser.xml
-
Thrown when the xml queryparser encounters
invalid syntax/configuration.
- ParserException() - Constructor for exception org.apache.lucene.queryparser.xml.ParserException
-
- ParserException(String) - Constructor for exception org.apache.lucene.queryparser.xml.ParserException
-
- ParserException(String, Throwable) - Constructor for exception org.apache.lucene.queryparser.xml.ParserException
-
- ParserException(Throwable) - Constructor for exception org.apache.lucene.queryparser.xml.ParserException
-
- ParserExtension - Class in org.apache.lucene.queryparser.ext
-
This class represents an extension base class to the Lucene standard
QueryParser
.
- ParserExtension() - Constructor for class org.apache.lucene.queryparser.ext.ParserExtension
-
- parseRules(List<String>, NormalizeCharMap.Builder) - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilterFactory
-
- parseSegmentName(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Parses the segment name out of the given file name.
- parseShape(String) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- parseShape(String, SpatialContext) - Method in class org.apache.lucene.spatial.query.SpatialArgsParser
-
- parseString(String) - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilterFactory
-
- parseUnitShape(String) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
- parseUnitShape(String) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
Parse a String to a UnitNRShape.
- partial - Variable in class org.apache.lucene.index.CheckIndex.Status
-
- partition(int, int, int, int, MutablePointValues, int, int, int, BytesRef, BytesRef) - Static method in class org.apache.lucene.util.bkd.MutablePointsReaderUtils
-
Partition points around mid
.
- PartOfSpeechAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
-
- PartOfSpeechAttribute - Interface in org.apache.lucene.analysis.ko.tokenattributes
-
Part of Speech attributes for Korean.
- PartOfSpeechAttributeImpl - Class in org.apache.lucene.analysis.ja.tokenattributes
-
- PartOfSpeechAttributeImpl() - Constructor for class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
-
- PartOfSpeechAttributeImpl - Class in org.apache.lucene.analysis.ko.tokenattributes
-
Part of Speech attributes for Korean.
- PartOfSpeechAttributeImpl() - Constructor for class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- Passage - Class in org.apache.lucene.search.uhighlight
-
Represents a passage (typically a sentence of the document).
- Passage() - Constructor for class org.apache.lucene.search.uhighlight.Passage
-
- passageFormatter - Variable in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- PassageFormatter - Class in org.apache.lucene.search.uhighlight
-
Creates a formatted snippet from the top passages.
- PassageFormatter() - Constructor for class org.apache.lucene.search.uhighlight.PassageFormatter
-
- passageScorer - Variable in class org.apache.lucene.search.uhighlight.FieldHighlighter
-
- PassageScorer - Class in org.apache.lucene.search.uhighlight
-
- PassageScorer() - Constructor for class org.apache.lucene.search.uhighlight.PassageScorer
-
Creates PassageScorer with these default values:
k1 = 1.2
,
b = 0.75
.
- PassageScorer(float, float, float) - Constructor for class org.apache.lucene.search.uhighlight.PassageScorer
-
Creates PassageScorer with specified scoring parameters
- path - Variable in class org.apache.lucene.facet.FacetField
-
Path for this field.
- path - Variable in class org.apache.lucene.facet.FacetResult
-
Path whose children were requested.
- path - Variable in class org.apache.lucene.facet.taxonomy.AssociationFacetField
-
Facet path for this field.
- Path(int, FST.Arc<T>, T, IntsRefBuilder) - Constructor for class org.apache.lucene.search.suggest.analyzing.FSTUtil.Path
-
Sole constructor.
- PathHierarchyTokenizer - Class in org.apache.lucene.analysis.path
-
Tokenizer for path-like hierarchies.
- PathHierarchyTokenizer() - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizer(int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizer(int, char) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizer(char, char) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizer(char, char, int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizer(AttributeFactory, char, char, int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizer(int, char, char, int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizer(AttributeFactory, int, char, char, int) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- PathHierarchyTokenizerFactory - Class in org.apache.lucene.analysis.path
-
- PathHierarchyTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.path.PathHierarchyTokenizerFactory
-
Creates a new PathHierarchyTokenizerFactory
- PathQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
PathQueryNode
is used to store queries like
/company/USA/California /product/shoes/brown.
- PathQueryNode(List<PathQueryNode.QueryText>) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
- PathQueryNode.QueryText - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
Term text with a beginning and end position
- pathToString(String, String[]) - Static method in class org.apache.lucene.facet.FacetsConfig
-
Turns a dim + path into an encoded string.
- pathToString(String[]) - Static method in class org.apache.lucene.facet.FacetsConfig
-
Turns a dim + path into an encoded string.
- pathToString(String[], int) - Static method in class org.apache.lucene.facet.FacetsConfig
-
Turns the first length
elements of path
into an encoded string.
- pathType(Path) - Static method in class org.apache.lucene.benchmark.byTask.feeds.TrecDocParser
-
Compute the path type of a file by inspecting name of file and its parents
- PATTERN - Static variable in class org.apache.lucene.analysis.miscellaneous.KeywordMarkerFilterFactory
-
- PATTERN - Static variable in class org.apache.lucene.analysis.pattern.PatternTokenizerFactory
-
- pattern - Variable in class org.apache.lucene.analysis.pattern.PatternTokenizerFactory
-
- PATTERN - Static variable in class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizerFactory
-
- PATTERN - Static variable in class org.apache.lucene.analysis.pattern.SimplePatternTokenizerFactory
-
- PatternCaptureGroupFilterFactory - Class in org.apache.lucene.analysis.pattern
-
- PatternCaptureGroupFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pattern.PatternCaptureGroupFilterFactory
-
- PatternCaptureGroupTokenFilter - Class in org.apache.lucene.analysis.pattern
-
CaptureGroup uses Java regexes to emit multiple tokens - one for each capture
group in one or more patterns.
- PatternCaptureGroupTokenFilter(TokenStream, boolean, Pattern...) - Constructor for class org.apache.lucene.analysis.pattern.PatternCaptureGroupTokenFilter
-
- PatternConsumer - Interface in org.apache.lucene.analysis.compound.hyphenation
-
This interface is used to connect the XML pattern file parser to the
hyphenation tree.
- PatternKeywordMarkerFilter - Class in org.apache.lucene.analysis.miscellaneous
-
- PatternKeywordMarkerFilter(TokenStream, Pattern) - Constructor for class org.apache.lucene.analysis.miscellaneous.PatternKeywordMarkerFilter
-
- PatternParser - Class in org.apache.lucene.analysis.compound.hyphenation
-
A SAX document handler to read and parse hyphenation patterns from a XML
file.
- PatternParser() - Constructor for class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- PatternParser(PatternConsumer) - Constructor for class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- PatternReplaceCharFilter - Class in org.apache.lucene.analysis.pattern
-
CharFilter that uses a regular expression for the target of replace string.
- PatternReplaceCharFilter(Pattern, String, Reader) - Constructor for class org.apache.lucene.analysis.pattern.PatternReplaceCharFilter
-
- PatternReplaceCharFilterFactory - Class in org.apache.lucene.analysis.pattern
-
- PatternReplaceCharFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pattern.PatternReplaceCharFilterFactory
-
Creates a new PatternReplaceCharFilterFactory
- PatternReplaceFilter - Class in org.apache.lucene.analysis.pattern
-
A TokenFilter which applies a Pattern to each token in the stream,
replacing match occurances with the specified replacement string.
- PatternReplaceFilter(TokenStream, Pattern, String, boolean) - Constructor for class org.apache.lucene.analysis.pattern.PatternReplaceFilter
-
Constructs an instance to replace either the first, or all occurances
- PatternReplaceFilterFactory - Class in org.apache.lucene.analysis.pattern
-
- PatternReplaceFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pattern.PatternReplaceFilterFactory
-
Creates a new PatternReplaceFilterFactory
- PatternTokenizer - Class in org.apache.lucene.analysis.pattern
-
This tokenizer uses regex pattern matching to construct distinct tokens
for the input stream.
- PatternTokenizer(Pattern, int) - Constructor for class org.apache.lucene.analysis.pattern.PatternTokenizer
-
creates a new PatternTokenizer returning tokens from group (-1 for split functionality)
- PatternTokenizer(AttributeFactory, Pattern, int) - Constructor for class org.apache.lucene.analysis.pattern.PatternTokenizer
-
creates a new PatternTokenizer returning tokens from group (-1 for split functionality)
- PatternTokenizerFactory - Class in org.apache.lucene.analysis.pattern
-
- PatternTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pattern.PatternTokenizerFactory
-
Creates a new PatternTokenizerFactory
- pause(long) - Method in class org.apache.lucene.index.MergeRateLimiter
-
- pause(long) - Method in class org.apache.lucene.store.RateLimiter
-
Pauses, if necessary, to keep the instantaneous IO
rate at or below the target.
- pause(long) - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
-
Pauses, if necessary, to keep the instantaneous IO
rate at or below the target.
- pauseNanos(long, MergePolicy.OneMergeProgress.PauseReason, BooleanSupplier) - Method in class org.apache.lucene.index.MergePolicy.OneMergeProgress
-
Pauses the calling thread for at least pauseNanos
nanoseconds
unless the merge is aborted or the external condition returns false
,
in which case control returns immediately.
- PAY_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
Filename extension for payloads and offsets.
- payload() - Method in class org.apache.lucene.search.suggest.BufferedInputIterator
-
- payload() - Method in class org.apache.lucene.search.suggest.DocumentDictionary.DocumentInputIterator
-
- payload() - Method in class org.apache.lucene.search.suggest.InputIterator.InputIteratorWrapper
-
- payload() - Method in interface org.apache.lucene.search.suggest.InputIterator
-
An arbitrary byte[] to record per suggestion.
- payload - Variable in class org.apache.lucene.search.suggest.Lookup.LookupResult
-
the key's payload (null if not present)
- payload() - Method in class org.apache.lucene.search.suggest.SortedInputIterator
-
- payload() - Method in class org.apache.lucene.search.suggest.UnsortedInputIterator
-
- payload - Variable in class org.apache.lucene.util.fst.Util.FSTPath
-
- PayloadAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
The payload of a Token.
- PayloadAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- PayloadAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
Initialize this attribute with no payload.
- PayloadAttributeImpl(BytesRef) - Constructor for class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
Initialize this attribute with the given payload.
- PayloadDecoder - Interface in org.apache.lucene.queries.payloads
-
- PayloadEncoder - Interface in org.apache.lucene.analysis.payloads
-
Mainly for use with the DelimitedPayloadTokenFilter, converts char buffers to
BytesRef
.
- payloadField - Variable in class org.apache.lucene.search.suggest.DocumentDictionary
-
Field to read payload from
- PayloadFunction - Class in org.apache.lucene.queries.payloads
-
An abstract class that defines a way for PayloadScoreQuery instances to transform
the cumulative effects of payload scores for a document.
- PayloadFunction() - Constructor for class org.apache.lucene.queries.payloads.PayloadFunction
-
- PayloadHelper - Class in org.apache.lucene.analysis.payloads
-
Utility methods for encoding payloads.
- PayloadHelper() - Constructor for class org.apache.lucene.analysis.payloads.PayloadHelper
-
- PAYLOADS - Static variable in class org.apache.lucene.index.PostingsEnum
-
- payloads - Variable in class org.apache.lucene.search.suggest.BufferedInputIterator
-
buffered payload entries
- PayloadScoreQuery - Class in org.apache.lucene.queries.payloads
-
A Query class that uses a
PayloadFunction
to modify the score of a wrapped SpanQuery
- PayloadScoreQuery(SpanQuery, PayloadFunction, PayloadDecoder, boolean) - Constructor for class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
Creates a new PayloadScoreQuery
- PayloadScoreQuery(SpanQuery, PayloadFunction, boolean) - Constructor for class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
- PayloadScoreQuery(SpanQuery, PayloadFunction, PayloadDecoder) - Constructor for class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
Creates a new PayloadScoreQuery that includes the underlying span scores
- PayloadScoreQuery(SpanQuery, PayloadFunction) - Constructor for class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
- PayloadSpanCollector - Class in org.apache.lucene.payloads
-
SpanCollector for collecting payloads
- PayloadSpanCollector() - Constructor for class org.apache.lucene.payloads.PayloadSpanCollector
-
- PayloadSpanUtil - Class in org.apache.lucene.payloads
-
Experimental class to get set of payloads for most standard Lucene queries.
- PayloadSpanUtil(IndexReaderContext) - Constructor for class org.apache.lucene.payloads.PayloadSpanUtil
-
- payloadToMatch - Variable in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery
-
- peekToken() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
-
Returns true if there is a new token.
- PENDING_SEGMENTS - Static variable in class org.apache.lucene.index.IndexFileNames
-
Name of pending index segment file
- PER_FIELD_FORMAT_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-
FieldInfo
attribute name used to store the
format name for each field.
- PER_FIELD_FORMAT_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-
FieldInfo
attribute name used to store the
format name for each field.
- PER_FIELD_NAME - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-
- PER_FIELD_NAME - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-
- PER_FIELD_REUSE_STRATEGY - Static variable in class org.apache.lucene.analysis.Analyzer
-
A predefined
Analyzer.ReuseStrategy
that reuses components per-field by
maintaining a Map of TokenStreamComponent per field name.
- PER_FIELD_SUFFIX_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-
FieldInfo
attribute name used to store the
segment suffix name for each field.
- PER_FIELD_SUFFIX_KEY - Static variable in class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-
FieldInfo
attribute name used to store the
segment suffix name for each field.
- PerFieldAnalyzerWrapper - Class in org.apache.lucene.analysis.miscellaneous
-
This analyzer is used to facilitate scenarios where different
fields require different analysis techniques.
- PerFieldAnalyzerWrapper(Analyzer) - Constructor for class org.apache.lucene.analysis.miscellaneous.PerFieldAnalyzerWrapper
-
Constructs with default analyzer.
- PerFieldAnalyzerWrapper(Analyzer, Map<String, Analyzer>) - Constructor for class org.apache.lucene.analysis.miscellaneous.PerFieldAnalyzerWrapper
-
Constructs with default analyzer and a map of analyzers to use for
specific fields.
- PerFieldDocValuesFormat - Class in org.apache.lucene.codecs.perfield
-
Enables per field docvalues support.
- PerFieldDocValuesFormat() - Constructor for class org.apache.lucene.codecs.perfield.PerFieldDocValuesFormat
-
Sole constructor.
- PerFieldPostingsFormat - Class in org.apache.lucene.codecs.perfield
-
Enables per field postings support.
- PerFieldPostingsFormat() - Constructor for class org.apache.lucene.codecs.perfield.PerFieldPostingsFormat
-
Sole constructor.
- PerFieldSimilarityWrapper - Class in org.apache.lucene.search.similarities
-
Provides the ability to use a different
Similarity
for different fields.
- PerFieldSimilarityWrapper() - Constructor for class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-
Sole constructor.
- perform(HttpServletRequest, HttpServletResponse) - Method in class org.apache.lucene.replicator.http.ReplicationService
-
Executes the replication task.
- PerfRunData - Class in org.apache.lucene.benchmark.byTask
-
Data maintained by a performance test run.
- PerfRunData(Config) - Constructor for class org.apache.lucene.benchmark.byTask.PerfRunData
-
- PerfTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
An abstract task to be tested for performance.
- PerfTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- PerSessionDirectoryFactory - Class in org.apache.lucene.replicator
-
- PerSessionDirectoryFactory(Path) - Constructor for class org.apache.lucene.replicator.PerSessionDirectoryFactory
-
Constructor with the given sources mapping.
- PersianAnalyzer - Class in org.apache.lucene.analysis.fa
-
- PersianAnalyzer() - Constructor for class org.apache.lucene.analysis.fa.PersianAnalyzer
-
- PersianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.fa.PersianAnalyzer
-
Builds an analyzer with the given stop words
- PersianCharFilter - Class in org.apache.lucene.analysis.fa
-
CharFilter that replaces instances of Zero-width non-joiner with an
ordinary space.
- PersianCharFilter(Reader) - Constructor for class org.apache.lucene.analysis.fa.PersianCharFilter
-
- PersianCharFilterFactory - Class in org.apache.lucene.analysis.fa
-
- PersianCharFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.fa.PersianCharFilterFactory
-
Creates a new PersianCharFilterFactory
- PersianNormalizationFilter - Class in org.apache.lucene.analysis.fa
-
- PersianNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.fa.PersianNormalizationFilter
-
- PersianNormalizationFilterFactory - Class in org.apache.lucene.analysis.fa
-
- PersianNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.fa.PersianNormalizationFilterFactory
-
Creates a new PersianNormalizationFilterFactory
- PersianNormalizer - Class in org.apache.lucene.analysis.fa
-
Normalizer for Persian.
- PersianNormalizer() - Constructor for class org.apache.lucene.analysis.fa.PersianNormalizer
-
- PersistentSnapshotDeletionPolicy - Class in org.apache.lucene.index
-
A
SnapshotDeletionPolicy
which adds a persistence layer so that
snapshots can be maintained across the life of an application.
- PersistentSnapshotDeletionPolicy(IndexDeletionPolicy, Directory) - Constructor for class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
- PersistentSnapshotDeletionPolicy(IndexDeletionPolicy, Directory, IndexWriterConfig.OpenMode) - Constructor for class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
- perThreadHardLimitMB - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
Sets the hard upper bound on RAM usage for a single
segment, after which the segment is forced to flush.
- PerThreadPKLookup - Class in org.apache.lucene.index
-
Utility class to do efficient primary-key (only 1 doc contains the
given term) lookups by segment, re-using the enums.
- PerThreadPKLookup(IndexReader, String) - Constructor for class org.apache.lucene.index.PerThreadPKLookup
-
- PhoneticFilter - Class in org.apache.lucene.analysis.phonetic
-
Create tokens for phonetic matches.
- PhoneticFilter(TokenStream, Encoder, boolean) - Constructor for class org.apache.lucene.analysis.phonetic.PhoneticFilter
-
Creates a PhoneticFilter with the specified encoder, and either
adding encoded forms as synonyms (inject=true
) or
replacing them.
- PhoneticFilterFactory - Class in org.apache.lucene.analysis.phonetic
-
- PhoneticFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.phonetic.PhoneticFilterFactory
-
Creates a new PhoneticFilterFactory
- phrase(String...) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Return an
IntervalsSource
exposing intervals for a phrase consisting of a list of terms
- phrase(IntervalsSource...) - Static method in class org.apache.lucene.search.intervals.Intervals
-
Return an
IntervalsSource
exposing intervals for a phrase consisting of a list of IntervalsSources
- PHRASE_OPERATOR - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables PHRASE
operator (")
- PHRASE_SLOP - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
Key used to set the default phrase slop
- PhraseHelper - Class in org.apache.lucene.search.uhighlight
-
- PhraseHelper(Query, String, Predicate<String>, Function<SpanQuery, Boolean>, Function<Query, Collection<Query>>, boolean) - Constructor for class org.apache.lucene.search.uhighlight.PhraseHelper
-
Constructor.
- PhraseQuery - Class in org.apache.lucene.search
-
A Query that matches documents containing a particular sequence of terms.
- PhraseQuery(int, String, String...) - Constructor for class org.apache.lucene.search.PhraseQuery
-
Create a phrase query which will match documents that contain the given
list of terms at consecutive positions in field
, and at a
maximum edit distance of slop
.
- PhraseQuery(String, String...) - Constructor for class org.apache.lucene.search.PhraseQuery
-
Create a phrase query which will match documents that contain the given
list of terms at consecutive positions in field
.
- PhraseQuery(int, String, BytesRef...) - Constructor for class org.apache.lucene.search.PhraseQuery
-
Create a phrase query which will match documents that contain the given
list of terms at consecutive positions in field
, and at a
maximum edit distance of slop
.
- PhraseQuery(String, BytesRef...) - Constructor for class org.apache.lucene.search.PhraseQuery
-
Create a phrase query which will match documents that contain the given
list of terms at consecutive positions in field
.
- PhraseQuery.Builder - Class in org.apache.lucene.search
-
A builder for phrase queries.
- PhraseQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- PhraseQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.PhraseQueryNodeBuilder
-
- PhraseSlopQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
- PhraseSlopQueryNode(QueryNode, int) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- PhraseSlopQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
This processor removes invalid
SlopQueryNode
objects in the query
node tree.
- PhraseSlopQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.PhraseSlopQueryNodeProcessor
-
- PKIndexSplitter - Class in org.apache.lucene.index
-
Split an index based on a
Query
.
- PKIndexSplitter(Directory, Directory, Directory, Query) - Constructor for class org.apache.lucene.index.PKIndexSplitter
-
Split an index based on a
Query
.
- PKIndexSplitter(Directory, Directory, Directory, Query, IndexWriterConfig, IndexWriterConfig) - Constructor for class org.apache.lucene.index.PKIndexSplitter
-
- PKIndexSplitter(Directory, Directory, Directory, Term) - Constructor for class org.apache.lucene.index.PKIndexSplitter
-
Split an index based on a given primary key term
and a 'middle' term.
- PKIndexSplitter(Directory, Directory, Directory, Term, IndexWriterConfig, IndexWriterConfig) - Constructor for class org.apache.lucene.index.PKIndexSplitter
-
- Placeholder - Class in org.apache.lucene.codecs
-
Remove this file when adding back compat codecs
- Placeholder() - Constructor for class org.apache.lucene.codecs.Placeholder
-
- PLAINTEXT_FIELD_NAME - Static variable in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- PlainTextDictionary - Class in org.apache.lucene.search.spell
-
Dictionary represented by a text file.
- PlainTextDictionary(Path) - Constructor for class org.apache.lucene.search.spell.PlainTextDictionary
-
Creates a dictionary based on a Path.
- PlainTextDictionary(InputStream) - Constructor for class org.apache.lucene.search.spell.PlainTextDictionary
-
Creates a dictionary based on an inputstream.
- PlainTextDictionary(Reader) - Constructor for class org.apache.lucene.search.spell.PlainTextDictionary
-
Creates a dictionary based on a reader.
- plane - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
The vertical line plane
- Plane - Class in org.apache.lucene.spatial3d.geom
-
We know about three kinds of planes.
- Plane(double, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.Plane
-
Construct a plane with all four coefficients defined.
- Plane(Vector, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.Plane
-
Construct a plane through two points and origin.
- Plane(Vector, Vector) - Constructor for class org.apache.lucene.spatial3d.geom.Plane
-
Construct a plane through two points and origin.
- Plane(PlanetModel, double) - Constructor for class org.apache.lucene.spatial3d.geom.Plane
-
Construct a horizontal plane at a specified Z.
- Plane(double, double) - Constructor for class org.apache.lucene.spatial3d.geom.Plane
-
Construct a vertical plane through a specified
x, y and origin.
- Plane(Vector, double) - Constructor for class org.apache.lucene.spatial3d.geom.Plane
-
Construct a plane with a specific vector, and D offset
from origin.
- Plane(Plane, boolean) - Constructor for class org.apache.lucene.spatial3d.geom.Plane
-
Construct a plane that is parallel to the one provided, but which is just barely numerically
distinguishable from it, in the direction desired.
- planePoints - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Notable points for the line (end points)
- planetModel - Variable in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- planetModel - Variable in class org.apache.lucene.spatial.spatial4j.Geo3dSpatialContextFactory
-
The planet model
- planetModel - Variable in class org.apache.lucene.spatial3d.geom.BasePlanetObject
-
This is the planet model embedded in all objects derived from this
class.
- PlanetModel - Class in org.apache.lucene.spatial3d.geom
-
Holds mathematical constants associated with the model of a planet.
- PlanetModel(double, double) - Constructor for class org.apache.lucene.spatial3d.geom.PlanetModel
-
Constructor.
- PlanetModel(InputStream) - Constructor for class org.apache.lucene.spatial3d.geom.PlanetModel
-
Deserialization constructor.
- PlanetObject - Interface in org.apache.lucene.spatial3d.geom
-
- PLUS - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- PLUS - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- pointCount - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
- pointDataDimensionCount() - Method in class org.apache.lucene.document.FieldType
-
- pointDataDimensionCount() - Method in interface org.apache.lucene.index.IndexableFieldType
-
If this is positive (representing the number of point data dimensions), the field is indexed as a point.
- pointIndexDimensionCount() - Method in class org.apache.lucene.document.FieldType
-
- pointIndexDimensionCount() - Method in interface org.apache.lucene.index.IndexableFieldType
-
The number of dimensions used for the index key
- pointInPolygon(List<Tessellator.Triangle>, double, double) - Static method in class org.apache.lucene.geo.Tessellator
-
Brute force compute if a point is in the polygon by traversing entire triangulation
todo: speed this up using either binary tree or prefix coding (filtering by bounding box of triangle)
- pointInRectPrecise(double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial.util.GeoRelationUtils
-
Determine if a bbox (defined by minLat, maxLat, minLon, maxLon) contains the provided point (defined by lat, lon)
NOTE: this is a basic method that does not handle dateline or pole crossing.
- PointInSetQuery - Class in org.apache.lucene.search
-
Abstract query class to find all documents whose single or multi-dimensional point values, previously indexed with e.g.
- PointInSetQuery(String, int, int, PointInSetQuery.Stream) - Constructor for class org.apache.lucene.search.PointInSetQuery
-
The packedPoints
iterator must be in sorted order.
- PointInSetQuery.Stream - Class in org.apache.lucene.search
-
Iterator of encoded point values.
- pointInTriangle(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.Tessellator
-
compute whether the given x, y point is in a triangle; uses the winding order method
- pointNumBytes() - Method in class org.apache.lucene.document.FieldType
-
- pointNumBytes() - Method in interface org.apache.lucene.index.IndexableFieldType
-
The number of bytes in each dimension's values.
- pointOnBearing(Point, double, double, SpatialContext, Point) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dDistanceCalculator
-
- pointOnSurface(Vector) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Check if point is on surface.
- pointOnSurface(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Check if point is on surface.
- pointOutside(Vector) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Check if point is outside surface.
- pointOutside(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Check if point is outside surface.
- PointPrefixTreeFieldCacheProvider - Class in org.apache.lucene.spatial.prefix
-
- PointPrefixTreeFieldCacheProvider(SpatialPrefixTree, String, int) - Constructor for class org.apache.lucene.spatial.prefix.PointPrefixTreeFieldCacheProvider
-
- PointQueryNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
This query node represents a field query that holds a point value.
- PointQueryNode(CharSequence, Number, NumberFormat) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
Creates a
PointQueryNode
object using the given field,
Number
value and
NumberFormat
used to convert the value to
String
.
- PointQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- PointQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.PointQueryNodeProcessor
-
- PointRangeQuery - Class in org.apache.lucene.search
-
Abstract class for range queries against single or multidimensional points such as
IntPoint
.
- PointRangeQuery(String, byte[], byte[], int) - Constructor for class org.apache.lucene.search.PointRangeQuery
-
Expert: create a multidimensional range query for point values.
- PointRangeQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- PointRangeQueryBuilder() - Constructor for class org.apache.lucene.queryparser.xml.builders.PointRangeQueryBuilder
-
- PointRangeQueryNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
This query node represents a range query composed by
PointQueryNode
bounds, which means the bound values are
Number
s.
- PointRangeQueryNode(PointQueryNode, PointQueryNode, boolean, boolean, PointsConfig) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.PointRangeQueryNode
-
- PointRangeQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- PointRangeQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.PointRangeQueryNodeBuilder
-
- PointRangeQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- PointRangeQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.PointRangeQueryNodeProcessor
-
- PointReader - Class in org.apache.lucene.util.bkd
-
One pass iterator through all points previously written with a
PointWriter
, abstracting away whether points a read
from (offline) disk or simple arrays in heap.
- PointReader() - Constructor for class org.apache.lucene.util.bkd.PointReader
-
- Points - Class in org.apache.lucene.benchmark.byTask.stats
-
Test run data points collected as the test proceeds.
- Points(Config) - Constructor for class org.apache.lucene.benchmark.byTask.stats.Points
-
Create a Points statistics object.
- points - Variable in class org.apache.lucene.spatial3d.geom.GeoPolygonFactory.PolygonDescription
-
The list of points
- POINTS_CONFIG - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
- POINTS_CONFIG_MAP - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
- PointsConfig - Class in org.apache.lucene.queryparser.flexible.standard.config
-
This class holds the configuration used to parse numeric queries and create
PointValues
queries.
- PointsConfig(NumberFormat, Class<? extends Number>) - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.PointsConfig
-
- PointsConfigListener - Class in org.apache.lucene.queryparser.flexible.standard.config
-
- PointsConfigListener(QueryConfigHandler) - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.PointsConfigListener
-
- pointsFormat() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- pointsFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes points index
- pointsFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- pointsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- pointsFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- pointsFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- pointsFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- PointsFormat - Class in org.apache.lucene.codecs
-
Encodes/decodes indexed points.
- PointsFormat() - Constructor for class org.apache.lucene.codecs.PointsFormat
-
Creates a new point format.
- pointsFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- pointsFormat() - Method in class org.apache.lucene.index.RandomCodec
-
- pointsOnly - Variable in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- PointsReader - Class in org.apache.lucene.codecs
-
Abstract API to visit point values.
- PointsReader() - Constructor for class org.apache.lucene.codecs.PointsReader
-
Sole constructor.
- pointsReaders - Variable in class org.apache.lucene.index.MergeState
-
Point readers to merge
- PointsStackTracker - Class in org.apache.lucene.index
-
- PointsStackTracker(int, int) - Constructor for class org.apache.lucene.index.PointsStackTracker
-
- PointsStackTracker.Cell - Class in org.apache.lucene.index
-
- pointsStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status for testing of PointValues (null if PointValues could not be tested).
- PointsWriter - Class in org.apache.lucene.codecs
-
Abstract API to write points
- PointsWriter() - Constructor for class org.apache.lucene.codecs.PointsWriter
-
Sole constructor.
- PointValues - Class in org.apache.lucene.index
-
Access to indexed numeric values.
- PointValues() - Constructor for class org.apache.lucene.index.PointValues
-
Default constructor
- PointValues.IntersectVisitor - Interface in org.apache.lucene.index
-
We recurse the BKD tree, using a provided instance of this to guide the recursion.
- PointValues.Relation - Enum in org.apache.lucene.index
-
- PointVectorStrategy - Class in org.apache.lucene.spatial.vector
-
- PointVectorStrategy(SpatialContext, String, FieldType) - Constructor for class org.apache.lucene.spatial.vector.PointVectorStrategy
-
Create a new instance configured with the provided FieldType options.
- PointWriter - Interface in org.apache.lucene.util.bkd
-
Appends many points, and then at the end provides a
PointReader
to iterate
those points.
- pointXY(double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- pointXYZ(double, double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- PolishAnalyzer - Class in org.apache.lucene.analysis.pl
-
- PolishAnalyzer() - Constructor for class org.apache.lucene.analysis.pl.PolishAnalyzer
-
- PolishAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.pl.PolishAnalyzer
-
Builds an analyzer with the given stop words.
- PolishAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.pl.PolishAnalyzer
-
Builds an analyzer with the given stop words.
- Polygon - Class in org.apache.lucene.geo
-
Represents a closed polygon on the earth's surface.
- Polygon(double[], double[], Polygon...) - Constructor for class org.apache.lucene.geo.Polygon
-
Creates a new Polygon from the supplied latitude/longitude array, and optionally any holes.
- polygon() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- Polygon2D - Class in org.apache.lucene.geo
-
2D polygon implementation represented as a balanced interval tree of edges.
- PolygonDescription(List<? extends GeoPoint>) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPolygonFactory.PolygonDescription
-
Instantiate the polygon description.
- PolygonDescription(List<? extends GeoPoint>, List<? extends GeoPolygonFactory.PolygonDescription>) - Constructor for class org.apache.lucene.spatial3d.geom.GeoPolygonFactory.PolygonDescription
-
Instantiate the polygon description.
- pop() - Method in class org.apache.lucene.search.DisiPriorityQueue
-
- pop() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
-
- pop() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- pop() - Method in class org.apache.lucene.util.PriorityQueue
-
Removes and returns the least element of the PriorityQueue in log(size)
time.
- pop_andnot(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
-
Returns the popcount or cardinality of A & ~B
.
- pop_array(long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
-
Returns the number of set bits in an array of longs.
- pop_intersect(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
-
Returns the popcount or cardinality of the two sets after an intersection.
- pop_union(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
-
Returns the popcount or cardinality of the union of two sets.
- pop_xor(long[], long[], int, int) - Static method in class org.apache.lucene.util.BitUtil
-
Returns the popcount or cardinality of A ^ B
Neither array is modified.
- populateResults(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopDocsCollector
-
Populates the results array with the ScoreDoc instances.
- populateResults(ScoreDoc[], int) - Method in class org.apache.lucene.search.TopFieldCollector
-
- PorterStemFilter - Class in org.apache.lucene.analysis.en
-
Transforms the token stream as per the Porter stemming algorithm.
- PorterStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.en.PorterStemFilter
-
- PorterStemFilterFactory - Class in org.apache.lucene.analysis.en
-
- PorterStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.en.PorterStemFilterFactory
-
Creates a new PorterStemFilterFactory
- PorterStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- PorterStemmer() - Constructor for class org.tartarus.snowball.ext.PorterStemmer
-
- PortugueseAnalyzer - Class in org.apache.lucene.analysis.pt
-
- PortugueseAnalyzer() - Constructor for class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
- PortugueseAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
Builds an analyzer with the given stop words.
- PortugueseAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.pt.PortugueseAnalyzer
-
Builds an analyzer with the given stop words.
- PortugueseLightStemFilter - Class in org.apache.lucene.analysis.pt
-
- PortugueseLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.pt.PortugueseLightStemFilter
-
- PortugueseLightStemFilterFactory - Class in org.apache.lucene.analysis.pt
-
- PortugueseLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pt.PortugueseLightStemFilterFactory
-
Creates a new PortugueseLightStemFilterFactory
- PortugueseLightStemmer - Class in org.apache.lucene.analysis.pt
-
Light Stemmer for Portuguese
- PortugueseLightStemmer() - Constructor for class org.apache.lucene.analysis.pt.PortugueseLightStemmer
-
- PortugueseMinimalStemFilter - Class in org.apache.lucene.analysis.pt
-
- PortugueseMinimalStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.pt.PortugueseMinimalStemFilter
-
- PortugueseMinimalStemFilterFactory - Class in org.apache.lucene.analysis.pt
-
- PortugueseMinimalStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pt.PortugueseMinimalStemFilterFactory
-
Creates a new PortugueseMinimalStemFilterFactory
- PortugueseMinimalStemmer - Class in org.apache.lucene.analysis.pt
-
Minimal Stemmer for Portuguese
- PortugueseMinimalStemmer() - Constructor for class org.apache.lucene.analysis.pt.PortugueseMinimalStemmer
-
- PortugueseStemFilter - Class in org.apache.lucene.analysis.pt
-
- PortugueseStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.pt.PortugueseStemFilter
-
- PortugueseStemFilterFactory - Class in org.apache.lucene.analysis.pt
-
- PortugueseStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pt.PortugueseStemFilterFactory
-
Creates a new PortugueseStemFilterFactory
- PortugueseStemmer - Class in org.apache.lucene.analysis.pt
-
Portuguese stemmer implementing the RSLP (Removedor de Sufixos da Lingua Portuguesa)
algorithm.
- PortugueseStemmer() - Constructor for class org.apache.lucene.analysis.pt.PortugueseStemmer
-
- PortugueseStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- PortugueseStemmer() - Constructor for class org.tartarus.snowball.ext.PortugueseStemmer
-
- POS - Class in org.apache.lucene.analysis.ko
-
Part of speech classification for Korean based on Sejong corpus classification.
- POS() - Constructor for class org.apache.lucene.analysis.ko.POS
-
- POS.Tag - Enum in org.apache.lucene.analysis.ko
-
Part of speech tag for Korean based on Sejong corpus classification.
- POS.Type - Enum in org.apache.lucene.analysis.ko
-
The type of the token.
- POS_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
Filename extension for positions.
- POS_SEP - Static variable in class org.apache.lucene.analysis.TokenStreamToAutomaton
-
We create transition between two adjacent tokens.
- posArcsStart - Variable in class org.apache.lucene.util.fst.FST.Arc
-
Where the first arc in the array starts; only valid if
bytesPerArc != 0
- POSDICT_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- POSDICT_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- POSDICT_HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- POSDICT_HEADER - Static variable in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- posIncAtt - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- position() - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter.NumberBuffer
-
- Position() - Constructor for class org.apache.lucene.analysis.LookaheadTokenFilter.Position
-
- position() - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- position(long) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- position() - Method in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
- position(long) - Method in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
- position - Variable in class org.apache.lucene.search.spans.TermSpans
-
- position() - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- PositionCheckingMap() - Constructor for class org.apache.lucene.search.highlight.WeightedSpanTermExtractor.PositionCheckingMap
-
- positionIncrement - Variable in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
The term's position increment.
- PositionIncrementAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
Determines the position of this token
relative to the previous Token in a TokenStream, used in phrase
searching.
- PositionIncrementAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- PositionIncrementAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-
Initialize this attribute with position increment of 1
- PositionLengthAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
Determines how many positions this
token spans.
- PositionLengthAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- PositionLengthAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-
Initializes this attribute with position length of 1.
- positions - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- POSITIONS - Static variable in class org.apache.lucene.index.PostingsEnum
-
- positionsCost() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- positionsCost() - Method in class org.apache.lucene.search.spans.Spans
-
- positionsCost() - Method in class org.apache.lucene.search.spans.TermSpans
-
- PositionSpan - Class in org.apache.lucene.search.highlight
-
Utility class to record Positions Spans
- PositionSpan(int, int) - Constructor for class org.apache.lucene.search.highlight.PositionSpan
-
- PositiveIntOutputs - Class in org.apache.lucene.util.fst
-
An FST
Outputs
implementation where each output
is a non-negative long value.
- PositiveScoresOnlyCollector - Class in org.apache.lucene.search
-
A
Collector
implementation which wraps another
Collector
and makes sure only documents with
scores > 0 are collected.
- PositiveScoresOnlyCollector(Collector) - Constructor for class org.apache.lucene.search.PositiveScoresOnlyCollector
-
- posix_madvise(ByteBuffer, int) - Static method in class org.apache.lucene.store.NativePosixUtil
-
- posLenAtt - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- posTag - Variable in class org.apache.lucene.analysis.ko.dict.Dictionary.Morpheme
-
- postBreak - Variable in class org.apache.lucene.analysis.compound.hyphenation.Hyphen
-
- postings(PostingsEnum, int) - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- postings(PostingsEnum, int) - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- postings(FieldInfo, BlockTermState, PostingsEnum, int) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- postings(FieldInfo, BlockTermState, PostingsEnum, int) - Method in class org.apache.lucene.codecs.PostingsReaderBase
-
Must fully consume state, since after this call that
TermState may be reused.
- postings(PostingsEnum, int) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
- postings(PostingsEnum, int) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- postings(Term, int) - Method in class org.apache.lucene.index.LeafReader
-
- postings(Term) - Method in class org.apache.lucene.index.LeafReader
-
- postings(PostingsEnum, int) - Method in class org.apache.lucene.index.MultiTermsEnum
-
- postings(PostingsEnum) - Method in class org.apache.lucene.index.TermsEnum
-
- postings(PostingsEnum, int) - Method in class org.apache.lucene.index.TermsEnum
-
Get
PostingsEnum
for the current term, with
control over whether freqs, positions, offsets or payloads
are required.
- postings(PostingsEnum, int) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- postings - Variable in class org.apache.lucene.search.spans.TermSpans
-
- postingsEnum - Variable in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
-
- PostingsEnum - Class in org.apache.lucene.index
-
Iterates through the postings.
- PostingsEnum() - Constructor for class org.apache.lucene.index.PostingsEnum
-
Sole constructor.
- postingsEnum - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- postingsEnums - Variable in class org.apache.lucene.index.PerThreadPKLookup
-
- postingsFormat() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- postingsFormat() - Method in class org.apache.lucene.codecs.cheapbastard.CheapBastardCodec
-
- postingsFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes postings
- postingsFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- postingsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- postingsFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- postingsFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- postingsFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- PostingsFormat - Class in org.apache.lucene.codecs
-
Encodes/decodes terms, postings, and proximity data.
- PostingsFormat(String) - Constructor for class org.apache.lucene.codecs.PostingsFormat
-
Creates a new postings format.
- postingsFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- PostingsOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
- PostingsOffsetStrategy(UHComponents) - Constructor for class org.apache.lucene.search.uhighlight.PostingsOffsetStrategy
-
- PostingsReaderBase - Class in org.apache.lucene.codecs
-
The core terms dictionaries (BlockTermsReader,
BlockTreeTermsReader) interact with a single instance
of this class to manage creation of
PostingsEnum
and
PostingsEnum
instances.
- PostingsReaderBase() - Constructor for class org.apache.lucene.codecs.PostingsReaderBase
-
Sole constructor.
- PostingsWithTermVectorsOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
- PostingsWithTermVectorsOffsetStrategy(UHComponents) - Constructor for class org.apache.lucene.search.uhighlight.PostingsWithTermVectorsOffsetStrategy
-
- PostingsWriterBase - Class in org.apache.lucene.codecs
-
Class that plugs into term dictionaries, such as
BlockTreeTermsWriter
, and handles writing postings.
- PostingsWriterBase() - Constructor for class org.apache.lucene.codecs.PostingsWriterBase
-
Sole constructor.
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.NoChildOptimizationQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorImpl
-
This method is invoked for every node when walking up the tree.
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.RemoveDeletedQueryNodesProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.precedence.processors.BooleanModifiersQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AllowLeadingWildcardProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AnalyzerQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BoostQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.DefaultPhraseSlopQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.FuzzyQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MatchAllDocsQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MultiFieldQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MultiTermRewriteMethodProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.OpenRangeQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PhraseSlopQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PointQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PointRangeQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.RegexpQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.TermRangeQueryNodeProcessor
-
- postProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.WildcardQueryNodeProcessor
-
- postSiblings(AbstractVisitingPrefixTreeQuery.VNode) - Method in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery.VisitorTemplate
-
- postTag - Variable in class org.apache.lucene.search.uhighlight.DefaultPassageFormatter
-
text that will appear after highlighted terms
- postTags - Variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- PowFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
Function to raise the base "a" to the power "b"
- PowFloatFunction(ValueSource, ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.PowFloatFunction
-
- pq - Variable in class org.apache.lucene.search.TopDocsCollector
-
The priority queue which holds the top documents.
- pread(FileDescriptor, long, ByteBuffer) - Static method in class org.apache.lucene.store.NativePosixUtil
-
- preBreak - Variable in class org.apache.lucene.analysis.compound.hyphenation.Hyphen
-
- PRECEDENCE_OPERATORS - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables PRECEDENCE
operators: (
and )
- PrecedenceQueryNodeProcessorPipeline - Class in org.apache.lucene.queryparser.flexible.precedence.processors
-
- PrecedenceQueryNodeProcessorPipeline(QueryConfigHandler) - Constructor for class org.apache.lucene.queryparser.flexible.precedence.processors.PrecedenceQueryNodeProcessorPipeline
-
- PrecedenceQueryParser - Class in org.apache.lucene.queryparser.flexible.precedence
-
This query parser works exactly as the standard query parser (
StandardQueryParser
),
except that it respect the boolean precedence, so <a AND b OR c AND d> is parsed to <(+a +b) (+c +d)>
instead of <+a +b +c +d>.
- PrecedenceQueryParser() - Constructor for class org.apache.lucene.queryparser.flexible.precedence.PrecedenceQueryParser
-
- PrecedenceQueryParser(Analyzer) - Constructor for class org.apache.lucene.queryparser.flexible.precedence.PrecedenceQueryParser
-
- preceding(int) - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- preceding(int) - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- preceding(int) - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- preceding(int) - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- preCopyMergedSegmentFiles(SegmentCommitInfo, Map<String, FileMetaData>) - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
Called when a merge has finished, but before IW switches to the merged segment
- predicateFunction(InnerT) - Method in class org.apache.lucene.util.FilterIterator
-
- prefix - Variable in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
-
- PREFIX_LENGTH_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.TruncateTokenFilterFactory
-
- PREFIX_OPERATOR - Static variable in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Enables PREFIX
operator (*)
- PREFIX_TREE - Static variable in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- PrefixCodedTerms - Class in org.apache.lucene.index
-
Prefix codes term instances (prefixes are shared).
- PrefixCodedTerms.Builder - Class in org.apache.lucene.index
-
Builds a PrefixCodedTerms: call add repeatedly, then finish.
- PrefixCodedTerms.TermIterator - Class in org.apache.lucene.index
-
- prefixCompletion(TernaryTreeNode, CharSequence, int) - Method in class org.apache.lucene.search.suggest.tst.TSTAutocomplete
-
Auto-completes a given prefix query using Depth-First Search with the end
of prefix as source node each time finding a new leaf to get a complete key
to be added in the suggest list.
- PrefixCompletionQuery - Class in org.apache.lucene.search.suggest.document
-
- PrefixCompletionQuery(Analyzer, Term) - Constructor for class org.apache.lucene.search.suggest.document.PrefixCompletionQuery
-
- PrefixCompletionQuery(Analyzer, Term, BitsProducer) - Constructor for class org.apache.lucene.search.suggest.document.PrefixCompletionQuery
-
Constructs an analyzed prefix completion query
- prefixes - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- prefixGridScanLevel - Variable in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery
-
- prefixGridScanLevel - Variable in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- PrefixOperatorQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- PrefixQuery - Class in org.apache.lucene.search
-
A Query that matches documents containing terms with a specified prefix.
- PrefixQuery(Term) - Constructor for class org.apache.lucene.search.PrefixQuery
-
Constructs a query for terms starting with prefix
.
- PREFIXTERM - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- prefixToString(StringBuilder) - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- PrefixTreeFacetCounter - Class in org.apache.lucene.spatial.prefix
-
- PrefixTreeFacetCounter.FacetVisitor - Class in org.apache.lucene.spatial.prefix
-
A callback/visitor of facet counts.
- PrefixTreeStrategy - Class in org.apache.lucene.spatial.prefix
-
- PrefixTreeStrategy(SpatialPrefixTree, String) - Constructor for class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- PrefixWildcardQueryNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
- PrefixWildcardQueryNode(CharSequence, CharSequence, int, int) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.PrefixWildcardQueryNode
-
- PrefixWildcardQueryNode(FieldQueryNode) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.PrefixWildcardQueryNode
-
- PrefixWildcardQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- PrefixWildcardQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.PrefixWildcardQueryNodeBuilder
-
- preMultiTermQueryRewrite(Query) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
When dealing with multi term queries / span queries, we may need to handle custom queries that aren't supported
by the default automata extraction in MultiTermHighlighting
.
- prepareCommit() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
prepare most of the work needed for a two-phase commit.
- prepareCommit() - Method in class org.apache.lucene.index.IndexWriter
-
Expert: prepare for commit.
- prepareCommit() - Method in interface org.apache.lucene.index.TwoPhaseCommit
-
The first stage of a 2-phase commit.
- PrepareCommitFailException(Throwable, TwoPhaseCommit) - Constructor for exception org.apache.lucene.index.TwoPhaseCommitTool.PrepareCommitFailException
-
Sole constructor.
- prepareQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- prepareQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.EnwikiQueryMaker
-
- prepareQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.FileBasedQueryMaker
-
- prepareQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.ReutersQueryMaker
-
- prepareQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.SimpleQueryMaker
-
Prepare the queries for this test.
- prepareQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.SimpleSloppyPhraseQueryMaker
-
- prepareQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- prependOutput(T) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.NoChildOptimizationQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorImpl
-
This method is invoked for every node when walking down the tree.
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.RemoveDeletedQueryNodesProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.precedence.processors.BooleanModifiersQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AllowLeadingWildcardProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AnalyzerQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BoostQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.DefaultPhraseSlopQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.FuzzyQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MatchAllDocsQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MultiFieldQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MultiTermRewriteMethodProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.OpenRangeQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PhraseSlopQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PointQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PointRangeQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.RegexpQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.TermRangeQueryNodeProcessor
-
- preProcessNode(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.WildcardQueryNodeProcessor
-
- prerelease - Variable in class org.apache.lucene.util.Version
-
Prerelease version, currently 0 (alpha), 1 (beta), or 2 (final)
- PRESERVE_ORIGINAL - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
Causes original words are preserved and added to the subword list (Defaults to false)
- PRESERVE_ORIGINAL - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes original words are preserved and added to the subword list (Defaults to false)
- PRESERVE_SEP - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- preservePositionIncrements() - Method in class org.apache.lucene.search.suggest.document.CompletionAnalyzer
-
Returns true if position increments are preserved when converting
the token stream to an automaton
- preserveSep() - Method in class org.apache.lucene.search.suggest.document.CompletionAnalyzer
-
Returns true if separation between tokens are preserved when converting
the token stream to an automaton
- preSiblings(AbstractVisitingPrefixTreeQuery.VNode) - Method in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery.VisitorTemplate
-
- preSpanQueryRewrite(Query) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
When highlighting phrases accurately, we may need to handle custom queries that aren't supported in the
WeightedSpanTermExtractor
as called by the
PhraseHelper
.
- preTag - Variable in class org.apache.lucene.search.uhighlight.DefaultPassageFormatter
-
text that will appear before highlighted terms
- preTags - Variable in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- previous() - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- previous() - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- previous() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- previous() - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- previous() - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- prevSetBit(int) - Method in class org.apache.lucene.util.BitSet
-
Returns the index of the last set bit before or on the index specified.
- prevSetBit(int) - Method in class org.apache.lucene.util.FixedBitSet
-
- prevSetBit(long) - Method in class org.apache.lucene.util.LongBitSet
-
Returns the index of the last set bit before or on the index specified.
- prevSetBit(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- PRIMARY_GEN_KEY - Static variable in class org.apache.lucene.replicator.nrt.Node
-
Key to store the primary gen in the commit data, which increments every time we promote a new primary, so replicas can detect when the
primary they were talking to is changed
- primaryGen - Variable in class org.apache.lucene.replicator.nrt.CopyState
-
- primaryGen - Variable in class org.apache.lucene.replicator.nrt.PrimaryNode
-
- PrimaryNode - Class in org.apache.lucene.replicator.nrt
-
Node that holds an IndexWriter, indexing documents into its local index.
- PrimaryNode(IndexWriter, int, long, long, SearcherFactory, PrintStream) - Constructor for class org.apache.lucene.replicator.nrt.PrimaryNode
-
- PrimaryQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- print(PrintStream) - Method in class org.egothor.stemmer.Row
-
Write the contents of this Row to the printstream.
- printInfo(PrintStream) - Method in class org.apache.lucene.spatial.prefix.tree.QuadPrefixTree
-
- printInfo(PrintStream, CharSequence) - Method in class org.egothor.stemmer.MultiTrie
-
Print the given prefix and the position(s) in the Trie where it appears.
- printInfo(PrintStream, CharSequence) - Method in class org.egothor.stemmer.Trie
-
writes debugging info to the printstream
- printQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- printQueries() - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
-
- printQueries() - Method in interface org.apache.lucene.benchmark.byTask.feeds.QueryMaker
-
Print the queries
- PrintReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Opens a reader and prints basic statistics.
- PrintReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.PrintReaderTask
-
- printStatistics(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
- printStats(PrintStream) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
- printStats(PrintStream) - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- printStats(TaxonomyReader, PrintStream, boolean) - Static method in class org.apache.lucene.facet.taxonomy.PrintTaxonomyStats
-
Recursively prints stats for all ordinals.
- printStream - Variable in class org.apache.lucene.replicator.nrt.Node
-
For debug logging
- PrintStreamInfoStream - Class in org.apache.lucene.util
-
InfoStream implementation over a PrintStream
such as System.out
.
- PrintStreamInfoStream(PrintStream) - Constructor for class org.apache.lucene.util.PrintStreamInfoStream
-
- PrintStreamInfoStream(PrintStream, int) - Constructor for class org.apache.lucene.util.PrintStreamInfoStream
-
- PrintTaxonomyStats - Class in org.apache.lucene.facet.taxonomy
-
Prints how many ords are under each dimension.
- PrintTaxonomyStats() - Constructor for class org.apache.lucene.facet.taxonomy.PrintTaxonomyStats
-
Sole constructor.
- PriorityQueue<T> - Class in org.apache.lucene.util
-
A PriorityQueue maintains a partial ordering of its elements such that the
least element can always be found in constant time.
- PriorityQueue(int) - Constructor for class org.apache.lucene.util.PriorityQueue
-
Create an empty priority queue of the configured size.
- PriorityQueue(int, Supplier<T>) - Constructor for class org.apache.lucene.util.PriorityQueue
-
Create a priority queue that is pre-filled with sentinel objects, so that
the code which uses that queue can always assume it's full and only change
the top without attempting to insert any new object.
Those sentinel values should always compare worse than any non-sentinel
value (i.e.,
PriorityQueue.lessThan(T, T)
should always favor the
non-sentinel values).
By default, the supplier returns null, which means the queue will not be
filled with sentinel values.
- process(String) - Method in class org.apache.lucene.analysis.cn.smart.hhmm.HHMMSegmenter
-
Return a list of
SegToken
representing the best segmentation of a sentence
- process(QueryNode) - Method in interface org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessor
-
Processes a query node tree.
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorImpl
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.RemoveDeletedQueryNodesProcessor
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.precedence.processors.BooleanModifiersQueryNodeProcessor
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AllowLeadingWildcardProcessor
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AnalyzerQueryNodeProcessor
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.DefaultPhraseSlopQueryNodeProcessor
-
- process(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
-
- processChildren(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorImpl
-
This method is called every time a child is processed.
- processChildren(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- processChildren(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.DefaultPhraseSlopQueryNodeProcessor
-
- processChildren(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MultiFieldQueryNodeProcessor
-
- ProductFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
ProductFloatFunction
returns the product of its components.
- ProductFloatFunction(ValueSource[]) - Constructor for class org.apache.lucene.queries.function.valuesource.ProductFloatFunction
-
- PROPERTY_RUN_NESTED - Static variable in class org.apache.lucene.util.TestRuleIgnoreTestSuites
-
A boolean system property indicating nested suites should be executed
normally.
- PROTECTED_TERMS - Static variable in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- PROTECTED_TOKENS - Static variable in class org.apache.lucene.analysis.miscellaneous.KeywordMarkerFilterFactory
-
- PROTECTED_TOKENS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilterFactory
-
Deprecated.
- PROTECTED_TOKENS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilterFactory
-
- PROTECTED_TOKENS - Static variable in class org.apache.lucene.analysis.snowball.SnowballPorterFilterFactory
-
- ProtectedTermFilter - Class in org.apache.lucene.analysis.miscellaneous
-
A ConditionalTokenFilter that only applies its wrapped filters to tokens that
are not contained in a protected set.
- ProtectedTermFilter(CharArraySet, TokenStream, Function<TokenStream, TokenStream>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilter
-
Creates a new ProtectedTermFilter
- ProtectedTermFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- ProtectedTermFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilterFactory
-
- provider() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- ProximityQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
A
ProximityQueryNode
represents a query where the terms should meet
specific distance conditions.
- ProximityQueryNode(List<QueryNode>, CharSequence, ProximityQueryNode.Type, int, boolean) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- ProximityQueryNode(List<QueryNode>, CharSequence, ProximityQueryNode.Type, boolean) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- ProximityQueryNode.ProximityType - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
utility class containing the distance condition and number
- ProximityQueryNode.Type - Enum in org.apache.lucene.queryparser.flexible.core.nodes
-
Distance condition: PARAGRAPH, SENTENCE, or NUMBER
- ProximityType(ProximityQueryNode.Type) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode.ProximityType
-
- ProximityType(ProximityQueryNode.Type, int) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode.ProximityType
-
- prune(SearcherLifetimeManager.Pruner) - Method in class org.apache.lucene.search.SearcherLifetimeManager
-
- PruneByAge(double) - Constructor for class org.apache.lucene.search.SearcherLifetimeManager.PruneByAge
-
- pruneLeafyBranches - Variable in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- PUA_EC00_MARKER - Static variable in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Example marker character: U+EC00 (PRIVATE USE AREA: EC00)
- publish(Revision) - Method in class org.apache.lucene.replicator.http.HttpReplicator
-
- publish(Revision) - Method in class org.apache.lucene.replicator.LocalReplicator
-
- publish(Revision) - Method in interface org.apache.lucene.replicator.Replicator
-
Publish a new
Revision
for consumption by clients.
- push(FieldTermStack.TermInfo) - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack
-
- pushLeft() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- PushPostingsWriterBase - Class in org.apache.lucene.codecs
-
Extension of
PostingsWriterBase
, adding a push
API for writing each element of the postings.
- PushPostingsWriterBase() - Constructor for class org.apache.lucene.codecs.PushPostingsWriterBase
-
Sole constructor.
- pushRight() - Method in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- put(CharSequence, V) - Method in class org.apache.lucene.analysis.CharArrayMap
-
Add the given mapping.
- put(Object, V) - Method in class org.apache.lucene.analysis.CharArrayMap
-
- put(String, V) - Method in class org.apache.lucene.analysis.CharArrayMap
-
Add the given mapping.
- put(char[], V) - Method in class org.apache.lucene.analysis.CharArrayMap
-
Add the given mapping.
- put(int, byte) - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- put(int, char) - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- put(FacetLabel, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
- put(FacetLabel, int) - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
Add a category to the cache, with the given ordinal as the value.
- put(FacetLabel, int) - Method in class org.apache.lucene.facet.taxonomy.writercache.UTF8TaxonomyWriterCache
-
- put(K, WeightedSpanTerm) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor.PositionCheckingMap
-
- put(CharSequence, Object) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Stores a value in the trie.
- put(K, V) - Method in class org.apache.lucene.util.MapOfSets
-
Adds val to the Set associated with key in the Map.
- put(int) - Method in class org.apache.lucene.util.SentinelIntSet
-
Puts this integer (key) in the set, and returns the slot index it was added to.
- put(K, V) - Method in class org.apache.lucene.util.WeakIdentityMap
-
Associates the specified value with the specified key in this map.
- putAll(Map<? extends K, ? extends WeightedSpanTerm>) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor.PositionCheckingMap
-
- putAll(K, Collection<? extends V>) - Method in class org.apache.lucene.util.MapOfSets
-
Adds multiple vals to the Set associated with key in the Map.
- putAttribute(String, String) - Method in class org.apache.lucene.document.FieldType
-
Puts an attribute value.
- putAttribute(String, String) - Method in class org.apache.lucene.index.FieldInfo
-
Puts a codec attribute value.
- putAttribute(String, String) - Method in class org.apache.lucene.index.SegmentInfo
-
Puts a codec attribute value.
- RadixSelector - Class in org.apache.lucene.util
-
Radix selector.
- RadixSelector(int) - Constructor for class org.apache.lucene.util.RadixSelector
-
Sole constructor.
- RAFDirectory - Class in org.apache.lucene.store
-
A straightforward implementation of
FSDirectory
using java.io.RandomAccessFile.
- RAFDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.RAFDirectory
-
Create a new RAFDirectory for the named location.
- RAFDirectory(Path) - Constructor for class org.apache.lucene.store.RAFDirectory
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.lucene60.Lucene60PointsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsProducer
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
Return the memory usage of this object in bytes.
- ramBytesUsed() - Method in class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader.CachedOrds
-
- ramBytesUsed() - Method in class org.apache.lucene.facet.taxonomy.CachedOrdinalsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- ramBytesUsed() - Method in class org.apache.lucene.facet.taxonomy.writercache.UTF8TaxonomyWriterCache
-
- ramBytesUsed() - Method in class org.apache.lucene.index.CodecReader
-
- ramBytesUsed() - Method in class org.apache.lucene.index.EmptyDocValuesProducer
-
- ramBytesUsed() - Method in class org.apache.lucene.index.FilterCodecReader
-
- ramBytesUsed() - Method in class org.apache.lucene.index.IndexWriter
-
- ramBytesUsed() - Method in class org.apache.lucene.index.OrdinalMap
-
- ramBytesUsed() - Method in class org.apache.lucene.index.PrefixCodedTerms
-
- ramBytesUsed() - Method in class org.apache.lucene.search.LRUQueryCache
-
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
Returns byte size of the underlying FST.
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
Returns byte size of the underlying FST.
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.document.CompletionsTermsReader
-
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.document.NRTSuggester
-
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
Returns byte size of the underlying FST.
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Deprecated.
- ramBytesUsed() - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
Returns byte size of the underlying TST
- ramBytesUsed() - Method in class org.apache.lucene.search.TermInSetQuery
-
- ramBytesUsed() - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- ramBytesUsed() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
- ramBytesUsed() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- ramBytesUsed() - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
Return total size in bytes of all files in this directory.
- ramBytesUsed() - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
- ramBytesUsed() - Method in class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
Returns byte usage of all buffers.
- ramBytesUsed() - Method in interface org.apache.lucene.util.Accountable
-
Return the memory usage of this object in bytes.
- ramBytesUsed() - Method in class org.apache.lucene.util.automaton.Automaton
-
- ramBytesUsed() - Method in class org.apache.lucene.util.BitDocIdSet
-
- ramBytesUsed() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- ramBytesUsed() - Method in class org.apache.lucene.util.FixedBitSet
-
- ramBytesUsed() - Method in class org.apache.lucene.util.FrequencyTrackingRingBuffer
-
- ramBytesUsed(BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- ramBytesUsed(CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- ramBytesUsed() - Method in class org.apache.lucene.util.fst.FST
-
- ramBytesUsed(IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- ramBytesUsed(Object) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- ramBytesUsed(Object) - Method in class org.apache.lucene.util.fst.NoOutputs
-
- ramBytesUsed(T) - Method in class org.apache.lucene.util.fst.Outputs
-
Return memory usage for the provided output.
- ramBytesUsed(PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
-
- ramBytesUsed(Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-
- ramBytesUsed(Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
-
- ramBytesUsed() - Method in class org.apache.lucene.util.NotDocIdSet
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.BlockPackedReader
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.DirectMonotonicReader.Meta
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
-
- ramBytesUsed() - Method in class org.apache.lucene.util.packed.PackedLongValues
-
- ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes
-
- ramBytesUsed() - Method in class org.apache.lucene.util.PagedBytes.Reader
-
- ramBytesUsed() - Method in class org.apache.lucene.util.RoaringDocIdSet
-
- ramBytesUsed() - Method in class org.apache.lucene.util.SentinelIntSet
-
Return the memory footprint of this class in bytes.
- ramBytesUsed() - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- ramCopyOf(Directory) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a copy of directory, entirely in RAM
- RAMDirectory - Class in org.apache.lucene.store
-
- RAMDirectory() - Constructor for class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- RAMDirectory(LockFactory) - Constructor for class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- RAMDirectory(FSDirectory, IOContext) - Constructor for class org.apache.lucene.store.RAMDirectory
-
Deprecated.
Creates a new RAMDirectory
instance from a different
Directory
implementation.
- RAMFile - Class in org.apache.lucene.store
-
- RAMFile() - Constructor for class org.apache.lucene.store.RAMFile
-
Deprecated.
- RAMInputStream - Class in org.apache.lucene.store
-
- RAMInputStream(String, RAMFile) - Constructor for class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- RAMOnlyPostingsFormat - Class in org.apache.lucene.codecs.ramonly
-
Stores all postings data in RAM, but writes a small
token (header + single int) to identify which "slot" the
index is using in RAM HashMap.
- RAMOnlyPostingsFormat() - Constructor for class org.apache.lucene.codecs.ramonly.RAMOnlyPostingsFormat
-
- RAMOutputStream - Class in org.apache.lucene.store
-
- RAMOutputStream() - Constructor for class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
Construct an empty output buffer.
- RAMOutputStream(RAMFile, boolean) - Constructor for class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
Creates this, with no name.
- RAMOutputStream(String, RAMFile, boolean) - Constructor for class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
Creates this, with specified name.
- RamUsageEstimator - Class in org.apache.lucene.util
-
Estimates the size (memory representation) of Java objects.
- RamUsageTester - Class in org.apache.lucene.util
-
Crawls object graph to collect RAM usage for testing
- RamUsageTester() - Constructor for class org.apache.lucene.util.RamUsageTester
-
- RamUsageTester.Accumulator - Class in org.apache.lucene.util
-
An accumulator of object references.
- RANDOM - Static variable in class org.apache.lucene.store.NativePosixUtil
-
- random() - Static method in class org.apache.lucene.util.LuceneTestCase
-
Access to the current RandomizedContext
's Random instance.
- RANDOM_MULTIPLIER - Static variable in class org.apache.lucene.util.LuceneTestCase
-
A random multiplier which you should use when writing random tests:
multiply it by the number of iterations to scale your tests (for nightly builds).
- RandomAcceptedStrings(Automaton) - Constructor for class org.apache.lucene.util.automaton.AutomatonTestUtil.RandomAcceptedStrings
-
- RandomAccessInput - Interface in org.apache.lucene.store
-
Random Access Index API.
- randomAccessSlice(long, long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- randomAccessSlice(long, long) - Method in class org.apache.lucene.store.IndexInput
-
Creates a random-access slice of this index input, with the given offset and length.
- randomAnalysisString(Random, int, boolean) - Static method in class org.apache.lucene.util.TestUtil
-
- RandomApproximationQuery - Class in org.apache.lucene.search
-
A
Query
that adds random approximations to its scorers.
- RandomApproximationQuery(Query, Random) - Constructor for class org.apache.lucene.search.RandomApproximationQuery
-
- randomAutomaton(Random) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
return a random NFA/DFA for testing
- randomBinaryTerm(Random) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a random binary term.
- RandomCodec - Class in org.apache.lucene.index
-
Codec that assigns per-field random postings formats.
- RandomCodec(Random, Set<String>) - Constructor for class org.apache.lucene.index.RandomCodec
-
- RandomCodec(Random) - Constructor for class org.apache.lucene.index.RandomCodec
-
- RandomDocument(int, int, BaseTermVectorsFormatTestCase.Options, String[], String[], BytesRef[]) - Constructor for class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomDocument
-
- RandomDocumentFactory(int, int) - Constructor for class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomDocumentFactory
-
- RandomFacetSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Simple implementation of a random facet source
- RandomFacetSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.RandomFacetSource
-
- randomFilter() - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
Returns a random filter over the document set
- randomFixedByteLengthUnicodeString(Random, int) - Static method in class org.apache.lucene.util.TestUtil
-
Returns random string, with a given UTF-8 byte length
- randomFixedLengthUnicodeString(Random, char[], int, int) - Static method in class org.apache.lucene.util.TestUtil
-
Fills provided char[] with valid random unicode code
unit sequence.
- randomHtmlishString(Random, int) - Static method in class org.apache.lucene.util.TestUtil
-
- randomId() - Static method in class org.apache.lucene.util.StringHelper
-
Generates a non-cryptographic globally unique id.
- RandomIndexWriter - Class in org.apache.lucene.index
-
Silly class that randomizes the indexing experience.
- RandomIndexWriter(Random, Directory) - Constructor for class org.apache.lucene.index.RandomIndexWriter
-
create a RandomIndexWriter with a random config: Uses MockAnalyzer
- RandomIndexWriter(Random, Directory, Analyzer) - Constructor for class org.apache.lucene.index.RandomIndexWriter
-
create a RandomIndexWriter with a random config
- RandomIndexWriter(Random, Directory, IndexWriterConfig) - Constructor for class org.apache.lucene.index.RandomIndexWriter
-
create a RandomIndexWriter with the provided config
- RandomIndexWriter(Random, Directory, IndexWriterConfig, boolean) - Constructor for class org.apache.lucene.index.RandomIndexWriter
-
create a RandomIndexWriter with the provided config
- RandomIndexWriter.TestPoint - Interface in org.apache.lucene.index
-
Simple interface that is executed for each
TP InfoStream
component
message.
- randomInstance(Random, int, int, boolean, int) - Static method in class org.apache.lucene.codecs.compressing.CompressingCodec
-
Create a random instance.
- randomInstance(Random) - Static method in class org.apache.lucene.codecs.compressing.CompressingCodec
-
- randomInstance(Random, boolean) - Static method in class org.apache.lucene.codecs.compressing.CompressingCodec
-
- randomLocale(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Return a random Locale from the available locales on the system.
- randomlyRecaseCodePoints(Random, String) - Static method in class org.apache.lucene.util.TestUtil
-
Randomly upcases, downcases, or leaves intact each code point in the given string
- randomOptions() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- randomPattern(Random) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a valid (compiling) Pattern instance with random stuff inside.
- randomPayload() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- RandomPostingsTester - Class in org.apache.lucene.index
-
Helper class extracted from BasePostingsFormatTestCase to exercise a postings format.
- RandomPostingsTester(Random) - Constructor for class org.apache.lucene.index.RandomPostingsTester
-
- RandomPostingsTester.FieldAndTerm - Class in org.apache.lucene.index
-
Holds one field, term and ord.
- RandomPostingsTester.Option - Enum in org.apache.lucene.index
-
Which features to test.
- RandomPostingsTester.SeedPostings - Class in org.apache.lucene.index
-
Given the same random seed this always enumerates the
same random postings
- randomRealisticUnicodeString(Random) - Static method in class org.apache.lucene.util.TestUtil
-
Returns random string of length between 0-20 codepoints, all codepoints within the same unicode block.
- randomRealisticUnicodeString(Random, int) - Static method in class org.apache.lucene.util.TestUtil
-
Returns random string of length up to maxLength codepoints , all codepoints within the same unicode block.
- randomRealisticUnicodeString(Random, int, int) - Static method in class org.apache.lucene.util.TestUtil
-
Returns random string of length between min and max codepoints, all codepoints within the same unicode block.
- randomRegexp(Random) - Static method in class org.apache.lucene.util.automaton.AutomatonTestUtil
-
Returns random string, including full unicode range.
- randomRegexpishString(Random) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a String thats "regexpish" (contains lots of operators typically found in regular expressions)
If you call this enough times, you might get a valid regex!
- randomRegexpishString(Random, int) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a String thats "regexpish" (contains lots of operators typically found in regular expressions)
If you call this enough times, you might get a valid regex!
- RandomSamplingFacetsCollector - Class in org.apache.lucene.facet
-
Collects hits for subsequent faceting, using sampling if needed.
- RandomSamplingFacetsCollector(int) - Constructor for class org.apache.lucene.facet.RandomSamplingFacetsCollector
-
Constructor with the given sample size and default seed.
- RandomSamplingFacetsCollector(int, long) - Constructor for class org.apache.lucene.facet.RandomSamplingFacetsCollector
-
Constructor with the given sample size and seed.
- RandomSimilarity - Class in org.apache.lucene.search.similarities
-
Similarity implementation that randomizes Similarity implementations
per-field.
- RandomSimilarity(Random) - Constructor for class org.apache.lucene.search.similarities.RandomSimilarity
-
- randomSimpleString(Random, int) - Static method in class org.apache.lucene.util.TestUtil
-
- randomSimpleString(Random, int, int) - Static method in class org.apache.lucene.util.TestUtil
-
- randomSimpleString(Random) - Static method in class org.apache.lucene.util.TestUtil
-
- randomSimpleStringRange(Random, char, char, int) - Static method in class org.apache.lucene.util.TestUtil
-
- randomSubString(Random, int, boolean) - Static method in class org.apache.lucene.util.TestUtil
-
- randomTerm() - Method in class org.apache.lucene.search.SearchEquivalenceTestBase
-
returns a term suitable for searching.
- randomTimeZone(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Return a random TimeZone from the available timezones on the system
- RandomTokenStream(int, String[], BytesRef[]) - Constructor for class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- randomUnicodeString(Random) - Static method in class org.apache.lucene.util.TestUtil
-
Returns random string, including full unicode range.
- randomUnicodeString(Random, int) - Static method in class org.apache.lucene.util.TestUtil
-
Returns a random string up to a certain length.
- Range - Class in org.apache.lucene.facet.range
-
Base class for a single labeled range.
- Range(String) - Constructor for class org.apache.lucene.facet.range.Range
-
Sole constructor.
- Range - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
Lexical state.
- Range - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
Lexical state.
- Range() - Constructor for class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- range(int, int) - Static method in class org.apache.lucene.search.DocIdSetIterator
-
A
DocIdSetIterator
that matches a range documents from
minDocID (inclusive) to maxDocID (exclusive).
- RANGE_GOOP - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RANGE_GOOP - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGE_QUOTED - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RANGE_QUOTED - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGE_TO - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RANGE_TO - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEEX_END - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RANGEEX_END - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEEX_START - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RANGEEX_START - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RangeFacetsExample - Class in org.apache.lucene.demo.facet
-
Shows simple usage of dynamic range faceting.
- RangeFacetsExample() - Constructor for class org.apache.lucene.demo.facet.RangeFacetsExample
-
Empty constructor
- RANGEIN_END - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RANGEIN_END - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RANGEIN_START - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RANGEIN_START - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RangeMapFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
RangeMapFloatFunction
implements a map function over
another
ValueSource
whose values fall within min and max inclusive to target.
- RangeMapFloatFunction(ValueSource, float, float, float, Float) - Constructor for class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- RangeMapFloatFunction(ValueSource, float, float, ValueSource, ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- RangeQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- RangeQueryBuilder() - Constructor for class org.apache.lucene.queryparser.xml.builders.RangeQueryBuilder
-
- RangeQueryNode<T extends FieldValuePairQueryNode<?>> - Interface in org.apache.lucene.queryparser.flexible.core.nodes
-
This interface should be implemented by a
QueryNode
that represents
some kind of range query.
- rarely(Random) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns true if something should happen rarely,
- rarely() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- RateLimitedIndexOutput - Class in org.apache.lucene.store
-
- RateLimitedIndexOutput(RateLimiter, IndexOutput) - Constructor for class org.apache.lucene.store.RateLimitedIndexOutput
-
- RateLimiter - Class in org.apache.lucene.store
-
Abstract base class to rate limit IO.
- RateLimiter() - Constructor for class org.apache.lucene.store.RateLimiter
-
- RateLimiter.SimpleRateLimiter - Class in org.apache.lucene.store
-
Simple class to rate limit IO.
- RawDirectoryWrapper - Class in org.apache.lucene.store
-
Delegates all operations, even optional ones, to the wrapped directory.
- RawDirectoryWrapper(Directory) - Constructor for class org.apache.lucene.store.RawDirectoryWrapper
-
- read() - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.charfilter.HTMLStripCharFilter
-
- read() - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilter
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilter
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.fa.PersianCharFilter
-
- read() - Method in class org.apache.lucene.analysis.fa.PersianCharFilter
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.icu.ICUNormalizer2CharFilter
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.ja.JapaneseIterationMarkCharFilter
-
- read() - Method in class org.apache.lucene.analysis.ja.JapaneseIterationMarkCharFilter
-
- read() - Method in class org.apache.lucene.analysis.MockCharFilter
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.MockCharFilter
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.MockReaderWrapper
-
- read(char[], int, int) - Method in class org.apache.lucene.analysis.pattern.PatternReplaceCharFilter
-
- read() - Method in class org.apache.lucene.analysis.pattern.PatternReplaceCharFilter
-
- read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.FieldInfosFormat
-
- read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50FieldInfosFormat
-
- read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50SegmentInfoFormat
-
Deprecated.
- read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.lucene60.Lucene60FieldInfosFormat
-
- read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.lucene62.Lucene62SegmentInfoFormat
-
- read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.lucene70.Lucene70SegmentInfoFormat
-
- read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.SegmentInfoFormat
-
- read(Directory, SegmentInfo, String, IOContext) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextFieldInfosFormat
-
- read(Directory, String, byte[], IOContext) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextSegmentInfoFormat
-
- read(ByteBuffer, long, A, CompletionHandler<Integer, ? super A>) - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- read(ByteBuffer, long) - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- read(ByteBuffer) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- read(ByteBuffer[], int, int) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- read(ByteBuffer, long) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- read() - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- read(byte[]) - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- read(byte[], int, int) - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- read(ByteBuffer) - Method in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
- read() - Method in class org.apache.lucene.replicator.IndexInputInputStream
-
- read(byte[]) - Method in class org.apache.lucene.replicator.IndexInputInputStream
-
- read(byte[], int, int) - Method in class org.apache.lucene.replicator.IndexInputInputStream
-
- READ - Static variable in class org.apache.lucene.store.IOContext
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- read(Path, Outputs<T>) - Static method in class org.apache.lucene.util.fst.FST
-
Reads an automaton from a file.
- read(DataInput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.NoOutputs
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.PairOutputs
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-
- read(DataInput) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
-
- readAttributes(Path, Class<A>, LinkOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- readAttributes(Path, String, LinkOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- readBitSet(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a bitset from a stream.
- readBool(String, boolean) - Static method in class org.apache.lucene.spatial.query.SpatialArgsParser
-
- readBoolean(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a boolean from a stream.
- readByte() - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- readByte() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readByte(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readByte() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- readByte() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readByte(long) - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readByte() - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- readByte(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- readByte() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readByte(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readByte() - Method in class org.apache.lucene.store.DataInput
-
Reads and returns a single byte.
- readByte() - Method in class org.apache.lucene.store.InputStreamDataInput
-
- readByte() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readByte() - Method in class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- readByte(long) - Method in interface org.apache.lucene.store.RandomAccessInput
-
Reads a byte at the given position in the file
- readByte(long) - Method in class org.apache.lucene.util.ByteBlockPool
-
Read a single byte at the given offset
.
- readByte() - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-
- readByteArray(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read byte array.
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readBytes(ByteBuffer, int) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
Reads exactly len
bytes into the given buffer.
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.DataInput
-
Reads a specified number of bytes into an array at the specified offset.
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.DataInput
-
Reads a specified number of bytes into an array at the
specified offset with control over whether the read
should be buffered (callers who have their own buffer
should pass in "false" for useBuffer).
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.InputStreamDataInput
-
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readBytes(byte[], int, int, boolean) - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readBytes(byte[], int, int) - Method in class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- readBytes(long, byte[], int, int) - Method in class org.apache.lucene.util.ByteBlockPool
-
Reads bytes bytes out of the pool starting at the given offset with the given
length into the given byte array at offset off.
- readBytes(byte[], int, int) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-
- readCeilArc(int, FST<T>, FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Static method in class org.apache.lucene.util.fst.Util
-
Reads the first arc greater or equal that the given label into the provided
arc in place and returns it iff found, otherwise return null
.
- readCell(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- readCell(BytesRef, Cell) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- readCell(BytesRef) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- readCell(BytesRef, Cell) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- readCell(BytesRef, Cell) - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
This creates a new Cell (or re-using scratch
if provided), initialized to the state as read
by the bytes.
- readChar() - Method in class org.apache.lucene.analysis.MockTokenizer
-
- readChar() - Method in interface org.apache.lucene.queryparser.classic.CharStream
-
Returns the next character from the selected input.
- readChar() - Method in class org.apache.lucene.queryparser.classic.FastCharStream
-
- readChar() - Method in interface org.apache.lucene.queryparser.flexible.standard.parser.CharStream
-
Returns the next character from the selected input.
- readChar() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.FastCharStream
-
- readChar() - Method in interface org.apache.lucene.queryparser.surround.parser.CharStream
-
Returns the next character from the selected input.
- readChar() - Method in class org.apache.lucene.queryparser.surround.parser.FastCharStream
-
- readCircle(DataInput) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dBinaryCodec
-
- readClass(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read the class from the stream
- readCodePoint() - Method in class org.apache.lucene.analysis.MockTokenizer
-
- readCollection(DataInput) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dBinaryCodec
-
- readCommit(Directory, String) - Static method in class org.apache.lucene.index.SegmentInfos
-
Read a particular segmentFileName.
- readCommit(Directory, ChecksumIndexInput, long) - Static method in class org.apache.lucene.index.SegmentInfos
-
- readDouble(String) - Static method in class org.apache.lucene.spatial.query.SpatialArgsParser
-
- readDouble(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a double from a stream.
- reader - Variable in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
- reader() - Method in class org.apache.lucene.index.CompositeReaderContext
-
- reader() - Method in class org.apache.lucene.index.IndexReaderContext
-
- reader() - Method in class org.apache.lucene.index.LeafReaderContext
-
- reader - Static variable in class org.apache.lucene.search.BaseExplanationTestCase
-
- reader - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- reader - Variable in class org.apache.lucene.search.suggest.DocumentDictionary
-
- Reader() - Constructor for class org.apache.lucene.util.packed.PackedInts.Reader
-
- readerBase(int) - Method in class org.apache.lucene.index.BaseCompositeReader
-
Helper method for subclasses to get the docBase of the given sub-reader index.
- readerContext - Variable in class org.apache.lucene.search.IndexSearcher
-
- readerIndex(int) - Method in class org.apache.lucene.index.BaseCompositeReader
-
Helper method for subclasses to get the corresponding reader for a doc ID
- readerIndex - Variable in class org.apache.lucene.index.ReaderSlice
-
Sub-reader index for this slice.
- ReaderManager - Class in org.apache.lucene.index
-
Utility class to safely share
DirectoryReader
instances across
multiple threads, while periodically reopening.
- ReaderManager(IndexWriter) - Constructor for class org.apache.lucene.index.ReaderManager
-
Creates and returns a new ReaderManager from the given
IndexWriter
.
- ReaderManager(IndexWriter, boolean, boolean) - Constructor for class org.apache.lucene.index.ReaderManager
-
Expert: creates and returns a new ReaderManager from the given
IndexWriter
, controlling whether past deletions should be applied.
- ReaderManager(Directory) - Constructor for class org.apache.lucene.index.ReaderManager
-
Creates and returns a new ReaderManager from the given
Directory
.
- ReaderManager(DirectoryReader) - Constructor for class org.apache.lucene.index.ReaderManager
-
Creates and returns a new ReaderManager from the given
already-opened
DirectoryReader
, stealing
the incoming reference.
- readerPooling - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
True if readers should be pooled.
- ReaderSlice - Class in org.apache.lucene.index
-
Subreader slice from a parent composite reader.
- ReaderSlice(int, int, int) - Constructor for class org.apache.lucene.index.ReaderSlice
-
Sole constructor.
- ReaderUtil - Class in org.apache.lucene.index
-
- readerValue() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- readerValue() - Method in class org.apache.lucene.document.Field
-
The value of the field as a Reader, or null.
- readerValue() - Method in class org.apache.lucene.document.LazyDocument.LazyField
-
- readerValue() - Method in interface org.apache.lucene.index.IndexableField
-
Non-null if this field has a Reader value
- readFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- readFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
-
- readFirstRealTargetArc(long, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-
- readFirstTargetArc(FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-
Follow the follow
arc and read the first arc of its target;
this changes the provided arc
(2nd arg) in-place and returns
it.
- readFooter(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
-
Retrieves the full footer from the provided
IndexInput
.
- readHeterogeneousArray(PlanetModel, InputStream, Class<T>) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read an array.
- readHomogeneousArray(PlanetModel, InputStream, Class<T>) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read an array.
- readIndexHeader(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
-
Retrieves the full index header from the provided
IndexInput
.
- ReadingAttribute - Interface in org.apache.lucene.analysis.ja.tokenattributes
-
Attribute for Kuromoji reading data
- ReadingAttribute - Interface in org.apache.lucene.analysis.ko.tokenattributes
-
Attribute for Korean reading data
- ReadingAttributeImpl - Class in org.apache.lucene.analysis.ja.tokenattributes
-
Attribute for Kuromoji reading data
- ReadingAttributeImpl() - Constructor for class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
-
- ReadingAttributeImpl - Class in org.apache.lucene.analysis.ko.tokenattributes
-
Attribute for Korean reading data
- ReadingAttributeImpl() - Constructor for class org.apache.lucene.analysis.ko.tokenattributes.ReadingAttributeImpl
-
- readInt(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read an int from a stream.
- readInt() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readInt(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readInt() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- readInt() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readInt(long) - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readInt(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- readInt() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readInt(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readInt() - Method in class org.apache.lucene.store.DataInput
-
Reads four bytes and returns an int.
- readInt() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readInt(long) - Method in interface org.apache.lucene.store.RandomAccessInput
-
Reads an integer at the given position in the file
- readInt() - Method in class org.apache.lucene.util.IntBlockPool.SliceReader
-
Reads the next int from the current slice and returns it.
- readInternal(byte[], int, int) - Method in class org.apache.lucene.store.BufferedIndexInput
-
Expert: implements buffer refill.
- readLabel(DataInput) - Method in class org.apache.lucene.util.fst.FST
-
Reads one BYTE1/2/4 label from the provided
DataInput
.
- readLastTargetArc(FST.Arc<T>, FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-
Follows the follow
arc and reads the last
arc of its target; this changes the provided
arc
(2nd arg) in-place and returns it.
- readLatestCommit(Directory) - Static method in class org.apache.lucene.index.SegmentInfos
-
- readLeafAdjust() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- readLeafAdjust() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
- readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.asserting.AssertingLiveDocsFormat
-
- readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.LiveDocsFormat
-
Read live docs bits.
- readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.lucene50.Lucene50LiveDocsFormat
-
- readLiveDocs(Directory, SegmentCommitInfo, IOContext) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextLiveDocsFormat
-
- readLocalFileMetaData(String) - Method in class org.apache.lucene.replicator.nrt.Node
-
Opens the specified file, reads its identifying information, including file length, full index header (includes the unique segment
ID) and the full footer (includes checksum), and returns the resulting
FileMetaData
.
- readLong(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a long from a stream.
- readLong() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readLong(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readLong() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- readLong() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readLong(long) - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readLong(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- readLong() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readLong(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readLong() - Method in class org.apache.lucene.store.DataInput
-
Reads eight bytes and returns a long.
- readLong() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readLong(long) - Method in interface org.apache.lucene.store.RandomAccessInput
-
Reads a long at the given position in the file
- readLong(int) - Method in class org.apache.lucene.util.packed.PackedDataInput
-
Read the next long using exactly bitsPerValue
bits.
- readMapOfStrings() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readMapOfStrings() - Method in class org.apache.lucene.store.DataInput
-
- readMapOfStrings() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readNameValuePairs(SpatialArgs, Map<String, String>) - Method in class org.apache.lucene.spatial.query.SpatialArgsParser
-
- readNextArc(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-
In-place read; returns the arc.
- readNextArcLabel(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-
Peeks at next arc's label; does not alter arc.
- readNextRealArc(FST.Arc<T>, FST.BytesReader) - Method in class org.apache.lucene.util.fst.FST
-
Never returns null, but you should never call this if
arc.isLast() is true.
- readObject(PlanetModel, InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read an object from a stream (for objects that need a PlanetModel).
- readObject(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read an object from a stream (for objects that do not need a PlanetModel).
- readObject(PlanetModel, InputStream, Class<?>) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Instantiate a serializable object from a stream.
- readObject(InputStream, Class<?>) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Instantiate a serializable object from a stream without a planet model.
- readOnce - Variable in class org.apache.lucene.store.IOContext
-
- READONCE - Static variable in class org.apache.lucene.store.IOContext
-
- readPackedValue(int, byte[]) - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- readPayload - Variable in class org.apache.lucene.search.spans.TermSpans
-
- readPlanetObject(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a PlanetObject from a stream.
- readPoint(DataInput) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dBinaryCodec
-
- readPointArray(PlanetModel, InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a point array.
- readPolygonArray(PlanetModel, InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a polygon array.
- readQueries(BufferedReader) - Method in class org.apache.lucene.benchmark.quality.trec.Trec1MQReader
-
Read quality queries from trec 1MQ format topics file.
- readQueries(BufferedReader) - Method in class org.apache.lucene.benchmark.quality.trec.TrecTopicsReader
-
Read quality queries from trec format topics file.
- readRect(DataInput) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dBinaryCodec
-
- readSetOfStrings() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readSetOfStrings() - Method in class org.apache.lucene.store.DataInput
-
- readSetOfStrings() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readShape(BytesRef) - Method in class org.apache.lucene.spatial.prefix.PointPrefixTreeFieldCacheProvider
-
- readShape(DataInput) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dBinaryCodec
-
- readShape(BytesRef) - Method in class org.apache.lucene.spatial.util.ShapeFieldCacheProvider
-
- readShort() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readShort(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readShort() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- readShort() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readShort(long) - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readShort(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- readShort() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readShort(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readShort() - Method in class org.apache.lucene.store.DataInput
-
Reads two bytes and returns a short.
- readShort() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readShort(long) - Method in interface org.apache.lucene.store.RandomAccessInput
-
Reads a short at the given position in the file
- readSkipData(int, IndexInput) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Subclasses must implement the actual skip data encoding in this method.
- readString(InputStream) - Static method in interface org.apache.lucene.spatial3d.geom.SerializableObject
-
Read a string from a stream.
- readString() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readString() - Method in class org.apache.lucene.store.DataInput
-
Reads a string.
- readString() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readSymbolicLink(Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- ReadTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Read index (abstract) task.
- ReadTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
- readTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
time spent in i/o read (in milliseconds)
- readToken(StringBuilder) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- ReadTokensTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Simple task to test performance of tokenizers.
- ReadTokensTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ReadTokensTask
-
- readVInt() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readVInt() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- readVInt() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readVInt() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readVInt() - Method in class org.apache.lucene.store.DataInput
-
Reads an int stored in variable-length format.
- readVInt() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readVLong() - Method in class org.apache.lucene.store.BufferedIndexInput
-
- readVLong() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- readVLong() - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- readVLong() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readVLong() - Method in class org.apache.lucene.store.DataInput
-
Reads a long stored in variable-length format.
- readVLong() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- ready() - Method in class org.apache.lucene.analysis.MockReaderWrapper
-
- readZInt() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readZInt() - Method in class org.apache.lucene.store.DataInput
-
- readZInt() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- readZLong() - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- readZLong() - Method in class org.apache.lucene.store.DataInput
-
- readZLong() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- reap() - Method in class org.apache.lucene.util.WeakIdentityMap
-
This method manually cleans up the reference queue to remove all garbage
collected key/value pairs from the map.
- reason - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- reasonableInstance(Random) - Static method in class org.apache.lucene.codecs.compressing.CompressingCodec
-
Creates a random
CompressingCodec
with more reasonable parameters for big tests.
- RECCNT - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- ReciprocalDoubleValuesSource - Class in org.apache.lucene.spatial.util
-
Transforms a DoubleValuesSource using the formula v = k / (v + k)
- ReciprocalDoubleValuesSource(double, DoubleValuesSource) - Constructor for class org.apache.lucene.spatial.util.ReciprocalDoubleValuesSource
-
Creates a ReciprocalDoubleValuesSource
- ReciprocalFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
ReciprocalFloatFunction
implements a reciprocal function f(x) = a/(mx+b), based on
the float value of a field or function as exported by
ValueSource
.
- ReciprocalFloatFunction(ValueSource, float, float, float) - Constructor for class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
f(source) = a/(m*float(source)+b)
- recompose(List<SrndQuery>) - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- record(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
-
Records that you are now using this IndexSearcher.
- recordBounds(PlanetModel, XYZBounds, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Accumulate (x,y,z) bounds information for this plane, intersected with another and the
world.
- recordBounds(PlanetModel, XYZBounds, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Accumulate (x,y,z) bounds information for this plane, intersected with the unit sphere.
- recordBounds(PlanetModel, LatLonBounds, Plane, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Accumulate bounds information for this plane, intersected with another plane
and the world.
- recordBounds(PlanetModel, LatLonBounds, Membership...) - Method in class org.apache.lucene.spatial3d.geom.Plane
-
Accumulate bounds information for this plane, intersected with the unit sphere.
- RECSEC - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- rect(Point, Point) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- rect(double, double, double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
- Rectangle - Class in org.apache.lucene.geo
-
Represents a lat/lon rectangle.
- Rectangle(double, double, double, double) - Constructor for class org.apache.lucene.geo.Rectangle
-
Constructs a bounding box by first validating the provided latitude and longitude coordinates
- Rectangle2D - Class in org.apache.lucene.geo
-
2D rectangle implementation containing spatial logic.
- rectCrosses(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial.util.GeoRelationUtils
-
Computes whether two rectangles cross
- rectIntersects(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial.util.GeoRelationUtils
-
Computes whether a rectangle intersects another rectangle (crosses, within, touching, etc)
- rectWithin(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial.util.GeoRelationUtils
-
Computes whether the first (a) rectangle is wholly within another (b) rectangle (shared boundaries allowed)
- RecursivePrefixTreeStrategy - Class in org.apache.lucene.spatial.prefix
-
- RecursivePrefixTreeStrategy(SpatialPrefixTree, String) - Constructor for class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
-
- recycleByteBlocks(List<byte[]>) - Method in class org.apache.lucene.util.ByteBlockPool.Allocator
-
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectAllocator
-
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.ByteBlockPool.DirectTrackingAllocator
-
- recycleByteBlocks(byte[][], int, int) - Method in class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.IntBlockPool.Allocator
-
- recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.IntBlockPool.DirectAllocator
-
- recycleIntBlocks(int[][], int, int) - Method in class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- RecyclingByteBlockAllocator - Class in org.apache.lucene.util
-
- RecyclingByteBlockAllocator(int, int, Counter) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- RecyclingByteBlockAllocator(int, int) - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- RecyclingByteBlockAllocator() - Constructor for class org.apache.lucene.util.RecyclingByteBlockAllocator
-
- RecyclingIntBlockAllocator - Class in org.apache.lucene.util
-
- RecyclingIntBlockAllocator(int, int, Counter) - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- RecyclingIntBlockAllocator(int, int) - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- RecyclingIntBlockAllocator() - Constructor for class org.apache.lucene.util.RecyclingIntBlockAllocator
-
- reduce(Collection<FacetsCollector>) - Method in class org.apache.lucene.facet.FacetsCollectorManager
-
- reduce(Collection<C>) - Method in interface org.apache.lucene.search.CollectorManager
-
Reduce the results of individual collectors into a meaningful result.
- reduce(Collection<MultiCollectorManager.Collectors>) - Method in class org.apache.lucene.search.MultiCollectorManager
-
- reduce(Reduce) - Method in class org.egothor.stemmer.MultiTrie
-
Remove empty rows from the given Trie and return the newly reduced Trie.
- reduce(Reduce) - Method in class org.egothor.stemmer.MultiTrie2
-
Remove empty rows from the given Trie and return the newly reduced Trie.
- Reduce - Class in org.egothor.stemmer
-
The Reduce object is used to remove gaps in a Trie which stores a dictionary.
- Reduce() - Constructor for class org.egothor.stemmer.Reduce
-
Constructor for the Reduce object.
- reduce(Reduce) - Method in class org.egothor.stemmer.Trie
-
Remove empty rows from the given Trie and return the newly reduced Trie.
- reduceOpenFiles(IndexWriter) - Static method in class org.apache.lucene.util.TestUtil
-
just tries to configure things to keep the open file
count lowish
- RefCount<T> - Class in org.apache.lucene.util
-
Manages reference counting for a given object.
- RefCount(T) - Constructor for class org.apache.lucene.util.RefCount
-
- refCounts - Variable in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Records how many snapshots are held against each
commit generation
- ReferenceManager<G> - Class in org.apache.lucene.search
-
Utility class to safely share instances of a certain type across multiple
threads, while periodically refreshing them.
- ReferenceManager() - Constructor for class org.apache.lucene.search.ReferenceManager
-
- ReferenceManager.RefreshListener - Interface in org.apache.lucene.search
-
Use to receive notification when a refresh has
finished.
- reflect(Class<? extends Attribute>, String, Object) - Method in interface org.apache.lucene.util.AttributeReflector
-
- reflectAsString(boolean) - Method in class org.apache.lucene.util.AttributeImpl
-
This method returns the current attribute values as a string in the following format
by calling the
AttributeImpl.reflectWith(AttributeReflector)
method:
iff prependAttClass=true
: "AttributeClass#key=value,AttributeClass#key=value"
iff prependAttClass=false
: "key=value,key=value"
- reflectAsString(boolean) - Method in class org.apache.lucene.util.AttributeSource
-
This method returns the current attribute values as a string in the following format
by calling the
AttributeSource.reflectWith(AttributeReflector)
method:
iff prependAttClass=true
: "AttributeClass#key=value,AttributeClass#key=value"
iff prependAttClass=false
: "key=value,key=value"
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase.CheckClearAttributesAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.ko.tokenattributes.ReadingAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.Token
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.BoostAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.util.AttributeImpl
-
This method is for introspection of attributes, it should simply
add the key/values this attribute holds to the given
AttributeReflector
.
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.util.AttributeSource
-
This method is for introspection of attributes, it should simply
add the key/values this AttributeSource holds to the given
AttributeReflector
.
- refresh() - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Reopens the underlying searcher; it's best to "batch
up" many additions/updates, and then call refresh
once in the end.
- refreshIfNeeded(SearcherTaxonomyManager.SearcherAndTaxonomy) - Method in class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
- refreshIfNeeded(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-
- refreshIfNeeded(G) - Method in class org.apache.lucene.search.ReferenceManager
-
Refresh the given reference if needed.
- refreshIfNeeded(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
-
- RegexCompletionQuery - Class in org.apache.lucene.search.suggest.document
-
A
CompletionQuery
which takes a regular expression
as the prefix of the query term.
- RegexCompletionQuery(Term) - Constructor for class org.apache.lucene.search.suggest.document.RegexCompletionQuery
-
- RegexCompletionQuery(Term, BitsProducer) - Constructor for class org.apache.lucene.search.suggest.document.RegexCompletionQuery
-
- RegexCompletionQuery(Term, int, int) - Constructor for class org.apache.lucene.search.suggest.document.RegexCompletionQuery
-
- RegexCompletionQuery(Term, int, int, BitsProducer) - Constructor for class org.apache.lucene.search.suggest.document.RegexCompletionQuery
-
Constructs a regular expression completion query
- RegExp - Class in org.apache.lucene.util.automaton
-
Regular Expression extension to Automaton
.
- RegExp(String) - Constructor for class org.apache.lucene.util.automaton.RegExp
-
Constructs new RegExp
from a string.
- RegExp(String, int) - Constructor for class org.apache.lucene.util.automaton.RegExp
-
Constructs new RegExp
from a string.
- RegexpQuery - Class in org.apache.lucene.search
-
- RegexpQuery(Term) - Constructor for class org.apache.lucene.search.RegexpQuery
-
Constructs a query for terms matching term
.
- RegexpQuery(Term, int) - Constructor for class org.apache.lucene.search.RegexpQuery
-
Constructs a query for terms matching term
.
- RegexpQuery(Term, int, int) - Constructor for class org.apache.lucene.search.RegexpQuery
-
Constructs a query for terms matching term
.
- RegexpQuery(Term, int, AutomatonProvider, int) - Constructor for class org.apache.lucene.search.RegexpQuery
-
Constructs a query for terms matching term
.
- RegexpQueryNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
- RegexpQueryNode(CharSequence, CharSequence, int, int) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- RegexpQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- RegexpQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.RegexpQueryNodeBuilder
-
- RegexpQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
Processor for Regexp queries.
- RegexpQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.RegexpQueryNodeProcessor
-
- REGEXPTERM - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- REGEXPTERM - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- region - Variable in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter.Heatmap
-
- register(TermState, int, int, long) - Method in class org.apache.lucene.index.TermContext
-
Registers and associates a
TermState
with an leaf ordinal.
- register(TermState, int) - Method in class org.apache.lucene.index.TermContext
-
Expert: Registers and associates a
TermState
with an leaf ordinal.
- register(WatchService, WatchEvent.Kind<?>[], WatchEvent.Modifier...) - Method in class org.apache.lucene.mockfile.FilterPath
-
- register(WatchService, WatchEvent.Kind<?>...) - Method in class org.apache.lucene.mockfile.FilterPath
-
- register(String) - Method in class org.apache.lucene.spatial.query.SpatialOperation
-
- registerParentReader(IndexReader) - Method in class org.apache.lucene.index.IndexReader
-
Expert: This method is called by IndexReader
s which wrap other readers
(e.g.
- rehash() - Method in class org.apache.lucene.util.SentinelIntSet
-
(internal) Rehashes by doubling int[] key
and filling with the old values.
- rehashCount - Variable in class org.apache.lucene.util.SentinelIntSet
-
the count at which a rehash should be done
- reinit(Token) - Method in class org.apache.lucene.analysis.Token
-
Copy the prototype token's fields into this one.
- reinit(boolean) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- ReInit(CharStream) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
Reinitialise.
- ReInit(QueryParserTokenManager) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
Reinitialise.
- ReInit(CharStream) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- ReInit(CharStream) - Method in class org.apache.lucene.queryparser.classic.QueryParserTokenManager
-
Reinitialise parser.
- ReInit(CharStream, int) - Method in class org.apache.lucene.queryparser.classic.QueryParserTokenManager
-
Reinitialise parser.
- ReInit(CharStream) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Reinitialise.
- ReInit(StandardSyntaxParserTokenManager) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Reinitialise.
- ReInit(CharStream) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
Reinitialise parser.
- ReInit(CharStream, int) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
Reinitialise parser.
- ReInit(CharStream) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
Reinitialise.
- ReInit(QueryParserTokenManager) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
Reinitialise.
- ReInit(CharStream) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParserTokenManager
-
Reinitialise parser.
- ReInit(CharStream, int) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParserTokenManager
-
Reinitialise parser.
- reinit() - Method in class org.apache.lucene.util.BytesRefHash
-
- reInitCache(int, boolean) - Method in class org.apache.lucene.classification.CachingNaiveBayesClassifier
-
This function is building the frame of the cache.
- reject(Thread) - Method in class org.apache.lucene.util.QuickPatchThreadsFilter
-
- relate(double, double, double, double) - Method in class org.apache.lucene.geo.EdgeTree
-
Returns relation to the provided rectangle
- relate(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.GeoUtils
-
Compute the relation between the provided box and distance query.
- relate(BaseRangeFieldQueryTestCase.Range) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- relate(Shape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- relate(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- relate(NumberRangePrefixTree.SpanUnitsNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- relate(Shape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- relate(NumberRangePrefixTree.SpanUnitsNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- relate(Shape) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- relateRangeBBox(int, int, byte[], int, int, byte[]) - Method in class org.apache.lucene.geo.Rectangle2D
-
compare this to a provided rangle bounding box
- relateTriangle(double, double, double, double, double, double) - Method in class org.apache.lucene.geo.EdgeTree
-
Returns relation to the provided triangle
- relateXRange(double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- relateYRange(double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- relationship - Variable in class org.apache.lucene.search.Scorer.ChildScorer
-
An arbitrary string relating this scorer to the parent.
- relatives - Variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Deprecated.
The relative nodes.
- relativize(Path) - Method in class org.apache.lucene.mockfile.FilterPath
-
- release(IndexCommit) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Deletes a snapshotted commit.
- release(long) - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Deletes a snapshotted commit by generation.
- release(IndexCommit) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Release a snapshotted commit.
- release(String) - Method in class org.apache.lucene.replicator.http.HttpReplicator
-
- release() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- release() - Method in class org.apache.lucene.replicator.IndexRevision
-
- release(String) - Method in class org.apache.lucene.replicator.LocalReplicator
-
- release(String) - Method in interface org.apache.lucene.replicator.Replicator
-
Notify that the specified
SessionToken
is no longer needed by the
caller.
- release() - Method in interface org.apache.lucene.replicator.Revision
-
Called when this revision can be safely released, i.e.
- release(G) - Method in class org.apache.lucene.search.ReferenceManager
-
- release(IndexSearcher) - Method in class org.apache.lucene.search.SearcherLifetimeManager
-
- release(ShardSearchingTestBase.NodeState.ShardIndexSearcher) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- release() - Method in class org.apache.lucene.util.RefCount
-
Called when reference counting hits 0.
- releaseCopyState(CopyState) - Method in class org.apache.lucene.replicator.nrt.PrimaryNode
-
Called once replica is done (or failed) copying an NRT point
- releaseGen(long) - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Release a snapshot by generation.
- releaseSearcher(IndexSearcher) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- RELEVANCE - Static variable in class org.apache.lucene.search.Sort
-
Represents sorting by computed relevance.
- RelevanceComparator(int) - Constructor for class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
Creates a new comparator based on relevance for numHits
.
- reload(ClassLoader) - Method in class org.apache.lucene.analysis.util.AnalysisSPILoader
-
Reloads the internal SPI list from the given ClassLoader
.
- reload(ClassLoader) - Method in class org.apache.lucene.util.NamedSPILoader
-
Reloads the internal SPI list from the given ClassLoader
.
- reloadCharFilters(ClassLoader) - Static method in class org.apache.lucene.analysis.util.CharFilterFactory
-
Reloads the factory list from the given ClassLoader
.
- reloadCodecs(ClassLoader) - Static method in class org.apache.lucene.codecs.Codec
-
Reloads the codec list from the given ClassLoader
.
- reloadDocValuesFormats(ClassLoader) - Static method in class org.apache.lucene.codecs.DocValuesFormat
-
Reloads the DocValues format list from the given ClassLoader
.
- reloadPostingsFormats(ClassLoader) - Static method in class org.apache.lucene.codecs.PostingsFormat
-
Reloads the postings format list from the given ClassLoader
.
- reloadTokenFilters(ClassLoader) - Static method in class org.apache.lucene.analysis.util.TokenFilterFactory
-
Reloads the factory list from the given ClassLoader
.
- reloadTokenizers(ClassLoader) - Static method in class org.apache.lucene.analysis.util.TokenizerFactory
-
Reloads the factory list from the given ClassLoader
.
- remove() - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
-
- remove(Object) - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
-
- remove(Object) - Method in class org.apache.lucene.analysis.CharArrayMap
-
- remove() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource.Iterator
-
- remove(String[]) - Method in class org.apache.lucene.index.IndexSplitter
-
- remove(SegmentCommitInfo) - Method in class org.apache.lucene.index.SegmentInfos
-
- remove(Object) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- remove(int) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- remove(String) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Removes the value indexed by key.
- remove() - Method in class org.apache.lucene.spatial.prefix.tree.CellIterator
-
This prevents sub-cells (those underneath the current cell) from being iterated to,
if applicable, otherwise a NO-OP.
- remove() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PrefixTreeIterator
-
- remove() - Method in class org.apache.lucene.util.FilterIterator
-
- remove() - Method in class org.apache.lucene.util.MergedIterator
-
- remove(T) - Method in class org.apache.lucene.util.PriorityQueue
-
Removes an existing element currently stored in the PriorityQueue.
- remove() - Method in class org.apache.lucene.util.SPIClassIterator
-
- remove(Object) - Method in class org.apache.lucene.util.WeakIdentityMap
-
Removes the mapping for a key from this weak hash map if it is present.
- removeAll(Collection<?>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- removeAllAttributes() - Method in class org.apache.lucene.util.AttributeSource
-
Removes all attributes and their implementations from this AttributeSource.
- removeChildren(QueryNode) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
Remove a child node
- removeChildren(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- removeDeadStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Removes transitions to dead states (a state is "dead" if it is not
reachable from the initial state or no accept state is reachable from it.)
- RemoveDeletedQueryNodesProcessor - Class in org.apache.lucene.queryparser.flexible.core.processors
-
- RemoveDeletedQueryNodesProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.core.processors.RemoveDeletedQueryNodesProcessor
-
- RemoveDuplicatesTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
-
A TokenFilter which filters out Tokens at the same position and Term text as the previous token in the stream.
- RemoveDuplicatesTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.RemoveDuplicatesTokenFilter
-
Creates a new RemoveDuplicatesTokenFilter
- RemoveDuplicatesTokenFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- RemoveDuplicatesTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.RemoveDuplicatesTokenFilterFactory
-
Creates a new RemoveDuplicatesTokenFilterFactory
- removeEldestEntry(Map.Entry<K, V>) - Method in class org.apache.lucene.facet.taxonomy.LRUHashMap
-
- RemoveEmptyNonLeafQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
This processor removes every
QueryNode
that is not a leaf and has not
children.
- RemoveEmptyNonLeafQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
-
- removeField(String) - Method in class org.apache.lucene.document.Document
-
Removes field with the specified name from the document.
- removeFields(String) - Method in class org.apache.lucene.document.Document
-
Removes all fields with the given name from the document.
- removeFromParent() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
Removes this query node from its parent.
- removeFromParent() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- removeIndexInput(IndexInput, String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- removeIndexOutput(IndexOutput, String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- removeListener(ReferenceManager.RefreshListener) - Method in class org.apache.lucene.search.ReferenceManager
-
- rename(String, String) - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- rename(String, String) - Method in class org.apache.lucene.store.Directory
-
Renames source
file to dest
file where
dest
must not already exist in the directory.
- rename(String, String) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- rename(String, String) - Method in class org.apache.lucene.store.FilterDirectory
-
- rename(String, String) - Method in class org.apache.lucene.store.FSDirectory
-
- rename(String, String) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
-
- rename(String, String) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- rename(String, String) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- rename(String, String) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- rename(String, String) - Method in class org.apache.lucene.store.TrackingDirectoryWrapper
-
- reopen() - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- ReopenReaderTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Reopens IndexReader and closes old IndexReader.
- ReopenReaderTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ReopenReaderTask
-
- RepAllTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Report all statistics with no aggregations.
- RepAllTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.RepAllTask
-
- repeat(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton that accepts the Kleene star (zero or more
concatenated repetitions) of the language of the given automaton.
- repeat(Automaton, int) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton that accepts min
or more concatenated
repetitions of the language of the given automaton.
- repeat(Automaton, int, int) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton that accepts between min
and
max
(including both) concatenated repetitions of the language
of the given automaton.
- REPEAT_EXHAUST - Static variable in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- replace(char[], int) - Method in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
-
- replace_s(int, int, CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
-
- replaceLast(int, Builder.Node, T, boolean) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- replaceMaxFailureRule(TestRuleIgnoreAfterMaxFailures) - Static method in class org.apache.lucene.util.LuceneTestCase
-
- replacement - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
-
- replaceTaxonomy(Directory) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Replaces the current taxonomy with the given one.
- replay(Collector) - Method in class org.apache.lucene.search.CachingCollector
-
Replays the cached doc IDs (and scores) to the given Collector.
- ReplicaNode - Class in org.apache.lucene.replicator.nrt
-
Replica node, that pulls index changes from the primary node by copying newly flushed or merged index files.
- ReplicaNode(int, Directory, SearcherFactory, PrintStream) - Constructor for class org.apache.lucene.replicator.nrt.ReplicaNode
-
- REPLICATE_FILENAME_PARAM - Static variable in class org.apache.lucene.replicator.http.ReplicationService
-
Request parameter name for providing the file's name.
- REPLICATE_SESSION_ID_PARAM - Static variable in class org.apache.lucene.replicator.http.ReplicationService
-
Request parameter name for providing a session ID.
- REPLICATE_SOURCE_PARAM - Static variable in class org.apache.lucene.replicator.http.ReplicationService
-
Request parameter name for providing the file's source.
- REPLICATE_VERSION_PARAM - Static variable in class org.apache.lucene.replicator.http.ReplicationService
-
Request parameter name for providing the revision version.
- REPLICATION_CONTEXT - Static variable in class org.apache.lucene.replicator.http.ReplicationService
-
The context path for the servlet.
- ReplicationClient - Class in org.apache.lucene.replicator
-
A client which monitors and obtains new revisions from a
Replicator
.
- ReplicationClient(Replicator, ReplicationClient.ReplicationHandler, ReplicationClient.SourceDirectoryFactory) - Constructor for class org.apache.lucene.replicator.ReplicationClient
-
Constructor.
- ReplicationClient.ReplicationHandler - Interface in org.apache.lucene.replicator
-
Handler for revisions obtained by the client.
- ReplicationClient.SourceDirectoryFactory - Interface in org.apache.lucene.replicator
-
Resolves a session and source into a
Directory
to use for copying
the session files to.
- ReplicationService - Class in org.apache.lucene.replicator.http
-
A server-side service for handling replication requests.
- ReplicationService(Map<String, Replicator>) - Constructor for class org.apache.lucene.replicator.http.ReplicationService
-
- ReplicationService.ReplicationAction - Enum in org.apache.lucene.replicator.http
-
- Replicator - Interface in org.apache.lucene.replicator
-
An interface for replicating files.
- Report - Class in org.apache.lucene.benchmark.byTask.stats
-
Textual report of current statistics.
- Report(String, int, int, int) - Constructor for class org.apache.lucene.benchmark.byTask.stats.Report
-
- report(QualityQuery, TopDocs, String, IndexSearcher) - Method in class org.apache.lucene.benchmark.quality.utils.SubmissionReport
-
Report a search result for a certain quality query.
- reportAll(List<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepAllTask
-
Report detailed statistics as a string
- reportSelectByPrefix(List<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSelectByPrefTask
-
- reportSumByName(List<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByNameTask
-
Report statistics as a string, aggregate for tasks named the same.
- reportSumByNameRound(List<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByNameRoundTask
-
Report statistics as a string, aggregate for tasks named the same, and from the same round.
- reportSumByPrefix(List<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
-
- reportSumByPrefixRound(List<TaskStats>) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefRoundTask
-
- ReportTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Report (abstract) task - all report tasks extend this task.
- ReportTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- RepSelectByPrefTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Report by-name-prefix statistics with no aggregations.
- RepSelectByPrefTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.RepSelectByPrefTask
-
- RepSumByNameRoundTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Report all statistics grouped/aggregated by name and round.
- RepSumByNameRoundTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.RepSumByNameRoundTask
-
- RepSumByNameTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Report all statistics aggregated by name.
- RepSumByNameTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.RepSumByNameTask
-
- RepSumByPrefRoundTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Report all prefix matching statistics grouped/aggregated by name and round.
- RepSumByPrefRoundTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefRoundTask
-
- RepSumByPrefTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Report by-name-prefix statistics aggregated by name.
- RepSumByPrefTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
-
- reqB(Query) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO: Wraps a Query in a BooleanQuery so that it is required, along
with a second optional clause which will match everything
- require(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- require(Map<String, String>, String, Collection<String>) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- require(Map<String, String>, String, Collection<String>, boolean) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- requireBoolean(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- requireChar(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- requiredFiles(Map<String, List<RevisionFile>>) - Method in class org.apache.lucene.replicator.ReplicationClient
-
Returns the files required for replication.
- requireDimCount - Variable in class org.apache.lucene.facet.FacetsConfig.DimConfig
-
True if the count/aggregate for the entire dimension
is required, which is unusual (default is false).
- requireDimensionDrillDown - Variable in class org.apache.lucene.facet.FacetsConfig.DimConfig
-
True if drilling down by a whole dimension, to match all
documents that had any value for this dimension, is necessary
(default is true)
- requireFloat(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- requireInt(Map<String, String>, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- requiresRewrite(SpanQuery) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.QueryRescorer
-
- rescore(IndexSearcher, TopDocs, Query, double, int) - Static method in class org.apache.lucene.search.QueryRescorer
-
Sugar API, calling {#rescore} using a simple linear
combination of firstPassScore + weight * secondPassScore
- rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.Rescorer
-
Rescore an initial first-pass
TopDocs
.
- rescore(IndexSearcher, TopDocs, int) - Method in class org.apache.lucene.search.SortRescorer
-
- Rescorer - Class in org.apache.lucene.search
-
Re-scores the topN results (
TopDocs
) from an original
query.
- Rescorer() - Constructor for class org.apache.lucene.search.Rescorer
-
- reserve(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- reset() - Method in class org.apache.lucene.analysis.CachingTokenFilter
-
Propagates reset if incrementToken has not yet been called.
- reset() - Method in class org.apache.lucene.analysis.CharacterUtils.CharacterBuffer
-
Resets the CharacterBuffer.
- reset() - Method in class org.apache.lucene.analysis.charfilter.MappingCharFilter
-
- reset() - Method in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
- reset() - Method in class org.apache.lucene.analysis.cn.smart.HMMChineseTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.commongrams.CommonGramsFilter
-
- reset() - Method in class org.apache.lucene.analysis.commongrams.CommonGramsQueryFilter
-
- reset() - Method in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- reset() - Method in class org.apache.lucene.analysis.core.FlattenGraphFilter
-
- reset() - Method in class org.apache.lucene.analysis.core.KeywordTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.CrankyTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.FilteringTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.hunspell.HunspellStemFilter
-
- reset() - Method in class org.apache.lucene.analysis.icu.segmentation.ICUTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.ja.JapaneseNumberFilter
-
- reset() - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.ko.KoreanTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
-
- reset() - Method in class org.apache.lucene.analysis.LookaheadTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.minhash.MinHashFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.ASCIIFoldingFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenatingTokenStream
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.FingerprintFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.FixBrokenOffsetsFilter
-
Deprecated.
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.HyphenatedWordsFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.KeywordRepeatFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenCountFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenPositionFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.RemoveDuplicatesTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.TypeAsSynonymFilter
-
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- reset() - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
- reset() - Method in class org.apache.lucene.analysis.MockGraphTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.MockHoleInjectingTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.MockRandomLookaheadTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.MockSynonymFilter
-
- reset() - Method in class org.apache.lucene.analysis.MockTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.MockTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.morfologik.MorfologikFilter
-
Resets stems accumulator and hands over to superclass.
- reset() - Method in class org.apache.lucene.analysis.ngram.EdgeNGramTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.ngram.NGramTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.ngram.NGramTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.path.PathHierarchyTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.pattern.PatternCaptureGroupTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.pattern.PatternTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.pattern.SimplePatternTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.phonetic.BeiderMorseFilter
-
- reset() - Method in class org.apache.lucene.analysis.phonetic.DaitchMokotoffSoundexFilter
-
- reset() - Method in class org.apache.lucene.analysis.phonetic.DoubleMetaphoneFilter
-
- reset() - Method in class org.apache.lucene.analysis.phonetic.PhoneticFilter
-
- reset() - Method in class org.apache.lucene.analysis.shingle.FixedShingleFilter
-
- reset() - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
- reset() - Method in class org.apache.lucene.analysis.SimplePayloadFilter
-
- reset() - Method in class org.apache.lucene.analysis.sinks.TeeSinkTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.sinks.TeeSinkTokenFilter.SinkTokenStream
-
- reset() - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.synonym.SynonymFilter
-
Deprecated.
- reset() - Method in class org.apache.lucene.analysis.synonym.SynonymGraphFilter
-
- reset() - Method in class org.apache.lucene.analysis.TokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.Tokenizer
-
- reset() - Method in class org.apache.lucene.analysis.TokenStream
-
- reset() - Method in class org.apache.lucene.analysis.util.CharTokenizer
-
- reset() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- reset(Reader) - Method in class org.apache.lucene.analysis.util.RollingCharBuffer
-
Clear array and switch to new reader.
- reset() - Method in class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
- reset() - Method in class org.apache.lucene.analysis.ValidatingTokenFilter
-
- reset() - Method in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- reset() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomTokenStream
-
- reset() - Method in class org.apache.lucene.index.DocIDMerger
-
Reuse API, currently only used by postings during merge
- reset() - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Resets the
MemoryIndex
to its initial state and recycles all internal buffers.
- reset(MultiPostingsEnum.EnumWithSlice[], int) - Method in class org.apache.lucene.index.MultiPostingsEnum
-
Re-use and reset this instance on the provided slices.
- reset(MultiTermsEnum.TermsEnumIndex[]) - Method in class org.apache.lucene.index.MultiTermsEnum
-
- reset() - Method in class org.apache.lucene.index.QueryTimeoutImpl
-
Reset the timeout value.
- reset() - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- reset() - Method in class org.apache.lucene.payloads.PayloadSpanCollector
-
- reset() - Method in class org.apache.lucene.search.highlight.OffsetLimitTokenFilter
-
- reset() - Method in class org.apache.lucene.search.highlight.TokenStreamFromTermVector
-
- reset() - Method in interface org.apache.lucene.search.spans.SpanCollector
-
Call to indicate that the driving Spans has moved to a new position
- reset() - Method in class org.apache.lucene.search.suggest.analyzing.SuggestStopFilter
-
- reset() - Method in class org.apache.lucene.search.uhighlight.Passage
-
- reset(Iterator<Cell>) - Method in class org.apache.lucene.spatial.prefix.CellToBytesRefIterator
-
- reset(double, double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dCircleShape
-
- reset(double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dPointShape
-
- reset(double, double, double, double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dRectangleShape
-
- reset() - Method in class org.apache.lucene.store.BufferedChecksum
-
- reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- reset(byte[]) - Method in class org.apache.lucene.store.ByteArrayDataOutput
-
- reset(byte[], int, int) - Method in class org.apache.lucene.store.ByteArrayDataOutput
-
- reset() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
This method resets this object to a clean (zero-size) state and
publishes any currently allocated buffers for reuse to the reuse strategy
provided in the constructor.
- reset() - Method in class org.apache.lucene.store.GrowableByteArrayDataOutput
-
- reset() - Method in class org.apache.lucene.store.MockDirectoryWrapper.Failure
-
reset should set the state of the failure to its default
(freshly constructed) state.
- reset() - Method in class org.apache.lucene.store.RAMOutputStream
-
Deprecated.
Resets this to an empty file.
- reset() - Method in class org.apache.lucene.util.ByteBlockPool
-
- reset(boolean, boolean) - Method in class org.apache.lucene.util.ByteBlockPool
-
Expert: Resets the pool to its initial state reusing the first buffer.
- reset() - Method in class org.apache.lucene.util.IntBlockPool
-
Resets the pool to its initial state reusing the first buffer.
- reset(boolean, boolean) - Method in class org.apache.lucene.util.IntBlockPool
-
Expert: Resets the pool to its initial state reusing the first buffer.
- reset(int, int) - Method in class org.apache.lucene.util.IntBlockPool.SliceReader
-
Resets the reader to a slice give the slices absolute start and end offset in the pool
- reset(int) - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
-
- reset(Random) - Method in class org.apache.lucene.util.LineFileDocs
-
- reset(DataInput, long) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
-
Reset the current reader to wrap a stream of valueCount
values contained in in
.
- reset() - Method in class org.apache.lucene.util.RollingBuffer
-
- reset() - Method in interface org.apache.lucene.util.RollingBuffer.Resettable
-
- resetDefaultQueryCache() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- resetFailures() - Static method in class org.apache.lucene.util.FailureMarker
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Resets the input for this content source, so that the test would behave as
if it was just started, input-wise.
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
Reset inputs so that the test run would behave, input wise, as if it just started.
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.EnwikiContentSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.FacetSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishContentSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
-
- resetInputs() - Method in interface org.apache.lucene.benchmark.byTask.feeds.QueryMaker
-
Reset inputs so that the test run would behave, input wise, as if it just started.
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.ReutersContentSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.SingleDocSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- resetInputs() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- ResetInputsTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Reset inputs so that the test run would behave, input wise,
as if it just started.
- ResetInputsTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ResetInputsTask
-
- resetMaxUsedSizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- resetSkip() - Method in class org.apache.lucene.codecs.MultiLevelSkipListWriter
-
Creates new buffers or empties the existing ones
- ResetSystemEraseTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Reset all index and input data and call gc, erase index and dir, does NOT clear statistics.
- ResetSystemEraseTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ResetSystemEraseTask
-
- ResetSystemSoftTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Reset all index and input data and call gc, does NOT erase index/dir, does NOT clear statistics.
- ResetSystemSoftTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.ResetSystemSoftTask
-
- resize(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- resize(long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
Create a new copy of size newSize
based on the content of
this buffer.
- resize(int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- resizeBuffer(int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Grows the termBuffer to at least size newSize, preserving the
existing content.
- resizeBuffer(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- resolve(Path) - Method in class org.apache.lucene.mockfile.FilterPath
-
- resolve(String) - Method in class org.apache.lucene.mockfile.FilterPath
-
- resolveDistErr(SpatialContext, double) - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
Gets the error distance that specifies how precise the query shape is.
- resolveEntity(String, String) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- resolveSibling(Path) - Method in class org.apache.lucene.mockfile.FilterPath
-
- resolveSibling(String) - Method in class org.apache.lucene.mockfile.FilterPath
-
- resolveTag(String) - Static method in class org.apache.lucene.analysis.ko.POS
-
Returns the
POS.Tag
of the provided
name
.
- resolveTag(byte) - Static method in class org.apache.lucene.analysis.ko.POS
-
Returns the
POS.Tag
of the provided
tag
.
- resolveType(String) - Static method in class org.apache.lucene.analysis.ko.POS
-
Returns the
POS.Type
of the provided
name
.
- resolveType(byte) - Static method in class org.apache.lucene.analysis.ko.POS
-
Returns the
POS.Type
of the provided
type
.
- ResourceLoader - Interface in org.apache.lucene.analysis.util
-
Abstraction for loading resources (streams, files, and classes).
- ResourceLoaderAware - Interface in org.apache.lucene.analysis.util
-
Interface for a component that needs to be initialized by
an implementation of
ResourceLoader
.
- responseInputStream(HttpResponse) - Method in class org.apache.lucene.replicator.http.HttpClientBase
-
Internal utility: input stream of the provided response
- responseInputStream(HttpResponse, boolean) - Method in class org.apache.lucene.replicator.http.HttpClientBase
-
Internal utility: input stream of the provided response, which optionally
consumes the response's resources when the input stream is exhausted.
- restore(int, int) - Method in class org.apache.lucene.util.TimSorter
-
Restore element j
from the temporary storage into slot i
.
- restoreCPUCoreCount() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- restoreIndexWriterMaxDocs() - Method in class org.apache.lucene.util.LuceneTestCase
-
- restoreMaxDocs() - Static method in class org.apache.lucene.index.IndexWriterMaxDocsChanger
-
- restoreSpins() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- restoreState(AttributeSource.State) - Method in class org.apache.lucene.util.AttributeSource
-
Restores this state by copying the values of all attribute implementations
that this state contains into the attributes implementations of the targetStream.
- Result(IntsRef, T) - Constructor for class org.apache.lucene.util.fst.Util.Result
-
- retainAll(Collection<?>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- reThrow(Throwable) - Static method in class org.apache.lucene.util.IOUtils
-
- Rethrow - Class in org.apache.lucene.util
-
Sneaky: rethrowing checked exceptions as unchecked
ones.
- rethrow(Throwable) - Static method in class org.apache.lucene.util.Rethrow
-
Rethrows t
(identical object).
- rethrowAlways(Throwable) - Static method in class org.apache.lucene.util.IOUtils
-
This utility method takes a previously caught (non-null)
Throwable
and rethrows either the original argument
if it was a subclass of the IOException
or an
RuntimeException
with the cause set to the argument.
- reThrowUnchecked(Throwable) - Static method in class org.apache.lucene.util.IOUtils
-
- retrieveChecksum(IndexInput) - Static method in class org.apache.lucene.codecs.CodecUtil
-
- retrieveDoc(IndexReader, int) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
- retrieveDoc(IndexReader, int) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetLoadFieldSelectorTask
-
- retrieveGroupHeads(int) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- retrieveGroupHeads() - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- retrieveInterestingTerms(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
- retrieveInterestingTerms(Reader, String) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Convenience routine to make it easy to return the most interesting words in a document.
- reuse(ByteBuffer) - Method in class org.apache.lucene.store.ByteBuffersDataOutput.ByteBufferRecycler
-
- reuseFields - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- ReuseStrategy() - Constructor for class org.apache.lucene.analysis.Analyzer.ReuseStrategy
-
Sole constructor.
- ReutersContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
- ReutersContentSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.ReutersContentSource
-
- ReutersQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
A QueryMaker that makes queries devised manually (by Grant Ingersoll) for
searching in the Reuters collection.
- ReutersQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.ReutersQueryMaker
-
- reverse(String) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Reverses the given input string
- reverse(char[]) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Reverses the given input buffer in-place
- reverse(char[], int) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Partially reverses the given input buffer in-place from offset 0
up to the given length.
- reverse(char[], int, int) - Static method in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Partially reverses the given input buffer in-place from the given offset
up to the given length.
- reverse(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns an automaton accepting the reverse language.
- reversed - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- reversed() - Method in class org.apache.lucene.util.fst.FST.BytesReader
-
Returns true if this reader uses reversed bytes
under-the-hood.
- reverseModify(PlanetModel, Vector, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.spatial3d.geom.Plane
-
Reverse modify a point to produce a GeoPoint in normal space.
- reverseMul - Variable in class org.apache.lucene.search.FieldValueHitQueue
-
- ReversePathHierarchyTokenizer - Class in org.apache.lucene.analysis.path
-
Tokenizer for domain-like hierarchies.
- ReversePathHierarchyTokenizer() - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(int, char) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(char, char) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(int, char, char) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(char, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(char, char, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(AttributeFactory, char, char, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(int, char, char, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReversePathHierarchyTokenizer(AttributeFactory, int, char, char, int) - Constructor for class org.apache.lucene.analysis.path.ReversePathHierarchyTokenizer
-
- ReverseStringFilter - Class in org.apache.lucene.analysis.reverse
-
Reverse token string, for example "country" => "yrtnuoc".
- ReverseStringFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Create a new ReverseStringFilter that reverses all tokens in the
supplied
TokenStream
.
- ReverseStringFilter(TokenStream, char) - Constructor for class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Create a new ReverseStringFilter that reverses and marks all tokens in the
supplied
TokenStream
.
- ReverseStringFilterFactory - Class in org.apache.lucene.analysis.reverse
-
- ReverseStringFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.reverse.ReverseStringFilterFactory
-
Creates a new ReverseStringFilterFactory
- Revision - Interface in org.apache.lucene.replicator
-
A revision comprises lists of files that come from different sources and need
to be replicated together to e.g.
- RevisionFile - Class in org.apache.lucene.replicator
-
- RevisionFile(String) - Constructor for class org.apache.lucene.replicator.RevisionFile
-
Constructor with the given file name.
- revisionFiles(IndexCommit, IndexCommit) - Static method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
Returns a singleton map of the revision files from the given
IndexCommit
.
- revisionFiles(IndexCommit) - Static method in class org.apache.lucene.replicator.IndexRevision
-
Returns a singleton map of the revision files from the given
IndexCommit
.
- revisionReady(String, Map<String, List<RevisionFile>>, Map<String, List<String>>, Map<String, Directory>) - Method in class org.apache.lucene.replicator.IndexAndTaxonomyReplicationHandler
-
- revisionReady(String, Map<String, List<RevisionFile>>, Map<String, List<String>>, Map<String, Directory>) - Method in class org.apache.lucene.replicator.IndexReplicationHandler
-
- revisionReady(String, Map<String, List<RevisionFile>>, Map<String, List<String>>, Map<String, Directory>) - Method in interface org.apache.lucene.replicator.ReplicationClient.ReplicationHandler
-
Called when a new revision was obtained and is available (i.e.
- revisionVersion(IndexCommit, IndexCommit) - Static method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
Returns a String representation of a revision's version from the given
IndexCommit
s of the search and taxonomy indexes.
- revisionVersion(IndexCommit) - Static method in class org.apache.lucene.replicator.IndexRevision
-
Returns a String representation of a revision's version from the given
IndexCommit
.
- rewind() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree.Iterator
-
- rewind() - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- rewrite(IndexReader) - Method in class org.apache.lucene.classification.utils.NearestFuzzyQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.facet.DrillDownQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.BoostingQuery
-
Deprecated.
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.function.BoostedQuery
-
Deprecated.
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.function.FunctionScoreQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.sandbox.queries.FuzzyLikeThisQuery
-
- rewrite(Query) - Method in class org.apache.lucene.search.AssertingIndexSearcher
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.AssertingQuery
-
- rewrite(Query[]) - Method in class org.apache.lucene.search.BlendedTermQuery.DisjunctionMaxRewrite
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.BlendedTermQuery
-
- rewrite(Query[]) - Method in class org.apache.lucene.search.BlendedTermQuery.RewriteMethod
-
Merge the provided sub queries into a single
Query
object.
- rewrite(IndexReader) - Method in class org.apache.lucene.search.BooleanQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.BoostQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.ConstantScoreQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.CoveringQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Optimize our representation and our subqueries representations
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.DocValuesRewriteMethod
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.search.DoubleValuesSource
-
Return a DoubleValuesSource specialised for the given IndexSearcher
Implementations should assume that this will only be called once.
- rewrite(IndexReader) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
-
- rewrite(Query) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: called to re-write queries into primitive queries.
- rewrite(IndexReader) - Method in class org.apache.lucene.search.join.ParentChildrenBlockJoinQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.search.LongValuesSource
-
Return a LongValuesSource specialised for the given IndexSearcher
Implementations should assume that this will only be called once.
- rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiPhraseQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.MultiTermQuery
-
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.MultiTermQuery.RewriteMethod
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.NGramPhraseQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.PhraseQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.Query
-
Expert: called to re-write queries into primitive queries.
- rewrite(IndexReader) - Method in class org.apache.lucene.search.RandomApproximationQuery
-
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.ScoringRewrite
-
- rewrite(Query) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.search.Sort
-
Rewrites the SortFields in this Sort, returning a new Sort if any of the fields
changes during their rewriting.
- rewrite(IndexSearcher) - Method in class org.apache.lucene.search.SortField
-
Rewrites this SortField, returning a new SortField if a change is made.
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.AssertingSpanQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanBoostQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.SpanRewriteMethod
-
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.spans.SpanPositionCheckQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.suggest.document.CompletionQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.SynonymQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
- rewrite(IndexReader) - Method in class org.apache.lucene.search.TermInSetQuery
-
- rewrite(IndexReader, MultiTermQuery) - Method in class org.apache.lucene.search.TopTermsRewrite
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
- rewrite(IndexReader) - Method in class org.apache.lucene.spatial.composite.CompositeVerifyQuery
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.spatial.util.CachingDoubleValueSource
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.spatial.util.DistanceToShapeValueSource
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.spatial.util.ReciprocalDoubleValuesSource
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.spatial.util.ShapeAreaValueSource
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.spatial.util.ShapeFieldCacheDistanceValueSource
-
- rewrite(IndexSearcher) - Method in class org.apache.lucene.spatial.vector.DistanceValueSource
-
- RewriteMethod() - Constructor for class org.apache.lucene.search.BlendedTermQuery.RewriteMethod
-
Sole constructor
- rewriteMethod - Variable in class org.apache.lucene.search.MultiTermQuery
-
- RewriteMethod() - Constructor for class org.apache.lucene.search.MultiTermQuery.RewriteMethod
-
- right - Variable in class org.apache.lucene.geo.EdgeTree
-
- RIGHT_ID - Static variable in class org.apache.lucene.analysis.ja.dict.UserDictionary
-
- RIGHT_ID - Static variable in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- RIGHT_ID_F - Static variable in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- RIGHT_ID_T - Static variable in class org.apache.lucene.analysis.ko.dict.UserDictionary
-
- rm(Path...) - Static method in class org.apache.lucene.util.IOUtils
-
Deletes one or more files or directories (and everything underneath it).
- RoaringDocIdSet - Class in org.apache.lucene.util
-
DocIdSet
implementation inspired from http://roaringbitmap.org/
The space is divided into blocks of 2^16 bits and each block is encoded
independently.
- RoaringDocIdSet.Builder - Class in org.apache.lucene.util
-
- rollback() - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Rollback changes to the taxonomy writer and closes the instance.
- rollback() - Method in class org.apache.lucene.index.IndexWriter
-
Close the IndexWriter
without committing
any changes that have occurred since the last commit
(or since it was opened, if commit hasn't been called).
- rollback() - Method in interface org.apache.lucene.index.TwoPhaseCommit
-
Discards any changes that have occurred since the last commit.
- RollbackIndexTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Rollback the index writer.
- RollbackIndexTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.RollbackIndexTask
-
- RollingBuffer<T extends RollingBuffer.Resettable> - Class in org.apache.lucene.util
-
Acts like forever growing T[], but internally uses a
circular buffer to reuse instances of T.
- RollingBuffer() - Constructor for class org.apache.lucene.util.RollingBuffer
-
- RollingBuffer.Resettable - Interface in org.apache.lucene.util
-
Implement to reset an instance
- RollingCharBuffer - Class in org.apache.lucene.analysis.util
-
Acts like a forever growing char[] as you read
characters into it from the provided reader, but
internally it uses a circular buffer to only hold the
characters that haven't been freed yet.
- RollingCharBuffer() - Constructor for class org.apache.lucene.analysis.util.RollingCharBuffer
-
- rollup() - Method in class org.apache.lucene.facet.taxonomy.FloatTaxonomyFacets
-
Rolls up any single-valued hierarchical dimensions.
- rollup() - Method in class org.apache.lucene.facet.taxonomy.IntTaxonomyFacets
-
Rolls up any single-valued hierarchical dimensions.
- RomanianAnalyzer - Class in org.apache.lucene.analysis.ro
-
- RomanianAnalyzer() - Constructor for class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
- RomanianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
Builds an analyzer with the given stop words.
- RomanianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.ro.RomanianAnalyzer
-
Builds an analyzer with the given stop words.
- RomanianStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- RomanianStemmer() - Constructor for class org.tartarus.snowball.ext.RomanianStemmer
-
- root - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- ROOT_ORDINAL - Static variable in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
The root category (the category with the empty path) always has the ordinal
0, to which we give a name ROOT_ORDINAL.
- rotateXY(double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Rotate vector counter-clockwise in x-y by an angle.
- rotateXY(double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Rotate vector counter-clockwise in x-y by an angle, expressed as sin and cos.
- rotateXZ(double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Rotate vector counter-clockwise in x-z by an angle.
- rotateXZ(double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Rotate vector counter-clockwise in x-z by an angle, expressed as sin and cos.
- rotateZY(double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Rotate vector counter-clockwise in z-y by an angle.
- rotateZY(double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Rotate vector counter-clockwise in z-y by an angle, expressed as sin and cos.
- ROUND - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- round(Date, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Limit a date's resolution.
- round(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Limit a date's resolution.
- roundDownX(double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Round the provided X value down, by encoding it, decrementing it, and unencoding it.
- roundDownY(double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Round the provided Y value down, by encoding it, decrementing it, and unencoding it.
- roundDownZ(double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Round the provided Z value down, by encoding it, decrementing it, and unencoding it.
- roundToLevel(int) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- roundToLevel(int) - Method in interface org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRShape
-
Returns this shape rounded to the target level.
- roundToLevel(int) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- roundToLevel(int) - Method in interface org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.UnitNRShape
-
- roundUpX(double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Round the provided X value up, by encoding it, incrementing it, and unencoding it.
- roundUpY(double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Round the provided Y value up, by encoding it, incrementing it, and unencoding it.
- roundUpZ(double) - Static method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Round the provided Z value up, by encoding it, incrementing it, and unencoding it.
- Row - Class in org.egothor.stemmer
-
The Row class represents a row in a matrix representation of a trie.
- Row(DataInput) - Constructor for class org.egothor.stemmer.Row
-
Construct a Row object from input carried in via the given input stream.
- Row() - Constructor for class org.egothor.stemmer.Row
-
The default constructor for the Row object.
- Row(Row) - Constructor for class org.egothor.stemmer.Row
-
Construct a Row using the cells of the given Row.
- rows - Variable in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter.Heatmap
-
- RPAREN - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
-
- RPAREN - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- RPAREN - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- RPAREN - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- RSLPStemmerBase - Class in org.apache.lucene.analysis.pt
-
Base class for stemmers that use a set of RSLP-like stemming steps.
- RSLPStemmerBase() - Constructor for class org.apache.lucene.analysis.pt.RSLPStemmerBase
-
- RSLPStemmerBase.Rule - Class in org.apache.lucene.analysis.pt
-
A basic rule, with no exceptions.
- RSLPStemmerBase.RuleWithSetExceptions - Class in org.apache.lucene.analysis.pt
-
A rule with a set of whole-word exceptions.
- RSLPStemmerBase.RuleWithSuffixExceptions - Class in org.apache.lucene.analysis.pt
-
A rule with a set of exceptional suffixes.
- RSLPStemmerBase.Step - Class in org.apache.lucene.analysis.pt
-
A step containing a list of rules.
- RTL_DIRECTION_MARKER - Static variable in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Example marker character: U+200F (RIGHT-TO-LEFT MARK)
- Rule(String, int, String) - Constructor for class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
-
Create a rule.
- RULE_JAVA - Static variable in class org.apache.lucene.analysis.core.WhitespaceTokenizerFactory
-
- RULE_UNICODE - Static variable in class org.apache.lucene.analysis.core.WhitespaceTokenizerFactory
-
- ruleChain - Variable in class org.apache.lucene.util.LuceneTestCase
-
This controls how individual test rules are nested.
- rules - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
-
- RuleWithSetExceptions(String, int, String, String[]) - Constructor for class org.apache.lucene.analysis.pt.RSLPStemmerBase.RuleWithSetExceptions
-
- RuleWithSuffixExceptions(String, int, String, String[]) - Constructor for class org.apache.lucene.analysis.pt.RSLPStemmerBase.RuleWithSuffixExceptions
-
- run() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler.MergeThread
-
- run() - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
-
- run(IndexCommit) - Method in class org.apache.lucene.index.SegmentInfos.FindSegmentsFile
-
- run(CopyJob) - Method in interface org.apache.lucene.replicator.nrt.CopyJob.OnceDone
-
- run() - Method in class org.apache.lucene.search.ControlledRealTimeReopenThread
-
- run() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
- run(byte[], int, int) - Method in class org.apache.lucene.util.automaton.ByteRunAutomaton
-
Returns true if the given byte array is accepted by this automaton
- run(String) - Method in class org.apache.lucene.util.automaton.CharacterRunAutomaton
-
Returns true if the given string is accepted by this automaton.
- run(char[], int, int) - Method in class org.apache.lucene.util.automaton.CharacterRunAutomaton
-
Returns true if the given string is accepted by this automaton
- run(Automaton, String) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if the given string is accepted by the automaton.
- run(Automaton, IntsRef) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if the given string (expressed as unicode codepoints) is accepted by the automaton.
- run() - Method in interface org.apache.lucene.util.LuceneTestCase.ThrowingRunnable
-
- runAndMaybeStats(boolean) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Run the task, record statistics.
- runAutomaton - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-
Matcher for quickly determining if a byte[] is accepted.
- RunAutomaton - Class in org.apache.lucene.util.automaton
-
Finite-state automaton with fast run operation.
- RunAutomaton(Automaton, int) - Constructor for class org.apache.lucene.util.automaton.RunAutomaton
-
Constructs a new RunAutomaton
from a deterministic
Automaton
.
- RunAutomaton(Automaton, int, int) - Constructor for class org.apache.lucene.util.automaton.RunAutomaton
-
Constructs a new RunAutomaton
from a deterministic
Automaton
.
- runBlocking() - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
Use current thread (blocking) to do all copying and then return once done, or throw exception on failure
- RUNCNT - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- runDrillDown() - Method in class org.apache.lucene.demo.facet.AssociationsFacetsExample
-
Runs the drill-down example.
- runDrillDown() - Method in class org.apache.lucene.demo.facet.SimpleFacetsExample
-
Runs the drill-down example.
- runDrillDown() - Method in class org.apache.lucene.demo.facet.SimpleSortedSetFacetsExample
-
Runs the drill-down example.
- runDrillSideways() - Method in class org.apache.lucene.demo.facet.SimpleFacetsExample
-
Runs the drill-sideways example.
- runFacetOnly() - Method in class org.apache.lucene.demo.facet.SimpleFacetsExample
-
Runs the search example.
- RunListenerPrintReproduceInfo - Class in org.apache.lucene.util
-
A suite listener printing a "reproduce string".
- RunListenerPrintReproduceInfo() - Constructor for class org.apache.lucene.util.RunListenerPrintReproduceInfo
-
- runSearch() - Method in class org.apache.lucene.demo.facet.ExpressionAggregationFacetsExample
-
Runs the search example.
- runSearch() - Method in class org.apache.lucene.demo.facet.MultiCategoryListsFacetsExample
-
Runs the search example.
- runSearch() - Method in class org.apache.lucene.demo.facet.SimpleFacetsExample
-
Runs the search example.
- runSearch() - Method in class org.apache.lucene.demo.facet.SimpleSortedSetFacetsExample
-
Runs the search example.
- runSearchThreads(long) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- runSumAssociations() - Method in class org.apache.lucene.demo.facet.AssociationsFacetsExample
-
Runs summing association example.
- runTest(String) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- runWithRestrictedPermissions(PrivilegedExceptionAction<T>, Permission...) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Runs a code part with restricted permissions (be sure to add all required permissions,
because it would start with empty permissions).
- RussianAnalyzer - Class in org.apache.lucene.analysis.ru
-
- RussianAnalyzer() - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
-
- RussianAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Builds an analyzer with the given stop words
- RussianAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.ru.RussianAnalyzer
-
Builds an analyzer with the given stop words
- RussianLightStemFilter - Class in org.apache.lucene.analysis.ru
-
- RussianLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ru.RussianLightStemFilter
-
- RussianLightStemFilterFactory - Class in org.apache.lucene.analysis.ru
-
- RussianLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ru.RussianLightStemFilterFactory
-
Creates a new RussianLightStemFilterFactory
- RussianLightStemmer - Class in org.apache.lucene.analysis.ru
-
Light Stemmer for Russian.
- RussianLightStemmer() - Constructor for class org.apache.lucene.analysis.ru.RussianLightStemmer
-
- RussianStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- RussianStemmer() - Constructor for class org.tartarus.snowball.ext.RussianStemmer
-
- s - Variable in class org.apache.lucene.search.similarities.Axiomatic
-
hyperparam for the growth function
- s1 - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- s2 - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- safeAcos(double) - Static method in class org.apache.lucene.spatial3d.geom.Tools
-
Java acos yields a NAN if you take an arc-cos of an
angle that's just a tiny bit greater than 1.0, so
here's a more resilient version.
- sameClassAs(Object) - Method in class org.apache.lucene.search.Query
-
Utility method to check whether other
is not null and is exactly
of the same class as this object's class.
- sameLanguage(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if these two automata accept exactly the
same language.
- SameThreadExecutorService - Class in org.apache.lucene.util
-
An ExecutorService
that executes tasks immediately in the calling thread during submit.
- SameThreadExecutorService() - Constructor for class org.apache.lucene.util.SameThreadExecutorService
-
- Sample - Class in org.apache.lucene.benchmark.byTask.programmatic
-
Sample performance test written programmatically - no algorithm file is needed here.
- Sample() - Constructor for class org.apache.lucene.benchmark.byTask.programmatic.Sample
-
- save - Variable in class org.apache.lucene.analysis.phonetic.PhoneticFilter
-
captured state, non-null when inject=true
and a token is buffered
- save(DataOutput) - Method in class org.apache.lucene.util.fst.FST
-
- save(Path) - Method in class org.apache.lucene.util.fst.FST
-
Writes an automaton to a file.
- save(DataOutput) - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- save(DataOutput) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
-
Save this mutable into out
.
- save(int, int) - Method in class org.apache.lucene.util.TimSorter
-
Save all elements between slots i
and i+len
into the temporary storage.
- sc - Variable in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
The character stored in this node: splitchar.
- scale - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The scale of the planet
- ScaleFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
Scales values to be between min and max.
- ScaleFloatFunction(ValueSource, float, float) - Constructor for class org.apache.lucene.queries.function.valuesource.ScaleFloatFunction
-
- scan(int) - Method in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery.VisitorTemplate
-
Scans (termsEnum.next()
) terms until a term is found that does
not start with curVNode's cell.
- ScandinavianFoldingFilter - Class in org.apache.lucene.analysis.miscellaneous
-
This filter folds Scandinavian characters åÅäæÄÆ->a and öÖøØ->o.
- ScandinavianFoldingFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.ScandinavianFoldingFilter
-
- ScandinavianFoldingFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- ScandinavianFoldingFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ScandinavianFoldingFilterFactory
-
- ScandinavianNormalizationFilter - Class in org.apache.lucene.analysis.miscellaneous
-
This filter normalize use of the interchangeable Scandinavian characters æÆäÄöÖøØ
and folded variants (aa, ao, ae, oe and oo) by transforming them to åÅæÆøØ.
- ScandinavianNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.ScandinavianNormalizationFilter
-
- ScandinavianNormalizationFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- ScandinavianNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.ScandinavianNormalizationFilterFactory
-
- scanIsEmpty() - Method in class org.apache.lucene.util.FixedBitSet
-
Scans the backing store to check if all bits are clear.
- scanIsEmpty() - Method in class org.apache.lucene.util.LongBitSet
-
Scans the backing store to check if all bits are clear.
- scheme - Variable in class org.apache.lucene.mockfile.FilterFileStore
-
URI scheme used for this instance.
- scheme - Variable in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
The URI scheme for this provider.
- score - Variable in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- score(List<SegmentCommitInfo>, boolean, Map<SegmentCommitInfo, TieredMergePolicy.SegmentSizeAndDocs>) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Expert: scores one merge; subclasses can override.
- score() - Method in class org.apache.lucene.queries.function.FunctionQuery.AllScorer
-
- score() - Method in class org.apache.lucene.queries.function.ValueSourceScorer
-
- score() - Method in class org.apache.lucene.search.AssertingScorer
-
- score(LeafCollector, Bits) - Method in class org.apache.lucene.search.BulkScorer
-
Scores and collects all matching documents.
- score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.BulkScorer
-
Collects matching documents in a range and return an estimation of the
next matching document which is on or after max
.
- score() - Method in class org.apache.lucene.search.BulkScorerWrapperScorer
-
- score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.ConstantScoreQuery.ConstantBulkScorer
-
- score() - Method in class org.apache.lucene.search.ConstantScoreScorer
-
- score() - Method in class org.apache.lucene.search.ConstantScoreWeight
-
Return the score produced by this
Weight
.
- score() - Method in class org.apache.lucene.search.FilterScorer
-
- score - Variable in class org.apache.lucene.search.grouping.GroupDocs
-
Overall aggregated score of this group (currently only
set by join queries).
- score() - Method in class org.apache.lucene.search.ScoreCachingWrappingScorer
-
- score - Variable in class org.apache.lucene.search.ScoreDoc
-
The score of this document for the query.
- score() - Method in class org.apache.lucene.search.Scorer
-
Returns the score of the current document matching the query.
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffect
-
Returns the aftereffect score.
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectB
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.AfterEffectL
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Axiomatic
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModel
-
Returns the informative content score.
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelBE
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelD
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelG
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIF
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIn
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelIne
-
- score(BasicStats, float) - Method in class org.apache.lucene.search.similarities.BasicModelP
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.DFISimilarity
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Distribution
-
Computes the score.
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.DistributionLL
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.DistributionSPL
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.IBSimilarity
-
- score(float, float) - Method in class org.apache.lucene.search.similarities.Independence
-
Computes distance from independence
- score(float, float) - Method in class org.apache.lucene.search.similarities.IndependenceChiSquared
-
- score(float, float) - Method in class org.apache.lucene.search.similarities.IndependenceSaturated
-
- score(float, float) - Method in class org.apache.lucene.search.similarities.IndependenceStandardized
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.LMDirichletSimilarity
-
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.LMJelinekMercerSimilarity
-
- score(int, float) - Method in class org.apache.lucene.search.similarities.Similarity.SimScorer
-
Score a single document
- score(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
Scores the document doc
.
- score() - Method in class org.apache.lucene.search.spans.SpanScorer
-
- score - Variable in class org.apache.lucene.search.spell.DirectSpellChecker.ScoreTerm
-
The similarity score.
- score - Variable in class org.apache.lucene.search.spell.SuggestWord
-
the score of the word
- score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.suggest.document.CompletionScorer
-
- score(float, float) - Method in class org.apache.lucene.search.suggest.document.CompletionScorer
-
Returns the score for a matched completion
based on the query time boost and the
index time weight.
- score(Passage, int) - Method in class org.apache.lucene.search.uhighlight.PassageScorer
-
- score(LeafCollector, Bits, int, int) - Method in class org.apache.lucene.search.Weight.DefaultBulkScorer
-
- score(Rectangle, AtomicReference<Explanation>) - Method in class org.apache.lucene.spatial.bbox.BBoxOverlapRatioValueSource
-
- score(Rectangle, AtomicReference<Explanation>) - Method in class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
Return a relevancy score.
- ScoreCachingWrappingScorer - Class in org.apache.lucene.search
-
A
Scorer
which wraps another scorer and caches the score of the
current document.
- ScoreCachingWrappingScorer(Scorer) - Constructor for class org.apache.lucene.search.ScoreCachingWrappingScorer
-
Creates a new instance by wrapping the given scorer.
- ScoreComparator() - Constructor for class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder.ScoreComparator
-
- scoreCurrentDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
-
Score the current doc.
- ScoreDoc - Class in org.apache.lucene.search
-
- ScoreDoc(int, float) - Constructor for class org.apache.lucene.search.ScoreDoc
-
Constructs a ScoreDoc.
- ScoreDoc(int, float, int) - Constructor for class org.apache.lucene.search.ScoreDoc
-
Constructs a ScoreDoc.
- ScoreDocKey(int, float) - Constructor for class org.apache.lucene.search.DiversifiedTopDocsCollector.ScoreDocKey
-
- scoreDocs - Variable in class org.apache.lucene.search.grouping.GroupDocs
-
Hits; this may be
FieldDoc
instances if the
withinGroupSort sorted by fields.
- scoreDocs - Variable in class org.apache.lucene.search.TopDocs
-
The top hits for the query.
- scoreLookupDocs() - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocs
-
- ScoreMode - Enum in org.apache.lucene.search.join
-
How to aggregate multiple child hit scores into a single parent score.
- ScoreOrderFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
-
An implementation of FragmentsBuilder that outputs score-order fragments.
- ScoreOrderFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder
-
a constructor.
- ScoreOrderFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder
-
a constructor.
- ScoreOrderFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder
-
- ScoreOrderFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.ScoreOrderFragmentsBuilder
-
- ScoreOrderFragmentsBuilder.ScoreComparator - Class in org.apache.lucene.search.vectorhighlight
-
- scorePayload(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
The default implementation returns 1
- scorePayload(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
-
The default implementation returns 1
- scorePayload(int, int, int, BytesRef) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Deprecated.
- scorer(LeafReaderContext) - Method in class org.apache.lucene.queries.function.FunctionQuery.FunctionWeight
-
- scorer(LeafReaderContext) - Method in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
-
- scorer - Variable in class org.apache.lucene.search.DisiWrapper
-
- scorer(LeafReaderContext) - Method in class org.apache.lucene.search.DisjunctionMaxQuery.DisjunctionMaxWeight
-
Create the scorer used to score our associated DisjunctionMaxQuery
- scorer(LeafReaderContext) - Method in class org.apache.lucene.search.FilterWeight
-
- scorer - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- Scorer - Interface in org.apache.lucene.search.highlight
-
A Scorer is responsible for scoring a stream of tokens.
- Scorer - Class in org.apache.lucene.search
-
Expert: Common scoring functionality for different types of queries.
- Scorer(Weight) - Constructor for class org.apache.lucene.search.Scorer
-
Constructs a Scorer
- scorer(LeafReaderContext) - Method in class org.apache.lucene.search.spans.AssertingSpanWeight
-
- scorer(LeafReaderContext) - Method in class org.apache.lucene.search.spans.SpanWeight
-
- scorer(LeafReaderContext) - Method in class org.apache.lucene.search.suggest.document.CompletionWeight
-
- scorer(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
-
Returns a
Scorer
which can iterate in order over all matching
documents and assign them a score.
- Scorer.ChildScorer - Class in org.apache.lucene.search
-
A child Scorer and its relationship to its parent.
- ScorerIndexSearcher - Class in org.apache.lucene.search
-
- ScorerIndexSearcher(IndexReader, ExecutorService) - Constructor for class org.apache.lucene.search.ScorerIndexSearcher
-
Creates a searcher searching the provided index.
- ScorerIndexSearcher(IndexReader) - Constructor for class org.apache.lucene.search.ScorerIndexSearcher
-
Creates a searcher searching the provided index.
- ScorerSupplier - Class in org.apache.lucene.search
-
- ScorerSupplier() - Constructor for class org.apache.lucene.search.ScorerSupplier
-
- scorerSupplier(LeafReaderContext) - Method in class org.apache.lucene.search.Weight
-
Optional method.
- scores - Variable in class org.apache.lucene.facet.FacetsCollector.MatchingDocs
-
Non-sparse scores array.
- SCORES - Static variable in class org.apache.lucene.search.DoubleValuesSource
-
- scoreSubDocsAtOnce() - Method in class org.apache.lucene.facet.DrillSideways
-
Override this and return true if your collector
(e.g., ToParentBlockJoinCollector
) expects all
sub-scorers to be positioned on the document being
collected.
- ScoreTerm() - Constructor for class org.apache.lucene.search.spell.DirectSpellChecker.ScoreTerm
-
Constructor.
- SCORING_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.MultiTermQuery
-
A rewrite method that first translates each term into
BooleanClause.Occur.SHOULD
clause in a
BooleanQuery, and keeps the scores as computed by the
query.
- SCORING_BOOLEAN_REWRITE - Static variable in class org.apache.lucene.search.ScoringRewrite
-
A rewrite method that first translates each term into
BooleanClause.Occur.SHOULD
clause in a
BooleanQuery, and keeps the scores as computed by the
query.
- SCORING_SPAN_QUERY_REWRITE - Static variable in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
A rewrite method that first translates each term into a SpanTermQuery in a
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, and keeps the
scores as computed by the query.
- ScoringRewrite<B> - Class in org.apache.lucene.search
-
Base rewrite method that translates each term into a query, and keeps
the scores as computed by the query.
- ScoringRewrite() - Constructor for class org.apache.lucene.search.ScoringRewrite
-
- ScriptAttribute - Interface in org.apache.lucene.analysis.icu.tokenattributes
-
This attribute stores the UTR #24 script value for a token of text.
- ScriptAttributeImpl - Class in org.apache.lucene.analysis.icu.tokenattributes
-
- ScriptAttributeImpl() - Constructor for class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
Initializes this attribute with UScript.COMMON
- sdv - Variable in class org.apache.lucene.search.DocValuesStats.SortedDocValuesStats
-
- search() - Method in class org.apache.lucene.demo.facet.DistanceFacetsExample
-
User runs a query and counts facets.
- search() - Method in class org.apache.lucene.demo.facet.RangeFacetsExample
-
User runs a query and counts facets.
- search(DrillDownQuery, Collector) - Method in class org.apache.lucene.facet.DrillSideways
-
Search, collecting hits with a
Collector
, and
computing drill down and sideways counts.
- search(DrillDownQuery, Query, FieldDoc, int, Sort, boolean, boolean) - Method in class org.apache.lucene.facet.DrillSideways
-
Search, sorting by
Sort
, and computing
drill down and sideways counts.
- search(DrillDownQuery, int) - Method in class org.apache.lucene.facet.DrillSideways
-
Search, sorting by score, and computing
drill down and sideways counts.
- search(ScoreDoc, DrillDownQuery, int) - Method in class org.apache.lucene.facet.DrillSideways
-
Search, sorting by score, and computing
drill down and sideways counts.
- search(DrillDownQuery, CollectorManager<?, R>) - Method in class org.apache.lucene.facet.DrillSideways
-
- search(IndexSearcher, Query, int, Collector) - Static method in class org.apache.lucene.facet.FacetsCollector
-
Utility method, to search and also collect all hits
into the provided
Collector
.
- search(IndexSearcher, Query, int, Sort, Collector) - Static method in class org.apache.lucene.facet.FacetsCollector
-
Utility method, to search and also collect all hits
into the provided
Collector
.
- search(IndexSearcher, Query, int, Sort, boolean, boolean, Collector) - Static method in class org.apache.lucene.facet.FacetsCollector
-
Utility method, to search and also collect all hits
into the provided
Collector
.
- search(Query) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Convenience method that efficiently returns the relevance score by
matching this index against the given Lucene query expression.
- search(List<LeafReaderContext>, Weight, Collector) - Method in class org.apache.lucene.search.AssertingIndexSearcher
-
- search(Query, int, Sort) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
-
- search(Query, Collector) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
-
- search(Query, int) - Method in class org.apache.lucene.search.CheckHits.ExplanationAssertingSearcher
-
- search(IndexSearcher, Query, int, int) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Executes a grouped search.
- search(Query, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top n
hits for query
.
- search(Query, Collector) - Method in class org.apache.lucene.search.IndexSearcher
-
Lower-level search API.
- search(Query, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
-
Search implementation with arbitrary sorting, plus
control over whether hit scores and max score
should be computed.
- search(Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
-
Search implementation with arbitrary sorting.
- search(Query, CollectorManager<C, T>) - Method in class org.apache.lucene.search.IndexSearcher
-
Lower-level search API.
- search(List<LeafReaderContext>, Weight, Collector) - Method in class org.apache.lucene.search.IndexSearcher
-
Lower-level search API.
- search(List<LeafReaderContext>, Weight, Collector) - Method in class org.apache.lucene.search.ScorerIndexSearcher
-
- search(Query, int) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- search(Query, int, Sort) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- search() - Method in class org.apache.lucene.util.fst.Util.TopNSearcher
-
- searchAfter(IndexSearcher, ScoreDoc, Query, int, Collector) - Static method in class org.apache.lucene.facet.FacetsCollector
-
Utility method, to search and also collect all hits
into the provided
Collector
.
- searchAfter(IndexSearcher, ScoreDoc, Query, int, Sort, Collector) - Static method in class org.apache.lucene.facet.FacetsCollector
-
Utility method, to search and also collect all hits
into the provided
Collector
.
- searchAfter(IndexSearcher, ScoreDoc, Query, int, Sort, boolean, boolean, Collector) - Static method in class org.apache.lucene.facet.FacetsCollector
-
Utility method, to search and also collect all hits
into the provided
Collector
.
- searchAfter(ScoreDoc, Query, int) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top n
hits for query
where all results are after a previous
result (after
).
- searchAfter(ScoreDoc, Query, int, Sort) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top n
hits for query
where all results are after a previous
result (after
).
- searchAfter(ScoreDoc, Query, int, Sort, boolean, boolean) - Method in class org.apache.lucene.search.IndexSearcher
-
Finds the top n
hits for query
where all results are after a previous
result (after
), allowing control over
whether hit scores and max score should be computed.
- searchAfter(ScoreDoc, Query, int) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- SearchEquivalenceTestBase - Class in org.apache.lucene.search
-
Simple base class for checking search equivalence.
- SearchEquivalenceTestBase() - Constructor for class org.apache.lucene.search.SearchEquivalenceTestBase
-
- searcher - Variable in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
Index to be searched.
- searcher - Variable in class org.apache.lucene.facet.DrillSideways
-
- searcher - Variable in class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager.SearcherAndTaxonomy
-
- searcher - Variable in class org.apache.lucene.queries.function.FunctionQuery.FunctionWeight
-
- searcher - Static variable in class org.apache.lucene.search.BaseExplanationTestCase
-
- searcher - Variable in class org.apache.lucene.search.ShardSearchingTestBase.SearcherAndVersion
-
- searcher - Variable in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- SearcherAndTaxonomy(IndexSearcher, DirectoryTaxonomyReader) - Constructor for class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager.SearcherAndTaxonomy
-
Create a SearcherAndTaxonomy
- SearcherAndVersion(IndexSearcher, long) - Constructor for class org.apache.lucene.search.ShardSearchingTestBase.SearcherAndVersion
-
- SearcherExpiredException(String) - Constructor for exception org.apache.lucene.search.ShardSearchingTestBase.SearcherExpiredException
-
- searcherFactory - Variable in class org.apache.lucene.replicator.nrt.Node
-
- SearcherFactory - Class in org.apache.lucene.search
-
- SearcherFactory() - Constructor for class org.apache.lucene.search.SearcherFactory
-
- SearcherLifetimeManager - Class in org.apache.lucene.search
-
Keeps track of current plus old IndexSearchers, closing
the old ones once they have timed out.
- SearcherLifetimeManager() - Constructor for class org.apache.lucene.search.SearcherLifetimeManager
-
- SearcherLifetimeManager.PruneByAge - Class in org.apache.lucene.search
-
Simple pruner that drops any searcher older by
more than the specified seconds, than the newest
searcher.
- SearcherLifetimeManager.Pruner - Interface in org.apache.lucene.search
-
- SearcherManager - Class in org.apache.lucene.search
-
Utility class to safely share
IndexSearcher
instances across multiple
threads, while periodically reopening.
- SearcherManager(IndexWriter, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
-
Creates and returns a new SearcherManager from the given
IndexWriter
.
- SearcherManager(IndexWriter, boolean, boolean, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
-
Expert: creates and returns a new SearcherManager from the given
IndexWriter
, controlling whether past deletions should be applied.
- SearcherManager(Directory, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
-
Creates and returns a new SearcherManager from the given
Directory
.
- SearcherManager(DirectoryReader, SearcherFactory) - Constructor for class org.apache.lucene.search.SearcherManager
-
Creates and returns a new SearcherManager from an existing
DirectoryReader
.
- searcherMgr - Variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- searcherMgrLock - Variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Used to manage concurrent access to searcherMgr
- searchers - Variable in class org.apache.lucene.search.ShardSearchingTestBase.NodeState
-
- SearcherTaxonomyManager - Class in org.apache.lucene.facet.taxonomy
-
Manages near-real-time reopen of both an IndexSearcher
and a TaxonomyReader.
- SearcherTaxonomyManager(IndexWriter, SearcherFactory, DirectoryTaxonomyWriter) - Constructor for class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
Creates near-real-time searcher and taxonomy reader
from the corresponding writers.
- SearcherTaxonomyManager(IndexWriter, boolean, SearcherFactory, DirectoryTaxonomyWriter) - Constructor for class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
Expert: creates near-real-time searcher and taxonomy reader
from the corresponding writers, controlling whether deletes should be applied.
- SearcherTaxonomyManager(Directory, Directory, SearcherFactory) - Constructor for class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
Creates search and taxonomy readers over the corresponding directories.
- SearcherTaxonomyManager(IndexReader, DirectoryTaxonomyReader, SearcherFactory) - Constructor for class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
- SearcherTaxonomyManager.SearcherAndTaxonomy - Class in org.apache.lucene.facet.taxonomy
-
- SearchFiles - Class in org.apache.lucene.demo
-
Simple command-line based search demo.
- SearchGroup<T> - Class in org.apache.lucene.search.grouping
-
Represents a group that is found during the first pass search.
- SearchGroup() - Constructor for class org.apache.lucene.search.grouping.SearchGroup
-
- searchPatterns(char[], int, byte[]) - Method in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
Search for all possible partial matches of word starting at index an update
interletter values.
- searchPhrase(List<FieldTermStack.TermInfo>) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery.QueryPhraseMap
-
- searchPhrase(String, List<FieldTermStack.TermInfo>) - Method in class org.apache.lucene.search.vectorhighlight.FieldQuery
-
- SearchTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Search task.
- SearchTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchTask
-
- SearchTravRetHighlightTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Search and Traverse and Retrieve docs task.
- SearchTravRetHighlightTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
-
- SearchTravRetLoadFieldSelectorTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Search and Traverse and Retrieve docs task using a
FieldVisitor loading only the requested fields.
- SearchTravRetLoadFieldSelectorTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetLoadFieldSelectorTask
-
- SearchTravRetTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Search and Traverse and Retrieve docs task.
- SearchTravRetTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetTask
-
- SearchTravTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Search and Traverse task.
- SearchTravTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
-
- SearchWithCollectorTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Does search w/ a custom collector
- SearchWithCollectorTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
-
- SearchWithSortTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Does sort search on specified field.
- SearchWithSortTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
-
- second - Variable in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
-
- SECOND - Static variable in class org.apache.lucene.util.TimeUnits
-
1 second in milliseconds
- SecondPassGroupingCollector<T> - Class in org.apache.lucene.search.grouping
-
SecondPassGroupingCollector runs over an already collected set of
groups, further applying a
GroupReducer
to each group
- SecondPassGroupingCollector(GroupSelector<T>, Collection<SearchGroup<T>>, GroupReducer<T, ?>) - Constructor for class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
Create a new SecondPassGroupingCollector
- secondRangeBeginningOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
-
- secondRangeEndOriginal - Variable in class org.apache.lucene.analysis.CollationTestBase
-
- SeedPostings(long, int, int, IndexOptions, boolean) - Constructor for class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- seek(BytesRef) - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase.FieldIndexEnum
-
Seeks to "largest" indexed term that's <=
term; returns file pointer index (into the main
terms index file) for that term
- seek(long) - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase.FieldIndexEnum
-
- seek(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- seek(long) - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- seek(long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- seek(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- seek(long) - Method in class org.apache.lucene.store.ChecksumIndexInput
-
Sets current position in this file, where the next read will occur.
- seek(long) - Method in class org.apache.lucene.store.IndexInput
-
Sets current position in this file, where the next read will occur.
- seek(long) - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- seek(long) - Method in class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- seekCeil(BytesRef) - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- seekCeil(BytesRef) - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
This enum does not support seeking!
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.MultiTermsEnum
-
- seekCeil(BytesRef) - Method in class org.apache.lucene.index.TermsEnum
-
Seeks to the specified term, if it exists, or to the
next (ceiling) term.
- seekCeil(BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- seekCeil(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
Seeks to smallest term that's >= target.
- seekCeil(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
Seeks to smallest term that's >= target.
- seekChild(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Seeks the skip entry on the given level
- seekExact(BytesRef) - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- seekExact(long) - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- seekExact(BytesRef) - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- seekExact(BytesRef, long) - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- seekExact(long) - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- seekExact(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
This enum does not support seeking!
- seekExact(long) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
This enum does not support seeking!
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
This enum does not support seeking!
- seekExact(long) - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- seekExact(BytesRef) - Method in class org.apache.lucene.index.MultiTermsEnum
-
- seekExact(long) - Method in class org.apache.lucene.index.MultiTermsEnum
-
- seekExact(BytesRef) - Method in class org.apache.lucene.index.TermsEnum
-
Attempts to seek to the exact term, returning
true if the term is found.
- seekExact(long) - Method in class org.apache.lucene.index.TermsEnum
-
Seeks to the specified term by ordinal (position) as
previously returned by
TermsEnum.ord()
.
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.index.TermsEnum
-
- seekExact(BytesRef, TermState) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- seekExact(BytesRef) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- seekExact(long) - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- seekExact(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
Seeks to exactly this term, returning null if the term
doesn't exist.
- seekExact(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
Seeks to exactly this term, returning null if the term
doesn't exist.
- seekFloor(BytesRef) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
Seeks to biggest term that's <= target.
- seekFloor(IntsRef) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
Seeks to biggest term that's <= target.
- seekInternal(long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
Expert: implements seek.
- segment - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Segment name.
- SegmentCacheable - Interface in org.apache.lucene.search
-
- SegmentCommitInfo - Class in org.apache.lucene.index
-
Embeds a [read-only] SegmentInfo and adds per-commit
fields.
- SegmentCommitInfo(SegmentInfo, int, int, long, long, long) - Constructor for class org.apache.lucene.index.SegmentCommitInfo
-
Sole constructor.
- segmentFacetCounts - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- segmentFileName(String, String, String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Returns a file name that includes the given segment name, your own custom
name and extension.
- segmentInfo - Variable in class org.apache.lucene.index.MergeState
-
- SegmentInfo - Class in org.apache.lucene.index
-
Information about a segment such as its name, directory, and files related
to the segment.
- SegmentInfo(Directory, Version, Version, String, int, boolean, Codec, Map<String, String>, byte[], Map<String, String>, Sort) - Constructor for class org.apache.lucene.index.SegmentInfo
-
Construct a new complete SegmentInfo instance from input.
- segmentInfo - Variable in class org.apache.lucene.index.SegmentReadState
-
- segmentInfo - Variable in class org.apache.lucene.index.SegmentWriteState
-
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes segment info file
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- SegmentInfoFormat - Class in org.apache.lucene.codecs
-
Expert: Controls the format of the
SegmentInfo
(segment metadata file).
- SegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.SegmentInfoFormat
-
Sole constructor.
- segmentInfoFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- segmentInfos - Variable in class org.apache.lucene.index.CheckIndex.Status
-
- SegmentInfos - Class in org.apache.lucene.index
-
A collection of segmentInfo objects with methods for operating on those
segments in relation to the file system.
- SegmentInfos(int) - Constructor for class org.apache.lucene.index.SegmentInfos
-
Sole constructor.
- SegmentInfos.FindSegmentsFile<T> - Class in org.apache.lucene.index
-
Utility class for executing code that needs to do
something with the current segments file.
- SegmentingTokenizerBase - Class in org.apache.lucene.analysis.util
-
Breaks text into sentences with a BreakIterator
and
allows subclasses to decompose these sentences into words.
- SegmentingTokenizerBase(BreakIterator) - Constructor for class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
Construct a new SegmenterBase, using
the provided BreakIterator for sentence segmentation.
- SegmentingTokenizerBase(AttributeFactory, BreakIterator) - Constructor for class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
Construct a new SegmenterBase, also supplying the AttributeFactory
- SegmentReader - Class in org.apache.lucene.index
-
IndexReader implementation over a single segment.
- SegmentReadState - Class in org.apache.lucene.index
-
Holder class for common parameters used during read.
- SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext) - Constructor for class org.apache.lucene.index.SegmentReadState
-
Create a SegmentReadState
.
- SegmentReadState(Directory, SegmentInfo, FieldInfos, IOContext, String) - Constructor for class org.apache.lucene.index.SegmentReadState
-
Create a SegmentReadState
.
- SegmentReadState(SegmentReadState, String) - Constructor for class org.apache.lucene.index.SegmentReadState
-
Create a SegmentReadState
.
- SegmentResult(int[], int, int, int) - Constructor for class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
- segmentResults - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- SEGMENTS - Static variable in class org.apache.lucene.index.IndexFileNames
-
Name of the index segment file
- segments - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
-
Segments to be merged.
- segmentsChecked - Variable in class org.apache.lucene.index.CheckIndex.Status
-
Empty unless you passed specific segments list to check as optional 3rd argument.
- segmentsFileName - Variable in class org.apache.lucene.index.CheckIndex.Status
-
Name of latest segments_N file in the index.
- segmentSuffix - Variable in class org.apache.lucene.index.SegmentReadState
-
Unique suffix for any postings files read for this
segment.
- segmentSuffix - Variable in class org.apache.lucene.index.SegmentWriteState
-
Unique suffix for any postings files written for this
segment.
- segmentTotalCount - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- SegmentWriteState - Class in org.apache.lucene.index
-
Holder class for common parameters used during write.
- SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, BufferedUpdates, IOContext) - Constructor for class org.apache.lucene.index.SegmentWriteState
-
Sole constructor.
- SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, BufferedUpdates, IOContext, String) - Constructor for class org.apache.lucene.index.SegmentWriteState
-
Constructor which takes segment suffix.
- SegmentWriteState(SegmentWriteState, String) - Constructor for class org.apache.lucene.index.SegmentWriteState
-
- segString(Directory) - Method in class org.apache.lucene.index.MergePolicy.MergeSpecification
-
Returns a description of the merges in this specification.
- segString() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Returns a readable description of the current merge
state.
- segString(MergePolicy.MergeContext, Iterable<SegmentCommitInfo>) - Method in class org.apache.lucene.index.MergePolicy
-
Builds a String representation of the given SegmentCommitInfo instances
- SegToken - Class in org.apache.lucene.analysis.cn.smart.hhmm
-
SmartChineseAnalyzer internal token
- SegToken(char[], int, int, int, int) - Constructor for class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
-
Create a new SegToken from a character array.
- SegTokenFilter - Class in org.apache.lucene.analysis.cn.smart.hhmm
-
Filters a
SegToken
by converting full-width latin to half-width, then lowercasing latin.
- SegTokenFilter() - Constructor for class org.apache.lucene.analysis.cn.smart.hhmm.SegTokenFilter
-
- segUpdates - Variable in class org.apache.lucene.index.SegmentWriteState
-
Deletes and updates to apply while we are flushing the segment.
- select(T[], int, int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Reorganize arr[from:to[
so that the element at offset k is at the
same position as if arr[from:to[
was sorted, and all elements on
its left are less than or equal to it, and all elements on its right are
greater than or equal to it.
- select(int, int, int) - Method in class org.apache.lucene.util.IntroSelector
-
- select(int, int, int) - Method in class org.apache.lucene.util.RadixSelector
-
- select(int, int, int) - Method in class org.apache.lucene.util.Selector
-
Reorder elements so that the element at position k
is the same
as if all elements were sorted and all other elements are partitioned
around it: [from, k)
only contains elements that are less than
or equal to k
and (k, to)
only contains elements that
are greater than or equal to k
.
- selector - Variable in class org.apache.lucene.queries.function.valuesource.MultiValuedDoubleFieldSource
-
- selector - Variable in class org.apache.lucene.queries.function.valuesource.MultiValuedFloatFieldSource
-
- selector - Variable in class org.apache.lucene.queries.function.valuesource.MultiValuedIntFieldSource
-
- selector - Variable in class org.apache.lucene.queries.function.valuesource.MultiValuedLongFieldSource
-
- selector - Variable in class org.apache.lucene.queries.function.valuesource.SortedSetFieldSource
-
- Selector - Class in org.apache.lucene.util
-
An implementation of a selection algorithm, ie.
- Selector() - Constructor for class org.apache.lucene.util.Selector
-
- sendNewReplica() - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Tell primary we (replica) just started, so primary can tell us to warm any already warming merges.
- SENTENCE_BEGIN - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
Start of a Sentence
- SENTENCE_END - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
End of a Sentence
- SentinelIntSet - Class in org.apache.lucene.util
-
A native int hash-based set where one value is reserved to mean "EMPTY" internally.
- SentinelIntSet(int, int) - Constructor for class org.apache.lucene.util.SentinelIntSet
-
- SEP - Static variable in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
- SEP_LABEL - Static variable in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
Represents the separation between tokens, if
preserveSep
is true
.
- SEPARATOR_KEY - Static variable in class org.apache.lucene.analysis.miscellaneous.FingerprintFilterFactory
-
- SEPARATOR_TERM - Static variable in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Term that can be used to prohibit adjacent terms from being combined
- SEQUENTIAL - Static variable in class org.apache.lucene.store.NativePosixUtil
-
- SerbianNormalizationFilter - Class in org.apache.lucene.analysis.sr
-
Normalizes Serbian Cyrillic and Latin characters to "bald" Latin.
- SerbianNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.sr.SerbianNormalizationFilter
-
- SerbianNormalizationFilterFactory - Class in org.apache.lucene.analysis.sr
-
- SerbianNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.sr.SerbianNormalizationFilterFactory
-
Creates a new SerbianNormalizationFilterFactory
- SerbianNormalizationRegularFilter - Class in org.apache.lucene.analysis.sr
-
Normalizes Serbian Cyrillic to Latin.
- SerbianNormalizationRegularFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.sr.SerbianNormalizationRegularFilter
-
- SerializableObject - Interface in org.apache.lucene.spatial3d.geom
-
Indicates that a geo3d object can be serialized and deserialized.
- serialize(DataOutput) - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
Serializes the data set to file using the following format:
FuzzySet -->FuzzySetVersion,HashFunctionName,BloomSize,
NumBitSetWords,BitSetWord
NumBitSetWords
HashFunctionName -->
String
The
name of a ServiceProvider registered
HashFunction
FuzzySetVersion -->
Uint32
The version number of the
FuzzySet
class
BloomSize -->
Uint32
The modulo value used
to project hashes into the field's Bitset
NumBitSetWords -->
Uint32
The number of
longs (as returned from
FixedBitSet.getBits()
)
BitSetWord -->
Long
A long from the array
returned by
FixedBitSet.getBits()
- serialize(DataOutput) - Method in class org.apache.lucene.replicator.SessionToken
-
Serialize the token data for communication between server and client.
- SerializedDVStrategy - Class in org.apache.lucene.spatial.serialized
-
A SpatialStrategy based on serializing a Shape stored into BinaryDocValues.
- SerializedDVStrategy(SpatialContext, String) - Constructor for class org.apache.lucene.spatial.serialized.SerializedDVStrategy
-
Constructs the spatial strategy with its mandatory arguments.
- SerialMergeScheduler - Class in org.apache.lucene.index
-
A
MergeScheduler
that simply does each merge
sequentially, using the current thread.
- SerialMergeScheduler() - Constructor for class org.apache.lucene.index.SerialMergeScheduler
-
Sole constructor.
- SessionExpiredException - Exception in org.apache.lucene.replicator
-
Exception indicating that a revision update session was expired due to lack
of activity.
- SessionExpiredException(String, Throwable) - Constructor for exception org.apache.lucene.replicator.SessionExpiredException
-
- SessionExpiredException(String) - Constructor for exception org.apache.lucene.replicator.SessionExpiredException
-
- SessionExpiredException(Throwable) - Constructor for exception org.apache.lucene.replicator.SessionExpiredException
-
- SessionToken - Class in org.apache.lucene.replicator
-
Token for a replication session, for guaranteeing that source replicated
files will be kept safe until the replication completes.
- SessionToken(DataInput) - Constructor for class org.apache.lucene.replicator.SessionToken
-
Constructor which deserializes from the given DataInput
.
- SessionToken(String, Revision) - Constructor for class org.apache.lucene.replicator.SessionToken
-
Constructor with the given id and revision.
- set(char[], int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- set(String, String) - Method in class org.apache.lucene.benchmark.byTask.utils.Config
-
Set a property.
- set(ConfigurationKey<T>, T) - Method in class org.apache.lucene.queryparser.flexible.core.config.AbstractQueryConfig
-
Sets a key and its value.
- set(List<QueryNode>) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
- set(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- set(int, QueryNodeProcessor) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- set(int) - Method in class org.apache.lucene.util.BitSet
-
Set the bit at i
.
- set(T) - Method in class org.apache.lucene.util.CloseableThreadLocal
-
- set(int) - Method in class org.apache.lucene.util.FixedBitSet
-
- set(int, int) - Method in class org.apache.lucene.util.FixedBitSet
-
Sets a range of bits
- set(long) - Method in class org.apache.lucene.util.LongBitSet
-
- set(long, long) - Method in class org.apache.lucene.util.LongBitSet
-
Sets a range of bits
- set(long, long) - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
Set value at index
.
- set(int, long) - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- set(int, long[], int, int) - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- set(int, long) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
-
Set the value at the given index in the array.
- set(int, long[], int, int) - Method in class org.apache.lucene.util.packed.PackedInts.Mutable
-
Bulk set: set at least one and at most len
longs starting
at off
in arr
into this mutable, starting at
index
.
- set(T) - Method in class org.apache.lucene.util.SetOnce
-
Sets the given object.
- set(int) - Method in class org.apache.lucene.util.SparseFixedBitSet
-
Set the bit at index i.
- setAborted() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Marks this merge as aborted.
- setAccept(int, boolean) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Marks the specified state as accept or not.
- setAccept(int, boolean) - Method in class org.apache.lucene.util.automaton.Automaton.Builder
-
Set or clear this state as an accept state.
- setAccept(int, boolean) - Method in class org.apache.lucene.util.automaton.Automaton
-
Set or clear this state as an accept state.
- setAccuracy(float) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Set the minimal accuracy required (default: 0.5f) from a StringDistance
for a suggestion match.
- setAccuracy(float) - Method in class org.apache.lucene.search.spell.SpellChecker
-
- setAlgLineNum(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- setAllGroupHeads(boolean) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Whether to compute all group heads (most relevant document per group) matching the query.
- setAllGroups(boolean) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Whether to also compute all groups matching the query.
- setAllowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Set to true
to allow leading wildcard characters.
- setAllowLeadingWildcard(boolean) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Set to true
to allow leading wildcard characters.
- setAllowLeadingWildcard(boolean) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Set to true
to allow leading wildcard characters.
- setAllowRandomFileNotFoundException(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
If set to true (the default), when we throw random
IOException on openInput or createOutput, we may
sometimes throw FileNotFoundException or
NoSuchFileException.
- setAllowReadingFilesStillOpenForWrite(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
If set to true, you can open an inputstream on a file
that is still open for writes.
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the analyzer to use.
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- setAnalyzer(Analyzer) - Method in class org.apache.lucene.util.QueryBuilder
-
Sets the analyzer used to tokenize text.
- setAssertNoDeleteOpenFile(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Trip a test assert if there is an attempt
to delete an open file.
- setAssertNoUnrefencedFilesOnClose(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- setAttribute(Path, String, Object, LinkOption...) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- setAttribute(Path, String, Object, LinkOption...) - Method in class org.apache.lucene.mockfile.VerboseFS
-
- setAutoGenerateMultiTermSynonymsPhraseQuery(boolean) - Method in class org.apache.lucene.util.QueryBuilder
-
Set to true
if phrase queries should be automatically generated
for multi terms synonyms.
- setAutoGeneratePhraseQueries(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
Set to true if phrase queries will be automatically generated
when the analyzer returns more than one term from whitespace
delimited text.
- setAutoGeneratePhraseQueries(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Set to true if phrase queries will be automatically generated
when the analyzer returns more than one term from whitespace
delimited text.
- setAutomata(CompiledAutomaton[]) - Method in interface org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttribute
-
- setAutomata(CompiledAutomaton[]) - Method in class org.apache.lucene.search.FuzzyTermsEnum.LevenshteinAutomataAttributeImpl
-
- setAvgFieldLength(float) - Method in class org.apache.lucene.search.similarities.BasicStats
-
Sets the average field length.
- setBaseline(long) - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Sets the baseline for this collector.
- setBaseline() - Method in class org.apache.lucene.search.TimeLimitingCollector
-
- setBaselineTfFactors(float, float) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Sets the baseline and minimum function variables for baselineTf
- setBegin(int) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- setBeginColumn(int) - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
- setBeginLine(int) - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
- setBigIntegerValues(BigInteger...) - Method in class org.apache.lucene.document.BigIntegerPoint
-
Change the values of this field
- setBody(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- setBoost(boolean) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets whether to boost terms in query based on "score" or not.
- setBoost(float) - Method in interface org.apache.lucene.search.BoostAttribute
-
Sets the boost in this attribute
- setBoost(float) - Method in class org.apache.lucene.search.BoostAttributeImpl
-
- setBoostFactor(float) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the boost factor to use when boosting terms
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- setBottom(int) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- setBottom(int) - Method in interface org.apache.lucene.search.LeafFieldComparator
-
Set the bottom slot, ie the "weakest" (sorted last)
entry in the queue.
- setBounds(T, T, boolean, boolean) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
Sets the lower and upper bounds.
- setBounds(PointQueryNode, PointQueryNode, boolean, boolean, PointsConfig) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointRangeQueryNode
-
Sets the upper and lower bounds of this range query node and the
PointsConfig
associated with these bounds.
- setBreakIterator(Supplier<BreakIterator>) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setBufferSize(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Sets the scanner buffer size in chars
- setBufferSize(int) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Sets the scanner buffer size in chars
- setBufferSize(int) - Method in class org.apache.lucene.store.BufferedIndexInput
-
Change the buffer size used by this IndexInput
- setBuilder(CharSequence, QueryBuilder) - Method in class org.apache.lucene.queryparser.flexible.core.builders.QueryTreeBuilder
-
Associates a field name with a builder.
- setBuilder(Class<? extends QueryNode>, QueryBuilder) - Method in class org.apache.lucene.queryparser.flexible.core.builders.QueryTreeBuilder
-
Associates a class with a builder
- setByteAt(int, byte) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Set a byte.
- setBytesComparator(Comparator<BytesRef>) - Method in class org.apache.lucene.search.SortField
-
- setBytesRef(BytesRef) - Method in interface org.apache.lucene.analysis.tokenattributes.BytesTermAttribute
-
- setBytesRef(BytesRef) - Method in class org.apache.lucene.analysis.tokenattributes.BytesTermAttributeImpl
-
- setBytesRef(BytesRef, int) - Method in class org.apache.lucene.util.ByteBlockPool
-
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.BigIntegerPoint
-
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.DoublePoint
-
- setBytesValue(byte[]) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.FloatPoint
-
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.HalfFloatPoint
-
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.InetAddressPoint
-
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.IntPoint
-
- setBytesValue(BytesRef) - Method in class org.apache.lucene.document.LongPoint
-
- setByteValue(byte) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setCacheFieldValCharsThreshold(int) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setCacheMissesUntilFill(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
Set the number of cache misses before an attempt is made to read the entire
taxonomy into the in-memory cache.
- setCacheSize(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
- setCaching(int, boolean) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Enables caching for the second pass search.
- setCachingInMB(double, boolean) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Enables caching for the second pass search.
- setCalibrateSizeByDeletes(boolean) - Method in class org.apache.lucene.index.LogMergePolicy
-
Sets whether the segment size should be calibrated by
the number of deletes when choosing segments for merge.
- setCharAt(int, char) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- setCharAt(int, char) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Set a char.
- setCheckIndexOnClose(boolean) - Method in class org.apache.lucene.store.BaseDirectoryWrapper
-
Set whether or not checkindex should be run
on close
- setCheckPendingFlushUpdate(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setCheckPendingFlushUpdate(boolean) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Expert: sets if indexing threads check for pending flushes on update in order
to help our flushing indexing buffers to disk.
- setChecksumsOnly(boolean) - Method in class org.apache.lucene.index.CheckIndex
-
If true, only validate physical integrity for all files.
- setChild(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.GroupQueryNode
-
- setChild(QueryNode) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.NoChildOptimizationQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorImpl
-
This method is invoked for every node that has at least on child.
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.core.processors.RemoveDeletedQueryNodesProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.precedence.processors.BooleanModifiersQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AllowLeadingWildcardProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.AnalyzerQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanSingleChildOptimizationQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BoostQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.DefaultPhraseSlopQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.FuzzyQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MatchAllDocsQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MultiFieldQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.MultiTermRewriteMethodProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.OpenRangeQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PhraseSlopQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PointQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.PointRangeQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.RegexpQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.RemoveEmptyNonLeafQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.TermRangeQueryNodeProcessor
-
- setChildrenOrder(List<QueryNode>) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.WildcardQueryNodeProcessor
-
- setCircleAccuracy(double) - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShapeFactory
-
Set the accuracy for circles in decimal degrees.
- setCmd(Character, int) - Method in class org.egothor.stemmer.Row
-
Set the command in the Cell of the given Character to the given integer.
- setCode(int) - Method in interface org.apache.lucene.analysis.icu.tokenattributes.ScriptAttribute
-
Set the numeric code for this script value.
- setCode(int) - Method in class org.apache.lucene.analysis.icu.tokenattributes.ScriptAttributeImpl
-
- setCodec(Codec) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setCodec(Codec) - Method in class org.apache.lucene.index.SegmentInfo
-
Can only be called once.
- setCollectionProbability(float) - Method in class org.apache.lucene.search.similarities.LMSimilarity.LMStats
-
Sets the probability that the current term is generated by the
collection.
- SetCollector(Set<Integer>) - Constructor for class org.apache.lucene.search.CheckHits.SetCollector
-
- setCollector(Collector) - Method in class org.apache.lucene.search.TimeLimitingCollector
-
This is so the same timer can be used with a multi-phase search process such as grouping.
- setCommitOnClose(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setComparator(Comparator<SuggestWord>) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Set the comparator for sorting suggestions.
- setComparator(Comparator<SuggestWord>) - Method in class org.apache.lucene.search.spell.SpellChecker
-
- setCompetitiveTerm(BytesRef) - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
-
This is the term or null
of the term that triggered the boost change.
- setCompetitiveTerm(BytesRef) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.AbstractQueryMaker
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Sets the
Config
for this content source.
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.DirContentSource
-
- setConfig(Config, ContentSource) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
Set the configuration parameters of this doc maker.
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.EnwikiContentSource
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.LineDocSource
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.LongToEnglishQueryMaker
-
- setConfig(Config) - Method in interface org.apache.lucene.benchmark.byTask.feeds.QueryMaker
-
Set the properties
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.RandomFacetSource
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.ReutersContentSource
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.SortableSingleDocSource
-
- setConfig(Config, ContentSource) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- setConfig(Config) - Method in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- setConsumer(PatternConsumer) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- setCountsByTime(int[], long) - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- setCrossCheckTermVectors(boolean) - Method in class org.apache.lucene.index.CheckIndex
-
If true, term vectors are compared against postings to
make sure they are the same.
- setCrossCheckTermVectorsOnClose(boolean) - Method in class org.apache.lucene.store.BaseDirectoryWrapper
-
- setCurrent(String) - Method in class org.tartarus.snowball.SnowballProgram
-
Set the current string.
- setCurrent(char[], int) - Method in class org.tartarus.snowball.SnowballProgram
-
Set the current string.
- setCurrentLabel(int) - Method in class org.apache.lucene.util.fst.BytesRefFSTEnum
-
- setCurrentLabel(int) - Method in class org.apache.lucene.util.fst.IntsRefFSTEnum
-
- setDate(Date) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- setDate(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- setDateResolution(DateTools.Resolution) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Sets the default date resolution used by RangeQueries for fields for which no
specific date resolutions has been set.
- setDateResolution(String, DateTools.Resolution) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Sets the date resolution used by RangeQueries for a specific field.
- setDateResolution(DateTools.Resolution) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- setDateResolution(DateTools.Resolution) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- setDateResolutionMap(Map<CharSequence, DateTools.Resolution>) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- setDefault(Codec) - Static method in class org.apache.lucene.codecs.Codec
-
- setDefault(InfoStream) - Static method in class org.apache.lucene.util.InfoStream
-
Sets the default InfoStream
used
by a newly instantiated classes.
- setDefaultFieldValuesArrayLen(int) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
- setDefaultMaxMergesAndThreads(boolean) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Sets max merges and threads to proper defaults for rotational
or non-rotational storage.
- setDefaultOperator(QueryParser.Operator) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Sets the boolean operator of the QueryParser.
- setDefaultOperator(StandardQueryConfigHandler.Operator) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Sets the boolean operator of the QueryParser.
- setDefaultOperator(BooleanClause.Occur) - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Sets the implicit operator setting, which must be
either SHOULD
or MUST
.
- setDefaultQueryCache(QueryCache) - Static method in class org.apache.lucene.search.IndexSearcher
-
- setDefaultQueryCachingPolicy(QueryCachingPolicy) - Static method in class org.apache.lucene.search.IndexSearcher
-
- setDefaultTempDir(Path) - Static method in class org.apache.lucene.analysis.hunspell.Dictionary
-
Used by test framework
- setDeletesPctAllowed(double) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Controls the maximum percentage of deleted documents that is tolerated in
the index.
- setDelGen(long) - Method in class org.apache.lucene.index.PrefixCodedTerms
-
Records del gen for this packet.
- setDepth(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- setDimensions(int, int) - Method in class org.apache.lucene.document.FieldType
-
Enables points indexing.
- setDimensions(int, int, int) - Method in class org.apache.lucene.document.FieldType
-
Enables points indexing with selectable dimension indexing.
- setDirectory(Directory) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- setDisableCounting(boolean) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Sets whether overlap tokens (Tokens with 0 position increment) are
ignored when computing norm.
- setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
Determines whether overlap tokens (Tokens with
0 position increment) are ignored when computing
norm.
- setDiscountOverlaps(boolean) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Determines whether overlap tokens (Tokens with
0 position increment) are ignored when computing
norm.
- setDiscreteMultiValueHighlighting(boolean) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- setDistance(StringDistance) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Set the string distance metric.
- setDistErr(Double) - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
- setDistErrPct(double) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
The default measure of shape precision affecting shapes at index and query
times.
- setDistErrPct(Double) - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
- setDocFreq(long) - Method in class org.apache.lucene.search.similarities.BasicStats
-
Sets the document frequency.
- setDocId(int) - Method in class org.apache.lucene.util.BitSetIterator
-
Set the current doc id that this iterator is on.
- setDocument(int) - Method in class org.apache.lucene.index.LegacySortedNumericDocValues
-
Deprecated.
Positions to the specified document
- setDocument(int) - Method in class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
Sets iteration to the specified docID
- setDocValuesType(DocValuesType) - Method in class org.apache.lucene.document.FieldType
-
Sets the field's DocValuesType
- setDocValuesType(DocValuesType) - Method in class org.apache.lucene.index.FieldInfo
-
Record that this field is indexed with docvalues, with the specified type
- setDocValuesUpdatesFiles(Map<Integer, Set<String>>) - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Sets the DocValues updates file names, per field number.
- setDoFail() - Method in class org.apache.lucene.store.MockDirectoryWrapper.Failure
-
- setDoNonBulkMerges(boolean) - Method in class org.apache.lucene.index.MockRandomMergePolicy
-
Set to true if sometimes readers to be merged should be wrapped in a FilterReader
to mixup bulk merging.
- setDoRandomForceMerge(boolean) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- setDoRandomForceMergeAssert(boolean) - Method in class org.apache.lucene.index.RandomIndexWriter
-
- setDoubleValue(double) - Method in class org.apache.lucene.document.DoubleDocValuesField
-
- setDoubleValue(double) - Method in class org.apache.lucene.document.DoublePoint
-
- setDoubleValue(double) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setDoubleValues(double...) - Method in class org.apache.lucene.document.DoublePoint
-
Change the values of this field
- setEmpty() - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Sets the length of the termBuffer to zero.
- setEmpty() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- setEnableChecks(boolean) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
Toggle consumer workflow checking: if your test consumes tokenstreams normally you
should leave this enabled.
- setEnableChecks(boolean) - Method in class org.apache.lucene.analysis.MockTokenizer
-
Toggle consumer workflow checking: if your test consumes tokenstreams normally you
should leave this enabled.
- setEnableGraphQueries(boolean) - Method in class org.apache.lucene.util.QueryBuilder
-
Enable or disable graph TokenStream processing (enabled by default).
- setEnablePositionIncrements(boolean) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Set to true
to enable position increments in result query.
- setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Set to true
to enable position increments in result query.
- setEnablePositionIncrements(boolean) - Method in class org.apache.lucene.util.QueryBuilder
-
Set to true
to enable position increments in result query.
- setEncoder(Encoder) - Method in class org.apache.lucene.search.highlight.Highlighter
-
- setEnd(int) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- setEndOffset(int) - Method in class org.apache.lucene.search.uhighlight.Passage
-
- setEndOffset(int) - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
-
- setErrorToken(String) - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
- setExpandMultiTermQuery(boolean) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- setExpandMultiTermQuery(boolean) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- setExpirationThreshold(long) - Method in class org.apache.lucene.replicator.LocalReplicator
-
Modify session expiration time - if a replication session is inactive that
long it is automatically expired, and further attempts to operate within
this session will throw a
SessionExpiredException
.
- setExplicitLuceneMatchVersion(boolean) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
- setFailFast(boolean) - Method in class org.apache.lucene.index.CheckIndex
-
If true, just throw the original exception immediately when
corruption is detected, rather than continuing to iterate to other
segments looking for more corruption.
- setFailOnCreateOutput(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- setFailOnOpenInput(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- setFeatureValue(float) - Method in class org.apache.lucene.document.FeatureField
-
Update the feature value of this field.
- setField(FieldInfo) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- setField(FieldInfo) - Method in class org.apache.lucene.codecs.PostingsWriterBase
-
Sets the current field for writing, and returns the
fixed length of long[] metadata (which is fixed per
field), called when the writing switches to another field.
- setField(FieldInfo) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
-
Sets the current field for writing, and returns the
fixed length of long[] metadata (which is fixed per
field), called when the writing switches to another field.
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
- setField(CharSequence) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.FieldableNode
-
Associates the node to a field.
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.TokenizedPhraseQueryNode
-
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
Sets the field associated with this node.
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.MultiPhraseQueryNode
-
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
Sets the field associated with this node.
- setField(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- setFieldInfosFiles(Set<String>) - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Sets the FieldInfos file names.
- setFieldMatcher(Predicate<String>) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setFieldNames(String[]) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the field names that will be used when generating the 'More Like This' query.
- setFieldsBoost(Map<String, Float>) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Sets the boost used for each field.
- setFiles(Collection<String>) - Method in class org.apache.lucene.index.SegmentInfo
-
Sets the files written for this segment.
- setFillerToken(String) - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
Sets the string to insert for each position at which there is no token
(i.e., when position increment is greater than one).
- setFillSortFields(boolean) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Whether to also fill the sort fields per returned group and groups docs.
- setFinalOffsetGapAsHole(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
-
If true, any final offset gaps will result in adding a position hole.
- setFlags(int) - Method in class org.apache.lucene.analysis.Token
-
Set the flags to a new bitset.
- setFlags(int) - Method in interface org.apache.lucene.analysis.tokenattributes.FlagsAttribute
-
Set the flags to a new bitset.
- setFlags(int) - Method in class org.apache.lucene.analysis.tokenattributes.FlagsAttributeImpl
-
- setFloatValue(float) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setFloatValue(float) - Method in class org.apache.lucene.document.FloatDocValuesField
-
- setFloatValue(float) - Method in class org.apache.lucene.document.FloatPoint
-
- setFloatValue(float) - Method in class org.apache.lucene.document.HalfFloatPoint
-
- setFloatValues(float...) - Method in class org.apache.lucene.document.FloatPoint
-
Change the values of this field
- setFloatValues(float...) - Method in class org.apache.lucene.document.HalfFloatPoint
-
Change the values of this field
- setFloorSegmentMB(double) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Segments smaller than this are "rounded up" to this
size, ie treated as equal (floor) size for merge
selection.
- setForceMergeDeletesPctAllowed(double) - Method in class org.apache.lucene.index.TieredMergePolicy
-
When forceMergeDeletes is called, we only merge away a
segment if its delete percentage is over this
threshold.
- setForceMergeMBPerSec(double) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Set the per-merge IO throttle rate for forced merges (default: Double.POSITIVE_INFINITY
).
- setFormatter(PassageFormatter) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setFragmentScorer(Scorer) - Method in class org.apache.lucene.search.highlight.Highlighter
-
- setFragmentSize(int) - Method in class org.apache.lucene.search.highlight.SimpleFragmenter
-
- setFreqCurrentDoc() - Method in class org.apache.lucene.search.spans.SpanScorer
-
- setFuzzyMinSim(float) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Set the minimum similarity for fuzzy queries.
- setFuzzyMinSim(float) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Set the minimum similarity for fuzzy queries.
- setFuzzyMinSim(float) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Set the minimum similarity for fuzzy queries.
- setFuzzyPrefixLength(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Set the prefix length for fuzzy queries.
- setFuzzyPrefixLength(int) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Set the prefix length for fuzzy queries.
- setFuzzyPrefixLength(int) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Set the prefix length for fuzzy queries.
- setGraphvizFormatter(GraphvizFormatter) - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
Expert: set this to produce graphviz (dot) output of
the Viterbi lattice
- setGraphvizFormatter(GraphvizFormatter) - Method in class org.apache.lucene.analysis.ko.KoreanTokenizer
-
Expert: set this to produce graphviz (dot) output of
the Viterbi lattice
- setGreedy(boolean) - Method in class org.apache.lucene.search.TimeLimitingCollector
-
Sets whether this time limited collector is greedy.
- setGroupDocsLimit(int) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Specifies the number of documents to return inside a group from the specified groupDocsOffset.
- setGroupDocsOffset(int) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Specifies the offset for documents inside a group.
- setGroups(Collection<SearchGroup<T>>) - Method in class org.apache.lucene.search.grouping.GroupReducer
-
Define which groups should be reduced.
- setGroups(Collection<SearchGroup<T>>) - Method in class org.apache.lucene.search.grouping.GroupSelector
-
- setGroups(Collection<SearchGroup<BytesRef>>) - Method in class org.apache.lucene.search.grouping.TermGroupSelector
-
- setGroups(Collection<SearchGroup<MutableValue>>) - Method in class org.apache.lucene.search.grouping.ValueSourceGroupSelector
-
- setGroupSort(Sort) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Specifies how groups are sorted.
- setHandleMultiTermQuery(boolean) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setHierarchical(String, boolean) - Method in class org.apache.lucene.facet.FacetsConfig
-
Pass true
if this dimension is hierarchical
(has depth > 1 paths).
- setHighFreqMinimumNumberShouldMatch(float) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Specifies a minimum number of the high frequent optional BooleanClauses which must be
satisfied in order to produce a match on the low frequency terms query
part.
- setHighlightPhrasesStrictly(boolean) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setHyperbolicTfFactors(float, float, double, float) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Sets the function variables for the hyperbolicTf functions
- setID(int) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- setIgnoreTF(boolean) - Method in class org.apache.lucene.sandbox.queries.FuzzyLikeThisQuery
-
- setIncludeMaxScore(boolean) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Whether to include the score of the most relevant document per group.
- setIncludeScores(boolean) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Whether to include the scores per doc inside a group.
- setIndex(int) - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
- setIndexCommit(IndexCommit) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: allows to open a certain commit point.
- setIndexCreatedVersionMajor(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: set the compatibility version to use for this index.
- setIndexDeletionPolicy(IndexDeletionPolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setIndexFieldName(String, String) - Method in class org.apache.lucene.facet.FacetsConfig
-
Specify which index field name should hold the
ordinals for this dimension; this is only used by the
taxonomy based facet methods.
- setIndexOptions(IndexOptions) - Method in class org.apache.lucene.document.FieldType
-
Sets the indexing options for the field:
- setIndexOptions(IndexOptions) - Method in class org.apache.lucene.index.FieldInfo
-
- setIndexReader(DirectoryReader) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Set the index reader.
- setIndexSort(Sort) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Set the
Sort
order to use for all (flushed and merged) segments.
- setIndexWriter(IndexWriter) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- setIndexWriterMaxDocs(int) - Method in class org.apache.lucene.util.LuceneTestCase
-
- setInetAddressValue(InetAddress) - Method in class org.apache.lucene.document.InetAddressPoint
-
Change the values of this field
- setInfoStream(PrintStream, boolean) - Method in class org.apache.lucene.index.CheckIndex
-
Set infoStream where messages should go.
- setInfoStream(PrintStream) - Method in class org.apache.lucene.index.CheckIndex
-
Set infoStream where messages should go.
- setInfoStream(InfoStream) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Information about merges, deletes and a
message when maxFieldLength is reached will be printed
to this.
- setInfoStream(PrintStream) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setInfoStream(PrintStream) - Static method in class org.apache.lucene.index.SegmentInfos
-
If non-null, information about retries when loading
the segments file will be printed to this.
- setInfoStream(InfoStream) - Method in class org.apache.lucene.replicator.IndexAndTaxonomyReplicationHandler
-
- setInfoStream(InfoStream) - Method in class org.apache.lucene.replicator.IndexReplicationHandler
-
- setInfoStream(InfoStream) - Method in class org.apache.lucene.replicator.ReplicationClient
-
- setInitialSeekTerm(BytesRef) - Method in class org.apache.lucene.index.FilteredTermsEnum
-
Use this method to set the initial
BytesRef
to seek before iterating.
- setInnerFilters(List<TokenFilterFactory>) - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilterFactory
-
- setInOrder(boolean) - Method in class org.apache.lucene.queryparser.complexPhrase.ComplexPhraseQueryParser
-
When inOrder
is true, the search terms must
exists in the documents as the same order as in query.
- setIntAt(int, int) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Set an int.
- setIntValue(int) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setIntValue(int) - Method in class org.apache.lucene.document.IntPoint
-
- setIntValues(int...) - Method in class org.apache.lucene.document.IntPoint
-
Change the values of this field
- setKeyword(boolean) - Method in interface org.apache.lucene.analysis.tokenattributes.KeywordAttribute
-
Marks the current token as keyword if set to true
.
- setKeyword(boolean) - Method in class org.apache.lucene.analysis.tokenattributes.KeywordAttributeImpl
-
- SetKeywordMarkerFilter - Class in org.apache.lucene.analysis.miscellaneous
-
- SetKeywordMarkerFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.miscellaneous.SetKeywordMarkerFilter
-
Create a new KeywordSetMarkerFilter, that marks the current token as a
keyword if the tokens term buffer is contained in the given set via the
KeywordAttribute
.
- setLastOutput(int, T) - Method in class org.apache.lucene.util.fst.Builder.UnCompiledNode
-
- setLastSkipData(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Copies the values of the last read skip entry on this level
- setLeaf(boolean) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- setLeaf() - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
Set this cell to be a leaf.
- setLeaf() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- setLeaf() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- setLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.CharTermAttribute
-
Set number of valid characters (length of the term) in
the termBuffer array.
- setLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- setLength(int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- setLength(int) - Method in class org.apache.lucene.index.FieldInvertState
-
Set length value.
- setLength(long) - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
- setLength(int) - Method in class org.apache.lucene.util.BytesRefBuilder
-
Set the length.
- setLength(int) - Method in class org.apache.lucene.util.CharsRefBuilder
-
Set the length.
- setLength(int) - Method in class org.apache.lucene.util.IntsRefBuilder
-
Set the length.
- setLengthNormFactors(int, int, float, boolean) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Sets the default function variables used by lengthNorm when no field
specific variables have been set.
- setLikeText(String) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setLiveCommitData(Iterable<Map.Entry<String, String>>) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter
-
- setLiveCommitData(Iterable<Map.Entry<String, String>>) - Method in interface org.apache.lucene.facet.taxonomy.TaxonomyWriter
-
Sets the commit user data iterable.
- setLiveCommitData(Iterable<Map.Entry<String, String>>) - Method in class org.apache.lucene.index.IndexWriter
-
Sets the iterator to provide the commit user data map at commit time.
- setLiveCommitData(Iterable<Map.Entry<String, String>>, boolean) - Method in class org.apache.lucene.index.IndexWriter
-
- setLocale(Locale) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- setLocale(Locale) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Set locale used by date range parsing, lowercasing, and other
locale-sensitive operations.
- setLocale(Locale) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Set locale used by date range parsing.
- setLocale(Locale) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Set locale used by date range parsing.
- setLocationValue(double, double) - Method in class org.apache.lucene.document.LatLonDocValuesField
-
Change the values of this field
- setLocationValue(double, double) - Method in class org.apache.lucene.document.LatLonPoint
-
Change the values of this field
- setLocationValue(GeoPoint) - Method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Change the values of this field
- setLocationValue(double, double, double) - Method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Change the values of this field
- setLongValue(long) - Method in class org.apache.lucene.document.DoubleDocValuesField
-
- setLongValue(long) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setLongValue(long) - Method in class org.apache.lucene.document.FloatDocValuesField
-
- setLongValue(long) - Method in class org.apache.lucene.document.LongPoint
-
- setLongValues(long...) - Method in class org.apache.lucene.document.LongPoint
-
Change the values of this field
- setLowerCaseTerms(boolean) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
True if the spellchecker should lowercase terms (default: true)
- setLowFreqMinimumNumberShouldMatch(float) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
Specifies a minimum number of the low frequent optional BooleanClauses which must be
satisfied in order to produce a match on the low frequency terms query
part.
- setMatchAlmostDiff(int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Sets the number of characters by which words can differ from target word
when calling the matchAlmost
method.
- setMax(int, Object) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setMaxBufferedDocs(int) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Determines the minimal number of documents required before the buffered
in-memory documents are flushed as a new Segment.
- setMaxCFSSegmentSizeMB(double) - Method in class org.apache.lucene.index.FilterMergePolicy
-
- setMaxCFSSegmentSizeMB(double) - Method in class org.apache.lucene.index.MergePolicy
-
If a merged segment will be more than this value,
leave the segment as
non-compound file even if compound file is enabled.
- setMaxCFSSegmentSizeMB(double) - Method in class org.apache.lucene.index.NoMergePolicy
-
- setMaxChanges(int) - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
The maximum numbers of changes (word breaks or combinations) to make on the
original term(s).
- setMaxClauseCount(int) - Static method in class org.apache.lucene.search.BooleanQuery
-
Set the maximum number of clauses permitted per BooleanQuery.
- setMaxCombineWordLength(int) - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
The maximum length of a suggestion made by combining 1 or more original
terms.
- setMaxDeterminizedStates(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- setMaxDocCharsToAnalyze(int) - Method in class org.apache.lucene.search.highlight.Highlighter
-
- setMaxDocCharsToAnalyze(int) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- setMaxDocCharsToAnalyze(int) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
A threshold of number of characters to analyze.
- setMaxDocFreq(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Set the maximum frequency in which words may still appear.
- setMaxDocFreqPct(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Set the maximum percentage in which words may still appear.
- setMaxDocs(int) - Static method in class org.apache.lucene.index.IndexWriterMaxDocsChanger
-
- setMaxEdits(int) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Sets the maximum number of Levenshtein edit-distances to draw
candidate terms from.
- setMaxEvaluations(int) - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
The maximum number of word combinations to evaluate.
- setMaxInspections(int) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Set the maximum number of top-N inspections (default: 5) per suggestion.
- setMaxLength(int) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setMaxMergeAtOnce(int) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Maximum number of segments to be merged at a time
during "normal" merging.
- setMaxMergeAtOnceExplicit(int) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Maximum number of segments to be merged at a time,
during forceMerge or forceMergeDeletes.
- setMaxMergeDocs(int) - Method in class org.apache.lucene.index.LogMergePolicy
-
Determines the largest segment (measured by
document count) that may be merged with other segments.
- setMaxMergedSegmentMB(double) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Maximum sized segment to produce during
normal merging.
- setMaxMergeMB(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Determines the largest segment (measured by total
byte size of the segment's files, in MB) that may be
merged with other segments.
- setMaxMergeMBForForcedMerge(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Determines the largest segment (measured by total
byte size of the segment's files, in MB) that may be
merged with other segments during forceMerge.
- setMaxMergesAndThreads(int, int) - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Expert: directly set the maximum number of merge threads and
simultaneous merges allowed.
- setMaxNoHighlightPassages(int) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setMaxNonCompetitiveBoost(float) - Method in interface org.apache.lucene.search.MaxNonCompetitiveBoostAttribute
-
This is the maximum boost that would not be competitive.
- setMaxNonCompetitiveBoost(float) - Method in class org.apache.lucene.search.MaxNonCompetitiveBoostAttributeImpl
-
- setMaxNumTokensParsed(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
- setMaxQueries(int) - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
Set the maximum number of quality queries to run.
- setMaxQueryFrequency(float) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Set the maximum threshold (default: 0.01f) of documents a query term can
appear in order to provide suggestions.
- setMaxQueryTerms(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the maximum number of query terms that will be included in any generated query.
- setMaxQueryTerms(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setMaxResults(int) - Method in class org.apache.lucene.benchmark.quality.QualityBenchmark
-
set the maximum number of results to collect for each quality query.
- setMaxScore(float) - Method in class org.apache.lucene.search.TopDocs
-
Sets the maximum score value encountered.
- setMaxShingleSize(int) - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
Set the max shingle size (default: 2)
- setMaxSize(int) - Method in class org.apache.lucene.facet.taxonomy.LRUHashMap
-
setMaxSize() allows changing the map's maximal number of elements
which was defined at construction time.
- setMaxSizeInBytes(long) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
Toggle maxTokenLength for MockTokenizer
- setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
Set maximum allowed token length.
- setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
Set the max allowed token length.
- setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.StandardAnalyzer
-
Set the max allowed token length.
- setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Set the max allowed token length.
- setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
Set the max allowed token length.
- setMaxTokenLength(int) - Method in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Set the max allowed token length.
- setMaxWordLen(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the maximum word length above which words will be ignored.
- setMBPerSec(double) - Method in class org.apache.lucene.index.MergeRateLimiter
-
- setMBPerSec(double) - Method in class org.apache.lucene.store.RateLimiter
-
Sets an updated MB per second rate limit.
- setMBPerSec(double) - Method in class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
-
Sets an updated mb per second rate limit.
- setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setMergedSegmentWarmer(IndexWriter.IndexReaderWarmer) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Set the merged segment warmer.
- setMergeFactor(int) - Method in class org.apache.lucene.index.LogMergePolicy
-
Determines how often segment indices are merged by
addDocument().
- setMergeInfo(SegmentCommitInfo) - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
- setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setMergePolicy(MergePolicy) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Expert:
MergePolicy
is invoked whenever there are changes to the
segments in the index.
- setMergeScheduler(MergeScheduler) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: sets the merge scheduler used by this writer.
- setMin(int, Object) - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase.Range
-
- setMinBreakWordLength(int) - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
The minimum length to break words down to.
- setMinDocFreq(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the frequency at which words will be ignored which do not occur in at least this
many docs.
- setMinDocFreq(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.search.BooleanQuery.Builder
-
Specifies a minimum number of the optional BooleanClauses
which must be satisfied.
- setMinMergeDocs(int) - Method in class org.apache.lucene.index.LogDocMergePolicy
-
Sets the minimum size for the lowest level segments.
- setMinMergeMB(double) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
Sets the minimum size for the lowest level segments.
- setMinPrefix(int) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Sets the minimal number of initial characters (default: 1)
that must match exactly.
- setMinQueryLength(int) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Set the minimum length of a query term (default: 4) needed to return suggestions.
- setMinShingleSize(int) - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
Set the min shingle size (default: 2).
- setMinSimilarity(float) - Method in class org.apache.lucene.queryparser.flexible.standard.config.FuzzyConfig
-
- setMinSuggestionFrequency(int) - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
The minimum frequency a term must have to be included as part of a
suggestion.
- setMinTermFreq(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the frequency below which terms will be ignored in the source doc.
- setMinTermFrequency(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setMinWordLen(int) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Sets the minimum word length below which words will be ignored.
- setMissingValue(Object) - Method in class org.apache.lucene.search.SortedNumericSortField
-
- setMissingValue(Object) - Method in class org.apache.lucene.search.SortedSetSortField
-
Set how missing values (the empty set) are sorted.
- setMissingValue(Object) - Method in class org.apache.lucene.search.SortField
-
Set the value to use for documents that don't have a value.
- setMoreLikeFields(String[]) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setMultiFields(CharSequence[]) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Set the fields a query should be expanded to when the field is
null
- setMultiOverlappingIndexedShapes(boolean) - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- setMultiTermRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- setMultiValued(String, boolean) - Method in class org.apache.lucene.facet.FacetsConfig
-
Pass true
if this dimension may have more than
one value per document.
- setMultiValuedSeparator(char) - Method in class org.apache.lucene.search.vectorhighlight.BaseFragmentsBuilder
-
- setName(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- setName(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- setName(String) - Method in class org.apache.lucene.benchmark.byTask.utils.AnalyzerFactory
-
- setNBestCost(int) - Method in class org.apache.lucene.analysis.ja.JapaneseTokenizer
-
- setNextMatch(IntsRef) - Method in class org.apache.lucene.search.suggest.document.CompletionWeight
-
Set for every partial path in the index that matched the query
automaton.
- setNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector.GroupHead
-
Called for each segment
- setNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.GroupReducer
-
- setNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.GroupSelector
-
Set the LeafReaderContext
- setNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.TermGroupSelector
-
- setNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.ValueSourceGroupSelector
-
- setNextSentence(int, int) - Method in class org.apache.lucene.analysis.cn.smart.HMMChineseTokenizer
-
- setNextSentence(int, int) - Method in class org.apache.lucene.analysis.th.ThaiTokenizer
-
- setNextSentence(int, int) - Method in class org.apache.lucene.analysis.util.SegmentingTokenizerBase
-
Provides the next input sentence for analysis
- setNextWriteGeneration(long) - Method in class org.apache.lucene.index.SegmentInfos
-
Set the generation to be used for the next commit
- setNoCFSRatio(double) - Method in class org.apache.lucene.index.FilterMergePolicy
-
- setNoCFSRatio(double) - Method in class org.apache.lucene.index.MergePolicy
-
If a merged segment will be more than this percentage
of the total size of the index, leave the segment as
non-compound file even if compound file is enabled.
- setNoCFSRatio(double) - Method in class org.apache.lucene.index.NoMergePolicy
-
- setNoChildReport() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
Execute child tasks in a way that they do not report their time separately.
- setNonLocalizedMessage(Message) - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
- setNumberFormat(NumberFormat) - Method in class org.apache.lucene.queryparser.flexible.standard.config.PointsConfig
-
Sets the NumberFormat
used to parse a String
to
Number
- setNumberFormat(NumberFormat) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
Sets the NumberFormat
used to convert the value to String
.
- setNumberOfDocuments(long) - Method in class org.apache.lucene.search.similarities.BasicStats
-
Sets the number of documents.
- setNumberOfFieldTokens(long) - Method in class org.apache.lucene.search.similarities.BasicStats
-
Sets the total number of tokens in the field.
- setNumOverlap(int) - Method in class org.apache.lucene.index.FieldInvertState
-
Set number of terms with positionIncrement ==
0
.
- setNumReturnValues(int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Sets the default maximum number of values returned from the
matchPrefix
and matchAlmost
methods.
- setOffset(int, int) - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
-
Set the starting and ending offset.
- setOffset(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-
- setOffset(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Set the starting and ending offset.
- setOffsetGap(int) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
Set a new offset gap which will then be added to the offset when several fields with the same name are indexed
- setOffsetGap(Integer) - Method in class org.apache.lucene.benchmark.byTask.utils.AnalyzerFactory
-
- setOmitNorms(boolean) - Method in class org.apache.lucene.document.FieldType
-
Set to true
to omit normalization values for the field.
- setOmitsNorms() - Method in class org.apache.lucene.index.FieldInfo
-
Omit norms for this field.
- SetOnce<T> - Class in org.apache.lucene.util
-
A convenient class which offers a semi-immutable object wrapper
implementation which allows one to set the value of an object exactly once,
and retrieve it many times.
- SetOnce() - Constructor for class org.apache.lucene.util.SetOnce
-
A default constructor which does not set the internal object, and allows
setting it by calling
SetOnce.set(Object)
.
- SetOnce(T) - Constructor for class org.apache.lucene.util.SetOnce
-
Creates a new instance with the internal object set to the given object.
- SetOnce.AlreadySetException - Exception in org.apache.lucene.util
-
- setOpenMode(IndexWriterConfig.OpenMode) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setOperation(SpatialOperation) - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
- setOptimizePredicates(boolean) - Method in class org.apache.lucene.spatial.composite.CompositeSpatialStrategy
-
Set to false to NOT use optimized search predicates that avoid checking the geometry sometimes.
- setOut(PrintStream) - Method in class org.apache.lucene.index.CheckIndex.Options
-
Set the PrintStream to use for reporting results.
- setOutputUnigrams(boolean) - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
Shall the output stream contain the input tokens (unigrams) as well as
shingles? (default: true.)
- setOutputUnigramsIfNoShingles(boolean) - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
Shall we override the behavior of outputUnigrams==false for those
times when no shingles are available (because there are fewer than
minShingleSize tokens in the input stream)? (default: false.)
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
Set the params (docSize only)
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.AddIndexesTask
-
Set the params (useAddIndexesDir only)
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.AnalyzerFactoryTask
-
Sets the params.
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.CloseIndexTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.CommitIndexTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.ForceMergeTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.NearRealtimeReaderTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.NewAnalyzerTask
-
Set the params (analyzerName only), Comma-separate list of Analyzer class names.
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.NewLocaleTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenReaderTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Set the params of this task.
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.PrintReaderTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetLoadFieldSelectorTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
-
SortFields: field:type,field:type[,noscore][,nomaxscore]
If noscore is present, then we turn off score tracking
in
TopFieldCollector
.
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.SetPropTask
-
Set the params (property name and value).
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.UpdateDocTask
-
Set the params (docSize only)
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.WaitTask
-
- setParams(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
Set the params (docSize only)
- setPathElements(List<PathQueryNode.QueryText>) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
Returns the a List with all QueryText elements
- setPayload(BytesRef) - Method in class org.apache.lucene.analysis.Token
-
Sets this Token's payload.
- setPayload(BytesRef) - Method in interface org.apache.lucene.analysis.tokenattributes.PayloadAttribute
-
Sets this Token's payload.
- setPayload(BytesRef) - Method in class org.apache.lucene.analysis.tokenattributes.PayloadAttributeImpl
-
- setPayload(BytesRef) - Method in class org.apache.lucene.search.suggest.document.CompletionTokenStream
-
Sets a payload available throughout successive token stream enumeration
- setPercentTermsToMatch(float) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setPerfObject(String, Object) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Sets an object that is required by
PerfTask
s, keyed by the given
key
.
- setPhraseLimit(int) - Method in class org.apache.lucene.search.vectorhighlight.FastVectorHighlighter
-
set the maximum number of phrases to analyze when searching for the highest-scoring phrase.
- setPhraseSlop(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
Sets the default slop for phrases.
- setPhraseSlop(int) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
Sets the default slop for phrases.
- setPhraseSlop(int) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
Sets the default slop for phrases.
- setPivot(int) - Method in class org.apache.lucene.util.IntroSelector
-
- setPivot(int) - Method in class org.apache.lucene.util.IntroSorter
-
- setPivot(int) - Method in class org.apache.lucene.util.Sorter
-
- setPointDimensions(int, int, int) - Method in class org.apache.lucene.index.FieldInfo
-
Record that this field is indexed with points, with the
specified number of dimensions and bytes per dimension.
- setPointsConfigMap(Map<String, PointsConfig>) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- setPointsOnly(boolean) - Method in class org.apache.lucene.spatial.prefix.PrefixTreeStrategy
-
True if only indexed points shall be supported.
- setPosition(int) - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- setPosition(long) - Method in class org.apache.lucene.util.fst.FST.BytesReader
-
Set current read position.
- setPosition(long) - Method in class org.apache.lucene.util.PagedBytes.PagedBytesDataInput
-
- setPositionIncrement(int) - Method in class org.apache.lucene.analysis.ko.Token
-
- setPositionIncrement(int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Set the position increment.
- setPositionIncrement(int) - Method in interface org.apache.lucene.analysis.tokenattributes.PositionIncrementAttribute
-
Set the position increment.
- setPositionIncrement(int) - Method in class org.apache.lucene.analysis.tokenattributes.PositionIncrementAttributeImpl
-
- setPositionIncrement(int) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- setPositionIncrementGap(int) - Method in class org.apache.lucene.analysis.MockAnalyzer
-
- setPositionIncrementGap(Integer) - Method in class org.apache.lucene.benchmark.byTask.utils.AnalyzerFactory
-
- setPositionLength(int) - Method in class org.apache.lucene.analysis.ja.Token
-
Set the position length (in tokens) of this token.
- setPositionLength(int) - Method in class org.apache.lucene.analysis.ko.Token
-
- setPositionLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Set the position length of this Token.
- setPositionLength(int) - Method in interface org.apache.lucene.analysis.tokenattributes.PositionLengthAttribute
-
Set the position length of this Token.
- setPositionLength(int) - Method in class org.apache.lucene.analysis.tokenattributes.PositionLengthAttributeImpl
-
- setPositionSensitive(boolean) - Method in class org.apache.lucene.search.highlight.WeightedSpanTerm
-
- setPrefix(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
-
- setPrefixGridScanLevel(int) - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
Sets the grid level [1-maxLevels] at which indexed terms are scanned brute-force
instead of by grid decomposition.
- setPrefixLength(int) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- setPrefixLength(int) - Method in class org.apache.lucene.queryparser.flexible.standard.config.FuzzyConfig
-
- setPreload(boolean) - Method in class org.apache.lucene.store.MMapDirectory
-
Set to true
to ask mapped pages to be loaded
into physical memory on init.
- setPreservePositionIncrements(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
-
Whether to generate holes in the automaton for missing positions, true
by default.
- setPreservePositionIncrements(boolean) - Method in class org.apache.lucene.search.TokenStreamToTermAutomatonQuery
-
Whether to generate holes in the automaton for missing positions, true
by default.
- setProps(Properties) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- SetPropTask - Class in org.apache.lucene.benchmark.byTask.tasks
-
Set a performance test configuration property.
- SetPropTask(PerfRunData) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.SetPropTask
-
- setPruneLeafyBranches(boolean) - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
An optional hint affecting non-point shapes and tree cells implementing
CellCanPrune
, otherwise
ignored.
- setPruneLeafyBranches(boolean) - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- setQuery(CharSequence) - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeParseException
-
- setQueryBuilder(QueryBuilder) - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
The query builder that will be used to build an object from the query node
tree.
- setQueryCache(QueryCache) - Method in class org.apache.lucene.search.IndexSearcher
-
Set the
QueryCache
to use when scores are not needed.
- setQueryCachingPolicy(QueryCachingPolicy) - Method in class org.apache.lucene.search.IndexSearcher
-
- setQueryConfigHandler(QueryConfigHandler) - Method in interface org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessor
-
- setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorImpl
-
- setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
Sets the query configuration handler that will be used during query
processing.
- setQueryConfigHandler(QueryConfigHandler) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- setQueryNodeProcessor(QueryNodeProcessor) - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
Sets the processor that will be used to process the query node tree.
- setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setRAMBufferSizeMB(double) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Determines the amount of RAM that may be used for buffering added documents
and deletions before they are flushed to the Directory.
- setRAMPerThreadHardLimitMB(int) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: Sets the maximum memory consumption per thread triggering a forced
flush if exceeded.
- setRandomIOExceptionRate(double) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
If 0.0, no exceptions will be thrown.
- setRandomIOExceptionRateOnOpen(double) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
If 0.0, no exceptions will be thrown during openInput
and createOutput.
- setRangeValues(double[], double[]) - Method in class org.apache.lucene.document.DoubleRange
-
Changes the values of the field.
- setRangeValues(float[], float[]) - Method in class org.apache.lucene.document.FloatRange
-
Changes the values of the field.
- setRangeValues(InetAddress, InetAddress) - Method in class org.apache.lucene.document.InetAddressRange
-
Change (or set) the min/max values of the field.
- setRangeValues(int[], int[]) - Method in class org.apache.lucene.document.IntRange
-
Changes the values of the field.
- setRangeValues(double, double, double, double) - Method in class org.apache.lucene.document.LatLonBoundingBox
-
Changes the values of the field
- setRangeValues(long[], long[]) - Method in class org.apache.lucene.document.LongRange
-
Changes the values of the field.
- setRate(int, boolean) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- setRawBytesRef(BytesRef, long) - Method in class org.apache.lucene.util.ByteBlockPool
-
Set the given
BytesRef
so that its content is equal to the
ref.length
bytes starting at
offset
.
- setReader(Reader) - Method in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
-
Resets the encapsulated components with the given reader.
- setReader(Reader) - Method in class org.apache.lucene.analysis.Tokenizer
-
Expert: Set a new reader on the Tokenizer.
- setReaderPooling(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
-
By default, IndexWriter does not pool the
SegmentReaders it must open for deletions and
merging, unless a near-real-time reader has been
obtained by calling
DirectoryReader.open(IndexWriter)
.
- setReaderValue(Reader) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setRef(Character, int) - Method in class org.egothor.stemmer.Row
-
Set the reference to the next row in the Cell of the given Character to the
given integer.
- setRepetitions(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- setRequireDimCount(String, boolean) - Method in class org.apache.lucene.facet.FacetsConfig
-
Pass true
if at search time you require
accurate counts of the dimension, i.e.
- setRequireDimensionDrillDown(String, boolean) - Method in class org.apache.lucene.facet.FacetsConfig
-
Specify whether drill down on just the dimension is necessary.
- setResolution(long) - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
Set the timer resolution.
- setReusableComponents(Analyzer, String, Analyzer.TokenStreamComponents) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
-
Stores the given TokenStreamComponents as the reusable components for the
field with the give name.
- setRewriteMethod(BlendedTermQuery.RewriteMethod) - Method in class org.apache.lucene.search.BlendedTermQuery.Builder
-
- setRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.apache.lucene.search.MultiTermQuery
-
Sets the rewrite method to be used when executing the
query.
- setRewriteMethod(SpanMultiTermQueryWrapper.SpanRewriteMethod) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
Expert: sets the rewrite method.
- setRunInBackground(int) - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- setRunTime(double) - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- setScore(float) - Method in class org.apache.lucene.search.uhighlight.Passage
-
- setScorer(Scorer) - Method in class org.apache.lucene.facet.FacetsCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.CheckHits.ExplanationAsserter
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.CheckHits.SetCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.FilterLeafCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector.GroupHead
-
Called for each segment
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.AllGroupsCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.BlockGroupingCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.FirstPassGroupingCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.GroupReducer
-
Set the Scorer on all group collectors
- setScorer(Scorer) - Method in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- setScorer(Scorer) - Method in interface org.apache.lucene.search.LeafCollector
-
- setScorer(Scorer) - Method in interface org.apache.lucene.search.LeafFieldComparator
-
Sets the Scorer to use in case a document's score is
needed.
- setScorer(Scorer) - Method in class org.apache.lucene.search.MultiCollectorManager.Collectors.LeafCollectors
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.SimpleCollector
-
- setScorer(Scorer) - Method in class org.apache.lucene.search.SimpleFieldComparator
-
- setScorer(PassageScorer) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- setSegmentsPerTier(double) - Method in class org.apache.lucene.index.TieredMergePolicy
-
Sets the allowed number of segments per tier.
- setShape(Shape) - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
- setShapeRel(SpatialRelation) - Method in interface org.apache.lucene.spatial.prefix.tree.Cell
-
- setShapeRel(SpatialRelation) - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- setShapeRel(SpatialRelation) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- setShortValue(short) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setSimilarity(Similarity) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Expert: set the
Similarity
implementation used by this IndexWriter.
- setSimilarity(Similarity) - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Set the Similarity to be used for calculating field norms
- setSimilarity(TFIDFSimilarity) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
- setSimilarity(float) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- setSimilarity(Similarity) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Set the Similarity implementation used by this IndexSearcher.
- setSize(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.DiskOrdinalMap
-
- setSize(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.MemoryOrdinalMap
-
- setSize(int) - Method in interface org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyWriter.OrdinalMap
-
Set the size of the map.
- setSlop(int) - Method in class org.apache.lucene.search.MultiPhraseQuery.Builder
-
Sets the phrase slop for this query.
- setSlop(int) - Method in class org.apache.lucene.search.PhraseQuery.Builder
-
Set the slop.
- setSlop(int) - Method in class org.apache.lucene.search.spans.SpanNearQuery.Builder
-
Set the slop for this query
- setSoftDeletesField(String) - Method in class org.apache.lucene.index.IndexWriterConfig
-
Sets the soft deletes field.
- setSort(SortField) - Method in class org.apache.lucene.search.Sort
-
Sets the sort to the given criteria.
- setSort(SortField...) - Method in class org.apache.lucene.search.Sort
-
Sets the sort to the given criteria in succession: the
first SortField is checked first, but if it produces a
tie, then the second SortField is used to break the tie,
etc.
- setSortWithinGroup(Sort) - Method in class org.apache.lucene.search.grouping.GroupingSearch
-
Specified how documents inside a group are sorted.
- setSpellIndex(Directory) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Use a different index as the spell checker index or re-open
the existing index if spellIndex
is the same value
as given in the constructor.
- setSplitOnWhitespace(boolean) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
Whether query text should be split on whitespace prior to analysis.
- setStartOffset(int) - Method in class org.apache.lucene.search.uhighlight.Passage
-
- setStartTimeMillis() - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- setStemmer(GermanStemmer) - Method in class org.apache.lucene.analysis.de.GermanStemFilter
-
- setStopWords(Set<?>) - Method in class org.apache.lucene.queries.mlt.MoreLikeThis
-
Set the set of stopwords.
- setStopWords(Set<?>) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- setStored(boolean) - Method in class org.apache.lucene.document.FieldType
-
Set to true
to store this field.
- setStoredValue(Analyzer, Object) - Method in class org.apache.lucene.analysis.Analyzer.ReuseStrategy
-
Sets the stored value.
- setStoreTermVectorOffsets(boolean) - Method in class org.apache.lucene.document.FieldType
-
Set to true
to also store token character offsets into the term
vector for this field.
- setStoreTermVectorPayloads(boolean) - Method in class org.apache.lucene.document.FieldType
-
Set to true
to also store token payloads into the term
vector for this field.
- setStoreTermVectorPositions(boolean) - Method in class org.apache.lucene.document.FieldType
-
Set to true
to also store token positions into the term
vector for this field.
- setStoreTermVectors(boolean) - Method in class org.apache.lucene.document.FieldType
-
Set to true
if this field's indexed form should be also stored
into term vectors.
- setStringDistance(StringDistance) - Method in class org.apache.lucene.search.spell.SpellChecker
-
- setStringValue(String) - Method in class org.apache.lucene.collation.CollationDocValuesField
-
- setStringValue(String) - Method in class org.apache.lucene.collation.ICUCollationDocValuesField
-
- setStringValue(String) - Method in class org.apache.lucene.document.Field
-
Expert: change the value of this field.
- setSyntaxParser(SyntaxParser) - Method in class org.apache.lucene.queryparser.flexible.core.QueryParserHelper
-
Sets the text parser that will be used to parse the query string, it cannot
be null
.
- setTag(String, Object) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
Associate the specified value with the specified tagName.
- setTag(String, Object) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
- setTags(List<StringBuilder>) - Method in interface org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttribute
-
Set the POS tag.
- setTags(List<StringBuilder>) - Method in class org.apache.lucene.analysis.morfologik.MorphosyntacticTagsAttributeImpl
-
Sets the internal tags reference to the given list.
- setTaxonomyReader(TaxonomyReader) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
Set the taxonomy reader.
- setTaxonomyWriter(TaxonomyWriter) - Method in class org.apache.lucene.benchmark.byTask.PerfRunData
-
- setTerm(String) - Method in class org.apache.lucene.search.highlight.WeightedTerm
-
- setTermFrequency(int) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
- setTermFrequency(int) - Method in interface org.apache.lucene.analysis.tokenattributes.TermFrequencyAttribute
-
Set the custom term frequency of the current term within one document.
- setTermFrequency(int) - Method in class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
-
- setText(char[], int, int) - Method in class org.apache.lucene.analysis.util.CharArrayIterator
-
Set a new region of text to be examined by this iterator
- setText(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- setText(CharSequence) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.TextableQueryNode
-
- setText(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- setText(CharacterIterator) - Method in class org.apache.lucene.search.uhighlight.CustomSeparatorBreakIterator
-
- setText(String) - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- setText(CharacterIterator) - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- setText(CharacterIterator) - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- setText(String) - Method in class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- setText(CharacterIterator) - Method in class org.apache.lucene.search.uhighlight.WholeBreakIterator
-
- setTextFragmenter(Fragmenter) - Method in class org.apache.lucene.search.highlight.Highlighter
-
- setThreshold(float) - Method in class org.apache.lucene.search.spell.JaroWinklerDistance
-
Sets the threshold used to determine when Winkler bonus should be used.
- setThresholdFrequency(float) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Set the minimal threshold of documents a term must appear for a match.
- setThrottling(MockDirectoryWrapper.Throttling) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- setTimeZone(TimeZone) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- setTimeZone(TimeZone) - Method in interface org.apache.lucene.queryparser.flexible.standard.CommonQueryParserConfiguration
-
- setTimeZone(TimeZone) - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- setTitle(String) - Method in class org.apache.lucene.benchmark.byTask.feeds.DocData
-
- setToken(Token) - Method in interface org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttribute
-
- setToken(Token) - Method in class org.apache.lucene.analysis.ja.tokenattributes.BaseFormAttributeImpl
-
- setToken(Token) - Method in interface org.apache.lucene.analysis.ja.tokenattributes.InflectionAttribute
-
- setToken(Token) - Method in class org.apache.lucene.analysis.ja.tokenattributes.InflectionAttributeImpl
-
- setToken(Token) - Method in interface org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttribute
-
- setToken(Token) - Method in class org.apache.lucene.analysis.ja.tokenattributes.PartOfSpeechAttributeImpl
-
- setToken(Token) - Method in interface org.apache.lucene.analysis.ja.tokenattributes.ReadingAttribute
-
- setToken(Token) - Method in class org.apache.lucene.analysis.ja.tokenattributes.ReadingAttributeImpl
-
- setToken(Token) - Method in interface org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttribute
-
Set the current token.
- setToken(Token) - Method in class org.apache.lucene.analysis.ko.tokenattributes.PartOfSpeechAttributeImpl
-
- setToken(Token) - Method in interface org.apache.lucene.analysis.ko.tokenattributes.ReadingAttribute
-
Set the current token.
- setToken(Token) - Method in class org.apache.lucene.analysis.ko.tokenattributes.ReadingAttributeImpl
-
- setTokenized(boolean) - Method in class org.apache.lucene.document.FieldType
-
Set to
true
to tokenize this field's contents via the
configured
Analyzer
.
- setTokenSeparator(String) - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
Sets the string to use when joining adjacent tokens to form a shingle
- setTokenStream(TokenStream) - Method in class org.apache.lucene.document.Field
-
Expert: sets the token stream to be used for indexing and causes
isIndexed() and isTokenized() to return true.
- setTokenType(String) - Method in class org.apache.lucene.analysis.shingle.ShingleFilter
-
Set the type of the shingle tokens produced by this filter.
- setTopValue(Integer) - Method in class org.apache.lucene.search.FieldComparator.DocComparator
-
- setTopValue(Double) - Method in class org.apache.lucene.search.FieldComparator.DoubleComparator
-
- setTopValue(Float) - Method in class org.apache.lucene.search.FieldComparator.FloatComparator
-
- setTopValue(Integer) - Method in class org.apache.lucene.search.FieldComparator.IntComparator
-
- setTopValue(Long) - Method in class org.apache.lucene.search.FieldComparator.LongComparator
-
- setTopValue(Float) - Method in class org.apache.lucene.search.FieldComparator.RelevanceComparator
-
- setTopValue(T) - Method in class org.apache.lucene.search.FieldComparator
-
- setTopValue(BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
- setTopValue(BytesRef) - Method in class org.apache.lucene.search.FieldComparator.TermValComparator
-
- setTotalTermFreq(long) - Method in class org.apache.lucene.search.similarities.BasicStats
-
Sets the total number of occurrences of this term across all documents.
- setTrackDiskUsage(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- setType(String) - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Set the lexical type.
- setType(String) - Method in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
-
Set the lexical type.
- setType(String) - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-
- setType(Class<? extends Number>) - Method in class org.apache.lucene.queryparser.flexible.standard.config.PointsConfig
-
Sets the numeric type used to index the numeric values
- setUnicodeArcs(boolean) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
-
Whether to make transition labels Unicode code points instead of UTF8 bytes,
false
by default
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddFacetedDocTask
-
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddIndexesTask
-
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Task setup work that should not be measured for that specific task.
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTokensTask
-
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetHighlightTask
-
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithCollectorTask
-
- setup() - Method in class org.apache.lucene.benchmark.byTask.tasks.UpdateDocTask
-
- setUp() - Method in class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
- setUp() - Method in class org.apache.lucene.util.LuceneTestCase
-
For subclasses to override.
- setupCPUCoreCount() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- setupSpins() - Static method in class org.apache.lucene.util.LuceneTestCase
-
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.IndexWriterConfig
-
- setUseCompoundFile(boolean) - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
Sets if the
IndexWriter
should pack newly written segments in a
compound file.
- setUsePayloads(boolean) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- setUsePayloads(boolean) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- setUserData(Map<String, String>, boolean) - Method in class org.apache.lucene.index.SegmentInfos
-
Sets the commit data.
- setUseSlowOpenClosers(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
Add a rare small sleep to catch race conditions in open/close
- setUseUnmap(boolean) - Method in class org.apache.lucene.store.MMapDirectory
-
This method enables the workaround for unmapping the buffers
from address space after closing
IndexInput
, that is
mentioned in the bug report.
- setValue(V) - Method in class org.apache.lucene.analysis.CharArrayMap.EntryIterator
-
sets the value associated with the last key returned
- setValue(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- setValue(T) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.ValueQueryNode
-
- setValue(Number) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
Sets the numeric value.
- setVerboseClone(boolean) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
If set to true, we print a fake exception
with filename and stacktrace on every indexinput clone()
- setVersion(Version) - Method in class org.apache.lucene.analysis.Analyzer
-
Set the version of Lucene this analyzer should mimic the behavior for for analysis.
- setWeight(float) - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- setWeight(float) - Method in class org.apache.lucene.search.highlight.WeightedTerm
-
- setWrapIfNotCachingTokenFilter(boolean) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- setWrapIfNotCachingTokenFilter(boolean) - Method in class org.apache.lucene.search.highlight.WeightedSpanTermExtractor
-
- sf(String, int) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanFirst(SpanTermQuery)
- SHADDA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- shallowSizeOf(Object[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the shallow size in bytes of the Object[] object.
- shallowSizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Estimates a "shallow" memory usage of the given object.
- shallowSizeOfInstance(Class<?>) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the shallow instance size in bytes an instance of the given class would occupy.
- shape - Variable in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- shape - Variable in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- ShapeAreaValueSource - Class in org.apache.lucene.spatial.util
-
The area of a Shape retrieved from an ShapeValuesSource
- ShapeAreaValueSource(ShapeValuesSource, SpatialContext, boolean, double) - Constructor for class org.apache.lucene.spatial.util.ShapeAreaValueSource
-
- shapeConverter - Variable in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- shapeField - Variable in class org.apache.lucene.spatial.util.ShapeFieldCacheProvider
-
- ShapeFieldCache<T extends org.locationtech.spatial4j.shape.Shape> - Class in org.apache.lucene.spatial.util
-
Bounded Cache of Shapes associated with docIds.
- ShapeFieldCache(int, int) - Constructor for class org.apache.lucene.spatial.util.ShapeFieldCache
-
- ShapeFieldCacheDistanceValueSource - Class in org.apache.lucene.spatial.util
-
A DoubleValuesSource that returns the spatial distance
between an input point and a document's points in
ShapeFieldCacheProvider
.
- ShapeFieldCacheDistanceValueSource(SpatialContext, ShapeFieldCacheProvider<Point>, Point, double) - Constructor for class org.apache.lucene.spatial.util.ShapeFieldCacheDistanceValueSource
-
- ShapeFieldCacheProvider<T extends org.locationtech.spatial4j.shape.Shape> - Class in org.apache.lucene.spatial.util
-
- ShapeFieldCacheProvider(String, int) - Constructor for class org.apache.lucene.spatial.util.ShapeFieldCacheProvider
-
- shapeRel - Variable in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
When set via getSubCells(filter), it is the relationship between this cell
and the given shape filter.
- shapes - Variable in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
Shape's container
- ShapeValues - Class in org.apache.lucene.spatial
-
Iterator over Shape
objects for an index segment
- ShapeValues() - Constructor for class org.apache.lucene.spatial.ShapeValues
-
- ShapeValuesPredicate - Class in org.apache.lucene.spatial.util
-
- ShapeValuesPredicate(ShapeValuesSource, SpatialOperation, Shape) - Constructor for class org.apache.lucene.spatial.util.ShapeValuesPredicate
-
- ShapeValuesSource - Class in org.apache.lucene.spatial
-
- ShapeValuesSource() - Constructor for class org.apache.lucene.spatial.ShapeValuesSource
-
- shardIndex - Variable in class org.apache.lucene.search.ScoreDoc
-
- ShardIndexSearcher(long[], IndexReader, int) - Constructor for class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- ShardSearchingTestBase - Class in org.apache.lucene.search
-
Base test class for simulating distributed search across multiple shards.
- ShardSearchingTestBase() - Constructor for class org.apache.lucene.search.ShardSearchingTestBase
-
- ShardSearchingTestBase.NodeState - Class in org.apache.lucene.search
-
- ShardSearchingTestBase.NodeState.ShardIndexSearcher - Class in org.apache.lucene.search
-
Matches docs in the local shard but scores based on
aggregated stats ("mock distributed scoring") from all
nodes.
- ShardSearchingTestBase.SearcherAndVersion - Class in org.apache.lucene.search
-
An IndexSearcher and associated version (lease)
- ShardSearchingTestBase.SearcherExpiredException - Exception in org.apache.lucene.search
-
Thrown when the lease for a searcher has expired.
- ShingleAnalyzerWrapper - Class in org.apache.lucene.analysis.shingle
-
- ShingleAnalyzerWrapper(Analyzer) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- ShingleAnalyzerWrapper(Analyzer, int) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- ShingleAnalyzerWrapper(Analyzer, int, int) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- ShingleAnalyzerWrapper(Analyzer, int, int, String, boolean, boolean, String) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
Creates a new ShingleAnalyzerWrapper
- ShingleAnalyzerWrapper() - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- ShingleAnalyzerWrapper(int, int) - Constructor for class org.apache.lucene.analysis.shingle.ShingleAnalyzerWrapper
-
- ShingleFilter - Class in org.apache.lucene.analysis.shingle
-
A ShingleFilter constructs shingles (token n-grams) from a token stream.
- ShingleFilter(TokenStream, int, int) - Constructor for class org.apache.lucene.analysis.shingle.ShingleFilter
-
Constructs a ShingleFilter with the specified shingle size from the
TokenStream
input
- ShingleFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.shingle.ShingleFilter
-
Constructs a ShingleFilter with the specified shingle size from the
TokenStream
input
- ShingleFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.shingle.ShingleFilter
-
Construct a ShingleFilter with default shingle size: 2.
- ShingleFilter(TokenStream, String) - Constructor for class org.apache.lucene.analysis.shingle.ShingleFilter
-
Construct a ShingleFilter with the specified token type for shingle tokens
and the default shingle size: 2
- ShingleFilterFactory - Class in org.apache.lucene.analysis.shingle
-
- ShingleFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.shingle.ShingleFilterFactory
-
Creates a new ShingleFilterFactory
- shortestPaths(FST<T>, FST.Arc<T>, T, Comparator<T>, int, boolean) - Static method in class org.apache.lucene.util.fst.Util
-
Starting from node, find the top N min cost
completions to a final node.
- shortVal(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- shortVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- shortVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- shortVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- shortVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- shortVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- shortVal(int, short[]) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- shouldCache(Query) - Method in interface org.apache.lucene.search.QueryCachingPolicy
-
Whether the given
Query
is worth caching.
- shouldCache(Query) - Method in class org.apache.lucene.search.UsageTrackingQueryCachingPolicy
-
- shouldExit() - Method in interface org.apache.lucene.index.QueryTimeout
-
- shouldExit() - Method in class org.apache.lucene.index.QueryTimeoutImpl
-
- shouldFilter() - Method in class org.apache.lucene.analysis.miscellaneous.ConditionalTokenFilter
-
Whether or not to execute the wrapped TokenFilter(s) for the current token
- shouldFilter() - Method in class org.apache.lucene.analysis.miscellaneous.ProtectedTermFilter
-
- shouldHandleMultiTermQuery(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- shouldHighlightPhrasesStrictly(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
Returns whether position sensitive queries (e.g.
- shouldLog() - Method in class org.apache.lucene.benchmark.byTask.feeds.ContentItemsSource
-
Returns true whether it's time to log a message (depending on verbose and
the number of items generated).
- shouldNeverLogAtStart() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Tasks that should never log at start can override this.
- shouldNeverLogAtStart() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- shouldNotRecordStats() - Method in class org.apache.lucene.benchmark.byTask.tasks.ClearStatsTask
-
- shouldNotRecordStats() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewRoundTask
-
- shouldNotRecordStats() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Tasks that should not record statistics can override this.
- shouldNotRecordStats() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- shouldNotRecordStats() - Method in class org.apache.lucene.benchmark.byTask.tasks.ResetInputsTask
-
- shouldPreferPassageRelevancyOverSpeed(String) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter
-
- shouldUpgradeSegment(SegmentCommitInfo) - Method in class org.apache.lucene.index.UpgradeIndexMergePolicy
-
Returns if the given segment should be upgraded.
- ShuffleFS - Class in org.apache.lucene.mockfile
-
Gives an unpredictable, but deterministic order to directory listings.
- ShuffleFS(FileSystem, long) - Constructor for class org.apache.lucene.mockfile.ShuffleFS
-
Create a new instance, wrapping delegate
.
- shutdown() - Method in class org.apache.lucene.util.SameThreadExecutorService
-
- shutdownExecutorService(ExecutorService) - Static method in class org.apache.lucene.util.TestUtil
-
Shutdown ExecutorService
and wait for its.
- shutdownNow() - Method in class org.apache.lucene.util.SameThreadExecutorService
-
- SI_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene50.Lucene50SegmentInfoFormat
-
Deprecated.
- SI_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene62.Lucene62SegmentInfoFormat
-
- SI_EXTENSION - Static variable in class org.apache.lucene.codecs.lucene70.Lucene70SegmentInfoFormat
-
- SI_EXTENSION - Static variable in class org.apache.lucene.codecs.simpletext.SimpleTextSegmentInfoFormat
-
- siblings() - Method in class org.apache.lucene.facet.taxonomy.ParallelTaxonomyArrays
-
Returns the siblings array, where siblings[i]
denotes the sibling
of category ordinal i
.
- siblingsLoaded() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
Returns true if the (costly, and lazily initialized) sibling int[] was initialized.
- SidedPlane - Class in org.apache.lucene.spatial3d.geom
-
Combination of a plane, and a sign value indicating what evaluation values are on the correct
side of the plane.
- SidedPlane(SidedPlane) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a SidedPlane identical to an existing one, but reversed.
- SidedPlane(double, double, double, Vector, Vector) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from a pair of vectors describing points, and including
origin, plus a point p which describes the side.
- SidedPlane(Vector, Vector, Vector) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from a pair of vectors describing points, and including
origin, plus a point p which describes the side.
- SidedPlane(Vector, Vector) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from a pair of vectors describing points, and including
origin.
- SidedPlane(Vector, Vector, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from a pair of vectors describing points, and including
origin, plus a point p which describes the side.
- SidedPlane(Vector, boolean, Vector, Vector) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from a pair of vectors describing points, and including
origin, plus a point p which describes the side.
- SidedPlane(Vector, PlanetModel, double) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane from a point and a Z coordinate.
- SidedPlane(Vector, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided vertical plane from a point and specified x and y coordinates.
- SidedPlane(Vector, double, double, double, double) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane with a normal vector and offset.
- SidedPlane(Vector, Vector, double) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane with a normal vector and offset.
- SidedPlane(double, double, double, Vector, double) - Constructor for class org.apache.lucene.spatial3d.geom.SidedPlane
-
Construct a sided plane with a normal vector and offset.
- sign() - Method in enum org.apache.lucene.geo.GeoUtils.WindingOrder
-
- sigNum - Variable in class org.apache.lucene.spatial3d.geom.SidedPlane
-
The sign value for evaluation of a point on the correct side of the plane
- similarity - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
- Similarity - Class in org.apache.lucene.search.similarities
-
Similarity defines the components of Lucene scoring.
- Similarity() - Constructor for class org.apache.lucene.search.similarities.Similarity
-
Sole constructor.
- similarity - Variable in class org.apache.lucene.search.spans.SpanWeight
-
- Similarity.SimScorer - Class in org.apache.lucene.search.similarities
-
- Similarity.SimWeight - Class in org.apache.lucene.search.similarities
-
Stores the weight for a query across the indexed collection.
- SimilarityBase - Class in org.apache.lucene.search.similarities
-
A subclass of Similarity
that provides a simplified API for its
descendants.
- SimilarityBase() - Constructor for class org.apache.lucene.search.similarities.SimilarityBase
-
Sole constructor.
- similarityDescription() - Method in class org.apache.lucene.spatial.bbox.BBoxOverlapRatioValueSource
-
- similarityDescription() - Method in class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
- SIMPLE - Static variable in class org.apache.lucene.analysis.MockTokenizer
-
Acts like LetterTokenizer.
- SimpleAnalyzer - Class in org.apache.lucene.analysis.core
-
- SimpleAnalyzer() - Constructor for class org.apache.lucene.analysis.core.SimpleAnalyzer
-
- SimpleBindings - Class in org.apache.lucene.expressions
-
- SimpleBindings() - Constructor for class org.apache.lucene.expressions.SimpleBindings
-
Creates a new empty Bindings
- SimpleBoolFunction - Class in org.apache.lucene.queries.function.valuesource
-
BoolFunction
implementation which applies an extendible boolean
function to the values of a single wrapped
ValueSource
.
- SimpleBoolFunction(ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.SimpleBoolFunction
-
- SimpleBoundaryScanner - Class in org.apache.lucene.search.vectorhighlight
-
Simple boundary scanner implementation that divides fragments
based on a set of separator characters.
- SimpleBoundaryScanner() - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- SimpleBoundaryScanner(int) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- SimpleBoundaryScanner(Character[]) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- SimpleBoundaryScanner(int, Character[]) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- SimpleBoundaryScanner(int, Set<Character>) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleBoundaryScanner
-
- SimpleCollector - Class in org.apache.lucene.search
-
Base
Collector
implementation that is used to collect all contexts.
- SimpleCollector() - Constructor for class org.apache.lucene.search.SimpleCollector
-
- SimpleFacetsExample - Class in org.apache.lucene.demo.facet
-
Shows simple usage of faceted indexing and search.
- SimpleFacetsExample() - Constructor for class org.apache.lucene.demo.facet.SimpleFacetsExample
-
Empty constructor
- SimpleFieldComparator<T> - Class in org.apache.lucene.search
-
- SimpleFieldComparator() - Constructor for class org.apache.lucene.search.SimpleFieldComparator
-
- SimpleFieldFragList - Class in org.apache.lucene.search.vectorhighlight
-
- SimpleFieldFragList(int) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFieldFragList
-
a constructor.
- SimpleFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
A simple float function with a single argument
- SimpleFloatFunction(ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.SimpleFloatFunction
-
- SimpleFragListBuilder - Class in org.apache.lucene.search.vectorhighlight
-
- SimpleFragListBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragListBuilder
-
- SimpleFragListBuilder(int) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragListBuilder
-
- SimpleFragmenter - Class in org.apache.lucene.search.highlight
-
Fragmenter
implementation which breaks text up into same-size
fragments with no concerns over spotting sentence boundaries.
- SimpleFragmenter() - Constructor for class org.apache.lucene.search.highlight.SimpleFragmenter
-
- SimpleFragmenter(int) - Constructor for class org.apache.lucene.search.highlight.SimpleFragmenter
-
- SimpleFragmentsBuilder - Class in org.apache.lucene.search.vectorhighlight
-
A simple implementation of FragmentsBuilder.
- SimpleFragmentsBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
-
a constructor.
- SimpleFragmentsBuilder(String[], String[]) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
-
a constructor.
- SimpleFragmentsBuilder(BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
-
- SimpleFragmentsBuilder(String[], String[], BoundaryScanner) - Constructor for class org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder
-
- SimpleFSDirectory - Class in org.apache.lucene.store
-
A straightforward implementation of
FSDirectory
using
Files.newByteChannel(Path, java.nio.file.OpenOption...)
.
- SimpleFSDirectory(Path, LockFactory) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
-
Create a new SimpleFSDirectory for the named location.
- SimpleFSDirectory(Path) - Constructor for class org.apache.lucene.store.SimpleFSDirectory
-
- SimpleFSLockFactory - Class in org.apache.lucene.store
-
Implements
LockFactory
using
Files.createFile(java.nio.file.Path, java.nio.file.attribute.FileAttribute<?>...)
.
- SimpleHTMLEncoder - Class in org.apache.lucene.search.highlight
-
Simple
Encoder
implementation to escape text for HTML output
- SimpleHTMLEncoder() - Constructor for class org.apache.lucene.search.highlight.SimpleHTMLEncoder
-
- SimpleHTMLFormatter - Class in org.apache.lucene.search.highlight
-
Simple
Formatter
implementation to highlight terms with a pre and
post tag.
- SimpleHTMLFormatter(String, String) - Constructor for class org.apache.lucene.search.highlight.SimpleHTMLFormatter
-
- SimpleHTMLFormatter() - Constructor for class org.apache.lucene.search.highlight.SimpleHTMLFormatter
-
Default constructor uses HTML: <B> tags to markup terms.
- SimpleLineParser(String[]) - Constructor for class org.apache.lucene.benchmark.byTask.feeds.LineDocSource.SimpleLineParser
-
- SimpleMergedSegmentWarmer - Class in org.apache.lucene.index
-
A very simple merged segment warmer that just ensures
data structures are initialized.
- SimpleMergedSegmentWarmer(InfoStream) - Constructor for class org.apache.lucene.index.SimpleMergedSegmentWarmer
-
Creates a new SimpleMergedSegmentWarmer
- SimpleNaiveBayesClassifier - Class in org.apache.lucene.classification
-
A simplistic Lucene based NaiveBayes classifier, see http://en.wikipedia.org/wiki/Naive_Bayes_classifier
- SimpleNaiveBayesClassifier(IndexReader, Analyzer, Query, String, String...) - Constructor for class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
Creates a new NaiveBayes classifier.
- SimpleNaiveBayesDocumentClassifier - Class in org.apache.lucene.classification.document
-
A simplistic Lucene based NaiveBayes classifier, see http://en.wikipedia.org/wiki/Naive_Bayes_classifier
- SimpleNaiveBayesDocumentClassifier(IndexReader, Query, String, Map<String, Analyzer>, String...) - Constructor for class org.apache.lucene.classification.document.SimpleNaiveBayesDocumentClassifier
-
Creates a new NaiveBayes classifier.
- SimplePatternSplitTokenizer - Class in org.apache.lucene.analysis.pattern
-
This tokenizer uses a Lucene
RegExp
or (expert usage) a pre-built determinized
Automaton
, to locate tokens.
- SimplePatternSplitTokenizer(String) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizer
-
See
RegExp
for the accepted syntax.
- SimplePatternSplitTokenizer(Automaton) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizer
-
Runs a pre-built automaton.
- SimplePatternSplitTokenizer(AttributeFactory, String, int) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizer
-
See
RegExp
for the accepted syntax.
- SimplePatternSplitTokenizer(AttributeFactory, Automaton) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizer
-
Runs a pre-built automaton.
- SimplePatternSplitTokenizerFactory - Class in org.apache.lucene.analysis.pattern
-
- SimplePatternSplitTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternSplitTokenizerFactory
-
Creates a new SimpleSplitPatternTokenizerFactory
- SimplePatternTokenizer - Class in org.apache.lucene.analysis.pattern
-
This tokenizer uses a Lucene
RegExp
or (expert usage) a pre-built determinized
Automaton
, to locate tokens.
- SimplePatternTokenizer(String) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternTokenizer
-
See
RegExp
for the accepted syntax.
- SimplePatternTokenizer(Automaton) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternTokenizer
-
Runs a pre-built automaton.
- SimplePatternTokenizer(AttributeFactory, String, int) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternTokenizer
-
See
RegExp
for the accepted syntax.
- SimplePatternTokenizer(AttributeFactory, Automaton) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternTokenizer
-
Runs a pre-built automaton.
- SimplePatternTokenizerFactory - Class in org.apache.lucene.analysis.pattern
-
- SimplePatternTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.pattern.SimplePatternTokenizerFactory
-
Creates a new SimplePatternTokenizerFactory
- SimplePayloadFilter - Class in org.apache.lucene.analysis
-
Simple payload filter that sets the payload as pos: XXXX
- SimplePayloadFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.SimplePayloadFilter
-
- SimpleQQParser - Class in org.apache.lucene.benchmark.quality.utils
-
Simplistic quality query parser.
- SimpleQQParser(String[], String) - Constructor for class org.apache.lucene.benchmark.quality.utils.SimpleQQParser
-
Constructor of a simple qq parser.
- SimpleQQParser(String, String) - Constructor for class org.apache.lucene.benchmark.quality.utils.SimpleQQParser
-
Constructor of a simple qq parser.
- SimpleQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
A QueryMaker that makes queries for a collection created
using
SingleDocSource
.
- SimpleQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.SimpleQueryMaker
-
- SimpleQueryParser - Class in org.apache.lucene.queryparser.simple
-
SimpleQueryParser is used to parse human readable query syntax.
- SimpleQueryParser(Analyzer, String) - Constructor for class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Creates a new parser searching over a single field.
- SimpleQueryParser(Analyzer, Map<String, Float>) - Constructor for class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Creates a new parser searching over multiple fields with different weights.
- SimpleQueryParser(Analyzer, Map<String, Float>, int) - Constructor for class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Creates a new parser with custom flags used to enable/disable certain features.
- SimpleRateLimiter(double) - Constructor for class org.apache.lucene.store.RateLimiter.SimpleRateLimiter
-
mbPerSec is the MB/sec max IO rate
- SimpleSloppyPhraseQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
Create sloppy phrase queries for performance test, in an index created using simple doc maker.
- SimpleSloppyPhraseQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.SimpleSloppyPhraseQueryMaker
-
- SimpleSortedSetFacetsExample - Class in org.apache.lucene.demo.facet
-
- SimpleSortedSetFacetsExample() - Constructor for class org.apache.lucene.demo.facet.SimpleSortedSetFacetsExample
-
Empty constructor
- SimpleSpanFragmenter - Class in org.apache.lucene.search.highlight
-
Fragmenter
implementation which breaks text up into same-size
fragments but does not split up
Spans
.
- SimpleSpanFragmenter(QueryScorer) - Constructor for class org.apache.lucene.search.highlight.SimpleSpanFragmenter
-
- SimpleSpanFragmenter(QueryScorer, int) - Constructor for class org.apache.lucene.search.highlight.SimpleSpanFragmenter
-
- SimpleTerm() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- SimpleTerm - Class in org.apache.lucene.queryparser.surround.query
-
Base class for queries that expand to sets of simple terms.
- SimpleTerm(boolean) - Constructor for class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- SimpleTerm.MatchingTermVisitor - Interface in org.apache.lucene.queryparser.surround.query
-
- SimpleTextCodec - Class in org.apache.lucene.codecs.simpletext
-
plain text index format.
- SimpleTextCodec() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- SimpleTextCompoundFormat - Class in org.apache.lucene.codecs.simpletext
-
plain text compound format.
- SimpleTextCompoundFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextCompoundFormat
-
Sole constructor.
- SimpleTextFieldInfosFormat - Class in org.apache.lucene.codecs.simpletext
-
plaintext field infos format
- SimpleTextFieldInfosFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextFieldInfosFormat
-
- SimpleTextLiveDocsFormat - Class in org.apache.lucene.codecs.simpletext
-
reads/writes plaintext live docs
- SimpleTextLiveDocsFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextLiveDocsFormat
-
- SimpleTextNormsConsumer(SegmentWriteState) - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsConsumer
-
- SimpleTextNormsFormat - Class in org.apache.lucene.codecs.simpletext
-
plain-text norms format.
- SimpleTextNormsFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat
-
- SimpleTextNormsFormat.SimpleTextNormsConsumer - Class in org.apache.lucene.codecs.simpletext
-
Writes plain-text norms.
- SimpleTextNormsFormat.SimpleTextNormsProducer - Class in org.apache.lucene.codecs.simpletext
-
Reads plain-text norms.
- SimpleTextNormsProducer(SegmentReadState) - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsProducer
-
- SimpleTextPointsFormat - Class in org.apache.lucene.codecs.simpletext
-
For debugging, curiosity, transparency only!! Do not
use this codec in production.
- SimpleTextPointsFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextPointsFormat
-
- SimpleTextSegmentInfoFormat - Class in org.apache.lucene.codecs.simpletext
-
plain text segments file format.
- SimpleTextSegmentInfoFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextSegmentInfoFormat
-
- SimpleTextStoredFieldsFormat - Class in org.apache.lucene.codecs.simpletext
-
plain text stored fields format.
- SimpleTextStoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsFormat
-
- SimpleTextStoredFieldsReader - Class in org.apache.lucene.codecs.simpletext
-
reads plaintext stored fields
- SimpleTextStoredFieldsReader(Directory, SegmentInfo, FieldInfos, IOContext) - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsReader
-
- SimpleTextStoredFieldsWriter - Class in org.apache.lucene.codecs.simpletext
-
Writes plain-text stored fields.
- SimpleTextStoredFieldsWriter(Directory, String, IOContext) - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsWriter
-
- SimpleTextTermVectorsFormat - Class in org.apache.lucene.codecs.simpletext
-
plain text term vectors format.
- SimpleTextTermVectorsFormat() - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsFormat
-
- SimpleTextTermVectorsReader - Class in org.apache.lucene.codecs.simpletext
-
Reads plain-text term vectors.
- SimpleTextTermVectorsReader(Directory, SegmentInfo, IOContext) - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsReader
-
- SimpleTextTermVectorsWriter - Class in org.apache.lucene.codecs.simpletext
-
Writes plain-text term vectors.
- SimpleTextTermVectorsWriter(Directory, String, IOContext) - Constructor for class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsWriter
-
- SimpleWKTShapeParser - Class in org.apache.lucene.geo
-
Parses shape geometry represented in WKT format
complies with OGC® document: 12-063r5 and ISO/IEC 13249-3:2016 standard
located at http://docs.opengeospatial.org/is/12-063r5/12-063r5.html
- SimpleWKTShapeParser.ShapeType - Enum in org.apache.lucene.geo
-
Enumerated type for Shapes
- simplify(BooleanQuery) - Method in class org.apache.lucene.queryparser.simple.SimpleQueryParser
-
Helper to simplify boolean queries with 0 or 1 clause
- simplifyIndexedCells - Variable in class org.apache.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
-
- sims - Variable in class org.apache.lucene.search.similarities.MultiSimilarity
-
the sub-similarities used to create the combined score
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.BooleanSimilarity
-
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.MultiSimilarity
-
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.PerFieldSimilarityWrapper
-
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.Similarity
-
Creates a new
Similarity.SimScorer
to score matching documents from a segment of the inverted index.
- SimScorer() - Constructor for class org.apache.lucene.search.similarities.Similarity.SimScorer
-
Sole constructor.
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
- simScorer(Similarity.SimWeight, LeafReaderContext) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
- SimWeight() - Constructor for class org.apache.lucene.search.similarities.Similarity.SimWeight
-
Sole constructor.
- simWeight - Variable in class org.apache.lucene.search.spans.SpanWeight
-
- SINGLE_TYPE - Static variable in class org.apache.lucene.analysis.cjk.CJKBigramFilter
-
when we emit a unigram, it's then marked as this type
- SingleDocSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
- SingleDocSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.SingleDocSource
-
- SingleFragListBuilder - Class in org.apache.lucene.search.vectorhighlight
-
- SingleFragListBuilder() - Constructor for class org.apache.lucene.search.vectorhighlight.SingleFragListBuilder
-
- SingleFunction - Class in org.apache.lucene.queries.function.valuesource
-
A function with a single argument
- SingleFunction(ValueSource) - Constructor for class org.apache.lucene.queries.function.valuesource.SingleFunction
-
- SingleInstanceLockFactory - Class in org.apache.lucene.store
-
Implements
LockFactory
for a single in-process instance,
meaning all locking will take place through this one instance.
- SingleInstanceLockFactory() - Constructor for class org.apache.lucene.store.SingleInstanceLockFactory
-
- SingleTermsEnum - Class in org.apache.lucene.index
-
Subclass of FilteredTermsEnum for enumerating a single term.
- SingleTermsEnum(TermsEnum, BytesRef) - Constructor for class org.apache.lucene.index.SingleTermsEnum
-
Creates a new SingleTermsEnum
.
- singleton(SortedDocValues) - Static method in class org.apache.lucene.index.DocValues
-
Returns a multi-valued view over the provided SortedDocValues
- singleton(NumericDocValues) - Static method in class org.apache.lucene.index.DocValues
-
Returns a multi-valued view over the provided NumericDocValues
- singletonView(Iterable<Number>, Iterable<Number>, Number) - Static method in class org.apache.lucene.codecs.DocValuesConsumer
-
Helper: returns single-valued view, using missingValue
when count is zero
- singleValuePerDoc - Variable in class org.apache.lucene.util.bkd.BKDWriter
-
True if every document has at most one value.
- sink - Variable in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
-
Sink tokenstream, such as the outer tokenfilter decorating
the chain.
- sinkState - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-
Which state, if any, accepts all suffixes, else -1.
- size() - Method in class org.apache.lucene.analysis.CharArrayMap.EntrySet
-
- size() - Method in class org.apache.lucene.analysis.CharArrayMap
-
- size() - Method in class org.apache.lucene.analysis.CharArraySet
-
- size() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- size() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- size() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- size() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- size() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- size() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- size() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- size() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- size() - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- size() - Method in class org.apache.lucene.facet.taxonomy.writercache.LruTaxonomyWriterCache
-
- size() - Method in interface org.apache.lucene.facet.taxonomy.writercache.TaxonomyWriterCache
-
How many labels are currently stored in the cache.
- size() - Method in class org.apache.lucene.facet.taxonomy.writercache.UTF8TaxonomyWriterCache
-
How many labels are currently stored in the cache.
- size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.AlcoholicMergePolicy
-
- size() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPointValues
-
- size() - Method in class org.apache.lucene.index.FieldInfos
-
Returns the number of fields
- size() - Method in class org.apache.lucene.index.Fields
-
Returns the number of fields or -1 if the number of
distinct field names is unknown.
- size() - Method in class org.apache.lucene.index.FilterLeafReader.FilterFields
-
- size() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTerms
-
- size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.FilterMergePolicy
-
- size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogByteSizeMergePolicy
-
- size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogDocMergePolicy
-
- size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.MergePolicy
-
Return the byte size of the provided
SegmentCommitInfo
, pro-rated by percentage of
non-deleted documents is set.
- size() - Method in class org.apache.lucene.index.MultiFields
-
- size() - Method in class org.apache.lucene.index.MultiTerms
-
- size(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.NoMergePolicy
-
- size(IndexReader, String) - Static method in class org.apache.lucene.index.PointValues
-
Return the cumulated number of points across all leaves of the given
IndexReader
.
- size() - Method in class org.apache.lucene.index.PointValues
-
Returns the total number of indexed points across all documents.
- size() - Method in class org.apache.lucene.index.PrefixCodedTerms
-
- size() - Method in class org.apache.lucene.index.SegmentInfos
-
- size() - Method in class org.apache.lucene.index.Terms
-
Returns the number of terms for this field, or -1 if this
measure isn't stored by the codec.
- size() - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- size() - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- size() - Method in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
- size() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- size() - Method in class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- size - Variable in class org.apache.lucene.replicator.RevisionFile
-
- size() - Method in class org.apache.lucene.search.DisiPriorityQueue
-
- size() - Method in class org.apache.lucene.search.LiveFieldValues
-
Returns the [approximate] number of id/value pairs
buffered in RAM.
- size() - Method in class org.apache.lucene.spatial3d.geom.GeoBaseCompositeShape
-
Get the number of shapes in the composite
- size() - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- size() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
- size() - Method in class org.apache.lucene.util.automaton.LimitedFiniteStringsIterator
-
Number of iterated finite strings.
- size() - Method in class org.apache.lucene.util.bkd.BKDReader
-
- size() - Method in class org.apache.lucene.util.BytesRefArray
-
- size() - Method in class org.apache.lucene.util.BytesRefHash
-
- size() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
The number of values.
- size() - Method in class org.apache.lucene.util.packed.GrowableWriter
-
- size() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
-
Returns the number of values
- size() - Method in class org.apache.lucene.util.packed.PackedInts.NullReader
-
- size() - Method in class org.apache.lucene.util.packed.PackedInts.Reader
-
- size() - Method in interface org.apache.lucene.util.packed.PackedInts.ReaderIterator
-
Returns number of values
- size() - Method in class org.apache.lucene.util.packed.PackedLongValues.Builder
-
Return the number of elements that have been added to this builder.
- size() - Method in class org.apache.lucene.util.packed.PackedLongValues
-
Get the number of values in this array.
- size() - Method in class org.apache.lucene.util.PriorityQueue
-
Returns the number of elements currently stored in the PriorityQueue.
- size() - Method in class org.apache.lucene.util.SentinelIntSet
-
The number of integers in this set.
- size() - Method in class org.apache.lucene.util.WeakIdentityMap
-
Returns the number of key-value mappings in this map.
- sizeBytes(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
-
- sizeDocs(SegmentCommitInfo, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.LogMergePolicy
-
- sizeInBytes() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns total size in bytes of all files for this
segment.
- sizeInBytes() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- sizeInBytes - Variable in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- sizeInBytes - Variable in class org.apache.lucene.store.RAMFile
-
Deprecated.
- sizeMB - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Net size (MB) of the files referenced by this
segment.
- sizeOf(Long) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Return the size of the provided Long
object, returning 0 if it is
cached by the JVM and its shallow size otherwise.
- sizeOf(byte[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the byte[] object.
- sizeOf(boolean[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the boolean[] object.
- sizeOf(char[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the char[] object.
- sizeOf(short[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the short[] object.
- sizeOf(int[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the int[] object.
- sizeOf(float[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the float[] object.
- sizeOf(long[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the long[] object.
- sizeOf(double[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
Returns the size in bytes of the double[] object.
- sizeOf(Accountable[]) - Static method in class org.apache.lucene.util.RamUsageEstimator
-
- sizeOf(Object, RamUsageTester.Accumulator) - Static method in class org.apache.lucene.util.RamUsageTester
-
Estimates the RAM usage by the given object.
- sizeOf(Object) - Static method in class org.apache.lucene.util.RamUsageTester
-
Same as calling sizeOf(obj, DEFAULT_FILTER)
.
- skip(long) - Method in class org.apache.lucene.mockfile.FilterInputStream2
-
- skip(long) - Method in class org.apache.lucene.replicator.IndexInputInputStream
-
- skip(long) - Method in class org.apache.lucene.util.packed.BlockPackedReaderIterator
-
Skip exactly count
values.
- SKIP_INTERVAL - Static variable in class org.apache.lucene.codecs.memory.FSTOrdTermsWriter
-
- skipBytes(long) - Method in class org.apache.lucene.store.ByteArrayDataInput
-
- skipBytes(long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- skipBytes(long) - Method in class org.apache.lucene.store.DataInput
-
Skip over numBytes
bytes.
- skipBytes(long) - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- skipDoc - Variable in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Doc id of current skip entry per level.
- skipFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- skipFinalOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
-
- skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.Outputs
-
- skipOutput(DataInput) - Method in class org.apache.lucene.util.fst.PairOutputs
-
- skipTo(int) - Method in class org.apache.lucene.codecs.MultiLevelSkipListReader
-
Skips entries to the first beyond the current whose document number is
greater than or equal to target.
- skipToNextByte() - Method in class org.apache.lucene.util.packed.PackedDataInput
-
If there are pending bits (at most 7), they will be ignored and the next
value will be read starting at the next byte.
- SleepingLockWrapper - Class in org.apache.lucene.store
-
Directory that wraps another, and that sleeps and retries
if obtaining the lock fails.
- SleepingLockWrapper(Directory, long) - Constructor for class org.apache.lucene.store.SleepingLockWrapper
-
Create a new SleepingLockFactory
- SleepingLockWrapper(Directory, long, long) - Constructor for class org.apache.lucene.store.SleepingLockWrapper
-
Create a new SleepingLockFactory
- slice - Variable in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
-
ReaderSlice
describing how this sub-reader
fits into the composite reader.
- slice(String, long, long) - Method in class org.apache.lucene.store.BufferedChecksumIndexInput
-
- slice(String, long, long) - Method in class org.apache.lucene.store.BufferedIndexInput
-
- slice(String, long, long) - Method in class org.apache.lucene.store.ByteArrayIndexInput
-
Deprecated.
- slice(long, long) - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- slice(String, long, long) - Method in class org.apache.lucene.store.ByteBuffersIndexInput
-
- slice(String, long, long) - Method in class org.apache.lucene.store.IndexInput
-
Creates a slice of this index input, with the given description, offset, and length.
- slice(String, long, long) - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- slice(String, long, long) - Method in class org.apache.lucene.store.RAMInputStream
-
Deprecated.
- slice_check() - Method in class org.tartarus.snowball.SnowballProgram
-
- slice_del() - Method in class org.tartarus.snowball.SnowballProgram
-
- slice_from(CharSequence) - Method in class org.tartarus.snowball.SnowballProgram
-
- slice_to(StringBuilder) - Method in class org.tartarus.snowball.SnowballProgram
-
- SliceReader(IntBlockPool) - Constructor for class org.apache.lucene.util.IntBlockPool.SliceReader
-
- slices(List<LeafReaderContext>) - Method in class org.apache.lucene.search.IndexSearcher
-
Expert: Creates an array of leaf slices each holding a subset of the given leaves.
- SliceWriter(IntBlockPool) - Constructor for class org.apache.lucene.util.IntBlockPool.SliceWriter
-
- slop - Variable in class org.apache.lucene.search.spans.SpanNearQuery
-
- slope - Variable in class org.apache.lucene.queries.function.valuesource.LinearFloatFunction
-
- sloppyFreq(int) - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
Implemented as 1 / (distance + 1)
.
- sloppyFreq(int) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
-
Implemented as 1 / (distance + 1)
.
- sloppyFreq(int) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Deprecated.
- SloppyMath - Class in org.apache.lucene.util
-
Math functions that trade off accuracy for speed.
- SloppyMath() - Constructor for class org.apache.lucene.util.SloppyMath
-
- sloppySin(double) - Static method in class org.apache.lucene.geo.GeoUtils
-
Returns the trigonometric sine of an angle converted as a cos operation.
- SlopQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
- SlopQueryNode(QueryNode, int) - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- SlopQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- SlopQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.SlopQueryNodeBuilder
-
- slot - Variable in class org.apache.lucene.search.FieldValueHitQueue.Entry
-
- slowAdvance(int) - Method in class org.apache.lucene.search.DocIdSetIterator
-
- SlowCodecReaderWrapper - Class in org.apache.lucene.index
-
Wraps arbitrary readers for merging.
- slowFileExists(Directory, String) - Static method in class org.apache.lucene.util.LuceneTestCase
-
Returns true if the file exists (can be opened), false
if it cannot be opened, and (unlike Java's
File.exists) throws IOException if there's some
unexpected error.
- SmallFloat - Class in org.apache.lucene.util
-
Floating point numbers smaller than 32 bits.
- SmartChineseAnalyzer - Class in org.apache.lucene.analysis.cn.smart
-
SmartChineseAnalyzer is an analyzer for Chinese or mixed Chinese-English text.
- SmartChineseAnalyzer() - Constructor for class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
Create a new SmartChineseAnalyzer, using the default stopword list.
- SmartChineseAnalyzer(boolean) - Constructor for class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
Create a new SmartChineseAnalyzer, optionally using the default stopword list.
- SmartChineseAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.cn.smart.SmartChineseAnalyzer
-
Create a new SmartChineseAnalyzer, using the provided Set
of stopwords.
- smokeTestSearcher(IndexSearcher) - Method in class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- snapshot() - Method in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Snapshots the last commit.
- snapshot() - Method in class org.apache.lucene.index.SnapshotDeletionPolicy
-
Snapshots the last commit and returns it.
- SnapshotDeletionPolicy - Class in org.apache.lucene.index
-
- SnapshotDeletionPolicy(IndexDeletionPolicy) - Constructor for class org.apache.lucene.index.SnapshotDeletionPolicy
-
- SnapshotDirectoryTaxonomyWriter(Directory, IndexWriterConfig.OpenMode, TaxonomyWriterCache) - Constructor for class org.apache.lucene.replicator.IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter
-
- SnapshotDirectoryTaxonomyWriter(Directory, IndexWriterConfig.OpenMode) - Constructor for class org.apache.lucene.replicator.IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter
-
- SnapshotDirectoryTaxonomyWriter(Directory) - Constructor for class org.apache.lucene.replicator.IndexAndTaxonomyRevision.SnapshotDirectoryTaxonomyWriter
-
- SNAPSHOTS_PREFIX - Static variable in class org.apache.lucene.index.PersistentSnapshotDeletionPolicy
-
Prefix used for the save file.
- sndv - Variable in class org.apache.lucene.search.DocValuesStats.SortedNumericDocValuesStats
-
- snear(String, String, int, boolean) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanNearQuery containing two SpanTerm queries
- snear(SpanQuery, SpanQuery, int, boolean) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanNearQuery containing two SpanQueries
- snear(String, String, String, int, boolean) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanNearQuery containing three SpanTerm queries
- snear(SpanQuery, SpanQuery, SpanQuery, int, boolean) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanNearQuery containing three SpanQueries
- snot(SpanQuery, SpanQuery) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanNotQuery
- SnowballFilter - Class in org.apache.lucene.analysis.snowball
-
A filter that stems words using a Snowball-generated stemmer.
- SnowballFilter(TokenStream, SnowballProgram) - Constructor for class org.apache.lucene.analysis.snowball.SnowballFilter
-
- SnowballFilter(TokenStream, String) - Constructor for class org.apache.lucene.analysis.snowball.SnowballFilter
-
Construct the named stemming filter.
- SnowballPorterFilterFactory - Class in org.apache.lucene.analysis.snowball
-
- SnowballPorterFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.snowball.SnowballPorterFilterFactory
-
Creates a new SnowballPorterFilterFactory
- SnowballProgram - Class in org.tartarus.snowball
-
This is the rev 502 of the Snowball SVN trunk,
now located at
GitHub,
but modified:
made abstract and introduced abstract method stem to avoid expensive reflection in filter class.
- SnowballProgram() - Constructor for class org.tartarus.snowball.SnowballProgram
-
- softDelCountOnFlush - Variable in class org.apache.lucene.index.SegmentWriteState
-
Number of only soft deleted documents set while flushing the
segment.
- SoftDeletesDirectoryReaderWrapper - Class in org.apache.lucene.index
-
This reader filters out documents that have a doc values value in the given field and treat these
documents as soft deleted.
- SoftDeletesDirectoryReaderWrapper(DirectoryReader, String) - Constructor for class org.apache.lucene.index.SoftDeletesDirectoryReaderWrapper
-
Creates a new soft deletes wrapper.
- softDeletesField - Variable in class org.apache.lucene.index.LiveIndexWriterConfig
-
soft deletes field
- SoftDeletesRetentionMergePolicy - Class in org.apache.lucene.index
-
This
MergePolicy
allows to carry over soft deleted documents across merges.
- SoftDeletesRetentionMergePolicy(String, Supplier<Query>, MergePolicy) - Constructor for class org.apache.lucene.index.SoftDeletesRetentionMergePolicy
-
- softUpdateDocument(Term, Iterable<? extends IndexableField>, Field...) - Method in class org.apache.lucene.index.IndexWriter
-
Expert:
Updates a document by first updating the document(s)
containing term
with the given doc-values fields
and then adding the new document.
- softUpdateDocuments(Term, Iterable<? extends Iterable<? extends IndexableField>>, Field...) - Method in class org.apache.lucene.index.IndexWriter
-
Expert:
Atomically updates documents matching the provided
term with the given doc-values fields
and adds a block of documents with sequentially
assigned document IDs, such that an external reader
will see all or none of the documents.
- SolrSynonymParser - Class in org.apache.lucene.analysis.synonym
-
Parser for the Solr synonyms format.
- SolrSynonymParser(boolean, boolean, Analyzer) - Constructor for class org.apache.lucene.analysis.synonym.SolrSynonymParser
-
- sor(String, String) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanOrQuery containing two SpanTerm queries
- sor(SpanQuery, SpanQuery) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanOrQuery containing two SpanQueries
- sor(String, String, String) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanOrQuery containing three SpanTerm queries
- sor(SpanQuery, SpanQuery, SpanQuery) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanOrQuery containing two SpanQueries
- SoraniAnalyzer - Class in org.apache.lucene.analysis.ckb
-
- SoraniAnalyzer() - Constructor for class org.apache.lucene.analysis.ckb.SoraniAnalyzer
-
- SoraniAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.ckb.SoraniAnalyzer
-
Builds an analyzer with the given stop words.
- SoraniAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.ckb.SoraniAnalyzer
-
Builds an analyzer with the given stop words.
- SoraniNormalizationFilter - Class in org.apache.lucene.analysis.ckb
-
- SoraniNormalizationFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ckb.SoraniNormalizationFilter
-
- SoraniNormalizationFilterFactory - Class in org.apache.lucene.analysis.ckb
-
- SoraniNormalizationFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ckb.SoraniNormalizationFilterFactory
-
Creates a new SoraniNormalizationFilterFactory
- SoraniNormalizer - Class in org.apache.lucene.analysis.ckb
-
Normalizes the Unicode representation of Sorani text.
- SoraniNormalizer() - Constructor for class org.apache.lucene.analysis.ckb.SoraniNormalizer
-
- SoraniStemFilter - Class in org.apache.lucene.analysis.ckb
-
- SoraniStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.ckb.SoraniStemFilter
-
- SoraniStemFilterFactory - Class in org.apache.lucene.analysis.ckb
-
- SoraniStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.ckb.SoraniStemFilterFactory
-
Creates a new SoraniStemFilterFactory
- SoraniStemmer - Class in org.apache.lucene.analysis.ckb
-
Light stemmer for Sorani
- SoraniStemmer() - Constructor for class org.apache.lucene.analysis.ckb.SoraniStemmer
-
- sort - Variable in class org.apache.lucene.search.EarlyTerminatingSortingCollector
-
Deprecated.
Sort used to sort the search results
- sort - Variable in class org.apache.lucene.search.grouping.AllGroupHeadsCollector
-
- Sort - Class in org.apache.lucene.search
-
Encapsulates sort criteria for returned hits.
- Sort() - Constructor for class org.apache.lucene.search.Sort
-
Sorts by computed relevance.
- Sort(SortField) - Constructor for class org.apache.lucene.search.Sort
-
Sorts by the criteria in the given SortField.
- Sort(SortField...) - Constructor for class org.apache.lucene.search.Sort
-
Sets the sort to the given criteria in succession: the
first SortField is checked first, but if it produces a
tie, then the second SortField is used to break the tie,
etc.
- sort(int, int, MutablePointValues, int, int) - Static method in class org.apache.lucene.util.bkd.MutablePointsReaderUtils
-
- sort() - Method in class org.apache.lucene.util.BytesRefHash
-
Returns the values array sorted by the referenced byte values.
- sort(int, int) - Method in class org.apache.lucene.util.InPlaceMergeSorter
-
- sort(int, int) - Method in class org.apache.lucene.util.IntroSorter
-
- sort(int, int[], int) - Method in class org.apache.lucene.util.LSBRadixSorter
-
Sort array[0:len]
in place.
- sort(int, int) - Method in class org.apache.lucene.util.MSBRadixSorter
-
- sort(String) - Method in class org.apache.lucene.util.OfflineSorter
-
Sort input to a new temp file, returning its name.
- sort(int, int) - Method in class org.apache.lucene.util.Sorter
-
Sort the slice which starts at from
(inclusive) and ends at
to
(exclusive).
- sort(int, int) - Method in class org.apache.lucene.util.TimSorter
-
- sortableBytesToBigInt(byte[], int, int) - Static method in class org.apache.lucene.util.NumericUtils
-
- sortableBytesToInt(byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
-
- sortableBytesToLong(byte[], int) - Static method in class org.apache.lucene.util.NumericUtils
-
- sortableDoubleBits(long) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts IEEE 754 representation of a double to sortable order (or back to the original)
- sortableFloatBits(int) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts IEEE 754 representation of a float to sortable order (or back to the original)
- sortableIntToFloat(int) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts a sortable int
back to a float
.
- sortableLongToDouble(long) - Static method in class org.apache.lucene.util.NumericUtils
-
Converts a sortable long
back to a double
.
- sortableShortToHalfFloat(short) - Static method in class org.apache.lucene.document.HalfFloatPoint
-
Convert short bits to a half-float value that maintains ordering.
- SortableSingleDocSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
Adds fields appropriate for sorting: country, random_string and sort_field
(int).
- SortableSingleDocSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.SortableSingleDocSource
-
- sortByDim(int, int, int[], MutablePointValues, int, int, BytesRef, BytesRef) - Static method in class org.apache.lucene.util.bkd.MutablePointsReaderUtils
-
Sort points on the given dimension.
- SortedDocValues - Class in org.apache.lucene.index
-
A per-document byte[] with presorted values.
- SortedDocValues() - Constructor for class org.apache.lucene.index.SortedDocValues
-
Sole constructor.
- SortedDocValuesField - Class in org.apache.lucene.document
-
Field that stores
a per-document
BytesRef
value, indexed for
sorting.
- SortedDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.SortedDocValuesField
-
Create a new sorted DocValues field.
- SortedDocValuesStats(String) - Constructor for class org.apache.lucene.search.DocValuesStats.SortedDocValuesStats
-
- SortedDoubleDocValuesStats(String) - Constructor for class org.apache.lucene.search.DocValuesStats.SortedDoubleDocValuesStats
-
- SortedInputIterator - Class in org.apache.lucene.search.suggest
-
This wrapper buffers incoming elements and makes sure they are sorted based on given comparator.
- SortedInputIterator(Directory, String, InputIterator) - Constructor for class org.apache.lucene.search.suggest.SortedInputIterator
-
Creates a new sorted wrapper, using natural order
for sorting.
- SortedInputIterator(Directory, String, InputIterator, Comparator<BytesRef>) - Constructor for class org.apache.lucene.search.suggest.SortedInputIterator
-
Creates a new sorted wrapper, sorting by BytesRef
(ascending) then cost (ascending).
- SortedLongDocValuesStats(String) - Constructor for class org.apache.lucene.search.DocValuesStats.SortedLongDocValuesStats
-
- SortedNumericDocValues - Class in org.apache.lucene.index
-
A list of per-document numeric values, sorted
according to Long.compare(long, long)
.
- SortedNumericDocValues() - Constructor for class org.apache.lucene.index.SortedNumericDocValues
-
Sole constructor.
- SortedNumericDocValuesField - Class in org.apache.lucene.document
-
Field that stores a per-document long
values for scoring,
sorting or value retrieval.
- SortedNumericDocValuesField(String, long) - Constructor for class org.apache.lucene.document.SortedNumericDocValuesField
-
Creates a new DocValues field with the specified 64-bit long value
- SortedNumericDocValuesStats(String, T, T) - Constructor for class org.apache.lucene.search.DocValuesStats.SortedNumericDocValuesStats
-
- SortedNumericSelector - Class in org.apache.lucene.search
-
Selects a value from the document's list to use as the representative value
- SortedNumericSelector() - Constructor for class org.apache.lucene.search.SortedNumericSelector
-
- SortedNumericSelector.Type - Enum in org.apache.lucene.search
-
Type of selection to perform.
- SortedNumericSortField - Class in org.apache.lucene.search
-
- SortedNumericSortField(String, SortField.Type) - Constructor for class org.apache.lucene.search.SortedNumericSortField
-
Creates a sort, by the minimum value in the set
for the document.
- SortedNumericSortField(String, SortField.Type, boolean) - Constructor for class org.apache.lucene.search.SortedNumericSortField
-
Creates a sort, possibly in reverse, by the minimum value in the set
for the document.
- SortedNumericSortField(String, SortField.Type, boolean, SortedNumericSelector.Type) - Constructor for class org.apache.lucene.search.SortedNumericSortField
-
Creates a sort, possibly in reverse, specifying how the sort value from
the document's set is selected.
- sortedNumericToDocCount(DocValuesProducer, FieldInfo, int) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- sortedNumericToValues(DocValuesProducer, FieldInfo) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- sortedOrdIterable(DocValuesProducer, FieldInfo, int) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- SortedSetDocValues - Class in org.apache.lucene.index
-
- SortedSetDocValues() - Constructor for class org.apache.lucene.index.SortedSetDocValues
-
Sole constructor.
- SortedSetDocValuesFacetCounts - Class in org.apache.lucene.facet.sortedset
-
- SortedSetDocValuesFacetCounts(SortedSetDocValuesReaderState) - Constructor for class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetCounts
-
- SortedSetDocValuesFacetCounts(SortedSetDocValuesReaderState, FacetsCollector) - Constructor for class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetCounts
-
Counts all facet dimensions across the provided hits.
- SortedSetDocValuesFacetField - Class in org.apache.lucene.facet.sortedset
-
Add an instance of this to your Document for every facet
label to be indexed via SortedSetDocValues.
- SortedSetDocValuesFacetField(String, String) - Constructor for class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetField
-
Sole constructor.
- SortedSetDocValuesField - Class in org.apache.lucene.document
-
Field that stores
a set of per-document
BytesRef
values, indexed for
faceting,grouping,joining.
- SortedSetDocValuesField(String, BytesRef) - Constructor for class org.apache.lucene.document.SortedSetDocValuesField
-
Create a new sorted DocValues field.
- SortedSetDocValuesReaderState - Class in org.apache.lucene.facet.sortedset
-
- SortedSetDocValuesReaderState() - Constructor for class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState
-
Sole constructor.
- SortedSetDocValuesReaderState.OrdRange - Class in org.apache.lucene.facet.sortedset
-
Holds start/end range of ords, which maps to one
dimension (someday we may generalize it to map to
hierarchies within one dimension).
- SortedSetDocValuesStats(String) - Constructor for class org.apache.lucene.search.DocValuesStats.SortedSetDocValuesStats
-
- SortedSetFieldSource - Class in org.apache.lucene.queries.function.valuesource
-
Retrieves
FunctionValues
instances for multi-valued string based fields.
- SortedSetFieldSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.SortedSetFieldSource
-
- SortedSetFieldSource(String, SortedSetSelector.Type) - Constructor for class org.apache.lucene.queries.function.valuesource.SortedSetFieldSource
-
- sortedSetOrdCountIterable(DocValuesProducer, FieldInfo, int) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- sortedSetOrdsIterable(DocValuesProducer, FieldInfo) - Static method in class org.apache.lucene.codecs.LegacyDocValuesIterables
-
- SortedSetSelector - Class in org.apache.lucene.search
-
Selects a value from the document's set to use as the representative value
- SortedSetSelector() - Constructor for class org.apache.lucene.search.SortedSetSelector
-
- SortedSetSelector.Type - Enum in org.apache.lucene.search
-
Type of selection to perform.
- SortedSetSortField - Class in org.apache.lucene.search
-
- SortedSetSortField(String, boolean) - Constructor for class org.apache.lucene.search.SortedSetSortField
-
Creates a sort, possibly in reverse, by the minimum value in the set
for the document.
- SortedSetSortField(String, boolean, SortedSetSelector.Type) - Constructor for class org.apache.lucene.search.SortedSetSortField
-
Creates a sort, possibly in reverse, specifying how the sort value from
the document's set is selected.
- Sorter - Class in org.apache.lucene.util
-
Base class for sorting algorithms implementations.
- Sorter() - Constructor for class org.apache.lucene.util.Sorter
-
Sole constructor, used for inheritance.
- SortField - Class in org.apache.lucene.search
-
Stores information about how to sort documents by terms in an individual
field.
- SortField(String, SortField.Type) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort by terms in the given field with the type of term
values explicitly given.
- SortField(String, SortField.Type, boolean) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort, possibly in reverse, by terms in the given field with the
type of term values explicitly given.
- SortField(String, FieldComparatorSource) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort with a custom comparison function.
- SortField(String, FieldComparatorSource, boolean) - Constructor for class org.apache.lucene.search.SortField
-
Creates a sort, possibly in reverse, with a custom comparison function.
- SortField.Type - Enum in org.apache.lucene.search
-
Specifies the type of the terms to be sorted, or special types such as CUSTOM
- SortInfo() - Constructor for class org.apache.lucene.util.OfflineSorter.SortInfo
-
create a new SortInfo (with empty statistics) for debugging
- sortKeyLength(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
-
Returns the length of currentTerm
needed for use as a sort key.
- sortKeys(JaspellTernarySearchTrie.TSTNode, int) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie
-
Deprecated.
Returns keys sorted in alphabetical order.
- SortRescorer - Class in org.apache.lucene.search
-
A
Rescorer
that re-sorts according to a provided
Sort.
- SortRescorer(Sort) - Constructor for class org.apache.lucene.search.SortRescorer
-
Sole constructor.
- sortTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
time spent sorting data (in milliseconds)
- sortValues - Variable in class org.apache.lucene.search.grouping.SearchGroup
-
The sort values used during sorting.
- source - Variable in class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
-
Original source of the tokens.
- source - Variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- SOURCE - Static variable in class org.apache.lucene.index.IndexWriter
-
- source - Variable in class org.apache.lucene.queries.function.valuesource.LinearFloatFunction
-
- source - Variable in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- source - Variable in class org.apache.lucene.queries.function.valuesource.ReciprocalFloatFunction
-
- source - Variable in class org.apache.lucene.queries.function.valuesource.ScaleFloatFunction
-
- source - Variable in class org.apache.lucene.queries.function.valuesource.SimpleBoolFunction
-
- source - Variable in class org.apache.lucene.queries.function.valuesource.SingleFunction
-
- source - Variable in class org.apache.lucene.util.automaton.Transition
-
Source state.
- SOURCE_ADDINDEXES_READERS - Static variable in class org.apache.lucene.index.IndexWriter
-
- SOURCE_FLUSH - Static variable in class org.apache.lucene.index.IndexWriter
-
Source of a segment which results from a flush.
- SOURCE_MERGE - Static variable in class org.apache.lucene.index.IndexWriter
-
Source of a segment which results from a merge of other segments.
- sourceFiles - Variable in class org.apache.lucene.replicator.SessionToken
-
- sources - Variable in class org.apache.lucene.queries.function.valuesource.MultiBoolFunction
-
- sources - Variable in class org.apache.lucene.queries.function.valuesource.MultiFloatFunction
-
- sources - Variable in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- sources - Variable in class org.apache.lucene.queries.function.valuesource.VectorValueSource
-
- sourceText - Variable in class org.apache.lucene.expressions.Expression
-
The original source text
- SOUTH_EAST_ASIAN_TYPE - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Chars in class \p{Line_Break = Complex_Context} are from South East Asian
scripts (Thai, Lao, Myanmar, Khmer, etc.).
- SOUTH_EAST_ASIAN_TYPE - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizerImpl
-
Chars in class \p{Line_Break = Complex_Context} are from South East Asian
scripts (Thai, Lao, Myanmar, Khmer, etc.).
- SOUTH_POLE - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
South pole
- SOUTHEAST_ASIAN - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
Southeast Asian token type
- SOUTHEAST_ASIAN - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
Southeast Asian token type
- SPACE - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- SPACE - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- SPACE - Static variable in class org.apache.lucene.geo.SimpleWKTShapeParser
-
- SPACE_LIKE - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Characters that act as a space
- SPACES - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
Space-like characters that need to be skipped: such as space, tab, newline, carriage return.
- SpanBoostQuery - Class in org.apache.lucene.search.spans
-
- SpanBoostQuery(SpanQuery, float) - Constructor for class org.apache.lucene.search.spans.SpanBoostQuery
-
Sole constructor: wrap query
in such a way that the produced
scores will be boosted by boost
.
- SpanBuilderBase - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanBuilderBase() - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanBuilderBase
-
- SpanCollector - Interface in org.apache.lucene.search.spans
-
An interface defining the collection of postings information from the leaves
of a
Spans
- SpanContainingQuery - Class in org.apache.lucene.search.spans
-
Keep matches that contain another SpanScorer.
- SpanContainingQuery(SpanQuery, SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanContainingQuery
-
Construct a SpanContainingQuery matching spans from big
that contain at least one spans from little
.
- spanContainingQuery(SpanQuery, SpanQuery) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanContainingQuery (with additional asserts).
- SpanContainingQuery.SpanContainingWeight - Class in org.apache.lucene.search.spans
-
- SpanContainingWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight, SpanWeight, float) - Constructor for class org.apache.lucene.search.spans.SpanContainingQuery.SpanContainingWeight
-
- spanFactory - Variable in class org.apache.lucene.queryparser.xml.CoreParser
-
- SpanFirstBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanFirstBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanFirstBuilder
-
- SpanFirstQuery - Class in org.apache.lucene.search.spans
-
Matches spans near the beginning of a field.
- SpanFirstQuery(SpanQuery, int) - Constructor for class org.apache.lucene.search.spans.SpanFirstQuery
-
Construct a SpanFirstQuery matching spans in match
whose end
position is less than or equal to end
.
- spanFirstQuery(SpanQuery, int) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanFirstQuery (with additional asserts).
- SpanGradientFormatter - Class in org.apache.lucene.search.highlight
-
Formats text with different color intensity depending on the score of the
term using the span tag.
- SpanGradientFormatter(float, String, String, String, String) - Constructor for class org.apache.lucene.search.highlight.SpanGradientFormatter
-
- SpanishAnalyzer - Class in org.apache.lucene.analysis.es
-
- SpanishAnalyzer() - Constructor for class org.apache.lucene.analysis.es.SpanishAnalyzer
-
- SpanishAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.es.SpanishAnalyzer
-
Builds an analyzer with the given stop words.
- SpanishAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.es.SpanishAnalyzer
-
Builds an analyzer with the given stop words.
- SpanishLightStemFilter - Class in org.apache.lucene.analysis.es
-
- SpanishLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.es.SpanishLightStemFilter
-
- SpanishLightStemFilterFactory - Class in org.apache.lucene.analysis.es
-
- SpanishLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.es.SpanishLightStemFilterFactory
-
Creates a new SpanishLightStemFilterFactory
- SpanishLightStemmer - Class in org.apache.lucene.analysis.es
-
Light Stemmer for Spanish
- SpanishLightStemmer() - Constructor for class org.apache.lucene.analysis.es.SpanishLightStemmer
-
- SpanishStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- SpanishStemmer() - Constructor for class org.tartarus.snowball.ext.SpanishStemmer
-
- SpanMultiTermQueryWrapper<Q extends MultiTermQuery> - Class in org.apache.lucene.search.spans
-
- SpanMultiTermQueryWrapper(Q) - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
Create a new SpanMultiTermQueryWrapper.
- SpanMultiTermQueryWrapper.SpanRewriteMethod - Class in org.apache.lucene.search.spans
-
Abstract class that defines how the query is rewritten.
- SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite - Class in org.apache.lucene.search.spans
-
A rewrite method that first translates each term into a SpanTermQuery in a
BooleanClause.Occur.SHOULD
clause in a BooleanQuery, and keeps the
scores as computed by the query.
- SpanNearBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanNearBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanNearBuilder
-
- SpanNearClauseFactory - Class in org.apache.lucene.queryparser.surround.query
-
- SpanNearClauseFactory(IndexReader, String, BasicQueryFactory) - Constructor for class org.apache.lucene.queryparser.surround.query.SpanNearClauseFactory
-
- spanNearOrderedQuery(String, int, String...) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new ordered SpanNearQuery (with additional asserts) from the provided terms
- spanNearOrderedQuery(int, SpanQuery...) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new ordered SpanNearQuery (with additional asserts)
- SpanNearQuery - Class in org.apache.lucene.search.spans
-
Matches spans which are near one another.
- SpanNearQuery(SpanQuery[], int, boolean) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery
-
Construct a SpanNearQuery.
- SpanNearQuery.Builder - Class in org.apache.lucene.search.spans
-
A builder for SpanNearQueries
- SpanNearQuery.SpanNearWeight - Class in org.apache.lucene.search.spans
-
- spanNearUnorderedQuery(String, int, String...) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new unordered SpanNearQuery (with additional asserts) from the provided terms
- spanNearUnorderedQuery(int, SpanQuery...) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new unordered SpanNearQuery (with additional asserts)
- SpanNearWeight(List<SpanWeight>, IndexSearcher, Map<Term, TermContext>, float) - Constructor for class org.apache.lucene.search.spans.SpanNearQuery.SpanNearWeight
-
- SpanNotBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanNotBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanNotBuilder
-
- SpanNotQuery - Class in org.apache.lucene.search.spans
-
Removes matches which overlap with another SpanQuery or which are
within x tokens before or y tokens after another SpanQuery.
- SpanNotQuery(SpanQuery, SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
-
Construct a SpanNotQuery matching spans from include
which
have no overlap with spans from exclude
.
- SpanNotQuery(SpanQuery, SpanQuery, int) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
-
Construct a SpanNotQuery matching spans from include
which
have no overlap with spans from exclude
within
dist
tokens of include
.
- SpanNotQuery(SpanQuery, SpanQuery, int, int) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery
-
Construct a SpanNotQuery matching spans from include
which
have no overlap with spans from exclude
within
pre
tokens before or post
tokens of
include
.
- spanNotQuery(SpanQuery, SpanQuery) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanNotQuery (with additional asserts).
- spanNotQuery(SpanQuery, SpanQuery, int, int) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanNotQuery (with additional asserts).
- SpanNotQuery.SpanNotWeight - Class in org.apache.lucene.search.spans
-
- SpanNotWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight, SpanWeight, float) - Constructor for class org.apache.lucene.search.spans.SpanNotQuery.SpanNotWeight
-
- SpanOrBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanOrBuilder(SpanQueryBuilder) - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanOrBuilder
-
- SpanOrQuery - Class in org.apache.lucene.search.spans
-
Matches the union of its clauses.
- SpanOrQuery(SpanQuery...) - Constructor for class org.apache.lucene.search.spans.SpanOrQuery
-
Construct a SpanOrQuery merging the provided clauses.
- spanOrQuery(String, String...) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanOrQuery (with additional asserts) from the provided terms
.
- spanOrQuery(SpanQuery...) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanOrQuery (with additional asserts).
- SpanOrQuery.SpanOrWeight - Class in org.apache.lucene.search.spans
-
- SpanOrTermsBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanOrTermsBuilder(Analyzer) - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanOrTermsBuilder
-
- SpanOrWeight(IndexSearcher, Map<Term, TermContext>, List<SpanWeight>, float) - Constructor for class org.apache.lucene.search.spans.SpanOrQuery.SpanOrWeight
-
- SpanPayloadCheckQuery - Class in org.apache.lucene.queries.payloads
-
Only return those matches that have a specific payload at the given position.
- SpanPayloadCheckQuery(SpanQuery, List<BytesRef>) - Constructor for class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery
-
- SpanPayloadCheckQuery.SpanPayloadCheckWeight - Class in org.apache.lucene.queries.payloads
-
Weight that pulls its Spans using a PayloadSpanCollector
- SpanPayloadCheckWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight, float) - Constructor for class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery.SpanPayloadCheckWeight
-
- SpanPositionCheckQuery - Class in org.apache.lucene.search.spans
-
Base class for filtering a SpanQuery based on the position of a match.
- SpanPositionCheckQuery(SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanPositionCheckQuery
-
- SpanPositionCheckQuery.SpanPositionCheckWeight - Class in org.apache.lucene.search.spans
-
- SpanPositionCheckWeight(SpanWeight, IndexSearcher, Map<Term, TermContext>, float) - Constructor for class org.apache.lucene.search.spans.SpanPositionCheckQuery.SpanPositionCheckWeight
-
- SpanPositionRangeQuery - Class in org.apache.lucene.search.spans
-
- SpanPositionRangeQuery(SpanQuery, int, int) - Constructor for class org.apache.lucene.search.spans.SpanPositionRangeQuery
-
- spanPositionRangeQuery(SpanQuery, int, int) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanPositionRangeQuery (with additional asserts).
- SpanQuery - Class in org.apache.lucene.search.spans
-
Base class for span-based queries.
- SpanQuery() - Constructor for class org.apache.lucene.search.spans.SpanQuery
-
- spanQuery(SpanQuery) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Adds additional asserts to a spanquery.
- SpanQueryBuilder - Interface in org.apache.lucene.queryparser.xml.builders
-
- SpanQueryBuilderFactory - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanQueryBuilderFactory() - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanQueryBuilderFactory
-
- SpanRewriteMethod() - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.SpanRewriteMethod
-
- spans - Variable in class org.apache.lucene.search.DisiWrapper
-
- Spans - Class in org.apache.lucene.search.spans
-
Iterates through combinations of start/end positions per-doc.
- Spans() - Constructor for class org.apache.lucene.search.spans.Spans
-
- spans - Variable in class org.apache.lucene.search.spans.SpanScorer
-
- SpanScorer - Class in org.apache.lucene.search.spans
-
- SpanScorer(SpanWeight, Spans, Similarity.SimScorer) - Constructor for class org.apache.lucene.search.spans.SpanScorer
-
Sole constructor.
- SpanTermBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- SpanTermBuilder() - Constructor for class org.apache.lucene.queryparser.xml.builders.SpanTermBuilder
-
- SpanTermQuery - Class in org.apache.lucene.search.spans
-
Matches spans containing a term.
- SpanTermQuery(Term) - Constructor for class org.apache.lucene.search.spans.SpanTermQuery
-
Construct a SpanTermQuery matching the named term's spans.
- SpanTermQuery(Term, TermContext) - Constructor for class org.apache.lucene.search.spans.SpanTermQuery
-
Expert: Construct a SpanTermQuery matching the named term's spans, using
the provided TermContext
- spanTermQuery(String, String) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanTermQuery (with additional asserts).
- SpanTermQuery.SpanTermWeight - Class in org.apache.lucene.search.spans
-
- SpanTermWeight(TermContext, IndexSearcher, Map<Term, TermContext>, float) - Constructor for class org.apache.lucene.search.spans.SpanTermQuery.SpanTermWeight
-
- SpanTestUtil - Class in org.apache.lucene.search.spans
-
Some utility methods used for testing span queries
- SpanTestUtil() - Constructor for class org.apache.lucene.search.spans.SpanTestUtil
-
- SpanWeight - Class in org.apache.lucene.search.spans
-
Expert-only.
- SpanWeight(SpanQuery, IndexSearcher, Map<Term, TermContext>, float) - Constructor for class org.apache.lucene.search.spans.SpanWeight
-
Create a new SpanWeight
- SpanWeight.Postings - Enum in org.apache.lucene.search.spans
-
Enumeration defining what postings information should be retrieved from the
index for a given Spans
- spanWithinQuery(SpanQuery, SpanQuery) - Static method in class org.apache.lucene.search.spans.SpanTestUtil
-
Makes a new SpanWithinQuery (with additional asserts).
- SpanWithinQuery - Class in org.apache.lucene.search.spans
-
Keep matches that are contained within another Spans.
- SpanWithinQuery(SpanQuery, SpanQuery) - Constructor for class org.apache.lucene.search.spans.SpanWithinQuery
-
Construct a SpanWithinQuery matching spans from little
that are inside of big
.
- SpanWithinQuery.SpanWithinWeight - Class in org.apache.lucene.search.spans
-
- SpanWithinWeight(IndexSearcher, Map<Term, TermContext>, SpanWeight, SpanWeight, float) - Constructor for class org.apache.lucene.search.spans.SpanWithinQuery.SpanWithinWeight
-
- spareChars - Variable in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- SparseFixedBitSet - Class in org.apache.lucene.util
-
A bit set that only stores longs that have at least one bit which is set.
- SparseFixedBitSet(int) - Constructor for class org.apache.lucene.util.SparseFixedBitSet
-
Create a
SparseFixedBitSet
that can contain bits between
0
included and
length
excluded.
- SPATIAL_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- SpatialArgs - Class in org.apache.lucene.spatial.query
-
- SpatialArgs(SpatialOperation, Shape) - Constructor for class org.apache.lucene.spatial.query.SpatialArgs
-
- SpatialArgsParser - Class in org.apache.lucene.spatial.query
-
Parses a string that usually looks like "OPERATION(SHAPE)" into a
SpatialArgs
object.
- SpatialArgsParser() - Constructor for class org.apache.lucene.spatial.query.SpatialArgsParser
-
- spatialcontext - Variable in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- SpatialDocMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
- SpatialDocMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.SpatialDocMaker
-
- SpatialDocMaker.ShapeConverter - Interface in org.apache.lucene.benchmark.byTask.feeds
-
Converts one shape to another.
- SpatialFileQueryMaker - Class in org.apache.lucene.benchmark.byTask.feeds
-
Reads spatial data from the body field docs from an internally created
LineDocSource
.
- SpatialFileQueryMaker() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- SpatialOperation - Class in org.apache.lucene.spatial.query
-
A predicate that compares a stored geometry to a supplied geometry.
- SpatialOperation(String) - Constructor for class org.apache.lucene.spatial.query.SpatialOperation
-
- SpatialPrefixTree - Class in org.apache.lucene.spatial.prefix.tree
-
A spatial Prefix Tree, or Trie, which decomposes shapes into prefixed strings
at variable lengths corresponding to variable precision.
- SpatialPrefixTree(SpatialContext, int) - Constructor for class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
- SpatialPrefixTreeFactory - Class in org.apache.lucene.spatial.prefix.tree
-
Abstract Factory for creating
SpatialPrefixTree
instances with useful
defaults and passed on configurations defined in a Map.
- SpatialPrefixTreeFactory() - Constructor for class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTreeFactory
-
- SpatialStrategy - Class in org.apache.lucene.spatial
-
The SpatialStrategy encapsulates an approach to indexing and searching based
on shapes.
- SpatialStrategy(SpatialContext, String) - Constructor for class org.apache.lucene.spatial.SpatialStrategy
-
Constructs the spatial strategy with its mandatory arguments.
- specialToken - Variable in class org.apache.lucene.queryparser.classic.Token
-
This field is used to access special tokens that occur prior to this
token, but after the immediately preceding regular (non-special) token.
- specialToken - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
This field is used to access special tokens that occur prior to this
token, but after the immediately preceding regular (non-special) token.
- specialToken - Variable in class org.apache.lucene.queryparser.surround.parser.Token
-
This field is used to access special tokens that occur prior to this
token, but after the immediately preceding regular (non-special) token.
- SpellChecker - Class in org.apache.lucene.search.spell
-
Spell Checker class (Main class).
(initially inspired by the David Spencer code).
- SpellChecker(Directory, StringDistance) - Constructor for class org.apache.lucene.search.spell.SpellChecker
-
Use the given directory as a spell checker index.
- SpellChecker(Directory) - Constructor for class org.apache.lucene.search.spell.SpellChecker
-
- SpellChecker(Directory, StringDistance, Comparator<SuggestWord>) - Constructor for class org.apache.lucene.search.spell.SpellChecker
-
Use the given directory as a spell checker index with the given
StringDistance
measure
and the given
Comparator
for sorting the results.
- SPHERE - Static variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Planet model corresponding to sphere.
- SPIClassIterator<S> - Class in org.apache.lucene.util
-
Helper class for loading SPI classes from classpath (META-INF files).
- spins(Directory) - Static method in class org.apache.lucene.util.IOUtils
-
- spins(Path) - Static method in class org.apache.lucene.util.IOUtils
-
Rough Linux-only heuristics to determine whether the provided
Path
is backed by spinning storage.
- split(IndexReader, Directory, Directory, Directory, Analyzer, boolean, String, String...) - Method in class org.apache.lucene.classification.utils.DatasetSplitter
-
Split a given index into 3 indexes for training, test and cross validation tasks respectively
- split(Path, String[]) - Method in class org.apache.lucene.index.IndexSplitter
-
- split(IndexReader, Directory[], boolean) - Method in class org.apache.lucene.index.MultiPassIndexSplitter
-
Split source index into multiple parts.
- split() - Method in class org.apache.lucene.index.PKIndexSplitter
-
- split(byte[], byte[], int[]) - Method in class org.apache.lucene.util.bkd.BKDWriter
-
Pick the next dimension to split.
- split(long, LongBitSet, PointWriter, PointWriter, boolean) - Method in class org.apache.lucene.util.bkd.OfflinePointReader
-
- split(long, LongBitSet, PointWriter, PointWriter, boolean) - Method in class org.apache.lucene.util.bkd.PointReader
-
Splits this reader into left and right partitions
- SPLIT_ON_CASE_CHANGE - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
If not set, causes case changes to be ignored (subwords will only be generated
given SUBWORD_DELIM tokens)
- SPLIT_ON_CASE_CHANGE - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes lowercase -> uppercase transition to start a new subword.
- SPLIT_ON_NUMERICS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
If not set, causes numeric changes to be ignored (subwords will only be generated
given SUBWORD_DELIM tokens).
- SPLIT_ON_NUMERICS - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
If not set, causes numeric changes to be ignored (subwords will only be generated
given SUBWORD_DELIM tokens).
- splitAt(char, String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
Splits a list separated by zero or more given separator characters.
- splitchar - Variable in class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Deprecated.
The char used in the split.
- splitDim - Variable in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- splitExtensionField(String, String) - Method in class org.apache.lucene.queryparser.ext.Extensions
-
Splits a extension field and returns the field / extension part as a
Extensions.Pair
.
- splitFileNames(String) - Method in class org.apache.lucene.analysis.util.AbstractAnalysisFactory
-
Splits file names separated by comma character.
- splitPackedValueStack - Variable in class org.apache.lucene.util.bkd.BKDReader.IndexTree
-
- SplittingBreakIterator - Class in org.apache.lucene.search.uhighlight
-
Virtually slices the text on both sides of every occurrence of the specified character.
- SplittingBreakIterator(BreakIterator, char) - Constructor for class org.apache.lucene.search.uhighlight.SplittingBreakIterator
-
- splitX - Variable in class org.apache.lucene.geo.EdgeTree
-
which dimension was this node split on
- squareRatio - Variable in class org.apache.lucene.spatial3d.geom.PlanetModel
-
The square ratio
- SrndPrefixQuery - Class in org.apache.lucene.queryparser.surround.query
-
Query that matches String prefixes
- SrndPrefixQuery(String, boolean, char) - Constructor for class org.apache.lucene.queryparser.surround.query.SrndPrefixQuery
-
- SrndQuery - Class in org.apache.lucene.queryparser.surround.query
-
Lowest level base class for surround queries
- SrndQuery() - Constructor for class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- SrndTermQuery - Class in org.apache.lucene.queryparser.surround.query
-
Simple single-term clause
- SrndTermQuery(String, boolean) - Constructor for class org.apache.lucene.queryparser.surround.query.SrndTermQuery
-
- SrndTruncQuery - Class in org.apache.lucene.queryparser.surround.query
-
Query that matches wildcards
- SrndTruncQuery(String, char, char) - Constructor for class org.apache.lucene.queryparser.surround.query.SrndTruncQuery
-
- ssdv - Variable in class org.apache.lucene.search.DocValuesStats.SortedSetDocValuesStats
-
- st(String) - Method in class org.apache.lucene.search.BaseExplanationTestCase
-
MACRO for SpanTermQuery
- stack - Variable in class org.apache.lucene.index.PointsStackTracker
-
- StandardAnalyzer - Class in org.apache.lucene.analysis.standard
-
- StandardAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
-
Builds an analyzer with the given stop words.
- StandardAnalyzer() - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
-
- StandardAnalyzer(Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardAnalyzer
-
Builds an analyzer with the stop words from the given reader.
- StandardDirectoryReader - Class in org.apache.lucene.index
-
- StandardFilter - Class in org.apache.lucene.analysis.standard
-
- StandardFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.standard.StandardFilter
-
Deprecated.
Sole constructor
- StandardFilterFactory - Class in org.apache.lucene.analysis.standard
-
- StandardFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.standard.StandardFilterFactory
-
Deprecated.
Creates a new StandardFilterFactory
- StandardQueryBuilder - Interface in org.apache.lucene.queryparser.flexible.standard.builders
-
This interface should be implemented by every class that wants to build
Query
objects from
QueryNode
objects.
- StandardQueryConfigHandler - Class in org.apache.lucene.queryparser.flexible.standard.config
-
- StandardQueryConfigHandler() - Constructor for class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler
-
- StandardQueryConfigHandler.ConfigurationKeys - Class in org.apache.lucene.queryparser.flexible.standard.config
-
Class holding keys for StandardQueryNodeProcessorPipeline options.
- StandardQueryConfigHandler.Operator - Enum in org.apache.lucene.queryparser.flexible.standard.config
-
Boolean Operator: AND or OR
- StandardQueryNodeProcessorPipeline - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
This pipeline has all the processors needed to process a query node tree,
generated by
StandardSyntaxParser
, already assembled.
- StandardQueryNodeProcessorPipeline(QueryConfigHandler) - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.StandardQueryNodeProcessorPipeline
-
- StandardQueryParser - Class in org.apache.lucene.queryparser.flexible.standard
-
This class is a helper that enables users to easily use the Lucene query
parser.
- StandardQueryParser() - Constructor for class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- StandardQueryParser(Analyzer) - Constructor for class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- StandardQueryTreeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
This query tree builder only defines the necessary map to build a
Query
tree object.
- StandardQueryTreeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.StandardQueryTreeBuilder
-
- StandardSyntaxParser - Class in org.apache.lucene.queryparser.flexible.standard.parser
-
Parser for the standard Lucene syntax
- StandardSyntaxParser() - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- StandardSyntaxParser(CharStream) - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Constructor with user supplied CharStream.
- StandardSyntaxParser(StandardSyntaxParserTokenManager) - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Constructor with generated Token Manager.
- StandardSyntaxParserConstants - Interface in org.apache.lucene.queryparser.flexible.standard.parser
-
Token literal values and constants.
- StandardSyntaxParserTokenManager - Class in org.apache.lucene.queryparser.flexible.standard.parser
-
Token Manager.
- StandardSyntaxParserTokenManager(CharStream) - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
Constructor.
- StandardSyntaxParserTokenManager(CharStream, int) - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
Constructor.
- StandardTokenizer - Class in org.apache.lucene.analysis.standard
-
A grammar-based tokenizer constructed with JFlex.
- StandardTokenizer() - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizer
-
- StandardTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizer
-
- StandardTokenizerFactory - Class in org.apache.lucene.analysis.standard
-
- StandardTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizerFactory
-
Creates a new StandardTokenizerFactory
- StandardTokenizerImpl - Class in org.apache.lucene.analysis.standard
-
- StandardTokenizerImpl(Reader) - Constructor for class org.apache.lucene.analysis.standard.StandardTokenizerImpl
-
Creates a new scanner
- STAR - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- start - Variable in class org.apache.lucene.facet.sortedset.SortedSetDocValuesReaderState.OrdRange
-
Start of range, inclusive:
- start - Variable in class org.apache.lucene.index.ReaderSlice
-
Document ID this slice starts from.
- start() - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
Begin copying files
- start(long) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
Start up this replica, which possibly requires heavy copying of files from the primary node, if we were down for a long time
- start(String, TokenStream) - Method in interface org.apache.lucene.search.highlight.Fragmenter
-
Initializes the Fragmenter.
- start(String, TokenStream) - Method in class org.apache.lucene.search.highlight.NullFragmenter
-
- start(String, TokenStream) - Method in class org.apache.lucene.search.highlight.SimpleFragmenter
-
- start(String, TokenStream) - Method in class org.apache.lucene.search.highlight.SimpleSpanFragmenter
-
- start() - Method in class org.apache.lucene.search.intervals.IntervalFilter
-
- start() - Method in class org.apache.lucene.search.intervals.IntervalIterator
-
- start(int, double, int) - Method in class org.apache.lucene.search.ShardSearchingTestBase
-
- start - Variable in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-
- start() - Method in class org.apache.lucene.spatial.prefix.AbstractVisitingPrefixTreeQuery.VisitorTemplate
-
Called first to setup things.
- START_CHAR_ARRAY - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
- START_OF_HEADING_MARKER - Static variable in class org.apache.lucene.analysis.reverse.ReverseStringFilter
-
Example marker character: U+0001 (START OF HEADING)
- startCopyFile(String) - Method in class org.apache.lucene.replicator.nrt.ReplicaNode
-
- startDoc(int, int) - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- startDoc(int, int) - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
-
Adds a new doc in this term.
- startDocument() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsWriter
-
- startDocument(int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- startDocument() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsWriter
-
- startDocument(int) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsWriter
-
- startDocument() - Method in class org.apache.lucene.codecs.StoredFieldsWriter
-
Called before writing the stored fields of the document.
- startDocument(int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Called before writing the term vectors of the document.
- startElement(String, String, String, Attributes) - Method in class org.apache.lucene.analysis.compound.hyphenation.PatternParser
-
- startFacetOrd - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector
-
- startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsWriter
-
- startField(FieldInfo, int, boolean, boolean, boolean) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Called before writing the terms of the field.
- startFragment(TextFragment) - Method in class org.apache.lucene.search.highlight.QueryScorer
-
- startFragment(TextFragment) - Method in class org.apache.lucene.search.highlight.QueryTermScorer
-
- startFragment(TextFragment) - Method in interface org.apache.lucene.search.highlight.Scorer
-
Called when a new fragment is started for consideration.
- startNewSlice() - Method in class org.apache.lucene.util.IntBlockPool.SliceWriter
-
starts a new slice and returns the start offset.
- startNS - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- startOffset - Variable in class org.apache.lucene.analysis.cn.smart.hhmm.SegToken
-
start offset into original sentence
- startOffset - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase.CompoundToken
-
- startOffset - Variable in class org.apache.lucene.analysis.LookaheadTokenFilter.Position
-
- startOffset() - Method in interface org.apache.lucene.analysis.tokenattributes.OffsetAttribute
-
Returns this Token's starting offset, the position of the first character
corresponding to this token in the source text.
- startOffset() - Method in class org.apache.lucene.analysis.tokenattributes.OffsetAttributeImpl
-
- startOffset() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Returns this Token's starting offset, the position of the first character
corresponding to this token in the source text.
- startOffset() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingPostingsEnum
-
- startOffset() - Method in class org.apache.lucene.index.FilterLeafReader.FilterPostingsEnum
-
- startOffset() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- startOffset() - Method in class org.apache.lucene.index.PostingsEnum
-
Returns start offset for the current position, or -1
if offsets were not indexed.
- startOffset() - Method in class org.apache.lucene.index.RandomPostingsTester.SeedPostings
-
- startOffset() - Method in class org.apache.lucene.search.FilterMatchesIterator
-
- startOffset() - Method in interface org.apache.lucene.search.MatchesIterator
-
The starting offset of the current match, or
-1
if offsets are not available
Should only be called after
MatchesIterator.next()
has returned
true
- startOffset() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.MultiOffsetsEnum
-
- startOffset() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIterator
-
- startOffset() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfMatchesIteratorWithSubs
-
- startOffset() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum.OfPostings
-
- startOffset() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum
-
- startOfSegment() - Method in class org.apache.lucene.spatial.prefix.PrefixTreeFacetCounter.FacetVisitor
-
Called at the start of the segment, if there is indexed data.
- startPosition() - Method in class org.apache.lucene.search.FilterMatchesIterator
-
- startPosition() - Method in interface org.apache.lucene.search.MatchesIterator
-
- startPosition() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- startPosition() - Method in class org.apache.lucene.search.spans.NearSpansOrdered
-
- startPosition() - Method in class org.apache.lucene.search.spans.NearSpansUnordered
-
- startPosition() - Method in class org.apache.lucene.search.spans.Spans
-
- startPosition() - Method in class org.apache.lucene.search.spans.TermSpans
-
- startsWith(char[], int, String) - Static method in class org.apache.lucene.analysis.util.StemmerUtil
-
Returns true if the character array starts with the suffix.
- startsWith(Path) - Method in class org.apache.lucene.mockfile.FilterPath
-
- startsWith(String) - Method in class org.apache.lucene.mockfile.FilterPath
-
- startsWith(byte[], BytesRef) - Static method in class org.apache.lucene.util.StringHelper
-
Returns true
iff the ref starts with the given prefix.
- startsWith(BytesRef, BytesRef) - Static method in class org.apache.lucene.util.StringHelper
-
Returns true
iff the ref starts with the given prefix.
- startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsWriter
-
- startTerm() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsWriter
-
- startTerm() - Method in class org.apache.lucene.codecs.PushPostingsWriterBase
-
Start a new term.
- startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsWriter
-
- startTerm(BytesRef, int) - Method in class org.apache.lucene.codecs.TermVectorsWriter
-
Adds a term and its term frequency freq
.
- startUpdateThread(long, String) - Method in class org.apache.lucene.replicator.ReplicationClient
-
Start the update thread with the specified interval in milliseconds.
- state - Variable in class org.apache.lucene.facet.DrillSideways
-
- state - Variable in class org.apache.lucene.search.suggest.analyzing.FSTUtil.Path
-
Node in the automaton where path ends:
- State() - Constructor for class org.apache.lucene.util.AttributeSource.State
-
- StatePair - Class in org.apache.lucene.util.automaton
-
Pair of states.
- StatePair(int, int) - Constructor for class org.apache.lucene.util.automaton.StatePair
-
Constructs a new state pair.
- StaticImplementationAttributeFactory(AttributeFactory, Class<A>) - Constructor for class org.apache.lucene.util.AttributeFactory.StaticImplementationAttributeFactory
-
Expert: Creates an AttributeFactory returning clazz
as instance for the
attributes it implements and for all other attributes calls the given delegate factory.
- Stats - Class in org.apache.lucene.codecs.blocktree
-
- stdev() - Method in class org.apache.lucene.search.DocValuesStats.NumericDocValuesStats
-
Returns the stdev of all values of the field.
- stdev() - Method in class org.apache.lucene.search.DocValuesStats.SortedNumericDocValuesStats
-
Returns the stdev of all values of the field.
- stem(char[], int) - Method in class org.apache.lucene.analysis.ar.ArabicStemmer
-
Stem an input buffer of Arabic text.
- stem(char[], int) - Method in class org.apache.lucene.analysis.bg.BulgarianStemmer
-
Stem an input buffer of Bulgarian text.
- stem(char[], int) - Method in class org.apache.lucene.analysis.bn.BengaliStemmer
-
- stem(String) - Method in class org.apache.lucene.analysis.br.BrazilianStemmer
-
Stems the given term to an unique discriminator.
- stem(char[], int) - Method in class org.apache.lucene.analysis.ckb.SoraniStemmer
-
Stem an input buffer of Sorani text.
- stem(char[], int) - Method in class org.apache.lucene.analysis.cz.CzechStemmer
-
Stem an input buffer of Czech text.
- stem(char[], int) - Method in class org.apache.lucene.analysis.de.GermanLightStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.de.GermanMinimalStemmer
-
- stem(String) - Method in class org.apache.lucene.analysis.de.GermanStemmer
-
Stemms the given term to an unique discriminator.
- stem(char[], int) - Method in class org.apache.lucene.analysis.el.GreekStemmer
-
Stems a word contained in a leading portion of a char[] array.
- stem(char[], int) - Method in class org.apache.lucene.analysis.en.EnglishMinimalStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.es.SpanishLightStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.fi.FinnishLightStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.fr.FrenchLightStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.fr.FrenchMinimalStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.gl.GalicianMinimalStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.gl.GalicianStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.hi.HindiStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.hu.HungarianLightStemmer
-
- stem(char[], int, boolean) - Method in class org.apache.lucene.analysis.id.IndonesianStemmer
-
Stem a term (returning its new length).
- stem(char[], int) - Method in class org.apache.lucene.analysis.it.ItalianLightStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.lv.LatvianStemmer
-
Stem a latvian word.
- stem(char[], int) - Method in class org.apache.lucene.analysis.no.NorwegianLightStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.no.NorwegianMinimalStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.pt.PortugueseLightStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.pt.PortugueseMinimalStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.pt.PortugueseStemmer
-
- stem(char[], int) - Method in class org.apache.lucene.analysis.ru.RussianLightStemmer
-
- stem(CharSequence) - Method in class org.apache.lucene.analysis.stempel.StempelStemmer
-
Stem a word.
- stem(char[], int) - Method in class org.apache.lucene.analysis.sv.SwedishLightStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.ArabicStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.ArmenianStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.BasqueStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.CatalanStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.DanishStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.DutchStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.EnglishStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.FinnishStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.FrenchStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.German2Stemmer
-
- stem() - Method in class org.tartarus.snowball.ext.GermanStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.HungarianStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.IrishStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.ItalianStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.KpStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.LithuanianStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.LovinsStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.NorwegianStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.PorterStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.PortugueseStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.RomanianStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.RussianStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.SpanishStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.SwedishStemmer
-
- stem() - Method in class org.tartarus.snowball.ext.TurkishStemmer
-
- stem() - Method in class org.tartarus.snowball.SnowballProgram
-
- STEM_ENGLISH_POSSESSIVE - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
Causes trailing "'s" to be removed for each subword
- STEM_ENGLISH_POSSESSIVE - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
Causes trailing "'s" to be removed for each subword
- StemmerOverrideFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Provides the ability to override any
KeywordAttribute
aware stemmer
with custom dictionary-based stemming.
- StemmerOverrideFilter(TokenStream, StemmerOverrideFilter.StemmerOverrideMap) - Constructor for class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter
-
Create a new StemmerOverrideFilter, performing dictionary-based stemming
with the provided dictionary
.
- StemmerOverrideFilter.Builder - Class in org.apache.lucene.analysis.miscellaneous
-
- StemmerOverrideFilter.StemmerOverrideMap - Class in org.apache.lucene.analysis.miscellaneous
-
A read-only 4-byte FST backed map that allows fast case-insensitive key
value lookups for
StemmerOverrideFilter
- StemmerOverrideFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- StemmerOverrideFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilterFactory
-
Creates a new StemmerOverrideFilterFactory
- StemmerOverrideMap(FST<BytesRef>, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.StemmerOverrideFilter.StemmerOverrideMap
-
- StemmerUtil - Class in org.apache.lucene.analysis.util
-
Some commonly-used stemming functions
- StempelFilter - Class in org.apache.lucene.analysis.stempel
-
Transforms the token stream as per the stemming algorithm.
- StempelFilter(TokenStream, StempelStemmer) - Constructor for class org.apache.lucene.analysis.stempel.StempelFilter
-
Create filter using the supplied stemming table.
- StempelFilter(TokenStream, StempelStemmer, int) - Constructor for class org.apache.lucene.analysis.stempel.StempelFilter
-
Create filter using the supplied stemming table.
- StempelPolishStemFilterFactory - Class in org.apache.lucene.analysis.stempel
-
- StempelPolishStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.stempel.StempelPolishStemFilterFactory
-
Creates a new StempelPolishStemFilterFactory
- StempelStemmer - Class in org.apache.lucene.analysis.stempel
-
Stemmer class is a convenient facade for other stemmer-related classes.
- StempelStemmer(InputStream) - Constructor for class org.apache.lucene.analysis.stempel.StempelStemmer
-
Create a Stemmer using selected stemmer table
- StempelStemmer(Trie) - Constructor for class org.apache.lucene.analysis.stempel.StempelStemmer
-
Create a Stemmer using pre-loaded stemmer table
- stemPrefix(char[], int) - Method in class org.apache.lucene.analysis.ar.ArabicStemmer
-
Stem a prefix off an Arabic word.
- stemSuffix(char[], int) - Method in class org.apache.lucene.analysis.ar.ArabicStemmer
-
Stem suffix(es) off an Arabic word.
- Step(String, RSLPStemmerBase.Rule[], int, String[]) - Constructor for class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
-
Create a new step
- step(int, int) - Method in class org.apache.lucene.util.automaton.Automaton
-
Performs lookup in transitions, assuming determinism.
- step(int, int) - Method in class org.apache.lucene.util.automaton.RunAutomaton
-
Returns the state obtained by reading the given char from the given state.
- STOP_WORDS_SET - Static variable in class org.apache.lucene.analysis.standard.ClassicAnalyzer
-
An unmodifiable set containing some common English words that are usually not
useful for searching.
- STOP_WORDS_SET - Static variable in class org.apache.lucene.analysis.standard.StandardAnalyzer
-
- STOP_WORDS_SET - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailAnalyzer
-
An unmodifiable set containing some common English words that are usually not
useful for searching.
- StopAnalyzer - Class in org.apache.lucene.analysis.core
-
- StopAnalyzer() - Constructor for class org.apache.lucene.analysis.core.StopAnalyzer
-
- StopAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.core.StopAnalyzer
-
Builds an analyzer with the stop words from the given set.
- StopAnalyzer(Path) - Constructor for class org.apache.lucene.analysis.core.StopAnalyzer
-
Builds an analyzer with the stop words from the given path.
- StopAnalyzer(Reader) - Constructor for class org.apache.lucene.analysis.core.StopAnalyzer
-
Builds an analyzer with the stop words from the given reader.
- StopFilter - Class in org.apache.lucene.analysis.core
-
Removes stop words from a token stream.
- StopFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.core.StopFilter
-
Constructs a filter which removes words from the input TokenStream that are
named in the Set.
- StopFilter - Class in org.apache.lucene.analysis
-
Removes stop words from a token stream.
- StopFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.analysis.StopFilter
-
Constructs a filter which removes words from the input TokenStream that are
named in the Set.
- StopFilterFactory - Class in org.apache.lucene.analysis.core
-
- StopFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.core.StopFilterFactory
-
Creates a new StopFilterFactory
- stoplist - Variable in class org.apache.lucene.analysis.compound.hyphenation.HyphenationTree
-
This map stores hyphenation exceptions
- stopNow - Variable in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- stopNow() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- stopNow() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- stopTimer() - Method in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
Stops the timer thread
- stopUpdateThread() - Method in class org.apache.lucene.replicator.ReplicationClient
-
Stop the update thread.
- stopword - Static variable in class org.apache.lucene.search.SearchEquivalenceTestBase
-
- StopwordAnalyzerBase - Class in org.apache.lucene.analysis
-
Base class for Analyzers that need to make use of stopword sets.
- StopwordAnalyzerBase(CharArraySet) - Constructor for class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a new instance initialized with the given stopword set
- StopwordAnalyzerBase() - Constructor for class org.apache.lucene.analysis.StopwordAnalyzerBase
-
Creates a new Analyzer with an empty stopword set
- stopwords - Variable in class org.apache.lucene.analysis.StopwordAnalyzerBase
-
An immutable stopword set
- STOPWORDS_COMMENT - Static variable in class org.apache.lucene.analysis.fa.PersianAnalyzer
-
The comment character in the stopwords file.
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.analyzing.AnalyzingSuggester
-
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.analyzing.FreeTextSuggester
-
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.fst.FSTCompletionLookup
-
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.fst.WFSTCompletionLookup
-
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.jaspell.JaspellLookup
-
Deprecated.
- store(OutputStream) - Method in class org.apache.lucene.search.suggest.Lookup
-
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.Lookup
-
Persist the constructed lookup data to a directory.
- store(DataOutput) - Method in class org.apache.lucene.search.suggest.tst.TSTLookup
-
- store(DataOutput) - Method in class org.egothor.stemmer.MultiTrie
-
Write this data structure to the given output stream.
- store(DataOutput) - Method in class org.egothor.stemmer.MultiTrie2
-
Write this data structure to the given output stream.
- store(DataOutput) - Method in class org.egothor.stemmer.Row
-
Write the contents of this Row to the given output stream.
- store(DataOutput) - Method in class org.egothor.stemmer.Trie
-
Write this Trie to the given output stream.
- stored() - Method in class org.apache.lucene.document.FieldType
-
True if the field's value should be stored
- stored() - Method in interface org.apache.lucene.index.IndexableFieldType
-
True if the field's value should be stored
- StoredField - Class in org.apache.lucene.document
-
- StoredField(String, FieldType) - Constructor for class org.apache.lucene.document.StoredField
-
Expert: allows you to customize the
FieldType
.
- StoredField(String, BytesRef, FieldType) - Constructor for class org.apache.lucene.document.StoredField
-
Expert: allows you to customize the
FieldType
.
- StoredField(String, byte[]) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given binary value.
- StoredField(String, byte[], int, int) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given binary value.
- StoredField(String, BytesRef) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given binary value.
- StoredField(String, String) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given string value.
- StoredField(String, String, FieldType) - Constructor for class org.apache.lucene.document.StoredField
-
Expert: allows you to customize the
FieldType
.
- StoredField(String, CharSequence, FieldType) - Constructor for class org.apache.lucene.document.StoredField
-
Expert: allows you to customize the
FieldType
.
- StoredField(String, int) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given integer value.
- StoredField(String, float) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given float value.
- StoredField(String, long) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given long value.
- StoredField(String, double) - Constructor for class org.apache.lucene.document.StoredField
-
Create a stored-only field with the given double value.
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes stored fields
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.compressing.CompressingCodec
-
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- storedFieldsFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- StoredFieldsFormat - Class in org.apache.lucene.codecs
-
Controls the format of stored fields
- StoredFieldsFormat() - Constructor for class org.apache.lucene.codecs.StoredFieldsFormat
-
Sole constructor.
- StoredFieldsReader - Class in org.apache.lucene.codecs
-
Codec API for reading stored fields.
- StoredFieldsReader() - Constructor for class org.apache.lucene.codecs.StoredFieldsReader
-
Sole constructor.
- storedFieldsReaders - Variable in class org.apache.lucene.index.MergeState
-
Stored field producers being merged
- storedFieldStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status for testing of stored fields (null if stored fields could not be tested).
- StoredFieldsWriter - Class in org.apache.lucene.codecs
-
- StoredFieldsWriter() - Constructor for class org.apache.lucene.codecs.StoredFieldsWriter
-
Sole constructor.
- StoredFieldsWriter.MergeVisitor - Class in org.apache.lucene.codecs
-
A visitor that adds every field it sees.
- StoredFieldVisitor - Class in org.apache.lucene.index
-
Expert: provides a low-level means of accessing the stored field
values in an index.
- StoredFieldVisitor() - Constructor for class org.apache.lucene.index.StoredFieldVisitor
-
Sole constructor.
- StoredFieldVisitor.Status - Enum in org.apache.lucene.index
-
- storeTermVectorOffsets() - Method in class org.apache.lucene.document.FieldType
-
True if this field's token character offsets should also
be stored into term vectors.
- storeTermVectorOffsets() - Method in interface org.apache.lucene.index.IndexableFieldType
-
True if this field's token character offsets should also
be stored into term vectors.
- storeTermVectorPayloads() - Method in class org.apache.lucene.document.FieldType
-
True if this field's token payloads should also be stored
into the term vectors.
- storeTermVectorPayloads() - Method in interface org.apache.lucene.index.IndexableFieldType
-
True if this field's token payloads should also be stored
into the term vectors.
- storeTermVectorPositions() - Method in class org.apache.lucene.document.FieldType
-
True if this field's token positions should also be stored
into the term vectors.
- storeTermVectorPositions() - Method in interface org.apache.lucene.index.IndexableFieldType
-
True if this field's token positions should also be stored
into the term vectors.
- storeTermVectors() - Method in class org.apache.lucene.document.FieldType
-
True if this field's indexed form should be also stored
into term vectors.
- storeTermVectors() - Method in interface org.apache.lucene.index.IndexableFieldType
-
True if this field's indexed form should be also stored
into term vectors.
- strategy - Variable in class org.apache.lucene.benchmark.byTask.feeds.SpatialFileQueryMaker
-
- strcmp(char[], int, char[], int) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Compares 2 null terminated char arrays
- strcmp(String, char[], int) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Compares a string with null terminated char array
- strcpy(char[], int, char[], int) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- StrDocValues - Class in org.apache.lucene.queries.function.docvalues
-
Abstract
FunctionValues
implementation which supports retrieving String values.
- StrDocValues(ValueSource) - Constructor for class org.apache.lucene.queries.function.docvalues.StrDocValues
-
- Stream() - Constructor for class org.apache.lucene.search.PointInSetQuery.Stream
-
- stream - Variable in class org.apache.lucene.util.PrintStreamInfoStream
-
- StreamUtils - Class in org.apache.lucene.benchmark.byTask.utils
-
Stream utilities.
- StreamUtils() - Constructor for class org.apache.lucene.benchmark.byTask.utils.StreamUtils
-
- StreamUtils.Type - Enum in org.apache.lucene.benchmark.byTask.utils
-
File format type
- strictlyWithin(Vector) - Method in class org.apache.lucene.spatial3d.geom.SidedPlane
-
Check whether a point is strictly within a plane.
- strictlyWithin(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.SidedPlane
-
Check whether a point is strictly within a plane.
- STRING - Static variable in class org.apache.lucene.analysis.cn.smart.WordType
-
ASCII String
- string - Variable in class org.apache.lucene.queries.function.valuesource.LiteralValueSource
-
- string - Variable in class org.apache.lucene.search.spell.SuggestWord
-
the suggested word
- STRING_CHAR_ARRAY - Static variable in class org.apache.lucene.analysis.cn.smart.Utility
-
- STRING_CODEPOINT_COMPARATOR - Static variable in class org.apache.lucene.util.TestUtil
-
A comparator that compares UTF-16 strings / char sequences according to Unicode
code point order.
- STRING_FIRST - Static variable in class org.apache.lucene.search.SortField
-
- STRING_LAST - Static variable in class org.apache.lucene.search.SortField
-
- StringDistance - Interface in org.apache.lucene.search.spell
-
Interface for string distances.
- stringField(FieldInfo, byte[]) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- stringField(FieldInfo, byte[]) - Method in class org.apache.lucene.document.DocumentStoredFieldVisitor
-
- StringField - Class in org.apache.lucene.document
-
A field that is indexed but not tokenized: the entire
String value is indexed as a single token.
- StringField(String, String, Field.Store) - Constructor for class org.apache.lucene.document.StringField
-
Creates a new textual StringField, indexing the provided String value
as a single token.
- StringField(String, BytesRef, Field.Store) - Constructor for class org.apache.lucene.document.StringField
-
Creates a new binary StringField, indexing the provided binary (BytesRef)
value as a single token.
- stringField(FieldInfo, byte[]) - Method in class org.apache.lucene.index.StoredFieldVisitor
-
Process a string field; the provided byte[] value is a UTF-8 encoded string value.
- stringField(FieldInfo, byte[]) - Method in class org.apache.lucene.search.uhighlight.UnifiedHighlighter.LimitedStoredFieldVisitor
-
- StringHelper - Class in org.apache.lucene.util
-
Methods for manipulating strings.
- stringToCharSequence(String, Random) - Static method in class org.apache.lucene.util.TestUtil
-
- stringToDate(String) - Static method in class org.apache.lucene.document.DateTools
-
Converts a string produced by timeToString
or
dateToString
back to a time, represented as a
Date object.
- stringToPath(String) - Static method in class org.apache.lucene.facet.FacetsConfig
-
- stringToTime(String) - Static method in class org.apache.lucene.document.DateTools
-
Converts a string produced by timeToString
or
dateToString
back to a time, represented as the
number of milliseconds since January 1, 1970, 00:00:00 GMT.
- StringUtils - Class in org.apache.lucene.queryparser.flexible.core.util
-
String manipulation routines
- StringUtils() - Constructor for class org.apache.lucene.queryparser.flexible.core.util.StringUtils
-
- stringValue() - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- stringValue() - Method in class org.apache.lucene.document.Field
-
The value of the field as a String, or null.
- stringValue() - Method in class org.apache.lucene.document.LazyDocument.LazyField
-
- stringValue() - Method in interface org.apache.lucene.index.IndexableField
-
Non-null if this field has a string value
- stripExtension(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Removes the extension (anything after the first '.'),
otherwise returns the original filename.
- stripSegmentName(String) - Static method in class org.apache.lucene.index.IndexFileNames
-
Strips the segment name out of the given file name.
- stripTags(StringBuilder, int) - Static method in class org.apache.lucene.benchmark.byTask.feeds.TrecDocParser
-
strip tags from buf
: each tag is replaced by a single blank.
- stripTags(String, int) - Static method in class org.apache.lucene.benchmark.byTask.feeds.TrecDocParser
-
strip tags from input.
- strlen(char[], int) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- strlen(char[]) - Static method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
- strVal(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- strVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- strVal(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- strVal(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- strVal(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- strVal(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- strVal(int) - Method in class org.apache.lucene.queries.function.docvalues.StrDocValues
-
- strVal(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- strVal(int, String[]) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- Sub(MergeState.DocMap) - Constructor for class org.apache.lucene.index.DocIDMerger.Sub
-
Sole constructor
- SUB_HEADING - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- SUB_HEADING_ID - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
- subBlocksOnlyBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
The number of "internal" blocks that do not contain
terms (have only sub-blocks).
- subIndex(int, int[]) - Static method in class org.apache.lucene.index.ReaderUtil
-
Returns index of the searcher/reader for document n
in the
array used to construct this searcher/reader.
- subIndex(int, List<LeafReaderContext>) - Static method in class org.apache.lucene.index.ReaderUtil
-
Returns index of the searcher/reader for document n
in the
array used to construct this searcher/reader.
- SubInfo(String, List<FieldPhraseList.WeightedPhraseInfo.Toffs>, int, float) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
-
- subList(int, int) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- SubmissionReport - Class in org.apache.lucene.benchmark.quality.utils
-
Create a log ready for submission.
- SubmissionReport(PrintWriter, String) - Constructor for class org.apache.lucene.benchmark.quality.utils.SubmissionReport
-
Constructor for SubmissionReport.
- subpath(int) - Method in class org.apache.lucene.facet.taxonomy.FacetLabel
-
Returns a sub-path of this path up to length
components.
- subpath(int, int) - Method in class org.apache.lucene.mockfile.FilterPath
-
- subQueriesOrdered() - Method in class org.apache.lucene.queryparser.surround.query.DistanceQuery
-
- SubReaderWrapper() - Constructor for class org.apache.lucene.index.FilterDirectoryReader.SubReaderWrapper
-
Constructor
- subSequence(int, int) - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
- subSequence(int, int) - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- subSequence(int, int) - Method in class org.apache.lucene.queryparser.flexible.core.util.UnescapedCharSequence
-
- subSequence(int, int) - Method in class org.apache.lucene.util.CharsRef
-
- subsetOf(Automaton, Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns true if the language of a1
is a subset of the language
of a2
.
- subtract(BytesRef, BytesRef) - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- subtract(CharsRef, CharsRef) - Method in class org.apache.lucene.util.fst.CharSequenceOutputs
-
- subtract(IntsRef, IntsRef) - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- subtract(Object, Object) - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- subtract(Object, Object) - Method in class org.apache.lucene.util.fst.NoOutputs
-
- subtract(T, T) - Method in class org.apache.lucene.util.fst.Outputs
-
Eg subtract("foobar", "foo") -> "bar"
- subtract(PairOutputs.Pair<A, B>, PairOutputs.Pair<A, B>) - Method in class org.apache.lucene.util.fst.PairOutputs
-
- subtract(Long, Long) - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-
- subtract(Object, Object) - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs
-
- subtract(int, int, byte[], byte[], byte[]) - Static method in class org.apache.lucene.util.NumericUtils
-
Result = a - b, where a >= b, else IllegalArgumentException
is thrown.
- SUBWORD_DELIM - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilter
-
Deprecated.
- suffix - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Rule
-
- SUFFIX_MAXX - Static variable in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- SUFFIX_MAXY - Static variable in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- SUFFIX_MINX - Static variable in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- SUFFIX_MINY - Static variable in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- SUFFIX_X - Static variable in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
- SUFFIX_XDL - Static variable in class org.apache.lucene.spatial.bbox.BBoxStrategy
-
- SUFFIX_Y - Static variable in class org.apache.lucene.spatial.vector.PointVectorStrategy
-
- suffixes - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- suffixes - Variable in class org.apache.lucene.analysis.pt.RSLPStemmerBase.Step
-
- SUFFIXTERM - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- suffixToString(StringBuilder) - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- suffixToString(StringBuilder) - Method in class org.apache.lucene.queryparser.surround.query.SrndPrefixQuery
-
- suggest(CompletionQuery, int, boolean) - Method in class org.apache.lucene.search.suggest.document.SuggestIndexSearcher
-
Returns top n
completion hits for
query
- suggest(CompletionQuery, TopSuggestDocsCollector) - Method in class org.apache.lucene.search.suggest.document.SuggestIndexSearcher
-
Lower-level suggest API.
- suggester() - Method in class org.apache.lucene.search.suggest.document.CompletionsTermsReader
-
Returns the suggester for a field, if not loaded already, loads
the appropriate suggester from CompletionDictionary
- suggester() - Method in class org.apache.lucene.search.suggest.document.CompletionTerms
-
Returns a
NRTSuggester
for the field
or
null
if no FST
was indexed for this field
- SuggestField - Class in org.apache.lucene.search.suggest.document
-
Field that indexes a string value and a weight as a weighted completion
against a named suggester.
- SuggestField(String, String, int) - Constructor for class org.apache.lucene.search.suggest.document.SuggestField
-
- SuggestIndexSearcher - Class in org.apache.lucene.search.suggest.document
-
Adds document suggest capabilities to IndexSearcher.
- SuggestIndexSearcher(IndexReader) - Constructor for class org.apache.lucene.search.suggest.document.SuggestIndexSearcher
-
Creates a searcher with document suggest capabilities
for reader
.
- suggestion - Variable in class org.apache.lucene.search.spell.CombineSuggestion
-
The word combination suggestion
- SuggestMode - Enum in org.apache.lucene.search.spell
-
Set of strategies for suggesting related terms
- SuggestScoreDoc(int, CharSequence, CharSequence, float) - Constructor for class org.apache.lucene.search.suggest.document.TopSuggestDocs.SuggestScoreDoc
-
Creates a SuggestScoreDoc instance
- suggestSimilar(Term, int, IndexReader) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
- suggestSimilar(Term, int, IndexReader, SuggestMode) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
- suggestSimilar(Term, int, IndexReader, SuggestMode, float) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Suggest similar words.
- suggestSimilar(Term, int, IndexReader, int, int, float, CharsRefBuilder) - Method in class org.apache.lucene.search.spell.DirectSpellChecker
-
Provide spelling corrections based on several parameters.
- suggestSimilar(String, int) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Suggest similar words.
- suggestSimilar(String, int, float) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Suggest similar words.
- suggestSimilar(String, int, IndexReader, String, SuggestMode) - Method in class org.apache.lucene.search.spell.SpellChecker
-
- suggestSimilar(String, int, IndexReader, String, SuggestMode, float) - Method in class org.apache.lucene.search.spell.SpellChecker
-
Suggest similar words (optionally restricted to a field of an index).
- SuggestStopFilter - Class in org.apache.lucene.search.suggest.analyzing
-
Like
StopFilter
except it will not remove the
last token if that token was not followed by some token
separator.
- SuggestStopFilter(TokenStream, CharArraySet) - Constructor for class org.apache.lucene.search.suggest.analyzing.SuggestStopFilter
-
Sole constructor.
- SuggestStopFilterFactory - Class in org.apache.lucene.search.suggest.analyzing
-
- SuggestStopFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.search.suggest.analyzing.SuggestStopFilterFactory
-
Creates a new StopFilterFactory
- SuggestWord - Class in org.apache.lucene.search.spell
-
SuggestWord, used in suggestSimilar method in SpellChecker class.
- SuggestWord() - Constructor for class org.apache.lucene.search.spell.SuggestWord
-
Creates a new empty suggestion with null text.
- suggestWordBreaks(Term, int, IndexReader, SuggestMode, WordBreakSpellChecker.BreakSuggestionSortMethod) - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Generate suggestions by breaking the passed-in term into multiple words.
- suggestWordCombinations(Term[], int, IndexReader, SuggestMode) - Method in class org.apache.lucene.search.spell.WordBreakSpellChecker
-
Generate suggestions by combining one or more of the passed-in terms into
single words.
- SuggestWordFrequencyComparator - Class in org.apache.lucene.search.spell
-
Frequency first, then score.
- SuggestWordFrequencyComparator() - Constructor for class org.apache.lucene.search.spell.SuggestWordFrequencyComparator
-
- SuggestWordQueue - Class in org.apache.lucene.search.spell
-
Sorts SuggestWord instances
- SuggestWordQueue(int) - Constructor for class org.apache.lucene.search.spell.SuggestWordQueue
-
- SuggestWordQueue(int, Comparator<SuggestWord>) - Constructor for class org.apache.lucene.search.spell.SuggestWordQueue
-
Specify the size of the queue and the comparator to use for sorting.
- SuggestWordScoreComparator - Class in org.apache.lucene.search.spell
-
Score first, then frequency
- SuggestWordScoreComparator() - Constructor for class org.apache.lucene.search.spell.SuggestWordScoreComparator
-
- suiteFailureMarker - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Suite failure marker (any error in the test or suite scope).
- SUKUN - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- sum() - Method in class org.apache.lucene.search.DocValuesStats.DoubleDocValuesStats
-
- sum() - Method in class org.apache.lucene.search.DocValuesStats.LongDocValuesStats
-
- sum() - Method in class org.apache.lucene.search.DocValuesStats.NumericDocValuesStats
-
Returns the sum of values of the field.
- sum() - Method in class org.apache.lucene.search.DocValuesStats.SortedDoubleDocValuesStats
-
- sum() - Method in class org.apache.lucene.search.DocValuesStats.SortedLongDocValuesStats
-
- sum() - Method in class org.apache.lucene.search.DocValuesStats.SortedNumericDocValuesStats
-
Returns the sum of values of the field.
- sumDocFreq(String) - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the sumDocFreq for a given field
- sumDocFreq() - Method in class org.apache.lucene.search.CollectionStatistics
-
returns the total number of postings for this field
- SumFloatFunction - Class in org.apache.lucene.queries.function.valuesource
-
SumFloatFunction
returns the sum of its components.
- SumFloatFunction(ValueSource[]) - Constructor for class org.apache.lucene.queries.function.valuesource.SumFloatFunction
-
- SumPayloadFunction - Class in org.apache.lucene.queries.payloads
-
Calculate the final score as the sum of scores of all payloads seen.
- SumPayloadFunction() - Constructor for class org.apache.lucene.queries.payloads.SumPayloadFunction
-
- sumTotalTermFreq(String) - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the sumTotalTermFreq for a field
- sumTotalTermFreq() - Method in class org.apache.lucene.search.CollectionStatistics
-
returns the total number of tokens for this field
- SumTotalTermFreqValueSource - Class in org.apache.lucene.queries.function.valuesource
-
SumTotalTermFreqValueSource
returns the number of tokens.
- SumTotalTermFreqValueSource(String) - Constructor for class org.apache.lucene.queries.function.valuesource.SumTotalTermFreqValueSource
-
- SUN_OS - Static variable in class org.apache.lucene.util.Constants
-
True iff running on SunOS.
- supportedFileAttributeViews() - Method in class org.apache.lucene.mockfile.FilterFileSystem
-
- supportsFileAttributeView(Class<? extends FileAttributeView>) - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- supportsFileAttributeView(String) - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- supportsIndexSort() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
- supportsMinVersion() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Whether this format records min versions.
- supportsOrd() - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexReader
-
- supportsOrd() - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase
-
- supportsOrd() - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexReader
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddIndexesTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.AnalyzerFactoryTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.CloseIndexTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.CommitIndexTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.ForceMergeTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.NearRealtimeReaderTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewAnalyzerTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewCollationAnalyzerTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.NewLocaleTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenIndexTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.OpenReaderTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Sub classes that support parameters must override this method to return
true.
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.PrintReaderTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravRetLoadFieldSelectorTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchWithSortTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.SetPropTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.UpdateDocTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.WaitTask
-
- supportsParams() - Method in class org.apache.lucene.benchmark.byTask.tasks.WriteLineDocTask
-
- supportsPolygons() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Whether this impl supports polygons.
- SuppressForbidden - Annotation Type in org.apache.lucene.util
-
Annotation to suppress forbidden-apis errors inside a whole class, a method, or a field.
- SuppressingConcurrentMergeScheduler - Class in org.apache.lucene.index
-
- SuppressingConcurrentMergeScheduler() - Constructor for class org.apache.lucene.index.SuppressingConcurrentMergeScheduler
-
- surfaceDistance(GeoPoint, GeoPoint) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Compute surface distance between two points.
- surfaceForm - Variable in class org.apache.lucene.analysis.ko.dict.Dictionary.Morpheme
-
- surfacePointOnBearing(GeoPoint, double, double) - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
Compute new point given original point, a bearing direction, and an adjusted angle (as would be computed by
the surfaceDistance() method above).
- SURROGATE - Static variable in class org.apache.lucene.analysis.cn.smart.CharType
-
Surrogate character
- swap(int, int) - Method in class org.apache.lucene.codecs.MutablePointValues
-
Swap the i-th and j-th values.
- swap(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Swap values stored in slots i
and j
- swap(int, int) - Method in class org.apache.lucene.util.Selector
-
Swap values at slots i
and j
.
- swap(int, int) - Method in class org.apache.lucene.util.Sorter
-
Swap values at slots i
and j
.
- SwedishAnalyzer - Class in org.apache.lucene.analysis.sv
-
- SwedishAnalyzer() - Constructor for class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
- SwedishAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
Builds an analyzer with the given stop words.
- SwedishAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.sv.SwedishAnalyzer
-
Builds an analyzer with the given stop words.
- SwedishLightStemFilter - Class in org.apache.lucene.analysis.sv
-
- SwedishLightStemFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.sv.SwedishLightStemFilter
-
- SwedishLightStemFilterFactory - Class in org.apache.lucene.analysis.sv
-
- SwedishLightStemFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.sv.SwedishLightStemFilterFactory
-
Creates a new SwedishLightStemFilterFactory
- SwedishLightStemmer - Class in org.apache.lucene.analysis.sv
-
Light Stemmer for Swedish.
- SwedishLightStemmer() - Constructor for class org.apache.lucene.analysis.sv.SwedishLightStemmer
-
- SwedishStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- SwedishStemmer() - Constructor for class org.tartarus.snowball.ext.SwedishStemmer
-
- SweetSpotSimilarity - Class in org.apache.lucene.misc
-
A similarity with a lengthNorm that provides for a "plateau" of
equally good lengths, and tf helper functions.
- SweetSpotSimilarity() - Constructor for class org.apache.lucene.misc.SweetSpotSimilarity
-
- SwitchTo(int) - Method in class org.apache.lucene.queryparser.classic.QueryParserTokenManager
-
Switch to specified lex state.
- SwitchTo(int) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserTokenManager
-
Switch to specified lex state.
- SwitchTo(int) - Method in class org.apache.lucene.queryparser.surround.parser.QueryParserTokenManager
-
Switch to specified lex state.
- SYMBOL - Static variable in class org.apache.lucene.analysis.ja.dict.CharacterDefinition
-
- SYMBOL - Static variable in class org.apache.lucene.analysis.ko.dict.CharacterDefinition
-
- sync() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Wait for any running merge threads to finish.
- sync(Collection<String>) - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- sync(Collection<String>) - Method in class org.apache.lucene.store.Directory
-
Ensures that any writes to these files are moved to
stable storage (made durable).
- sync(Collection<String>) - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- sync(Collection<String>) - Method in class org.apache.lucene.store.FilterDirectory
-
- sync(Collection<String>) - Method in class org.apache.lucene.store.FSDirectory
-
- sync(Collection<String>) - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
-
- sync(Collection<String>) - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- sync(Collection<String>) - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- sync(Collection<String>) - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- syncConcurrentMerges(IndexWriter) - Static method in class org.apache.lucene.util.TestUtil
-
- syncConcurrentMerges(MergeScheduler) - Static method in class org.apache.lucene.util.TestUtil
-
- syncMetaData() - Method in class org.apache.lucene.store.ByteBuffersDirectory
-
- syncMetaData() - Method in class org.apache.lucene.store.Directory
-
Ensures that directory metadata, such as recent file renames, are moved to stable
storage.
- syncMetaData() - Method in class org.apache.lucene.store.FileSwitchDirectory
-
- syncMetaData() - Method in class org.apache.lucene.store.FilterDirectory
-
- syncMetaData() - Method in class org.apache.lucene.store.FSDirectory
-
- syncMetaData() - Method in class org.apache.lucene.store.LockValidatingDirectoryWrapper
-
- syncMetaData() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- syncMetaData() - Method in class org.apache.lucene.store.RAMDirectory
-
Deprecated.
- SynonymFilter - Class in org.apache.lucene.analysis.synonym
-
- SynonymFilter(TokenStream, SynonymMap, boolean) - Constructor for class org.apache.lucene.analysis.synonym.SynonymFilter
-
Deprecated.
- SynonymFilterFactory - Class in org.apache.lucene.analysis.synonym
-
- SynonymFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.synonym.SynonymFilterFactory
-
Deprecated.
- SynonymGraphFilter - Class in org.apache.lucene.analysis.synonym
-
Applies single- or multi-token synonyms from a
SynonymMap
to an incoming
TokenStream
, producing a fully correct graph
output.
- SynonymGraphFilter(TokenStream, SynonymMap, boolean) - Constructor for class org.apache.lucene.analysis.synonym.SynonymGraphFilter
-
Apply previously built synonyms to incoming tokens.
- SynonymGraphFilterFactory - Class in org.apache.lucene.analysis.synonym
-
- SynonymGraphFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.synonym.SynonymGraphFilterFactory
-
- SynonymMap - Class in org.apache.lucene.analysis.synonym
-
A map of synonyms, keys and values are phrases.
- SynonymMap(FST<BytesRef>, BytesRefHash, int) - Constructor for class org.apache.lucene.analysis.synonym.SynonymMap
-
- SynonymMap.Builder - Class in org.apache.lucene.analysis.synonym
-
Builds an FSTSynonymMap.
- SynonymMap.Parser - Class in org.apache.lucene.analysis.synonym
-
Abstraction for parsing synonym files.
- SynonymQuery - Class in org.apache.lucene.search
-
A query that treats multiple terms as synonyms.
- SynonymQuery(Term...) - Constructor for class org.apache.lucene.search.SynonymQuery
-
Creates a new SynonymQuery, matching any of the supplied terms.
- SynonymQueryNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
QueryNode
for clauses that are synonym of each other.
- SynonymQueryNode(List<QueryNode>) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.SynonymQueryNode
-
Sole constructor.
- SynonymQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- SynonymQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.SynonymQueryNodeBuilder
-
Sole constructor.
- SyntaxParser - Interface in org.apache.lucene.queryparser.flexible.core.parser
-
- SYSPROP_AWAITSFIX - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- SYSPROP_BADAPPLES - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- SYSPROP_FAILFAST - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- SYSPROP_MAXFAILURES - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- SYSPROP_MONSTER - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- SYSPROP_NIGHTLY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- SYSPROP_SLOW - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- SYSPROP_WEEKLY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- ta(String[]) - Static method in class org.apache.lucene.search.BaseExplanationTestCase
-
helper for generating MultiPhraseQueries
- tableTitle(String) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
Compute a title line for a report table
- TAG_ID - Static variable in class org.apache.lucene.queryparser.flexible.standard.processors.MultiTermRewriteMethodProcessor
-
- tagModifierButDoNotOverride(QueryNode, ModifierQueryNode.Modifier) - Method in class org.apache.lucene.queryparser.flexible.standard.processors.BooleanQuery2ModifierNodeProcessor
-
- target - Variable in class org.apache.lucene.queries.function.valuesource.RangeMapFloatFunction
-
- target - Variable in class org.apache.lucene.util.fst.Builder.Arc
-
- target - Variable in class org.apache.lucene.util.fst.FST.Arc
-
To node (ord or address)
- targetHasArcs(FST.Arc<T>) - Static method in class org.apache.lucene.util.fst.FST
-
returns true if the node at this address has any
outgoing arcs
- TARGETMAP_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- TARGETMAP_FILENAME_SUFFIX - Static variable in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- TARGETMAP_HEADER - Static variable in class org.apache.lucene.analysis.ja.dict.BinaryDictionary
-
- TARGETMAP_HEADER - Static variable in class org.apache.lucene.analysis.ko.dict.BinaryDictionary
-
- targetMBPerSec - Variable in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Current IO writes throttle rate
- targetMBPerSecChanged() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
Subclass can override to tweak targetMBPerSec.
- taskReportLine(String, TaskStats) - Method in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
Compute a report line for the given task stat.
- TaskSequence - Class in org.apache.lucene.benchmark.byTask.tasks
-
Sequence of parallel or sequential tasks.
- TaskSequence(PerfRunData, String, TaskSequence, boolean) - Constructor for class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- taskStats() - Method in class org.apache.lucene.benchmark.byTask.stats.Points
-
Return the current task stats.
- TaskStats - Class in org.apache.lucene.benchmark.byTask.stats
-
Statistics for a task run.
- TATWEEL - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- TAXONOMY_SOURCE - Static variable in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- TaxonomyFacetCounts - Class in org.apache.lucene.facet.taxonomy
-
- TaxonomyFacetCounts(OrdinalsReader, TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacetCounts
-
Create TaxonomyFacetCounts
, which also
counts all facet labels.
- TaxonomyFacets - Class in org.apache.lucene.facet.taxonomy
-
Base class for all taxonomy-based facets impls.
- TaxonomyFacets(String, TaxonomyReader, FacetsConfig) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
Sole constructor.
- TaxonomyFacetSumFloatAssociations - Class in org.apache.lucene.facet.taxonomy
-
- TaxonomyFacetSumFloatAssociations(TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacetSumFloatAssociations
-
Create TaxonomyFacetSumFloatAssociations
against
the default index field.
- TaxonomyFacetSumFloatAssociations(String, TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacetSumFloatAssociations
-
Create TaxonomyFacetSumFloatAssociations
against
the specified index field.
- TaxonomyFacetSumIntAssociations - Class in org.apache.lucene.facet.taxonomy
-
- TaxonomyFacetSumIntAssociations(TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacetSumIntAssociations
-
Create TaxonomyFacetSumIntAssociations
against
the default index field.
- TaxonomyFacetSumIntAssociations(String, TaxonomyReader, FacetsConfig, FacetsCollector) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacetSumIntAssociations
-
Create TaxonomyFacetSumIntAssociations
against
the specified index field.
- TaxonomyFacetSumValueSource - Class in org.apache.lucene.facet.taxonomy
-
- TaxonomyFacetSumValueSource(TaxonomyReader, FacetsConfig, FacetsCollector, DoubleValuesSource) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacetSumValueSource
-
- TaxonomyFacetSumValueSource(OrdinalsReader, TaxonomyReader, FacetsConfig, FacetsCollector, DoubleValuesSource) - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyFacetSumValueSource
-
- TaxonomyMergeUtils - Class in org.apache.lucene.facet.taxonomy
-
Utility methods for merging index and taxonomy directories.
- taxonomyReader - Variable in class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager.SearcherAndTaxonomy
-
- TaxonomyReader - Class in org.apache.lucene.facet.taxonomy
-
TaxonomyReader is the read-only interface with which the faceted-search
library uses the taxonomy during search time.
- TaxonomyReader() - Constructor for class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Sole constructor.
- TaxonomyReader.ChildrenIterator - Class in org.apache.lucene.facet.taxonomy
-
An iterator over a category's children.
- TaxonomyWriter - Interface in org.apache.lucene.facet.taxonomy
-
TaxonomyWriter is the interface which the faceted-search library uses
to dynamically build the taxonomy at indexing time.
- TaxonomyWriterCache - Interface in org.apache.lucene.facet.taxonomy.writercache
-
TaxonomyWriterCache is a relatively simple interface for a cache of
category->ordinal mappings, used in TaxonomyWriter implementations (such as
DirectoryTaxonomyWriter
).
- taxoReader - Variable in class org.apache.lucene.facet.DrillSideways
-
- taxoReader - Variable in class org.apache.lucene.facet.taxonomy.TaxonomyFacets
-
TaxonomyReader
provided to the constructor.
- tearDown() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddDocTask
-
- tearDown() - Method in class org.apache.lucene.benchmark.byTask.tasks.AddIndexesTask
-
- tearDown() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
Task tearDown work that should not be measured for that specific task.
- tearDown() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTokensTask
-
- tearDown() - Method in class org.apache.lucene.benchmark.byTask.tasks.UpdateDocTask
-
- tearDown() - Method in class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
- tearDown() - Method in class org.apache.lucene.util.LuceneTestCase
-
For subclasses to override.
- TeeSinkTokenFilter - Class in org.apache.lucene.analysis.sinks
-
This TokenFilter provides the ability to set aside attribute states that have already been analyzed.
- TeeSinkTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.sinks.TeeSinkTokenFilter
-
- TeeSinkTokenFilter.SinkTokenStream - Class in org.apache.lucene.analysis.sinks
-
TokenStream output from a tee.
- TEH - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- TEH_MARBUTA - Static variable in class org.apache.lucene.analysis.ar.ArabicNormalizer
-
- TEH_MARBUTA - Static variable in class org.apache.lucene.analysis.ar.ArabicStemmer
-
- tempMergeFiles - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
number of temporary files created when merging partitions
- tenum - Variable in class org.apache.lucene.index.FilteredTermsEnum
-
- term() - Method in class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase.FieldIndexEnum
-
- term() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- term() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- term(String, String, String...) - Static method in class org.apache.lucene.facet.DrillDownQuery
-
Creates a drill-down term.
- term() - Method in class org.apache.lucene.index.FilteredTermsEnum
-
- term() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- term() - Method in class org.apache.lucene.index.MultiTermsEnum
-
- Term - Class in org.apache.lucene.index
-
A Term represents a word from text.
- Term(String, BytesRef) - Constructor for class org.apache.lucene.index.Term
-
Constructs a Term with the given field and bytes.
- Term(String, BytesRefBuilder) - Constructor for class org.apache.lucene.index.Term
-
Constructs a Term with the given field and the bytes from a builder.
- Term(String, String) - Constructor for class org.apache.lucene.index.Term
-
Constructs a Term with the given field and text.
- Term(String) - Constructor for class org.apache.lucene.index.Term
-
Constructs a Term with the given field and empty text.
- term() - Method in class org.apache.lucene.index.TermsEnum
-
Returns current term.
- Term(String) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
- TERM - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
RegularExpression Id.
- Term(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- TERM - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
RegularExpression Id.
- TERM - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- term - Variable in class org.apache.lucene.search.AutomatonQuery
-
term containing the field, and possibly some pattern structure
- term() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- term(BytesRef) - Static method in class org.apache.lucene.search.intervals.Intervals
-
- term(String) - Static method in class org.apache.lucene.search.intervals.Intervals
-
- term - Variable in class org.apache.lucene.search.spans.SpanTermQuery
-
- term - Variable in class org.apache.lucene.search.spans.TermSpans
-
- term - Variable in class org.apache.lucene.search.spell.DirectSpellChecker.ScoreTerm
-
The actual spellcheck correction.
- term() - Method in class org.apache.lucene.search.TermStatistics
-
returns the term text
- term - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-
- termAsString - Variable in class org.apache.lucene.search.spell.DirectSpellChecker.ScoreTerm
-
The spellcheck correction represented as string, can be null
.
- termAtt - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- TermAutomatonQuery - Class in org.apache.lucene.search
-
A proximity query that lets you express an automaton, whose
transitions are terms, to match documents.
- TermAutomatonQuery(String) - Constructor for class org.apache.lucene.search.TermAutomatonQuery
-
- termBlockOrd - Variable in class org.apache.lucene.codecs.BlockTermState
-
the term's ord in the current block
- TermContext - Class in org.apache.lucene.index
-
- TermContext(IndexReaderContext) - Constructor for class org.apache.lucene.index.TermContext
-
- TermContext(IndexReaderContext, TermState, int, int, long) - Constructor for class org.apache.lucene.index.TermContext
-
- termContext - Variable in class org.apache.lucene.search.spans.SpanTermQuery
-
- termCount - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
-
Number of terms with at least one live doc.
- termFreq(Term) - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a value source that returns the term freq of a given term for each document
- TermFrequencyAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
Sets the custom term frequency of a term within one document.
- TermFrequencyAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- TermFrequencyAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TermFrequencyAttributeImpl
-
Initialize this attribute with term frequencey of 1
- TermFreqValueSource - Class in org.apache.lucene.queries.function.valuesource
-
- TermFreqValueSource(String, String, String, BytesRef) - Constructor for class org.apache.lucene.queries.function.valuesource.TermFreqValueSource
-
- TermGroupFacetCollector - Class in org.apache.lucene.search.grouping
-
An implementation of
GroupFacetCollector
that computes grouped facets based on the indexed terms
from DocValues.
- TermGroupSelector - Class in org.apache.lucene.search.grouping
-
A GroupSelector implementation that groups via SortedDocValues
- TermGroupSelector(String) - Constructor for class org.apache.lucene.search.grouping.TermGroupSelector
-
Create a new TermGroupSelector
- terminatedEarly() - Method in class org.apache.lucene.search.EarlyTerminatingSortingCollector
-
Deprecated.
- TERMINATING_DOC - Static variable in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- TERMINATING_DOCNO - Static variable in class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- termIndexStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status for testing of indexed terms (null if indexed terms could not be tested).
- TermInSetQuery - Class in org.apache.lucene.search
-
- TermInSetQuery(String, Collection<BytesRef>) - Constructor for class org.apache.lucene.search.TermInSetQuery
-
- TermInSetQuery(String, BytesRef...) - Constructor for class org.apache.lucene.search.TermInSetQuery
-
- termLenByLevel - Variable in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- TermOrdValComparator(int, String) - Constructor for class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
Creates this, sorting missing values first.
- TermOrdValComparator(int, String, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.TermOrdValComparator
-
Creates this, with control over how missing values
are sorted.
- TermQuery - Class in org.apache.lucene.search
-
A Query that matches documents containing a term.
- TermQuery(Term) - Constructor for class org.apache.lucene.search.TermQuery
-
Constructs a query for the term t
.
- TermQuery(Term, TermContext) - Constructor for class org.apache.lucene.search.TermQuery
-
Expert: constructs a TermQuery that will use the provided docFreq instead
of looking up the docFreq against the searcher.
- TermQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
- TermQueryBuilder() - Constructor for class org.apache.lucene.queryparser.xml.builders.TermQueryBuilder
-
- TermQueryPrefixTreeStrategy - Class in org.apache.lucene.spatial.prefix
-
- TermQueryPrefixTreeStrategy(SpatialPrefixTree, String) - Constructor for class org.apache.lucene.spatial.prefix.TermQueryPrefixTreeStrategy
-
- TermRangeQuery - Class in org.apache.lucene.search
-
A Query that matches documents within an range of terms.
- TermRangeQuery(String, BytesRef, BytesRef, boolean, boolean) - Constructor for class org.apache.lucene.search.TermRangeQuery
-
Constructs a query selecting all terms greater/equal than lowerTerm
but less/equal than upperTerm
.
- TermRangeQueryNode - Class in org.apache.lucene.queryparser.flexible.standard.nodes
-
This query node represents a range query composed by
FieldQueryNode
bounds, which means the bound values are strings.
- TermRangeQueryNode(FieldQueryNode, FieldQueryNode, boolean, boolean) - Constructor for class org.apache.lucene.queryparser.flexible.standard.nodes.TermRangeQueryNode
-
- TermRangeQueryNodeBuilder - Class in org.apache.lucene.queryparser.flexible.standard.builders
-
- TermRangeQueryNodeBuilder() - Constructor for class org.apache.lucene.queryparser.flexible.standard.builders.TermRangeQueryNodeBuilder
-
- TermRangeQueryNodeProcessor - Class in org.apache.lucene.queryparser.flexible.standard.processors
-
- TermRangeQueryNodeProcessor() - Constructor for class org.apache.lucene.queryparser.flexible.standard.processors.TermRangeQueryNodeProcessor
-
- terms(String) - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- terms(String) - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- terms(String) - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- terms(String) - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- terms(String) - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- terms(String) - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- terms(String) - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingFields
-
- terms(String) - Method in class org.apache.lucene.index.AssertingLeafReader
-
- terms(String) - Method in class org.apache.lucene.index.CodecReader
-
- terms(String) - Method in class org.apache.lucene.index.ExitableDirectoryReader.ExitableFilterAtomicReader
-
- terms(String) - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- terms(String) - Method in class org.apache.lucene.index.Fields
-
Get the
Terms
for this field.
- terms(String) - Method in class org.apache.lucene.index.FilterLeafReader.FilterFields
-
- terms(String) - Method in class org.apache.lucene.index.FilterLeafReader
-
- terms(String) - Method in class org.apache.lucene.index.LeafReader
-
Returns the
Terms
index for this field, or null if it has none.
- terms(String) - Method in class org.apache.lucene.index.MappedMultiFields
-
- terms(String) - Method in class org.apache.lucene.index.MultiFields
-
- terms(String) - Method in class org.apache.lucene.index.ParallelLeafReader
-
- Terms - Class in org.apache.lucene.index
-
Access to the terms in a specific field.
- Terms() - Constructor for class org.apache.lucene.index.Terms
-
Sole constructor.
- terms - Variable in class org.apache.lucene.queries.CommonTermsQuery
-
- terms(String) - Method in class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- terms(String) - Method in class org.apache.lucene.search.uhighlight.OverlaySingleDocTermsLeafReader
-
- terms - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- TERMS_VERSION_CURRENT - Static variable in class org.apache.lucene.codecs.memory.FSTTermsWriter
-
- TERMS_VERSION_START - Static variable in class org.apache.lucene.codecs.memory.FSTTermsWriter
-
- termsEnum() - Method in class org.apache.lucene.index.LegacySortedDocValues
-
Deprecated.
- termsEnum() - Method in class org.apache.lucene.index.LegacySortedSetDocValues
-
Deprecated.
- termsEnum() - Method in class org.apache.lucene.index.SortedDocValues
-
- termsEnum() - Method in class org.apache.lucene.index.SortedSetDocValues
-
- TermsEnum - Class in org.apache.lucene.index
-
- TermsEnum() - Constructor for class org.apache.lucene.index.TermsEnum
-
Sole constructor.
- termsEnum - Variable in class org.apache.lucene.spatial.prefix.AbstractPrefixTreeQuery.BaseTermsEnumTraverser
-
- TermsEnum.SeekStatus - Enum in org.apache.lucene.index
-
- termsEnums - Variable in class org.apache.lucene.index.PerThreadPKLookup
-
- termsIndex - Variable in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- TermsIndexReaderBase - Class in org.apache.lucene.codecs.blockterms
-
BlockTermsReader
interacts with an instance of this class
to manage its terms index.
- TermsIndexReaderBase() - Constructor for class org.apache.lucene.codecs.blockterms.TermsIndexReaderBase
-
- TermsIndexReaderBase.FieldIndexEnum - Class in org.apache.lucene.codecs.blockterms
-
Similar to TermsEnum, except, the only "metadata" it
reports for a given indexed term is the long fileOffset
into the main terms dictionary file.
- TermsIndexWriterBase - Class in org.apache.lucene.codecs.blockterms
-
- TermsIndexWriterBase() - Constructor for class org.apache.lucene.codecs.blockterms.TermsIndexWriterBase
-
- TermsIndexWriterBase.FieldWriter - Class in org.apache.lucene.codecs.blockterms
-
Terms index API for a single field.
- termsOnlyBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
The number of "leaf" blocks (blocks that have only
terms).
- TermSpans - Class in org.apache.lucene.search.spans
-
Expert:
Public for extension only.
- TermSpans(Similarity.SimScorer, PostingsEnum, Term, float) - Constructor for class org.apache.lucene.search.spans.TermSpans
-
- TermsQueryBuilder - Class in org.apache.lucene.queryparser.xml.builders
-
Builds a BooleanQuery from all of the terms found in the XML element using the choice of analyzer
- TermsQueryBuilder(Analyzer) - Constructor for class org.apache.lucene.queryparser.xml.builders.TermsQueryBuilder
-
- termState() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- termState() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- termState() - Method in class org.apache.lucene.index.FilteredTermsEnum
-
Returns the filtered enums term state
- termState() - Method in class org.apache.lucene.index.TermsEnum
-
Expert: Returns the TermsEnums internal state to position the TermsEnum
without re-seeking the term dictionary.
- TermState - Class in org.apache.lucene.index
-
Encapsulates all required internal state to position the associated
TermsEnum
without re-seeking.
- TermState() - Constructor for class org.apache.lucene.index.TermState
-
Sole constructor.
- termState() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- termStatistics(Term, TermContext) - Method in class org.apache.lucene.search.IndexSearcher
-
- termStatistics(Term, TermContext) - Method in class org.apache.lucene.search.ShardSearchingTestBase.NodeState.ShardIndexSearcher
-
- TermStatistics - Class in org.apache.lucene.search
-
Contains statistics for a specific term
- TermStatistics(BytesRef, long, long) - Constructor for class org.apache.lucene.search.TermStatistics
-
- TermStats - Class in org.apache.lucene.codecs
-
Holder for per-term statistics.
- TermStats(int, long) - Constructor for class org.apache.lucene.codecs.TermStats
-
Sole constructor.
- TermStats - Class in org.apache.lucene.misc
-
- termtext - Variable in class org.apache.lucene.misc.TermStats
-
- TermToBytesRefAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
This attribute is requested by TermsHashPerField to index the contents.
- TermValComparator(int, String, boolean) - Constructor for class org.apache.lucene.search.FieldComparator.TermValComparator
-
Sole constructor.
- TermVectorLeafReader - Class in org.apache.lucene.search.highlight
-
Wraps a Terms with a
LeafReader
, typically from term vectors.
- TermVectorLeafReader(String, Terms) - Constructor for class org.apache.lucene.search.highlight.TermVectorLeafReader
-
- TermVectorOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
Uses term vectors that contain offsets.
- TermVectorOffsetStrategy(UHComponents) - Constructor for class org.apache.lucene.search.uhighlight.TermVectorOffsetStrategy
-
- termVectorsFormat() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- termVectorsFormat() - Method in class org.apache.lucene.codecs.Codec
-
Encodes/decodes term vectors
- termVectorsFormat() - Method in class org.apache.lucene.codecs.compressing.CompressingCodec
-
- termVectorsFormat() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- termVectorsFormat() - Method in class org.apache.lucene.codecs.FilterCodec
-
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene60.Lucene60Codec
-
Deprecated.
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene62.Lucene62Codec
-
- termVectorsFormat() - Method in class org.apache.lucene.codecs.lucene70.Lucene70Codec
-
- termVectorsFormat() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextCodec
-
- TermVectorsFormat - Class in org.apache.lucene.codecs
-
Controls the format of term vectors
- TermVectorsFormat() - Constructor for class org.apache.lucene.codecs.TermVectorsFormat
-
Sole constructor.
- TermVectorsReader - Class in org.apache.lucene.codecs
-
Codec API for reading term vectors:
- TermVectorsReader() - Constructor for class org.apache.lucene.codecs.TermVectorsReader
-
Sole constructor.
- termVectorsReaders - Variable in class org.apache.lucene.index.MergeState
-
Term vector producers being merged
- termVectorStatus - Variable in class org.apache.lucene.index.CheckIndex.Status.SegmentInfoStatus
-
Status for testing of term vectors (null if term vectors could not be tested).
- TermVectorsWriter - Class in org.apache.lucene.codecs
-
- TermVectorsWriter() - Constructor for class org.apache.lucene.codecs.TermVectorsWriter
-
Sole constructor.
- TernaryTree - Class in org.apache.lucene.analysis.compound.hyphenation
-
Ternary Search Tree.
- TernaryTree.Iterator - Class in org.apache.lucene.analysis.compound.hyphenation
-
- TernaryTreeNode - Class in org.apache.lucene.search.suggest.tst
-
The class creates a TST node.
- TernaryTreeNode() - Constructor for class org.apache.lucene.search.suggest.tst.TernaryTreeNode
-
Creates a new empty node
- tessellate(Polygon) - Static method in class org.apache.lucene.geo.Tessellator
-
Produces an array of vertices representing the triangulated result set of the Points array
- Tessellator - Class in org.apache.lucene.geo
-
Computes a triangular mesh tessellation for a given polygon.
- Tessellator.Node - Class in org.apache.lucene.geo
-
Circular Doubly-linked list used for polygon coordinates
- Tessellator.Triangle - Class in org.apache.lucene.geo
-
Triangle in the tessellated mesh
- test(Analyzer) - Method in class org.apache.lucene.analysis.standard.EmojiTokenizationTestUnicode_11_0
-
- test(Analyzer) - Method in class org.apache.lucene.analysis.standard.WordBreakTestUnicode_9_0_0
-
- test(int, int) - Method in class org.apache.lucene.geo.GeoEncodingUtils.DistancePredicate
-
Check whether the given point is within a distance of another point.
- test(int, int) - Method in class org.apache.lucene.geo.GeoEncodingUtils.PolygonPredicate
-
Check whether the given point is within the considered polygon.
- test1Bit() - Method in class org.apache.lucene.util.BaseDocIdSetTestCase
-
Test length=1.
- test2Bits() - Method in class org.apache.lucene.util.BaseDocIdSetTestCase
-
Test length=2.
- TEST_ASSERTS_ENABLED - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- TEST_AWAITSFIX - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- TEST_BADAPPLES - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- TEST_CODEC - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Gets the codec to run tests with.
- TEST_DIRECTORY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Gets the directory to run tests with
- TEST_DOCVALUESFORMAT - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Gets the docValuesFormat to run tests with
- TEST_LINE_DOCS_FILE - Static variable in class org.apache.lucene.util.LuceneTestCase
-
the line file used by LineFileDocs
- TEST_MONSTER - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- TEST_NIGHTLY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- TEST_POSTINGSFORMAT - Static variable in class org.apache.lucene.util.LuceneTestCase
-
Gets the postingsFormat to run tests with.
- TEST_SLOW - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- TEST_THROTTLING - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- TEST_WEEKLY - Static variable in class org.apache.lucene.util.LuceneTestCase
-
- testAddIndexes() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testAddsSelfToFiles() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Tests SI writer adds itself to files...
- testAgainstBitSet() - Method in class org.apache.lucene.util.BaseDocIdSetTestCase
-
Compare the content of the set against a
BitSet
.
- testAllEqual() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testAllLatEqual() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testAllLonEqual() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testAllPointDocsDeletedInSegment() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testAllZeros() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testAskForPositionsWhenNotThere() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testAttributes() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test attributes map
- testBasic() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testBasics() - Method in class org.apache.lucene.store.BaseLockFactoryTestCase
-
Test obtaining and releasing locks, checking validity
- testBigDocuments() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testBigIntNDims() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testBigNumericRange() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBigNumericRange2() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBinaryFieldOffsetLength() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testBinaryFixedLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBinaryMergeAwayAllValuesLargeSegment() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBinaryVariableLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- TestBloomFilteredLucenePostings - Class in org.apache.lucene.codecs.bloom
-
- TestBloomFilteredLucenePostings() - Constructor for class org.apache.lucene.codecs.bloom.TestBloomFilteredLucenePostings
-
- testBooleanNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBoxBasics() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Add a single point and search for it in a box
- testBoxInvalidCoordinates() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testBoxNull() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
null field name not allowed
- testBulkMergeWithDeletes() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testByte() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testByteNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testByteRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBytesMergeAwayAllValues() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBytesTwoDocumentsMerged() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testBytesWithNewline() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testCardinality() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testChecksum() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testChecksumsOnly(Directory) - Method in class org.apache.lucene.index.BaseTestCheckIndex
-
- testChecksumsOnlyVerbose(Directory) - Method in class org.apache.lucene.index.BaseTestCheckIndex
-
- testClear() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testClearRange() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testClone() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testClonedStreamsClosing() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testCodecUsesOwnBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testCodecUsesOwnSortedBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testConcurrentReads() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testCopyBytes() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testCopyBytesWithThreads() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testCopyFrom() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testCorruptFilesAreCaught() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testCreateOutputDisabled() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testCreateOutputForExistingFile() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testCreateTempOutput() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testDateCompression() - Method in class org.apache.lucene.index.BaseCompressingDocValuesFormatTestCase
-
- testDeletedDocs(Directory) - Method in class org.apache.lucene.index.BaseTestCheckIndex
-
- testDeleteFile() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testDeleteFileDisabled() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testDenseLiveDocs() - Method in class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
- testDetectClose() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
Make sure directory throws AlreadyClosedException if
you try to createOutput after closing.
- testDiagnostics() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test diagnostics map
- testDidntWantFreqsButAskedAnyway() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testDirectoryStreamFiltered() - Method in class org.apache.lucene.mockfile.MockFileSystemTestCase
-
Tests that newDirectoryStream with a filter works correctly
- testDirectoryStreamGlobFiltered() - Method in class org.apache.lucene.mockfile.MockFileSystemTestCase
-
Tests that newDirectoryStream with globbing works correctly
- testDistanceBasics() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
test we can search for a point
- testDistanceIllegal() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
distance query should not accept invalid lat/lon as origin
- testDistanceInf() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Inf distance queries are not allowed
- testDistanceNaN() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
NaN distance queries are not allowed
- testDistanceNegative() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
negative distance queries are not allowed
- testDistanceNull() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
null field name not allowed
- testDocsAndFreqs() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testDocsAndFreqsAndPositions() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testDocsAndFreqsAndPositionsAndOffsets() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testDocsAndFreqsAndPositionsAndOffsetsAndPayloads() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testDocsAndFreqsAndPositionsAndPayloads() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testDocsOnly() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testDocValues(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
-
Test docvalues.
- testDocValuesSimple() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testDoubleClose() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testDoubleClose() - Method in class org.apache.lucene.store.BaseLockFactoryTestCase
-
Test closing locks twice
- testDoubleCloseInput() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testDoubleCloseOutput() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testEmpty() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testEmptyBinaryValueOnPageSizes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testEmptyBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testEmptyDocs() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testEmptyFieldAndEmptyTerm() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testEmptyLiveDocs() - Method in class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
- testEmptySortedBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testEquals() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testExceptionOnCloseInput() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Test field infos read that hits exception on close.
- testExceptionOnCloseInput() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test segment infos read that hits exception on close
make sure we get our exception back, no file handle leaks, etc.
- testExceptionOnCloseOutput() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Test field infos write that hits exception on close.
- testExceptionOnCloseOutput() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test segment infos write that hits exception on close.
- testExceptionOnCreateOutput() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Test field infos write that hits exception immediately on open.
- testExceptionOnCreateOutput() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test segment infos write that hits exception immediately on open.
- testExceptionOnOpenInput() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Test field infos read that hits exception immediately on open.
- testExceptionOnOpenInput() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test segment infos read that hits exception immediately on open.
- testFailure(Failure) - Method in class org.apache.lucene.util.FailureMarker
-
- testFailure(Failure) - Method in class org.apache.lucene.util.RunListenerPrintReproduceInfo
-
- testFarsiRangeFilterCollating(Analyzer, BytesRef, BytesRef, BytesRef, BytesRef) - Method in class org.apache.lucene.analysis.CollationTestBase
-
- testFarsiRangeQueryCollating(Analyzer, BytesRef, BytesRef, BytesRef, BytesRef) - Method in class org.apache.lucene.analysis.CollationTestBase
-
- testFarsiTermRangeQuery(Analyzer, BytesRef, BytesRef, BytesRef, BytesRef) - Method in class org.apache.lucene.analysis.CollationTestBase
-
- testFewLargeValues() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testFewSparseLargeValues() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testFewSparseValues() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testFewValues() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testFieldInfos(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
-
Test field infos.
- testFieldNorms(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
-
Test field norms.
- testFields(Fields) - Method in class org.apache.lucene.index.RandomPostingsTester
-
- testFileExistsInListAfterCreated() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
LUCENE-1468: once we create an output, we should see
it in the dir listing.
- testFileNotFound() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testFiles() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test files map
- testFindForcedDeletesMerges() - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
- testFinished(Description) - Method in class org.apache.lucene.util.RunListenerPrintReproduceInfo
-
- testForceMergeNotNeeded() - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
- testFsyncDoesntCreateNewFiles() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testFull(Codec, Path, IndexOptions, boolean) - Method in class org.apache.lucene.index.RandomPostingsTester
-
Indexes all fields/terms at the specified
IndexOptions, and fully tests at that IndexOptions.
- testFullLongRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testGCDCompression() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testGhosts() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testHashCodeEquals() - Method in class org.apache.lucene.mockfile.MockFileSystemTestCase
-
Test that Path.hashcode/equals are sane
- testHighFreqs() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testIllegalEOF() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testImmutableAttributes() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Test field infos attributes coming back are not mutable
- testIndexedBit() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testIndexExtremeValues() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Valid values that should not cause exception
- testIndexInfValues() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Inf: illegal
- testIndexNaNValues() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
NaN: illegal
- testIndexOutOfRangeValues() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Invalid values
- testIndexOutputToString() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testInt() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testIntNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testInvalidAfterClose() - Method in class org.apache.lucene.store.BaseLockFactoryTestCase
-
Test ensureValid throws exception after close
- testInvertedWrite() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testJustEmptyField() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testLargeCFS() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testLargeWrites() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
This test that writes larger than the size of the buffer output
will correctly increment the file pointer.
- testLevel2Ghosts() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testListAll() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testListAllIsSorted() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testLiveDocs(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
-
Test live docs.
- testLong() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testLongNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testLongRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testLotsOfFields() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testMakeLockDisabled() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testManySubFiles() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testMapOfStrings() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testMerge() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testMerge() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testMergeFilterReader() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testMergeStability() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testMergeStability() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testMismatchedFields() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
mix up field numbers, merge, and check that data is correct
- testMissingCodecHeadersAreCaught() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testMissingSortedBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testMixedOptions() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testMixedSchema() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testMostZeros() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testMultiPolygonBasics() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
test we can search for a multi-polygon
- testMultiValued() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testMultiValued() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testMultiValued() - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- testNCommon() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testNCommonBig() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
a more thorough n-common that tests all low bpv
- testNextSetBit() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testNoBit() - Method in class org.apache.lucene.util.BaseDocIdSetTestCase
-
Test length=0.
- testNoDir() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testNumberMergeAwayAllValues() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testNumericField() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testNumericMergeAwayAllValuesLargeSegment() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testObtainConcurrently() - Method in class org.apache.lucene.store.BaseLockFactoryTestCase
-
- testObtainsLock(Directory) - Method in class org.apache.lucene.index.BaseTestCheckIndex
-
- testOneDimEqual() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testOneDimTwoValues() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testOneField() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Test field infos read/write with a single field
- testOneFloat() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testOneNumber() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testOneSortedNumber() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testOneSortedNumberOneMissing() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testOrDense() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testOrRandom() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testOrSparse() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testOutliers() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testOutliers2() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testOverflow() - Method in class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
- testPassIOContext() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testPendingDeletions() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testPoints(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
-
Test the points index
- testPolygonBasics() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
test we can search for a polygon
- testPolygonHole() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
test we can search for a polygon with a hole (but still includes the doc)
- testPolygonHoleExcludes() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
test we can search for a polygon with a hole (that excludes the doc)
- testPolygonNullField() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
null field name not allowed
- testPostings(CodecReader, PrintStream, Version) - Static method in class org.apache.lucene.index.CheckIndex
-
Test the term index.
- testPostings(CodecReader, PrintStream, boolean, boolean, Version) - Static method in class org.apache.lucene.index.CheckIndex
-
Test the term index.
- testPostingsEnumAll() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testPostingsEnumAll() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testPostingsEnumDocsOnly() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testPostingsEnumFreqs() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testPostingsEnumFreqs() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testPostingsEnumOffsets() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testPostingsEnumOffsets() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testPostingsEnumOffsetsWithoutPositions() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testPostingsEnumPayloads() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testPostingsEnumPayloads() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testPostingsEnumPositions() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testPostingsEnumPositions() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testPostingsEnumReuse() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testPrevSetBit() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testRamBytesUsed() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
- testRamBytesUsed() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
- testRamBytesUsed() - Method in class org.apache.lucene.util.BaseDocIdSetTestCase
-
Test ram usage estimation.
- testRandom() - Method in class org.apache.lucene.index.BaseFieldInfoFormatTestCase
-
Test field infos read/write with random fields, with different values.
- testRandom() - Method in class org.apache.lucene.index.BasePostingsFormatTestCase
-
- testRandom() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Sets some otherwise hard-to-test properties:
random segment names, ID values, document count, etc and round-trips
- testRandom() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testRandomAccess() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
This test opens two files from a compound stream and verifies that
their file positions are independent of each other.
- testRandomAccessClones() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
This test opens two files from a compound stream and verifies that
their file positions are independent of each other.
- testRandomAdvanceBinary() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testRandomAdvanceNumeric() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testRandomBig() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testRandomBig() - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- testRandomBinaryBig() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testRandomBinaryMedium() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testRandomBinaryTiny() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
- testRandomByte() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testRandomDistance() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Run a few iterations with just 10 docs, hopefully easy to debug
- testRandomDistanceHuge() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Runs with thousands of docs
- testRandomFiles() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
This test creates a compound file based on a large number of files of
various length.
- testRandomInt() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testRandomLong() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testRandomMedium() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testRandomMedium() - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- testRandomShort() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testRandomSortedBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testRandomStoredFields() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testRandomTiny() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testRandomTiny() - Method in class org.apache.lucene.search.BaseRangeFieldQueryTestCase
-
- testRareVectors() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase
-
- testReadPastEOF() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testReadSkip() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testRectBoundariesAreInclusive() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testRename() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testRenameFileDisabled() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testResourceNameInsideCompoundFile() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- TestRuleAssertionsRequired - Class in org.apache.lucene.util
-
Require assertions for Lucene/Solr packages.
- TestRuleAssertionsRequired() - Constructor for class org.apache.lucene.util.TestRuleAssertionsRequired
-
- TestRuleIgnoreAfterMaxFailures - Class in org.apache.lucene.util
-
This rule keeps a count of failed tests (suites) and will result in an
AssumptionViolatedException
after a given number of failures for all
tests following this condition.
- TestRuleIgnoreAfterMaxFailures(int) - Constructor for class org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures
-
- TestRuleIgnoreTestSuites - Class in org.apache.lucene.util
-
This rule will cause the suite to be assumption-ignored if
the test class implements a given marker interface and a special
property is not set.
- TestRuleIgnoreTestSuites() - Constructor for class org.apache.lucene.util.TestRuleIgnoreTestSuites
-
- TestRuleIgnoreTestSuites.NestedTestSuite - Interface in org.apache.lucene.util
-
Marker interface for nested suites that should be ignored
if executed in stand-alone mode.
- TestRuleLimitSysouts - Class in org.apache.lucene.util
-
Fails the suite if it prints over the given limit of bytes to either
System.out
or
System.err
,
unless the condition is not enforced (see
TestRuleLimitSysouts.isEnforced()
).
- TestRuleLimitSysouts(TestRuleMarkFailure) - Constructor for class org.apache.lucene.util.TestRuleLimitSysouts
-
- TestRuleLimitSysouts.Limit - Annotation Type in org.apache.lucene.util
-
An annotation specifying the limit of bytes per class.
- TestRuleMarkFailure - Class in org.apache.lucene.util
-
A rule for marking failed tests and suites.
- TestRuleMarkFailure(TestRuleMarkFailure...) - Constructor for class org.apache.lucene.util.TestRuleMarkFailure
-
- TestRuleRestoreSystemProperties - Class in org.apache.lucene.util
-
Restore a given set of system properties to a snapshot taken at the beginning
of the rule.
- TestRuleRestoreSystemProperties(String...) - Constructor for class org.apache.lucene.util.TestRuleRestoreSystemProperties
-
- TestRuleStoreClassName - Class in org.apache.lucene.util
-
- TestRuleStoreClassName() - Constructor for class org.apache.lucene.util.TestRuleStoreClassName
-
- testRunFinished(Result) - Method in class org.apache.lucene.util.RunListenerPrintReproduceInfo
-
- testRunStarted(Description) - Method in class org.apache.lucene.util.RunListenerPrintReproduceInfo
-
- testSamePointManyTimes() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- TestSecurityManager - Class in org.apache.lucene.util
-
A SecurityManager
that prevents tests calling System.exit(int)
.
- TestSecurityManager() - Constructor for class org.apache.lucene.util.TestSecurityManager
-
Creates a new TestSecurityManager.
- testSeekBeyondEndOfFile() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testSeekPastEOF() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testSeekToEndOfFile() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testSeekToEOFThenBack() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testSet() - Method in class org.apache.lucene.util.BaseBitSetTestCase
-
- testSetOfStrings() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testShort() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testShortNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testShortRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSimulateAppendOnly() - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Simulate an append-only use-case, ie.
- testSimulateUpdates() - Method in class org.apache.lucene.index.BaseMergePolicyTestCase
-
Simulate an update use-case where documents are uniformly updated across segments.
- testSingleBigValueCompression() - Method in class org.apache.lucene.index.BaseCompressingDocValuesFormatTestCase
-
- testSingleFile() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
This test creates compound file based on a single file.
- testSliceOfSlice() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
try to stress slices of slices
- testSliceOutOfBounds() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testSmallSetDateline() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetDistance() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetDistanceDateline() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetDistanceNotEmpty() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
see https://issues.apache.org/jira/browse/LUCENE-6905
- testSmallSetHugeDistance() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
Explicitly large
- testSmallSetMultiValued() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetPoly() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetPolyWholeMap() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetRect() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetTinyDistance() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSmallSetWholeMap() - Method in class org.apache.lucene.geo.BaseGeoPointTestCase
-
- testSort() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test sort
- testSort(CodecReader, Sort, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
-
Tests index sort order.
- testSortedBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedBytesThreeDocuments() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedBytesTwoDocuments() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedBytesTwoDocumentsMerged() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedEnumAdvanceIndependently() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedFixedLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedMergeAwayAllValues() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedMergeAwayAllValuesLargeSegment() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedNumberMerge() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedNumberMergeAwayAllValues() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedNumericMergeAwayAllValuesLargeSegment() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedNumericsFewUniqueSetsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedNumericsMultipleValuesVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedNumericsSingleValuedMissingVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedNumericsSingleValuedVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetEnumAdvanceIndependently() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetFixedLengthFewUniqueSetsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetFixedLengthManyValuesPerDocVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetFixedLengthSingleValuedVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetFixedLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetMergeAwayAllValues() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetMergeAwayAllValuesLargeSegment() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetOneValue() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTermsEnum() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetThreeValuesTwoDocs() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoDocumentsFirstMissing() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoDocumentsFirstMissingMerge() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoDocumentsLastMissing() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoDocumentsLastMissingMerge() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoDocumentsMerged() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoValues() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetTwoValuesUnordered() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetVariableLengthFewUniqueSetsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetVariableLengthManyValuesPerDocVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetVariableLengthSingleValuedVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedSetVariableLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedTermsEnum() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSortedVariableLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseAllZeros() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseBinaryFixedLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseBinaryVariableLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseBooleanNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseByteNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseByteRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseFullLongRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseGCDCompression() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseIntNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseLiveDocs() - Method in class org.apache.lucene.index.BaseLiveDocsFormatTestCase
-
- testSparseLongNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseLongRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseNCommon() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseNCommonBig() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
a more thorough n-common that tests all low bpv and sparse docs
- testSparseOutliers() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseOutliers2() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseShortNumericsVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseShortRange() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testSparseSortedFixedLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseSortedVariableLengthVsStoredFields() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testSparseZeros() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testStarted(Description) - Method in class org.apache.lucene.util.RunListenerPrintReproduceInfo
-
- testStoredFields(CodecReader, PrintStream, boolean) - Static method in class org.apache.lucene.index.CheckIndex
-
Test stored fields.
- testStoredFieldsOrder() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testStressLocks() - Method in class org.apache.lucene.store.BaseLockFactoryTestCase
-
- testString() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testSyncDisabled() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
- testTerms(Fields, EnumSet<RandomPostingsTester.Option>, IndexOptions, IndexOptions, boolean) - Method in class org.apache.lucene.index.RandomPostingsTester
-
- testTermVectors(CodecReader, PrintStream, Version) - Static method in class org.apache.lucene.index.CheckIndex
-
Test term vectors.
- testTermVectors(CodecReader, PrintStream, boolean, boolean, boolean, Version) - Static method in class org.apache.lucene.index.CheckIndex
-
Test term vectors.
- testThreads() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
Tests dv against stored fields with threads (binary/numeric/sorted, no missing)
- testThreads() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testThreads2() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
Tests dv against stored fields with threads (all types + missing)
- testThreads3() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testThreadSafetyInListAll() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testThreeBytesOneMissingWithMerging() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testThreeFieldsMixed() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testThreeFieldsMixed2() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testThreeNumbersOneMissingWithMerging() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoBinaryValues() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoBytesOneMissing() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoBytesOneMissingWithMerging() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoDocumentsMerged() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoDocumentsNumeric() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoFieldsMixed() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoFiles() - Method in class org.apache.lucene.index.BaseCompoundFormatTestCase
-
This test creates compound file based on two files.
- testTwoNumbers() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoNumbersOneMissing() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoNumbersOneMissingWithMerging() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoSortedNumber() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoSortedNumberOneMissing() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testTwoSortedNumberSameValue() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testUndeadNorms() - Method in class org.apache.lucene.index.BaseNormsFormatTestCase
-
- testUniqueID() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test unique ID
- testUniqueValuesCompression() - Method in class org.apache.lucene.index.BaseCompressingDocValuesFormatTestCase
-
- testURI() - Method in class org.apache.lucene.mockfile.MockFileSystemTestCase
-
Test that URIs are not corrumpted
- testURIchinese() - Method in class org.apache.lucene.mockfile.MockFileSystemTestCase
-
- testURIumlaute() - Method in class org.apache.lucene.mockfile.MockFileSystemTestCase
-
- TestUtil - Class in org.apache.lucene.util
-
General utility methods for Lucene unit tests.
- testValidAfterAcquire() - Method in class org.apache.lucene.store.BaseLockFactoryTestCase
-
Test ensureValid returns true after acquire
- testVersions() - Method in class org.apache.lucene.index.BaseSegmentInfoFormatTestCase
-
Test versions
- testVeryLargeButLegalBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testVeryLargeButLegalSortedBytes() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testVInt() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testVLong() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testWithExceptions() - Method in class org.apache.lucene.index.BasePointsFormatTestCase
-
Make sure we close open files, delete temp files, etc., on exception
- testWriteReadMerge() - Method in class org.apache.lucene.index.BaseStoredFieldsFormatTestCase
-
- testZeroOrMin() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testZeros() - Method in class org.apache.lucene.index.BaseDocValuesFormatTestCase
-
- testZInt() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- testZLong() - Method in class org.apache.lucene.store.BaseDirectoryTestCase
-
- text - Variable in class org.apache.lucene.expressions.js.VariableContext
-
The text of this piece of the variable.
- text() - Method in class org.apache.lucene.index.Term
-
Returns the text of this term.
- text - Variable in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
The term's text.
- TEXT_FIELD_NAME - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
Field name used for the indexed text.
- TextableQueryNode - Interface in org.apache.lucene.queryparser.flexible.core.nodes
-
Interface for a node that has text as a CharSequence
- TextField - Class in org.apache.lucene.document
-
A field that is indexed and tokenized, without term
vectors.
- TextField(String, Reader) - Constructor for class org.apache.lucene.document.TextField
-
Creates a new un-stored TextField with Reader value.
- TextField(String, String, Field.Store) - Constructor for class org.apache.lucene.document.TextField
-
Creates a new TextField with String value.
- TextField(String, TokenStream) - Constructor for class org.apache.lucene.document.TextField
-
Creates a new un-stored TextField with TokenStream value.
- textFieldNames - Variable in class org.apache.lucene.classification.KNearestNeighborClassifier
-
the name of the fields used as the input text
- textFieldNames - Variable in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
names of the fields to be used as input text
- TextFragment - Class in org.apache.lucene.search.highlight
-
Low-level class used to record information about a section of a document
with a score.
- TextFragment(CharSequence, int, int) - Constructor for class org.apache.lucene.search.highlight.TextFragment
-
- TEXTGRAMS_FIELD_NAME - Static variable in class org.apache.lucene.search.suggest.analyzing.AnalyzingInfixSuggester
-
- textToBytesRef() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- tf(float) - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
Delegates to baselineTf
- tf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Axiomatic
-
compute the term frequency component
- tf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
compute the term frequency component
- tf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
compute the term frequency component
- tf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
compute the term frequency component
- tf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
compute the term frequency component
- tf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
compute the term frequency component
- tf(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
-
compute the term frequency component
- tf(float) - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
-
Implemented as sqrt(freq)
.
- tf(float) - Method in class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Computes a score factor based on a term or phrase's frequency in a
document.
- tf(int, int) - Method in class org.apache.lucene.search.uhighlight.PassageScorer
-
Computes term weight, given the frequency within the passage
and the passage's length.
- TFIDFSimilarity - Class in org.apache.lucene.search.similarities
-
Implementation of
Similarity
with the Vector Space Model.
- TFIDFSimilarity() - Constructor for class org.apache.lucene.search.similarities.TFIDFSimilarity
-
Sole constructor.
- tfln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Axiomatic
-
compute the mixed term frequency and document length component
- tfln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
compute the mixed term frequency and document length component
- tfln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
compute the mixed term frequency and document length component
- tfln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
compute the mixed term frequency and document length component
- tfln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
compute the mixed term frequency and document length component
- tfln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
compute the mixed term frequency and document length component
- tfln(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
-
compute the mixed term frequency and document length component
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
-
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.Normalization
-
Returns the normalized term frequency.
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationH1
-
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationH2
-
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationH3
-
- tfn(BasicStats, float, float) - Method in class org.apache.lucene.search.similarities.NormalizationZ
-
- TFValueSource - Class in org.apache.lucene.queries.function.valuesource
-
- TFValueSource(String, String, String, BytesRef) - Constructor for class org.apache.lucene.queries.function.valuesource.TFValueSource
-
- ThaiAnalyzer - Class in org.apache.lucene.analysis.th
-
- ThaiAnalyzer() - Constructor for class org.apache.lucene.analysis.th.ThaiAnalyzer
-
Builds an analyzer with the default stop words.
- ThaiAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.th.ThaiAnalyzer
-
Builds an analyzer with the given stop words.
- ThaiTokenizer - Class in org.apache.lucene.analysis.th
-
Tokenizer that use BreakIterator
to tokenize Thai text.
- ThaiTokenizer() - Constructor for class org.apache.lucene.analysis.th.ThaiTokenizer
-
Creates a new ThaiTokenizer
- ThaiTokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.th.ThaiTokenizer
-
Creates a new ThaiTokenizer, supplying the AttributeFactory
- ThaiTokenizerFactory - Class in org.apache.lucene.analysis.th
-
- ThaiTokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.th.ThaiTokenizerFactory
-
Creates a new ThaiTokenizerFactory
- thisCell - Variable in class org.apache.lucene.spatial.prefix.tree.CellIterator
-
- thisCell() - Method in class org.apache.lucene.spatial.prefix.tree.CellIterator
-
- THREAD_NAME - Static variable in class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
- ThreadedIndexingAndSearchingTestCase - Class in org.apache.lucene.index
-
Utility class that spawns multiple indexing and
searching threads.
- ThreadedIndexingAndSearchingTestCase() - Constructor for class org.apache.lucene.index.ThreadedIndexingAndSearchingTestCase
-
- ThreadInterruptedException - Exception in org.apache.lucene.util
-
Thrown by lucene on detecting that Thread.interrupt() had
been called.
- ThreadInterruptedException(InterruptedException) - Constructor for exception org.apache.lucene.util.ThreadInterruptedException
-
- ThrottledIndexOutput - Class in org.apache.lucene.util
-
Intentionally slow IndexOutput for testing.
- ThrottledIndexOutput(int, long, IndexOutput) - Constructor for class org.apache.lucene.util.ThrottledIndexOutput
-
- ThrottledIndexOutput(int, long, int, IndexOutput) - Constructor for class org.apache.lucene.util.ThrottledIndexOutput
-
- ThrottledIndexOutput(int, long, long, long, long, IndexOutput) - Constructor for class org.apache.lucene.util.ThrottledIndexOutput
-
- throwExcAfterChar(int) - Method in class org.apache.lucene.analysis.MockReaderWrapper
-
Throw an exception after reading this many chars.
- throwExcNext() - Method in class org.apache.lucene.analysis.MockReaderWrapper
-
- throwKnownError(HttpResponse, StatusLine) - Method in class org.apache.lucene.replicator.http.HttpClientBase
-
- TieredMergePolicy - Class in org.apache.lucene.index
-
Merges segments of approximately equal size, subject to
an allowed number of segments per tier.
- TieredMergePolicy() - Constructor for class org.apache.lucene.index.TieredMergePolicy
-
Sole constructor, setting all settings to their
defaults.
- TieredMergePolicy.MergeScore - Class in org.apache.lucene.index
-
Holds score and explanation for a single candidate
merge.
- TIME_SEC_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- TimeLimitingCollector - Class in org.apache.lucene.search
-
The
TimeLimitingCollector
is used to timeout search requests that
take longer than the maximum allowed search time limit.
- TimeLimitingCollector(Collector, Counter, long) - Constructor for class org.apache.lucene.search.TimeLimitingCollector
-
Create a TimeLimitedCollector wrapper over another
Collector
with a specified timeout.
- TimeLimitingCollector.TimeExceededException - Exception in org.apache.lucene.search
-
Thrown when elapsed search time exceeds allowed search time.
- TimeLimitingCollector.TimerThread - Class in org.apache.lucene.search
-
Thread used to timeout search requests.
- TimerThread(long, Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
- TimerThread(Counter) - Constructor for class org.apache.lucene.search.TimeLimitingCollector.TimerThread
-
- timeToString(long, DateTools.Resolution) - Static method in class org.apache.lucene.document.DateTools
-
Converts a millisecond time to a string suitable for indexing.
- TimeUnits - Class in org.apache.lucene.util
-
time unit constants for use in annotations.
- TIMEZONE - Static variable in class org.apache.lucene.queryparser.flexible.standard.config.StandardQueryConfigHandler.ConfigurationKeys
-
- timSort(T[], int, int, Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice using the Comparator
.
- timSort(T[], Comparator<? super T>) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array using the Comparator
.
- timSort(T[], int, int) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array slice in natural order.
- timSort(T[]) - Static method in class org.apache.lucene.util.ArrayUtil
-
Sorts the given array in natural order.
- timSort(List<T>, Comparator<? super T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access List
using the Comparator
.
- timSort(List<T>) - Static method in class org.apache.lucene.util.CollectionUtil
-
Sorts the given random access List
in natural order.
- TimSorter - Class in org.apache.lucene.util
-
- TimSorter(int) - Constructor for class org.apache.lucene.util.TimSorter
-
- title - Variable in class org.apache.lucene.benchmark.byTask.feeds.DemoHTMLParser.Parser
-
- TITLE_FIELD - Static variable in class org.apache.lucene.benchmark.byTask.feeds.DocMaker
-
- tmpName - Variable in class org.apache.lucene.replicator.nrt.CopyOneFile
-
- TO_DEGREES - Static variable in class org.apache.lucene.util.SloppyMath
-
- TO_RADIANS - Static variable in class org.apache.lucene.util.SloppyMath
-
- toAbsolutePath() - Method in class org.apache.lucene.mockfile.FilterPath
-
- toAggregationForm(double) - Method in interface org.apache.lucene.spatial3d.geom.DistanceStyle
-
Convert a distance to a form meant for aggregation.
- toAggregationForm(double) - Method in class org.apache.lucene.spatial3d.geom.LinearSquaredDistance
-
- toAggregationForm(double) - Method in class org.apache.lucene.spatial3d.geom.NormalSquaredDistance
-
- toArray(T[]) - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- toArray() - Method in class org.apache.lucene.queryparser.flexible.core.processors.QueryNodeProcessorPipeline
-
- toArrayCopy() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
Return a contiguous array with the current content written to the output.
- toAutomaton() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
Converts the tokenStream to an automaton, treating the transition labels as utf-8.
- toAutomaton(boolean) - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter
-
Converts the tokenStream to an automaton.
- toAutomaton(TokenStream) - Method in class org.apache.lucene.analysis.TokenStreamToAutomaton
-
Pulls the graph (including
PositionLengthAttribute
) from the provided
TokenStream
, and creates the corresponding
automaton where arcs are bytes (or Unicode code points
if unicodeArcs = true) from each term.
- toAutomaton(BytesRef) - Static method in class org.apache.lucene.search.PrefixQuery
-
Build an automaton accepting all terms with the specified prefix.
- toAutomaton() - Method in class org.apache.lucene.search.suggest.document.CompletionTokenStream
-
Delegates to...At
- toAutomaton(boolean) - Method in class org.apache.lucene.search.suggest.document.CompletionTokenStream
-
Delegates to...
- toAutomaton(BytesRef, BytesRef, boolean, boolean) - Static method in class org.apache.lucene.search.TermRangeQuery
-
- toAutomaton(Term) - Static method in class org.apache.lucene.search.WildcardQuery
-
Convert Lucene wildcard syntax into an automaton.
- toAutomaton(int) - Method in class org.apache.lucene.util.automaton.LevenshteinAutomata
-
Compute a DFA that accepts all strings within an edit distance of n
.
- toAutomaton(int, String) - Method in class org.apache.lucene.util.automaton.LevenshteinAutomata
-
Compute a DFA that accepts all strings within an edit distance of n
,
matching the specified exact prefix.
- toAutomaton() - Method in class org.apache.lucene.util.automaton.RegExp
-
Constructs new Automaton
from this RegExp
.
- toAutomaton(int) - Method in class org.apache.lucene.util.automaton.RegExp
-
Constructs new Automaton
from this RegExp
.
- toAutomaton(AutomatonProvider, int) - Method in class org.apache.lucene.util.automaton.RegExp
-
Constructs new Automaton
from this RegExp
.
- toAutomaton(Map<String, Automaton>, int) - Method in class org.apache.lucene.util.automaton.RegExp
-
Constructs new Automaton
from this RegExp
.
- toBufferList() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
Return a list of read-only view of ByteBuffer
blocks over the
current content written to the output.
- toBytesRef() - Method in class org.apache.lucene.util.BytesRefBuilder
-
Build a new
BytesRef
that has the same content as this buffer.
- toBytesRef(IntsRef, BytesRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
-
Just converts IntsRef to BytesRef; you must ensure the
int values fit into a byte.
- toCalendar(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
- toCharArray() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- toChars(int[], int, int, char[], int) - Static method in class org.apache.lucene.analysis.CharacterUtils
-
Converts a sequence of unicode code points to a sequence of Java characters.
- toCharsRef() - Method in class org.apache.lucene.util.CharsRefBuilder
-
Build a new
CharsRef
that has the same content as this builder.
- ToChildBlockJoinQuery - Class in org.apache.lucene.search.join
-
Just like
ToParentBlockJoinQuery
, except this
query joins in reverse: you provide a Query matching
parent documents and it joins down to child
documents.
- ToChildBlockJoinQuery(Query, BitSetProducer) - Constructor for class org.apache.lucene.search.join.ToChildBlockJoinQuery
-
Create a ToChildBlockJoinQuery.
- toCodePoints(char[], int, int, int[], int) - Static method in class org.apache.lucene.analysis.CharacterUtils
-
Converts a sequence of Java characters to a sequence of unicode code points.
- toCopy - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- toDataInput() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
- toDegrees(double) - Static method in class org.apache.lucene.util.SloppyMath
-
Convert to degrees.
- toDelegate(Path) - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- toDelegate(Path) - Method in class org.apache.lucene.mockfile.FilterPath
-
Override this to customize the unboxing of Path
from various operations
- toDenseLocalFreqDoubleArray(Terms) - Static method in class org.apache.lucene.classification.utils.DocToDoubleVectorUtils
-
create a dense Double
vector given doc and field term vectors using local frequency of the terms in the doc
- toDigitString() - Method in enum org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode.Modifier
-
- toDocument() - Method in class org.apache.lucene.index.BaseTermVectorsFormatTestCase.RandomDocument
-
- toDot(Analyzer, String) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- toDot() - Method in class org.apache.lucene.analysis.TokenStreamToDot
-
- toDot() - Method in class org.apache.lucene.search.TermAutomatonQuery
-
Returns the dot (graphviz) representation of this automaton.
- toDot() - Method in class org.apache.lucene.util.automaton.Automaton
-
Returns the dot (graphviz) representation of this automaton.
- toDot(FST<T>, Writer, boolean, boolean) - Static method in class org.apache.lucene.util.fst.Util
-
Dumps an
FST
to a GraphViz's
dot
language description
for visualization.
- toDotFile(Analyzer, String, String) - Method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
- toDoubleValuesSource() - Method in class org.apache.lucene.search.LongValuesSource
-
Convert to a DoubleValuesSource by casting long values to doubles
- Toffs(int, int) - Constructor for class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
-
- toFile() - Method in class org.apache.lucene.mockfile.FilterPath
-
- toGeoJSON() - Method in class org.apache.lucene.geo.Line
-
prints polygons as geojson
- toGeoJSON() - Method in class org.apache.lucene.geo.Polygon
-
prints polygons as geojson
- toHexString(String) - Static method in class org.apache.lucene.util.UnicodeUtil
-
- toIntsRef(BytesRef, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
-
Just takes unsigned byte values from the BytesRef and
converts into an IntsRef.
- toIntsRef() - Method in class org.apache.lucene.util.IntsRefBuilder
-
Build a new
CharsRef
that has the same content as this builder.
- toIter(BitSet) - Static method in class org.apache.lucene.search.join.BlockJoinSelector
-
creates an iterator for the given bitset
- Token - Class in org.apache.lucene.analysis.ja
-
Analyzed token with morphological data from its dictionary.
- Token(int, char[], int, int, JapaneseTokenizer.Type, int, Dictionary) - Constructor for class org.apache.lucene.analysis.ja.Token
-
- Token - Class in org.apache.lucene.analysis.ko
-
Analyzed token with morphological data.
- Token(char[], int, int, int, int) - Constructor for class org.apache.lucene.analysis.ko.Token
-
- Token - Class in org.apache.lucene.analysis
-
A Token is an occurrence of a term from the text of a field.
- Token() - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token will null text.
- Token(CharSequence, int, int) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with the given term text, start
and end offsets.
- Token(CharSequence, int, int, int) - Constructor for class org.apache.lucene.analysis.Token
-
Constructs a Token with the given term text, position increment, start and end offsets
- token - Variable in class org.apache.lucene.queryparser.classic.QueryParser
-
Current token.
- Token - Class in org.apache.lucene.queryparser.classic
-
Describes the input token stream.
- Token() - Constructor for class org.apache.lucene.queryparser.classic.Token
-
No-argument constructor
- Token(int) - Constructor for class org.apache.lucene.queryparser.classic.Token
-
Constructs a new token for the specified Image.
- Token(int, String) - Constructor for class org.apache.lucene.queryparser.classic.Token
-
Constructs a new token for the specified Image and Kind.
- token - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Current token.
- Token - Class in org.apache.lucene.queryparser.flexible.standard.parser
-
Describes the input token stream.
- Token() - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
No-argument constructor
- Token(int) - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
Constructs a new token for the specified Image.
- Token(int, String) - Constructor for class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
Constructs a new token for the specified Image and Kind.
- token - Variable in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
Current token.
- Token - Class in org.apache.lucene.queryparser.surround.parser
-
Describes the input token stream.
- Token() - Constructor for class org.apache.lucene.queryparser.surround.parser.Token
-
No-argument constructor
- Token(int) - Constructor for class org.apache.lucene.queryparser.surround.parser.Token
-
Constructs a new token for the specified Image.
- Token(int, String) - Constructor for class org.apache.lucene.queryparser.surround.parser.Token
-
Constructs a new token for the specified Image and Kind.
- TOKEN_ATTRIBUTE_FACTORY - Static variable in class org.apache.lucene.analysis.Token
-
Convenience factory that returns Token
as implementation for the basic
attributes and return the default impl (with "Impl" appended) for all other
attributes.
- TOKEN_OUTPUT - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizerFactory
-
- token_source - Variable in class org.apache.lucene.queryparser.classic.QueryParser
-
Generated Token Manager.
- token_source - Variable in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
Generated Token Manager.
- token_source - Variable in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
Generated Token Manager.
- TOKEN_TYPES - Static variable in class org.apache.lucene.analysis.standard.ClassicTokenizer
-
String token types that correspond to token type int constants
- TOKEN_TYPES - Static variable in class org.apache.lucene.analysis.standard.StandardTokenizer
-
String token types that correspond to token type int constants
- TOKEN_TYPES - Static variable in class org.apache.lucene.analysis.standard.UAX29URLEmailTokenizer
-
String token types that correspond to token type int constants
- TOKEN_TYPES - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
String token types that correspond to token type int constants
- TokenFilter - Class in org.apache.lucene.analysis
-
A TokenFilter is a TokenStream whose input is another TokenStream.
- TokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.TokenFilter
-
Construct a token stream filtering the given input.
- TokenFilterFactory - Class in org.apache.lucene.analysis.util
-
Abstract parent class for analysis factories that create
TokenFilter
instances.
- TokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.util.TokenFilterFactory
-
Initialize this factory via a set of key-value pairs.
- TokenGroup - Class in org.apache.lucene.search.highlight
-
One, or several overlapping tokens, along with the score(s) and the scope of
the original text.
- TokenGroup(TokenStream) - Constructor for class org.apache.lucene.search.highlight.TokenGroup
-
- tokenImage - Variable in exception org.apache.lucene.queryparser.classic.ParseException
-
This is a reference to the "tokenImage" array of the generated
parser within which the parse error occurred.
- tokenImage - Static variable in interface org.apache.lucene.queryparser.classic.QueryParserConstants
-
Literal token values.
- tokenImage - Variable in exception org.apache.lucene.queryparser.flexible.standard.parser.ParseException
-
This is a reference to the "tokenImage" array of the generated
parser within which the parse error occurred.
- tokenImage - Static variable in interface org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParserConstants
-
Literal token values.
- tokenImage - Variable in exception org.apache.lucene.queryparser.surround.parser.ParseException
-
This is a reference to the "tokenImage" array of the generated
parser within which the parse error occurred.
- tokenImage - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
Literal token values.
- TokenInfoDictionary - Class in org.apache.lucene.analysis.ja.dict
-
Binary dictionary implementation for a known-word dictionary model:
Words are encoded into an FST mapping to a list of wordIDs.
- TokenInfoDictionary - Class in org.apache.lucene.analysis.ko.dict
-
Binary dictionary implementation for a known-word dictionary model:
Words are encoded into an FST mapping to a list of wordIDs.
- TokenInfoFST - Class in org.apache.lucene.analysis.ja.dict
-
Thin wrapper around an FST with root-arc caching for Japanese.
- TokenInfoFST(FST<Long>, boolean) - Constructor for class org.apache.lucene.analysis.ja.dict.TokenInfoFST
-
- TokenInfoFST - Class in org.apache.lucene.analysis.ko.dict
-
Thin wrapper around an FST with root-arc caching for Hangul syllables (11,172 arcs).
- TokenInfoFST(FST<Long>) - Constructor for class org.apache.lucene.analysis.ko.dict.TokenInfoFST
-
- tokenize(String) - Method in class org.apache.lucene.classification.SimpleNaiveBayesClassifier
-
tokenize a String
on this classifier's text fields and analyzer
- tokenized() - Method in class org.apache.lucene.document.FieldType
-
True if this field's value should be analyzed by the
Analyzer
.
- tokenized() - Method in interface org.apache.lucene.index.IndexableFieldType
-
True if this field's value should be analyzed by the
Analyzer
.
- TokenizedPhraseQueryNode - Class in org.apache.lucene.queryparser.flexible.core.nodes
-
- TokenizedPhraseQueryNode() - Constructor for class org.apache.lucene.queryparser.flexible.core.nodes.TokenizedPhraseQueryNode
-
- Tokenizer - Class in org.apache.lucene.analysis
-
A Tokenizer is a TokenStream whose input is a Reader.
- Tokenizer() - Constructor for class org.apache.lucene.analysis.Tokenizer
-
- Tokenizer(AttributeFactory) - Constructor for class org.apache.lucene.analysis.Tokenizer
-
- TokenizerFactory - Class in org.apache.lucene.analysis.util
-
Abstract parent class for analysis factories that create
Tokenizer
instances.
- TokenizerFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.util.TokenizerFactory
-
Initialize this factory via a set of key-value pairs.
- TokenMgrError - Error in org.apache.lucene.queryparser.classic
-
Token Manager Error.
- TokenMgrError() - Constructor for error org.apache.lucene.queryparser.classic.TokenMgrError
-
No arg constructor.
- TokenMgrError(String, int) - Constructor for error org.apache.lucene.queryparser.classic.TokenMgrError
-
Constructor with message and reason.
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.lucene.queryparser.classic.TokenMgrError
-
Full Constructor.
- TokenMgrError - Error in org.apache.lucene.queryparser.flexible.standard.parser
-
Token Manager Error.
- TokenMgrError() - Constructor for error org.apache.lucene.queryparser.flexible.standard.parser.TokenMgrError
-
No arg constructor.
- TokenMgrError(String, int) - Constructor for error org.apache.lucene.queryparser.flexible.standard.parser.TokenMgrError
-
Constructor with message and reason.
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.lucene.queryparser.flexible.standard.parser.TokenMgrError
-
Full Constructor.
- TokenMgrError - Error in org.apache.lucene.queryparser.surround.parser
-
Token Manager Error.
- TokenMgrError() - Constructor for error org.apache.lucene.queryparser.surround.parser.TokenMgrError
-
No arg constructor.
- TokenMgrError(String, int) - Constructor for error org.apache.lucene.queryparser.surround.parser.TokenMgrError
-
Constructor with message and reason.
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.lucene.queryparser.surround.parser.TokenMgrError
-
Full Constructor.
- TokenOffsetPayloadTokenFilter - Class in org.apache.lucene.analysis.payloads
-
- TokenOffsetPayloadTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.payloads.TokenOffsetPayloadTokenFilter
-
- TokenOffsetPayloadTokenFilterFactory - Class in org.apache.lucene.analysis.payloads
-
- TokenOffsetPayloadTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.payloads.TokenOffsetPayloadTokenFilterFactory
-
Creates a new TokenOffsetPayloadTokenFilterFactory
- tokenOutput - Variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizerFactory
-
- tokens - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase
-
- TOKENS_ONLY - Static variable in class org.apache.lucene.analysis.wikipedia.WikipediaTokenizer
-
Only output tokens
- TokenSources - Class in org.apache.lucene.search.highlight
-
Convenience methods for obtaining a
TokenStream
for use with the
Highlighter
- can obtain from
term vectors with offsets and positions or from an Analyzer re-parsing the stored content.
- tokenStream(String, Reader) - Method in class org.apache.lucene.analysis.Analyzer
-
Returns a TokenStream suitable for fieldName
, tokenizing
the contents of reader
.
- tokenStream(String, String) - Method in class org.apache.lucene.analysis.Analyzer
-
Returns a TokenStream suitable for fieldName
, tokenizing
the contents of text
.
- TokenStream - Class in org.apache.lucene.analysis
-
A
TokenStream
enumerates the sequence of tokens, either from
Field
s of a
Document
or from query text.
- TokenStream() - Constructor for class org.apache.lucene.analysis.TokenStream
-
A TokenStream using the default attribute factory.
- TokenStream(AttributeSource) - Constructor for class org.apache.lucene.analysis.TokenStream
-
A TokenStream that uses the same attributes as the supplied one.
- TokenStream(AttributeFactory) - Constructor for class org.apache.lucene.analysis.TokenStream
-
A TokenStream using the supplied AttributeFactory for creating new
Attribute
instances.
- tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.codecs.StoredFieldsWriter.MergeVisitor
-
- tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.document.FeatureField
-
- tokenStream - Variable in class org.apache.lucene.document.Field
-
Pre-analyzed tokenStream for indexed fields; this is
separate from fieldsData because you are allowed to
have both; eg maybe field has a String value but you
customize how it's tokenized
- tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.document.Field
-
- tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.document.LazyDocument.LazyField
-
- tokenStream(Analyzer, TokenStream) - Method in interface org.apache.lucene.index.IndexableField
-
Creates the TokenStream used for indexing this field.
- tokenStream(Analyzer, TokenStream) - Method in class org.apache.lucene.search.suggest.document.SuggestField
-
- tokenStream(String) - Method in class org.apache.lucene.search.uhighlight.AnalysisOffsetStrategy
-
- TokenStreamComponents(Tokenizer, TokenStream) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
-
- TokenStreamComponents(Tokenizer) - Constructor for class org.apache.lucene.analysis.Analyzer.TokenStreamComponents
-
- TokenStreamFromTermVector - Class in org.apache.lucene.search.highlight
-
TokenStream created from a term vector field.
- TokenStreamFromTermVector(Terms, int) - Constructor for class org.apache.lucene.search.highlight.TokenStreamFromTermVector
-
Constructor.
- TokenStreamOffsetStrategy - Class in org.apache.lucene.search.uhighlight
-
Analyzes the text, producing a single
OffsetsEnum
wrapping the
TokenStream
filtered to terms
in the query, including wildcards.
- TokenStreamOffsetStrategy(UHComponents, Analyzer) - Constructor for class org.apache.lucene.search.uhighlight.TokenStreamOffsetStrategy
-
- TokenStreamToAutomaton - Class in org.apache.lucene.analysis
-
Consumes a TokenStream and creates an
Automaton
where the transition labels are UTF8 bytes (or Unicode
code points if unicodeArcs is true) from the
TermToBytesRefAttribute
.
- TokenStreamToAutomaton() - Constructor for class org.apache.lucene.analysis.TokenStreamToAutomaton
-
Sole constructor.
- TokenStreamToDot - Class in org.apache.lucene.analysis
-
Consumes a TokenStream and outputs the dot (graphviz) string (graph).
- TokenStreamToDot(String, TokenStream, PrintWriter) - Constructor for class org.apache.lucene.analysis.TokenStreamToDot
-
If inputText is non-null, and the TokenStream has
offsets, we include the surface form in each arc's
label.
- TokenStreamToTermAutomatonQuery - Class in org.apache.lucene.search
-
- TokenStreamToTermAutomatonQuery() - Constructor for class org.apache.lucene.search.TokenStreamToTermAutomatonQuery
-
Sole constructor.
- tokenStreamValue() - Method in class org.apache.lucene.document.Field
-
The TokenStream for this field to be used when indexing, or null.
- toLargeString() - Method in enum org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode.Modifier
-
- toLongValuesSource() - Method in class org.apache.lucene.search.DoubleValuesSource
-
Convert to a LongValuesSource by casting the double values to longs
- toLowerCase(char[], int, int) - Static method in class org.apache.lucene.analysis.CharacterUtils
-
Converts each unicode codepoint to lowerCase via Character.toLowerCase(int)
starting
at the given offset.
- toLowerCase(CharSequence, Locale) - Static method in class org.apache.lucene.queryparser.flexible.core.util.UnescapedCharSequence
-
- TOO_MANY_BOOLEAN_CLAUSES - Static variable in class org.apache.lucene.queryparser.flexible.core.messages.QueryParserMessages
-
- toObject(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
- toObject(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
Converts a UnitNRShape shape to the corresponding type supported by this class, such as a Calendar/BigDecimal.
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValue
-
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueBool
-
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueDate
-
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueDouble
-
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueFloat
-
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueInt
-
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueLong
-
- toObject() - Method in class org.apache.lucene.util.mutable.MutableValueStr
-
- TooComplexToDeterminizeException - Exception in org.apache.lucene.util.automaton
-
This exception is thrown when determinizing an automaton would result in one
has too many states.
- TooComplexToDeterminizeException(RegExp, TooComplexToDeterminizeException) - Constructor for exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
-
Use this constructor when the RegExp failed to convert to an automaton.
- TooComplexToDeterminizeException(Automaton, int) - Constructor for exception org.apache.lucene.util.automaton.TooComplexToDeterminizeException
-
Use this constructor when the automaton failed to determinize.
- toolOutOfDate - Variable in class org.apache.lucene.index.CheckIndex.Status
-
True if the index was created with a newer version of Lucene than the CheckIndex tool.
- Tools - Class in org.apache.lucene.spatial3d.geom
-
Static methods globally useful for 3d geometric work.
- TooManyBasicQueries - Exception in org.apache.lucene.queryparser.surround.query
-
- TooManyBasicQueries(int) - Constructor for exception org.apache.lucene.queryparser.surround.query.TooManyBasicQueries
-
- TooManyClauses() - Constructor for exception org.apache.lucene.search.BooleanQuery.TooManyClauses
-
- top() - Method in class org.apache.lucene.search.DisiPriorityQueue
-
- top() - Method in class org.apache.lucene.util.PriorityQueue
-
Returns the least element of the PriorityQueue in constant time.
- ToParentBlockJoinQuery - Class in org.apache.lucene.search.join
-
- ToParentBlockJoinQuery(Query, BitSetProducer, ScoreMode) - Constructor for class org.apache.lucene.search.join.ToParentBlockJoinQuery
-
Create a ToParentBlockJoinQuery.
- ToParentBlockJoinSortField - Class in org.apache.lucene.search.join
-
A special sort field that allows sorting parent docs based on nested / child level fields.
- ToParentBlockJoinSortField(String, SortField.Type, boolean, BitSetProducer, BitSetProducer) - Constructor for class org.apache.lucene.search.join.ToParentBlockJoinSortField
-
Create ToParentBlockJoinSortField.
- ToParentBlockJoinSortField(String, SortField.Type, boolean, boolean, BitSetProducer, BitSetProducer) - Constructor for class org.apache.lucene.search.join.ToParentBlockJoinSortField
-
Create ToParentBlockJoinSortField.
- TopDocs - Class in org.apache.lucene.search
-
- TopDocs(long, ScoreDoc[], float) - Constructor for class org.apache.lucene.search.TopDocs
-
- topDocs() - Method in class org.apache.lucene.search.TopDocsCollector
-
Returns the top docs that were collected by this collector.
- topDocs(int) - Method in class org.apache.lucene.search.TopDocsCollector
-
Returns the documents in the range [start ..
- topDocs(int, int) - Method in class org.apache.lucene.search.TopDocsCollector
-
Returns the documents in the range [start ..
- topDocs() - Method in class org.apache.lucene.search.TopFieldCollector
-
- TopDocsCollector<T extends ScoreDoc> - Class in org.apache.lucene.search
-
A base class for all collectors that return a
TopDocs
output.
- TopDocsCollector(PriorityQueue<T>) - Constructor for class org.apache.lucene.search.TopDocsCollector
-
- topDocsSize() - Method in class org.apache.lucene.search.TopDocsCollector
-
The number of valid PQ entries
- topdocsString(TopDocs, int, int) - Static method in class org.apache.lucene.search.CheckHits
-
- TopFieldCollector - Class in org.apache.lucene.search
-
- TopFieldDocs - Class in org.apache.lucene.search
-
- TopFieldDocs(long, ScoreDoc[], SortField[], float) - Constructor for class org.apache.lucene.search.TopFieldDocs
-
Creates one of these objects.
- TopGroups<T> - Class in org.apache.lucene.search.grouping
-
Represents result returned by a grouping search.
- TopGroups(SortField[], SortField[], int, int, GroupDocs<T>[], float) - Constructor for class org.apache.lucene.search.grouping.TopGroups
-
- TopGroups(TopGroups<T>, Integer) - Constructor for class org.apache.lucene.search.grouping.TopGroups
-
- TopGroups.ScoreMergeMode - Enum in org.apache.lucene.search.grouping
-
How the GroupDocs score (if any) should be merged.
- TopGroupsCollector<T> - Class in org.apache.lucene.search.grouping
-
A second-pass collector that collects the TopDocs for each group, and
returns them as a
TopGroups
object
- TopGroupsCollector(GroupSelector<T>, Collection<SearchGroup<T>>, Sort, Sort, int, boolean, boolean, boolean) - Constructor for class org.apache.lucene.search.grouping.TopGroupsCollector
-
Create a new TopGroupsCollector
- topLat - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Top latitude of the vertical line
- topLeaves - Variable in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets
-
The count of documents with ranges that completely spanned the parents of the detail level.
- TopLevelQuery(String) - Method in class org.apache.lucene.queryparser.classic.QueryParser
-
- TopLevelQuery(String) - Method in class org.apache.lucene.queryparser.classic.QueryParserBase
-
- TopLevelQuery(CharSequence) - Method in class org.apache.lucene.queryparser.flexible.standard.parser.StandardSyntaxParser
-
- topList() - Method in class org.apache.lucene.search.DisiPriorityQueue
-
Get the list of scorers which are on the current doc.
- topN - Variable in class org.apache.lucene.util.fst.Util.TopResults
-
The top results
- TopNSearcher(FST<T>, int, int, Comparator<T>) - Constructor for class org.apache.lucene.util.fst.Util.TopNSearcher
-
Creates an unbounded TopNSearcher
- TopNSearcher(FST<T>, int, int, Comparator<T>, Comparator<Util.FSTPath<T>>) - Constructor for class org.apache.lucene.util.fst.Util.TopNSearcher
-
- TopOrdAndFloatQueue - Class in org.apache.lucene.facet
-
Keeps highest results, first by largest float value,
then tie break by smallest ord.
- TopOrdAndFloatQueue(int) - Constructor for class org.apache.lucene.facet.TopOrdAndFloatQueue
-
Sole constructor.
- TopOrdAndFloatQueue.OrdAndValue - Class in org.apache.lucene.facet
-
Holds a single entry.
- TopOrdAndIntQueue - Class in org.apache.lucene.facet
-
Keeps highest results, first by largest int value,
then tie break by smallest ord.
- TopOrdAndIntQueue(int) - Constructor for class org.apache.lucene.facet.TopOrdAndIntQueue
-
Sole constructor.
- TopOrdAndIntQueue.OrdAndValue - Class in org.apache.lucene.facet
-
Holds a single entry.
- topoSortStates(Automaton) - Static method in class org.apache.lucene.util.automaton.Operations
-
Returns the topological sort of all states reachable from
the initial state.
- topPlane - Variable in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
Top end cutoff plane
- TopScoreDocCollector - Class in org.apache.lucene.search
-
A
Collector
implementation that collects the top-scoring hits,
returning them as a
TopDocs
.
- TopSrndQuery() - Method in class org.apache.lucene.queryparser.surround.parser.QueryParser
-
- TopSuggestDocs - Class in org.apache.lucene.search.suggest.document
-
- TopSuggestDocs(int, TopSuggestDocs.SuggestScoreDoc[], float) - Constructor for class org.apache.lucene.search.suggest.document.TopSuggestDocs
-
- TopSuggestDocs.SuggestScoreDoc - Class in org.apache.lucene.search.suggest.document
-
ScoreDoc
with an
additional CharSequence key
- TopSuggestDocsCollector - Class in org.apache.lucene.search.suggest.document
-
Collector
that collects completion and
score, along with document id
- TopSuggestDocsCollector(int, boolean) - Constructor for class org.apache.lucene.search.suggest.document.TopSuggestDocsCollector
-
Sole constructor
Collects at most num
completions
with corresponding document and weight
- TopTermsBlendedFreqScoringRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBlendedFreqScoringRewrite
-
Create a TopTermsBlendedScoringBooleanQueryRewrite for at most
size
terms.
- TopTermsBoostOnlyBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsBoostOnlyBooleanQueryRewrite
-
Create a TopTermsBoostOnlyBooleanQueryRewrite for
at most size
terms.
- TopTermsRewrite<B> - Class in org.apache.lucene.search
-
Base rewrite method for collecting only the top terms
via a priority queue.
- TopTermsRewrite(int) - Constructor for class org.apache.lucene.search.TopTermsRewrite
-
Create a TopTermsBooleanQueryRewrite for
at most size
terms.
- TopTermsScoringBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.MultiTermQuery.TopTermsScoringBooleanQueryRewrite
-
Create a TopTermsScoringBooleanQueryRewrite for
at most size
terms.
- TopTermsSpanBooleanQueryRewrite(int) - Constructor for class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper.TopTermsSpanBooleanQueryRewrite
-
Create a TopTermsSpanBooleanQueryRewrite for
at most size
terms.
- toQuery(String, TokenStream) - Method in class org.apache.lucene.search.TokenStreamToTermAutomatonQuery
-
Pulls the graph (including
PositionLengthAttribute
) from the provided
TokenStream
, and creates the corresponding
automaton where arcs are bytes (or Unicode code points
if unicodeArcs = true) from each term.
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AndQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BooleanQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BoostQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.DeletedQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.GroupQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.MatchAllDocsQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.NoTokenFoundQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.OpaqueQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.OrQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
convert to a query string understood by the query parser
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QuotedFieldQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.core.nodes.TokenizedPhraseQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.MultiPhraseQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- toQueryString(EscapeQuerySyntax) - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.WildcardQueryNode
-
- toQueryStringIgnoreFields - Variable in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
If set to true the the method toQueryString will not write field names
- toRadians(double) - Static method in class org.apache.lucene.util.SloppyMath
-
Convert to radians.
- toRangeShape(NumberRangePrefixTree.UnitNRShape, NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
Returns a shape that represents the continuous range between start
and end
.
- toRealPath(LinkOption...) - Method in class org.apache.lucene.mockfile.FilterPath
-
- toShape(Calendar) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Converts the Calendar into a Shape.
- toShape(int[], int) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- toSparseLocalFreqDoubleArray(Terms, Terms) - Static method in class org.apache.lucene.classification.utils.DocToDoubleVectorUtils
-
create a sparse Double
vector given doc and field term vectors using local frequency of the terms in the doc
- toString(Analyzer, String) - Static method in class org.apache.lucene.analysis.BaseTokenStreamTestCase
-
Returns a String
summary of the tokens this analyzer produces on this text
- toString() - Method in class org.apache.lucene.analysis.CharArrayMap
-
- toString() - Method in class org.apache.lucene.analysis.CharArraySet
-
- toString() - Method in class org.apache.lucene.analysis.compound.hyphenation.Hyphen
-
- toString() - Method in class org.apache.lucene.analysis.custom.CustomAnalyzer
-
- toString() - Method in class org.apache.lucene.analysis.ja.Token
-
- toString() - Method in class org.apache.lucene.analysis.ko.DecompoundToken
-
- toString() - Method in class org.apache.lucene.analysis.ko.DictionaryToken
-
- toString() - Method in class org.apache.lucene.analysis.miscellaneous.LimitTokenCountAnalyzer
-
- toString() - Method in class org.apache.lucene.analysis.miscellaneous.PerFieldAnalyzerWrapper
-
- toString() - Method in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilter
-
- toString() - Method in class org.apache.lucene.analysis.tokenattributes.CharTermAttributeImpl
-
Returns solely the term text as specified by the
CharSequence
interface.
- toString() - Method in class org.apache.lucene.analysis.util.OpenStringBuilder
-
- toString() - Method in class org.apache.lucene.benchmark.byTask.stats.TaskStats
-
- toString() - Method in class org.apache.lucene.benchmark.byTask.tasks.PerfTask
-
- toString() - Method in class org.apache.lucene.benchmark.byTask.tasks.RepSumByPrefTask
-
- toString() - Method in class org.apache.lucene.benchmark.byTask.tasks.TaskSequence
-
- toString() - Method in class org.apache.lucene.benchmark.byTask.utils.Algorithm
-
- toString() - Method in class org.apache.lucene.benchmark.byTask.utils.AnalyzerFactory
-
- toString() - Method in class org.apache.lucene.classification.KNearestFuzzyClassifier
-
- toString() - Method in class org.apache.lucene.classification.KNearestNeighborClassifier
-
- toString() - Method in class org.apache.lucene.classification.utils.ConfusionMatrixGenerator.ConfusionMatrix
-
- toString(String) - Method in class org.apache.lucene.classification.utils.NearestFuzzyQuery
-
- toString() - Method in class org.apache.lucene.codecs.asserting.AssertingCodec
-
- toString() - Method in class org.apache.lucene.codecs.asserting.AssertingLiveDocsFormat
-
- toString() - Method in class org.apache.lucene.codecs.blockterms.BlockTermsReader
-
- toString() - Method in class org.apache.lucene.codecs.blockterms.FixedGapTermsIndexReader
-
- toString() - Method in class org.apache.lucene.codecs.blockterms.VariableGapTermsIndexReader
-
- toString() - Method in class org.apache.lucene.codecs.BlockTermState
-
- toString() - Method in class org.apache.lucene.codecs.blocktree.BlockTreeTermsReader
-
- toString() - Method in class org.apache.lucene.codecs.blocktree.FieldReader
-
- toString() - Method in class org.apache.lucene.codecs.blocktree.Stats
-
- toString() - Method in class org.apache.lucene.codecs.blocktreeords.BlockTreeOrdsPostingsFormat
-
- toString() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsBlockTreeTermsReader
-
- toString() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- toString() - Method in class org.apache.lucene.codecs.bloom.BloomFilteringPostingsFormat
-
- toString() - Method in class org.apache.lucene.codecs.bloom.FuzzySet
-
- toString() - Method in class org.apache.lucene.codecs.bloom.MurmurHash2
-
- toString() - Method in class org.apache.lucene.codecs.bloom.TestBloomFilteredLucenePostings
-
- toString() - Method in class org.apache.lucene.codecs.Codec
-
returns the codec's name.
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingCodec
-
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsFormat
-
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsIndexReader
-
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingStoredFieldsReader
-
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsFormat
-
- toString() - Method in class org.apache.lucene.codecs.compressing.CompressingTermVectorsReader
-
- toString() - Method in class org.apache.lucene.codecs.cranky.CrankyCodec
-
- toString() - Method in class org.apache.lucene.codecs.DocValuesFormat
-
- toString() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- toString() - Method in class org.apache.lucene.codecs.idversion.VersionBlockTreeTermsReader
-
- toString() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsFormat
-
- toString() - Method in class org.apache.lucene.codecs.lucene50.Lucene50PostingsReader
-
- toString() - Method in class org.apache.lucene.codecs.memory.FSTOrdPostingsFormat
-
- toString() - Method in class org.apache.lucene.codecs.memory.FSTOrdTermsReader
-
- toString() - Method in class org.apache.lucene.codecs.memory.FSTPostingsFormat
-
- toString() - Method in class org.apache.lucene.codecs.memory.FSTTermsReader
-
- toString() - Method in class org.apache.lucene.codecs.memory.MemoryPostingsFormat
-
- toString() - Method in class org.apache.lucene.codecs.PostingsFormat
-
- toString() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextNormsFormat.SimpleTextNormsProducer
-
- toString() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextStoredFieldsReader
-
- toString() - Method in class org.apache.lucene.codecs.simpletext.SimpleTextTermVectorsReader
-
- toString() - Method in class org.apache.lucene.document.BigIntegerPoint
-
- toString() - Method in enum org.apache.lucene.document.DateTools.Resolution
-
this method returns the name of the resolution
in lowercase (for backwards compatibility)
- toString() - Method in class org.apache.lucene.document.Document
-
Prints the fields of a document for human consumption.
- toString() - Method in class org.apache.lucene.document.DoublePoint
-
- toString() - Method in class org.apache.lucene.document.DoubleRange
-
- toString() - Method in class org.apache.lucene.document.Field
-
Prints a Field for human consumption.
- toString() - Method in class org.apache.lucene.document.FieldType
-
Prints a Field for human consumption.
- toString() - Method in class org.apache.lucene.document.FloatPoint
-
- toString() - Method in class org.apache.lucene.document.FloatRange
-
- toString() - Method in class org.apache.lucene.document.HalfFloatPoint
-
- toString() - Method in class org.apache.lucene.document.InetAddressPoint
-
- toString() - Method in class org.apache.lucene.document.IntPoint
-
- toString() - Method in class org.apache.lucene.document.IntRange
-
- toString() - Method in class org.apache.lucene.document.LatLonBoundingBox
-
- toString() - Method in class org.apache.lucene.document.LatLonDocValuesField
-
- toString() - Method in class org.apache.lucene.document.LatLonPoint
-
- toString() - Method in class org.apache.lucene.document.LongPoint
-
- toString() - Method in class org.apache.lucene.document.LongRange
-
- toString(String) - Method in class org.apache.lucene.facet.DrillDownQuery
-
- toString() - Method in class org.apache.lucene.facet.FacetField
-
- toString() - Method in class org.apache.lucene.facet.FacetResult
-
- toString() - Method in class org.apache.lucene.facet.LabelAndValue
-
- toString() - Method in class org.apache.lucene.facet.LongValueFacetCounts
-
- toString() - Method in class org.apache.lucene.facet.range.DoubleRange
-
- toString() - Method in class org.apache.lucene.facet.range.LongRange
-
- toString() - Method in class org.apache.lucene.facet.sortedset.DefaultSortedSetDocValuesReaderState
-
- toString() - Method in class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetField
-
- toString() - Method in class org.apache.lucene.facet.taxonomy.AssociationFacetField
-
- toString(int) - Method in class org.apache.lucene.facet.taxonomy.directory.DirectoryTaxonomyReader
-
Returns ordinal -> label mapping, up to the provided
max ordinal or number of ordinals, whichever is
smaller.
- toString() - Method in class org.apache.lucene.facet.taxonomy.FacetLabel
-
Returns a string representation of the path.
- toString() - Method in class org.apache.lucene.facet.taxonomy.FloatAssociationFacetField
-
- toString() - Method in class org.apache.lucene.facet.taxonomy.IntAssociationFacetField
-
- toString() - Method in class org.apache.lucene.geo.Line
-
- toString() - Method in class org.apache.lucene.geo.Polygon
-
- toString() - Method in class org.apache.lucene.geo.Rectangle
-
- toString() - Method in class org.apache.lucene.geo.Rectangle2D
-
- toString() - Method in class org.apache.lucene.geo.Tessellator.Node
-
- toString() - Method in class org.apache.lucene.geo.Tessellator.Triangle
-
pretty print the triangle vertices
- toString() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingBinaryDocValues
-
- toString() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingNumericDocValues
-
- toString() - Method in class org.apache.lucene.index.AssertingLeafReader.AssertingTerms
-
- toString() - Method in class org.apache.lucene.index.CompositeReader
-
- toString() - Method in class org.apache.lucene.index.ConcurrentMergeScheduler
-
- toString() - Method in class org.apache.lucene.index.ExitableDirectoryReader
-
- toString() - Method in class org.apache.lucene.index.FieldFilterLeafReader
-
- toString() - Method in class org.apache.lucene.index.FilterLeafReader
-
- toString() - Method in class org.apache.lucene.index.FilterMergePolicy
-
- toString() - Method in class org.apache.lucene.index.IndexWriterConfig
-
- toString() - Method in class org.apache.lucene.index.LeafReaderContext
-
- toString() - Method in class org.apache.lucene.index.LegacyNumericDocValuesWrapper
-
Deprecated.
- toString() - Method in class org.apache.lucene.index.LegacySortedSetDocValuesWrapper
-
Deprecated.
- toString() - Method in class org.apache.lucene.index.LiveIndexWriterConfig
-
- toString() - Method in class org.apache.lucene.index.LogMergePolicy
-
- toString() - Method in class org.apache.lucene.index.MultiPostingsEnum.EnumWithSlice
-
- toString() - Method in class org.apache.lucene.index.MultiPostingsEnum
-
- toString() - Method in class org.apache.lucene.index.MultiTermsEnum
-
- toString() - Method in class org.apache.lucene.index.NoMergePolicy
-
- toString() - Method in class org.apache.lucene.index.OrdTermState
-
- toString() - Method in class org.apache.lucene.index.ParallelLeafReader
-
- toString() - Method in class org.apache.lucene.index.QueryTimeoutImpl
-
- toString() - Method in class org.apache.lucene.index.RandomCodec
-
- toString() - Method in class org.apache.lucene.index.ReaderSlice
-
- toString(int) - Method in class org.apache.lucene.index.SegmentCommitInfo
-
Returns a description of this segment.
- toString() - Method in class org.apache.lucene.index.SegmentCommitInfo
-
- toString() - Method in class org.apache.lucene.index.SegmentInfo
-
- toString(int) - Method in class org.apache.lucene.index.SegmentInfo
-
Used for debugging.
- toString() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns readable description of this segment.
- toString() - Method in class org.apache.lucene.index.SegmentReader
-
- toString() - Method in class org.apache.lucene.index.StandardDirectoryReader
-
- toString(BytesRef) - Static method in class org.apache.lucene.index.Term
-
Returns human-readable form of the term text.
- toString() - Method in class org.apache.lucene.index.Term
-
- toString() - Method in class org.apache.lucene.index.TermContext
-
- toString() - Method in class org.apache.lucene.index.TermState
-
- toString() - Method in class org.apache.lucene.index.TieredMergePolicy
-
- toString() - Method in class org.apache.lucene.misc.SweetSpotSimilarity
-
- toString() - Method in class org.apache.lucene.misc.TermStats
-
- toString() - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- toString() - Method in class org.apache.lucene.mockfile.FilterFileSystemProvider
-
- toString() - Method in class org.apache.lucene.mockfile.FilterPath
-
- toString(String) - Method in class org.apache.lucene.queries.BoostingQuery
-
Deprecated.
- toString(String) - Method in class org.apache.lucene.queries.CommonTermsQuery
-
- toString(String) - Method in class org.apache.lucene.queries.CustomScoreQuery
-
Deprecated.
- toString(String) - Method in class org.apache.lucene.queries.function.BoostedQuery
-
Deprecated.
- toString(int) - Method in class org.apache.lucene.queries.function.docvalues.BoolDocValues
-
- toString(int) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- toString(int) - Method in class org.apache.lucene.queries.function.docvalues.DoubleDocValues
-
- toString(int) - Method in class org.apache.lucene.queries.function.docvalues.FloatDocValues
-
- toString(int) - Method in class org.apache.lucene.queries.function.docvalues.IntDocValues
-
- toString(int) - Method in class org.apache.lucene.queries.function.docvalues.LongDocValues
-
- toString(int) - Method in class org.apache.lucene.queries.function.docvalues.StrDocValues
-
- toString(String) - Method in class org.apache.lucene.queries.function.FunctionMatchQuery
-
- toString(String) - Method in class org.apache.lucene.queries.function.FunctionQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.queries.function.FunctionRangeQuery
-
- toString(String) - Method in class org.apache.lucene.queries.function.FunctionScoreQuery
-
- toString(int) - Method in class org.apache.lucene.queries.function.FunctionValues
-
- toString(String, FunctionValues[], int) - Static method in class org.apache.lucene.queries.function.valuesource.MultiFunction
-
- toString(int) - Method in class org.apache.lucene.queries.function.valuesource.MultiFunction.Values
-
- toString() - Method in class org.apache.lucene.queries.function.ValueSource
-
- toString(String) - Method in class org.apache.lucene.queries.mlt.MoreLikeThisQuery
-
- toString(String) - Method in class org.apache.lucene.queries.payloads.PayloadScoreQuery
-
- toString(String) - Method in class org.apache.lucene.queries.payloads.SpanPayloadCheckQuery
-
- toString() - Method in class org.apache.lucene.queryparser.classic.Token
-
Returns the image.
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.config.FieldConfig
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AndQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.AnyQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BooleanQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.BoostQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.DeletedQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FieldQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.FuzzyQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.GroupQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.MatchAllDocsQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.MatchNoDocsQueryNode
-
- toString() - Method in enum org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode.Modifier
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ModifierQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.NoTokenFoundQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.OpaqueQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.OrQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode.QueryText
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PathQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.PhraseSlopQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.ProximityQueryNode
-
- toString() - Method in interface org.apache.lucene.queryparser.flexible.core.nodes.QueryNode
-
for printing
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QueryNodeImpl
-
Every implementation of this class should return pseudo xml like this:
For FieldQueryNode: <field start='1' end='2' field='subject' text='foo'/>
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.QuotedFieldQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.SlopQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.nodes.TokenizedPhraseQueryNode
-
- toString() - Method in exception org.apache.lucene.queryparser.flexible.core.QueryNodeException
-
- toString(Object) - Static method in class org.apache.lucene.queryparser.flexible.core.util.StringUtils
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.core.util.UnescapedCharSequence
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.messages.MessageImpl
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.AbstractRangeQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.MultiPhraseQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PointRangeQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.PrefixWildcardQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.RegexpQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.nodes.WildcardQueryNode
-
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.parser.Token
-
Returns the image.
- toString() - Method in class org.apache.lucene.queryparser.flexible.standard.StandardQueryParser
-
- toString() - Method in class org.apache.lucene.queryparser.surround.parser.Token
-
Returns the image.
- toString() - Method in class org.apache.lucene.queryparser.surround.query.BasicQueryFactory
-
- toString() - Method in class org.apache.lucene.queryparser.surround.query.ComposedQuery
-
- toString() - Method in class org.apache.lucene.queryparser.surround.query.FieldsQuery
-
- toString() - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- toString() - Method in class org.apache.lucene.queryparser.surround.query.SrndQuery
-
- toString() - Method in class org.apache.lucene.replicator.IndexAndTaxonomyRevision
-
- toString() - Method in class org.apache.lucene.replicator.IndexRevision
-
- toString() - Method in class org.apache.lucene.replicator.nrt.CopyState
-
- toString() - Method in class org.apache.lucene.replicator.nrt.FileMetaData
-
- toString() - Method in class org.apache.lucene.replicator.nrt.Node
-
- toString() - Method in class org.apache.lucene.replicator.ReplicationClient
-
- toString() - Method in class org.apache.lucene.replicator.RevisionFile
-
- toString() - Method in class org.apache.lucene.replicator.SessionToken
-
- toString(String) - Method in class org.apache.lucene.sandbox.queries.FuzzyLikeThisQuery
-
- toString() - Method in class org.apache.lucene.search.AssertingIndexSearcher
-
- toString(String) - Method in class org.apache.lucene.search.AssertingQuery
-
- toString() - Method in class org.apache.lucene.search.AssertingScorer
-
- toString(String) - Method in class org.apache.lucene.search.AutomatonQuery
-
- toString(String) - Method in class org.apache.lucene.search.BlendedTermQuery
-
- toString() - Method in class org.apache.lucene.search.BooleanClause
-
- toString(String) - Method in class org.apache.lucene.search.BooleanQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.BoostQuery
-
- toString(String) - Method in class org.apache.lucene.search.ConstantScoreQuery
-
- toString(String) - Method in class org.apache.lucene.search.CoveringQuery
-
- toString(String) - Method in class org.apache.lucene.search.DisjunctionMaxQuery
-
Prettyprint us.
- toString() - Method in class org.apache.lucene.search.DiversifiedTopDocsCollector.ScoreDocKey
-
- toString(String) - Method in class org.apache.lucene.search.DocValuesFieldExistsQuery
-
- toString(String) - Method in class org.apache.lucene.search.DocValuesNumbersQuery
-
- toString(String) - Method in class org.apache.lucene.search.DocValuesTermsQuery
-
- toString() - Method in class org.apache.lucene.search.DoubleValuesSource
-
- toString() - Method in class org.apache.lucene.search.Explanation
-
Render an explanation as text.
- toString() - Method in class org.apache.lucene.search.FieldDoc
-
- toString() - Method in class org.apache.lucene.search.FieldValueHitQueue.Entry
-
- toString() - Method in class org.apache.lucene.search.FilterCollector
-
- toString() - Method in class org.apache.lucene.search.FilterLeafCollector
-
- toString(String) - Method in class org.apache.lucene.search.FuzzyQuery
-
- toString() - Method in class org.apache.lucene.search.grouping.GroupFacetCollector.FacetEntry
-
- toString() - Method in class org.apache.lucene.search.grouping.SearchGroup
-
- toString() - Method in class org.apache.lucene.search.highlight.TextFragment
-
- toString(String) - Method in class org.apache.lucene.search.IndexOrDocValuesQuery
-
- toString() - Method in class org.apache.lucene.search.IndexSearcher
-
- toString() - Method in class org.apache.lucene.search.intervals.IntervalIterator
-
- toString(String) - Method in class org.apache.lucene.search.intervals.IntervalQuery
-
- toString() - Method in class org.apache.lucene.search.intervals.IntervalsSource
-
- toString(String) - Method in class org.apache.lucene.search.join.ParentChildrenBlockJoinQuery
-
- toString() - Method in class org.apache.lucene.search.join.QueryBitSetProducer
-
- toString(String) - Method in class org.apache.lucene.search.join.ToChildBlockJoinQuery
-
- toString(String) - Method in class org.apache.lucene.search.join.ToParentBlockJoinQuery
-
- toString() - Method in class org.apache.lucene.search.LongValuesSource
-
- toString(String) - Method in class org.apache.lucene.search.MatchAllDocsQuery
-
- toString(String) - Method in class org.apache.lucene.search.MatchNoDocsQuery
-
- toString(String) - Method in class org.apache.lucene.search.MultiPhraseQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.NGramPhraseQuery
-
- toString(String) - Method in class org.apache.lucene.search.NormsFieldExistsQuery
-
- toString(String) - Method in class org.apache.lucene.search.PhraseQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.PointInSetQuery
-
- toString(byte[]) - Method in class org.apache.lucene.search.PointInSetQuery
-
Returns a string of a single value in a human-readable format for debugging.
- toString(String) - Method in class org.apache.lucene.search.PointRangeQuery
-
- toString(int, byte[]) - Method in class org.apache.lucene.search.PointRangeQuery
-
Returns a string of a single value in a human-readable format for debugging.
- toString(String) - Method in class org.apache.lucene.search.PrefixQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.Query
-
Prints a query to a string, with field
assumed to be the
default field and omitted.
- toString() - Method in class org.apache.lucene.search.Query
-
Prints a query to a string.
- toString(String) - Method in class org.apache.lucene.search.RandomApproximationQuery
-
- toString(String) - Method in class org.apache.lucene.search.RegexpQuery
-
Prints a user-readable version of this query.
- toString() - Method in class org.apache.lucene.search.ScoreDoc
-
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffect.NoAfterEffect
-
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffect
-
Subclasses must override this method to return the code of the
after effect formula.
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffectB
-
- toString() - Method in class org.apache.lucene.search.similarities.AfterEffectL
-
- toString() - Method in class org.apache.lucene.search.similarities.Axiomatic
-
Name of the axiomatic method.
- toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF1EXP
-
- toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF1LOG
-
- toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF2EXP
-
- toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF2LOG
-
- toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF3EXP
-
- toString() - Method in class org.apache.lucene.search.similarities.AxiomaticF3LOG
-
- toString() - Method in class org.apache.lucene.search.similarities.BasicModel
-
Subclasses must override this method to return the code of the
basic model formula.
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelBE
-
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelD
-
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelG
-
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelIF
-
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelIn
-
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelIne
-
- toString() - Method in class org.apache.lucene.search.similarities.BasicModelP
-
- toString() - Method in class org.apache.lucene.search.similarities.BM25Similarity
-
- toString() - Method in class org.apache.lucene.search.similarities.ClassicSimilarity
-
- toString() - Method in class org.apache.lucene.search.similarities.DFISimilarity
-
- toString() - Method in class org.apache.lucene.search.similarities.DFRSimilarity
-
- toString() - Method in class org.apache.lucene.search.similarities.Distribution
-
Subclasses must override this method to return the name of the
distribution.
- toString() - Method in class org.apache.lucene.search.similarities.DistributionLL
-
- toString() - Method in class org.apache.lucene.search.similarities.DistributionSPL
-
- toString() - Method in class org.apache.lucene.search.similarities.IBSimilarity
-
The name of IB methods follow the pattern
IB <distribution> <lambda><normalization>
.
- toString() - Method in class org.apache.lucene.search.similarities.Independence
-
- toString() - Method in class org.apache.lucene.search.similarities.IndependenceChiSquared
-
- toString() - Method in class org.apache.lucene.search.similarities.IndependenceSaturated
-
- toString() - Method in class org.apache.lucene.search.similarities.IndependenceStandardized
-
- toString() - Method in class org.apache.lucene.search.similarities.Lambda
-
Subclasses must override this method to return the code of the lambda
formula.
- toString() - Method in class org.apache.lucene.search.similarities.LambdaDF
-
- toString() - Method in class org.apache.lucene.search.similarities.LambdaTTF
-
- toString() - Method in class org.apache.lucene.search.similarities.LMSimilarity
-
Returns the name of the LM method.
- toString() - Method in class org.apache.lucene.search.similarities.Normalization.NoNormalization
-
- toString() - Method in class org.apache.lucene.search.similarities.Normalization
-
Subclasses must override this method to return the code of the
normalization formula.
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationH1
-
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationH2
-
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationH3
-
- toString() - Method in class org.apache.lucene.search.similarities.NormalizationZ
-
- toString() - Method in class org.apache.lucene.search.similarities.RandomSimilarity
-
- toString() - Method in class org.apache.lucene.search.similarities.SimilarityBase
-
Subclasses must override this method to return the name of the Similarity
and preferably the values of parameters (if any) as well.
- toString() - Method in class org.apache.lucene.search.Sort
-
- toString() - Method in class org.apache.lucene.search.SortedNumericSortField
-
- toString() - Method in class org.apache.lucene.search.SortedSetSortField
-
- toString() - Method in class org.apache.lucene.search.SortField
-
- toString(String) - Method in class org.apache.lucene.search.spans.AssertingSpanQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.FieldMaskingSpanQuery
-
- toString() - Method in class org.apache.lucene.search.spans.FilterSpans
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanBoostQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanContainingQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanFirstQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanMultiTermQueryWrapper
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanNearQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanNotQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanOrQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanPositionRangeQuery
-
- toString() - Method in class org.apache.lucene.search.spans.Spans
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanTermQuery
-
- toString(String) - Method in class org.apache.lucene.search.spans.SpanWithinQuery
-
- toString() - Method in class org.apache.lucene.search.spans.TermSpans
-
- toString() - Method in class org.apache.lucene.search.spell.JaroWinklerDistance
-
- toString() - Method in class org.apache.lucene.search.spell.LevenshteinDistance
-
- toString() - Method in class org.apache.lucene.search.spell.NGramDistance
-
- toString(String) - Method in class org.apache.lucene.search.suggest.document.CompletionQuery
-
- toString(String) - Method in class org.apache.lucene.search.suggest.document.ContextQuery
-
- toString(String) - Method in class org.apache.lucene.search.suggest.document.FuzzyCompletionQuery
-
- toString() - Method in class org.apache.lucene.search.suggest.document.TopSuggestDocs.SuggestScoreDoc
-
- toString() - Method in class org.apache.lucene.search.suggest.fst.FSTCompletion.Completion
-
- toString() - Method in class org.apache.lucene.search.suggest.Lookup.LookupResult
-
- toString(String) - Method in class org.apache.lucene.search.SynonymQuery
-
- toString(String) - Method in class org.apache.lucene.search.TermAutomatonQuery
-
- toString(String) - Method in class org.apache.lucene.search.TermInSetQuery
-
- toString(String) - Method in class org.apache.lucene.search.TermQuery
-
Prints a user-readable version of this query.
- toString(String) - Method in class org.apache.lucene.search.TermRangeQuery
-
Prints a user-readable version of this query.
- toString() - Method in class org.apache.lucene.search.uhighlight.LengthGoalBreakIterator
-
- toString() - Method in class org.apache.lucene.search.uhighlight.OffsetsEnum
-
- toString() - Method in class org.apache.lucene.search.uhighlight.Passage
-
For debugging.
- toString() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo.SubInfo
-
- toString() - Method in class org.apache.lucene.search.vectorhighlight.FieldFragList.WeightedFragInfo
-
- toString() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo.Toffs
-
- toString() - Method in class org.apache.lucene.search.vectorhighlight.FieldPhraseList.WeightedPhraseInfo
-
- toString() - Method in class org.apache.lucene.search.vectorhighlight.FieldTermStack.TermInfo
-
- toString(String) - Method in class org.apache.lucene.search.WildcardQuery
-
Prints a user-readable version of this query.
- toString() - Method in class org.apache.lucene.spatial.bbox.BBoxSimilarityValueSource
-
- toString(String) - Method in class org.apache.lucene.spatial.composite.CompositeVerifyQuery
-
- toString(String) - Method in class org.apache.lucene.spatial.composite.IntersectsRPTVerifyQuery
-
- toString(String) - Method in class org.apache.lucene.spatial.prefix.ContainsPrefixTreeQuery
-
- toString() - Method in class org.apache.lucene.spatial.prefix.HeatmapFacetCounter.Heatmap
-
- toString(String) - Method in class org.apache.lucene.spatial.prefix.IntersectsPrefixTreeQuery
-
- toString() - Method in class org.apache.lucene.spatial.prefix.NumberRangePrefixTreeStrategy.Facets
-
- toString() - Method in class org.apache.lucene.spatial.prefix.RecursivePrefixTreeStrategy
-
- toString(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
- toString(Calendar) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Calendar utility method consistent with DateTimeFormatter.ISO_INSTANT
except
has no trailing 'Z', and will be truncated to the units given according to
Calendar.isSet(int)
.
- toString() - Method in class org.apache.lucene.spatial.prefix.tree.LegacyCell
-
- toString() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
- toString() - Method in interface org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRShape
-
- toString() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.SpanUnitsNRShape
-
- toString(NumberRangePrefixTree.UnitNRShape) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- toString() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- toString() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree.PackedQuadCell
-
Used for debugging, this will print the bits of the cell
- toString() - Method in class org.apache.lucene.spatial.prefix.tree.PackedQuadPrefixTree
-
- toString() - Method in class org.apache.lucene.spatial.prefix.tree.SpatialPrefixTree
-
- toString(String) - Method in class org.apache.lucene.spatial.prefix.WithinPrefixTreeQuery
-
- toString() - Method in class org.apache.lucene.spatial.query.SpatialArgs
-
- toString() - Method in class org.apache.lucene.spatial.query.SpatialOperation
-
- toString() - Method in class org.apache.lucene.spatial.spatial4j.Geo3dShape
-
- toString() - Method in class org.apache.lucene.spatial.SpatialStrategy
-
- toString() - Method in class org.apache.lucene.spatial.util.CachingDoubleValueSource
-
- toString() - Method in class org.apache.lucene.spatial.util.DistanceToShapeValueSource
-
- toString() - Method in class org.apache.lucene.spatial.util.ReciprocalDoubleValuesSource
-
- toString() - Method in class org.apache.lucene.spatial.util.ShapeAreaValueSource
-
- toString() - Method in class org.apache.lucene.spatial.util.ShapeFieldCacheDistanceValueSource
-
- toString() - Method in class org.apache.lucene.spatial.util.ShapeValuesPredicate
-
- toString() - Method in class org.apache.lucene.spatial.vector.DistanceValueSource
-
Returns the ValueSource description.
- toString() - Method in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
- toString() - Method in class org.apache.lucene.spatial3d.Geo3DPoint
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.GeoCompositeAreaShape
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.GeoCompositeMembershipShape
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.GeoCompositePolygon
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.GeoDegenerateVerticalLine
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.GeoPoint
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.Plane
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.PlanetModel
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.SidedPlane
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.Vector
-
- toString() - Method in class org.apache.lucene.spatial3d.geom.XYZBounds
-
- toString() - Method in class org.apache.lucene.store.BaseDirectory
-
- toString() - Method in class org.apache.lucene.store.ByteBuffersDataInput
-
- toString() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
- toString() - Method in class org.apache.lucene.store.CorruptingIndexOutput
-
- toString() - Method in class org.apache.lucene.store.Directory
-
- toString() - Method in class org.apache.lucene.store.FilterDirectory
-
- toString() - Method in class org.apache.lucene.store.FlushInfo
-
- toString() - Method in class org.apache.lucene.store.FSDirectory
-
- toString() - Method in class org.apache.lucene.store.IndexInput
-
- toString() - Method in class org.apache.lucene.store.IndexOutput
-
- toString() - Method in class org.apache.lucene.store.IOContext
-
- toString() - Method in class org.apache.lucene.store.MergeInfo
-
- toString() - Method in class org.apache.lucene.store.MockDirectoryWrapper
-
- toString() - Method in class org.apache.lucene.store.MockIndexInputWrapper
-
- toString() - Method in class org.apache.lucene.store.MockIndexOutputWrapper
-
- toString() - Method in class org.apache.lucene.store.NRTCachingDirectory
-
- toString() - Method in class org.apache.lucene.store.RAMFile
-
Deprecated.
- toString() - Method in class org.apache.lucene.store.SleepingLockWrapper
-
- toString(Accountable) - Static method in class org.apache.lucene.util.Accountables
-
Returns a String description of an Accountable and any nested resources.
- toString() - Method in class org.apache.lucene.util.AttributeSource
-
Returns a string consisting of the class's simple name, the hex representation of the identity hash code,
and the current reflection of all attributes.
- toString() - Method in class org.apache.lucene.util.automaton.RegExp
-
Constructs string from parsed regular expression.
- toString() - Method in class org.apache.lucene.util.automaton.RunAutomaton
-
Returns a string representation of this automaton.
- toString() - Method in class org.apache.lucene.util.automaton.StatePair
-
- toString() - Method in class org.apache.lucene.util.automaton.Transition
-
- toString() - Method in class org.apache.lucene.util.BitDocIdSet
-
- toString() - Method in class org.apache.lucene.util.bkd.HeapPointWriter
-
- toString() - Method in class org.apache.lucene.util.bkd.OfflinePointWriter
-
- toString() - Method in class org.apache.lucene.util.BytesRef
-
Returns hex encoded bytes, eg [0x6c 0x75 0x63 0x65 0x6e 0x65]
- toString() - Method in class org.apache.lucene.util.CharsRef
-
- toString() - Method in class org.apache.lucene.util.CharsRefBuilder
-
- toString() - Method in class org.apache.lucene.util.fst.ByteSequenceOutputs
-
- toString() - Method in class org.apache.lucene.util.fst.FST.Arc
-
- toString() - Method in class org.apache.lucene.util.fst.FST
-
- toString() - Method in class org.apache.lucene.util.fst.IntSequenceOutputs
-
- toString() - Method in class org.apache.lucene.util.fst.ListOfOutputs
-
- toString() - Method in class org.apache.lucene.util.fst.NoOutputs
-
- toString() - Method in class org.apache.lucene.util.fst.PairOutputs.Pair
-
- toString() - Method in class org.apache.lucene.util.fst.PairOutputs
-
- toString() - Method in class org.apache.lucene.util.fst.PositiveIntOutputs
-
- toString() - Method in class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
-
- toString() - Method in class org.apache.lucene.util.fst.Util.FSTPath
-
- toString() - Method in class org.apache.lucene.util.IntsRef
-
- toString() - Method in class org.apache.lucene.util.LongsRef
-
- toString() - Method in class org.apache.lucene.util.mutable.MutableValue
-
- toString() - Method in class org.apache.lucene.util.OfflineSorter.SortInfo
-
- toString() - Method in class org.apache.lucene.util.packed.AbstractPagedMutable
-
- toString() - Method in class org.apache.lucene.util.packed.BlockPackedReader
-
- toString() - Method in class org.apache.lucene.util.packed.MonotonicBlockPackedReader
-
- toString() - Method in class org.apache.lucene.util.packed.PackedInts.FormatAndBits
-
- toString() - Method in class org.apache.lucene.util.PagedBytes.Reader
-
- toString() - Method in class org.apache.lucene.util.RoaringDocIdSet
-
- toString() - Method in class org.apache.lucene.util.SparseFixedBitSet
-
- toString() - Method in class org.apache.lucene.util.Version
-
- toStringDebug() - Method in class org.apache.lucene.index.memory.MemoryIndex
-
Returns a String representation of the index data for debugging purposes.
- toStringDebug() - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree.NRCell
-
Configure your IDE to use this.
- toStringEscaped() - Method in class org.apache.lucene.queryparser.flexible.core.util.UnescapedCharSequence
-
Return a escaped String
- toStringEscaped(char[]) - Method in class org.apache.lucene.queryparser.flexible.core.util.UnescapedCharSequence
-
Return a escaped String
- toStringTree() - Method in class org.apache.lucene.util.automaton.RegExp
-
Like to string, but more verbose (shows the higherchy more clearly).
- toStringUnitRaw(NumberRangePrefixTree.UnitNRShape) - Static method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
- toStringUnquoted() - Method in class org.apache.lucene.queryparser.surround.query.SimpleTerm
-
- toStringUnquoted() - Method in class org.apache.lucene.queryparser.surround.query.SrndPrefixQuery
-
- toStringUnquoted() - Method in class org.apache.lucene.queryparser.surround.query.SrndTermQuery
-
- toStringUnquoted() - Method in class org.apache.lucene.queryparser.surround.query.SrndTruncQuery
-
- ToStringUtil - Class in org.apache.lucene.analysis.ja.util
-
Utility class for english translations of morphological data,
used only for debugging.
- ToStringUtil() - Constructor for class org.apache.lucene.analysis.ja.util.ToStringUtil
-
- ToStringUtils - Class in org.apache.lucene.util
-
Helper methods to ease implementing Object.toString()
.
- toSVG(Object...) - Static method in class org.apache.lucene.geo.GeoTestUtil
-
Returns svg of polygon for debugging.
- total - Variable in class org.apache.lucene.search.grouping.GroupFacetCollector.SegmentResult
-
- totalBinaryFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
-
Total number of binary fields
- totalBlockCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Total number of blocks.
- totalBlockOtherBytes - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Total bytes stored by the
PostingsReaderBase
,
plus the other few vInts stored in the frame.
- totalBlockStatsBytes - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Total number of bytes used to store term stats (not
including what the
PostingsReaderBase
stores.
- totalBlockSuffixBytes - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Total number of bytes used to store term suffixes.
- totalBytesSize() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Returns the total size in bytes of this merge.
- totalGroupCount - Variable in class org.apache.lucene.search.grouping.TopGroups
-
The total number of unique groups.
- totalGroupedHitCount - Variable in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- totalGroupedHitCount - Variable in class org.apache.lucene.search.grouping.TopGroups
-
Number of documents grouped into the topN groups
- totalHitCount - Variable in class org.apache.lucene.search.grouping.SecondPassGroupingCollector
-
- totalHitCount - Variable in class org.apache.lucene.search.grouping.TopGroups
-
Number of documents matching the search
- TotalHitCountCollector - Class in org.apache.lucene.search
-
Just counts the total number of hits.
- TotalHitCountCollector() - Constructor for class org.apache.lucene.search.TotalHitCountCollector
-
- totalHits - Variable in class org.apache.lucene.facet.FacetsCollector.MatchingDocs
-
Total number of hits
- totalHits - Variable in class org.apache.lucene.search.grouping.GroupDocs
-
Total hits within this group
- totalHits - Variable in class org.apache.lucene.search.TopDocs
-
The total number of hits for the query.
- totalHits - Variable in class org.apache.lucene.search.TopDocsCollector
-
The total number of documents that the collector encountered.
- totalMaxDoc - Variable in class org.apache.lucene.index.MergePolicy.OneMerge
-
Total number of documents in segments to be merged, not accounting for deletions.
- totalMaxDoc() - Method in class org.apache.lucene.index.SegmentInfos
-
Returns sum of all segment's maxDocs.
- totalMaxDoc - Variable in class org.apache.lucene.store.MergeInfo
-
- totalNumDocs() - Method in class org.apache.lucene.index.MergePolicy.OneMerge
-
Returns the total number of documents that are included with this merge.
- totalNumericFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
-
Total number of numeric fields
- totalSortedFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
-
Total number of sorted fields
- totalSortedNumericFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
-
Total number of sortednumeric fields
- totalSortedSetFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
-
Total number of sortedset fields
- totalTermBytes - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Total number of bytes (sum of term lengths) across all terms in the field.
- totalTermCount - Variable in class org.apache.lucene.codecs.blocktree.Stats
-
Total number of terms in the field.
- totalTermFreq - Variable in class org.apache.lucene.codecs.BlockTermState
-
total number of occurrences of this term
- totalTermFreq() - Method in class org.apache.lucene.codecs.blocktreeords.OrdsSegmentTermsEnum
-
- totalTermFreq() - Method in class org.apache.lucene.codecs.idversion.IDVersionSegmentTermsEnum
-
- totalTermFreq - Variable in class org.apache.lucene.codecs.TermStats
-
Total number of times this term occurs across all
documents in the field.
- totalTermFreq(Term) - Method in class org.apache.lucene.index.BaseCompositeReader
-
- totalTermFreq() - Method in class org.apache.lucene.index.FilteredTermsEnum
-
- totalTermFreq() - Method in class org.apache.lucene.index.FilterLeafReader.FilterTermsEnum
-
- totalTermFreq(Term) - Method in class org.apache.lucene.index.IndexReader
-
Returns the total number of occurrences of term
across all
documents (the sum of the freq() for each doc that has this term).
- totalTermFreq(Term) - Method in class org.apache.lucene.index.LeafReader
-
Returns the number of documents containing the term
t
.
- totalTermFreq() - Method in class org.apache.lucene.index.MultiTermsEnum
-
- totalTermFreq() - Method in class org.apache.lucene.index.TermContext
-
- totalTermFreq() - Method in class org.apache.lucene.index.TermsEnum
-
Returns the total number of occurrences of this term
across all documents (the sum of the freq() for each
doc that has this term).
- totalTermFreq - Variable in class org.apache.lucene.misc.TermStats
-
- totalTermFreq(Term) - Static method in class org.apache.lucene.queries.function.IndexReaderFunctions
-
Creates a constant value source returning the totalTermFreq for a given term
- totalTermFreq() - Method in class org.apache.lucene.search.FuzzyTermsEnum
-
- totalTermFreq - Variable in class org.apache.lucene.search.similarities.BasicStats
-
The total number of occurrences of this term across all documents.
- totalTermFreq() - Method in class org.apache.lucene.search.TermStatistics
-
returns the total number of occurrences of this term
- TotalTermFreqComparator() - Constructor for class org.apache.lucene.misc.HighFreqTerms.TotalTermFreqComparator
-
- TotalTermFreqValueSource - Class in org.apache.lucene.queries.function.valuesource
-
TotalTermFreqValueSource
returns the total term freq
(sum of term freqs across all documents).
- TotalTermFreqValueSource(String, String, String, BytesRef) - Constructor for class org.apache.lucene.queries.function.valuesource.TotalTermFreqValueSource
-
- totalTimeMS - Variable in class org.apache.lucene.util.OfflineSorter.SortInfo
-
total time spent (in milliseconds)
- totalValueFields - Variable in class org.apache.lucene.index.CheckIndex.Status.DocValuesStatus
-
Total number of docValues tested.
- totalValueFields - Variable in class org.apache.lucene.index.CheckIndex.Status.PointsStatus
-
Total number of fields with points.
- totalValuePoints - Variable in class org.apache.lucene.index.CheckIndex.Status.PointsStatus
-
Total number of values points tested.
- totBytes - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- totBytesCopied - Variable in class org.apache.lucene.replicator.nrt.CopyJob
-
- toTerm(String) - Method in class org.apache.lucene.queries.function.docvalues.DocTermsIndexDocValues
-
- totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldInfoStatus
-
Number of fields successfully tested
- totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.FieldNormStatus
-
Number of fields successfully tested
- totFields - Variable in class org.apache.lucene.index.CheckIndex.Status.StoredFieldStatus
-
Total number of stored fields tested.
- totFreq - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
-
Total frequency across all terms.
- totLoseDocCount - Variable in class org.apache.lucene.index.CheckIndex.Status
-
How many documents will be lost to bad segments.
- TOTMEM - Static variable in class org.apache.lucene.benchmark.byTask.tasks.ReportTask
-
- totPos - Variable in class org.apache.lucene.index.CheckIndex.Status.TermIndexStatus
-
Total number of positions.
- totVectors - Variable in class org.apache.lucene.index.CheckIndex.Status.TermVectorStatus
-
Total number of term vectors tested.
- toUnitShape(Object) - Method in class org.apache.lucene.spatial.prefix.tree.DateRangePrefixTree
-
Converts value
from a Calendar
or Date
to a Shape
.
- toUnitShape(Object) - Method in class org.apache.lucene.spatial.prefix.tree.NumberRangePrefixTree
-
Converts the value to a unit shape.
- toUpperCase(char[], int, int) - Static method in class org.apache.lucene.analysis.CharacterUtils
-
Converts each unicode codepoint to UpperCase via Character.toUpperCase(int)
starting
at the given offset.
- toUri() - Method in class org.apache.lucene.mockfile.FilterPath
-
- toUTF16() - Method in interface org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttribute
-
Returns the term represented as UTF-16
- toUTF16() - Method in class org.apache.lucene.analysis.miscellaneous.ConcatenateGraphFilter.BytesRefBuilderTermAttributeImpl
-
- toUTF16(CharSequence, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
-
Just maps each UTF16 unit (char) to the ints in an
IntsRef.
- toUTF32(CharSequence, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
-
Decodes the Unicode codepoints from the provided
CharSequence and places them in the provided scratch
IntsRef, which must not be null, returning it.
- toUTF32(char[], int, int, IntsRefBuilder) - Static method in class org.apache.lucene.util.fst.Util
-
Decodes the Unicode codepoints from the provided
char[] and places them in the provided scratch
IntsRef, which must not be null, returning it.
- toWriteableBufferList() - Method in class org.apache.lucene.store.ByteBuffersDataOutput
-
Returns a list of writeable blocks over the (source) content buffers.
- TrackingDirectoryWrapper - Class in org.apache.lucene.store
-
A delegating Directory that records which files were
written to and deleted.
- TrackingDirectoryWrapper(Directory) - Constructor for class org.apache.lucene.store.TrackingDirectoryWrapper
-
- transferAndCancel(CopyJob) - Method in class org.apache.lucene.replicator.nrt.CopyJob
-
Transfers whatever tmp files were already copied in this previous job and cancels the previous job
- transferFrom(ReadableByteChannel, long, long) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- transferTo(long, long, WritableByteChannel) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- Transition - Class in org.apache.lucene.util.automaton
-
- Transition() - Constructor for class org.apache.lucene.util.automaton.Transition
-
Sole constructor.
- translate(double, double, double) - Method in class org.apache.lucene.spatial3d.geom.Vector
-
Translate vector.
- traversalSize() - Method in class org.apache.lucene.benchmark.byTask.tasks.ReadTask
-
Specify the number of hits to traverse.
- traversalSize - Variable in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
-
- traversalSize() - Method in class org.apache.lucene.benchmark.byTask.tasks.SearchTravTask
-
- Trec1MQReader - Class in org.apache.lucene.benchmark.quality.trec
-
Read topics of TREC 1MQ track.
- Trec1MQReader(String) - Constructor for class org.apache.lucene.benchmark.quality.trec.Trec1MQReader
-
Constructor for Trec's 1MQ TopicsReader
- TrecContentSource - Class in org.apache.lucene.benchmark.byTask.feeds
-
- TrecContentSource() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecContentSource
-
- TrecDocParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Parser for trec doc content, invoked on doc text excluding <DOC> and <DOCNO>
which are handled in TrecContentSource.
- TrecDocParser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecDocParser
-
- TrecDocParser.ParsePathType - Enum in org.apache.lucene.benchmark.byTask.feeds
-
Types of trec parse paths,
- TrecFBISParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Parser for the FBIS docs in trec disks 4+5 collection format
- TrecFBISParser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecFBISParser
-
- TrecFR94Parser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Parser for the FR94 docs in trec disks 4+5 collection format
- TrecFR94Parser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecFR94Parser
-
- TrecFTParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Parser for the FT docs in trec disks 4+5 collection format
- TrecFTParser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecFTParser
-
- TrecGov2Parser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Parser for the GOV2 collection format
- TrecGov2Parser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecGov2Parser
-
- TrecJudge - Class in org.apache.lucene.benchmark.quality.trec
-
Judge if given document is relevant to given quality query, based on Trec format for judgements.
- TrecJudge(BufferedReader) - Constructor for class org.apache.lucene.benchmark.quality.trec.TrecJudge
-
Constructor from a reader.
- TrecLATimesParser - Class in org.apache.lucene.benchmark.byTask.feeds
-
Parser for the FT docs in trec disks 4+5 collection format
- TrecLATimesParser() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecLATimesParser
-
- TrecParserByPath - Class in org.apache.lucene.benchmark.byTask.feeds
-
Parser for trec docs which selects the parser to apply according
to the source files path, defaulting to
TrecGov2Parser
.
- TrecParserByPath() - Constructor for class org.apache.lucene.benchmark.byTask.feeds.TrecParserByPath
-
- TrecTopicsReader - Class in org.apache.lucene.benchmark.quality.trec
-
Read TREC topics.
- TrecTopicsReader() - Constructor for class org.apache.lucene.benchmark.quality.trec.TrecTopicsReader
-
Constructor for Trec's TopicsReader
- tree - Variable in class org.apache.lucene.geo.EdgeTree
-
root node of edge tree
- Triangle(Tessellator.Node, Tessellator.Node, Tessellator.Node) - Constructor for class org.apache.lucene.geo.Tessellator.Triangle
-
- Trie - Class in org.egothor.stemmer
-
A Trie is used to store a dictionary of words and their stems.
- Trie(DataInput) - Constructor for class org.egothor.stemmer.Trie
-
Constructor for the Trie object.
- Trie(boolean) - Constructor for class org.egothor.stemmer.Trie
-
Constructor for the Trie object.
- Trie(boolean, int, List<CharSequence>, List<Row>) - Constructor for class org.egothor.stemmer.Trie
-
Constructor for the Trie object.
- TrimFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Trims leading and trailing whitespace from Tokens in the stream.
- TrimFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.TrimFilter
-
- TrimFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- TrimFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.TrimFilterFactory
-
Creates a new TrimFilterFactory
- trimToSize() - Method in class org.apache.lucene.analysis.compound.hyphenation.ByteVector
-
- trimToSize() - Method in class org.apache.lucene.analysis.compound.hyphenation.CharVector
-
- trimToSize() - Method in class org.apache.lucene.analysis.compound.hyphenation.TernaryTree
-
Each node stores a character (splitchar) which is part of some key(s).
- truncate(long) - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- truncate(long) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- truncate(long) - Method in class org.apache.lucene.mockfile.FilterSeekableByteChannel
-
- truncatedToPrefixAndPattern() - Method in class org.apache.lucene.queryparser.surround.query.SrndTruncQuery
-
- TruncateTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
-
A token filter for truncating the terms into a specific length.
- TruncateTokenFilter(TokenStream, int) - Constructor for class org.apache.lucene.analysis.miscellaneous.TruncateTokenFilter
-
- TruncateTokenFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- TruncateTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.TruncateTokenFilterFactory
-
- TRUNCQUOTED - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- TRUNCTERM - Static variable in interface org.apache.lucene.queryparser.surround.parser.QueryParserConstants
-
RegularExpression Id.
- tryDeleteDocument(IndexReader, int) - Method in class org.apache.lucene.index.IndexWriter
-
- tryIncRef(SearcherTaxonomyManager.SearcherAndTaxonomy) - Method in class org.apache.lucene.facet.taxonomy.SearcherTaxonomyManager
-
- tryIncRef() - Method in class org.apache.lucene.facet.taxonomy.TaxonomyReader
-
Expert: increments the refCount of this TaxonomyReader
instance only if it has not been closed yet.
- tryIncRef() - Method in class org.apache.lucene.index.IndexReader
-
Expert: increments the refCount of this IndexReader
instance only if the IndexReader has not been closed yet
and returns true
iff the refCount was
successfully incremented, otherwise false
.
- tryIncRef(DirectoryReader) - Method in class org.apache.lucene.index.ReaderManager
-
- tryIncRef(G) - Method in class org.apache.lucene.search.ReferenceManager
-
Try to increment reference counting on the given reference.
- tryIncRef(IndexSearcher) - Method in class org.apache.lucene.search.SearcherManager
-
- tryLock(long, long, boolean) - Method in class org.apache.lucene.mockfile.FilterAsynchronousFileChannel
-
- tryLock(long, long, boolean) - Method in class org.apache.lucene.mockfile.FilterFileChannel
-
- tryUpdateDocValue(IndexReader, int, Field...) - Method in class org.apache.lucene.index.IndexWriter
-
- TSTAutocomplete - Class in org.apache.lucene.search.suggest.tst
-
Ternary Search Trie implementation.
- TSTLookup - Class in org.apache.lucene.search.suggest.tst
-
- TSTLookup() - Constructor for class org.apache.lucene.search.suggest.tst.TSTLookup
-
Creates a new TSTLookup with an empty Ternary Search Tree.
- TSTLookup(Directory, String) - Constructor for class org.apache.lucene.search.suggest.tst.TSTLookup
-
Creates a new TSTLookup, for building.
- TSTNode(char, JaspellTernarySearchTrie.TSTNode) - Constructor for class org.apache.lucene.search.suggest.jaspell.JaspellTernarySearchTrie.TSTNode
-
Deprecated.
Constructor method.
- TurkishAnalyzer - Class in org.apache.lucene.analysis.tr
-
- TurkishAnalyzer() - Constructor for class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
- TurkishAnalyzer(CharArraySet) - Constructor for class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
Builds an analyzer with the given stop words.
- TurkishAnalyzer(CharArraySet, CharArraySet) - Constructor for class org.apache.lucene.analysis.tr.TurkishAnalyzer
-
Builds an analyzer with the given stop words.
- TurkishLowerCaseFilter - Class in org.apache.lucene.analysis.tr
-
Normalizes Turkish token text to lower case.
- TurkishLowerCaseFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.tr.TurkishLowerCaseFilter
-
Create a new TurkishLowerCaseFilter, that normalizes Turkish token text
to lower case.
- TurkishLowerCaseFilterFactory - Class in org.apache.lucene.analysis.tr
-
- TurkishLowerCaseFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.tr.TurkishLowerCaseFilterFactory
-
Creates a new TurkishLowerCaseFilterFactory
- TurkishStemmer - Class in org.tartarus.snowball.ext
-
This class was automatically generated by a Snowball to Java compiler
It implements the stemming algorithm defined by a snowball script.
- TurkishStemmer() - Constructor for class org.tartarus.snowball.ext.TurkishStemmer
-
- TwoLongs(long, long) - Constructor for class org.apache.lucene.util.fst.UpToTwoPositiveIntOutputs.TwoLongs
-
- TwoPhaseCommit - Interface in org.apache.lucene.index
-
An interface for implementations that support 2-phase commit.
- TwoPhaseCommitTool - Class in org.apache.lucene.index
-
A utility for executing 2-phase commit on several objects.
- TwoPhaseCommitTool.CommitFailException - Exception in org.apache.lucene.index
-
- TwoPhaseCommitTool.PrepareCommitFailException - Exception in org.apache.lucene.index
-
- twoPhaseIterator() - Method in class org.apache.lucene.queries.function.ValueSourceScorer
-
- twoPhaseIterator() - Method in class org.apache.lucene.search.AssertingScorer
-
- twoPhaseIterator() - Method in class org.apache.lucene.search.ConstantScoreScorer
-
- twoPhaseIterator() - Method in class org.apache.lucene.search.FilterScorer
-
- twoPhaseIterator() - Method in class org.apache.lucene.search.Scorer
-
- twoPhaseIterator() - Method in class org.apache.lucene.search.spans.SpanScorer
-
- TwoPhaseIterator - Class in org.apache.lucene.search
-
- TwoPhaseIterator(DocIdSetIterator) - Constructor for class org.apache.lucene.search.TwoPhaseIterator
-
- twoPhaseView - Variable in class org.apache.lucene.search.DisiWrapper
-
- txt - Variable in class org.apache.lucene.analysis.compound.CompoundWordTokenFilterBase.CompoundToken
-
- type() - Method in class org.apache.lucene.analysis.tokenattributes.PackedTokenAttributeImpl
-
Returns this Token's lexical type.
- type() - Method in interface org.apache.lucene.analysis.tokenattributes.TypeAttribute
-
Returns this Token's lexical type.
- type() - Method in class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-
- TYPE - Static variable in class org.apache.lucene.document.BinaryDocValuesField
-
Type for straight bytes DocValues.
- type - Variable in class org.apache.lucene.document.Field
-
Field's type
- TYPE - Static variable in class org.apache.lucene.document.LatLonDocValuesField
-
Type for a LatLonDocValuesField
- TYPE - Static variable in class org.apache.lucene.document.LatLonPoint
-
Type for an indexed LatLonPoint
- TYPE - Static variable in class org.apache.lucene.document.LatLonShape
-
- TYPE - Static variable in class org.apache.lucene.document.NumericDocValuesField
-
Type for numeric DocValues.
- TYPE - Static variable in class org.apache.lucene.document.SortedDocValuesField
-
Type for sorted bytes DocValues
- TYPE - Static variable in class org.apache.lucene.document.SortedNumericDocValuesField
-
Type for sorted numeric DocValues.
- TYPE - Static variable in class org.apache.lucene.document.SortedSetDocValuesField
-
Type for sorted bytes DocValues
- TYPE - Static variable in class org.apache.lucene.document.StoredField
-
Type for a stored-only field.
- type - Variable in class org.apache.lucene.expressions.js.VariableContext
-
The type of this piece of a variable.
- TYPE - Static variable in class org.apache.lucene.facet.FacetField
-
Field type used for storing facet values: docs, freqs, and positions.
- TYPE - Static variable in class org.apache.lucene.facet.sortedset.SortedSetDocValuesFacetField
-
- TYPE - Static variable in class org.apache.lucene.facet.taxonomy.AssociationFacetField
-
- type() - Method in class org.apache.lucene.mockfile.FilterFileStore
-
- type - Variable in class org.apache.lucene.search.suggest.document.CompletionsTermsReader
-
type of suggester (context-enabled or not)
- type() - Method in class org.apache.lucene.search.suggest.document.ContextSuggestField
-
- type() - Method in class org.apache.lucene.search.suggest.document.SuggestField
-
Returns a byte to denote the type of the field
- TYPE - Static variable in class org.apache.lucene.spatial3d.Geo3DDocValuesField
-
Type for a Geo3DDocValuesField
- TYPE - Static variable in class org.apache.lucene.spatial3d.Geo3DPoint
-
- type - Variable in class org.apache.lucene.util.automaton.CompiledAutomaton
-
If simplify is true this will be the "simplified" type; else, this is NORMAL
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.StringField
-
Indexed, not tokenized, omits norms, indexes
DOCS_ONLY, not stored.
- TYPE_NOT_STORED - Static variable in class org.apache.lucene.document.TextField
-
Indexed, tokenized, not stored.
- TYPE_STORED - Static variable in class org.apache.lucene.document.StringField
-
Indexed, not tokenized, omits norms, indexes
DOCS_ONLY, stored
- TYPE_STORED - Static variable in class org.apache.lucene.document.TextField
-
Indexed, tokenized, stored.
- TYPE_SYNONYM - Static variable in class org.apache.lucene.analysis.synonym.SynonymFilter
-
Deprecated.
- TYPE_SYNONYM - Static variable in class org.apache.lucene.analysis.synonym.SynonymGraphFilter
-
- TypeAsPayloadTokenFilter - Class in org.apache.lucene.analysis.payloads
-
- TypeAsPayloadTokenFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.payloads.TypeAsPayloadTokenFilter
-
- TypeAsPayloadTokenFilterFactory - Class in org.apache.lucene.analysis.payloads
-
- TypeAsPayloadTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.payloads.TypeAsPayloadTokenFilterFactory
-
Creates a new TypeAsPayloadTokenFilterFactory
- TypeAsSynonymFilter - Class in org.apache.lucene.analysis.miscellaneous
-
- TypeAsSynonymFilter(TokenStream) - Constructor for class org.apache.lucene.analysis.miscellaneous.TypeAsSynonymFilter
-
- TypeAsSynonymFilter(TokenStream, String) - Constructor for class org.apache.lucene.analysis.miscellaneous.TypeAsSynonymFilter
-
- TypeAsSynonymFilterFactory - Class in org.apache.lucene.analysis.miscellaneous
-
- TypeAsSynonymFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.miscellaneous.TypeAsSynonymFilterFactory
-
- TypeAttribute - Interface in org.apache.lucene.analysis.tokenattributes
-
A Token's lexical type.
- TypeAttributeImpl - Class in org.apache.lucene.analysis.tokenattributes
-
- TypeAttributeImpl() - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-
- TypeAttributeImpl(String) - Constructor for class org.apache.lucene.analysis.tokenattributes.TypeAttributeImpl
-
Initialize this attribute with type
- typename() - Method in enum org.apache.lucene.geo.SimpleWKTShapeParser.ShapeType
-
- TYPES - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterFilterFactory
-
Deprecated.
- TYPES - Static variable in class org.apache.lucene.analysis.miscellaneous.WordDelimiterGraphFilterFactory
-
- TypeTokenFilter - Class in org.apache.lucene.analysis.core
-
Removes tokens whose types appear in a set of blocked types from a token stream.
- TypeTokenFilter(TokenStream, Set<String>, boolean) - Constructor for class org.apache.lucene.analysis.core.TypeTokenFilter
-
- TypeTokenFilter(TokenStream, Set<String>) - Constructor for class org.apache.lucene.analysis.core.TypeTokenFilter
-
- TypeTokenFilterFactory - Class in org.apache.lucene.analysis.core
-
- TypeTokenFilterFactory(Map<String, String>) - Constructor for class org.apache.lucene.analysis.core.TypeTokenFilterFactory
-
Creates a new TypeTokenFilterFactory